- 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
-
- AbstractBuilder() - Constructor for class com.hazelcast.internal.serialization.impl.SerializationServiceV1.AbstractBuilder
-
- AbstractCacheConfig<K,V> - Class in com.hazelcast.config
-
- 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(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
-
- AbstractContainerCollector(NodeEngine) - Constructor for class com.hazelcast.spi.impl.merge.AbstractContainerCollector
-
- AbstractContainerCollector.EmptyIterator - Class in com.hazelcast.spi.impl.merge
-
- AbstractContainerMerger<C,V,T extends MergingValue<V>> - Class in com.hazelcast.spi.impl.merge
-
- 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
-
- 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
-
- AbstractEntryProcessor() - Constructor for class com.hazelcast.map.AbstractEntryProcessor
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- AbstractSerializationService.Builder<T extends AbstractSerializationService.Builder<T>> - Class in com.hazelcast.internal.serialization.impl
-
- AbstractSplitBrainHandlerService<Store> - Class in com.hazelcast.spi.impl.merge
-
Collects mergeable stores and passes them to merge-runnable.
- AbstractSplitBrainHandlerService(NodeEngine) - Constructor for class com.hazelcast.spi.impl.merge.AbstractSplitBrainHandlerService
-
- AbstractSplitBrainMergePolicy<V,T extends MergingValue<V>> - Class in com.hazelcast.spi.impl.merge
-
- 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
-
- AccumulatorHandler<T> - Interface in com.hazelcast.map.impl.querycache.accumulator
-
- AccumulatorInfo - Class in com.hazelcast.map.impl.querycache.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
-
- 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
-
- AccumulatorScannerTask(QueryCacheContext) - Constructor for class com.hazelcast.map.impl.querycache.accumulator.AccumulatorScannerTask
-
- AccumulatorSweeper - Class in com.hazelcast.map.impl.querycache.publisher
-
- 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
-
- AddAllBackupOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.AddAllBackupOperation
-
- AddAllBackupOperation(String, Map<Long, Data>) - Constructor for class com.hazelcast.collection.impl.queue.operations.AddAllBackupOperation
-
- AddAllBackupOperation - Class in com.hazelcast.ringbuffer.impl.operations
-
- AddAllBackupOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.AddAllBackupOperation
-
- AddAllBackupOperation(String, 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
-
- 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
-
- 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
-
- addClasses(String...) - Method in class com.hazelcast.config.ClassFilter
-
- 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
-
- 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
-
- 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
-
- addEntryListener(EntryListener, boolean) - Method in interface com.hazelcast.core.IMap
-
- addEntryListener(MapListener, K, boolean) - Method in interface com.hazelcast.core.IMap
-
- addEntryListener(EntryListener, K, boolean) - Method in interface com.hazelcast.core.IMap
-
- addEntryListener(MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
-
- addEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
-
- addEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
-
- addEntryListener(EntryListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
-
- addEntryListener(EntryListener<K, V>, boolean) - Method in interface com.hazelcast.core.MultiMap
-
Adds an entry listener for this multimap.
- addEntryListener(EntryListener<K, V>, K, boolean) - Method in interface com.hazelcast.core.MultiMap
-
Adds the specified entry listener for the specified key.
- addEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.core.ReplicatedMap
-
Adds an entry listener for this map.
- addEntryListener(EntryListener<K, V>, K) - Method in interface com.hazelcast.core.ReplicatedMap
-
Adds the specified entry listener for the specified key.
- addEntryListener(EntryListener<K, V>, Predicate<K, V>) - Method in interface com.hazelcast.core.ReplicatedMap
-
Adds an continuous entry listener for this map.
- addEntryListener(EntryListener<K, V>, Predicate<K, V>, K) - Method in interface com.hazelcast.core.ReplicatedMap
-
Adds an continuous entry listener for this map.
- addEntryListener(MapListener, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addEntryListener(EntryListener, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addEntryListener(MapListener, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addEntryListener(EntryListener, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addEntryListener(EntryListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addEntryListener(MapListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addEntryListener(MapListener, boolean) - Method in 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- addLocalEntryListener(EntryListener) - Method in interface com.hazelcast.core.IMap
-
- addLocalEntryListener(MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
-
- addLocalEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
-
- addLocalEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
-
Adds a local entry listener for this map.
- addLocalEntryListener(EntryListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
-
- addLocalEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.core.MultiMap
-
Adds a local entry listener for this multimap.
- addLocalEntryListener(MapListener) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addLocalEntryListener(EntryListener) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addLocalEntryListener(MapListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addLocalEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addLocalEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addLocalEntryListener(EntryListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addLocalEntryListener(EntryListener<K, V>) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- addLocalEventListener(Object, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
-
- addLocalEventListener(Object, EventFilter, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
-
- 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
-
- addPackages(String...) - Method in class com.hazelcast.config.ClassFilter
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in interface com.hazelcast.core.IMap
-
- aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in interface com.hazelcast.core.MultiMap
-
- aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in interface com.hazelcast.core.MultiMap
-
- 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
-
- 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
-
- AggregationResultProcessor(AccumulationExecutor, SerializationService) - Constructor for class com.hazelcast.map.impl.query.AggregationResultProcessor
-
- Aggregations - Class in com.hazelcast.mapreduce.aggregation
-
- 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
PropertyExtractor
s 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
-
- AMEM_AVAILABLE - Static variable in class com.hazelcast.internal.memory.GlobalMemoryAccessorRegistry
-
- 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
-
- answerWhoisMasterQuestion(JoinMessage, Connection) - Method in class com.hazelcast.internal.cluster.impl.ClusterJoinManager
-
- 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
-
- 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 contents 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
- AuthenticationCustomCredentialsMessageTask - Class in com.hazelcast.client.impl.protocol.task
-
Custom Authentication with custom credential impl
- AuthenticationCustomCredentialsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AuthenticationCustomCredentialsMessageTask
-
- AuthenticationException - Exception in com.hazelcast.client
-
- AuthenticationException() - Constructor for exception com.hazelcast.client.AuthenticationException
-
Creates a AuthenticationException with a default message.
- AuthenticationException(String) - Constructor for exception com.hazelcast.client.AuthenticationException
-
Creates a AuthenticationException with the given message.
- 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
-
- 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
-
- CacheClearBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
-
- CacheClearBackupOperation(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
-
- CacheClearMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheClearMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheClearMessageTask
-
- CacheClearOperation - Class in com.hazelcast.cache.impl.operation
-
Cache Clear will clear all internal cache data without sending any event
- CacheClearOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheClearOperation
-
- CacheClearOperation(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheClearOperation
-
- CacheClearOperationFactory - Class in com.hazelcast.cache.impl.operation
-
- CacheClearOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
-
- CacheClearOperationFactory(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
-
- CacheClearResponse - Class in com.hazelcast.cache.impl
-
- CacheClearResponse() - Constructor for class com.hazelcast.cache.impl.CacheClearResponse
-
- CacheClearResponse(Object) - Constructor for class com.hazelcast.cache.impl.CacheClearResponse
-
- cacheConfig - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- CacheConfig<K,V> - Class in com.hazelcast.config
-
Contains all the configuration for the
ICache
.
- CacheConfig() - Constructor for class com.hazelcast.config.CacheConfig
-
- CacheConfig(String) - Constructor for class com.hazelcast.config.CacheConfig
-
- CacheConfig(CompleteConfiguration<K, V>) - Constructor for class com.hazelcast.config.CacheConfig
-
- CacheConfig(CacheSimpleConfig) - Constructor for class com.hazelcast.config.CacheConfig
-
- CacheConfigReadOnly<K,V> - Class in com.hazelcast.config
-
- CacheConfiguration<K,V> - Interface in com.hazelcast.config
-
Mutable extension to CompleteConfiguration
- CacheContainsKeyMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheContainsKeyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheContainsKeyMessageTask
-
- CacheContainsKeyOperation - Class in com.hazelcast.cache.impl.operation
-
Cache contains key operation, determines if the cache contains an entry for the specified key.
- CacheContainsKeyOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheContainsKeyOperation
-
- CacheContainsKeyOperation(String, Data) - Constructor for class com.hazelcast.cache.impl.operation.CacheContainsKeyOperation
-
- 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
-
- 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
-
- 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() - 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
-
- 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
-
- 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
-
- 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
-
- CacheEventContext - Class in com.hazelcast.cache.impl
-
- CacheEventContext() - Constructor for class com.hazelcast.cache.impl.CacheEventContext
-
- CacheEventContextUtil - Class in com.hazelcast.cache.impl
-
- CacheEventData - Interface in com.hazelcast.cache.impl
-
Internal event data wrapper used during publishing and dispatching events.
- CacheEventDataImpl - Class in com.hazelcast.cache.impl
-
- CacheEventDataImpl() - Constructor for class com.hazelcast.cache.impl.CacheEventDataImpl
-
- CacheEventDataImpl(String, CacheEventType, Data, Data, Data, boolean) - Constructor for class com.hazelcast.cache.impl.CacheEventDataImpl
-
- cacheEventHandler - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-
- 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
-
- 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
-
- CacheEvictionConfigReadOnly(EvictionConfig) - Constructor for class com.hazelcast.config.CacheEvictionConfigReadOnly
-
Deprecated.
- CacheEvictionPolicyComparator<K,V> - Class in com.hazelcast.cache
-
- 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
-
- CacheGetAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheGetAllMessageTask
-
- CacheGetAllOperation - Class in com.hazelcast.cache.impl.operation
-
Gets all keys from the cache.
- CacheGetAllOperation(String, Set<Data>, ExpiryPolicy) - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAllOperation
-
- CacheGetAllOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAllOperation
-
- CacheGetAllOperationFactory - Class in com.hazelcast.cache.impl.operation
-
- CacheGetAllOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAllOperationFactory
-
- CacheGetAllOperationFactory(String, Set<Data>, ExpiryPolicy) - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAllOperationFactory
-
- CacheGetAndRemoveMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheGetAndRemoveMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndRemoveMessageTask
-
- CacheGetAndRemoveOperation - Class in com.hazelcast.cache.impl.operation
-
Cache GetAndRemove Operation.
- CacheGetAndRemoveOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
-
- CacheGetAndRemoveOperation(String, Data, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
-
- CacheGetAndReplaceMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheGetAndReplaceMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndReplaceMessageTask
-
- CacheGetAndReplaceOperation - Class in com.hazelcast.cache.impl.operation
-
Cache GetAndReplace Operation.
- CacheGetAndReplaceOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
-
- CacheGetAndReplaceOperation(String, Data, Data, ExpiryPolicy, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
-
- CacheGetConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheGetConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheGetConfigMessageTask
-
- CacheGetConfigOperation - Class in com.hazelcast.cache.impl.operation
-
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
-
- 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
-
- 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
-
- CacheIterateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheIterateMessageTask
-
- CacheKeyIterationResult - Class in com.hazelcast.cache.impl
-
- 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
-
- 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
-
- 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
-
- CacheLoadAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheLoadAllMessageTask
-
- CacheLoadAllOperation - Class in com.hazelcast.cache.impl.operation
-
- CacheLoadAllOperation(String, Set<Data>, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-
- CacheLoadAllOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-
- CacheLoadAllOperationFactory - Class in com.hazelcast.cache.impl.operation
-
- CacheLoadAllOperationFactory(String, Set<Data>, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheLoadAllOperationFactory
-
- CacheLoadAllOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheLoadAllOperationFactory
-
- cacheLoader - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- cacheLoaderFactory - Variable in class com.hazelcast.config.AbstractCacheConfig
-
The Factory
for the CacheLoader
.
- CacheManagementConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheManagementConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheManagementConfigMessageTask
-
- CacheManagementConfigOperation - Class in com.hazelcast.cache.impl.operation
-
Cache ManagementConfig Operation provides enabling/disabling the functionality of management and
statistics mxbeans of the cache.
- CacheManagementConfigOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
-
- CacheManagementConfigOperation(String, boolean, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
-
- CacheManagerBeanDefinitionParser - Class in com.hazelcast.spring
-
Bean definition parser for JCache CacheManager
.
- CacheManagerBeanDefinitionParser() - Constructor for class com.hazelcast.spring.CacheManagerBeanDefinitionParser
-
- CacheMergeOperation - Class in com.hazelcast.cache.impl.operation
-
- CacheMergeOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheMergeOperation
-
- CacheMergeOperation(String, List<SplitBrainMergeTypes.CacheMergeTypes>, SplitBrainMergePolicy<Data, SplitBrainMergeTypes.CacheMergeTypes>) - Constructor for class com.hazelcast.cache.impl.operation.CacheMergeOperation
-
- CacheMergeOperationFactory - Class in com.hazelcast.cache.impl.operation
-
Inserts the merging entries for all partitions of a member via locally invoked
CacheMergeOperation
.
- CacheMergeOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheMergeOperationFactory
-
- CacheMergeOperationFactory(String, int[], List<SplitBrainMergeTypes.CacheMergeTypes>[], SplitBrainMergePolicy<Data, SplitBrainMergeTypes.CacheMergeTypes>) - Constructor for class com.hazelcast.cache.impl.operation.CacheMergeOperationFactory
-
- CacheMergePolicy - Interface in com.hazelcast.cache
-
Policy for merging cache entries after a split-brain has been healed.
- CacheMergePolicyProvider - Class in com.hazelcast.cache.impl.merge.policy
-
- CacheMergePolicyProvider(NodeEngine) - Constructor for class com.hazelcast.cache.impl.merge.policy.CacheMergePolicyProvider
-
- CacheMergingEntryImpl - Class in com.hazelcast.spi.impl.merge
-
- CacheMergingEntryImpl() - Constructor for class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
-
- CacheMergingEntryImpl(SerializationService) - Constructor for class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
-
- CacheMXBeanImpl - Class in com.hazelcast.cache.impl
-
Implementation of CacheMXBean
.
- CacheMXBeanImpl(CacheConfig) - Constructor for class com.hazelcast.cache.impl.CacheMXBeanImpl
-
- cacheNamePrefix - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- cacheNamePrefix() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
This method calculates a fixed string based on the URI and classloader using the formula:
- CacheNearCacheStateHolder - Class in com.hazelcast.cache.impl.operation
-
Holder for Near Cache metadata.
- CacheNearCacheStateHolder() - Constructor for class com.hazelcast.cache.impl.operation.CacheNearCacheStateHolder
-
- CacheNearCacheStateHolder(CacheReplicationOperation) - Constructor for class com.hazelcast.cache.impl.operation.CacheNearCacheStateHolder
-
- CacheNotExistsException - Exception in com.hazelcast.cache
-
This exception class is thrown while creating
CacheRecordStore
instances but the cache config does not exist on the node to create the instance on.
- CacheNotExistsException(String) - Constructor for exception com.hazelcast.cache.CacheNotExistsException
-
- CacheObjectRecord - Class in com.hazelcast.cache.impl.record
-
Implementation of
CacheRecord
which has an internal object format.
- CacheObjectRecord() - Constructor for class com.hazelcast.cache.impl.record.CacheObjectRecord
-
- CacheObjectRecord(Object, long, long) - Constructor for class com.hazelcast.cache.impl.record.CacheObjectRecord
-
- CacheOperationProvider - Interface in com.hazelcast.cache.impl
-
Provide InMemoryFormat specific operations for cache
- CachePartitionEventData - Class in com.hazelcast.cache.impl
-
- CachePartitionEventData() - Constructor for class com.hazelcast.cache.impl.CachePartitionEventData
-
- CachePartitionEventData(String, int, Member) - Constructor for class com.hazelcast.cache.impl.CachePartitionEventData
-
- CachePartitionIterator<K,V> - Class in com.hazelcast.cache.impl
-
- CachePartitionIterator(CacheProxy<K, V>, int, int, boolean) - Constructor for class com.hazelcast.cache.impl.CachePartitionIterator
-
- CachePartitionLostEvent - Class in com.hazelcast.cache.impl.event
-
Used to provide information about the lost partition of a cache.
- CachePartitionLostEvent(Object, Member, int, int) - Constructor for class com.hazelcast.cache.impl.event.CachePartitionLostEvent
-
- CachePartitionLostEventFilter - Class in com.hazelcast.cache.impl.event
-
Used to filter partition lost listener events
- CachePartitionLostEventFilter() - Constructor for class com.hazelcast.cache.impl.event.CachePartitionLostEventFilter
-
- CachePartitionLostListener - Interface in com.hazelcast.cache.impl.event
-
Invoked when owner and all backups of a partition are lost for a specific cache.
- CachePartitionLostListenerConfig - Class in com.hazelcast.config
-
Configuration for CachePartitionLostListener
- CachePartitionLostListenerConfig() - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfig
-
- CachePartitionLostListenerConfig(String) - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfig
-
- CachePartitionLostListenerConfig(CachePartitionLostListener) - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfig
-
- CachePartitionLostListenerConfig(CachePartitionLostListenerConfig) - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfig
-
- CachePartitionLostListenerConfigReadOnly - Class in com.hazelcast.config
-
- CachePartitionLostListenerConfigReadOnly(CachePartitionLostListenerConfig) - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfigReadOnly
-
Deprecated.
- CachePartitionSegment - Class in com.hazelcast.cache.impl
-
Responsible for all cache data of a partition.
- CachePartitionSegment(AbstractCacheService, int) - Constructor for class com.hazelcast.cache.impl.CachePartitionSegment
-
- CachePermission - Class in com.hazelcast.security.permission
-
- CachePermission(String, String...) - Constructor for class com.hazelcast.security.permission.CachePermission
-
- CacheProxy<K,V> - Class in com.hazelcast.cache.impl
-
ICache implementation
- CacheProxyUtil - Class in com.hazelcast.cache.impl
-
Static util methods for
ICache implementations.
- CachePutAllBackupOperation - Class in com.hazelcast.cache.impl.operation
-
Cache PutAllBackup Operation is the backup operation used by load all operation.
- CachePutAllBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CachePutAllBackupOperation
-
- CachePutAllBackupOperation(String, Map<Data, CacheRecord>) - Constructor for class com.hazelcast.cache.impl.operation.CachePutAllBackupOperation
-
- CachePutAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CachePutAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CachePutAllMessageTask
-
- CachePutAllOperation - Class in com.hazelcast.cache.impl.operation
-
- CachePutAllOperation() - Constructor for class com.hazelcast.cache.impl.operation.CachePutAllOperation
-
- CachePutAllOperation(String, List<Map.Entry<Data, Data>>, ExpiryPolicy, int) - Constructor for class com.hazelcast.cache.impl.operation.CachePutAllOperation
-
- CachePutBackupOperation - Class in com.hazelcast.cache.impl.operation
-
Backup operation for the operation of adding cache entries into record stores.
- CachePutBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CachePutBackupOperation
-
- CachePutBackupOperation(String, Data, CacheRecord) - Constructor for class com.hazelcast.cache.impl.operation.CachePutBackupOperation
-
- CachePutBackupOperation(String, Data, CacheRecord, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CachePutBackupOperation
-
- CachePutIfAbsentMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CachePutIfAbsentMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CachePutIfAbsentMessageTask
-
- CachePutIfAbsentOperation - Class in com.hazelcast.cache.impl.operation
-
- CachePutIfAbsentOperation() - Constructor for class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
-
- CachePutIfAbsentOperation(String, Data, Data, ExpiryPolicy, int) - Constructor for class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
-
- CachePutMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CachePutMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CachePutMessageTask
-
- CachePutOperation - Class in com.hazelcast.cache.impl.operation
-
- CachePutOperation() - Constructor for class com.hazelcast.cache.impl.operation.CachePutOperation
-
- CachePutOperation(String, Data, Data, ExpiryPolicy, boolean, int) - Constructor for class com.hazelcast.cache.impl.operation.CachePutOperation
-
- CacheRecord<V> - Interface in com.hazelcast.cache.impl.record
-
An expirable and evictable data object which represents a cache entry.
- cacheRecordFactory - Variable in class com.hazelcast.cache.impl.CacheRecordStore
-
- CacheRecordFactory<R extends CacheRecord> - Class in com.hazelcast.cache.impl.record
-
- CacheRecordFactory(InMemoryFormat, SerializationService) - Constructor for class com.hazelcast.cache.impl.record.CacheRecordFactory
-
- CacheRecordHashMap - Class in com.hazelcast.cache.impl.record
-
- CacheRecordHashMap(SerializationService, int, CacheContext) - Constructor for class com.hazelcast.cache.impl.record.CacheRecordHashMap
-
- CacheRecordMap<K extends Data,V extends CacheRecord> - Interface in com.hazelcast.cache.impl.record
-
- cacheRecordStore - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-
- CacheRecordStore - Class in com.hazelcast.cache.impl
-
- CacheRecordStore(String, int, NodeEngine, AbstractCacheService) - Constructor for class com.hazelcast.cache.impl.CacheRecordStore
-
- CacheRemoveAllBackupOperation - Class in com.hazelcast.cache.impl.operation
-
- CacheRemoveAllBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
-
- CacheRemoveAllBackupOperation(String, Set<Data>) - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
-
- CacheRemoveAllKeysMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheRemoveAllKeysMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllKeysMessageTask
-
- CacheRemoveAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheRemoveAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllMessageTask
-
- CacheRemoveAllOperation - Class in com.hazelcast.cache.impl.operation
-
TODO add a proper JavaDoc
- CacheRemoveAllOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
-
- CacheRemoveAllOperation(String, Set<Data>, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
-
- CacheRemoveAllOperationFactory - Class in com.hazelcast.cache.impl.operation
-
- CacheRemoveAllOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveAllOperationFactory
-
- CacheRemoveAllOperationFactory(String, Set<Data>, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveAllOperationFactory
-
- CacheRemoveBackupOperation - Class in com.hazelcast.cache.impl.operation
-
Backup operation used by remove operations.
- CacheRemoveBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
-
- CacheRemoveBackupOperation(String, Data) - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
-
- CacheRemoveBackupOperation(String, Data, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
-
- CacheRemoveEntryListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
Client request which unregisters the event listener on behalf of the client.
- CacheRemoveEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveEntryListenerMessageTask
-
- CacheRemoveInvalidationListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
Client request which unregisters the invalidation listener on behalf of the client.
- CacheRemoveInvalidationListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
-
- CacheRemoveMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheRemoveMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveMessageTask
-
- CacheRemoveOperation - Class in com.hazelcast.cache.impl.operation
-
Operation implementation for cache remove functionality.
- CacheRemoveOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveOperation
-
- CacheRemoveOperation(String, Data, Data, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveOperation
-
- CacheRemovePartitionLostListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheRemovePartitionLostListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheRemovePartitionLostListenerMessageTask
-
- CacheReplaceMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheReplaceMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheReplaceMessageTask
-
- CacheReplaceOperation - Class in com.hazelcast.cache.impl.operation
-
Operator implementation for cache replace functionality.
- CacheReplaceOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheReplaceOperation
-
- CacheReplaceOperation(String, Data, Data, Data, ExpiryPolicy, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheReplaceOperation
-
- CacheReplicationOperation - Class in com.hazelcast.cache.impl.operation
-
- CacheReplicationOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheReplicationOperation
-
- cacheResourcesConstructorFunction - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-
- cacheResourcesMutexFactory - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-
- caches - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- cacheService - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- cacheService - Variable in class com.hazelcast.cache.impl.CachePartitionSegment
-
- CacheService - Class in com.hazelcast.cache.impl
-
Cache Service is the main access point of JCache implementation.
- CacheService() - Constructor for class com.hazelcast.cache.impl.CacheService
-
- cacheService - Variable in class com.hazelcast.cache.impl.operation.AbstractCacheOperation
-
- CacheSimpleConfig - Class in com.hazelcast.config
-
Simple configuration to hold parsed XML configuration.
- CacheSimpleConfig(CacheSimpleConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfig
-
- CacheSimpleConfig() - Constructor for class com.hazelcast.config.CacheSimpleConfig
-
- CacheSimpleConfig.ExpiryPolicyFactoryConfig - Class in com.hazelcast.config
-
Represents configuration for "ExpiryPolicyFactory".
- CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig - Class in com.hazelcast.config
-
Represents duration configuration with duration amount and time unit
for the "TimedExpiryPolicyFactoryConfig".
- CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig - Class in com.hazelcast.config
-
Represents configuration for time based "ExpiryPolicyFactory" with duration and time unit.
- CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType - Enum in com.hazelcast.config
-
Represents type of the "TimedExpiryPolicyFactoryConfig".
- CacheSimpleConfigReadOnly - Class in com.hazelcast.config
-
- CacheSimpleConfigReadOnly(CacheSimpleConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfigReadOnly
-
Deprecated.
- CacheSimpleEntryListenerConfig - Class in com.hazelcast.config
-
Simple configuration to hold parsed listener config.
- CacheSimpleEntryListenerConfig(CacheSimpleEntryListenerConfig) - Constructor for class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- CacheSimpleEntryListenerConfig() - Constructor for class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- CacheSimpleEntryListenerConfigReadOnly - Class in com.hazelcast.config
-
- CacheSimpleEntryListenerConfigReadOnly(CacheSimpleEntryListenerConfig) - Constructor for class com.hazelcast.config.CacheSimpleEntryListenerConfigReadOnly
-
Deprecated.
- CacheSizeMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheSizeMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheSizeMessageTask
-
- CacheSizeOperation - Class in com.hazelcast.cache.impl.operation
-
This operation implementation is for calculating the cluster size of a named cache.
- CacheSizeOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheSizeOperation
-
- CacheSizeOperation(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheSizeOperation
-
- CacheSizeOperationFactory - Class in com.hazelcast.cache.impl.operation
-
- CacheSizeOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
-
- CacheSizeOperationFactory(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
-
- CacheStatistics - Interface in com.hazelcast.cache
-
Cache statistics
- cacheStatisticsConstructorFunction - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-
- CacheStatisticsImpl - Class in com.hazelcast.cache.impl
-
- CacheStatisticsImpl(long) - Constructor for class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- CacheStatisticsImpl(long, CacheEntryCountResolver) - Constructor for class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- CacheStatisticsMXBeanImpl - Class in com.hazelcast.cache.impl
-
Implementation of CacheStatisticsMXBean
- CacheStatisticsMXBeanImpl(CacheStatisticsImpl) - Constructor for class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- CacheSyncListenerCompleter - Interface in com.hazelcast.cache.impl
-
used to state that a sync event completed and any resources waiting for it should be released
- CacheUtil - Class in com.hazelcast.cache
-
Utility class for various cache related operations to be used by our internal structure and end user.
- CacheWanEventPublisher - Interface in com.hazelcast.cache.impl.event
-
This interface provides methods to publish wan replication events
from cache operations.
- cacheWriter - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- cacheWriterFactory - Variable in class com.hazelcast.config.AbstractCacheConfig
-
The Factory
for the CacheWriter
.
- cachingProvider - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- calculateDataSize(String) - Static method in class com.hazelcast.client.impl.protocol.util.ParameterUtil
-
- calculateDataSize(Data) - Static method in class com.hazelcast.client.impl.protocol.util.ParameterUtil
-
- calculateDataSize(Map.Entry<Data, Data>) - Static method in class com.hazelcast.client.impl.protocol.util.ParameterUtil
-
- calculateDataSize(byte[]) - Static method in class com.hazelcast.client.impl.protocol.util.ParameterUtil
-
- calculateDataSize(Integer) - Static method in class com.hazelcast.client.impl.protocol.util.ParameterUtil
-
- calculateDataSize(Boolean) - Static method in class com.hazelcast.client.impl.protocol.util.ParameterUtil
-
- calculateDataSize(Long) - Static method in class com.hazelcast.client.impl.protocol.util.ParameterUtil
-
- calculateEntryCost(K, V) - Method in interface com.hazelcast.map.impl.EntryCostEstimator
-
Calculate the entry's cost in memory
- calculateExpirationWithDelay(long, long, boolean) - Static method in class com.hazelcast.map.impl.ExpirationTimeSetter
-
On backup partitions, this method delays key's expiration.
- calculateMaxIdleMillis(MapConfig) - Static method in class com.hazelcast.map.impl.ExpirationTimeSetter
-
- calculateMaxPartitionSize(int, int) - Static method in class com.hazelcast.cache.impl.maxsize.impl.EntryCountCacheEvictionChecker
-
- calculateObjectName(String, String, boolean) - Static method in class com.hazelcast.cache.impl.MXBeanUtil
-
Creates an object name using the scheme.
- calculatePartitionHash(Object, PartitioningStrategy) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-
- calculateValueCost(V) - Method in interface com.hazelcast.map.impl.EntryCostEstimator
-
Calculate the entry's value cost in memory
- calculateVersion(String) - Static method in class com.hazelcast.instance.BuildInfo
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.AbstractCallableMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMultiPartitionMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.AbstractRemoveListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.AbstractTransactionalMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.AddMembershipListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionLostListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddEntryListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddNearCacheInvalidationListenerTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddPartitionLostListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheDestroyMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.cache.Pre38CacheAddInvalidationListenerTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.ClientStatisticsMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetConfiguredReplicaCountMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.DestroyProxyMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.AbstractExecutorServiceCancelMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorIsShutdownMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorShutdownMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceIsShutdownMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceShutdownMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.GetDistributedObjectsMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.GetPartitionsMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapAddEntryListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapQueryMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddPartitionLostListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.map.MapDestroyCacheMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteWithPredicateMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFlushMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadAllMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateWithValueMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceCancelMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceJobProcessInformationMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.multimap.AbstractMultiMapAddEntryListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.PingMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicAddMessageListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAClearRemoteTransactionMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCommitMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCreateMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionPrepareMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionRollbackMessageTask
-
- call() - Method in class com.hazelcast.console.Echo
-
- call() - Method in class com.hazelcast.console.SimulateLoadTask
-
- call() - Method in class com.hazelcast.executor.impl.RunnableAdapter
-
- call() - Method in class com.hazelcast.internal.partition.operation.PromotionCommitOperation
-
- call() - Method in class com.hazelcast.map.impl.operation.EntryOperation
-
- call() - Method in class com.hazelcast.scheduledexecutor.impl.NamedTaskDecorator
-
- call() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledRunnableAdapter
-
- call(int) - Method in interface com.hazelcast.spi.impl.operationservice.impl.batching.PartitionAwareCallable
-
- call() - Method in class com.hazelcast.spi.Operation
-
Call the operation and returns the CallStatus.
- CALL_TIMEOUT_RESPONSE - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
-
- CALLABLE_TASK - Static variable in class com.hazelcast.executor.impl.ExecutorDataSerializerHook
-
- CallableTaskOperation - Class in com.hazelcast.executor.impl.operations
-
- CallableTaskOperation() - Constructor for class com.hazelcast.executor.impl.operations.CallableTaskOperation
-
- CallableTaskOperation(String, String, Data) - Constructor for class com.hazelcast.executor.impl.operations.CallableTaskOperation
-
- callAfterStoreListeners(Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindProcessor
-
- callBeforeStoreListeners(Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindProcessor
-
- caller - Variable in class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
-
- CALLER_NOT_MEMBER - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- CallerNotMemberException - Exception in com.hazelcast.spi.exception
-
A
RetryableHazelcastException
that indicates that an operation was sent by a machine which isn't member
in the cluster when the operation is executed.
- CallerNotMemberException(Address, Address, int, String, String) - Constructor for exception com.hazelcast.spi.exception.CallerNotMemberException
-
- CallerNotMemberException(String) - Constructor for exception com.hazelcast.spi.exception.CallerNotMemberException
-
- CallerRunsAccumulationExecutor - Class in com.hazelcast.map.impl.query
-
Implementation of the
AccumulationExecutor
that runs the accumulation in the calling thread in a sequential fashion.
- CallerRunsAccumulationExecutor(SerializationService) - Constructor for class com.hazelcast.map.impl.query.CallerRunsAccumulationExecutor
-
- CallerRunsPartitionScanExecutor - Class in com.hazelcast.map.impl.query
-
Implementation of the
PartitionScanExecutor
which executes the partition scan in a sequential-fashion
in the calling thread.
- CallerRunsPartitionScanExecutor(PartitionScanRunner) - Constructor for class com.hazelcast.map.impl.query.CallerRunsPartitionScanExecutor
-
- callId - Variable in class com.hazelcast.spi.impl.operationservice.impl.responses.Response
-
- CallIdFactory - Class in com.hazelcast.spi.impl.sequence
-
- CallIdSequence - Interface in com.hazelcast.spi.impl.sequence
-
Responsible for generating invocation callIds.
- CallIdSequenceWithBackpressure - Class in com.hazelcast.spi.impl.sequence
-
A
CallIdSequence
that provides backpressure by taking
the number of in-flight operations into account when before creating a new call-id.
- CallIdSequenceWithBackpressure(int, long) - Constructor for class com.hazelcast.spi.impl.sequence.CallIdSequenceWithBackpressure
-
- CallIdSequenceWithoutBackpressure - Class in com.hazelcast.spi.impl.sequence
-
- CallIdSequenceWithoutBackpressure() - Constructor for class com.hazelcast.spi.impl.sequence.CallIdSequenceWithoutBackpressure
-
- callOnAddress(Address, Operation) - Method in class com.hazelcast.internal.management.ManagementCenterService
-
- callOnMember(Member, Operation) - Method in class com.hazelcast.internal.management.ManagementCenterService
-
- callOnThis(Operation) - Method in class com.hazelcast.internal.management.ManagementCenterService
-
- CallsPerMember - Class in com.hazelcast.spi
-
Implements
LiveOperations
and additionally collects the call IDs of operations on remote members
whose cancellation was requested.
- CallsPerMember(Address) - Constructor for class com.hazelcast.spi.CallsPerMember
-
- CallStatus - Enum in com.hazelcast.spi
-
- callTimeout - Variable in class com.hazelcast.spi.InvocationBuilder
-
- CallTimeoutResponse - Class in com.hazelcast.spi.impl.operationservice.impl.responses
-
An response that indicates that the execution of a single call ran into a timeout.
- CallTimeoutResponse() - Constructor for class com.hazelcast.spi.impl.operationservice.impl.responses.CallTimeoutResponse
-
- CallTimeoutResponse(long, boolean) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.responses.CallTimeoutResponse
-
- canAcquireLock(Data, String, long) - Method in interface com.hazelcast.concurrent.lock.LockStore
-
Return if the key can be locked by the caller and thread ID.
- canAcquireLock(Data, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- canAcquireLock(Data, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
-
- canAcquireLock(Data, String, long) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- canAcquireLock(Data, String, long) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
- canAcquireLock(Data, String, long) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- CanCancelOperations - Interface in com.hazelcast.spi
-
Implemented by a service that can cancel its operations.
- cancel(boolean) - Method in class com.hazelcast.client.proxy.ClientScheduledFutureProxy
-
- cancel(boolean) - Method in class com.hazelcast.client.proxy.IExecutorDelegatingFuture
-
- cancel(boolean) - Method in class com.hazelcast.client.util.ClientDelegatingFuture
-
- cancel(String, boolean) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
-
- cancel() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- cancel() - Method in class com.hazelcast.mapreduce.impl.task.MapCombineTask
-
- cancel() - Method in class com.hazelcast.mapreduce.impl.task.MappingPhase
-
- cancel() - Method in class com.hazelcast.mapreduce.impl.task.ReducerTask
-
- cancel(boolean) - Method in class com.hazelcast.scheduledexecutor.impl.DelegatingScheduledFutureStripper
-
- cancel(String) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
-
- cancel(boolean) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledFutureProxy
-
- cancel(boolean) - Method in interface com.hazelcast.scheduledexecutor.IScheduledFuture
-
Attempts to cancel further scheduling of this task.
- cancel(boolean) - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
-
- cancel(boolean) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
-
- cancel(boolean) - Method in class com.hazelcast.util.executor.CompletedFuture
-
- cancel(boolean) - Method in class com.hazelcast.util.executor.DelegatingFuture
-
- cancel(K) - Method in interface com.hazelcast.util.scheduler.EntryTaskScheduler
-
Cancel all scheduled executions with the given key.
- cancel(K) - Method in class com.hazelcast.util.scheduler.SecondsBasedEntryTaskScheduler
-
- CANCEL_BACKUP_OP - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
-
- CANCEL_JOB_SUPERVISOR_OPERATION - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-
- CANCEL_OP - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
-
- cancelAll(String, Object, Throwable) - Method in class com.hazelcast.spi.impl.operationparker.impl.WaitSet
-
- cancelAll() - Method in interface com.hazelcast.util.scheduler.EntryTaskScheduler
-
Cancel all scheduled executions
- cancelAll() - Method in class com.hazelcast.util.scheduler.SecondsBasedEntryTaskScheduler
-
- cancelAndNotify(Exception) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- cancelEviction(String) - Method in class com.hazelcast.collection.impl.queue.QueueService
-
- cancelEvictionIfExists() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-
- cancelExecution() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-
- cancelIfExists(K, V) - Method in interface com.hazelcast.util.scheduler.EntryTaskScheduler
-
Cancels the scheduled executions for the given key and value if present.
- cancelIfExists(K, V) - Method in class com.hazelcast.util.scheduler.SecondsBasedEntryTaskScheduler
-
- CancelJobSupervisorOperation - Class in com.hazelcast.mapreduce.impl.operation
-
This operation is fired by the jobs owner node to remotely cancel the defined jobId on all nodes.
- CancelJobSupervisorOperation() - Constructor for class com.hazelcast.mapreduce.impl.operation.CancelJobSupervisorOperation
-
- CancelJobSupervisorOperation(String, String) - Constructor for class com.hazelcast.mapreduce.impl.operation.CancelJobSupervisorOperation
-
- CANCELLATION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- CANCELLATION - Static variable in class com.hazelcast.executor.impl.ExecutorDataSerializerHook
-
- CancellationOperation - Class in com.hazelcast.executor.impl.operations
-
- CancellationOperation() - Constructor for class com.hazelcast.executor.impl.operations.CancellationOperation
-
- CancellationOperation(String, boolean) - Constructor for class com.hazelcast.executor.impl.operations.CancellationOperation
-
- cancelled(boolean) - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
-
Protected method invoked when this task transitions to state
isCancelled
.
- cancelled(boolean) - Method in class com.hazelcast.util.executor.CompletableFutureTask
-
- cancelOperation(Address, long) - Method in interface com.hazelcast.spi.CanCancelOperations
-
Notifies this service that an operation was requested to be cancelled.
- cancelParkedOperations(String, Object, Throwable) - Method in class com.hazelcast.spi.impl.operationparker.impl.OperationParkerImpl
-
- cancelParkedOperations(String, Object, Throwable) - Method in interface com.hazelcast.spi.impl.operationparker.OperationParker
-
- cancelPartitionState() - Method in class com.hazelcast.mapreduce.impl.task.JobProcessInformationImpl
-
- CancelTaskBackupOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
-
- CancelTaskBackupOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.CancelTaskBackupOperation
-
- CancelTaskBackupOperation(String, String) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.CancelTaskBackupOperation
-
- CancelTaskOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
-
- CancelTaskOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.CancelTaskOperation
-
- CancelTaskOperation(ScheduledTaskHandler, boolean) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.CancelTaskOperation
-
- cancelTtlEntry(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-
- cancelTtlEntry(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- canEvictRecord(Record, ExpiredKey) - Method in class com.hazelcast.map.impl.operation.EvictBatchBackupOperation
-
- canPrimaryDriveExpiration() - Method in class com.hazelcast.map.impl.eviction.ExpirationManager
-
- canSendInvalidation(Invalidation) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.AbstractBaseNearCacheInvalidationListener
-
- canThisOpGenerateWANEvent() - Method in class com.hazelcast.map.impl.operation.BasePutOperation
-
- canThisOpGenerateWANEvent() - Method in class com.hazelcast.map.impl.operation.LegacyMergeOperation
-
- canTransformResource(String) - Method in class com.hazelcast.buildutils.HazelcastManifestTransformer
-
- capacity() - Method in class com.hazelcast.client.impl.protocol.util.BufferBuilder
-
The current capacity of the buffer.
- capacity() - Method in interface com.hazelcast.client.impl.protocol.util.ClientProtocolBuffer
-
Get the capacity of the underlying buffer.
- capacity() - Method in class com.hazelcast.client.impl.protocol.util.SafeBuffer
-
- capacity() - Method in class com.hazelcast.client.impl.protocol.util.UnsafeBuffer
-
- capacity() - Method in class com.hazelcast.client.proxy.ClientRingbufferProxy
-
- capacity() - Method in interface com.hazelcast.internal.util.concurrent.Pipe
-
Returns the number of items this pipe can hold at a time.
- capacity() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray
-
- capacity() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
-
- capacity() - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
-
- capacity() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
-
Returns the capacity of this Ringbuffer.
- capacity() - Method in class com.hazelcast.util.collection.BiInt2ObjectMap
-
Get the total capacity for the map to which the load factor with be a fraction of.
- capacity() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
-
Get the total capacity for the map to which the load factor with be a fraction of.
- capacity() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
-
Get the total capacity for the map to which the load factor with be a fraction of.
- CAPACITY_OFFSET - Static variable in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
-
- CapacityUtil - Class in com.hazelcast.internal.util.hashslot.impl
-
Utility functions related to data structure capacity calculation.
- CARDINALITY_EST_CONTAINER - Static variable in class com.hazelcast.cardinality.impl.CardinalityEstimatorDataSerializerHook
-
- CARDINALITY_ESTIMATOR_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
-
- CARDINALITY_ESTIMATOR_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- CARDINALITY_ESTIMATOR_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- CARDINALITY_ESTIMATOR_MERGING_ENTRY - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
-
- CardinalityEstimator - Interface in com.hazelcast.cardinality
-
CardinalityEstimator is a redundant and highly available distributed data-structure used
for probabilistic cardinality estimation purposes, on unique items, in significantly sized data cultures.
- CardinalityEstimatorAddMessageTask - Class in com.hazelcast.client.impl.protocol.task.cardinality
-
- CardinalityEstimatorAddMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorAddMessageTask
-
- CardinalityEstimatorBackupAwareOperation - Class in com.hazelcast.cardinality.impl.operations
-
- CardinalityEstimatorBackupAwareOperation() - Constructor for class com.hazelcast.cardinality.impl.operations.CardinalityEstimatorBackupAwareOperation
-
- CardinalityEstimatorBackupAwareOperation(String) - Constructor for class com.hazelcast.cardinality.impl.operations.CardinalityEstimatorBackupAwareOperation
-
- CardinalityEstimatorConfig - Class in com.hazelcast.config
-
- CardinalityEstimatorConfig() - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
-
- CardinalityEstimatorConfig(String) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
-
- CardinalityEstimatorConfig(String, int, int) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
-
- CardinalityEstimatorConfig(String, int, int, MergePolicyConfig) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
-
- CardinalityEstimatorConfig(String, int, int, String, MergePolicyConfig) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
-
- CardinalityEstimatorConfig(CardinalityEstimatorConfig) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
-
- CardinalityEstimatorContainer - Class in com.hazelcast.cardinality.impl
-
- CardinalityEstimatorContainer() - Constructor for class com.hazelcast.cardinality.impl.CardinalityEstimatorContainer
-
- CardinalityEstimatorContainer(int, int) - Constructor for class com.hazelcast.cardinality.impl.CardinalityEstimatorContainer
-
- CardinalityEstimatorDataSerializerHook - Class in com.hazelcast.cardinality.impl
-
- CardinalityEstimatorDataSerializerHook() - Constructor for class com.hazelcast.cardinality.impl.CardinalityEstimatorDataSerializerHook
-
- CardinalityEstimatorEstimateMessageTask - Class in com.hazelcast.client.impl.protocol.task.cardinality
-
- CardinalityEstimatorEstimateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorEstimateMessageTask
-
- CardinalityEstimatorMergingEntry - Class in com.hazelcast.spi.impl.merge
-
- CardinalityEstimatorMergingEntry() - Constructor for class com.hazelcast.spi.impl.merge.CardinalityEstimatorMergingEntry
-
- CardinalityEstimatorMergingEntry(SerializationService) - Constructor for class com.hazelcast.spi.impl.merge.CardinalityEstimatorMergingEntry
-
- CardinalityEstimatorPermission - Class in com.hazelcast.security.permission
-
- CardinalityEstimatorPermission(String, String...) - Constructor for class com.hazelcast.security.permission.CardinalityEstimatorPermission
-
- CardinalityEstimatorProxy - Class in com.hazelcast.cardinality.impl
-
- CardinalityEstimatorService - Class in com.hazelcast.cardinality.impl
-
- CardinalityEstimatorService() - Constructor for class com.hazelcast.cardinality.impl.CardinalityEstimatorService
-
- casCachedValue(Object, Object) - Method in class com.hazelcast.map.impl.record.AbstractRecord
-
- casCachedValue(Object, Object) - Method in interface com.hazelcast.map.impl.record.Record
-
Atomically sets the cached value to the given new value
if the current cached value ==
the expected value.
- casRecordState(long, long) - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
-
- casRecordState(long, long) - Method in interface com.hazelcast.internal.nearcache.NearCacheRecord
-
- casSequence(long, long) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataContainer
-
- casStaleSequence(long, long) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataContainer
-
- casUuid(UUID, UUID) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataContainer
-
- cd - Variable in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-
- CDL_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- CDL_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- CDL_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- CDL_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- ChainingFuture<T> - Class in com.hazelcast.internal.util.futures
-
- ChainingFuture(Iterator<ICompletableFuture<T>>, Executor, ChainingFuture.ExceptionHandler, ILogger) - Constructor for class com.hazelcast.internal.util.futures.ChainingFuture
-
- ChainingFuture.ExceptionHandler - Interface in com.hazelcast.internal.util.futures
-
- CHANGE_CLUSTER_STATE - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
-
- changeClusterState(ClusterState) - Method in class com.hazelcast.client.proxy.ClientClusterProxy
-
- changeClusterState(ClusterState, TransactionOptions) - Method in class com.hazelcast.client.proxy.ClientClusterProxy
-
- changeClusterState(ClusterState) - Method in interface com.hazelcast.core.Cluster
-
Changes state of the cluster to the given state transactionally.
- changeClusterState(ClusterState, TransactionOptions) - Method in interface com.hazelcast.core.Cluster
-
Changes state of the cluster to the given state transactionally.
- changeClusterState(ClusterState) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
-
- changeClusterState(ClusterState, TransactionOptions) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
-
- ChangeClusterStateRequest - Class in com.hazelcast.internal.management.request
-
Request coming from Management Center for changing the
ClusterState
- ChangeClusterStateRequest() - Constructor for class com.hazelcast.internal.management.request.ChangeClusterStateRequest
-
- ChangeClusterStateRequest(String) - Constructor for class com.hazelcast.internal.management.request.ChangeClusterStateRequest
-
- changeClusterVersion(Version) - Method in class com.hazelcast.client.proxy.ClientClusterProxy
-
- changeClusterVersion(Version, TransactionOptions) - Method in class com.hazelcast.client.proxy.ClientClusterProxy
-
- changeClusterVersion(Version) - Method in interface com.hazelcast.core.Cluster
-
Changes the cluster version transactionally.
- changeClusterVersion(Version, TransactionOptions) - Method in interface com.hazelcast.core.Cluster
-
Changes the cluster version transactionally, with the transaction options provided.
- changeClusterVersion(Version) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
-
- changeClusterVersion(Version, TransactionOptions) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
-
- changeNodeStateToActive() - Method in class com.hazelcast.instance.Node
-
- changeNodeStateToPassive() - Method in class com.hazelcast.instance.Node
-
- ChangeWanStateOperation - Class in com.hazelcast.internal.management.operation
-
- ChangeWanStateOperation(String, String, boolean) - Constructor for class com.hazelcast.internal.management.operation.ChangeWanStateOperation
-
- ChangeWanStateRequest - Class in com.hazelcast.internal.management.request
-
- ChangeWanStateRequest() - Constructor for class com.hazelcast.internal.management.request.ChangeWanStateRequest
-
- ChangeWanStateRequest(String, String, boolean) - Constructor for class com.hazelcast.internal.management.request.ChangeWanStateRequest
-
- Channel - Interface in com.hazelcast.internal.networking
-
A Channel is a construct that can send/receive like Packets/ClientMessages etc.
- channel - Variable in class com.hazelcast.internal.networking.nio.NioPipeline
-
- channelAdded(MigratablePipeline, MigratablePipeline) - Method in class com.hazelcast.internal.networking.nio.iobalancer.IOBalancer
-
- ChannelCloseListener - Interface in com.hazelcast.internal.networking
-
A listener called when a
Channel
is closed.
- ChannelErrorHandler - Interface in com.hazelcast.internal.networking
-
A strategy for controlling what needs to be done in case of an Exception
being thrown when the
EventLoopGroup
processes events.
- ChannelFactory - Interface in com.hazelcast.internal.networking
-
A factory for creating
Channel
instances.
- ChannelInboundHandler - Interface in com.hazelcast.internal.networking
-
- ChannelInboundHandlerWithCounters - Class in com.hazelcast.internal.networking.nio
-
Trigger for the ChannelReader to inject the appropriate counters.
- ChannelInboundHandlerWithCounters() - Constructor for class com.hazelcast.internal.networking.nio.ChannelInboundHandlerWithCounters
-
- ChannelInitializer - Interface in com.hazelcast.internal.networking
-
Initializes the Channel when the Channel is used for the first time.
- channelInitializer(ChannelInitializer) - Method in class com.hazelcast.internal.networking.nio.NioEventLoopGroup.Context
-
- ChannelOutboundHandler<F extends OutboundFrame> - Interface in com.hazelcast.internal.networking
-
- channelRemoved(MigratablePipeline, MigratablePipeline) - Method in class com.hazelcast.internal.networking.nio.iobalancer.IOBalancer
-
- CHAR_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
-
Deprecated.
- CHAR_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
-
Deprecated.
- CHAR_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
-
- CHAR_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
-
Char size in bytes
- CharArraySerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.CharArraySerializer
-
- CharSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.CharSerializer
-
- check(Node, String, boolean) - Method in class com.hazelcast.util.PhoneHome
-
- check2BytesAligned(long) - Static method in class com.hazelcast.internal.memory.impl.AlignmentUtil
-
- check4BytesAligned(long) - Static method in class com.hazelcast.internal.memory.impl.AlignmentUtil
-
- check8BytesAligned(long) - Static method in class com.hazelcast.internal.memory.impl.AlignmentUtil
-
- CHECK_EVICT - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-
- CHECK_REPLICA_VERSION - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
-
- checkAllDone(Collection<Future>) - Static method in class com.hazelcast.util.FutureUtil
-
Rethrow exeception of the fist future that completed with an exception
- CheckAndEvictOperation - Class in com.hazelcast.collection.impl.queue.operations
-
Provides eviction functionality for Operations of Queue.
- CheckAndEvictOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.CheckAndEvictOperation
-
- CheckAndEvictOperation(String) - Constructor for class com.hazelcast.collection.impl.queue.operations.CheckAndEvictOperation
-
- checkAssignedMembersAvailable(Collection<Address>) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- checkAssignedMembersAvailable() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- checkAsyncBackupCount(int, int) - Static method in class com.hazelcast.util.Preconditions
-
Tests if the newAsyncBackupCount count is valid.
- checkAvailable() - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
-
- checkBackupCount(int, int) - Static method in class com.hazelcast.util.Preconditions
-
Tests if the newBackupCount count is valid.
- checkBasicConfig(C, SplitBrainMergePolicyProvider) - Static method in class com.hazelcast.internal.config.ConfigValidator
-
- checkBlockableReadSequence(long) - Method in class com.hazelcast.ringbuffer.impl.ArrayRingbuffer
-
- checkBlockableReadSequence(long) - Method in interface com.hazelcast.ringbuffer.impl.Ringbuffer
-
Check if the sequence can be read from the ringbuffer or if the sequence
is of the next item to be added into the ringbuffer.
- checkBlockableReadSequence(long) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-
Check if the sequence is of an item that can be read immediately
or is the sequence of the next item to be added into the ringbuffer.
- checkCacheConfig(CacheSimpleConfig, CacheMergePolicyProvider) - Static method in class com.hazelcast.internal.config.ConfigValidator
-
- checkCacheConfig(CacheConfig, CacheMergePolicyProvider) - Static method in class com.hazelcast.internal.config.ConfigValidator
-
- checkCacheConfig(InMemoryFormat, EvictionConfig, String, SplitBrainMergeTypeProvider, CacheMergePolicyProvider) - Static method in class com.hazelcast.internal.config.ConfigValidator
-
Validates the given parameters in the context of an
ICache
config.
- checkClassDefErrors - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-
- checkCollectionConfig(CollectionConfig, SplitBrainMergePolicyProvider) - Static method in class com.hazelcast.internal.config.ConfigValidator
-
- checkDrainerGone() - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
-
Checks whether the drainer thread has left and throws an exception if it
has.
- checkEvictable(RecordStore) - Method in class com.hazelcast.map.impl.eviction.EvictionChecker
-
- checkEvictable(RecordStore) - Method in interface com.hazelcast.map.impl.eviction.Evictor
-
Check whether the supplied record-store needs eviction.
- checkEvictable(RecordStore) - Method in class com.hazelcast.map.impl.eviction.EvictorImpl
-
- checkEvictionConfig(EvictionConfig, boolean) - Static method in class com.hazelcast.internal.config.ConfigValidator
-
- checkEvictionConfig(EvictionPolicy, String, Object, boolean) - Static method in class com.hazelcast.internal.config.ConfigValidator
-
Checks if parameters for an
EvictionConfig
are valid in their context.
- checkFalse(boolean, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests whether the supplied expression is false
.
- checkFreeHeapPercentageEviction(MaxSizeConfig) - Method in class com.hazelcast.map.impl.eviction.EvictionChecker
-
- checkFreeHeapSizeEviction(MaxSizeConfig) - Method in class com.hazelcast.map.impl.eviction.EvictionChecker
-
- checkFullyProcessed(JobProcessInformation) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- checkHasNext(Iterator<T>, String) - Static method in class com.hazelcast.util.Preconditions
-
Check if iterator has next element.
- checkHasText(String, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests if a string contains text.
- checkHeapPercentageEviction(String, MaxSizeConfig) - Method in class com.hazelcast.map.impl.eviction.EvictionChecker
-
- checkHeapSizeEviction(String, MaxSizeConfig) - Method in class com.hazelcast.map.impl.eviction.EvictionChecker
-
- checkIfLoaded() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- checkIfLoaded() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
- checkIndexNotNegative(int) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-
- checkInstanceOf(Class<E>, Object, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests whether the supplied object is an instance of the supplied class type.
- checkInstanceOf(Class<E>, Object) - Static method in class com.hazelcast.util.Preconditions
-
- checkMapConfig(MapConfig, MergePolicyProvider) - Static method in class com.hazelcast.internal.config.ConfigValidator
-
- checkMergePolicySupportsInMemoryFormat(String, Object, InMemoryFormat, Version, boolean, ILogger) - Static method in class com.hazelcast.internal.config.MergePolicyValidator
-
Checks if the given
InMemoryFormat
can be merged by the given
mergePolicy
instance.
- checkMultiMapConfig(MultiMapConfig, SplitBrainMergePolicyProvider) - Static method in class com.hazelcast.internal.config.ConfigValidator
-
- checkNearCacheConfig(String, NearCacheConfig, NativeMemoryConfig, boolean) - Static method in class com.hazelcast.internal.config.ConfigValidator
-
Checks preconditions to create a map proxy with Near Cache.
- checkNegative(long, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests if the value
is < 0.
- checkNoNullInside(Iterable<T>, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests if the elements inside the argument collection are not null.
- checkNotInstanceOf(Class, E, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests the supplied object to see if it is not a type of the supplied class.
- checkNotNegative(long, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests if the value
is >= 0.
- checkNotNegative(int, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests if the value
is >= 0.
- checkNotNull(T, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests if an argument is not null.
- checkNotNull(T) - Static method in class com.hazelcast.util.Preconditions
-
Tests if an argument is not null.
- checkObjectNotNull(Object) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-
- checkObjectNotNull(Object) - Method in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
-
- checkOrRepairSequence(int, long, boolean) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.RepairingHandler
-
Checks nextSequence
against current one.
- checkOrRepairUuid(int, UUID) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.RepairingHandler
-
- checkPermission(Subject, Permission) - Method in interface com.hazelcast.security.SecurityContext
-
Checks whether current
Subject
has been granted specified permission or not.
- checkPerNodeEviction(RecordStore) - Method in class com.hazelcast.map.impl.eviction.EvictionChecker
-
- checkPerPartitionEviction(String, MaxSizeConfig, int) - Method in class com.hazelcast.map.impl.eviction.EvictionChecker
-
- checkPositive(long, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests if a value
is positive, that is strictly larger than 0 (value > 0).
- checkPositive(double, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests if a value
is positive, that is strictly larger than 0 (value > 0).
- checkPositive(int, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests if a value
is positive, that is strictly larger than 0 (value > 0).
- checkQueueConfig(QueueConfig, SplitBrainMergePolicyProvider) - Static method in class com.hazelcast.internal.config.ConfigValidator
-
- checkReadSequence(long) - Method in class com.hazelcast.ringbuffer.impl.ArrayRingbuffer
-
- checkReadSequence(long) - Method in interface com.hazelcast.ringbuffer.impl.Ringbuffer
-
Check if the sequence can be read from the ringbuffer.
- checkReferenceAligned(long) - Static method in class com.hazelcast.internal.memory.impl.AlignmentUtil
-
- checkReplicatedMapConfig(ReplicatedMapConfig, MergePolicyProvider) - Static method in class com.hazelcast.internal.config.ConfigValidator
-
- CheckReplicaVersionOperation - Class in com.hazelcast.replicatedmap.impl.operation
-
Checks whether replica version is in sync with the primary.
- CheckReplicaVersionOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.CheckReplicaVersionOperation
-
- CheckReplicaVersionOperation(PartitionContainer) - Constructor for class com.hazelcast.replicatedmap.impl.operation.CheckReplicaVersionOperation
-
- checkRingbufferConfig(RingbufferConfig, SplitBrainMergePolicyProvider) - Static method in class com.hazelcast.internal.config.ConfigValidator
-
- checkScheduledExecutorConfig(ScheduledExecutorConfig, SplitBrainMergePolicyProvider) - Static method in class com.hazelcast.internal.config.ConfigValidator
-
- checkState(boolean, String) - Static method in class com.hazelcast.util.Preconditions
-
Check the state of a condition
- checkTransactionActive() - Method in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
-
- checkTrue(boolean, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests whether the supplied expression is true
.
- checkWanReplicationQueues() - Method in class com.hazelcast.map.impl.MapContainer
-
Checks if WAN replication is enabled and if the WAN queues have reached their capacity.
- checkWanReplicationQueues(String) - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
-
- checkWanReplicationQueues() - Method in interface com.hazelcast.wan.WanReplicationPublisher
-
Checks the size of the WAN replication queue and throws an
exception if it has been reached or crossed.
- checkWanReplicationQueues(String) - Method in interface com.hazelcast.wan.WanReplicationService
-
- childElements(Node) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- chunkSize - Variable in class com.hazelcast.mapreduce.impl.AbstractJob
-
- chunkSize(int) - Method in class com.hazelcast.mapreduce.impl.AbstractJob
-
- chunkSize(int) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.MappingJobImpl
-
- chunkSize(int) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.ReducingJobImpl
-
- chunkSize(int) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.ReducingSubmittableJobImpl
-
- chunkSize(int) - Method in interface com.hazelcast.mapreduce.Job
-
Deprecated.
Defines the number of elements per chunk.
- chunkSize(int) - Method in interface com.hazelcast.mapreduce.MappingJob
-
Deprecated.
Defines the number of elements per chunk.
- chunkSize(int) - Method in interface com.hazelcast.mapreduce.ReducingJob
-
Deprecated.
Defines the number of elements per chunk.
- chunkSize(int) - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
-
Deprecated.
Defines the number of elements per chunk.
- CLASS_CAST - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- CLASS_DATA - Static variable in class com.hazelcast.internal.usercodedeployment.impl.UserCodeDeploymentSerializerHook
-
- CLASS_DATA_FINDER_OP - Static variable in class com.hazelcast.internal.usercodedeployment.impl.UserCodeDeploymentSerializerHook
-
- CLASS_NOT_FOUND - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- ClassBlacklistFilter - Class in com.hazelcast.internal.usercodedeployment.impl.filter
-
Match all classes unless they are in the explicit blacklist
- ClassBlacklistFilter(String...) - Constructor for class com.hazelcast.internal.usercodedeployment.impl.filter.ClassBlacklistFilter
-
- ClassData - Class in com.hazelcast.internal.usercodedeployment.impl
-
Carries byte code of a class along with its inner classes.
- ClassData() - Constructor for class com.hazelcast.internal.usercodedeployment.impl.ClassData
-
- ClassDataFinderOperation - Class in com.hazelcast.internal.usercodedeployment.impl.operation
-
- ClassDataFinderOperation(String) - Constructor for class com.hazelcast.internal.usercodedeployment.impl.operation.ClassDataFinderOperation
-
- ClassDataFinderOperation() - Constructor for class com.hazelcast.internal.usercodedeployment.impl.operation.ClassDataFinderOperation
-
- ClassDataProvider - Class in com.hazelcast.internal.usercodedeployment.impl
-
- ClassDataProvider(UserCodeDeploymentConfig.ProviderMode, ClassLoader, ConcurrentMap<String, ClassSource>, ConcurrentMap<String, ClassSource>, ILogger) - Constructor for class com.hazelcast.internal.usercodedeployment.impl.ClassDataProvider
-
- ClassDefinition - Interface in com.hazelcast.nio.serialization
-
ClassDefinition defines a class schema for Portable classes.
- ClassDefinitionBuilder - Class in com.hazelcast.nio.serialization
-
ClassDefinitionBuilder is used to build and register ClassDefinitions manually.
- ClassDefinitionBuilder(int, int) - Constructor for class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
IMPORTANT: It uses a default portableVersion (0) for non-versioned classes.
- ClassDefinitionBuilder(int, int, int) - Constructor for class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
IMPORTANT: Make sure that the version matches the portableVersion in the SerializationService
- ClassDefinitionImpl - Class in com.hazelcast.internal.serialization.impl
-
- ClassDefinitionImpl(int, int, int) - Constructor for class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
-
- classDefinitions - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-
- ClassFilter - Class in com.hazelcast.config
-
Holds blacklist and whitelist configuration in java deserialization configuration.
- ClassFilter() - Constructor for class com.hazelcast.config.ClassFilter
-
- classIterator(Class<T>, String, ClassLoader) - Static method in class com.hazelcast.util.ServiceLoader
-
- classLoader - Variable in class com.hazelcast.config.AbstractCacheConfig
-
The ClassLoader to be used to resolve key & value types, if set
- classLoader - Variable in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
-
- classLoader - Variable in class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
-
- classLoader - Variable in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
-
- classLoader - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-
- classLoader - Variable in class com.hazelcast.util.executor.AbstractExecutorThreadFactory
-
- classLoaderReference - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- ClassLoaderUtil - Class in com.hazelcast.nio
-
Utility class to deal with classloaders.
- ClassLoadingMetricSet - Class in com.hazelcast.internal.metrics.metricsets
-
- ClassloadingMutexProvider - Class in com.hazelcast.internal.usercodedeployment.impl
-
Java 7+ onwards allows parallel classloading.
- ClassloadingMutexProvider() - Constructor for class com.hazelcast.internal.usercodedeployment.impl.ClassloadingMutexProvider
-
- ClassLocator - Class in com.hazelcast.internal.usercodedeployment.impl
-
Provides classes to a local member.
- ClassLocator(ConcurrentMap<String, ClassSource>, ConcurrentMap<String, ClassSource>, ClassLoader, Filter<String>, Filter<Member>, UserCodeDeploymentConfig.ClassCacheMode, NodeEngine) - Constructor for class com.hazelcast.internal.usercodedeployment.impl.ClassLocator
-
- className - Variable in class com.hazelcast.config.ListenerConfig
-
- className - Variable in class com.hazelcast.config.PredicateConfig
-
- className - Variable in class com.hazelcast.config.SecurityInterceptorConfig
-
- classNameFilter - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-
- ClassNameFilter - Interface in com.hazelcast.nio
-
Allows to intercept class resolution during deserialization based on classname.
- ClassNameFilterParser - Class in com.hazelcast.internal.usercodedeployment.impl.filter
-
- ClasspathXmlConfig - Class in com.hazelcast.config
-
A
Config
which is initialized by loading an XML configuration file from the classpath.
- ClasspathXmlConfig(String) - Constructor for class com.hazelcast.config.ClasspathXmlConfig
-
Creates a config which is loaded from a classpath resource using the
Thread.currentThread contextClassLoader.
- ClasspathXmlConfig(String, Properties) - Constructor for class com.hazelcast.config.ClasspathXmlConfig
-
Creates a config which is loaded from a classpath resource using the
Thread.currentThread contextClassLoader.
- ClasspathXmlConfig(ClassLoader, String) - Constructor for class com.hazelcast.config.ClasspathXmlConfig
-
Creates a config which is loaded from a classpath resource.
- ClasspathXmlConfig(ClassLoader, String, Properties) - Constructor for class com.hazelcast.config.ClasspathXmlConfig
-
Creates a config which is loaded from a classpath resource.
- ClassSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.ClassSerializer
-
- ClassSource - Class in com.hazelcast.internal.usercodedeployment.impl
-
Classloader created on a local member to define a class from a bytecode loaded from a remote source.
- ClassSource(ClassLoader, ClassLocator) - Constructor for class com.hazelcast.internal.usercodedeployment.impl.ClassSource
-
- ClassWhitelistFilter - Class in com.hazelcast.internal.usercodedeployment.impl.filter
-
Match only classes in the whitelist.
- ClassWhitelistFilter(String...) - Constructor for class com.hazelcast.internal.usercodedeployment.impl.filter.ClassWhitelistFilter
-
- cleanNodeName(Node) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- cleanup(ObjectNamespace, int) - Method in class com.hazelcast.cache.impl.journal.RingbufferCacheEventJournalImpl
-
- cleanup(ObjectNamespace, int) - Method in interface com.hazelcast.internal.journal.EventJournal
-
Cleans up the event journal by removing any expired items.
- cleanup(ObjectNamespace, int) - Method in class com.hazelcast.map.impl.journal.RingbufferMapEventJournalImpl
-
- cleanup() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-
- CLEANUP_OPERATION_COUNT - Static variable in class com.hazelcast.map.impl.eviction.ExpirationManager
-
- CLEANUP_PERCENTAGE - Static variable in class com.hazelcast.map.impl.eviction.ExpirationManager
-
- clear() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- CLEAR - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- clear() - Method in class com.hazelcast.cache.impl.CacheProxy
-
- clear() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
Implementation of CacheStatisticsMXBean.clear()
.
- clear() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- clear() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
clears all internal data without publishing any events
- clear() - Method in class com.hazelcast.cache.impl.record.CacheRecordHashMap
-
- clear() - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-
- clear() - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
-
- clear() - Method in interface com.hazelcast.client.ClientEndpointManager
-
Removes all endpoints.
- clear() - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
-
- clear() - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-
- clear() - Method in class com.hazelcast.client.proxy.ClientListProxy
-
- clear() - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- clear() - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-
- clear() - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-
- clear() - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
-
- clear() - Method in class com.hazelcast.client.proxy.ClientSetProxy
-
- clear() - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-
- clear() - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-
- clear(boolean) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-
- clear() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-
- CLEAR - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-
- clear() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- clear() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- clear() - Method in class com.hazelcast.config.InterfacesConfig
-
clears all interfaces.
- clear() - Method in class com.hazelcast.config.MemberGroupConfig
-
Removes all interfaces from the member group.
- clear() - Method in class com.hazelcast.config.PartitionGroupConfig
-
- clear() - Method in class com.hazelcast.config.ServicesConfig
-
- clear() - Method in class com.hazelcast.config.TcpIpConfig
-
Removes all members.
- clear() - Method in interface com.hazelcast.core.IAtomicReference
-
Clears the current stored reference.
- clear() - Method in interface com.hazelcast.core.IMap
-
Clears the map and deletes the items from the backing map store.
- clear() - Method in interface com.hazelcast.core.MultiMap
-
Clears the multimap.
- clear() - Method in interface com.hazelcast.core.ReplicatedMap
-
The clear operation wipes data out of the replicated maps.
- clear() - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
-
- clear() - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
-
- clear() - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
-
- clear() - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
-
- clear() - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
-
- clear() - Method in class com.hazelcast.internal.cluster.impl.MemberSelectingCollection
-
- clear() - Method in class com.hazelcast.internal.dynamicconfig.AggregatingMap
-
- clear() - Method in class com.hazelcast.internal.jmx.ListMBean
-
- clear() - Method in class com.hazelcast.internal.jmx.LockMBean
-
- clear() - Method in class com.hazelcast.internal.jmx.MapMBean
-
- clear() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
-
- clear() - Method in class com.hazelcast.internal.jmx.QueueMBean
-
- clear() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
-
- clear() - Method in class com.hazelcast.internal.jmx.SetMBean
-
- clear() - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
-
- clear() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationQueue
-
- clear() - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
-
- clear() - Method in interface com.hazelcast.internal.nearcache.NearCache
-
Removes all stored values.
- clear() - Method in interface com.hazelcast.internal.nearcache.NearCacheRecordStore
-
Removes all stored values.
- clear() - Method in class com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolThreadLocal
-
- clear() - Method in interface com.hazelcast.internal.util.collection.Long2LongMap
-
- clear() - Method in class com.hazelcast.internal.util.collection.Long2LongMapHsa
-
- clear() - Method in interface com.hazelcast.internal.util.collection.LongSet
-
- clear() - Method in class com.hazelcast.internal.util.collection.LongSetHsa
-
- clear() - Method in class com.hazelcast.internal.util.concurrent.MPSCQueue
-
.
- clear() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray
-
After this method returns, all slots in the current hash slot array are unassigned.
- clear() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
-
- CLEAR - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- clear() - Method in class com.hazelcast.map.impl.MapEntries
-
- clear() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
-
Removes all of the elements in this
WriteBehindQueue
Queue will be empty after this method returns.
- clear(boolean, boolean) - Method in class com.hazelcast.map.impl.PartitionContainer
-
- clear() - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- clear() - Method in interface com.hazelcast.map.impl.querycache.subscriber.InternalQueryCache
-
- clear() - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
-
- clear() - Method in interface com.hazelcast.map.impl.querycache.subscriber.QueryCacheRecordStore
-
- clear() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- clear() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
- clear(boolean) - Method in interface com.hazelcast.map.impl.recordstore.Storage
-
- clear(boolean) - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
-
- clear() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- CLEAR - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- clear() - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-
- clear() - Method in interface com.hazelcast.nio.BufferObjectDataInput
-
- clear() - Method in interface com.hazelcast.nio.BufferObjectDataOutput
-
- clear() - Method in interface com.hazelcast.query.impl.Index
-
Clears out all entries from this index.
- clear() - Method in class com.hazelcast.query.impl.IndexImpl
-
- clear() - Method in interface com.hazelcast.query.impl.IndexStore
-
- clear() - Method in class com.hazelcast.query.impl.SortedIndexStore
-
- clear() - Method in class com.hazelcast.query.impl.UnsortedIndexStore
-
- CLEAR - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
-
- clear() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- clear() - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
-
- clear() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- clear() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- clear() - Method in class com.hazelcast.ringbuffer.impl.ArrayRingbuffer
-
- clear() - Method in interface com.hazelcast.ringbuffer.impl.Ringbuffer
-
Clears the data in the ringbuffer.
- clear() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-
Clears the data in the ringbuffer.
- clear() - Method in class com.hazelcast.spi.CallsPerMember
-
- clear() - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
-
- clear() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
-
Clears the data in the ringbuffer.
- clear() - Method in class com.hazelcast.spring.cache.HazelcastCache
-
- clear() - Method in class com.hazelcast.util.collection.InflatableSet
-
- clear() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
-
- clear() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.KeySet
-
- clear() - Method in class com.hazelcast.util.collection.IntHashSet
-
- clear() - Method in class com.hazelcast.util.collection.Long2LongHashMap
-
- clear() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
-
- clear() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.KeySet
-
- clear() - Method in class com.hazelcast.util.collection.LongHashSet
- clear() - Method in class com.hazelcast.util.collection.MapDelegatingSet
- clear() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
-
Removes all of the mappings from this map.
- clear() - Method in class com.hazelcast.util.ItemCounter
-
Clears the counter.
- CLEAR_BACKUP - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- CLEAR_BACKUP - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-
- CLEAR_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- CLEAR_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- CLEAR_FACTORY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- CLEAR_FACTORY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- CLEAR_NEAR_CACHE - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- CLEAR_NEAR_CACHE_INVALIDATION - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- CLEAR_OP_FACTORY - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
-
- CLEAR_REMOTE_TX - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
-
- CLEAR_REMOTE_TX_BACKUP - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
-
- CLEAR_RESPONSE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- clearAll() - Method in class com.hazelcast.query.impl.Indexes
-
Clears contents of indexes managed by this instance.
- clearAllListeners() - Method in interface com.hazelcast.client.ClientEndpoint
-
- clearAllListeners() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- clearAllNearCaches() - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
-
- clearAllNearCaches() - Method in interface com.hazelcast.internal.nearcache.NearCacheManager
-
- clearAsync() - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-
- clearAsync() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- clearAsync() - Method in interface com.hazelcast.core.IAtomicReference
-
Clears the current stored reference.
- clearBackup(Set<Long>) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-
- clearBackup(Set<Long>) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-
- ClearBackupOperation - Class in com.hazelcast.collection.impl.queue.operations
-
Store items' ID as set when ClearOperation run.
- ClearBackupOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.ClearBackupOperation
-
- ClearBackupOperation(String, Set<Long>) - Constructor for class com.hazelcast.collection.impl.queue.operations.ClearBackupOperation
-
- ClearBackupOperation - Class in com.hazelcast.map.impl.operation
-
- ClearBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.ClearBackupOperation
-
- ClearBackupOperation(String) - Constructor for class com.hazelcast.map.impl.operation.ClearBackupOperation
-
- ClearBackupOperation - Class in com.hazelcast.multimap.impl.operations
-
- ClearBackupOperation() - Constructor for class com.hazelcast.multimap.impl.operations.ClearBackupOperation
-
- ClearBackupOperation(String) - Constructor for class com.hazelcast.multimap.impl.operations.ClearBackupOperation
-
- clearBit(byte, int) - Static method in class com.hazelcast.nio.Bits
-
Clears n-th bit of the byte value
- clearBit(int, int) - Static method in class com.hazelcast.nio.Bits
-
Clears n-th bit of the integer value
- clearClients() - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
-
- clearCRDTState(Map<String, VectorClock>) - Method in interface com.hazelcast.crdt.CRDTReplicationAwareService
-
Removes all of the CRDTs with vector clocks equal to the provided vector
clocks.
- clearCRDTState(Map<String, VectorClock>) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
-
- ClearExpiredOperation - Class in com.hazelcast.map.impl.operation
-
Clears expired records.
- ClearExpiredOperation(int) - Constructor for class com.hazelcast.map.impl.operation.ClearExpiredOperation
-
- clearIndexedData() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
Only indexed data will be removed, index info will stay.
- clearInternal() - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-
- clearInternal() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-
- clearLoadedLoggers() - Method in class com.hazelcast.logging.LoggerFactorySupport
-
- clearLockStore(int, ObjectNamespace) - Method in interface com.hazelcast.concurrent.lock.LockService
-
- clearLockStore(int, ObjectNamespace) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- clearLockStore() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- clearMapsHavingLesserBackupCountThan(int, int) - Method in interface com.hazelcast.map.impl.MapServiceContext
-
Clears all map partitions which are expected to have lesser backups
than given.
- clearMapStore() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- clearMigratingFlag(int) - Method in class com.hazelcast.internal.partition.impl.PartitionStateManager
-
- clearNearCache(String) - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
-
- clearNearCache(String) - Method in interface com.hazelcast.internal.nearcache.NearCacheManager
-
Clears
NearCache
instance associated with given
name
but not removes it.
- ClearNearCacheOperation - Class in com.hazelcast.map.impl.operation
-
Deprecated.
- ClearNearCacheOperation() - Constructor for class com.hazelcast.map.impl.operation.ClearNearCacheOperation
-
Deprecated.
- ClearNearCacheOperation(String) - Constructor for class com.hazelcast.map.impl.operation.ClearNearCacheOperation
-
Deprecated.
- ClearOperation - Class in com.hazelcast.collection.impl.queue.operations
-
Clears items stored by Queue.
- ClearOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.ClearOperation
-
- ClearOperation(String) - Constructor for class com.hazelcast.collection.impl.queue.operations.ClearOperation
-
- ClearOperation - Class in com.hazelcast.map.impl.operation
-
- ClearOperation() - Constructor for class com.hazelcast.map.impl.operation.ClearOperation
-
- ClearOperation(String) - Constructor for class com.hazelcast.map.impl.operation.ClearOperation
-
- ClearOperation - Class in com.hazelcast.multimap.impl.operations
-
- ClearOperation() - Constructor for class com.hazelcast.multimap.impl.operations.ClearOperation
-
- ClearOperation(String) - Constructor for class com.hazelcast.multimap.impl.operations.ClearOperation
-
- ClearOperation - Class in com.hazelcast.replicatedmap.impl.operation
-
- ClearOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ClearOperation
-
- ClearOperation(String, boolean) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ClearOperation
-
- ClearOperation(String, boolean, long) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ClearOperation
-
- ClearOperationFactory - Class in com.hazelcast.map.impl.operation
-
- ClearOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.ClearOperationFactory
-
- ClearOperationFactory(String) - Constructor for class com.hazelcast.map.impl.operation.ClearOperationFactory
-
- ClearOperationFactory - Class in com.hazelcast.replicatedmap.impl.operation
-
- ClearOperationFactory() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ClearOperationFactory
-
- ClearOperationFactory(String) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ClearOperationFactory
-
- clearPartition(boolean, boolean) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- clearPartition(boolean, boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
Clears internal partition data.
- clearPartitionData(int) - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- clearPartitionIndexesToAdd() - Method in class com.hazelcast.map.impl.MapContainer
-
- clearPartitionReplicaVersions(int, ServiceNamespace) - Method in class com.hazelcast.internal.partition.impl.PartitionReplicaManager
-
- clearPartitions(boolean, boolean) - Method in interface com.hazelcast.map.impl.MapServiceContext
-
Clears all partition based data allocated by MapService.
- clearQueues(String, String) - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
-
- clearQueues(String, String) - Method in interface com.hazelcast.wan.WanReplicationService
-
Clears WAN replication queues of the given wanReplicationName for the given target.
- ClearRemoteTransactionBackupOperation - Class in com.hazelcast.transaction.impl.xa.operations
-
- ClearRemoteTransactionBackupOperation() - Constructor for class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionBackupOperation
-
- ClearRemoteTransactionBackupOperation(Data) - Constructor for class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionBackupOperation
-
- ClearRemoteTransactionOperation - Class in com.hazelcast.transaction.impl.xa.operations
-
- ClearRemoteTransactionOperation() - Constructor for class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
-
- ClearRemoteTransactionOperation(Data) - Constructor for class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
-
- clearReplicaSyncRequest(int, ServiceNamespace, int) - Method in class com.hazelcast.internal.partition.impl.PartitionReplicaManager
-
Resets the state of the replica synchronization request for the given partition and replica.
- clearRingBuffersHavingLesserBackupCountThan(int) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorPartitionContainer
-
- clearServers() - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
-
- clearStorage(boolean) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- ClearWanQueuesOperation - Class in com.hazelcast.internal.management.operation
-
Clear WAN replication queues for the given wan replication schema and publisher
- ClearWanQueuesOperation(String, String) - Constructor for class com.hazelcast.internal.management.operation.ClearWanQueuesOperation
-
- ClearWanQueuesRequest - Class in com.hazelcast.internal.management.request
-
- ClearWanQueuesRequest() - Constructor for class com.hazelcast.internal.management.request.ClearWanQueuesRequest
-
- ClearWanQueuesRequest(String, String) - Constructor for class com.hazelcast.internal.management.request.ClearWanQueuesRequest
-
- clearWithVersion(long) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- clearWithVersion(long) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- client - Variable in class com.hazelcast.client.impl.DefaultClientExtension
-
- client - Variable in class com.hazelcast.client.impl.HazelcastClientProxy
-
- client - Variable in class com.hazelcast.client.spi.impl.AbstractClientInvocationService
-
- client - Variable in class com.hazelcast.client.spi.impl.ClientClusterServiceImpl
-
- client - Variable in class com.hazelcast.client.spi.impl.listener.AbstractClientListenerService
-
- Client - Interface in com.hazelcast.core
-
The Client interface allows to get information about
a connected client's socket address, type and UUID.
- CLIENT_BINARY_NEW - Static variable in class com.hazelcast.nio.Protocols
-
New Client Protocol that is used for clients (Java, c++, c# client)
- CLIENT_DISCONNECT - Static variable in class com.hazelcast.client.impl.ClientDataSerializerHook
-
- CLIENT_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- CLIENT_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- CLIENT_ENDPOINT_REMOVE_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
Time after which client connection is removed or owner node of a client is removed from the cluster.
- CLIENT_ENGINE_QUERY_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
- CLIENT_ENGINE_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
The number of threads that the client engine has available for processing requests that are not partition specific.
- CLIENT_ERROR - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
-
- CLIENT_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
-
Name of the client executor.
- CLIENT_HEARTBEAT_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
- CLIENT_MANAGEMENT_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
-
Name of the client management executor.
- CLIENT_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- CLIENT_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- CLIENT_QUERY_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
-
Name of the client executor.
- CLIENT_TXN_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- CLIENT_TXN_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- ClientAtomicLongProxy - Class in com.hazelcast.client.proxy
-
- ClientAtomicLongProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.proxy.ClientAtomicLongProxy
-
- ClientAtomicReferenceProxy<E> - Class in com.hazelcast.client.proxy
-
- ClientAtomicReferenceProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-
- clientAwareService - Variable in class com.hazelcast.map.impl.MapService
-
- ClientAwareService - Interface in com.hazelcast.spi
-
A interface that can be implemented by a SPI Service so that it can be notified about client disconnects.
- ClientAwsConfig - Class in com.hazelcast.client.config
-
The AWSConfig contains the configuration for client
to connect to nodes in aws environment.
- ClientAwsConfig() - Constructor for class com.hazelcast.client.config.ClientAwsConfig
-
- ClientCacheMetaDataFetcher - Class in com.hazelcast.client.cache.impl.nearcache.invalidation
-
MetaDataFetcher
for client side usage
- ClientCacheMetaDataFetcher(ClientContext) - Constructor for class com.hazelcast.client.cache.impl.nearcache.invalidation.ClientCacheMetaDataFetcher
-
- ClientCachePartitionIterator<K,V> - Class in com.hazelcast.client.cache.impl
-
- ClientCachePartitionIterator(ICacheInternal<K, V>, ClientContext, int, int, boolean) - Constructor for class com.hazelcast.client.cache.impl.ClientCachePartitionIterator
-
- ClientCacheProxy<K,V> - Class in com.hazelcast.client.cache.impl
-
ICache
implementation for Hazelcast clients.
- ClientCacheProxyFactory - Class in com.hazelcast.client.cache.impl
-
- ClientCacheProxyFactory(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.cache.impl.ClientCacheProxyFactory
-
- ClientCacheStatisticsImpl - Class in com.hazelcast.client.cache.impl
-
- ClientCacheStatisticsImpl(long) - Constructor for class com.hazelcast.client.cache.impl.ClientCacheStatisticsImpl
-
- ClientCardinalityEstimatorProxy - Class in com.hazelcast.client.proxy
-
- ClientCardinalityEstimatorProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.proxy.ClientCardinalityEstimatorProxy
-
- ClientClasspathXmlConfig - Class in com.hazelcast.client.config
-
A
ClientConfig
which is initialized by loading an XML configuration file from the classpath.
- ClientClasspathXmlConfig(String) - Constructor for class com.hazelcast.client.config.ClientClasspathXmlConfig
-
Creates a config which is loaded from a classpath resource using the
Thread.currentThread contextClassLoader.
- ClientClasspathXmlConfig(String, Properties) - Constructor for class com.hazelcast.client.config.ClientClasspathXmlConfig
-
Creates a config which is loaded from a classpath resource using the
Thread.currentThread contextClassLoader.
- ClientClasspathXmlConfig(ClassLoader, String, Properties) - Constructor for class com.hazelcast.client.config.ClientClasspathXmlConfig
-
Creates a config which is loaded from a classpath resource.
- ClientClusterProxy - Class in com.hazelcast.client.proxy
-
Client implementation of the
Cluster
.
- ClientClusterProxy(ClientClusterServiceImpl) - Constructor for class com.hazelcast.client.proxy.ClientClusterProxy
-
- ClientClusterService - Interface in com.hazelcast.client.spi
-
Cluster service for Hazelcast clients.
- ClientClusterServiceImpl - Class in com.hazelcast.client.spi.impl
-
- ClientClusterServiceImpl(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.spi.impl.ClientClusterServiceImpl
-
- ClientClusterWideIterator<K,V> - Class in com.hazelcast.client.cache.impl
-
Client side cluster-wide iterator for
ICache
.
- ClientClusterWideIterator(ICacheInternal<K, V>, ClientContext, boolean) - Constructor for class com.hazelcast.client.cache.impl.ClientClusterWideIterator
-
- ClientClusterWideIterator(ICacheInternal<K, V>, ClientContext, int, boolean) - Constructor for class com.hazelcast.client.cache.impl.ClientClusterWideIterator
-
- ClientClusterWideIterator(ICacheInternal<K, V>, ClientContext, int, int, boolean) - Constructor for class com.hazelcast.client.cache.impl.ClientClusterWideIterator
-
- ClientConditionProxy - Class in com.hazelcast.client.proxy
-
- ClientConditionProxy(ClientLockProxy, String, ClientContext) - Constructor for class com.hazelcast.client.proxy.ClientConditionProxy
-
- ClientConfig - Class in com.hazelcast.client.config
-
Main configuration to setup a Hazelcast Client
- ClientConfig() - Constructor for class com.hazelcast.client.config.ClientConfig
-
- clientConnected(Client) - Method in interface com.hazelcast.core.ClientListener
-
Invoked when a client is connected.
- ClientConnection - Class in com.hazelcast.client.connection.nio
-
- ClientConnection(HazelcastClientInstanceImpl, int, Channel) - Constructor for class com.hazelcast.client.connection.nio.ClientConnection
-
- ClientConnection(HazelcastClientInstanceImpl, int) - Constructor for class com.hazelcast.client.connection.nio.ClientConnection
-
- clientConnectionCount - Variable in class com.hazelcast.internal.management.dto.ConnectionManagerDTO
-
- ClientConnectionManager - Interface in com.hazelcast.client.connection
-
- ClientConnectionManagerFactory - Interface in com.hazelcast.client.impl
-
- ClientConnectionManagerImpl - Class in com.hazelcast.client.connection.nio
-
- ClientConnectionManagerImpl(HazelcastClientInstanceImpl, AddressTranslator, Collection<AddressProvider>) - Constructor for class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-
- ClientConnectionStrategy - Class in com.hazelcast.client.connection
-
An abstract class called from
ClientConnectionManager
to customize
how client connect to cluster, and provide various behaviours like async start or restart.
- ClientConnectionStrategy() - Constructor for class com.hazelcast.client.connection.ClientConnectionStrategy
-
- ClientConnectionStrategyConfig - Class in com.hazelcast.client.config
-
Client connection strategy configuration is used for setting custom strategies and configuring strategy parameters.
- ClientConnectionStrategyConfig() - Constructor for class com.hazelcast.client.config.ClientConnectionStrategyConfig
-
- clientConnectionStrategyConfig - Variable in class com.hazelcast.client.connection.ClientConnectionStrategy
-
- ClientConnectionStrategyConfig.ReconnectMode - Enum in com.hazelcast.client.config
-
Reconnect options.
- ClientConsoleApp - Class in com.hazelcast.client.console
-
A demo application to demonstrate a Hazelcast client.
- ClientConsoleApp(HazelcastInstance) - Constructor for class com.hazelcast.client.console.ClientConsoleApp
-
- clientContext - Variable in class com.hazelcast.client.connection.ClientConnectionStrategy
-
- ClientContext - Class in com.hazelcast.client.spi
-
Context holding all the required services, managers and the configuration for a Hazelcast client.
- ClientContext(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.spi.ClientContext
-
- ClientCountDownLatchProxy - Class in com.hazelcast.client.proxy
-
- ClientCountDownLatchProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.proxy.ClientCountDownLatchProxy
-
- ClientDataSerializerHook - Class in com.hazelcast.client.impl
-
- ClientDataSerializerHook() - Constructor for class com.hazelcast.client.impl.ClientDataSerializerHook
-
- ClientDelegatingFuture<V> - Class in com.hazelcast.client.util
-
The Client Delegating Future is used to delegate
ClientInvocationFuture
to a user type to be used with
andThen()
or
get()
.
- ClientDelegatingFuture(ClientInvocationFuture, SerializationService, ClientMessageDecoder, V, boolean) - Constructor for class com.hazelcast.client.util.ClientDelegatingFuture
-
- ClientDelegatingFuture(ClientInvocationFuture, SerializationService, ClientMessageDecoder, V) - Constructor for class com.hazelcast.client.util.ClientDelegatingFuture
-
- ClientDelegatingFuture(ClientInvocationFuture, SerializationService, ClientMessageDecoder) - Constructor for class com.hazelcast.client.util.ClientDelegatingFuture
-
- ClientDelegatingFuture(ClientInvocationFuture, SerializationService, ClientMessageDecoder, boolean) - Constructor for class com.hazelcast.client.util.ClientDelegatingFuture
-
- clientDisconnected(String) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- clientDisconnected(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-
- clientDisconnected(Client) - Method in interface com.hazelcast.core.ClientListener
-
Invoked when a client is disconnected.
- clientDisconnected(String) - Method in class com.hazelcast.map.impl.MapService
-
- clientDisconnected(String) - Method in interface com.hazelcast.spi.ClientAwareService
-
Invoked when a client disconnects from a member.
- clientDisconnected(String) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-
- ClientDisconnectedTask() - Constructor for class com.hazelcast.client.impl.operations.ClientDisconnectionOperation.ClientDisconnectedTask
-
- ClientDisconnectionOperation - Class in com.hazelcast.client.impl.operations
-
- ClientDisconnectionOperation() - Constructor for class com.hazelcast.client.impl.operations.ClientDisconnectionOperation
-
- ClientDisconnectionOperation(String, String) - Constructor for class com.hazelcast.client.impl.operations.ClientDisconnectionOperation
-
- ClientDisconnectionOperation.ClientDisconnectedTask - Class in com.hazelcast.client.impl.operations
-
- ClientDurableExecutorServiceProxy - Class in com.hazelcast.client.proxy
-
- ClientDurableExecutorServiceProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.proxy.ClientDurableExecutorServiceProxy
-
- ClientDynamicClusterConfig - Class in com.hazelcast.client.impl
-
Client implementation of member side config.
- ClientDynamicClusterConfig(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- ClientEndpoint - Interface in com.hazelcast.client
-
Represents an endpoint to a client.
- ClientEndPointDTO - Class in com.hazelcast.internal.management.dto
-
- ClientEndPointDTO() - Constructor for class com.hazelcast.internal.management.dto.ClientEndPointDTO
-
- ClientEndPointDTO(Client) - Constructor for class com.hazelcast.internal.management.dto.ClientEndPointDTO
-
- ClientEndpointImpl - Class in com.hazelcast.client.impl
-
- ClientEndpointImpl(ClientEngineImpl, NodeEngineImpl, Connection) - Constructor for class com.hazelcast.client.impl.ClientEndpointImpl
-
- ClientEndpointManager - Interface in com.hazelcast.client
-
- ClientEndpointManagerImpl - Class in com.hazelcast.client.impl
-
- ClientEndpointManagerImpl(NodeEngine) - Constructor for class com.hazelcast.client.impl.ClientEndpointManagerImpl
-
- ClientEngine - Interface in com.hazelcast.client
-
The client Engine.
- clientEngine - Variable in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-
- clientEngine - Variable in class com.hazelcast.instance.Node
-
- ClientEngineImpl - Class in com.hazelcast.client.impl
-
Class that requests, listeners from client handled in node side.
- ClientEngineImpl(Node) - Constructor for class com.hazelcast.client.impl.ClientEngineImpl
-
- ClientEngineMBean - Class in com.hazelcast.internal.jmx
-
- ClientEngineMBean(HazelcastInstance, ClientEngine, ManagementService) - Constructor for class com.hazelcast.internal.jmx.ClientEngineMBean
-
- ClientEvent - Class in com.hazelcast.client
-
Event used for notification of client connection and disconnection
- ClientEvent(String, ClientEventType, InetSocketAddress, ClientType) - Constructor for class com.hazelcast.client.ClientEvent
-
- ClientEventRegistration - Class in com.hazelcast.client.spi.impl.listener
-
Keeps the information related to to an event registration made by clients.
- ClientEventRegistration(String, long, Connection, ListenerMessageCodec) - Constructor for class com.hazelcast.client.spi.impl.listener.ClientEventRegistration
-
- ClientEventType - Enum in com.hazelcast.client
-
Event type used for client connection and disconnect events
- ClientExceptionFactory - Class in com.hazelcast.client.impl.protocol
-
This class has the error codes and means of
1) creating exception from error code
2) getting the error code of given exception
- ClientExceptionFactory(boolean) - Constructor for class com.hazelcast.client.impl.protocol.ClientExceptionFactory
-
- ClientExceptionFactory.ExceptionFactory - Interface in com.hazelcast.client.impl.protocol
-
- ClientExecutionService - Interface in com.hazelcast.client.spi
-
Executor service for Hazelcast clients.
- ClientExecutionServiceImpl - Class in com.hazelcast.client.spi.impl
-
- ClientExecutionServiceImpl(String, ClassLoader, HazelcastProperties, int, LoggingService) - Constructor for class com.hazelcast.client.spi.impl.ClientExecutionServiceImpl
-
- ClientExecutorServiceProxy - Class in com.hazelcast.client.proxy
-
- ClientExecutorServiceProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-
- ClientExtension - Interface in com.hazelcast.client
-
- ClientFlakeIdGeneratorConfig - Class in com.hazelcast.client.config
-
The
ClientFlakeIdGeneratorConfig
contains the configuration for the client
regarding
Flake ID Generator
.
- ClientFlakeIdGeneratorConfig(String) - Constructor for class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
-
- ClientFlakeIdGeneratorConfig(ClientFlakeIdGeneratorConfig) - Constructor for class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
-
Copy-constructor
- ClientFlakeIdGeneratorProxy - Class in com.hazelcast.client.proxy
-
- ClientFlakeIdGeneratorProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.proxy.ClientFlakeIdGeneratorProxy
-
- ClientHeartbeatMonitor - Class in com.hazelcast.client.impl
-
Monitors client heartbeats..
- ClientHeartbeatMonitor(ClientEndpointManager, ClientEngine, ExecutionService, HazelcastProperties) - Constructor for class com.hazelcast.client.impl.ClientHeartbeatMonitor
-
- ClientICacheManager - Class in com.hazelcast.client.impl
-
Hazelcast instance cache manager provides a means to obtain JCache caches via HazelcastInstance API.
- ClientICMPManager - Class in com.hazelcast.client.connection.nio
-
Client icmp based ping manager
Responsible for configuration handling and
scheduling related tasks
- ClientICMPManager(ClientIcmpPingConfig, ClientExecutionServiceImpl, LoggingService, ClientConnectionManagerImpl, HeartbeatManager) - Constructor for class com.hazelcast.client.connection.nio.ClientICMPManager
-
- ClientIcmpPingConfig - Class in com.hazelcast.client.config
-
Configuration for icmp ping failure detector of clients.
- ClientIcmpPingConfig() - Constructor for class com.hazelcast.client.config.ClientIcmpPingConfig
-
- ClientIdGeneratorProxy - Class in com.hazelcast.client.proxy
-
- ClientIdGeneratorProxy(String, String, ClientContext, IAtomicLong) - Constructor for class com.hazelcast.client.proxy.ClientIdGeneratorProxy
-
- ClientImpl - Class in com.hazelcast.client.impl
-
Default
Client
implementation.
- ClientImpl(String, InetSocketAddress) - Constructor for class com.hazelcast.client.impl.ClientImpl
-
- ClientInvocation - Class in com.hazelcast.client.spi.impl
-
Handles the routing of a request from a Hazelcast client.
- ClientInvocation(HazelcastClientInstanceImpl, ClientMessage, String, int, Address, Connection) - Constructor for class com.hazelcast.client.spi.impl.ClientInvocation
-
- ClientInvocation(HazelcastClientInstanceImpl, ClientMessage, String) - Constructor for class com.hazelcast.client.spi.impl.ClientInvocation
-
Create an invocation that will be executed on random member.
- ClientInvocation(HazelcastClientInstanceImpl, ClientMessage, String, int) - Constructor for class com.hazelcast.client.spi.impl.ClientInvocation
-
Create an invocation that will be executed on owner of partitionId
.
- ClientInvocation(HazelcastClientInstanceImpl, ClientMessage, String, Address) - Constructor for class com.hazelcast.client.spi.impl.ClientInvocation
-
Create an invocation that will be executed on member with given address
.
- ClientInvocation(HazelcastClientInstanceImpl, ClientMessage, String, Connection) - Constructor for class com.hazelcast.client.spi.impl.ClientInvocation
-
Create an invocation that will be executed on given connection
.
- ClientInvocationFuture - Class in com.hazelcast.client.spi.impl
-
- ClientInvocationFuture(ClientInvocation, Executor, ClientMessage, ILogger, CallIdSequence) - Constructor for class com.hazelcast.client.spi.impl.ClientInvocationFuture
-
- ClientInvocationService - Interface in com.hazelcast.client.spi
-
Invocation service for Hazelcast clients.
- ClientInvokerWrapper - Class in com.hazelcast.client.impl.querycache.subscriber
-
- ClientInvokerWrapper(QueryCacheContext, ClientContext) - Constructor for class com.hazelcast.client.impl.querycache.subscriber.ClientInvokerWrapper
-
- ClientListener - Interface in com.hazelcast.core
-
The ClientListener provides the ability to listen to clients connecting and disconnecting from the member.
- ClientListenerService - Interface in com.hazelcast.client.spi
-
Client service to add/remove remote listeners.
- ClientListProxy<E> - Class in com.hazelcast.client.proxy
-
Proxy implementation of
IList
.
- ClientListProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.proxy.ClientListProxy
-
- ClientLockProxy - Class in com.hazelcast.client.proxy
-
Proxy implementation of
ILock
.
- ClientLockProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.proxy.ClientLockProxy
-
- ClientLockReferenceIdGenerator - Class in com.hazelcast.client.impl
-
This class generates unique (per client) incrementing reference ID which is used during locking related requests.
- ClientLockReferenceIdGenerator() - Constructor for class com.hazelcast.client.impl.ClientLockReferenceIdGenerator
-
- ClientLoggingService - Class in com.hazelcast.client.impl
-
- ClientLoggingService(String, String, BuildInfo, String) - Constructor for class com.hazelcast.client.impl.ClientLoggingService
-
- ClientMapMetaDataFetcher - Class in com.hazelcast.client.map.impl.nearcache.invalidation
-
MetaDataFetcher
for client side usage
- ClientMapMetaDataFetcher(ClientContext) - Constructor for class com.hazelcast.client.map.impl.nearcache.invalidation.ClientMapMetaDataFetcher
-
- ClientMapPartitionIterator<K,V> - Class in com.hazelcast.client.map.impl
-
Iterator for iterating map entries in the partitionId
.
- ClientMapPartitionIterator(ClientMapProxy<K, V>, ClientContext, int, int, boolean) - Constructor for class com.hazelcast.client.map.impl.ClientMapPartitionIterator
-
- ClientMapProxy<K,V> - Class in com.hazelcast.client.proxy
-
Proxy implementation of
IMap
.
- ClientMapProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.proxy.ClientMapProxy
-
- ClientMapQueryPartitionIterator<K,V,R> - Class in com.hazelcast.client.map.impl
-
Iterator for iterating map entries in the partitionId
.
- ClientMapQueryPartitionIterator(ClientMapProxy<K, V>, ClientContext, int, int, Predicate<K, V>, Projection<Map.Entry<K, V>, R>) - Constructor for class com.hazelcast.client.map.impl.ClientMapQueryPartitionIterator
-
- ClientMapReduceProxy - Class in com.hazelcast.client.proxy
-
Proxy implementation of
JobTracker
for a client initiated map reduce job.
- ClientMapReduceProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.proxy.ClientMapReduceProxy
-
- ClientMessage - Class in com.hazelcast.client.impl.protocol
-
Client Message is the carrier framed data as defined below.
- ClientMessage() - Constructor for class com.hazelcast.client.impl.protocol.ClientMessage
-
- clientMessage - Variable in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-
- ClientMessageDecoder - Interface in com.hazelcast.client.impl
-
Interface to pass specific decode methods to generic data structures that is dealing with client message
- ClientMessageDecoder - Class in com.hazelcast.client.impl.protocol.util
-
- ClientMessageDecoder(Connection, ClientMessageHandler) - Constructor for class com.hazelcast.client.impl.protocol.util.ClientMessageDecoder
-
- ClientMessageEncoder - Class in com.hazelcast.client.impl.protocol.util
-
- ClientMessageEncoder() - Constructor for class com.hazelcast.client.impl.protocol.util.ClientMessageEncoder
-
- ClientMessageHandler - Interface in com.hazelcast.client.impl.protocol.util
-
Implementers will be responsible to messageHandler the constructed message
- ClientMessageSplitter - Class in com.hazelcast.client.impl.protocol.util
-
- ClientMultiMapProxy<K,V> - Class in com.hazelcast.client.proxy
-
- ClientMultiMapProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.proxy.ClientMultiMapProxy
-
- ClientNetworkConfig - Class in com.hazelcast.client.config
-
Contains configuration parameters for client network related behaviour
- ClientNetworkConfig() - Constructor for class com.hazelcast.client.config.ClientNetworkConfig
-
- ClientOutOfMemoryHandler - Class in com.hazelcast.client
-
To clear resources of the client upon OutOfMemory
- ClientOutOfMemoryHandler() - Constructor for class com.hazelcast.client.ClientOutOfMemoryHandler
-
- ClientPartitionListenerService - Class in com.hazelcast.client.impl
-
- ClientPartitionService - Interface in com.hazelcast.client.spi
-
Partition service for Hazelcast clients.
- ClientPartitionServiceImpl - Class in com.hazelcast.client.spi.impl
-
- ClientPartitionServiceImpl(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.spi.impl.ClientPartitionServiceImpl
-
- ClientPNCounterProxy - Class in com.hazelcast.client.proxy
-
- ClientPNCounterProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.proxy.ClientPNCounterProxy
-
- ClientPrincipal - Class in com.hazelcast.client.impl.client
-
- ClientPrincipal() - Constructor for class com.hazelcast.client.impl.client.ClientPrincipal
-
- ClientPrincipal(String, String) - Constructor for class com.hazelcast.client.impl.client.ClientPrincipal
-
- ClientProperty - Class in com.hazelcast.client.spi.properties
-
Defines the name and default value for Hazelcast Client properties.
- ClientProtocolBuffer - Interface in com.hazelcast.client.impl.protocol.util
-
Interface for buffer to be used in client protocol.
- ClientProtocolErrorCodes - Class in com.hazelcast.client.impl.protocol
-
Each exception that are defined in client protocol have unique identifier which are error code.
- ClientProxy - Class in com.hazelcast.client.spi
-
Base class for client proxies.
- ClientProxy(String, String) - Constructor for class com.hazelcast.client.spi.ClientProxy
-
- ClientProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.spi.ClientProxy
-
- ClientProxyDescriptor - Interface in com.hazelcast.client.spi
-
Descriptor of Hazelcast client proxies
Provided by corresponding provider (see com.hazelcast.client.spi.ClientProxyDescriptorProvider).
- ClientProxyDescriptorProvider - Interface in com.hazelcast.client.spi
-
It will be discovered from some external source (like META-INF/services) and registered in the system.
- ClientProxyFactory - Interface in com.hazelcast.client.spi
-
Factory interface creating client proxies.
- ClientProxyFactoryWithContext - Class in com.hazelcast.client.spi.impl
-
- ClientProxyFactoryWithContext() - Constructor for class com.hazelcast.client.spi.impl.ClientProxyFactoryWithContext
-
- ClientQueryCacheConfigurator - Class in com.hazelcast.client.impl.querycache.subscriber
-
- ClientQueryCacheConfigurator(ClientConfig, QueryCacheEventService) - Constructor for class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheConfigurator
-
- ClientQueryCacheContext - Class in com.hazelcast.client.impl.querycache
-
- ClientQueryCacheContext(ClientContext) - Constructor for class com.hazelcast.client.impl.querycache.ClientQueryCacheContext
-
- ClientQueryCacheEndToEndConstructor - Class in com.hazelcast.client.impl.querycache.subscriber
-
Client-side implementation of QueryCacheEndToEndConstructor
.
- ClientQueryCacheEndToEndConstructor(QueryCacheRequest) - Constructor for class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheEndToEndConstructor
-
- ClientQueryCacheEventService - Class in com.hazelcast.client.impl.querycache.subscriber
-
Client side event service implementation for query cache.
- ClientQueryCacheEventService(ClientContext) - Constructor for class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheEventService
-
- ClientQueryCacheScheduler - Class in com.hazelcast.client.impl.querycache.subscriber
-
Client side implementation of QueryCacheScheduler
.
- ClientQueryCacheScheduler(ClientExecutionService) - Constructor for class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheScheduler
-
- ClientQueueProxy<E> - Class in com.hazelcast.client.proxy
-
Proxy implementation of
IQueue
.
- ClientQueueProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.proxy.ClientQueueProxy
-
- ClientReAuthOperation - Class in com.hazelcast.client.impl.operations
-
- ClientReAuthOperation() - Constructor for class com.hazelcast.client.impl.operations.ClientReAuthOperation
-
- ClientReAuthOperation(String, long) - Constructor for class com.hazelcast.client.impl.operations.ClientReAuthOperation
-
- ClientReAuthOperation.ClientReauthTask - Class in com.hazelcast.client.impl.operations
-
- ClientReauthTask() - Constructor for class com.hazelcast.client.impl.operations.ClientReAuthOperation.ClientReauthTask
-
- ClientRegistrationKey - Class in com.hazelcast.client.spi.impl.listener
-
- ClientRegistrationKey(String, EventHandler, ListenerMessageCodec) - Constructor for class com.hazelcast.client.spi.impl.listener.ClientRegistrationKey
-
- ClientRegistrationKey(String) - Constructor for class com.hazelcast.client.spi.impl.listener.ClientRegistrationKey
-
- ClientReliableTopicConfig - Class in com.hazelcast.client.config
-
Contains the ReliableTopic configuration for a client.
- ClientReliableTopicConfig(String) - Constructor for class com.hazelcast.client.config.ClientReliableTopicConfig
-
Creates a new ReliableTopicConfig with default settings.
- ClientReliableTopicProxy<E> - Class in com.hazelcast.client.proxy
-
Reliable proxy implementation of
ITopic
.
- ClientReliableTopicProxy(String, ClientContext, HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.proxy.ClientReliableTopicProxy
-
- ClientReplicatedMapProxy<K,V> - Class in com.hazelcast.client.proxy
-
The replicated map client side proxy implementation proxying all requests to a member node
- ClientReplicatedMapProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.proxy.ClientReplicatedMapProxy
-
- ClientResponseHandler - Interface in com.hazelcast.client.spi.impl
-
Responsible for handling responses to invocations.
- ClientResponseHandlerSupplier - Class in com.hazelcast.client.spi.impl
-
- ClientResponseHandlerSupplier(AbstractClientInvocationService) - Constructor for class com.hazelcast.client.spi.impl.ClientResponseHandlerSupplier
-
- ClientRingbufferProxy<E> - Class in com.hazelcast.client.proxy
-
- ClientRingbufferProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.proxy.ClientRingbufferProxy
-
- ClientScheduledExecutorProxy - Class in com.hazelcast.client.proxy
-
- ClientScheduledExecutorProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.proxy.ClientScheduledExecutorProxy
-
- ClientScheduledFutureProxy<V> - Class in com.hazelcast.client.proxy
-
- ClientSecurityConfig - Class in com.hazelcast.client.config
-
Contains the security configuration for a client.
- ClientSecurityConfig() - Constructor for class com.hazelcast.client.config.ClientSecurityConfig
-
- ClientSemaphoreProxy - Class in com.hazelcast.client.proxy
-
- ClientSemaphoreProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.proxy.ClientSemaphoreProxy
-
- ClientService - Interface in com.hazelcast.core
-
ClientService allows you to query connected
Client
s and
attach/detach
ClientListener
s to listen to connection events.
- ClientServiceNotFoundException - Exception in com.hazelcast.client.spi.impl
-
- ClientServiceNotFoundException(String) - Constructor for exception com.hazelcast.client.spi.impl.ClientServiceNotFoundException
-
- ClientServiceProxy - Class in com.hazelcast.client.impl
-
- ClientServiceProxy(Node) - Constructor for class com.hazelcast.client.impl.ClientServiceProxy
-
- ClientSetProxy<E> - Class in com.hazelcast.client.proxy
-
Proxy implementation of
ISet
.
- ClientSetProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.proxy.ClientSetProxy
-
- ClientStateListener - Class in com.hazelcast.client.util
-
Helper class for the user to track the lifecycle state of the client.
- ClientStateListener(ClientConfig) - Constructor for class com.hazelcast.client.util.ClientStateListener
-
Registers this instance with the provided client configuration
- ClientStatisticsMessageTask - Class in com.hazelcast.client.impl.protocol.task
-
- ClientStatisticsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.ClientStatisticsMessageTask
-
- ClientSubscriberContext - Class in com.hazelcast.client.impl.querycache.subscriber
-
SubscriberContext
implementation for client side.
- ClientSubscriberContext(QueryCacheContext) - Constructor for class com.hazelcast.client.impl.querycache.subscriber.ClientSubscriberContext
-
- ClientSubscriberContextSupport - Class in com.hazelcast.client.impl.querycache.subscriber
-
SubscriberContextSupport
implementation for client side.
- ClientSubscriberContextSupport() - Constructor for class com.hazelcast.client.impl.querycache.subscriber.ClientSubscriberContextSupport
-
- ClientTopicProxy<E> - Class in com.hazelcast.client.proxy
-
Proxy implementation of
ITopic
.
- ClientTopicProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.proxy.ClientTopicProxy
-
- ClientTransactionContext - Interface in com.hazelcast.client.spi
-
Provides a context to perform transactional operations: beginning/committing transactions, but also retrieving
transactional data-structures like the
TransactionalMap
.
- ClientTransactionManagerService - Interface in com.hazelcast.client.spi
-
- ClientTransactionManagerServiceImpl - Class in com.hazelcast.client.spi.impl
-
- ClientTransactionManagerServiceImpl(HazelcastClientInstanceImpl, LoadBalancer) - Constructor for class com.hazelcast.client.spi.impl.ClientTransactionManagerServiceImpl
-
- ClientTransactionUtil - Class in com.hazelcast.client.proxy.txn
-
Contains static method that is used from client transaction classes.
- ClientTxnListProxy<E> - Class in com.hazelcast.client.proxy.txn
-
- ClientTxnListProxy(String, ClientTransactionContext) - Constructor for class com.hazelcast.client.proxy.txn.ClientTxnListProxy
-
- ClientTxnMapProxy<K,V> - Class in com.hazelcast.client.proxy.txn
-
- ClientTxnMapProxy(String, ClientTransactionContext) - Constructor for class com.hazelcast.client.proxy.txn.ClientTxnMapProxy
-
- ClientTxnMultiMapProxy<K,V> - Class in com.hazelcast.client.proxy.txn
-
- ClientTxnMultiMapProxy(String, ClientTransactionContext) - Constructor for class com.hazelcast.client.proxy.txn.ClientTxnMultiMapProxy
-
- ClientTxnQueueProxy<E> - Class in com.hazelcast.client.proxy.txn
-
- ClientTxnQueueProxy(String, ClientTransactionContext) - Constructor for class com.hazelcast.client.proxy.txn.ClientTxnQueueProxy
-
- ClientTxnSetProxy<E> - Class in com.hazelcast.client.proxy.txn
-
- ClientTxnSetProxy(String, ClientTransactionContext) - Constructor for class com.hazelcast.client.proxy.txn.ClientTxnSetProxy
-
- ClientType - Enum in com.hazelcast.core
-
Type of a client.
- clientType - Variable in class com.hazelcast.internal.management.dto.ClientEndPointDTO
-
- ClientTypes - Class in com.hazelcast.client
-
Constants class that contains the different types of clients.
- ClientUserCodeDeploymentConfig - Class in com.hazelcast.client.config
-
Configuration of User Code Deployment.
- ClientUserCodeDeploymentConfig() - Constructor for class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
-
- ClientUserCodeDeploymentService - Class in com.hazelcast.client.spi.impl
-
- ClientUserCodeDeploymentService(ClientUserCodeDeploymentConfig, ClassLoader) - Constructor for class com.hazelcast.client.spi.impl.ClientUserCodeDeploymentService
-
- Clock - Class in com.hazelcast.util
-
Abstracts the system clock to simulate different clocks without changing the actual system time.
- Clock.ClockImpl - Class in com.hazelcast.util
-
Extend this class if you want to provide your own clock implementation.
- ClockImpl() - Constructor for class com.hazelcast.util.Clock.ClockImpl
-
- ClockProperties - Class in com.hazelcast.util
-
Utility class to set system parameters for the clock implementation.
- clone() - Method in class com.hazelcast.monitor.TimedMemberState
-
- clone() - Method in class com.hazelcast.util.collection.InflatableSet
-
Returns a shallow copy of this InflatableSet instance: the keys and
values themselves are not cloned.
- cloneWithoutValue() - Method in class com.hazelcast.map.impl.querycache.event.LocalEntryEventData
-
- close() - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- close(ClassLoader) - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- close(URI, ClassLoader) - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- close(boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- close() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- close() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- close(ClassLoader) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- close(URI, ClassLoader) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- close(boolean) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Close is equivalent to below operations in the given order:
close resources.
unregister all listeners.
- close() - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
-
- close(String, Throwable) - Method in class com.hazelcast.client.connection.nio.ClientConnection
-
- close() - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
-
- close() - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
-
- close() - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
-
- close() - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
-
- close() - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
-
- close() - Method in class com.hazelcast.internal.networking.AbstractChannel
-
- close() - Method in interface com.hazelcast.internal.networking.Channel
-
Closes the Channel.
- close() - Method in class com.hazelcast.internal.networking.nio.NioInboundPipeline
-
- close() - Method in class com.hazelcast.internal.networking.nio.NioOutboundPipeline
-
- close() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-
- close() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
-
- close() - Method in class com.hazelcast.internal.usercodedeployment.impl.GlobalMutex
-
- close() - Method in class com.hazelcast.internal.util.BufferingInputStream
-
- close() - Method in class com.hazelcast.mapreduce.impl.ListKeyValueSource
-
- close() - Method in class com.hazelcast.mapreduce.impl.MapKeyValueSource
-
- close() - Method in class com.hazelcast.mapreduce.impl.MultiMapKeyValueSource
-
- close() - Method in class com.hazelcast.mapreduce.impl.SetKeyValueSource
-
- close(String, Throwable) - Method in interface com.hazelcast.nio.Connection
-
Closes this connection.
- close(ServerSocket) - Static method in class com.hazelcast.nio.IOUtil
-
Quietly attempts to close a
ServerSocket
, swallowing any exception.
- close(String, Throwable) - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- close(EventRegistration) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-
- close(EventRegistration) - Method in interface com.hazelcast.spi.impl.eventservice.InternalEventService
-
Closes an EventRegistration.
- close() - Method in class com.hazelcast.util.ContextMutexFactory.Mutex
-
- closeableListeners - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-
- closeConnection() - Method in class com.hazelcast.nio.ascii.TextDecoder
-
- closeInbound() - Method in class com.hazelcast.internal.networking.AbstractChannel
-
- closeInbound() - Method in interface com.hazelcast.internal.networking.Channel
-
Closes inbound.
- closeListeners() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- closeOutbound() - Method in class com.hazelcast.internal.networking.AbstractChannel
-
- closeOutbound() - Method in interface com.hazelcast.internal.networking.Channel
-
Closes outbound.
- closeResource(Closeable) - Static method in class com.hazelcast.nio.IOUtil
-
Quietly attempts to close a
Closeable
resource, swallowing any exception.
- closeSegments(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- CLOUD_URL_BASE_PROPERTY - Static variable in class com.hazelcast.client.spi.impl.discovery.HazelcastCloudDiscovery
-
Internal client property to change base url of cloud discovery endpoint.
- Cluster - Interface in com.hazelcast.core
-
Hazelcast cluster interface.
- CLUSTER - Static variable in class com.hazelcast.nio.Protocols
-
Protocol that is used among nodes
- CLUSTER_SHUTDOWN_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
- CLUSTER_STATE_CHANGE - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
-
- CLUSTER_STATE_TRANSACTION_LOG_RECORD - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
-
- ClusterClock - Interface in com.hazelcast.internal.cluster
-
- ClusterClockImpl - Class in com.hazelcast.internal.cluster.impl
-
- ClusterClockImpl(ILogger) - Constructor for class com.hazelcast.internal.cluster.impl.ClusterClockImpl
-
- ClusterDataSerializerHook - Class in com.hazelcast.internal.cluster.impl
-
- ClusterDataSerializerHook() - Constructor for class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
-
- ClusterFailureDetector - Interface in com.hazelcast.internal.cluster.fd
-
Cluster failure detector tracks heartbeats of the members and decides liveness/availability of them.
- ClusterFailureDetectorType - Enum in com.hazelcast.internal.cluster.fd
-
- ClusterHeartbeatManager - Class in com.hazelcast.internal.cluster.impl
-
ClusterHeartbeatManager manages the heartbeat sending and receiving
process of a node.
- ClusterHotRestartStatusDTO - Class in com.hazelcast.internal.management.dto
-
A DTO for Hot Restart status of cluster and all members.
- ClusterHotRestartStatusDTO() - Constructor for class com.hazelcast.internal.management.dto.ClusterHotRestartStatusDTO
-
- ClusterHotRestartStatusDTO(HotRestartClusterDataRecoveryPolicy, ClusterHotRestartStatusDTO.ClusterHotRestartStatus, long, long, Map<String, ClusterHotRestartStatusDTO.MemberHotRestartStatus>) - Constructor for class com.hazelcast.internal.management.dto.ClusterHotRestartStatusDTO
-
- ClusterHotRestartStatusDTO.ClusterHotRestartStatus - Enum in com.hazelcast.internal.management.dto
-
- ClusterHotRestartStatusDTO.MemberHotRestartStatus - Enum in com.hazelcast.internal.management.dto
-
- clusterJoinManager - Variable in class com.hazelcast.internal.cluster.impl.AbstractJoiner
-
- ClusterJoinManager - Class in com.hazelcast.internal.cluster.impl
-
ClusterJoinManager manages member join process.
- ClusterPermission - Class in com.hazelcast.security.permission
-
- ClusterPermission(String) - Constructor for class com.hazelcast.security.permission.ClusterPermission
-
- ClusterPermissionCollection - Class in com.hazelcast.security.permission
-
- ClusterPermissionCollection() - Constructor for class com.hazelcast.security.permission.ClusterPermissionCollection
-
- ClusterPermissionCollection(Class<? extends Permission>) - Constructor for class com.hazelcast.security.permission.ClusterPermissionCollection
-
- ClusterPropsRequest - Class in com.hazelcast.internal.management.request
-
Request for cluster properties.
- ClusterPropsRequest() - Constructor for class com.hazelcast.internal.management.request.ClusterPropsRequest
-
- clusterService - Variable in class com.hazelcast.instance.Node
-
- ClusterService - Interface in com.hazelcast.internal.cluster
-
A service responsible for member related functionality, e.g.
- clusterService - Variable in class com.hazelcast.internal.cluster.impl.AbstractJoiner
-
- clusterService - Variable in class com.hazelcast.map.impl.query.MapQueryEngineImpl
-
- clusterService - Variable in class com.hazelcast.map.impl.query.PartitionScanRunner
-
- clusterService - Variable in class com.hazelcast.map.impl.query.QueryRunner
-
- ClusterServiceImpl - Class in com.hazelcast.internal.cluster.impl
-
- ClusterServiceImpl(Node, MemberImpl) - Constructor for class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
-
- ClusterState - Enum in com.hazelcast.cluster
-
ClusterState
consists several states of the cluster
which each state can allow and/or deny specific actions
and/or change behaviours of specific actions.
- ClusterStateChange<T> - Class in com.hazelcast.internal.cluster.impl
-
Wrapper object indicating a change in the cluster state - it may be cluster state change or cluster version change.
- ClusterStateChange() - Constructor for class com.hazelcast.internal.cluster.impl.ClusterStateChange
-
- ClusterStateChange(T) - Constructor for class com.hazelcast.internal.cluster.impl.ClusterStateChange
-
- ClusterStateListener - Interface in com.hazelcast.internal.cluster
-
Used by services which needs to act against new cluster state.
- ClusterStateManager - Class in com.hazelcast.internal.cluster.impl
-
ClusterStateManager stores cluster state and manages cluster state transactions.
- ClusterStateTransactionLogRecord - Class in com.hazelcast.internal.cluster.impl
-
TransactionLogRecord implementation to be used in ClusterState
transactions.
- ClusterStateTransactionLogRecord() - Constructor for class com.hazelcast.internal.cluster.impl.ClusterStateTransactionLogRecord
-
- ClusterStateTransactionLogRecord(ClusterStateChange, Address, Address, String, long, int, boolean) - Constructor for class com.hazelcast.internal.cluster.impl.ClusterStateTransactionLogRecord
-
- ClusterTopologyChangedException - Exception in com.hazelcast.internal.cluster.impl
-
Thrown when a cluster topology change is detected.
- ClusterTopologyChangedException() - Constructor for exception com.hazelcast.internal.cluster.impl.ClusterTopologyChangedException
-
- ClusterTopologyChangedException(String) - Constructor for exception com.hazelcast.internal.cluster.impl.ClusterTopologyChangedException
-
- ClusterVersionListener - Interface in com.hazelcast.internal.cluster
-
Listeners interested in acting upon cluster version update should implement this interface.
- clusterVersionListeners - Variable in class com.hazelcast.instance.DefaultNodeExtension
-
- ClusterWideConfigurationService - Class in com.hazelcast.internal.dynamicconfig
-
- ClusterWideConfigurationService(NodeEngine, DynamicConfigListener) - Constructor for class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
-
- ClusterWideConfigurationService.Merger - Class in com.hazelcast.internal.dynamicconfig
-
- ClusterWideIterator<K,V> - Class in com.hazelcast.cache.impl
-
Cluster-wide iterator for
ICache
.
- ClusterWideIterator(CacheProxy<K, V>, boolean) - Constructor for class com.hazelcast.cache.impl.ClusterWideIterator
-
- ClusterWideIterator(CacheProxy<K, V>, int, boolean) - Constructor for class com.hazelcast.cache.impl.ClusterWideIterator
-
- ClusterWideIterator(CacheProxy<K, V>, int, int, boolean) - Constructor for class com.hazelcast.cache.impl.ClusterWideIterator
-
- clusterWideUpdateManagementCenterUrl(String, String, String) - Method in class com.hazelcast.internal.management.ManagementCenterService
-
- CoalescingDelayedTrigger - Class in com.hazelcast.util.scheduler
-
Coalescing trigger can be used when you want coalesce multiple execution of
Runnable
.
- CoalescingDelayedTrigger(ExecutionService, long, long, Runnable) - Constructor for class com.hazelcast.util.scheduler.CoalescingDelayedTrigger
-
- collate(Iterable<ValueIn>) - Method in interface com.hazelcast.mapreduce.Collator
-
Deprecated.
This method is called with the mapped and possibly reduced values from the MapReduce algorithm.
- Collator<ValueIn,ValueOut> - Interface in com.hazelcast.mapreduce
-
- COLLECT_REMOTE_TX - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
-
- COLLECT_REMOTE_TX_FACTORY - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
-
- COLLECTION - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
-
- COLLECTION - Static variable in class com.hazelcast.spi.impl.SpiPortableHook
-
- COLLECTION_ADD - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_ADD_ALL - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_ADD_ALL_BACKUP - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_ADD_BACKUP - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_CLEAR - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_CLEAR_BACKUP - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_COMPARE_AND_REMOVE - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_CONTAINS - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- COLLECTION_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- COLLECTION_EVENT - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_EVENT_FILTER - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_GET_ALL - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_IS_EMPTY - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_ITEM - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_MERGE - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_MERGE_BACKUP - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_MERGING_VALUE - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
-
- COLLECTION_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- COLLECTION_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- COLLECTION_PREPARE - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_PREPARE_BACKUP - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_REMOVE - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_REMOVE_BACKUP - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_RESERVE_ADD - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_RESERVE_REMOVE - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_ROLLBACK - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_ROLLBACK_BACKUP - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_SIZE - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_TRANSACTION_LOG_RECORD - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_TXN_ADD - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_TXN_ADD_BACKUP - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_TXN_REMOVE - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- COLLECTION_TXN_REMOVE_BACKUP - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- CollectionAddAllBackupOperation - Class in com.hazelcast.collection.impl.collection.operations
-
- CollectionAddAllBackupOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionAddAllBackupOperation
-
- CollectionAddAllBackupOperation(String, Map<Long, Data>) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionAddAllBackupOperation
-
- CollectionAddAllOperation - Class in com.hazelcast.collection.impl.collection.operations
-
- CollectionAddAllOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionAddAllOperation
-
- CollectionAddAllOperation(String, List<Data>) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionAddAllOperation
-
- CollectionAddBackupOperation - Class in com.hazelcast.collection.impl.collection.operations
-
- CollectionAddBackupOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionAddBackupOperation
-
- CollectionAddBackupOperation(String, long, Data) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionAddBackupOperation
-
- CollectionAddOperation - Class in com.hazelcast.collection.impl.collection.operations
-
- CollectionAddOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionAddOperation
-
- CollectionAddOperation(String, Data) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionAddOperation
-
- CollectionBackupAwareOperation - Class in com.hazelcast.collection.impl.collection.operations
-
- CollectionBackupAwareOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionBackupAwareOperation
-
- CollectionBackupAwareOperation(String) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionBackupAwareOperation
-
- CollectionClearBackupOperation - Class in com.hazelcast.collection.impl.collection.operations
-
- CollectionClearBackupOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionClearBackupOperation
-
- CollectionClearBackupOperation(String, Set<Long>) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionClearBackupOperation
-
- CollectionClearOperation - Class in com.hazelcast.collection.impl.collection.operations
-
- CollectionClearOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionClearOperation
-
- CollectionClearOperation(String) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionClearOperation
-
- CollectionCommitBackupOperation - Class in com.hazelcast.collection.impl.txncollection.operations
-
a wrapper for running all commit backup operations at once
- CollectionCommitBackupOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitBackupOperation
-
- CollectionCommitBackupOperation(String, String, List<Operation>) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitBackupOperation
-
- CollectionCommitOperation - Class in com.hazelcast.collection.impl.txncollection.operations
-
a wrapper for running all commit operations at once
- CollectionCommitOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitOperation
-
- CollectionCommitOperation(int, String, String, List<Operation>) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitOperation
-
- CollectionCompareAndRemoveOperation - Class in com.hazelcast.collection.impl.collection.operations
-
- CollectionCompareAndRemoveOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionCompareAndRemoveOperation
-
- CollectionCompareAndRemoveOperation(String, boolean, Set<Data>) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionCompareAndRemoveOperation
-
- CollectionConfig<T extends CollectionConfig> - Class in com.hazelcast.config
-
Provides configuration service for Collection.
- CollectionConfig() - Constructor for class com.hazelcast.config.CollectionConfig
-
- CollectionConfig(CollectionConfig) - Constructor for class com.hazelcast.config.CollectionConfig
-
- CollectionContainer - Class in com.hazelcast.collection.impl.collection
-
- CollectionContainer() - Constructor for class com.hazelcast.collection.impl.collection.CollectionContainer
-
- CollectionContainer(String, NodeEngine) - Constructor for class com.hazelcast.collection.impl.collection.CollectionContainer
-
- CollectionContainsOperation - Class in com.hazelcast.collection.impl.collection.operations
-
- CollectionContainsOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionContainsOperation
-
- CollectionContainsOperation(String, Set<Data>) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionContainsOperation
-
- CollectionDataSerializerHook - Class in com.hazelcast.collection.impl.collection
-
- CollectionDataSerializerHook() - Constructor for class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- CollectionEvent - Class in com.hazelcast.collection.impl.collection
-
- CollectionEvent() - Constructor for class com.hazelcast.collection.impl.collection.CollectionEvent
-
- CollectionEvent(String, Data, ItemEventType, Address) - Constructor for class com.hazelcast.collection.impl.collection.CollectionEvent
-
- CollectionEventFilter - Class in com.hazelcast.collection.impl.collection
-
- CollectionEventFilter() - Constructor for class com.hazelcast.collection.impl.collection.CollectionEventFilter
-
- CollectionEventFilter(boolean) - Constructor for class com.hazelcast.collection.impl.collection.CollectionEventFilter
-
- CollectionGetAllOperation - Class in com.hazelcast.collection.impl.collection.operations
-
- CollectionGetAllOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionGetAllOperation
-
- CollectionGetAllOperation(String) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionGetAllOperation
-
- CollectionIsEmptyOperation - Class in com.hazelcast.collection.impl.collection.operations
-
- CollectionIsEmptyOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionIsEmptyOperation
-
- CollectionIsEmptyOperation(String) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionIsEmptyOperation
-
- CollectionItem - Class in com.hazelcast.collection.impl.collection
-
- CollectionItem() - Constructor for class com.hazelcast.collection.impl.collection.CollectionItem
-
- CollectionItem(long, Data) - Constructor for class com.hazelcast.collection.impl.collection.CollectionItem
-
- CollectionMergeBackupOperation - Class in com.hazelcast.collection.impl.collection.operations
-
- CollectionMergeBackupOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionMergeBackupOperation
-
- CollectionMergeBackupOperation(String, Collection<CollectionItem>) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionMergeBackupOperation
-
- CollectionMergeOperation - Class in com.hazelcast.collection.impl.collection.operations
-
- CollectionMergeOperation(String, SplitBrainMergePolicy<Collection<Object>, SplitBrainMergeTypes.CollectionMergeTypes>, SplitBrainMergeTypes.CollectionMergeTypes) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionMergeOperation
-
- CollectionMergeOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionMergeOperation
-
- CollectionMergingValueImpl - Class in com.hazelcast.spi.impl.merge
-
- CollectionMergingValueImpl() - Constructor for class com.hazelcast.spi.impl.merge.CollectionMergingValueImpl
-
- CollectionMergingValueImpl(SerializationService) - Constructor for class com.hazelcast.spi.impl.merge.CollectionMergingValueImpl
-
- CollectionOperation - Class in com.hazelcast.collection.impl.collection.operations
-
- CollectionOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionOperation
-
- CollectionOperation(String) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionOperation
-
- CollectionPrepareBackupOperation - Class in com.hazelcast.collection.impl.txncollection.operations
-
- CollectionPrepareBackupOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareBackupOperation
-
- CollectionPrepareBackupOperation(String, long[], String) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareBackupOperation
-
- CollectionPrepareOperation - Class in com.hazelcast.collection.impl.txncollection.operations
-
- CollectionPrepareOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareOperation
-
- CollectionPrepareOperation(int, String, String, long[], String) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareOperation
-
- CollectionRemoveBackupOperation - Class in com.hazelcast.collection.impl.collection.operations
-
- CollectionRemoveBackupOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionRemoveBackupOperation
-
- CollectionRemoveBackupOperation(String, long) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionRemoveBackupOperation
-
- CollectionRemoveOperation - Class in com.hazelcast.collection.impl.collection.operations
-
- CollectionRemoveOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionRemoveOperation
-
- CollectionRemoveOperation(String, Data) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionRemoveOperation
-
- CollectionReplicationOperation - Class in com.hazelcast.collection.impl.collection.operations
-
- CollectionReplicationOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionReplicationOperation
-
- CollectionReplicationOperation(Map<String, CollectionContainer>, int, int) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionReplicationOperation
-
- CollectionReserveAddOperation - Class in com.hazelcast.collection.impl.txncollection.operations
-
- CollectionReserveAddOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveAddOperation
-
- CollectionReserveAddOperation(String, String, Data) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveAddOperation
-
- CollectionReserveRemoveOperation - Class in com.hazelcast.collection.impl.txncollection.operations
-
- CollectionReserveRemoveOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveRemoveOperation
-
- CollectionReserveRemoveOperation(String, long, Data, String) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveRemoveOperation
-
- CollectionRollbackBackupOperation - Class in com.hazelcast.collection.impl.txncollection.operations
-
- CollectionRollbackBackupOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackBackupOperation
-
- CollectionRollbackBackupOperation(String, long[]) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackBackupOperation
-
- CollectionRollbackOperation - Class in com.hazelcast.collection.impl.txncollection.operations
-
- CollectionRollbackOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackOperation
-
- CollectionRollbackOperation(int, String, String, long[]) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackOperation
-
- CollectionService - Class in com.hazelcast.collection.impl.collection
-
- CollectionService(NodeEngine) - Constructor for class com.hazelcast.collection.impl.collection.CollectionService
-
- CollectionSizeOperation - Class in com.hazelcast.collection.impl.collection.operations
-
- CollectionSizeOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionSizeOperation
-
- CollectionSizeOperation(String) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionSizeOperation
-
- CollectionTransactionLogRecord - Class in com.hazelcast.collection.impl.txncollection
-
This class contains Transaction log for the Collection.
- CollectionTransactionLogRecord() - Constructor for class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
-
- CollectionTransactionLogRecord(String, String, String, int) - Constructor for class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
-
- CollectionTransactionRollbackOperation - Class in com.hazelcast.collection.impl.txncollection.operations
-
- CollectionTransactionRollbackOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionTransactionRollbackOperation
-
- CollectionTransactionRollbackOperation(String, String) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionTransactionRollbackOperation
-
- CollectionTxnAddBackupOperation - Class in com.hazelcast.collection.impl.txncollection.operations
-
- CollectionTxnAddBackupOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddBackupOperation
-
- CollectionTxnAddBackupOperation(String, long, Data) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddBackupOperation
-
- CollectionTxnAddOperation - Class in com.hazelcast.collection.impl.txncollection.operations
-
- CollectionTxnAddOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddOperation
-
- CollectionTxnAddOperation(String, long, Data) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddOperation
-
- CollectionTxnOperation - Interface in com.hazelcast.collection.impl.txncollection
-
- CollectionTxnRemoveBackupOperation - Class in com.hazelcast.collection.impl.txncollection.operations
-
- CollectionTxnRemoveBackupOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveBackupOperation
-
- CollectionTxnRemoveBackupOperation(String, long) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveBackupOperation
-
- CollectionTxnRemoveOperation - Class in com.hazelcast.collection.impl.txncollection.operations
-
- CollectionTxnRemoveOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveOperation
-
- CollectionTxnRemoveOperation(String, long) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveOperation
-
- CollectionTxnUtil - Class in com.hazelcast.collection.impl
-
- CollectionUtil - Class in com.hazelcast.util
-
Various collection utility methods.
- collectMetrics(Object...) - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
-
- collectMetrics(Object...) - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
-
- collector - Variable in class com.hazelcast.spi.impl.merge.AbstractContainerMerger
-
- CollectRemoteTransactionsOperation - Class in com.hazelcast.transaction.impl.xa.operations
-
- CollectRemoteTransactionsOperation() - Constructor for class com.hazelcast.transaction.impl.xa.operations.CollectRemoteTransactionsOperation
-
- CollectRemoteTransactionsOperationSupplier - Class in com.hazelcast.client.impl
-
- CollectRemoteTransactionsOperationSupplier() - Constructor for class com.hazelcast.client.impl.CollectRemoteTransactionsOperationSupplier
-
- com.hazelcast - package com.hazelcast
-
This package contains PlaceHolder
- com.hazelcast.aggregation - package com.hazelcast.aggregation
-
Contains classes related to aggregations.
- com.hazelcast.aggregation.impl - package com.hazelcast.aggregation.impl
-
- com.hazelcast.buildutils - package com.hazelcast.buildutils
-
This module contains Maven and other build additions that are used by
Hazelcast to build bundle modules
- com.hazelcast.cache - package com.hazelcast.cache
-
This package contains the public API extension for Hazelcast JCache,
the Hazelcast implementation of the JSR-107 commonly referred to as JCache.
- com.hazelcast.cache.impl - package com.hazelcast.cache.impl
-
Hazelcast JSR-107 aka JCache implementation
- com.hazelcast.cache.impl.event - package com.hazelcast.cache.impl.event
-
Event classes to define listenters for JCache other than EntryListener
- com.hazelcast.cache.impl.journal - package com.hazelcast.cache.impl.journal
-
- com.hazelcast.cache.impl.maxsize - package com.hazelcast.cache.impl.maxsize
-
Max-Size policy interfaces for cache.
- com.hazelcast.cache.impl.maxsize.impl - package com.hazelcast.cache.impl.maxsize.impl
-
Max-Size policy implementations for cache.
- com.hazelcast.cache.impl.merge - package com.hazelcast.cache.impl.merge
-
This package contains merge functionality for Hazelcast cache.
- com.hazelcast.cache.impl.merge.entry - package com.hazelcast.cache.impl.merge.entry
-
This package contains merge entry internal interfaces and functionality for Hazelcast cache.
- com.hazelcast.cache.impl.merge.policy - package com.hazelcast.cache.impl.merge.policy
-
This package contains merge policy internal interfaces and functionality for Hazelcast cache.
- com.hazelcast.cache.impl.operation - package com.hazelcast.cache.impl.operation
-
Hazelcast JSR-107 aka JCache implementation
- com.hazelcast.cache.impl.record - package com.hazelcast.cache.impl.record
-
Hazelcast JSR-107 aka JCache implementation
Internal record store
- com.hazelcast.cache.journal - package com.hazelcast.cache.journal
-
- com.hazelcast.cache.merge - package com.hazelcast.cache.merge
-
Contains out-of-the-box merge policies for
ICache
.
- com.hazelcast.cardinality - package com.hazelcast.cardinality
-
This package contains Cardinality Estimator functionality for Hazelcast.
- com.hazelcast.cardinality.impl - package com.hazelcast.cardinality.impl
-
- com.hazelcast.cardinality.impl.hyperloglog - package com.hazelcast.cardinality.impl.hyperloglog
-
This package contains spec for the HyperLogLog data-structure.
- com.hazelcast.cardinality.impl.hyperloglog.impl - package com.hazelcast.cardinality.impl.hyperloglog.impl
-
- com.hazelcast.cardinality.impl.operations - package com.hazelcast.cardinality.impl.operations
-
- com.hazelcast.client - package com.hazelcast.client
-
Contains classes/interfaces related to Client
- com.hazelcast.client.cache.impl - package com.hazelcast.client.cache.impl
-
Hazelcast JSR-107 aka JCache implementation client side
- com.hazelcast.client.cache.impl.nearcache.invalidation - package com.hazelcast.client.cache.impl.nearcache.invalidation
-
- com.hazelcast.client.config - package com.hazelcast.client.config
-
Contains classes related to config for com.hazelcast.client
- com.hazelcast.client.connection - package com.hazelcast.client.connection
-
Provides connection interfaces/classes for com.hazelcast.client
- com.hazelcast.client.connection.nio - package com.hazelcast.client.connection.nio
-
Contains classes related to New IO for com.hazelcast.client.connection
- com.hazelcast.client.console - package com.hazelcast.client.console
-
This package contains ClientConsoleApp
- com.hazelcast.client.impl - package com.hazelcast.client.impl
-
Contains most of the client side HazelcastInstance implementation functionality.
- com.hazelcast.client.impl.client - package com.hazelcast.client.impl.client
-
This contains the Requests and other DTO's exchanged between client/server
- com.hazelcast.client.impl.operations - package com.hazelcast.client.impl.operations
-
Contains client operations
- com.hazelcast.client.impl.protocol - package com.hazelcast.client.impl.protocol
-
Client protocol related private implementation classes
- com.hazelcast.client.impl.protocol.exception - package com.hazelcast.client.impl.protocol.exception
-
- com.hazelcast.client.impl.protocol.task - package com.hazelcast.client.impl.protocol.task
-
Client tasks associated with requests.
- com.hazelcast.client.impl.protocol.task.atomiclong - package com.hazelcast.client.impl.protocol.task.atomiclong
-
Client protocol tasks implementations for AtomicLong
- com.hazelcast.client.impl.protocol.task.atomicreference - package com.hazelcast.client.impl.protocol.task.atomicreference
-
Client protocol tasks implementations for AtomicReference
- com.hazelcast.client.impl.protocol.task.cache - package com.hazelcast.client.impl.protocol.task.cache
-
Client protocol tasks implementations for JCache
- com.hazelcast.client.impl.protocol.task.cardinality - package com.hazelcast.client.impl.protocol.task.cardinality
-
- com.hazelcast.client.impl.protocol.task.condition - package com.hazelcast.client.impl.protocol.task.condition
-
Client protocol tasks implementations for Condition
- com.hazelcast.client.impl.protocol.task.countdownlatch - package com.hazelcast.client.impl.protocol.task.countdownlatch
-
Client protocol tasks implementations for CountDownLatch
- com.hazelcast.client.impl.protocol.task.crdt.pncounter - package com.hazelcast.client.impl.protocol.task.crdt.pncounter
-
- com.hazelcast.client.impl.protocol.task.dynamicconfig - package com.hazelcast.client.impl.protocol.task.dynamicconfig
-
- com.hazelcast.client.impl.protocol.task.executorservice - package com.hazelcast.client.impl.protocol.task.executorservice
-
Client protocol tasks implementations for ExecutorService
- com.hazelcast.client.impl.protocol.task.executorservice.durable - package com.hazelcast.client.impl.protocol.task.executorservice.durable
-
- com.hazelcast.client.impl.protocol.task.list - package com.hazelcast.client.impl.protocol.task.list
-
Client protocol tasks implementations for List
- com.hazelcast.client.impl.protocol.task.lock - package com.hazelcast.client.impl.protocol.task.lock
-
Client protocol tasks implementations for ILock
- com.hazelcast.client.impl.protocol.task.map - package com.hazelcast.client.impl.protocol.task.map
-
Client protocol tasks implementations for map
- com.hazelcast.client.impl.protocol.task.mapreduce - package com.hazelcast.client.impl.protocol.task.mapreduce
-
Client protocol tasks implementations for map reduce
- com.hazelcast.client.impl.protocol.task.multimap - package com.hazelcast.client.impl.protocol.task.multimap
-
Client protocol tasks implementations for multi map
- com.hazelcast.client.impl.protocol.task.queue - package com.hazelcast.client.impl.protocol.task.queue
-
Client protocol tasks implementations for Queue
- com.hazelcast.client.impl.protocol.task.replicatedmap - package com.hazelcast.client.impl.protocol.task.replicatedmap
-
Client protocol tasks implementations for ReplicatedMap
- com.hazelcast.client.impl.protocol.task.ringbuffer - package com.hazelcast.client.impl.protocol.task.ringbuffer
-
Client protocol tasks implementations for Ringbuffer
- com.hazelcast.client.impl.protocol.task.scheduledexecutor - package com.hazelcast.client.impl.protocol.task.scheduledexecutor
-
- com.hazelcast.client.impl.protocol.task.semaphore - package com.hazelcast.client.impl.protocol.task.semaphore
-
Client protocol tasks implementations for Semaphore
- com.hazelcast.client.impl.protocol.task.set - package com.hazelcast.client.impl.protocol.task.set
-
Client protocol tasks implementations for set
- com.hazelcast.client.impl.protocol.task.topic - package com.hazelcast.client.impl.protocol.task.topic
-
Client protocol tasks implementations for Topic
- com.hazelcast.client.impl.protocol.task.transaction - package com.hazelcast.client.impl.protocol.task.transaction
-
Client protocol tasks implementations for Transaction related
- com.hazelcast.client.impl.protocol.task.transactionallist - package com.hazelcast.client.impl.protocol.task.transactionallist
-
Client protocol tasks implementations for Transactional List
- com.hazelcast.client.impl.protocol.task.transactionalmap - package com.hazelcast.client.impl.protocol.task.transactionalmap
-
Client protocol tasks implementations for Transactional Map
- com.hazelcast.client.impl.protocol.task.transactionalmultimap - package com.hazelcast.client.impl.protocol.task.transactionalmultimap
-
Client protocol tasks implementations for Transactional MultiMap
- com.hazelcast.client.impl.protocol.task.transactionalqueue - package com.hazelcast.client.impl.protocol.task.transactionalqueue
-
Client protocol tasks implementations for Transactional Queue
- com.hazelcast.client.impl.protocol.task.transactionalset - package com.hazelcast.client.impl.protocol.task.transactionalset
-
Client protocol tasks implementations for Transactional Set
- com.hazelcast.client.impl.protocol.util - package com.hazelcast.client.impl.protocol.util
-
Protocol utils
- com.hazelcast.client.impl.querycache - package com.hazelcast.client.impl.querycache
-
Contains query cache internal implementations for client side.
- com.hazelcast.client.impl.querycache.subscriber - package com.hazelcast.client.impl.querycache.subscriber
-
Contains Hazelcast Enterprise version client-side query cache
subscriber implementation classes.
- com.hazelcast.client.impl.statistics - package com.hazelcast.client.impl.statistics
-
- com.hazelcast.client.map.impl - package com.hazelcast.client.map.impl
-
- com.hazelcast.client.map.impl.nearcache.invalidation - package com.hazelcast.client.map.impl.nearcache.invalidation
-
- com.hazelcast.client.proxy - package com.hazelcast.client.proxy
-
This package contains client side proxy implementations of the different Hazelcast data structures
and operation types
- com.hazelcast.client.proxy.txn - package com.hazelcast.client.proxy.txn
-
Contains classes related to proxy for client transactions
- com.hazelcast.client.proxy.txn.xa - package com.hazelcast.client.proxy.txn.xa
-
Contains classes related to proxy for XA
- com.hazelcast.client.spi - package com.hazelcast.client.spi
-
Contains classes/interfaces related to the Hazelcast client Service Provider Interface.
- com.hazelcast.client.spi.impl - package com.hazelcast.client.spi.impl
-
Provides util classes for the Hazelcast client SPI.
- com.hazelcast.client.spi.impl.discovery - package com.hazelcast.client.spi.impl.discovery
-
- com.hazelcast.client.spi.impl.listener - package com.hazelcast.client.spi.impl.listener
-
- com.hazelcast.client.spi.properties - package com.hazelcast.client.spi.properties
-
Contains the Hazelcast client properties implementation.
- com.hazelcast.client.util - package com.hazelcast.client.util
-
This package contains some utility classes and the base implementations of the
loadbalancer implementations
- com.hazelcast.cluster - package com.hazelcast.cluster
-
This package contains the cluster functionality.
- com.hazelcast.cluster.impl - package com.hazelcast.cluster.impl
-
- com.hazelcast.cluster.memberselector - package com.hazelcast.cluster.memberselector
-
- com.hazelcast.collection.impl - package com.hazelcast.collection.impl
-
- com.hazelcast.collection.impl.collection - package com.hazelcast.collection.impl.collection
-
- com.hazelcast.collection.impl.collection.operations - package com.hazelcast.collection.impl.collection.operations
-
- com.hazelcast.collection.impl.common - package com.hazelcast.collection.impl.common
-
- com.hazelcast.collection.impl.list - package com.hazelcast.collection.impl.list
-
This package contains IList functionality for Hazelcast.
- com.hazelcast.collection.impl.list.operations - package com.hazelcast.collection.impl.list.operations
-
- com.hazelcast.collection.impl.queue - package com.hazelcast.collection.impl.queue
-
- com.hazelcast.collection.impl.queue.operations - package com.hazelcast.collection.impl.queue.operations
-
This package contains the IQueue operations
- com.hazelcast.collection.impl.set - package com.hazelcast.collection.impl.set
-
This package contains ISet functionality for Hazelcast.
- com.hazelcast.collection.impl.set.operations - package com.hazelcast.collection.impl.set.operations
-
- com.hazelcast.collection.impl.txncollection - package com.hazelcast.collection.impl.txncollection
-
- com.hazelcast.collection.impl.txncollection.operations - package com.hazelcast.collection.impl.txncollection.operations
-
- com.hazelcast.collection.impl.txnlist - package com.hazelcast.collection.impl.txnlist
-
- com.hazelcast.collection.impl.txnqueue - package com.hazelcast.collection.impl.txnqueue
-
- com.hazelcast.collection.impl.txnqueue.operations - package com.hazelcast.collection.impl.txnqueue.operations
-
- com.hazelcast.collection.impl.txnset - package com.hazelcast.collection.impl.txnset
-
- com.hazelcast.concurrent.atomiclong - package com.hazelcast.concurrent.atomiclong
-
This package contains IAtomicLong functionality for Hazelcast.
The IAtomicLong is the distributed version of the
AtomicLong
.
- com.hazelcast.concurrent.atomiclong.operations - package com.hazelcast.concurrent.atomiclong.operations
-
This package contains the operations on the IAtomicLong.
- com.hazelcast.concurrent.atomicreference - package com.hazelcast.concurrent.atomicreference
-
This package contains IAtomicReferece functionality for Hazelcast.
The IAtomicReference is the distributed version of the
AtomicReference
.
- com.hazelcast.concurrent.atomicreference.operations - package com.hazelcast.concurrent.atomicreference.operations
-
This package contains the operations on the IAtomicReference.
- com.hazelcast.concurrent.countdownlatch - package com.hazelcast.concurrent.countdownlatch
-
This package contains ICountDownLatch functionality for Hazelcast.
The ICountDownLatch is the distributed version of the
CountDownLatch
.
- com.hazelcast.concurrent.countdownlatch.operations - package com.hazelcast.concurrent.countdownlatch.operations
-
This package contains the operations on the ICountDownLatch.
- com.hazelcast.concurrent.idgen - package com.hazelcast.concurrent.idgen
-
This package contains IdGenerator functionality for Hazelcast.
- com.hazelcast.concurrent.lock - package com.hazelcast.concurrent.lock
-
This package contains Lock for Hazelcast.
The
ILock
is the distributed version of the
Lock
.
- com.hazelcast.concurrent.lock.operations - package com.hazelcast.concurrent.lock.operations
-
This package contains the operations on the ILock.
- com.hazelcast.concurrent.semaphore - package com.hazelcast.concurrent.semaphore
-
This package contains ISemaphore functionality for Hazelcast.
The ISemaphore is the distributed version of the
Semaphore
.
- com.hazelcast.concurrent.semaphore.operations - package com.hazelcast.concurrent.semaphore.operations
-
This package contains the operations on the ISemaphore.
- com.hazelcast.config - package com.hazelcast.config
-
Provides classes for configuring HazelcastInstance.
- com.hazelcast.config.matcher - package com.hazelcast.config.matcher
-
- com.hazelcast.config.properties - package com.hazelcast.config.properties
-
This package contains the public API for properties defined in the XML configuration.
- com.hazelcast.config.replacer - package com.hazelcast.config.replacer
-
This package contains the public API and default implementation of variable replacers for configuration files.
- com.hazelcast.config.replacer.spi - package com.hazelcast.config.replacer.spi
-
This package contains the SPI for configuration files variable replacers.
- com.hazelcast.console - package com.hazelcast.console
-
This package contains classes related to ConsoleApp
- com.hazelcast.core - package com.hazelcast.core
-
Provides core API interfaces/classes.
- com.hazelcast.core.server - package com.hazelcast.core.server
-
This package contains classes to launch standalone Hazelcast Instance
- com.hazelcast.crdt - package com.hazelcast.crdt
-
This package contains CRDT (conflict-free replicated data type)
implementations based on the Hazelcast infrastructure.
- com.hazelcast.crdt.pncounter - package com.hazelcast.crdt.pncounter
-
This package contains the PN (Positive-Negative) CRDT counter
implementation.
- com.hazelcast.crdt.pncounter.operations - package com.hazelcast.crdt.pncounter.operations
-
Contains the operations for the
PNCounter
member-side
implementation.
- com.hazelcast.durableexecutor - package com.hazelcast.durableexecutor
-
This package contains DurableExecutorService functionality for Hazelcast.
The DurableExecutorService extends the
ExecutorService
and provides additional methods like
executing tasks on a member who is owner of a specific key.
- com.hazelcast.durableexecutor.impl - package com.hazelcast.durableexecutor.impl
-
- com.hazelcast.durableexecutor.impl.operations - package com.hazelcast.durableexecutor.impl.operations
-
This package contains operations for the DurableExecutorService.
- com.hazelcast.executor.impl - package com.hazelcast.executor.impl
-
This package contains IExecutorService functionality for Hazelcast.
The IExecutorService extends the
ExecutorService
and provides all kinds
of additional methods related to distributed systems.
- com.hazelcast.executor.impl.operations - package com.hazelcast.executor.impl.operations
-
This package contains operations for the IExecutorService.
- com.hazelcast.flakeidgen - package com.hazelcast.flakeidgen
-
This package contains Flake ID Generator functionality for Hazelcast.
- com.hazelcast.flakeidgen.impl - package com.hazelcast.flakeidgen.impl
-
- com.hazelcast.flakeidgen.impl.client - package com.hazelcast.flakeidgen.impl.client
-
- com.hazelcast.hotrestart - package com.hazelcast.hotrestart
-
This package contains Hot Restart classes needed for open source Hazelcast code
- com.hazelcast.instance - package com.hazelcast.instance
-
This package contains Hazelcast Instance functionality.
- com.hazelcast.internal - package com.hazelcast.internal
-
Contains the internal packages of Hazelcast.
- com.hazelcast.internal.adapter - package com.hazelcast.internal.adapter
-
Data structure adapters for Near Cache.
- com.hazelcast.internal.ascii - package com.hazelcast.internal.ascii
-
This package contains Ascii functionality for Hazelcast.
This is required for Memcached and the REST api.
- com.hazelcast.internal.ascii.memcache - package com.hazelcast.internal.ascii.memcache
-
This package contains MemoryCache functionality for Hazelcast.
- com.hazelcast.internal.ascii.rest - package com.hazelcast.internal.ascii.rest
-
This package contains Reset functionality for Hazelcast.
- com.hazelcast.internal.cluster - package com.hazelcast.internal.cluster
-
Contains the internals for cluster management like discovery, joining etc.
- com.hazelcast.internal.cluster.fd - package com.hazelcast.internal.cluster.fd
-
Contains failure detector mechanism and its implementations.
- com.hazelcast.internal.cluster.impl - package com.hazelcast.internal.cluster.impl
-
This package contains the implementation of the cluster functionality.
- com.hazelcast.internal.cluster.impl.operations - package com.hazelcast.internal.cluster.impl.operations
-
This package contains operations for the com.hazelcast.cluster.impl package.
- com.hazelcast.internal.config - package com.hazelcast.internal.config
-
Contains functionality for Hazelcast configurations.
- com.hazelcast.internal.diagnostics - package com.hazelcast.internal.diagnostics
-
Contains functionality what is happening in a HazelcastInstance.
- com.hazelcast.internal.dynamicconfig - package com.hazelcast.internal.dynamicconfig
-
Classes related to Dynamic Configuration.
- com.hazelcast.internal.eviction - package com.hazelcast.internal.eviction
-
Eviction policy implementations.
- com.hazelcast.internal.eviction.impl - package com.hazelcast.internal.eviction.impl
-
Eviction implementations.
- com.hazelcast.internal.eviction.impl.comparator - package com.hazelcast.internal.eviction.impl.comparator
-
- com.hazelcast.internal.eviction.impl.evaluator - package com.hazelcast.internal.eviction.impl.evaluator
-
com.hazelcast.internal.eviction.EvictionPolicyEvaluator
implementations.
- com.hazelcast.internal.eviction.impl.strategy - package com.hazelcast.internal.eviction.impl.strategy
-
com.hazelcast.internal.eviction.EvictionStrategy
implementations.
- com.hazelcast.internal.eviction.impl.strategy.sampling - package com.hazelcast.internal.eviction.impl.strategy.sampling
-
Sampling based com.hazelcast.internal.eviction.EvictionStrategy
implementations for cache.
- com.hazelcast.internal.jmx - package com.hazelcast.internal.jmx
-
Contains Hazelcast management bean classes.
- com.hazelcast.internal.jmx.suppliers - package com.hazelcast.internal.jmx.suppliers
-
Contains Hazelcast management bean stat providers.
- com.hazelcast.internal.journal - package com.hazelcast.internal.journal
-
This package contains supporting classes for data structure specific event journals.
- com.hazelcast.internal.management - package com.hazelcast.internal.management
-
Contains classes to provide data/operation interface for Management Center.
- com.hazelcast.internal.management.dto - package com.hazelcast.internal.management.dto
-
These contain the DTO object to exchange information with the management center.
- com.hazelcast.internal.management.operation - package com.hazelcast.internal.management.operation
-
Contains operations that are called from Management Center.
- com.hazelcast.internal.management.request - package com.hazelcast.internal.management.request
-
Contains requests that made from Management Center.
- com.hazelcast.internal.memory - package com.hazelcast.internal.memory
-
SPI that deals with memory operations.
- com.hazelcast.internal.memory.impl - package com.hazelcast.internal.memory.impl
-
Internal memory management API implementations
- com.hazelcast.internal.metrics - package com.hazelcast.internal.metrics
-
Contains the Hazelcast Metrics.
- com.hazelcast.internal.metrics.impl - package com.hazelcast.internal.metrics.impl
-
- com.hazelcast.internal.metrics.metricsets - package com.hazelcast.internal.metrics.metricsets
-
Contains all kinds of metric packs.
- com.hazelcast.internal.metrics.renderers - package com.hazelcast.internal.metrics.renderers
-
- com.hazelcast.internal.nearcache - package com.hazelcast.internal.nearcache
-
Near Cache support.
- com.hazelcast.internal.nearcache.impl - package com.hazelcast.internal.nearcache.impl
-
Near Cache implementations.
- com.hazelcast.internal.nearcache.impl.invalidation - package com.hazelcast.internal.nearcache.impl.invalidation
-
Invalidations for Near Cache.
- com.hazelcast.internal.nearcache.impl.maxsize - package com.hazelcast.internal.nearcache.impl.maxsize
-
Max-Size policy implementations for Near Cache.
- com.hazelcast.internal.nearcache.impl.preloader - package com.hazelcast.internal.nearcache.impl.preloader
-
Near Cache pre-loader implementation.
- com.hazelcast.internal.nearcache.impl.record - package com.hazelcast.internal.nearcache.impl.record
-
Near Cache record implementations.
- com.hazelcast.internal.nearcache.impl.store - package com.hazelcast.internal.nearcache.impl.store
-
Near Cache store implementations.
- com.hazelcast.internal.networking - package com.hazelcast.internal.networking
-
Contains the socket connection functionality.
- com.hazelcast.internal.networking.nio - package com.hazelcast.internal.networking.nio
-
- com.hazelcast.internal.networking.nio.iobalancer - package com.hazelcast.internal.networking.nio.iobalancer
-
Contains Handler Migration classes
- com.hazelcast.internal.partition - package com.hazelcast.internal.partition
-
Contains the internals for partition assignment/management, migration, replication etc.
- com.hazelcast.internal.partition.impl - package com.hazelcast.internal.partition.impl
-
- com.hazelcast.internal.partition.operation - package com.hazelcast.internal.partition.operation
-
Contains the operations for partition package.
- com.hazelcast.internal.serialization - package com.hazelcast.internal.serialization
-
Contains the private serialization API + implementation.
- com.hazelcast.internal.serialization.impl - package com.hazelcast.internal.serialization.impl
-
- com.hazelcast.internal.serialization.impl.bufferpool - package com.hazelcast.internal.serialization.impl.bufferpool
-
Contains the logic for the BufferPool.
- com.hazelcast.internal.usercodedeployment - package com.hazelcast.internal.usercodedeployment
-
Module related to User Code Deployment
- com.hazelcast.internal.usercodedeployment.impl - package com.hazelcast.internal.usercodedeployment.impl
-
- com.hazelcast.internal.usercodedeployment.impl.filter - package com.hazelcast.internal.usercodedeployment.impl.filter
-
- com.hazelcast.internal.usercodedeployment.impl.operation - package com.hazelcast.internal.usercodedeployment.impl.operation
-
- com.hazelcast.internal.util - package com.hazelcast.internal.util
-
This package contains classes to support the inner workings of Hazelcast
as well as some backports of newer Java features / data structures to
support older Java versions in a clean and nice way.
- com.hazelcast.internal.util.collection - package com.hazelcast.internal.util.collection
-
Primitive-typed collections.
- com.hazelcast.internal.util.concurrent - package com.hazelcast.internal.util.concurrent
-
Concurrent queues etc.
- com.hazelcast.internal.util.counters - package com.hazelcast.internal.util.counters
-
Provides various counter implementations.
- com.hazelcast.internal.util.filter - package com.hazelcast.internal.util.filter
-
- com.hazelcast.internal.util.futures - package com.hazelcast.internal.util.futures
-
Re-usable implementations of Futures.
- com.hazelcast.internal.util.hashslot - package com.hazelcast.internal.util.hashslot
-
Contains a family of interfaces that provide a common base for various
kinds of open-addressed hashtable implementations.
- com.hazelcast.internal.util.hashslot.impl - package com.hazelcast.internal.util.hashslot.impl
-
- com.hazelcast.internal.util.iterator - package com.hazelcast.internal.util.iterator
-
Re-usable implementations of Iterators.
- com.hazelcast.internal.util.sort - package com.hazelcast.internal.util.sort
-
General API for sorting.
- com.hazelcast.logging - package com.hazelcast.logging
-
This package contains logging functionality for Hazelcast.
Since Hazelcast has a zero dependency policy, Hazelcast provides a logging abstraction like commongs logging,
so that different logging frameworks like log4j, can be hooked in.
- com.hazelcast.map - package com.hazelcast.map
-
Contains Hazelcast map module classes.
- com.hazelcast.map.eviction - package com.hazelcast.map.eviction
-
This package contains eviction specific classes.
- com.hazelcast.map.impl - package com.hazelcast.map.impl
-
- com.hazelcast.map.impl.client - package com.hazelcast.map.impl.client
-
- com.hazelcast.map.impl.event - package com.hazelcast.map.impl.event
-
- com.hazelcast.map.impl.eviction - package com.hazelcast.map.impl.eviction
-
This package contains eviction classes.
- com.hazelcast.map.impl.iterator - package com.hazelcast.map.impl.iterator
-
- com.hazelcast.map.impl.journal - package com.hazelcast.map.impl.journal
-
- com.hazelcast.map.impl.mapstore - package com.hazelcast.map.impl.mapstore
-
Contains map store operations.
- com.hazelcast.map.impl.mapstore.writebehind - package com.hazelcast.map.impl.mapstore.writebehind
-
Package for processing write behind store operations.
- com.hazelcast.map.impl.mapstore.writebehind.entry - package com.hazelcast.map.impl.mapstore.writebehind.entry
-
- com.hazelcast.map.impl.mapstore.writethrough - package com.hazelcast.map.impl.mapstore.writethrough
-
Package for processing write through store operations.
- com.hazelcast.map.impl.nearcache - package com.hazelcast.map.impl.nearcache
-
Contains Near Cache specific classes.
- com.hazelcast.map.impl.nearcache.invalidation - package com.hazelcast.map.impl.nearcache.invalidation
-
- com.hazelcast.map.impl.operation - package com.hazelcast.map.impl.operation
-
Package for map operations.
- com.hazelcast.map.impl.proxy - package com.hazelcast.map.impl.proxy
-
Contains map proxy implementation and support classes.
- com.hazelcast.map.impl.query - package com.hazelcast.map.impl.query
-
- com.hazelcast.map.impl.querycache - package com.hazelcast.map.impl.querycache
-
Contains query cache internal implementation classes.
- com.hazelcast.map.impl.querycache.accumulator - package com.hazelcast.map.impl.querycache.accumulator
-
- com.hazelcast.map.impl.querycache.event - package com.hazelcast.map.impl.querycache.event
-
This package contains classes for query cache events.
- com.hazelcast.map.impl.querycache.event.sequence - package com.hazelcast.map.impl.querycache.event.sequence
-
This package contains classes which are used to give sequence numbers to events.
- com.hazelcast.map.impl.querycache.publisher - package com.hazelcast.map.impl.querycache.publisher
-
This package contains classes which are used for
QueryCache
event publishing side.
- com.hazelcast.map.impl.querycache.subscriber - package com.hazelcast.map.impl.querycache.subscriber
-
This package contains classes which are used for
QueryCache
event subscription side.
- com.hazelcast.map.impl.querycache.subscriber.operation - package com.hazelcast.map.impl.querycache.subscriber.operation
-
This package contains Enterprise specific operations for
QueryCache
.
- com.hazelcast.map.impl.querycache.subscriber.record - package com.hazelcast.map.impl.querycache.subscriber.record
-
- com.hazelcast.map.impl.querycache.utils - package com.hazelcast.map.impl.querycache.utils
-
Contains utility classes for QueryCache
implementation.
- com.hazelcast.map.impl.record - package com.hazelcast.map.impl.record
-
Contains record specific classes.
- com.hazelcast.map.impl.recordstore - package com.hazelcast.map.impl.recordstore
-
- com.hazelcast.map.impl.tx - package com.hazelcast.map.impl.tx
-
- com.hazelcast.map.impl.wan - package com.hazelcast.map.impl.wan
-
Contains wan replication event classes
- com.hazelcast.map.journal - package com.hazelcast.map.journal
-
- com.hazelcast.map.listener - package com.hazelcast.map.listener
-
- com.hazelcast.map.merge - package com.hazelcast.map.merge
-
Contains out-of-the-box merge policies for
IMap
.
- com.hazelcast.mapreduce - package com.hazelcast.mapreduce
-
This package contains the MapReduce API definition for Hazelcast.
All map reduce operations running in a distributed manner inside the
active Hazelcast cluster.
- com.hazelcast.mapreduce.aggregation - package com.hazelcast.mapreduce.aggregation
-
This package contains the aggregation API and the convenience helper classes
to retrieve predefined aggregation implementations.
- com.hazelcast.mapreduce.aggregation.impl - package com.hazelcast.mapreduce.aggregation.impl
-
This package contains a set of predefined aggregation implementations
- com.hazelcast.mapreduce.impl - package com.hazelcast.mapreduce.impl
-
This package contains the default implementation for the map reduce framework
internals.
- com.hazelcast.mapreduce.impl.notification - package com.hazelcast.mapreduce.impl.notification
-
This package contains all remote node notifications
- com.hazelcast.mapreduce.impl.operation - package com.hazelcast.mapreduce.impl.operation
-
This package contains all remote operations that are needed to control work on
supervising or worker nodes.
- com.hazelcast.mapreduce.impl.task - package com.hazelcast.mapreduce.impl.task
-
This package contains the base implementation for a standard map reduce job.
- com.hazelcast.memory - package com.hazelcast.memory
-
Provides classes/interfaces for memory utilities, heap/native memory storage support.
- com.hazelcast.monitor - package com.hazelcast.monitor
-
Contains Hazelcast statistics interfaces related to map, queue, topic, multimap, executor service etc.
- com.hazelcast.monitor.impl - package com.hazelcast.monitor.impl
-
Contains Hazelcast statistics implementations related to map, queue, topic, multimap, executor service etc.
- com.hazelcast.multimap.impl - package com.hazelcast.multimap.impl
-
Contains classes for Hazelcast MultiMap module.
- com.hazelcast.multimap.impl.operations - package com.hazelcast.multimap.impl.operations
-
Contains operations for Hazelcast MultiMap module.
- com.hazelcast.multimap.impl.txn - package com.hazelcast.multimap.impl.txn
-
This package contains the Transaction behavior for the Multimap.
- com.hazelcast.nio - package com.hazelcast.nio
-
This package contains classes related to New IO
- com.hazelcast.nio.ascii - package com.hazelcast.nio.ascii
-
Contains SocketTextReader and SocketTextWriter classes;
- com.hazelcast.nio.serialization - package com.hazelcast.nio.serialization
-
Contains interfaces/classes related to serialization;
such as serializer interfaces, input/output streams.
- com.hazelcast.nio.serialization.impl - package com.hazelcast.nio.serialization.impl
-
- com.hazelcast.nio.ssl - package com.hazelcast.nio.ssl
-
Contains interfaces/classes related to SSL for New IO
- com.hazelcast.nio.tcp - package com.hazelcast.nio.tcp
-
Contains functionality for the TCP/IP Networking for cluster members
This whole package is internal and no compatibility will be provided.
- com.hazelcast.osgi - package com.hazelcast.osgi
-
This package contains the OSGI functionality contract points for Hazelcast.
- com.hazelcast.osgi.impl - package com.hazelcast.osgi.impl
-
This package contains the OSGI functionality implementations for Hazelcast.
- com.hazelcast.partition - package com.hazelcast.partition
-
Contains the partition logic for Hazelcast.
- com.hazelcast.partition.membergroup - package com.hazelcast.partition.membergroup
-
todo
- com.hazelcast.partition.strategy - package com.hazelcast.partition.strategy
-
Packages contains different partitioning strategies.
- com.hazelcast.projection - package com.hazelcast.projection
-
Contains classes related to projections.
- com.hazelcast.projection.impl - package com.hazelcast.projection.impl
-
- com.hazelcast.query - package com.hazelcast.query
-
Contains interfaces/classes related to Hazelcast query and indexing support.
- com.hazelcast.query.extractor - package com.hazelcast.query.extractor
-
Contains classes related to custom attributes and the extraction of their values.
- com.hazelcast.query.impl - package com.hazelcast.query.impl
-
Contains the implementation classes of the query functionality.
- com.hazelcast.query.impl.getters - package com.hazelcast.query.impl.getters
-
Helper classes for extractions of values from object instances.
- com.hazelcast.query.impl.predicates - package com.hazelcast.query.impl.predicates
-
- com.hazelcast.quorum - package com.hazelcast.quorum
-
Contains classes related to cluster quorum.
- com.hazelcast.quorum.impl - package com.hazelcast.quorum.impl
-
Contains cluster quorum implementation classes.
- com.hazelcast.replicatedmap - package com.hazelcast.replicatedmap
-
Classes for replicated map.
- com.hazelcast.replicatedmap.impl - package com.hazelcast.replicatedmap.impl
-
This package contains the implementation of the replicated map service itself and some connection interfaces only used
internally.
- com.hazelcast.replicatedmap.impl.client - package com.hazelcast.replicatedmap.impl.client
-
This package contains classes for client communication on replicated map implementation
- com.hazelcast.replicatedmap.impl.operation - package com.hazelcast.replicatedmap.impl.operation
-
This package contains replicated map operations which are executed on remote nodes
- com.hazelcast.replicatedmap.impl.record - package com.hazelcast.replicatedmap.impl.record
-
This package contains the implementation of the backing data storage for the replicated map implementation
- com.hazelcast.replicatedmap.merge - package com.hazelcast.replicatedmap.merge
-
- com.hazelcast.ringbuffer - package com.hazelcast.ringbuffer
-
- com.hazelcast.ringbuffer.impl - package com.hazelcast.ringbuffer.impl
-
- com.hazelcast.ringbuffer.impl.client - package com.hazelcast.ringbuffer.impl.client
-
- com.hazelcast.ringbuffer.impl.operations - package com.hazelcast.ringbuffer.impl.operations
-
- com.hazelcast.scheduledexecutor - package com.hazelcast.scheduledexecutor
-
This package contains ScheduledExecutorService functionality for Hazelcast.
- com.hazelcast.scheduledexecutor.impl - package com.hazelcast.scheduledexecutor.impl
-
- com.hazelcast.scheduledexecutor.impl.operations - package com.hazelcast.scheduledexecutor.impl.operations
-
- com.hazelcast.security - package com.hazelcast.security
-
Provides interfaces/classes for Hazelcast security implementation.
- com.hazelcast.security.permission - package com.hazelcast.security.permission
-
Contains all the security permissions
- com.hazelcast.spi - package com.hazelcast.spi
-
Provides interfaces/classes for the Hazelcast SPI for building distributed data structures and services.
- com.hazelcast.spi.annotation - package com.hazelcast.spi.annotation
-
Contains annotations for Hazelcast SPI.
- com.hazelcast.spi.discovery - package com.hazelcast.spi.discovery
-
This package contains the public SPI for vendors and users to implement their
custom node / IP discovery strategy.
- com.hazelcast.spi.discovery.impl - package com.hazelcast.spi.discovery.impl
-
- com.hazelcast.spi.discovery.integration - package com.hazelcast.spi.discovery.integration
-
This package contains the public part of the integrators SPI and is meant for
people that integrate Hazelcast into their own systems or frameworks and cannot
use the default discovery service implementation (for example using a different
DiscoveryStrategy
lookup strategy like OSGi).
- com.hazelcast.spi.discovery.multicast - package com.hazelcast.spi.discovery.multicast
-
Contains the hazelcast multicast plugin classes
- com.hazelcast.spi.discovery.multicast.impl - package com.hazelcast.spi.discovery.multicast.impl
-
- com.hazelcast.spi.exception - package com.hazelcast.spi.exception
-
Contains exceptions for Hazelcast SPI.
- com.hazelcast.spi.impl - package com.hazelcast.spi.impl
-
Contains implementations for Hazelcast SPI.
- com.hazelcast.spi.impl.eventservice - package com.hazelcast.spi.impl.eventservice
-
- com.hazelcast.spi.impl.eventservice.impl - package com.hazelcast.spi.impl.eventservice.impl
-
- com.hazelcast.spi.impl.eventservice.impl.operations - package com.hazelcast.spi.impl.eventservice.impl.operations
-
- com.hazelcast.spi.impl.executionservice - package com.hazelcast.spi.impl.executionservice
-
- com.hazelcast.spi.impl.executionservice.impl - package com.hazelcast.spi.impl.executionservice.impl
-
- com.hazelcast.spi.impl.merge - package com.hazelcast.spi.impl.merge
-
This package contains split-brain related classes.
- com.hazelcast.spi.impl.operationexecutor - package com.hazelcast.spi.impl.operationexecutor
-
- com.hazelcast.spi.impl.operationexecutor.impl - package com.hazelcast.spi.impl.operationexecutor.impl
-
- com.hazelcast.spi.impl.operationexecutor.slowoperationdetector - package com.hazelcast.spi.impl.operationexecutor.slowoperationdetector
-
- com.hazelcast.spi.impl.operationparker - package com.hazelcast.spi.impl.operationparker
-
- com.hazelcast.spi.impl.operationparker.impl - package com.hazelcast.spi.impl.operationparker.impl
-
- com.hazelcast.spi.impl.operationservice - package com.hazelcast.spi.impl.operationservice
-
- com.hazelcast.spi.impl.operationservice.impl - package com.hazelcast.spi.impl.operationservice.impl
-
- com.hazelcast.spi.impl.operationservice.impl.batching - package com.hazelcast.spi.impl.operationservice.impl.batching
-
- com.hazelcast.spi.impl.operationservice.impl.operations - package com.hazelcast.spi.impl.operationservice.impl.operations
-
- com.hazelcast.spi.impl.operationservice.impl.responses - package com.hazelcast.spi.impl.operationservice.impl.responses
-
Contains the different responses that can be send as a consequence of an Operation invocation.
- com.hazelcast.spi.impl.operationutil - package com.hazelcast.spi.impl.operationutil
-
- com.hazelcast.spi.impl.proxyservice - package com.hazelcast.spi.impl.proxyservice
-
- com.hazelcast.spi.impl.proxyservice.impl - package com.hazelcast.spi.impl.proxyservice.impl
-
- com.hazelcast.spi.impl.proxyservice.impl.operations - package com.hazelcast.spi.impl.proxyservice.impl.operations
-
- com.hazelcast.spi.impl.sequence - package com.hazelcast.spi.impl.sequence
-
Call ID sequence generators
- com.hazelcast.spi.impl.servicemanager - package com.hazelcast.spi.impl.servicemanager
-
- com.hazelcast.spi.impl.servicemanager.impl - package com.hazelcast.spi.impl.servicemanager.impl
-
- com.hazelcast.spi.merge - package com.hazelcast.spi.merge
-
This package contains interfaces and classes of the split-brain merging SPI.
- com.hazelcast.spi.partition - package com.hazelcast.spi.partition
-
Contains the SPI for partition logic for Hazelcast.
- com.hazelcast.spi.partitiongroup - package com.hazelcast.spi.partitiongroup
-
This package contains the basic SPI for the Partition Group SPI to define
or configure how Hazelcast will configure and distribute backups in the
cluster.
- com.hazelcast.spi.properties - package com.hazelcast.spi.properties
-
Contains the Hazelcast properties implementation.
- com.hazelcast.spi.serialization - package com.hazelcast.spi.serialization
-
Contains SPI related to serialization
- com.hazelcast.spring - package com.hazelcast.spring
-
Provides Spring interfaces/classes for Hazelcast.
- com.hazelcast.spring.cache - package com.hazelcast.spring.cache
-
Contains Hazelcast cache classes related to Spring.
- com.hazelcast.spring.context - package com.hazelcast.spring.context
-
Contains context classes for Spring.
- com.hazelcast.spring.hibernate - package com.hazelcast.spring.hibernate
-
Contains class related to Hibernate.
- com.hazelcast.spring.transaction - package com.hazelcast.spring.transaction
-
Contains Hazelcast transaction classes for Spring Transaction API.
- com.hazelcast.topic - package com.hazelcast.topic
-
Contains the API for the
ITopic
.
- com.hazelcast.topic.impl - package com.hazelcast.topic.impl
-
This package contains ITopic functionality for Hazelcast.
With the ITopic it is possible to create publish subscribe solutions similar to JMS Topics.
- com.hazelcast.topic.impl.reliable - package com.hazelcast.topic.impl.reliable
-
- com.hazelcast.transaction - package com.hazelcast.transaction
-
Provides interfaces/classes for Hazelcast transaction support.
- com.hazelcast.transaction.impl - package com.hazelcast.transaction.impl
-
Provides implementation for Hazelcast transaction support.
- com.hazelcast.transaction.impl.operations - package com.hazelcast.transaction.impl.operations
-
- com.hazelcast.transaction.impl.xa - package com.hazelcast.transaction.impl.xa
-
Provides implementation for Hazelcast XA transaction support.
- com.hazelcast.transaction.impl.xa.operations - package com.hazelcast.transaction.impl.xa.operations
-
- com.hazelcast.util - package com.hazelcast.util
-
This package contains classes to support the inner workings of Hazelcast
as well as some backports of newer Java features / data structures to
support older Java versions in a clean and nice way.
- com.hazelcast.util.collection - package com.hazelcast.util.collection
-
The Agrona project backport: collections.
- com.hazelcast.util.concurrent - package com.hazelcast.util.concurrent
-
Abstractions that deal with common needs in concurrent programming.
- com.hazelcast.util.executor - package com.hazelcast.util.executor
-
This package contains classes related to Util.Executor
- com.hazelcast.util.function - package com.hazelcast.util.function
-
Backport of Java 8 functional interfaces which Agrona depends on.
- com.hazelcast.util.scheduler - package com.hazelcast.util.scheduler
-
This package contains scheduler classes for Util
- com.hazelcast.version - package com.hazelcast.version
-
This package contains classes to support the versioning API.
- com.hazelcast.wan - package com.hazelcast.wan
-
This package contains the WAN replication API
- com.hazelcast.wan.impl - package com.hazelcast.wan.impl
-
This package contains the opensource implementation of WAN replication
- combine(Aggregator) - Method in class com.hazelcast.aggregation.Aggregator
-
Incorporates the intermediary result of the given aggregator to this instance of the aggregator.
- combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.BigDecimalAverageAggregator
-
- combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.BigDecimalSumAggregator
-
- combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.BigIntegerAverageAggregator
-
- combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.BigIntegerSumAggregator
-
- combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.CountAggregator
-
- combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.DistinctValuesAggregator
-
- combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.DoubleAverageAggregator
-
- combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.DoubleSumAggregator
-
- combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.FixedSumAggregator
-
- combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.FloatingPointSumAggregator
-
- combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.IntegerAverageAggregator
-
- combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.IntegerSumAggregator
-
- combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.LongAverageAggregator
-
- combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.LongSumAggregator
-
- combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.MaxAggregator
-
- combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.MaxByAggregator
-
- combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.MinAggregator
-
- combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.MinByAggregator
-
- combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.NumberAverageAggregator
-
- combine(AggregationResult) - Method in class com.hazelcast.map.impl.query.AggregationResult
-
- combine(QueryResult) - Method in class com.hazelcast.map.impl.query.QueryResult
-
- combine(T) - Method in interface com.hazelcast.map.impl.query.Result
-
Combines the given result with this result modifying this result.
- combine(ValueIn) - Method in class com.hazelcast.mapreduce.Combiner
-
Deprecated.
This method is called to supply values to be combined into an intermediate result chunk.
The combine method might be called multiple times so the combined chunk needs to be held
internally in a member state of the Combiner.
After this method is called you need to
Combiner.reset()
the internal state to prepare for combining of
the next chunk.
- Combiner<ValueIn,ValueOut> - Class in com.hazelcast.mapreduce
-
- Combiner() - Constructor for class com.hazelcast.mapreduce.Combiner
-
Deprecated.
- combiner(CombinerFactory<? super Key, ? super Value, ? extends ValueOut>) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.MappingJobImpl
-
- combiner(CombinerFactory<? super KeyIn, ? super ValueIn, ? extends ValueOut>) - Method in interface com.hazelcast.mapreduce.MappingJob
-
Deprecated.
- COMBINER_RESULT_LIST - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-
- CombinerFactory<KeyIn,ValueIn,ValueOut> - Interface in com.hazelcast.mapreduce
-
- combinerFactory - Variable in class com.hazelcast.mapreduce.impl.AbstractJob
-
- CombinerResultList<E> - Class in com.hazelcast.mapreduce.impl
-
This
ArrayList
subclass exists to prevent
DefaultContext.CollectingCombinerFactory
created collections to be mixed up with user provided List results from
Combiner
s.
- CombinerResultList() - Constructor for class com.hazelcast.mapreduce.impl.CombinerResultList
-
- CombinerResultList(Collection<? extends E>) - Constructor for class com.hazelcast.mapreduce.impl.CombinerResultList
-
- combineToInt(short, short) - Static method in class com.hazelcast.nio.Bits
-
Combines two short integer values into an integer.
- combineToLong(int, int) - Static method in class com.hazelcast.nio.Bits
-
Combines two integer values into a long integer.
- CommandParser - Interface in com.hazelcast.internal.ascii
-
- commit(Xid, boolean) - Method in class com.hazelcast.client.proxy.txn.xa.XAResourceProxy
-
- commit() - Method in interface com.hazelcast.transaction.impl.Transaction
-
- commit() - Method in class com.hazelcast.transaction.impl.TransactionImpl
-
- commit(NodeEngine) - Method in class com.hazelcast.transaction.impl.TransactionLog
-
- commit(Xid, boolean) - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
-
- commit() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
-
- commitAdd(long, Data) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-
- commitAddBackup(long, Data) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-
- commitAsync(NodeEngine, ExecutionCallback) - Method in class com.hazelcast.transaction.impl.TransactionLog
-
- commitAsync(ExecutionCallback) - Method in class com.hazelcast.transaction.impl.xa.XATransaction
-
- commitClusterState(ClusterStateChange, Address, String, boolean) - Method in class com.hazelcast.internal.cluster.impl.ClusterStateManager
-
- CommitClusterStateOp - Class in com.hazelcast.internal.cluster.impl.operations
-
- CommitClusterStateOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.CommitClusterStateOp
-
- CommitClusterStateOp(ClusterStateChange, Address, String, boolean) - Constructor for class com.hazelcast.internal.cluster.impl.operations.CommitClusterStateOp
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.cache.impl.CacheService
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorService
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.collection.impl.collection.CollectionService
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.collection.impl.queue.QueueService
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.durableexecutor.impl.DistributedDurableExecutorService
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.map.impl.MapService
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.spi.impl.CountingMigrationAwareService
-
- commitMigration(PartitionMigrationEvent) - Method in interface com.hazelcast.spi.MigrationAwareService
-
Commits the migration process for this service, on both source and destination members.
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.transaction.impl.xa.XAService
-
- commitRemove(long) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-
- commitRemoveBackup(long) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-
- commitTransaction() - Method in class com.hazelcast.client.proxy.txn.TransactionContextProxy
-
- commitTransaction() - Method in class com.hazelcast.client.proxy.txn.xa.XATransactionContextProxy
-
- commitTransaction() - Method in class com.hazelcast.transaction.impl.xa.XATransactionContextImpl
-
- commitTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
-
Commits a transaction.
- compact() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
-
- compact() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
-
Compact the
Map
backing arrays by rehashing with a capacity just larger than current size
and giving consideration to the load factor.
- compact() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
-
Compact the
Map
backing arrays by rehashing with a capacity just larger than current size
and giving consideration to the load factor.
- compactOrClear(ByteBuffer) - Static method in class com.hazelcast.nio.IOUtil
-
Compacts or clears the buffer depending if bytes are remaining in the byte-buffer.
- COMPARABLE_MAX_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- COMPARABLE_MAX_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- COMPARABLE_MIN_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- COMPARABLE_MIN_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- comparableMax() - Static method in class com.hazelcast.aggregation.Aggregators
-
- comparableMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
-
- comparableMax() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
-
Deprecated.
Returns an aggregation to find the maximum value of all supplied
Comparable
implementing values.
This aggregation is similar to:
- ComparableMaxAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
-
The predefined maximum aggregation for values of type
Comparable
.
- ComparableMaxAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.ComparableMaxAggregation
-
- comparableMin() - Static method in class com.hazelcast.aggregation.Aggregators
-
- comparableMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
-
- comparableMin() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
-
Deprecated.
Returns an aggregation to find the minimum value of all supplied
Comparable
implementing values.
This aggregation is similar to:
- ComparableMinAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
-
The predefined minimum aggregation for values of type
Comparable
.
- ComparableMinAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.ComparableMinAggregation
-
- comparator - Variable in class com.hazelcast.config.EvictionConfig
-
- comparatorClassName - Variable in class com.hazelcast.config.EvictionConfig
-
- compare(CacheEntryView<K, V>, CacheEntryView<K, V>) - Method in class com.hazelcast.cache.CacheEvictionPolicyComparator
-
- compare(Object, Object) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- compare(E, E) - Method in class com.hazelcast.internal.eviction.EvictionPolicyComparator
-
- compare(EvictableEntryView, EvictableEntryView) - Method in class com.hazelcast.internal.eviction.impl.comparator.LFUEvictionPolicyComparator
-
- compare(EvictableEntryView, EvictableEntryView) - Method in class com.hazelcast.internal.eviction.impl.comparator.LRUEvictionPolicyComparator
-
- compare(EvictableEntryView, EvictableEntryView) - Method in class com.hazelcast.internal.eviction.impl.comparator.RandomEvictionPolicyComparator
-
- compare(EntryView, EntryView) - Method in class com.hazelcast.map.eviction.LFUEvictionPolicy
-
- compare(EntryView, EntryView) - Method in class com.hazelcast.map.eviction.LRUEvictionPolicy
-
- compare(EntryView<K, V>, EntryView<K, V>) - Method in class com.hazelcast.map.eviction.MapEvictionPolicy
- compare(EntryView, EntryView) - Method in class com.hazelcast.map.eviction.RandomEvictionPolicy
-
- compare(Comparator<Map.Entry>, IterationType, Map.Entry, Map.Entry) - Static method in class com.hazelcast.util.SortingUtil
-
- COMPARE_AND_REMOVE - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-
- COMPARE_AND_REMOVE - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- COMPARE_AND_REMOVE_BACKUP - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-
- COMPARE_AND_REMOVE_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- COMPARE_AND_SET - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-
- COMPARE_AND_SET - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-
- compareAnchor(PagingPredicate, QueryableEntry, Map.Entry<Integer, Map.Entry>) - Static method in class com.hazelcast.util.SortingUtil
-
- compareAndRemove(boolean, Set<Data>) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-
- compareAndRemove(Collection<Data>, boolean) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-
Compares if the queue contains the items in the dataList and removes them according to the retain parameter.
- compareAndRemoveBackup(Set<Long>) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-
- CompareAndRemoveBackupOperation - Class in com.hazelcast.collection.impl.queue.operations
-
This class triggers backup method for items' ID.
- CompareAndRemoveBackupOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveBackupOperation
-
- CompareAndRemoveBackupOperation(String, Set<Long>) - Constructor for class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveBackupOperation
-
- CompareAndRemoveOperation - Class in com.hazelcast.collection.impl.queue.operations
-
This class triggers iterator and if find same item in the Queue, remove this item.
- CompareAndRemoveOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveOperation
-
- CompareAndRemoveOperation(String, Collection<Data>, boolean) - Constructor for class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveOperation
-
- compareAndSet(long, long) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-
- compareAndSet(E, E) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-
- compareAndSet(long, long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongContainer
-
- compareAndSet(long, long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- compareAndSet(Data, Data) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceContainer
-
- compareAndSet(E, E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- compareAndSet(long, long) - Method in interface com.hazelcast.core.IAtomicLong
-
Atomically sets the value to the given updated value
only if the current value ==
the expected value.
- compareAndSet(E, E) - Method in interface com.hazelcast.core.IAtomicReference
-
Atomically sets the value to the given updated value
only if the current value ==
the expected value.
- compareAndSet(long, long) - Method in class com.hazelcast.internal.jmx.AtomicLongMBean
-
- compareAndSetAsync(long, long) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-
- compareAndSetAsync(E, E) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-
- compareAndSetAsync(long, long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- compareAndSetAsync(E, E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- compareAndSetAsync(long, long) - Method in interface com.hazelcast.core.IAtomicLong
-
Atomically sets the value to the given updated value
only if the current value ==
the expected value.
- compareAndSetAsync(E, E) - Method in interface com.hazelcast.core.IAtomicReference
-
Atomically sets the value to the given updated value
only if the current value ==
the expected value.
- CompareAndSetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-
- CompareAndSetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
-
- CompareAndSetOperation(String, long, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
-
- CompareAndSetOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-
- CompareAndSetOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
-
- CompareAndSetOperation(String, Data, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
-
- compareAndSetSequence(long, long) - Method in class com.hazelcast.map.impl.querycache.event.sequence.DefaultPartitionSequencer
-
- compareAndSetSequence(long, long, int) - Method in class com.hazelcast.map.impl.querycache.event.sequence.DefaultSubscriberSequencerProvider
-
- compareAndSetSequence(long, long) - Method in interface com.hazelcast.map.impl.querycache.event.sequence.PartitionSequencer
-
Atomically sets the value of sequence number for the partition.
- compareAndSetSequence(long, long, int) - Method in interface com.hazelcast.map.impl.querycache.event.sequence.SubscriberSequencerProvider
-
Atomically sets the value of sequence number for the partition.
- compareAndSwapInt(Object, long, int, int) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
-
Compares and swaps an int value to an expected value atomically
based by given object with given offset,
if and only if its current value is equal to the expected value.
- compareAndSwapInt(long, int, int) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
-
Compares and swaps the given int value to the expected value atomically
based in the given object with given offset
if and only if its current value equals to specified expected value.
- compareAndSwapInt(long, int, int) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- compareAndSwapInt(Object, long, int, int) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- compareAndSwapInt(long, int, int) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- compareAndSwapInt(Object, long, int, int) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- compareAndSwapLong(Object, long, long, long) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
-
Compares and swaps a long value to an expected value atomically
based by given object with given offset
if and only if its current value equals to the expected value.
- compareAndSwapLong(long, long, long) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
-
Compares and swaps the long value to the expected value atomically
based in the given object with given offset
if and only if its current value equals the expected value.
- compareAndSwapLong(long, long, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- compareAndSwapLong(Object, long, long, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- compareAndSwapLong(long, long, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- compareAndSwapLong(Object, long, long, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- compareAndSwapObject(Object, long, Object, Object) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
-
Compares and swaps referenced object to expected object atomically
based by given owner object at given offset
if and only if its current object is the expected object.
- compareAndSwapObject(long, Object, Object) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
-
Compares and swaps the referenced object to the expected object atomically
based by given owner object at given offset
if and only if its current referenced object is the expected object.
- compareAndSwapObject(long, Object, Object) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- compareAndSwapObject(Object, long, Object, Object) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- compareAndSwapObject(long, Object, Object) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- compareAndSwapObject(Object, long, Object, Object) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- compareIntegers(int, int) - Static method in class com.hazelcast.util.QuickMath
-
Compares two integers
- compareLongs(long, long) - Static method in class com.hazelcast.util.QuickMath
-
Compares two longs
- compareTo(Delayed) - Method in class com.hazelcast.client.proxy.ClientScheduledFutureProxy
-
- compareTo(CollectionItem) - Method in class com.hazelcast.collection.impl.collection.CollectionItem
-
- compareTo(QueueItem) - Method in class com.hazelcast.collection.impl.queue.QueueItem
-
- compareTo(MonitoredThread) - Method in class com.hazelcast.internal.management.MonitoredThread
-
- compareTo(Object) - Method in class com.hazelcast.query.impl.IndexImpl.NullObject
-
- compareTo(IndexInfo) - Method in class com.hazelcast.query.impl.IndexInfo
-
- compareTo(Delayed) - Method in class com.hazelcast.scheduledexecutor.impl.DelegatingScheduledFutureStripper
-
- compareTo(Delayed) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledFutureProxy
-
- compareTo(MemberVersion) - Method in class com.hazelcast.version.MemberVersion
-
- compareTo(Version) - Method in class com.hazelcast.version.Version
-
- ComparisonType - Enum in com.hazelcast.query.impl
-
Type of Comparison
- COMPATIBILITY_3_6_CLIENT_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
When this property is true, if the server can not determine the connected client version, it shall assume that it is of
3.6.x version client.
- COMPATIBILITY_3_6_SERVER_ENABLED - Static variable in class com.hazelcast.client.spi.properties.ClientProperty
-
When this property is true, if the client can not know the server version it will assume that the server is version 3.6.x.
- CompletableFutureTask<V> - Class in com.hazelcast.util.executor
-
- CompletableFutureTask(Callable<V>, ExecutorService) - Constructor for class com.hazelcast.util.executor.CompletableFutureTask
-
- CompletableFutureTask(Runnable, V, ExecutorService) - Constructor for class com.hazelcast.util.executor.CompletableFutureTask
-
- complete(Object) - Method in class com.hazelcast.client.util.ClientDelegatingFuture
-
- complete(Object) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
-
Can be called multiple times, but only the first answer will lead to the
future getting triggered.
- complete() - Method in class com.hazelcast.spi.impl.sequence.AbstractCallIdSequence
-
- complete() - Method in interface com.hazelcast.spi.impl.sequence.CallIdSequence
-
Not idempotent: must be called exactly once per invocation.
- complete() - Method in class com.hazelcast.spi.impl.sequence.CallIdSequenceWithoutBackpressure
-
- complete(Object) - Method in interface com.hazelcast.spi.InternalCompletableFuture
-
Completes this future.
- complete(Object) - Method in class com.hazelcast.util.executor.CompletedFuture
-
- complete(Object) - Method in class com.hazelcast.util.executor.DelegatingFuture
-
- completeConstruction(Collection<Integer>) - Method in class com.hazelcast.map.impl.query.AggregationResult
-
- completeConstruction(Collection<Integer>) - Method in class com.hazelcast.map.impl.query.QueryResult
-
- completeConstruction(Collection<Integer>) - Method in interface com.hazelcast.map.impl.query.Result
-
Completes the construction of this result.
- CompletedFuture<V> - Class in com.hazelcast.util.executor
-
- CompletedFuture(SerializationService, Object, Executor) - Constructor for class com.hazelcast.util.executor.CompletedFuture
-
- completedMigrations - Variable in class com.hazelcast.internal.networking.nio.NioPipeline
-
- completedTaskCount - Variable in class com.hazelcast.internal.management.dto.ManagedExecutorDTO
-
- completedTaskCount() - Method in class com.hazelcast.internal.networking.nio.NioThread
-
- completionId - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-
- completionId - Variable in class com.hazelcast.cache.impl.operation.AbstractMutatingCacheOperation
-
- ComposedKeyMap<K1,K2,V> - Class in com.hazelcast.util.collection
-
Map with a composed key.
- ComposedKeyMap() - Constructor for class com.hazelcast.util.collection.ComposedKeyMap
-
- CompositeEvictionChecker - Class in com.hazelcast.internal.eviction
-
- CompositeEvictionChecker(EvictionChecker...) - Constructor for class com.hazelcast.internal.eviction.CompositeEvictionChecker
-
- CompositeEvictionChecker.CompositionOperator - Enum in com.hazelcast.internal.eviction
-
- CompositeMessageTaskFactory - Class in com.hazelcast.client.impl
-
- CompositeMessageTaskFactory(NodeEngine) - Constructor for class com.hazelcast.client.impl.CompositeMessageTaskFactory
-
- CompoundPredicate - Interface in com.hazelcast.query.impl.predicates
-
Interface for predicates which operate on an array of sub-predicates.
- compress(byte[]) - Static method in class com.hazelcast.nio.IOUtil
-
- computeIfAbsent(int, IntFunction<? extends V>) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
-
Get a value for a given key, or if it does ot exist then default the value via a
IntFunction
and put it in the map.
- computeIfAbsent(long, LongFunction<? extends V>) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
-
Get a value for a given key, or if it does ot exist then default the value via a
LongFunction
and put it in the map.
- computePerturbationValue(int) - Static method in class com.hazelcast.util.HashUtil
-
Computes the key perturbation value applied before hashing.
- concat(T[], T[], T[]) - Static method in class com.hazelcast.util.collection.ArrayUtils
-
Copies in order sourceFirst
and sourceSecond
into dest
.
- concatenate(byte[], byte[]) - Static method in class com.hazelcast.internal.ascii.memcache.MemcacheCommandProcessor
-
- ConcurrencyUtil - Class in com.hazelcast.util
-
- CONCURRENT_MODIFICATION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- ConcurrentConveyor<E> - Class in com.hazelcast.internal.util.concurrent
-
A many-to-one conveyor of interthread messages.
- concurrentConveyor(E1, QueuedPipe<E1>...) - Static method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
-
Creates a new concurrent conveyor.
- ConcurrentConveyorException - Exception in com.hazelcast.internal.util.concurrent
-
- ConcurrentConveyorException(String) - Constructor for exception com.hazelcast.internal.util.concurrent.ConcurrentConveyorException
-
- ConcurrentConveyorException(String, Throwable) - Constructor for exception com.hazelcast.internal.util.concurrent.ConcurrentConveyorException
-
- ConcurrentConveyorSingleQueue<E> - Class in com.hazelcast.internal.util.concurrent
-
- concurrentConveyorSingleQueue(E1, QueuedPipe<E1>) - Static method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyorSingleQueue
-
Creates a new concurrent conveyor with a single queue.
- ConcurrentHeapMemoryAccessor - Interface in com.hazelcast.internal.memory
-
- ConcurrentMemoryAccessor - Interface in com.hazelcast.internal.memory
-
Extension of
MemoryAccessor
for memory operations with concurrent semantics:
volatile, ordered, and CAS.
- ConcurrentReferenceHashMap<K,V> - Class in com.hazelcast.util
-
An advanced hash table supporting configurable garbage collection semantics
of keys and values, optional referential-equality, full concurrency of
retrievals, and adjustable expected concurrency for updates.
- ConcurrentReferenceHashMap(int, float, int, ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType, EnumSet<ConcurrentReferenceHashMap.Option>) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
-
Creates a new, empty map with the specified initial
capacity, reference types, load factor, and concurrency level.
- ConcurrentReferenceHashMap(int, float, int) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
-
Creates a new, empty map with the specified initial
capacity, load factor, and concurrency level.
- ConcurrentReferenceHashMap(int, float) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
-
Creates a new, empty map with the specified initial capacity
and load factor and with the default reference types (weak keys,
strong values), and concurrencyLevel (16).
- ConcurrentReferenceHashMap(int, ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
-
Creates a new, empty map with the specified initial capacity,
reference types, and with a default load factor (0.75) and concurrencyLevel (16).
- ConcurrentReferenceHashMap(ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
-
Creates a new, empty reference map with the specified key
and value reference types.
- ConcurrentReferenceHashMap(ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType, EnumSet<ConcurrentReferenceHashMap.Option>) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
-
Creates a new, empty reference map with the specified reference types
and behavioral options.
- ConcurrentReferenceHashMap(int) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
-
Creates a new, empty map with the specified initial capacity,
and with default reference types (weak keys, strong values),
load factor (0.75) and concurrencyLevel (16).
- ConcurrentReferenceHashMap() - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
-
Creates a new, empty map with a default initial capacity (16),
reference types (weak keys, strong values), default
load factor (0.75) and concurrencyLevel (16).
- ConcurrentReferenceHashMap(Map<? extends K, ? extends V>) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
-
Creates a new map with the same mappings as the given map.
- ConcurrentReferenceHashMap.Option - Enum in com.hazelcast.util
-
Behavior-changing configuration options for the map
- ConcurrentReferenceHashMap.ReferenceType - Enum in com.hazelcast.util
-
An option specifying which Java reference type should be used to refer
to a key and/or value.
- ConcurrentReferenceHashMap.SimpleEntry<K,V> - Class in com.hazelcast.util
-
- ConcurrentReferenceHashMap.WriteThroughEntry - Class in com.hazelcast.util
-
Custom Entry class used by EntryIterator.next(), that relays setValue
changes to the underlying map.
- concurrentSetOfValues(Set<V>) - Static method in class com.hazelcast.cache.impl.DeferredValue
-
- ConditionAwaitMessageTask - Class in com.hazelcast.client.impl.protocol.task.condition
-
- ConditionAwaitMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.condition.ConditionAwaitMessageTask
-
- ConditionBeforeAwaitMessageTask - Class in com.hazelcast.client.impl.protocol.task.condition
-
- ConditionBeforeAwaitMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.condition.ConditionBeforeAwaitMessageTask
-
- ConditionKey - Class in com.hazelcast.concurrent.lock
-
- ConditionKey(String, Data, String, String, long) - Constructor for class com.hazelcast.concurrent.lock.ConditionKey
-
- ConditionSignalAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.condition
-
- ConditionSignalAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.condition.ConditionSignalAllMessageTask
-
- ConditionSignalMessageTask - Class in com.hazelcast.client.impl.protocol.task.condition
-
- ConditionSignalMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.condition.ConditionSignalMessageTask
-
- config - Variable in class com.hazelcast.collection.impl.txnqueue.TransactionalQueueProxySupport
-
- Config - Class in com.hazelcast.config
-
- Config() - Constructor for class com.hazelcast.config.Config
-
- Config(String) - Constructor for class com.hazelcast.config.Config
-
- config - Variable in class com.hazelcast.instance.Node
-
- config - Variable in class com.hazelcast.internal.cluster.impl.AbstractJoiner
-
- config - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-
- config - Variable in class com.hazelcast.multimap.impl.MultiMapProxySupport
-
- config - Variable in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
-
- CONFIG_CHECK - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
-
- CONFIG_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- CONFIG_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- CONFIG_MISMATCH - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- CONFIG_MISMATCH - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
-
- CONFIG_PUBLISH_MAX_ATTEMPT_COUNT - Static variable in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
-
- ConfigBuilder - Interface in com.hazelcast.config
-
Interface for all config builders.
- configBuilder - Variable in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
-
- ConfigCheck - Class in com.hazelcast.internal.cluster.impl
-
Contains enough information about Hazelcast Config to do a validation check so that clusters with different configurations
don't join.
- ConfigCheck() - Constructor for class com.hazelcast.internal.cluster.impl.ConfigCheck
-
- ConfigCheck(Config, String) - Constructor for class com.hazelcast.internal.cluster.impl.ConfigCheck
-
- configCheck - Variable in class com.hazelcast.internal.cluster.impl.JoinMessage
-
- ConfigCheckMode - Enum in com.hazelcast.internal.dynamicconfig
-
Behaviour when detects a configuration conflict while registering a new dynamic configuraiton.
- ConfigDataSerializerHook - Class in com.hazelcast.config
-
DataSerializerHook for com.hazelcast.config classes
- ConfigDataSerializerHook() - Constructor for class com.hazelcast.config.ConfigDataSerializerHook
-
- ConfigLoader - Class in com.hazelcast.config
-
Provides loading service for a configuration.
- ConfigMemberGroupFactory - Class in com.hazelcast.partition.membergroup
-
- ConfigMemberGroupFactory(Collection<MemberGroupConfig>) - Constructor for class com.hazelcast.partition.membergroup.ConfigMemberGroupFactory
-
- ConfigMismatchException - Exception in com.hazelcast.internal.cluster.impl
-
Exception thrown when 2 nodes want to join, but there configuration doesn't match
- ConfigMismatchException(String) - Constructor for exception com.hazelcast.internal.cluster.impl.ConfigMismatchException
-
- ConfigMismatchOp - Class in com.hazelcast.internal.cluster.impl.operations
-
When a node wants to join the cluster, its sends its ConfigCheck to the cluster where it is validated.
- ConfigMismatchOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.ConfigMismatchOp
-
- ConfigMismatchOp(String) - Constructor for class com.hazelcast.internal.cluster.impl.operations.ConfigMismatchOp
-
- ConfigPatternMatcher - Interface in com.hazelcast.config
-
The ConfigPatternMatcher provides a strategy to match an item name to a configuration pattern.
- ConfigPermission - Class in com.hazelcast.security.permission
-
- ConfigPermission() - Constructor for class com.hazelcast.security.permission.ConfigPermission
-
- ConfigPropertiesPlugin - Class in com.hazelcast.internal.diagnostics
-
- ConfigPropertiesPlugin(NodeEngineImpl) - Constructor for class com.hazelcast.internal.diagnostics.ConfigPropertiesPlugin
-
- ConfigPropertiesPlugin(ILogger, HazelcastProperties) - Constructor for class com.hazelcast.internal.diagnostics.ConfigPropertiesPlugin
-
- ConfigReplacer - Interface in com.hazelcast.config.replacer.spi
-
Interface to be implemented by pluggable variable replacers for the configuration files.
- configs - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-
- ConfigurableService<T> - Interface in com.hazelcast.spi
-
A capability for SPI services.
- CONFIGURATION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- ConfigurationException - Exception in com.hazelcast.config
-
A
HazelcastException
that is thrown when something is wrong with the server or client configuration.
- ConfigurationException(String, String, String) - Constructor for exception com.hazelcast.config.ConfigurationException
-
- ConfigurationException(String) - Constructor for exception com.hazelcast.config.ConfigurationException
-
- ConfigurationException(String, Throwable) - Constructor for exception com.hazelcast.config.ConfigurationException
-
- ConfigurationService - Interface in com.hazelcast.internal.dynamicconfig
-
Dynamic configurations.
- configure(GroupConfig, Properties) - Method in interface com.hazelcast.security.ICredentialsFactory
-
- configure(Config, Properties) - Method in interface com.hazelcast.security.IPermissionPolicy
-
- configure(T) - Method in interface com.hazelcast.spi.ConfigurableService
-
- configureSocket(Socket) - Method in interface com.hazelcast.nio.IOService
-
- configureSocket(Socket) - Method in class com.hazelcast.nio.NodeIOService
-
- ConfigUtils - Class in com.hazelcast.internal.config
-
Utility class to access configuration.
- ConfigValidator - Class in com.hazelcast.internal.config
-
Validates a Hazelcast configuration in a specific context like OS vs.
- ConfigXmlGenerator - Class in com.hazelcast.config
-
The ConfigXmlGenerator is responsible for transforming a
Config
to a Hazelcast XML string.
- ConfigXmlGenerator() - Constructor for class com.hazelcast.config.ConfigXmlGenerator
-
Creates a ConfigXmlGenerator that will format the code.
- ConfigXmlGenerator(boolean) - Constructor for class com.hazelcast.config.ConfigXmlGenerator
-
Creates a ConfigXmlGenerator.
- ConfigXmlGenerator(boolean, boolean) - Constructor for class com.hazelcast.config.ConfigXmlGenerator
-
Creates a ConfigXmlGenerator.
- connect() - Method in class com.hazelcast.client.spi.impl.ClientTransactionManagerServiceImpl
-
- CONNECT_ALL_WAIT_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
- connection - Variable in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-
- Connection - Interface in com.hazelcast.nio
-
Represents a 'connection' between two machines.
- connection - Variable in class com.hazelcast.nio.tcp.PacketDecoder
-
- CONNECTION_MONITOR_INTERVAL - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
- CONNECTION_MONITOR_MAX_FAULTS - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
- connectionAdded(Connection) - Method in class com.hazelcast.client.connection.nio.ClientICMPManager
-
- connectionAdded(Connection) - Method in class com.hazelcast.client.spi.impl.listener.NonSmartClientListenerService
-
- connectionAdded(Connection) - Method in class com.hazelcast.client.spi.impl.listener.SmartClientListenerService
-
- connectionAdded(Connection) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
-
- connectionAdded(Connection) - Method in interface com.hazelcast.nio.ConnectionListener
-
- connectionCount - Variable in class com.hazelcast.internal.management.dto.ConnectionManagerDTO
-
- ConnectionHeartbeatListener - Interface in com.hazelcast.client.spi.impl
-
- connectionIdGen - Variable in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-
- ConnectionListenable - Interface in com.hazelcast.nio
-
Provides connection listen capabilities.
- ConnectionListener - Interface in com.hazelcast.nio
-
A listener for the
ConnectionManager
to listen to connections
being added or removed.
- connectionManager - Variable in class com.hazelcast.client.spi.impl.AbstractClientInvocationService
-
- connectionManager - Variable in class com.hazelcast.instance.Node
-
- ConnectionManager - Interface in com.hazelcast.nio
-
- ConnectionManagerDTO - Class in com.hazelcast.internal.management.dto
-
- ConnectionManagerDTO() - Constructor for class com.hazelcast.internal.management.dto.ConnectionManagerDTO
-
- ConnectionManagerDTO(ConnectionManager) - Constructor for class com.hazelcast.internal.management.dto.ConnectionManagerDTO
-
- ConnectionManagerMBean - Class in com.hazelcast.internal.jmx
-
- ConnectionManagerMBean(HazelcastInstance, ConnectionManager, ManagementService) - Constructor for class com.hazelcast.internal.jmx.ConnectionManagerMBean
-
- connectionRemoved(Connection) - Method in class com.hazelcast.client.connection.nio.ClientICMPManager
-
- connectionRemoved(Connection) - Method in class com.hazelcast.client.spi.impl.listener.NonSmartClientListenerService
-
- connectionRemoved(Connection) - Method in class com.hazelcast.client.spi.impl.listener.SmartClientListenerService
-
- connectionRemoved(Connection) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
-
- connectionRemoved(Connection) - Method in interface com.hazelcast.nio.ConnectionListener
-
- ConnectionType - Enum in com.hazelcast.nio
-
An enumeration of all possible Connection types.
- connectToCluster() - Method in interface com.hazelcast.client.connection.ClientConnectionManager
-
- connectToCluster() - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-
- connectToClusterAsync() - Method in interface com.hazelcast.client.connection.ClientConnectionManager
-
- connectToClusterAsync() - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-
- CONSISTENCY_LOST_EXCEPTION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- ConsistencyLostException - Exception in com.hazelcast.core
-
Exception that indicates that the consistency guarantees provided by
some service has been lost.
- ConsistencyLostException(String) - Constructor for exception com.hazelcast.core.ConsistencyLostException
-
- ConsoleApp - Class in com.hazelcast.console
-
Special thanks to Alexandre Vasseur for providing this very nice test application.
- ConsoleApp(HazelcastInstance) - Constructor for class com.hazelcast.console.ConsoleApp
-
- ConsoleCommandHandler - Class in com.hazelcast.internal.management
-
Handler class for console commands that sent from Console application which located in Management Center.
- ConsoleCommandHandler(HazelcastInstance) - Constructor for class com.hazelcast.internal.management.ConsoleCommandHandler
-
- ConsoleCommandRequest - Class in com.hazelcast.internal.management.request
-
Request for sending console commands.
- ConsoleCommandRequest() - Constructor for class com.hazelcast.internal.management.request.ConsoleCommandRequest
-
- ConsoleRequest - Interface in com.hazelcast.internal.management.request
-
Represents request sent from Management Center.
- ConsoleRequestConstants - Class in com.hazelcast.internal.management.request
-
Constants to identify serialized requests.
- CONSTANT_SERIALIZERS_LENGTH - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-
- CONSTANT_TYPE_BOOLEAN - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-
- CONSTANT_TYPE_BOOLEAN_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-
- CONSTANT_TYPE_BYTE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-
- CONSTANT_TYPE_BYTE_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-
- CONSTANT_TYPE_CHAR - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-
- CONSTANT_TYPE_CHAR_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-
- CONSTANT_TYPE_DATA_SERIALIZABLE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-
- CONSTANT_TYPE_DOUBLE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-
- CONSTANT_TYPE_DOUBLE_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-
- CONSTANT_TYPE_FLOAT - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-
- CONSTANT_TYPE_FLOAT_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-
- CONSTANT_TYPE_INTEGER - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-
- CONSTANT_TYPE_INTEGER_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-
- CONSTANT_TYPE_LONG - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-
- CONSTANT_TYPE_LONG_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-
- CONSTANT_TYPE_NULL - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-
- CONSTANT_TYPE_PORTABLE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-
- CONSTANT_TYPE_SHORT - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-
- CONSTANT_TYPE_SHORT_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-
- CONSTANT_TYPE_STRING - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-
- CONSTANT_TYPE_STRING_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-
- ConstantSerializers - Class in com.hazelcast.internal.serialization.impl
-
- ConstantSerializers.BooleanArraySerializer - Class in com.hazelcast.internal.serialization.impl
-
- ConstantSerializers.BooleanSerializer - Class in com.hazelcast.internal.serialization.impl
-
- ConstantSerializers.ByteSerializer - Class in com.hazelcast.internal.serialization.impl
-
- ConstantSerializers.CharArraySerializer - Class in com.hazelcast.internal.serialization.impl
-
- ConstantSerializers.CharSerializer - Class in com.hazelcast.internal.serialization.impl
-
- ConstantSerializers.DoubleArraySerializer - Class in com.hazelcast.internal.serialization.impl
-
- ConstantSerializers.DoubleSerializer - Class in com.hazelcast.internal.serialization.impl
-
- ConstantSerializers.FloatArraySerializer - Class in com.hazelcast.internal.serialization.impl
-
- ConstantSerializers.FloatSerializer - Class in com.hazelcast.internal.serialization.impl
-
- ConstantSerializers.IntegerArraySerializer - Class in com.hazelcast.internal.serialization.impl
-
- ConstantSerializers.IntegerSerializer - Class in com.hazelcast.internal.serialization.impl
-
- ConstantSerializers.LongArraySerializer - Class in com.hazelcast.internal.serialization.impl
-
- ConstantSerializers.LongSerializer - Class in com.hazelcast.internal.serialization.impl
-
- ConstantSerializers.NullSerializer - Class in com.hazelcast.internal.serialization.impl
-
- ConstantSerializers.ShortArraySerializer - Class in com.hazelcast.internal.serialization.impl
-
- ConstantSerializers.ShortSerializer - Class in com.hazelcast.internal.serialization.impl
-
- ConstantSerializers.StringArraySerializer - Class in com.hazelcast.internal.serialization.impl
-
- ConstantSerializers.StringSerializer - Class in com.hazelcast.internal.serialization.impl
-
- ConstantSerializers.TheByteArraySerializer - Class in com.hazelcast.internal.serialization.impl
-
- ConstructorFunction<K,V> - Interface in com.hazelcast.util
-
See ConcurrencyUtil
- Consumer<T> - Interface in com.hazelcast.util.function
-
Represents an operation that accepts a single input argument and returns no
result.
- container - Variable in class com.hazelcast.collection.impl.queue.QueueItem
-
- CONTAINER - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-
- CONTAINER - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-
- containerIterator(int) - Method in class com.hazelcast.spi.impl.merge.AbstractContainerCollector
-
Returns all containers of the data structure for the given partition ID.
- containerIterator(int) - Method in class com.hazelcast.spi.impl.merge.AbstractNamedContainerCollector
-
- containers - Variable in class com.hazelcast.spi.impl.merge.AbstractNamedContainerCollector
-
- contains(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- contains(Data) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Determines if this store contains an entry for the specified key.
- contains(E) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-
- contains(Object) - Method in class com.hazelcast.client.proxy.ClientListProxy
-
- contains(Object) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-
- contains(Object) - Method in class com.hazelcast.client.proxy.ClientSetProxy
-
- contains(Object) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-
- contains(Set<Data>) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-
- contains(Collection<Data>) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-
Checks if the queue contains all items in the dataSet.
- CONTAINS - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-
- contains(Object) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
-
- contains(Data) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceContainer
-
- CONTAINS - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-
- contains(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- contains(E) - Method in interface com.hazelcast.core.IAtomicReference
-
Checks if the reference contains the value.
- contains(Object) - Method in class com.hazelcast.internal.cluster.impl.MemberSelectingCollection
-
- contains(long) - Method in interface com.hazelcast.internal.util.collection.LongSet
-
- contains(long) - Method in class com.hazelcast.internal.util.collection.LongSetHsa
-
- contains(E) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
-
Checks whether an element exist in this queue.
- CONTAINS - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- contains(Object) - Method in class com.hazelcast.query.impl.AndResultSet
-
- contains(Object) - Method in class com.hazelcast.query.impl.DuplicateDetectingMultiResult
-
- contains(Object) - Method in class com.hazelcast.query.impl.FastMultiResultSet
-
- contains(Object) - Method in class com.hazelcast.query.impl.OrResultSet
-
- contains(Object) - Method in class com.hazelcast.query.impl.SingleResultSet
-
- contains(T[], T) - Static method in class com.hazelcast.util.collection.ArrayUtils
-
- contains(Object) - Method in class com.hazelcast.util.collection.InflatableSet
-
- contains(Object) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.KeySet
-
- contains(int) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.KeySet
-
Non-boxing variant of contains().
- contains(Object) - Method in class com.hazelcast.util.collection.IntHashSet
-
- contains(int) - Method in class com.hazelcast.util.collection.IntHashSet
-
- contains(Object) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.KeySet
-
- contains(long) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.KeySet
-
Non-boxing variant of contains().
- contains(Object) - Method in class com.hazelcast.util.collection.LongHashSet
- contains(long) - Method in class com.hazelcast.util.collection.LongHashSet
- contains(Object) - Method in class com.hazelcast.util.collection.MapDelegatingSet
- contains(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
-
Legacy method testing if some key maps into the specified value
in this table.
- CONTAINS_ALL - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- CONTAINS_ENTRY - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- CONTAINS_KEY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- CONTAINS_KEY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- CONTAINS_KEY - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
-
- CONTAINS_VALUE - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- CONTAINS_VALUE - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
-
- CONTAINS_VALUE_FACTORY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- containsAddress(Address) - Method in class com.hazelcast.internal.cluster.impl.MembersView
-
- containsAll(Collection<?>) - Method in class com.hazelcast.client.proxy.ClientListProxy
-
- containsAll(Collection<?>) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-
- containsAll(Collection<?>) - Method in class com.hazelcast.client.proxy.ClientSetProxy
-
- containsAll(Collection<?>) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-
- containsAll(Collection<?>) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
-
- containsAll(Collection<?>) - Method in class com.hazelcast.internal.cluster.impl.MemberSelectingCollection
-
- containsAll(Collection<?>) - Method in class com.hazelcast.util.collection.IntHashSet
-
- containsAll(IntHashSet) - Method in class com.hazelcast.util.collection.IntHashSet
-
IntHashSet specialised variant of {this#containsAll(Collection)}.
- containsAll(Collection<?>) - Method in class com.hazelcast.util.collection.LongHashSet
- containsAll(LongHashSet) - Method in class com.hazelcast.util.collection.LongHashSet
-
LongHashSet specialised variant of {this#containsAll(Collection)}.
- containsAsync(E) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-
- containsAsync(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- containsAsync(E) - Method in interface com.hazelcast.core.IAtomicReference
-
Checks if the reference contains the value.
- containsAtomicLong(String) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-
- containsCounter(String) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
-
Returns true
if the CRDT state for the PN counter with the
given name
is present on this node.
- containsEntry(K, V) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-
- containsEntry(K, V) - Method in interface com.hazelcast.core.MultiMap
-
Returns whether the multimap contains the given key-value pair.
- containsEntry(boolean, Data, Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- containsEntry(K, V) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- ContainsEntryOperation - Class in com.hazelcast.multimap.impl.operations
-
- ContainsEntryOperation() - Constructor for class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
-
- ContainsEntryOperation(String, Data, Data) - Constructor for class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
-
- ContainsEntryOperation(String, Data, Data, long) - Constructor for class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
-
- containsInternal(Data, Data) - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-
- containsKey(K) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- containsKey(K) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-
- containsKey(Object) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- containsKey(K) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-
- containsKey(Object) - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
-
- containsKey(Object) - Method in class com.hazelcast.client.proxy.txn.ClientTxnMapProxy
-
- containsKey(Object) - Method in interface com.hazelcast.core.BaseMap
-
Returns true
if this map contains an entry for the specified
key.
- containsKey(Object) - Method in interface com.hazelcast.core.IMap
-
Returns true
if this map contains an entry for the specified
key.
- containsKey(K) - Method in interface com.hazelcast.core.MultiMap
-
Returns whether the multimap contains an entry with the key.
- containsKey(Object) - Method in interface com.hazelcast.core.TransactionalMap
-
- containsKey(K) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
-
- containsKey(K) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
-
- containsKey(K) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
-
- containsKey(K) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
-
- containsKey(K) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
-
- containsKey(Object) - Method in class com.hazelcast.internal.dynamicconfig.AggregatingMap
-
- containsKey(long) - Method in interface com.hazelcast.internal.util.collection.Long2LongMap
-
- containsKey(long) - Method in class com.hazelcast.internal.util.collection.Long2LongMapHsa
-
- containsKey(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- containsKey(Object) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
-
- containsKey(Data) - Method in interface com.hazelcast.map.impl.querycache.subscriber.QueryCacheRecordStore
-
- containsKey(Data) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- containsKey(Data) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
- containsKey(K) - Method in interface com.hazelcast.map.impl.recordstore.Storage
-
- containsKey(Data) - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
-
- containsKey(Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-
- containsKey(Object) - Method in interface com.hazelcast.map.QueryCache
-
- containsKey(Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- containsKey(K) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- containsKey(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- containsKey(Object) - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
-
- containsKey(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- containsKey(Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- containsKey(Object) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
-
- containsKey(int) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
-
- containsKey(long) - Method in class com.hazelcast.util.collection.Long2LongHashMap
-
Long primitive specialised containsKey.
- containsKey(Object) - Method in class com.hazelcast.util.collection.Long2LongHashMap
-
- containsKey(Object) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
-
- containsKey(long) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
-
- containsKey(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
-
Tests if the specified object is a key in this table.
- containsKeyInternal(Object) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-
- containsKeyInternal(Object) - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
-
- containsKeyInternal(Object) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- containsKeyInternal(Object) - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-
- containsKeyInternal(Object) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-
- ContainsKeyOperation - Class in com.hazelcast.map.impl.operation
-
- ContainsKeyOperation() - Constructor for class com.hazelcast.map.impl.operation.ContainsKeyOperation
-
- ContainsKeyOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.ContainsKeyOperation
-
- ContainsKeyOperation - Class in com.hazelcast.replicatedmap.impl.operation
-
- ContainsKeyOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ContainsKeyOperation
-
- ContainsKeyOperation(String, Data) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ContainsKeyOperation
-
- containsLatch(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- containsMember(Address, String) - Method in class com.hazelcast.internal.cluster.impl.MembersView
-
- ContainsOperation - Class in com.hazelcast.collection.impl.queue.operations
-
Checks whether contain or not item in the Queue.
- ContainsOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.ContainsOperation
-
- ContainsOperation(String, Collection<Data>) - Constructor for class com.hazelcast.collection.impl.queue.operations.ContainsOperation
-
- ContainsOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-
- ContainsOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.ContainsOperation
-
- ContainsOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.ContainsOperation
-
- containsQueue(String) - Method in class com.hazelcast.collection.impl.queue.QueueService
-
- containsRecordId(long) - Method in class com.hazelcast.multimap.impl.MultiMapValue
-
- containsRecordKey(K) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
-
- containsRecordKey(K) - Method in class com.hazelcast.internal.nearcache.impl.store.BaseHeapNearCacheRecordStore
-
- containsReferenceContainer(String) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-
- containsSemaphore(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-
- containsSpecialCharacters(String) - Static method in class com.hazelcast.internal.metrics.MetricsUtil
-
- containsValue(Object) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- containsValue(Object) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-
- containsValue(Object) - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
-
- containsValue(Object) - Method in interface com.hazelcast.core.IMap
- containsValue(Object) - Method in interface com.hazelcast.core.MultiMap
-
Returns whether the multimap contains an entry with the value.
- containsValue(Object) - Method in class com.hazelcast.internal.dynamicconfig.AggregatingMap
-
- containsValue(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- containsValue(Object) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
-
- containsValue(Object) - Method in interface com.hazelcast.map.impl.querycache.subscriber.QueryCacheRecordStore
-
- containsValue(Object) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- containsValue(Object) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
- containsValue(Object) - Method in interface com.hazelcast.map.QueryCache
-
- containsValue(boolean, Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- containsValue(Object) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- containsValue(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- containsValue(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- containsValue(Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- containsValue(Object) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
-
- containsValue(long) - Method in class com.hazelcast.util.collection.Long2LongHashMap
-
- containsValue(Object) - Method in class com.hazelcast.util.collection.Long2LongHashMap
-
- containsValue(Object) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
-
- containsValue(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
-
Returns true if this map maps one or more keys to the
specified value.
- ContainsValueOperation - Class in com.hazelcast.map.impl.operation
-
- ContainsValueOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.ContainsValueOperation
-
- ContainsValueOperation() - Constructor for class com.hazelcast.map.impl.operation.ContainsValueOperation
-
- ContainsValueOperation - Class in com.hazelcast.replicatedmap.impl.operation
-
- ContainsValueOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ContainsValueOperation
-
- ContainsValueOperation(String, Data) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ContainsValueOperation
-
- ContainsValueOperationFactory - Class in com.hazelcast.map.impl.operation
-
- ContainsValueOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.ContainsValueOperationFactory
-
- ContainsValueOperationFactory(String, Data) - Constructor for class com.hazelcast.map.impl.operation.ContainsValueOperationFactory
-
- CONTENT_LENGTH - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
-
- CONTENT_TYPE - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
-
- CONTENT_TYPE_BINARY - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
-
- CONTENT_TYPE_JSON - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
-
- CONTENT_TYPE_PLAIN_TEXT - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
-
- Context() - Constructor for class com.hazelcast.internal.networking.nio.NioEventLoopGroup.Context
-
- context - Variable in class com.hazelcast.map.impl.querycache.subscriber.AbstractQueryCacheEndToEndConstructor
-
- Context<K,V> - Interface in com.hazelcast.mapreduce
-
- ContextMutexFactory - Class in com.hazelcast.util
-
Provides reference-counted mutexes suitable for synchronization in the context of a supplied object.
- ContextMutexFactory() - Constructor for class com.hazelcast.util.ContextMutexFactory
-
- ContextMutexFactory.Mutex - Class in com.hazelcast.util
-
Reference counted mutex, which will remove itself from the mutexMap when it is no longer referenced.
- convert(Comparable) - Method in interface com.hazelcast.core.TypeConverter
-
- convert(long, MemoryUnit) - Method in enum com.hazelcast.memory.MemoryUnit
-
- convert(Map.Entry, Comparable, Comparable) - Method in class com.hazelcast.query.impl.predicates.AbstractPredicate
-
Converts givenAttributeValue to the type of entryAttributeValue
Good practice: do not invoke this method if entryAttributeValue == null
- convert(Comparable) - Method in class com.hazelcast.query.impl.TypeConverters.BaseTypeConverter
-
- convertData(Data, DataType) - Method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1
-
- convertData(Data, DataType) - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
-
- convertEnumValue(Object) - Method in class com.hazelcast.query.impl.predicates.AbstractPredicate
-
- convertToEventType(CacheEventType) - Static method in enum com.hazelcast.cache.CacheEventType
-
- convertToLazyEntryView(EntryView<K, V>, SerializationService, MapMergePolicy) - Static method in class com.hazelcast.map.impl.EntryViews
-
- convertToLetter(int) - Method in class com.hazelcast.util.PhoneHome
-
- convertVersionToString(int) - Static method in class com.hazelcast.internal.management.ManagementCenterIdentifier
-
- copy() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
-
- copy(T, boolean) - Method in class com.hazelcast.config.CacheConfig
-
Copy this CacheConfig to given target
object whose type extends CacheConfig.
- copy(File, File) - Static method in class com.hazelcast.nio.IOUtil
-
Deep copies source to target and creates the target if necessary.
- copy(InputStream, File) - Static method in class com.hazelcast.nio.IOUtil
-
Deep copies source to target.
- copy(IntHashSet) - Method in class com.hazelcast.util.collection.IntHashSet
-
- copy(LongHashSet) - Method in class com.hazelcast.util.collection.LongHashSet
- copyCollections() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- copyFile(File, File, long) - Static method in class com.hazelcast.nio.IOUtil
-
Copies source file to target and creates the target if necessary.
- copyFromByteArray(byte[], int, long, int) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- copyFromByteArray(byte[], int, long, int) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- copyFromByteArray(byte[], int, long, int) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
-
Copies bytes from a Java byte array into this accessor's address space.
- copyMemory(Object, long, Object, long, long) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Copies memory from source to destination.
- copyMemory(long, long, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- copyMemory(Object, long, Object, long, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- copyMemory(long, long, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- copyMemory(Object, long, Object, long, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- copyMemory(long, long, long) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
-
Copies memory from given source address to given destination address
as given size.
- copyTo(byte[], int) - Method in class com.hazelcast.internal.serialization.impl.HeapData
-
- copyTo(byte[], int) - Method in interface com.hazelcast.nio.serialization.Data
-
Copies the payload contained in the Data to the destination buffer.
- copyToByteArray(long, byte[], int, int) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- copyToByteArray(long, byte[], int, int) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- copyToByteArray(long, byte[], int, int) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
-
Copies bytes from this accessor's address space to a Java byte array.
- copyToHeapBuffer(ByteBuffer, ByteBuffer) - Static method in class com.hazelcast.nio.IOUtil
-
- copyWithoutNulls(T[], T[]) - Static method in class com.hazelcast.util.collection.ArrayUtils
-
Copy src array into destination and skip null values.
- CoreService - Interface in com.hazelcast.spi
-
Marker interface for core Hazelcast services.
- count() - Static method in class com.hazelcast.aggregation.Aggregators
-
- count(String) - Static method in class com.hazelcast.aggregation.Aggregators
-
- COUNT - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
-
- count(String, String, String) - Method in class com.hazelcast.internal.diagnostics.StoreLatencyPlugin
-
- count() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
-
Deprecated.
Returns an aggregation for counting all supplied values.
This aggregation is similar to:
- COUNT - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- COUNT_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- COUNT_DOWN_LATCH_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-
- COUNT_DOWN_LATCH_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
-
- COUNT_DOWN_LATCH_REPLICATION_OPERATION - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-
- COUNT_DOWN_OPERATION - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-
- COUNT_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- CountAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
-
The predefined count aggregation.
- CountAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.CountAggregation
-
- CountAggregator<I> - Class in com.hazelcast.aggregation.impl
-
- CountAggregator() - Constructor for class com.hazelcast.aggregation.impl.CountAggregator
-
- CountAggregator(String) - Constructor for class com.hazelcast.aggregation.impl.CountAggregator
-
- countDown() - Method in class com.hazelcast.client.proxy.ClientCountDownLatchProxy
-
- countDown() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
-
- countDown() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
-
- countDown(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- countDown() - Method in interface com.hazelcast.core.ICountDownLatch
-
Decrements the count of the latch, releasing all waiting threads if
the count reaches zero.
- countDown() - Method in class com.hazelcast.internal.jmx.CountDownLatchMBean
-
- countDownCompletionLatch(int) - Method in interface com.hazelcast.cache.impl.CacheSyncListenerCompleter
-
- CountDownLatchAwaitMessageTask - Class in com.hazelcast.client.impl.protocol.task.countdownlatch
-
- CountDownLatchAwaitMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchAwaitMessageTask
-
- CountDownLatchBackupOperation - Class in com.hazelcast.concurrent.countdownlatch.operations
-
- CountDownLatchBackupOperation() - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
-
- CountDownLatchBackupOperation(String, int) - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
-
- CountDownLatchConfig - Class in com.hazelcast.config
-
- CountDownLatchConfig() - Constructor for class com.hazelcast.config.CountDownLatchConfig
-
- CountDownLatchConfig(String) - Constructor for class com.hazelcast.config.CountDownLatchConfig
-
- CountDownLatchConfig(CountDownLatchConfig) - Constructor for class com.hazelcast.config.CountDownLatchConfig
-
Creates a CountDownLatchConfig by cloning another one.
- CountDownLatchContainer - Class in com.hazelcast.concurrent.countdownlatch
-
- CountDownLatchContainer() - Constructor for class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
-
- CountDownLatchContainer(String) - Constructor for class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
-
- CountDownLatchCountDownMessageTask - Class in com.hazelcast.client.impl.protocol.task.countdownlatch
-
- CountDownLatchCountDownMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchCountDownMessageTask
-
- CountDownLatchDataSerializerHook - Class in com.hazelcast.concurrent.countdownlatch
-
- CountDownLatchDataSerializerHook() - Constructor for class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-
- CountDownLatchGetCountMessageTask - Class in com.hazelcast.client.impl.protocol.task.countdownlatch
-
- CountDownLatchGetCountMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchGetCountMessageTask
-
- CountDownLatchMBean - Class in com.hazelcast.internal.jmx
-
- CountDownLatchMBean(ICountDownLatch, ManagementService) - Constructor for class com.hazelcast.internal.jmx.CountDownLatchMBean
-
- CountDownLatchPermission - Class in com.hazelcast.security.permission
-
- CountDownLatchPermission(String, String...) - Constructor for class com.hazelcast.security.permission.CountDownLatchPermission
-
- CountDownLatchProxy - Class in com.hazelcast.concurrent.countdownlatch
-
- CountDownLatchProxy(String, NodeEngine) - Constructor for class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
-
- CountDownLatchReplicationOperation - Class in com.hazelcast.concurrent.countdownlatch.operations
-
- CountDownLatchReplicationOperation() - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
-
- CountDownLatchReplicationOperation(Collection<CountDownLatchContainer>) - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
-
- CountDownLatchService - Class in com.hazelcast.concurrent.countdownlatch
-
- CountDownLatchService() - Constructor for class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- CountDownLatchTrySetCountMessageTask - Class in com.hazelcast.client.impl.protocol.task.countdownlatch
-
- CountDownLatchTrySetCountMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchTrySetCountMessageTask
-
- CountDownOperation - Class in com.hazelcast.concurrent.countdownlatch.operations
-
- CountDownOperation() - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
-
- CountDownOperation(String) - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
-
- Counter - Interface in com.hazelcast.internal.util.counters
-
A Counter keeps track of a long value.
- CountingMigrationAwareService - Class in com.hazelcast.spi.impl
-
- CountingMigrationAwareService(FragmentedMigrationAwareService) - Constructor for class com.hazelcast.spi.impl.CountingMigrationAwareService
-
- countInternal(Data) - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-
- CountOperation - Class in com.hazelcast.multimap.impl.operations
-
- CountOperation() - Constructor for class com.hazelcast.multimap.impl.operations.CountOperation
-
- CountOperation(String, Data) - Constructor for class com.hazelcast.multimap.impl.operations.CountOperation
-
- CPP - Static variable in class com.hazelcast.client.ClientTypes
-
CPP client protocol ID
- CRDT<T extends CRDT<T>> - Interface in com.hazelcast.crdt
-
Common interface for CRDT (conflict-free replicated data type)
implementations.
- CRDT_REPLICATION_MIGRATION_EXECUTOR - Static variable in class com.hazelcast.crdt.CRDTReplicationMigrationService
-
The executor for the CRDT replication and migration tasks
- CRDT_TIMESTAMPED_LONG - Static variable in class com.hazelcast.crdt.CRDTDataSerializerHook
-
- CRDTDataSerializerHook - Class in com.hazelcast.crdt
-
Serialization constants for all CRDT related objects
- CRDTDataSerializerHook() - Constructor for class com.hazelcast.crdt.CRDTDataSerializerHook
-
- CRDTReplicationAwareService<T> - Interface in com.hazelcast.crdt
-
Represents a service implementing a CRDT that may be replicated and
migrated to other replicas of the same CRDT.
- CRDTReplicationConfig - Class in com.hazelcast.config
-
Configures the replication mechanism for all
CRDT
implementations.
- CRDTReplicationConfig() - Constructor for class com.hazelcast.config.CRDTReplicationConfig
-
- CRDTReplicationContainer - Class in com.hazelcast.crdt
-
A container for a CRDT replication operation.
- CRDTReplicationContainer(Operation, Map<String, VectorClock>) - Constructor for class com.hazelcast.crdt.CRDTReplicationContainer
-
- CRDTReplicationMigrationService - Class in com.hazelcast.crdt
-
Service that handles replication and migration of CRDT data for all CRDT
implementations.
- CRDTReplicationMigrationService() - Constructor for class com.hazelcast.crdt.CRDTReplicationMigrationService
-
- CRDTTimestampedLong - Class in com.hazelcast.crdt.pncounter.operations
-
Response for CRDT PN counter operations which contains the PN counter
value as well as the current replica vector clock.
- CRDTTimestampedLong() - Constructor for class com.hazelcast.crdt.pncounter.operations.CRDTTimestampedLong
-
- CRDTTimestampedLong(long, VectorClock) - Constructor for class com.hazelcast.crdt.pncounter.operations.CRDTTimestampedLong
-
- create(String, ClientContext) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxyFactory
-
- create(ClientMessage, Connection) - Method in class com.hazelcast.client.impl.CompositeMessageTaskFactory
-
- create() - Static method in class com.hazelcast.client.impl.protocol.ClientMessage
-
- create(ClientMessage, Connection) - Method in interface com.hazelcast.client.impl.protocol.MessageTaskFactory
-
- create(String) - Method in interface com.hazelcast.client.spi.ClientProxyFactory
-
Creates a new client proxy with the given ID
- create(String) - Method in class com.hazelcast.client.spi.impl.ClientProxyFactoryWithContext
-
- create(String, ClientContext) - Method in class com.hazelcast.client.spi.impl.ClientProxyFactoryWithContext
-
Creates a new client proxy with the given ID.
- create(String, QueueStoreConfig, SerializationService, ClassLoader) - Static method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
-
- create(Node) - Static method in class com.hazelcast.instance.NodeExtensionFactory
-
- create(SocketChannel, boolean, boolean) - Method in interface com.hazelcast.internal.networking.ChannelFactory
-
Creates the Channel.
- create(SocketChannel, boolean, boolean) - Method in class com.hazelcast.internal.networking.nio.NioChannelFactory
-
- create(int) - Method in class com.hazelcast.internal.serialization.impl.ArrayDataSerializableFactory
-
- create(int, Version) - Method in class com.hazelcast.internal.serialization.impl.ArrayDataSerializableFactory
-
- create(InternalSerializationService) - Method in interface com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolFactory
-
- create(InternalSerializationService) - Method in class com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolFactoryImpl
-
- create(QueryCacheRequest, String) - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheFactory
-
- create(int) - Method in interface com.hazelcast.nio.serialization.DataSerializableFactory
-
Creates an IdentifiedDataSerializable instance using given type ID
- create(int, Version) - Method in interface com.hazelcast.nio.serialization.impl.VersionedDataSerializableFactory
-
Creates an IdentifiedDataSerializable instance using given type ID and object version
- create(int) - Method in interface com.hazelcast.nio.serialization.PortableFactory
-
Creates a Portable instance using given class ID
- create(boolean) - Method in interface com.hazelcast.nio.ssl.SSLEngineFactory
-
Creates a SSLEngine.
- create(ObjectNamespace, RingbufferStoreConfig, InMemoryFormat, SerializationService, ClassLoader) - Static method in class com.hazelcast.ringbuffer.impl.RingbufferStoreWrapper
-
- CREATE - Static variable in class com.hazelcast.security.permission.InstancePermission
-
- create() - Method in interface com.hazelcast.spi.impl.operationservice.impl.batching.PartitionAwareCallableFactory
-
- create(Throwable, String) - Method in interface com.hazelcast.util.ExceptionUtil.RuntimeExceptionFactory
-
- CREATE_ACCUMULATOR_INFO - Static variable in class com.hazelcast.map.impl.client.MapPortableHook
-
- CREATE_ALLOWED_DURING_PASSIVE_STATE_TX_BACKUP_LOG - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
-
- CREATE_CONFIG - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- CREATE_TX_BACKUP_LOG - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
-
- createAccumulator(AccumulatorInfo) - Method in interface com.hazelcast.map.impl.querycache.accumulator.AccumulatorFactory
-
- createAccumulator(AccumulatorInfo) - Method in class com.hazelcast.map.impl.querycache.publisher.PublisherAccumulatorFactory
-
- createAccumulator(AccumulatorInfo) - Method in class com.hazelcast.map.impl.querycache.subscriber.SubscriberAccumulatorFactory
-
- createAccumulatorInfo(QueryCacheConfig, String, String, Predicate) - Static method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
-
- createAccumulatorInfo(String, String, Predicate, int, int, long, boolean, boolean, boolean) - Static method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
-
- createAccumulatorProcessor(AccumulatorInfo, QueryCacheEventService) - Method in class com.hazelcast.map.impl.querycache.accumulator.BasicAccumulator
-
- createAddressPicker(Node) - Method in class com.hazelcast.instance.DefaultNodeContext
-
- createAddressPicker(Node) - Method in interface com.hazelcast.instance.NodeContext
-
- createAdHocRunner() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationRunnerFactory
-
Creates an ad hoc generic OperationRunner.
- createAllLocalMapStats() - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
-
- createAllowedDuringPassiveStateBackupLog(String, String) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-
- CreateAllowedDuringPassiveStateTxBackupLogOperation - Class in com.hazelcast.transaction.impl.operations
-
- CreateAllowedDuringPassiveStateTxBackupLogOperation() - Constructor for class com.hazelcast.transaction.impl.operations.CreateAllowedDuringPassiveStateTxBackupLogOperation
-
- CreateAllowedDuringPassiveStateTxBackupLogOperation(String, String) - Constructor for class com.hazelcast.transaction.impl.operations.CreateAllowedDuringPassiveStateTxBackupLogOperation
-
- createAndFillBeanBuilder(Node, Class, String, BeanDefinitionBuilder, String...) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
-
- createAndFillListedBean(Node, Class, String, ManagedMap<String, AbstractBeanDefinition>, String...) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
-
- createBackoffIdleStrategy(String) - Static method in class com.hazelcast.util.concurrent.BackoffIdleStrategy
-
Creates a new BackoffIdleStrategy.
- createBackupEntryProcessor() - Method in interface com.hazelcast.cache.BackupAwareEntryProcessor
-
Either creates a new, specialized EntryProcessor
to be executed on the backup-partition, or returns
- createBackupLog(String, String) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-
- createBaseEventContext(CacheEventType, Data, Data, long, String, int) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
-
- createBeanBuilder(Class) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
-
- createBoundedWriteBehindQueue(int, AtomicInteger) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueues
-
- createBuffer(byte[]) - Static method in class com.hazelcast.client.impl.protocol.util.BufferBuilder
-
Creates ClientProtocolBuffer safe/unsafe according to property with existing byteArray
- createCache(String, C) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- createCacheCompleteEvent(int) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
-
- createCacheCompleteEvent(Data, int) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
-
- createCacheCompleteEvent(Data, long, String, int) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
-
- createCacheConfig(String, C) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- createCacheConfig(String, CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- createCacheConfig(String, CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
-
- createCacheConfig(String, CacheConfig<K, V>) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
-
- createCacheConfigOnAllMembers(PreJoinCacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- createCacheConfigOnAllMembers(PreJoinCacheConfig<K, V>) - Method in interface com.hazelcast.cache.impl.ICacheService
-
Creates the given CacheConfig on all members of the cluster synchronously.
- createCacheConfigOnAllMembersAsync(PreJoinCacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- createCacheCreatedEvent(Data, Data, long, String, int) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
-
- createCacheDataRecord(Data, long, long) - Method in class com.hazelcast.cache.impl.record.CacheRecordFactory
-
- createCacheEntryProcessorEntry(Data, R, long, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- createCacheEntryProcessorEntry(Data, CacheRecord, long, int) - Method in class com.hazelcast.cache.impl.CacheRecordStore
-
- createCacheEvictionChecker(int, EvictionConfig.MaxSizePolicy) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
Creates an instance for checking if the maximum cache size has been reached.
- createCacheEvictionChecker(int, EvictionConfig.MaxSizePolicy) - Method in class com.hazelcast.cache.impl.CacheRecordStore
-
Creates an instance for checking if the maximum cache size has been reached.
- createCacheExpiredEvent(Data, Data, long, String, int) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
-
- createCacheManager(HazelcastInstance, URI, ClassLoader, Properties) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- createCacheManager(HazelcastInstance, URI, ClassLoader, Properties) - Method in class com.hazelcast.cache.impl.HazelcastServerCachingProvider
-
- createCacheManager(HazelcastInstance, URI, ClassLoader, Properties) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCachingProvider
-
- createCacheObjectRecord(Object, long, long) - Method in class com.hazelcast.cache.impl.record.CacheRecordFactory
-
- createCacheProxy(CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- createCacheProxy(CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
-
- createCacheProxy(CacheConfig<K, V>) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
-
- createCacheRecordFactory() - Method in class com.hazelcast.cache.impl.CacheRecordStore
-
- createCacheRemovedEvent(Data, Data, long, String, int) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
-
- createCacheRemovedEvent(Data) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
-
- createCacheStatIfAbsent(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- createCacheStatIfAbsent(String) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- createCacheUpdatedEvent(Data, Data, Data, long, long, long, long, String, int) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
-
- createCacheUpdatedEvent(Data, Data, Data, long, long, long, long) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
-
- createCachingProvider(HazelcastInstance) - Static method in class com.hazelcast.cache.impl.HazelcastServerCachingProvider
-
Helper method for creating caching provider for testing, etc.
- createCachingProvider(HazelcastInstance) - Static method in class com.hazelcast.client.cache.impl.HazelcastClientCachingProvider
-
Helper method for creating caching provider for testing etc.
- createClearOperation(String) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createClearOperation(String) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createClearOperationFactory() - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createClearOperationFactory() - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createClearOperationFactory(String) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createClearOperationFactory(String) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createClientLoginContext(Credentials) - Method in interface com.hazelcast.security.SecurityContext
-
- createClientProxyDescriptors() - Method in interface com.hazelcast.client.spi.ClientProxyDescriptorProvider
-
Return registered clientProxy descriptors
- createClientUuid(Address) - Static method in class com.hazelcast.util.UuidUtil
-
Creates a new client
UUID
string,
based on a cryptographically weak pseudo random number generator.
- createClusterUuid() - Static method in class com.hazelcast.util.UuidUtil
-
Creates a new cluster
UUID
string,
based on a cryptographically weak pseudo random number generator.
- createCollection(MultiMapConfig.ValueCollectionType) - Static method in class com.hazelcast.multimap.impl.ValueCollectionFactory
-
- createCollection(Collection) - Static method in class com.hazelcast.multimap.impl.ValueCollectionFactory
-
- createCollection(MultiMapConfig.ValueCollectionType, int) - Static method in class com.hazelcast.multimap.impl.ValueCollectionFactory
-
- createConcurrentHashMap(int) - Static method in class com.hazelcast.util.MapUtil
-
Utility method that creates an
LinkedHashMap
with its initialCapacity calculated
to minimize rehash operations
- createConcurrentSet() - Method in class com.hazelcast.config.AbstractCacheConfig
-
- createConfigCheck() - Method in class com.hazelcast.instance.Node
-
- createConnectionManager(HazelcastClientInstanceImpl, AddressTranslator, Collection<AddressProvider>) - Method in interface com.hazelcast.client.impl.ClientConnectionManagerFactory
-
- createConnectionManager(HazelcastClientInstanceImpl, AddressTranslator, Collection<AddressProvider>) - Method in class com.hazelcast.client.impl.DefaultClientConnectionManagerFactory
-
- createConnectionManager(Node, ServerSocketChannel) - Method in class com.hazelcast.instance.DefaultNodeContext
-
- createConnectionManager(Node, ServerSocketChannel) - Method in interface com.hazelcast.instance.NodeContext
-
- createContainsKeyOperation(Data) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createContainsKeyOperation(Data) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createContainsKeyOperation(String, Data) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createContainsKeyOperation(String, Data) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createContainsValueOperationFactory(String, Data) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createContainsValueOperationFactory(String, Data) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createCopy(T[]) - Static method in class com.hazelcast.util.collection.ArrayUtils
-
Create copy of the src array.
- createCreateTxBackupLogOperation() - Method in class com.hazelcast.transaction.impl.AllowedDuringPassiveStateTransactionImpl
-
- createCreateTxBackupLogOperation() - Method in class com.hazelcast.transaction.impl.TransactionImpl
-
- createDefault(K, V, long, int) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntries
-
- createDefaultEntryView(Data, Data, CacheRecord) - Static method in class com.hazelcast.cache.impl.CacheEntryViews
-
- createDefaultWriteBehindQueue() - Static method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueues
-
- createDeleteOperation(String, Data, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createDeleteOperation(String, Data, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
Creates a delete operation for an entry with key equal to key
from the map named name
.
- createDeleteOperation(String, Data, boolean) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-
- createDestroyQueryCacheOperation(String, String) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientSubscriberContextSupport
-
- createDestroyQueryCacheOperation(String, String) - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeSubscriberContextSupport
-
- createDestroyQueryCacheOperation(String, String) - Method in interface com.hazelcast.map.impl.querycache.subscriber.SubscriberContextSupport
-
Creates recovery operation for event loss cases.
- createDiscoveryService(DiscoveryConfig, Member) - Method in class com.hazelcast.instance.Node
-
- createDistributedObject(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- createDistributedObject(String) - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorService
-
- createDistributedObject(String) - Method in class com.hazelcast.collection.impl.list.ListService
-
- createDistributedObject(String) - Method in class com.hazelcast.collection.impl.queue.QueueService
-
- createDistributedObject(String) - Method in class com.hazelcast.collection.impl.set.SetService
-
- createDistributedObject(String) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-
- createDistributedObject(String) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-
- createDistributedObject(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- createDistributedObject(String) - Method in class com.hazelcast.concurrent.idgen.IdGeneratorService
-
- createDistributedObject(String) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- createDistributedObject(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-
- createDistributedObject(String) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
-
- createDistributedObject(String) - Method in class com.hazelcast.durableexecutor.impl.DistributedDurableExecutorService
-
- createDistributedObject(String) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
-
- createDistributedObject(String) - Method in class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorService
-
- createDistributedObject(String) - Method in class com.hazelcast.map.impl.MapService
-
- createDistributedObject(String) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- createDistributedObject(String) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- createDistributedObject(String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-
- createDistributedObject(String) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
-
- createDistributedObject(String) - Method in class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
-
- createDistributedObject(String) - Method in interface com.hazelcast.spi.RemoteService
-
Creates a distributed object.
- createDistributedObject(String) - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicService
-
- createDistributedObject(String) - Method in class com.hazelcast.topic.impl.TopicService
-
- createDistributedObject(String) - Method in class com.hazelcast.transaction.impl.xa.XAService
-
- createDistributedObjectsOnCluster(Connection) - Method in class com.hazelcast.client.spi.ProxyManager
-
- createDynamicConfigListener() - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- createDynamicConfigListener() - Method in interface com.hazelcast.instance.NodeExtension
-
Creates a listener for changes in dynamic data structure configurations
- createEmptyResponseHandler() - Static method in class com.hazelcast.spi.impl.OperationResponseHandlerFactory
-
- createEntryCountResolver(CacheContext) - Static method in class com.hazelcast.cache.impl.CacheEntryCountResolver
-
- createEntryIteratorOperation(int, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createEntryIteratorOperation(int, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createEntryOperation(String, Data, EntryProcessor) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createEntryOperation(String, Data, EntryProcessor) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createEntryOperation(String, Data, EntryProcessor) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-
- createEntryProcessorOperation(Data, Integer, EntryProcessor, Object...) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createEntryProcessorOperation(Data, Integer, EntryProcessor, Object...) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createEntryView(Data, Data, CacheRecord, CacheEntryViews.CacheEntryViewType) - Static method in class com.hazelcast.cache.impl.CacheEntryViews
-
- createErrorLoggingResponseHandler(ILogger) - Static method in class com.hazelcast.spi.impl.OperationResponseHandlerFactory
-
- createEvictAllOperation(String) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createEvictAllOperation(String) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createEvictAllOperationFactory(String) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createEvictAllOperationFactory(String) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createEvictionPolicyEvaluator(EvictionConfig) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- createEvictionStrategy(EvictionConfig) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- createEvictOperation(String, Data, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createEvictOperation(String, Data, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createException(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.ClientExceptionFactory
-
- createException(String, Throwable) - Method in interface com.hazelcast.client.impl.protocol.ClientExceptionFactory.ExceptionFactory
-
- createExceptionMessage(Throwable) - Method in class com.hazelcast.client.impl.protocol.ClientExceptionFactory
-
- createExecutorContainer(String, TaskRingBuffer) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorPartitionContainer
-
- createExtensionServices() - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- createExtensionServices() - Method in interface com.hazelcast.instance.NodeExtension
-
Creates additional extension services, which will be registered by
service manager during start-up.
- createFactory() - Method in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.client.impl.ClientDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.concurrent.lock.LockDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.config.ConfigDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.crdt.CRDTDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.executor.impl.ExecutorDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.internal.ascii.TextProtocolsDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.internal.journal.EventJournalDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.internal.management.ManagementDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.internal.partition.impl.PartitionPortableHook
-
- createFactory() - Method in interface com.hazelcast.internal.serialization.DataSerializerHook
-
- createFactory() - Method in interface com.hazelcast.internal.serialization.PortableHook
-
- createFactory() - Method in class com.hazelcast.internal.usercodedeployment.impl.UserCodeDeploymentSerializerHook
-
- createFactory() - Method in class com.hazelcast.map.impl.client.MapPortableHook
-
- createFactory() - Method in class com.hazelcast.map.impl.MapDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.mapreduce.impl.MapReducePortableHook
-
- createFactory() - Method in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.projection.impl.ProjectionDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- createFactory() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.ringbuffer.impl.client.RingbufferPortableHook
-
- createFactory() - Method in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.spi.impl.SpiDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.spi.impl.SpiPortableHook
-
- createFactory() - Method in class com.hazelcast.topic.impl.TopicDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.wan.impl.WanDataSerializerHook
-
- createFactoryOnRunner(NodeEngine) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperationFactory
-
- createFactoryOnRunner(NodeEngine) - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionAwareOperationFactory
-
This method will be called on operation runner node.
- createFetchEntriesOperation(String, int, int) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createFetchEntriesOperation(String, int, int) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createFetchKeysOperation(String, int, int) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createFetchKeysOperation(String, int, int) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createFetchWithQueryOperation(String, int, int, Query) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createFetchWithQueryOperation(String, int, int, Query) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
Creates an operation for fetching a segment of a query result from a single partition.
- createForDecode(ClientProtocolBuffer, int) - Static method in class com.hazelcast.client.impl.protocol.ClientMessage
-
- createForEncode(int) - Static method in class com.hazelcast.client.impl.protocol.ClientMessage
-
- createForEncode(ClientProtocolBuffer, int) - Static method in class com.hazelcast.client.impl.protocol.ClientMessage
-
- createGenericRunner() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationRunnerFactory
-
Creates an OperationRunner to execute generic Operations.
- createGetAllOperationFactory(Set<Data>, ExpiryPolicy) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createGetAllOperationFactory(Set<Data>, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createGetAllOperationFactory(String, List<Data>) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createGetAllOperationFactory(String, List<Data>) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createGetAndRemoveOperation(Data, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createGetAndRemoveOperation(Data, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createGetAndReplaceOperation(Data, Data, ExpiryPolicy, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createGetAndReplaceOperation(Data, Data, ExpiryPolicy, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createGetEntryViewOperation(String, Data) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createGetEntryViewOperation(String, Data) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createGetOperation(Data, ExpiryPolicy) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createGetOperation(Data, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createGetOperation(String, Data) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createGetOperation(String, Data) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createGetter(Object, String) - Static method in class com.hazelcast.query.impl.getters.ReflectionHelper
-
- createHashMap(int) - Static method in class com.hazelcast.util.MapUtil
-
Utility method that creates an
HashMap
with its initialCapacity calculated
to minimize rehash operations
- createHashMapAdapter(int) - Static method in class com.hazelcast.util.MapUtil
-
Utility method that creates an
HashMapAdapter
with its initialCapacity calculated
to minimize rehash operations
- createHashSet(int) - Static method in class com.hazelcast.util.SetUtil
-
Utility method that creates an
HashSet
with its initialCapacity calculated
to minimize rehash operations
- createHazelcastCacheManager(URI, ClassLoader, Properties) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- createHazelcastInstanceClient(C, ClientConnectionManagerFactory) - Method in interface com.hazelcast.client.HazelcastClientFactory
-
- createIMapEvent(EventData, EventFilter, Member, SerializationService) - Static method in class com.hazelcast.map.impl.querycache.subscriber.EventPublisherHelper
-
- createInboundHandler(TcpIpConnection, IOService) - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- createInboundHandler(TcpIpConnection, IOService) - Method in interface com.hazelcast.instance.NodeExtension
-
Creates a ChannelInboundHandler for given Connection instance.
- createInboundHandler(TcpIpConnection) - Method in interface com.hazelcast.nio.IOService
-
- createInboundHandler(TcpIpConnection) - Method in class com.hazelcast.nio.NodeIOService
-
- createIndex(String, boolean, Extractors, InternalSerializationService, IndexCopyBehavior) - Method in class com.hazelcast.map.impl.query.DefaultIndexProvider
-
- createIndex(String, boolean, Extractors, InternalSerializationService, IndexCopyBehavior) - Method in interface com.hazelcast.map.impl.query.IndexProvider
-
- createIndexStore(boolean) - Method in class com.hazelcast.query.impl.IndexImpl
-
- createInput(Data, InternalSerializationService) - Method in interface com.hazelcast.internal.serialization.InputOutputFactory
-
- createInput(byte[], InternalSerializationService) - Method in interface com.hazelcast.internal.serialization.InputOutputFactory
-
- createInputOutputFactory() - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-
- createInstanceName(Config) - Static method in class com.hazelcast.instance.HazelcastInstanceFactory
-
- createInt2ObjectHashMap(int) - Static method in class com.hazelcast.util.MapUtil
-
Utility method that creates an
Int2ObjectHashMap
with its initialCapacity calculated
to minimize rehash operations
- createInternalMemberGroups(Collection<? extends Member>) - Method in class com.hazelcast.partition.membergroup.ConfigMemberGroupFactory
-
- createInternalMemberGroups(Collection<? extends Member>) - Method in class com.hazelcast.partition.membergroup.HostAwareMemberGroupFactory
-
- createInternalMemberGroups(Collection<? extends Member>) - Method in class com.hazelcast.partition.membergroup.SPIAwareMemberGroupFactory
-
- createInternalMemberGroups(Collection<? extends Member>) - Method in class com.hazelcast.partition.membergroup.ZoneAwareMemberGroupFactory
-
- createInvocationBuilder() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.AbstractExecutorServiceCancelMessageTask
-
- createInvocationBuilder() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnAddressMessageTask
-
- createInvocationBuilder() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnPartitionMessageTask
-
- createInvocationBuilder(Operation) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
-
- createInvocationBuilder(Operation) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorMemberOwnedContainer
-
- createInvocationBuilder(String, Operation, int) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-
- createInvocationBuilder(String, Operation, Address) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-
- createInvocationBuilder(String, Operation, int) - Method in interface com.hazelcast.spi.OperationService
-
- createInvocationBuilder(String, Operation, Address) - Method in interface com.hazelcast.spi.OperationService
-
- createItemIdArray() - Method in class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
-
Creates an array of IDs for all operations in this transaction log.
- createJobProcessInformation(JobTaskConfiguration, JobSupervisor) - Static method in class com.hazelcast.mapreduce.impl.MapReduceUtil
-
- createJobSupervisor(JobTaskConfiguration) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- createJoiner(Node) - Method in class com.hazelcast.instance.DefaultNodeContext
-
- createJoiner(Node) - Method in interface com.hazelcast.instance.NodeContext
-
- createJoinRequest(boolean) - Method in class com.hazelcast.instance.Node
-
- createKeyIteratorOperation(int, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createKeyIteratorOperation(int, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createLazyEntryView(Data, Data, CacheRecord) - Static method in class com.hazelcast.cache.impl.CacheEntryViews
-
- createLazyEntryView(K, V, Record, SerializationService, MapMergePolicy) - Static method in class com.hazelcast.map.impl.EntryViews
-
- createLegacyMergeOperation(String, EntryView<Data, Data>, MapMergePolicy, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createLegacyMergeOperation(String, EntryView<Data, Data>, MapMergePolicy, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createLegacyMergeOperation(String, EntryView<Data, Data>, MapMergePolicy, boolean) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-
- createLinkedHashMap(int) - Static method in class com.hazelcast.util.MapUtil
-
Utility method that creates an
LinkedHashMap
with its initialCapacity calculated
to minimize rehash operations
- createLinkedHashSet(int) - Static method in class com.hazelcast.util.SetUtil
-
Utility method that creates an
LinkedHashSet
with its initialCapacity calculated
to minimize rehash operations
- createListenerAdapter(Object) - Static method in class com.hazelcast.map.impl.ListenerAdapters
-
- createListenerAdapters(EntryListener) - Static method in class com.hazelcast.map.impl.EntryListenerAdaptors
-
- createListenerAdapters(MapListener) - Static method in class com.hazelcast.map.impl.MapListenerAdaptors
-
- createLoadAllOperation(String, List<Data>, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createLoadAllOperation(String, List<Data>, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
Creates an operation to load entry values for the provided keys
on
the partition owner.
- createLoadAllOperationFactory(Set<Data>, boolean) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createLoadAllOperationFactory(Set<Data>, boolean) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createLoadAllOperationFactory(String, List<Data>, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createLoadAllOperationFactory(String, List<Data>, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createLoadMapOperation(String, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createLoadMapOperation(String, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createLocalMapStats(String) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
-
- createLocalQueueStats(String, int) - Method in class com.hazelcast.collection.impl.queue.QueueService
-
Returns the local queue statistics for the given name and
partition ID.
- createLocalQueueStats(String) - Method in class com.hazelcast.collection.impl.queue.QueueService
-
Returns the local queue statistics for the queue with the given name
.
- createLockStore(int, ObjectNamespace) - Method in interface com.hazelcast.concurrent.lock.LockService
-
- createLockStore(int, ObjectNamespace) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- createLogger(String) - Method in class com.hazelcast.logging.Log4j2Factory
-
- createLogger(String) - Method in class com.hazelcast.logging.Log4jFactory
-
- createLogger(String) - Method in class com.hazelcast.logging.LoggerFactorySupport
-
- createLogger(String) - Method in class com.hazelcast.logging.Slf4jFactory
-
- createLogger(String) - Method in class com.hazelcast.logging.StandardLoggerFactory
-
- createMapFlushOperation(String) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createMapFlushOperation(String) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createMapFlushOperationFactory(String) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createMapFlushOperationFactory(String) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createMapService() - Method in interface com.hazelcast.map.impl.MapServiceFactory
-
- createMapSizeEstimator(InMemoryFormat) - Static method in class com.hazelcast.map.impl.OwnedEntryCostEstimatorFactory
-
- createMapSizeOperationFactory(String) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createMapSizeOperationFactory(String) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createMapStoreContext(MapContainer) - Static method in class com.hazelcast.map.impl.mapstore.MapStoreContextFactory
-
- createMemberGroups(Collection<? extends Member>) - Method in interface com.hazelcast.partition.membergroup.MemberGroupFactory
-
- createMemberGroups(Collection<? extends Member>) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroupFactory
-
- createMemberLoginContext(Credentials) - Method in interface com.hazelcast.security.SecurityContext
-
- createMemberUuid(Address) - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- createMemberUuid(Address) - Method in interface com.hazelcast.instance.NodeExtension
-
Creates a UUID for local member
- createMemberUuid(Address) - Static method in class com.hazelcast.util.UuidUtil
-
Creates a new member
UUID
string,
based on a cryptographically weak pseudo random number generator.
- createMergeOperation(String, List<SplitBrainMergeTypes.CacheMergeTypes>, SplitBrainMergePolicy<Data, SplitBrainMergeTypes.CacheMergeTypes>) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createMergeOperation(String, List<SplitBrainMergeTypes.CacheMergeTypes>, SplitBrainMergePolicy<Data, SplitBrainMergeTypes.CacheMergeTypes>) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createMergeOperation(String, SplitBrainMergeTypes.MapMergeTypes, SplitBrainMergePolicy<Data, SplitBrainMergeTypes.MapMergeTypes>, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createMergeOperation(String, SplitBrainMergeTypes.MapMergeTypes, SplitBrainMergePolicy<Data, SplitBrainMergeTypes.MapMergeTypes>, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createMergeOperation(String, SplitBrainMergeTypes.MapMergeTypes, SplitBrainMergePolicy<Data, SplitBrainMergeTypes.MapMergeTypes>, boolean) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-
- createMergeOperationFactory(String, int[], List<SplitBrainMergeTypes.CacheMergeTypes>[], SplitBrainMergePolicy<Data, SplitBrainMergeTypes.CacheMergeTypes>) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createMergeOperationFactory(String, int[], List<SplitBrainMergeTypes.CacheMergeTypes>[], SplitBrainMergePolicy<Data, SplitBrainMergeTypes.CacheMergeTypes>) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createMergeOperationFactory(String, int[], List<SplitBrainMergeTypes.MapMergeTypes>[], SplitBrainMergePolicy<Data, SplitBrainMergeTypes.MapMergeTypes>) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createMergeOperationFactory(String, int[], List<SplitBrainMergeTypes.MapMergeTypes>[], SplitBrainMergePolicy<Data, SplitBrainMergeTypes.MapMergeTypes>) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createMergeOperationFactory(String, SplitBrainMergePolicy<V, MergingItem>, int[], List<MergingItem>[]) - Method in class com.hazelcast.spi.impl.merge.AbstractMergeRunnable
-
- createMergingEntry(SerializationService, EntryView<Data, Data>) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
-
- createMergingEntry(SerializationService, Record) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
-
- createMergingEntry(SerializationService, Data, Data, Record) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
-
- createMergingEntry(SerializationService, CacheEntryView<Data, Data>) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
-
- createMergingEntry(SerializationService, Data, Data, R) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
-
- createMergingEntry(SerializationService, ReplicatedRecord) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
-
- createMergingEntry(SerializationService, MultiMapMergeContainer) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
-
- createMergingEntry(SerializationService, MultiMapContainer, Data, Collection<MultiMapRecord>, long) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
-
- createMergingEntry(SerializationService, String, HyperLogLog) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
-
- createMergingEntry(SerializationService, ScheduledTaskDescriptor) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
-
- createMergingValue(SerializationService, Collection<CollectionItem>) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
-
- createMergingValue(SerializationService, Queue<QueueItem>) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
-
- createMergingValue(SerializationService, Long) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
-
- createMergingValue(SerializationService, Data) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
-
- createMergingValue(SerializationService, Ringbuffer<Object>) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
-
- createMulticastInputProcessor(IOService) - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- createMulticastInputProcessor(IOService) - Method in interface com.hazelcast.instance.NodeExtension
-
Returns a byte array processor for incoming data on the Multicast joiner
- createMulticastOutputProcessor(IOService) - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- createMulticastOutputProcessor(IOService) - Method in interface com.hazelcast.instance.NodeExtension
-
Returns a byte array processor for outgoing data on the Multicast joiner
- createMulticastService(Address, Node, Config, ILogger) - Static method in class com.hazelcast.internal.cluster.impl.MulticastService
-
- createMultipleEntryOperationFactory(String, Set<Data>, EntryProcessor) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createMultipleEntryOperationFactory(String, Set<Data>, EntryProcessor) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createMultipleEntryOperationFactory(String, Set<Data>, EntryProcessor) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-
- createNearCache(String, NearCacheConfig) - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
-
- createNearCacheEvictionChecker(EvictionConfig, NearCacheConfig) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
-
- createNearCacheEvictionChecker(EvictionConfig, NearCacheConfig) - Method in class com.hazelcast.internal.nearcache.impl.store.BaseHeapNearCacheRecordStore
-
- createNearCacheManager() - Method in interface com.hazelcast.client.ClientExtension
-
- createNearCacheManager() - Method in class com.hazelcast.client.impl.DefaultClientExtension
-
- createNearCacheRecordMap(NearCacheConfig) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
-
- createNearCacheRecordMap(NearCacheConfig) - Method in class com.hazelcast.internal.nearcache.impl.store.BaseHeapNearCacheRecordStore
-
- createNearCacheRecordStore(String, NearCacheConfig) - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
-
- createNew(String) - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-
- createNew(int, Collection<MemberImpl>) - Static method in class com.hazelcast.internal.cluster.impl.MembersView
-
Creates a new MemberMap
including given members.
- createNew(String) - Method in class com.hazelcast.map.impl.querycache.subscriber.AbstractQueryCacheEndToEndConstructor
-
Here order of method calls should not change.
- createNew(K) - Method in interface com.hazelcast.util.ConstructorFunction
-
Creates a new instance of an object given the construction argument
- createNew(K, Version) - Method in interface com.hazelcast.util.VersionAwareConstructorFunction
-
Creates a new instance of an object given the construction argument and the version of the object
- createNewRecordStore(String, int) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- createNewRecordStore(String, int) - Method in class com.hazelcast.cache.impl.CacheService
-
- createNode(Config, NodeContext) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- createNodeExtension(Node) - Method in class com.hazelcast.instance.DefaultNodeContext
-
- createNodeExtension(Node) - Method in interface com.hazelcast.instance.NodeContext
-
- createNodeState(MemberStateImpl) - Method in class com.hazelcast.internal.management.TimedMemberStateFactory
-
- createNullEntryView(K) - Static method in class com.hazelcast.map.impl.EntryViews
-
Creates a null entry view that has only key and no value.
- createObjectDataInput(byte[]) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-
- createObjectDataInput(Data) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-
- createObjectDataInput(byte[]) - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
-
- createObjectDataInput(Data) - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
-
- createObjectDataInputStream(InputStream, InternalSerializationService) - Static method in class com.hazelcast.internal.serialization.impl.SerializationUtil
-
- createObjectDataOutput(int) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-
- createObjectDataOutput() - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-
- createObjectDataOutput(int) - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
-
- createObjectDataOutput() - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
-
- createObjectDataOutputStream(OutputStream, InternalSerializationService) - Static method in class com.hazelcast.internal.serialization.impl.SerializationUtil
-
- createObjectName(String, String) - Method in class com.hazelcast.internal.jmx.ManagementService
-
- createOperation() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
-
- createOperation() - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperationFactory
-
- createOperation() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperationFactory
-
- createOperation() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperationFactory
-
- createOperation() - Method in class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
-
- createOperation() - Method in class com.hazelcast.client.impl.operations.OperationFactoryWrapper
-
- createOperation() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsOperationFactory
-
- createOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.AddIndexOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.ClearOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.ContainsValueOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.EvictAllOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.IsEmptyOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.IsPartitionLoadedOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.KeyLoadStatusOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.MapFlushOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.MapGetAllOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.MapLoadAllOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.SizeOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.MadePublishableOperationFactory
-
- createOperation() - Method in class com.hazelcast.mapreduce.impl.operation.GetResultOperationFactory
-
- createOperation() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperationFactory
-
- createOperation() - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperationFactory
-
- createOperation() - Method in class com.hazelcast.replicatedmap.impl.operation.PutAllOperationFactory
-
- createOperation() - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnPartitionOperationFactory
-
- createOperation() - Method in class com.hazelcast.spi.impl.BinaryOperationFactory
-
- createOperation() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionAwareOperationFactory
-
- createOperation() - Method in interface com.hazelcast.spi.OperationFactory
-
Creates the operation.
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.AbstractAllPartitionsMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMultiPartitionMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheClearMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAllMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheLoadAllMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllKeysMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheSizeMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddIndexMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsValueMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictAllMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnAllKeysMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeysMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsEmptyMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadGivenKeysMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapMadePublishableMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveAllMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSizeMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapClearMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsValueMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapEntrySetMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapKeySetMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapSizeMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValuesMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapClearMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutAllMessageTask
-
- createOperationProvider(String, InMemoryFormat) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- createOperationProvider(String, InMemoryFormat) - Method in class com.hazelcast.cache.impl.CacheService
-
- createOperationSupplier() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMultiTargetMessageTask
-
- createOperationSupplier() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
-
- createOperationSupplier() - Method in class com.hazelcast.client.impl.protocol.task.CreateProxiesMessageTask
-
- createOperationSupplier() - Method in class com.hazelcast.client.impl.protocol.task.DeployClassesMessageTask
-
- createOperationSupplier() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddInterceptorMessageTask
-
- createOperationSupplier() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveInterceptorMessageTask
-
- createOperationSupplier() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XACollectTransactionsMessageTask
-
- createOutboundHandler(TcpIpConnection, IOService) - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- createOutboundHandler(TcpIpConnection, IOService) - Method in interface com.hazelcast.instance.NodeExtension
-
Creates a ChannelOutboundHandler for given Connection instance.
- createOutboundHandler(TcpIpConnection) - Method in interface com.hazelcast.nio.IOService
-
- createOutboundHandler(TcpIpConnection) - Method in class com.hazelcast.nio.NodeIOService
-
- createOutput(int, InternalSerializationService) - Method in interface com.hazelcast.internal.serialization.InputOutputFactory
-
- createPartitionOperation(int) - Method in class com.hazelcast.cache.impl.operation.CacheMergeOperationFactory
-
- createPartitionOperation(int) - Method in class com.hazelcast.map.impl.operation.MergeOperationFactory
-
- createPartitionOperation(int) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperationFactory
-
- createPartitionOperation(int) - Method in class com.hazelcast.map.impl.operation.PutAllPartitionAwareOperationFactory
-
- createPartitionOperation(int) - Method in class com.hazelcast.replicatedmap.impl.operation.MergeOperationFactory
-
- createPartitionOperation(int) - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionAwareOperationFactory
-
This method can be called both caller and runner nodes.
- createPartitionRunner(int) - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationRunnerFactory
-
Creates an OperationRunner for a given partition.
- createPartitionState() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
-
- createPartitionState() - Method in interface com.hazelcast.internal.partition.InternalPartitionService
-
Creates the current partition runtime state.
- createPartitionStateInternal() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
-
Returns a copy of the partition table or null
if not initialized.
- createPartitionTableView() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
-
- createPartitionTableView() - Method in interface com.hazelcast.internal.partition.InternalPartitionService
-
- createPartitionWideEntryOperationFactory(String, EntryProcessor) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createPartitionWideEntryOperationFactory(String, EntryProcessor) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createPartitionWideEntryOperationFactory(String, EntryProcessor) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-
- createPartitionWideEntryWithPredicateOperationFactory(String, EntryProcessor, Predicate) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createPartitionWideEntryWithPredicateOperationFactory(String, EntryProcessor, Predicate) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createPartitionWideEntryWithPredicateOperationFactory(String, EntryProcessor, Predicate) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-
- createPortableReader(Data) - Method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1
-
- createPortableReader(Data) - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
-
- CreateProxiesMessageTask - Class in com.hazelcast.client.impl.protocol.task
-
- CreateProxiesMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.CreateProxiesMessageTask
-
- createProxy(T) - Method in interface com.hazelcast.client.HazelcastClientFactory
-
- createProxy(String, boolean, boolean) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyRegistry
-
Creates a DistributedObject proxy if it is not created yet
- CreateProxyMessageTask - Class in com.hazelcast.client.impl.protocol.task
-
- CreateProxyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.CreateProxyMessageTask
-
- createPublisherAccumulator(AccumulatorInfo) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheEndToEndConstructor
-
- createPublisherAccumulator(AccumulatorInfo) - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeQueryCacheEndToEndConstructor
-
- createPublisherAccumulator(AccumulatorInfo) - Method in interface com.hazelcast.map.impl.querycache.subscriber.QueryCacheEndToEndConstructor
-
- createPurgeTxBackupLogOperation() - Method in class com.hazelcast.transaction.impl.AllowedDuringPassiveStateTransactionImpl
-
- createPurgeTxBackupLogOperation() - Method in class com.hazelcast.transaction.impl.TransactionImpl
-
- createPutAllOperation(List<Map.Entry<Data, Data>>, ExpiryPolicy, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createPutAllOperation(List<Map.Entry<Data, Data>>, ExpiryPolicy, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createPutAllOperation(String, MapEntries) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createPutAllOperation(String, MapEntries) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createPutAllOperation(String, MapEntries) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-
- createPutAllOperationFactory(String, int[], MapEntries[]) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createPutAllOperationFactory(String, int[], MapEntries[]) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createPutAllOperationFactory(String, int[], MapEntries[]) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-
- createPutFromLoadAllOperation(String, List<Data>) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createPutFromLoadAllOperation(String, List<Data>) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createPutFromLoadAllOperation(String, List<Data>) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-
- createPutIfAbsentOperation(Data, Data, ExpiryPolicy, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createPutIfAbsentOperation(Data, Data, ExpiryPolicy, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createPutIfAbsentOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createPutIfAbsentOperation(String, Data, Data, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createPutIfAbsentOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-
- createPutOperation(Data, Data, ExpiryPolicy, boolean, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createPutOperation(Data, Data, ExpiryPolicy, boolean, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createPutOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createPutOperation(String, Data, Data, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createPutOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-
- createPutTransientOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createPutTransientOperation(String, Data, Data, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createPutTransientOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-
- createQueryCacheListenerAdaptor(MapListener) - Static method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheEventListenerAdapters
-
- createQueryOperation(Query) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createQueryOperation(Query) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createQueryOperation(Query) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-
- createQueryPartitionOperation(Query) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createQueryPartitionOperation(Query) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createQueryPartitionOperation(Query) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-
- createRecord(Object, long, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- createRecord(long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- createRecord(Object, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- createRecord(Data, Object, long, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- createRecord(Data, Object, long, long, boolean, int, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- createRecord(Object, long, long) - Method in class com.hazelcast.cache.impl.CacheRecordStore
-
- createRecord(Data) - Method in class com.hazelcast.map.impl.querycache.subscriber.record.DataQueryCacheRecordFactory
-
- createRecord(Data) - Method in class com.hazelcast.map.impl.querycache.subscriber.record.ObjectQueryCacheRecordFactory
-
- createRecord(Data) - Method in interface com.hazelcast.map.impl.querycache.subscriber.record.QueryCacheRecordFactory
-
- createRecord(Object, long, long) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
- createRecordCacheMap() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- createRecordCacheMap() - Method in class com.hazelcast.cache.impl.CacheRecordStore
-
- createRecordStore(MapContainer, int, MapKeyLoader) - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- createRecordStoreOnDemand - Variable in class com.hazelcast.map.impl.operation.MapOperation
-
- createRecordWithExpiry(Data, Object, long, long, boolean, int, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- createRecordWithExpiry(Data, Object, long, long, boolean, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- createRecordWithExpiry(Data, Object, ExpiryPolicy, long, boolean, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- createRecordWithExpiry(Data, Object, ExpiryPolicy, long, boolean, int, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- createRecoveryOperation(String, String, long, int) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientSubscriberContextSupport
-
- createRecoveryOperation(String, String, long, int) - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeSubscriberContextSupport
-
- createRecoveryOperation(String, String, long, int) - Method in interface com.hazelcast.map.impl.querycache.subscriber.SubscriberContextSupport
-
Creates recovery operation for event loss cases.
- createRemoteServiceDescriptors() - Method in interface com.hazelcast.spi.impl.servicemanager.RemoteServiceDescriptorProvider
-
- createRemoveAllOperationFactory(Set<Data>, Integer) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createRemoveAllOperationFactory(Set<Data>, Integer) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createRemoveIfSameOperation(String, Data, Data) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createRemoveIfSameOperation(String, Data, Data) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createRemoveIfSameOperation(String, Data, Data) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-
- createRemoveOperation(Data, Data, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createRemoveOperation(Data, Data, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createRemoveOperation(String, Data, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createRemoveOperation(String, Data, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createRemoveOperation(String, Data, boolean) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-
- createReplaceIfSameOperation(String, Data, Data, Data) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createReplaceIfSameOperation(String, Data, Data, Data) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createReplaceIfSameOperation(String, Data, Data, Data) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-
- createReplaceOperation(Data, Data, Data, ExpiryPolicy, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createReplaceOperation(Data, Data, Data, ExpiryPolicy, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createReplaceOperation(String, Data, Data) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createReplaceOperation(String, Data, Data) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createReplaceOperation(String, Data, Data) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-
- createReplicatedMapStats(String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-
- createReplicateTxBackupLogOperation() - Method in class com.hazelcast.transaction.impl.AllowedDuringPassiveStateTransactionImpl
-
- createReplicateTxBackupLogOperation() - Method in class com.hazelcast.transaction.impl.TransactionImpl
-
- createResult(SerializationService, long) - Method in class com.hazelcast.map.impl.query.Query
-
- createResultSet() - Method in class com.hazelcast.cache.impl.journal.CacheEventJournalReadOperation
-
- createResultSet() - Method in class com.hazelcast.internal.journal.EventJournalReadOperation
-
- createResultSet() - Method in class com.hazelcast.map.impl.journal.MapEventJournalReadOperation
-
- createRollbackTxBackupLogOperation() - Method in class com.hazelcast.transaction.impl.AllowedDuringPassiveStateTransactionImpl
-
- createRollbackTxBackupLogOperation() - Method in class com.hazelcast.transaction.impl.TransactionImpl
-
- createSamplingEntry(Data, CacheRecord) - Method in class com.hazelcast.cache.impl.record.CacheRecordHashMap
-
- createSamplingEntry(K, V) - Method in class com.hazelcast.internal.nearcache.impl.store.HeapNearCacheRecordMap
-
- createSamplingEntry(Data, QueryCacheRecord) - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheRecordHashMap
-
- createSamplingEntry(Data, R) - Method in class com.hazelcast.map.impl.recordstore.StorageSCHM
-
- createSamplingEntry(K, V) - Method in class com.hazelcast.util.SampleableConcurrentHashMap
-
- createSecureCallable(Subject, Callable<V>) - Method in interface com.hazelcast.security.SecurityContext
-
Creates secure callable that runs in a sandbox.
- createSerializationService(byte) - Method in interface com.hazelcast.client.ClientExtension
-
- createSerializationService(byte) - Method in class com.hazelcast.client.impl.DefaultClientExtension
-
- createSerializationService() - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- createSerializationService() - Method in interface com.hazelcast.instance.NodeExtension
-
Creates a SerializationService instance to be used by this Node.
- createSerializationService(InputOutputFactory, Supplier<RuntimeException>) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-
- createSerializer() - Method in interface com.hazelcast.nio.serialization.SerializerHook
-
Creates a new serializer for the serialization type
- createService(Class<T>) - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- createService(Class<T>) - Method in interface com.hazelcast.instance.NodeExtension
-
Creates a service which is an implementation of given type parameter.
- createServiceProxyFactory(Class<T>) - Method in interface com.hazelcast.client.ClientExtension
-
Creates a ClientProxyFactory
for the supplied service class.
- createServiceProxyFactory(Class<T>) - Method in class com.hazelcast.client.impl.DefaultClientExtension
-
- createSetOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createSetOperation(String, Data, Data, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createSetOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-
- createSimpleEntryView() - Static method in class com.hazelcast.map.impl.EntryViews
-
- createSimpleEntryView(K, V, Record) - Static method in class com.hazelcast.map.impl.EntryViews
-
- createSizeOperationFactory() - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createSizeOperationFactory() - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createSocketChannelWrapperFactory() - Method in interface com.hazelcast.client.ClientExtension
-
- createSocketChannelWrapperFactory() - Method in class com.hazelcast.client.impl.DefaultClientExtension
-
- createSocketConnection(Address) - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-
- createSocketInterceptor() - Method in interface com.hazelcast.client.ClientExtension
-
Creates a
SocketInterceptor
to be used by this client if available,
otherwise returns
null
- createSocketInterceptor() - Method in class com.hazelcast.client.impl.DefaultClientExtension
-
- createSplitBrainJoinMessage() - Method in class com.hazelcast.instance.Node
-
- createStats(String) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- createStorage(RecordFactory<R>, InMemoryFormat) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
- createStoreEvent(E) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.StoreEvent
-
- createSubResult() - Method in class com.hazelcast.map.impl.query.AggregationResult
-
- createSubResult() - Method in class com.hazelcast.map.impl.query.QueryResult
-
- createSubResult() - Method in interface com.hazelcast.map.impl.query.Result
-
Creates a new empty sub result of the same type as this result.
- createSubscriberAccumulator(AccumulatorInfo) - Method in class com.hazelcast.map.impl.querycache.subscriber.AbstractQueryCacheEndToEndConstructor
-
- createSubscriberAccumulator(AccumulatorInfo) - Method in interface com.hazelcast.map.impl.querycache.subscriber.QueryCacheEndToEndConstructor
-
- createSubscriberAccumulatorFactory() - Method in class com.hazelcast.map.impl.querycache.subscriber.SubscriberRegistry
-
- createSubscriberRegistry(String) - Method in class com.hazelcast.map.impl.querycache.subscriber.MapSubscriberRegistry
-
- createThread(Runnable) - Method in class com.hazelcast.util.executor.AbstractExecutorThreadFactory
-
- createThread(Runnable) - Method in class com.hazelcast.util.executor.PoolExecutorThreadFactory
-
- createThread(Runnable) - Method in class com.hazelcast.util.executor.SingleExecutorThreadFactory
-
- createThreadName(String, String) - Static method in class com.hazelcast.util.ThreadUtil
-
Creates the threadname with prefix and notation.
- createThreadPoolName(String, String) - Static method in class com.hazelcast.util.ThreadUtil
-
Creates the threadpool name with prefix and notation.
- createTimedMemberState() - Method in class com.hazelcast.internal.management.TimedMemberStateFactory
-
- createTimedMemberStateFactory(HazelcastInstanceImpl) - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- createTimedMemberStateFactory(HazelcastInstanceImpl) - Method in interface com.hazelcast.instance.NodeExtension
-
Creates a TimedMemberStateFactory for a given Hazelcast instance
- createTransactionalObject(String, Transaction) - Method in class com.hazelcast.collection.impl.list.ListService
-
- createTransactionalObject(String, Transaction) - Method in class com.hazelcast.collection.impl.queue.QueueService
-
- createTransactionalObject(String, Transaction) - Method in class com.hazelcast.collection.impl.set.SetService
-
- createTransactionalObject(String, Transaction) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
-
- createTransactionalObject(String, Transaction) - Method in class com.hazelcast.map.impl.MapService
-
- createTransactionalObject(String, Transaction) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- createTransactionalObject(String, Transaction) - Method in interface com.hazelcast.spi.TransactionalService
-
- createTryPutOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createTryPutOperation(String, Data, Data, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createTryPutOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-
- createTryRemoveOperation(String, Data, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createTryRemoveOperation(String, Data, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createTryRemoveOperation(String, Data, long) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-
- CreateTxBackupLogOperation - Class in com.hazelcast.transaction.impl.operations
-
- CreateTxBackupLogOperation() - Constructor for class com.hazelcast.transaction.impl.operations.CreateTxBackupLogOperation
-
- CreateTxBackupLogOperation(String, String) - Constructor for class com.hazelcast.transaction.impl.operations.CreateTxBackupLogOperation
-
- createTxnDeleteOperation(String, Data, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createTxnDeleteOperation(String, Data, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createTxnDeleteOperation(String, Data, long) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-
- createTxnLockAndGetOperation(String, Data, long, long, String, boolean, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createTxnLockAndGetOperation(String, Data, long, long, String, boolean, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createTxnSetOperation(String, Data, Data, long, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- createTxnSetOperation(String, Data, Data, long, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-
- createTxnSetOperation(String, Data, Data, long, long) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-
- createUrlEndpoint(HazelcastProperties, String) - Static method in class com.hazelcast.client.spi.impl.discovery.HazelcastCloudDiscovery
-
- createWithoutValue(K) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntries
-
- createWithoutValue(K, long, int) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntries
-
- createWriteBehindManager(MapStoreContext) - Static method in class com.hazelcast.map.impl.mapstore.MapStoreManagers
-
- createWriteBehindProcessor(MapStoreContext) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindProcessors
-
- createWriteBehindStore(MapStoreContext, int, WriteBehindProcessor) - Static method in class com.hazelcast.map.impl.mapstore.MapDataStores
-
Creates a write behind data store.
- createWriteThroughManager(MapStoreContext) - Static method in class com.hazelcast.map.impl.mapstore.MapStoreManagers
-
- createWriteThroughStore(MapStoreContext) - Static method in class com.hazelcast.map.impl.mapstore.MapDataStores
-
Creates a write through data store.
- creationTime - Variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
This field is not mutated (read only) so no need to define it as volatile.
- creationTime - Variable in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-
- creationTime - Variable in class com.hazelcast.collection.impl.collection.CollectionItem
-
- creationTime - Variable in class com.hazelcast.collection.impl.queue.QueueItem
-
- creationTime - Variable in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
-
- creationTime - Variable in class com.hazelcast.map.impl.record.AbstractRecord
-
- creationTime - Variable in class com.hazelcast.map.impl.record.RecordInfo
-
- credentials - Variable in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
-
- Credentials - Interface in com.hazelcast.security
-
Credentials is a container object for endpoint (Members and Clients)
security attributes.
- CredentialsFactoryConfig - Class in com.hazelcast.config
-
Contains the configuration for Credentials Factory.
- CredentialsFactoryConfig() - Constructor for class com.hazelcast.config.CredentialsFactoryConfig
-
- CredentialsFactoryConfig(String) - Constructor for class com.hazelcast.config.CredentialsFactoryConfig
-
- CSHARP - Static variable in class com.hazelcast.client.ClientTypes
-
CSHARP client protocol ID
- CSHARP_CLR_SERIALIZATION_TYPE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-
- CURRENT_CLUSTER_VERSION - Static variable in class com.hazelcast.internal.cluster.Versions
-
- currentFile() - Method in class com.hazelcast.internal.diagnostics.Diagnostics
-
- currentIndex - Variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
-
- currentIndex - Variable in class com.hazelcast.map.impl.iterator.AbstractMapPartitionIterator
-
- currentIndex - Variable in class com.hazelcast.map.impl.iterator.AbstractMapQueryPartitionIterator
-
- currentSequence(String, int) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataGenerator
-
- currentTask - Variable in class com.hazelcast.spi.impl.operationexecutor.OperationRunner
-
- currentTask() - Method in class com.hazelcast.spi.impl.operationexecutor.OperationRunner
-
Returns the current task that is executing.
- currentThread() - Method in class com.hazelcast.spi.impl.operationexecutor.OperationRunner
-
Get the thread that is currently running this OperationRunner instance.
- currentTimeMillis() - Method in class com.hazelcast.util.Clock.ClockImpl
-
- currentTimeMillis() - Static method in class com.hazelcast.util.Clock
-
- cursor() - Method in interface com.hazelcast.internal.util.collection.Long2LongMap
-
- cursor() - Method in class com.hazelcast.internal.util.collection.Long2LongMapHsa
-
- cursor() - Method in interface com.hazelcast.internal.util.collection.LongSet
-
- cursor() - Method in class com.hazelcast.internal.util.collection.LongSetHsa
-
- cursor() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray12byteKey
-
Returns a cursor over all assigned slots in this array.
- cursor() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray16byteKey
-
Returns a cursor over all assigned slots in this array.
- cursor() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray8byteKey
-
Returns a cursor over all assigned slots in this array.
- cursor() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray12byteKeyImpl
-
- cursor() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyImpl
-
- cursor() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray8byteKeyImpl
-
- Cursor() - Constructor for class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase.Cursor
-
- cursor() - Method in class com.hazelcast.util.collection.Long2LongHashMap
-
Provides a cursor over the map's entries.
- CursorIntKey2() - Constructor for class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase.CursorIntKey2
-
- CursorLongKey2() - Constructor for class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase.CursorLongKey2
-
- CUSTOM_ACCESS - Static variable in class com.hazelcast.internal.memory.impl.EndiannessUtil
-
- CustomByteAccessStrategy - Class in com.hazelcast.internal.memory.impl
-
- CyclicBuffer<E extends Sequenced> - Interface in com.hazelcast.map.impl.querycache.accumulator
-
- data - Variable in class com.hazelcast.collection.impl.queue.QueueItem
-
- data - Variable in class com.hazelcast.map.impl.operation.MapReplicationStateHolder
-
- Data - Interface in com.hazelcast.nio.serialization
-
Data is basic unit of serialization.
- data - Variable in class com.hazelcast.topic.impl.TopicEvent
-
- DATA_MEMBER_SELECTOR - Static variable in class com.hazelcast.cluster.memberselector.MemberSelectors
-
A
MemberSelector
instance that selects only data members that own a partition
- DATA_OFFSET - Static variable in class com.hazelcast.internal.serialization.impl.HeapData
-
- DataAwareEntryEvent<K,V> - Class in com.hazelcast.map.impl
-
- DataAwareEntryEvent(Member, int, String, Data, Data, Data, Data, SerializationService) - Constructor for class com.hazelcast.map.impl.DataAwareEntryEvent
-
- DataAwareItemEvent<E> - Class in com.hazelcast.collection.impl.common
-
- DataAwareItemEvent(String, ItemEventType, Data, Member, SerializationService) - Constructor for class com.hazelcast.collection.impl.common.DataAwareItemEvent
-
- DataAwareMessage - Class in com.hazelcast.topic.impl
-
- DataAwareMessage(String, Data, long, Member, SerializationService) - Constructor for class com.hazelcast.topic.impl.DataAwareMessage
-
- dataKey - Variable in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
-
- dataKey - Variable in class com.hazelcast.map.impl.event.EntryEventData
-
- dataKey - Variable in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
-
- dataKey - Variable in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-
- dataKey - Variable in class com.hazelcast.map.impl.operation.ReadonlyKeyBasedMapOperation
-
- dataKey - Variable in class com.hazelcast.multimap.impl.operations.AbstractKeyBasedMultiMapOperation
-
- dataMemberCount - Variable in class com.hazelcast.internal.cluster.impl.JoinMessage
-
- dataMergingValue - Variable in class com.hazelcast.map.impl.event.EntryEventData
-
- dataMergingValue - Variable in class com.hazelcast.map.impl.operation.BasePutOperation
-
- dataNewValue - Variable in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
-
- dataNewValue - Variable in class com.hazelcast.map.impl.event.EntryEventData
-
- dataNewValue - Variable in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
-
- dataOldValue - Variable in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
-
- dataOldValue - Variable in class com.hazelcast.map.impl.event.EntryEventData
-
- dataOldValue - Variable in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
-
- dataOldValue - Variable in class com.hazelcast.map.impl.operation.BasePutOperation
-
- dataOldValue - Variable in class com.hazelcast.map.impl.operation.BaseRemoveOperation
-
- DataQueryCacheRecordFactory - Class in com.hazelcast.map.impl.querycache.subscriber.record
-
Factory for DataQueryCacheRecord
.
- DataQueryCacheRecordFactory(SerializationService) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.record.DataQueryCacheRecordFactory
-
- DataRecordComparator - Class in com.hazelcast.map.impl.record
-
- DataRecordComparator(SerializationService) - Constructor for class com.hazelcast.map.impl.record.DataRecordComparator
-
- DataRecordFactory - Class in com.hazelcast.map.impl.record
-
- DataRecordFactory(MapConfig, SerializationService, PartitioningStrategy) - Constructor for class com.hazelcast.map.impl.record.DataRecordFactory
-
- DataReplicatedRecordStore - Class in com.hazelcast.replicatedmap.impl.record
-
- DataReplicatedRecordStore(String, ReplicatedMapService, int) - Constructor for class com.hazelcast.replicatedmap.impl.record.DataReplicatedRecordStore
-
- DataSerializable - Interface in com.hazelcast.nio.serialization
-
DataSerializable is a serialization method alternative to standard Java
serialization.
- dataSerializableFactories - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-
- DataSerializableFactory - Interface in com.hazelcast.nio.serialization
-
DataSerializableFactory is used to create IdentifiedDataSerializable instances during de-serialization.
- dataSerializerAdapter - Variable in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-
- DataSerializerHook - Interface in com.hazelcast.internal.serialization
-
- dataSize() - Method in class com.hazelcast.internal.serialization.impl.HeapData
-
- dataSize() - Method in interface com.hazelcast.nio.serialization.Data
-
Returns size of internal binary data in bytes
- DataStructureAdapter<K,V> - Interface in com.hazelcast.internal.adapter
-
Abstracts the Hazelcast data structures with Near Cache support for the Near Cache usage.
- DataStructureAdapter.DataStructureMethods - Enum in com.hazelcast.internal.adapter
-
- DataStructureAdapterMethod - Interface in com.hazelcast.internal.adapter
-
- dataToValue(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- dataToValue(Data) - Method in class com.hazelcast.cache.impl.CacheRecordStore
-
- dataToValue(Data) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
-
- DataType - Enum in com.hazelcast.nio.serialization
-
Defines type of the Data: heap or native.
- dataValue - Variable in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-
- DATE_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
-
- DateSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.DateSerializer
-
- deactivate() - Method in interface com.hazelcast.osgi.impl.HazelcastInternalOSGiService
-
Deactivates the service.
- deactivate(Operation) - Static method in class com.hazelcast.spi.OperationAccessor
-
Marks the supplied operation as "not active".
- DeadlineClusterFailureDetector - Class in com.hazelcast.internal.cluster.fd
-
Deadline based failure detector.
- DeadlineClusterFailureDetector(long) - Constructor for class com.hazelcast.internal.cluster.fd.DeadlineClusterFailureDetector
-
- decode(byte[]) - Static method in class com.hazelcast.util.Base64
-
Decodes Base64 data into octects
- decodeAddResponse(ClientMessage) - Method in interface com.hazelcast.client.spi.impl.ListenerMessageCodec
-
- decodeClientMessage(ClientMessage) - Method in interface com.hazelcast.client.impl.ClientMessageDecoder
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.AddMembershipListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionLostListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAddAndGetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAlterAndGetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAlterMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongApplyMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongCompareAndSetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongDecrementAndGetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndAddMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndAlterMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndIncrementMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndSetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongIncrementAndGetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongSetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceAlterAndGetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceAlterMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceApplyMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceClearMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceCompareAndSetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceContainsMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetAndAlterMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetAndSetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceIsNullMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceSetAndGetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceSetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationCustomCredentialsMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddEntryListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddNearCacheInvalidationListenerTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddPartitionLostListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheClearMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheContainsKeyMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheCreateConfigMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheDestroyMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEntryProcessorMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEventJournalReadTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEventJournalSubscribeTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheFetchNearCacheInvalidationMetadataTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndRemoveMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndReplaceMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetConfigMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheIterateEntriesMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheIterateMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheListenerRegistrationMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheLoadAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheManagementConfigMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutIfAbsentMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllKeysMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveEntryListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemovePartitionLostListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheReplaceMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheSizeMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.Pre38CacheAddInvalidationListenerTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorAddMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorEstimateMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ClientStatisticsMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionAwaitMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionBeforeAwaitMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionSignalAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionSignalMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchAwaitMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchCountDownMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchGetCountMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchTrySetCountMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterAddMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetConfiguredReplicaCountMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.CreateProxiesMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.CreateProxyMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.DeployClassesMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.DestroyProxyMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddCacheConfigMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddCardinalityEstimatorConfigMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddDurableExecutorConfigMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddEventJournalConfigMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddExecutorConfigMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddFlakeIdGeneratorConfigMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddListConfigMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddLockConfigMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddMapConfigMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddMultiMapConfigMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddQueueConfigMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddReliableTopicConfigMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddReplicatedMapConfigMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddRingbufferConfigMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddScheduledExecutorConfigMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddSemaphoreConfigMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddSetConfigMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddTopicConfigMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorDisposeResultMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorIsShutdownMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveAndDisposeResultMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveResultMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorShutdownMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorSubmitToPartitionMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnAddressMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnPartitionMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceIsShutdownMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceShutdownMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToAddressMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToPartitionMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.GetDistributedObjectsMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.GetPartitionsMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddAllWithIndexMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddWithIndexMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListClearMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRemoveAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRetainAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListContainsAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListContainsMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListGetAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListGetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListIndexOfMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListIsEmptyMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListIteratorMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListLastIndexOfMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListListIteratorMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveWithIndexMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListSetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListSizeMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListSubMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.lock.LockForceUnlockMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.lock.LockGetLockCountMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.lock.LockGetRemainingLeaseTimeMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.lock.LockIsLockedByCurrentThreadMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.lock.LockIsLockedMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.lock.LockLockMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.lock.LockTryLockMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.lock.LockUnlockMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyWithPredicateMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerWithPredicateMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddIndexMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddInterceptorMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddNearCacheInvalidationListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddPartitionLostListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAggregateMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAggregateWithPredicateMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearNearCacheMessageTask
-
Deprecated.
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsKeyMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsValueMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapDeleteMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapDestroyCacheMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPagingPredicateMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPredicateMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntrySetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEventJournalReadTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEventJournalSubscribeTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnAllKeysMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeyMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeysMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteWithPredicateMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchEntriesMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchKeysMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchNearCacheInvalidationMetadataTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchWithQueryMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapFlushMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapForceUnlockMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetEntryViewMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsEmptyMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsLockedMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPagingPredicateMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPredicateMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadGivenKeysMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapLockMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapMadePublishableMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapProjectionMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapProjectionWithPredicateMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateWithValueMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutIfAbsentMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutTransientMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveEntryListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveIfSameMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveInterceptorMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemovePartitionLostListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapReplaceIfSameMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapReplaceMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetReadCursorMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapSizeMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapSubmitToKeyMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryLockMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryPutMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryRemoveMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapUnlockMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPagingPredicateMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPredicateMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.Pre38MapAddNearCacheEntryListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceCancelMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForCustomMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForListMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMapMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMultiMapMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForSetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceJobProcessInformationMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerToKeyMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapClearMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsEntryMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsKeyMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsValueMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapDeleteMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapEntrySetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapForceUnlockMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapGetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapIsLockedMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapKeySetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapLockMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapPutMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapSizeMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapTryLockMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapUnlockMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValueCountMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValuesMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.NoSuchMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.PingMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueClearMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRemoveAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRetainAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMaxSizeMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIsEmptyMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIteratorMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueOfferMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePeekMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePollMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePutMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemainingCapacityMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueSizeMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueTakeMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistributedObjectListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.RemovePartitionLostListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerWithPredicateMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddNearCacheListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapClearMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsKeyMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsValueMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapEntrySetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapGetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapIsEmptyMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapKeySetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveEntryListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapSizeMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapValuesMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferCapacityMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferHeadSequenceMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadManyMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadOneMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferRemainingCapacityMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferSizeMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferTailSequenceMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorGetAllScheduledMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorShutdownMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToAddressMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToPartitionMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromAddressMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromPartitionMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromAddressMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromPartitionMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromAddressMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromPartitionMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromAddressMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromPartitionMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromAddressMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromPartitionMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromAddressMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromPartitionMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromAddressMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromPartitionMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreAcquireMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreAvailablePermitsMessageTasks
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreDrainPermitsMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreIncreasePermitsMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreInitMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreReducePermitsMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreReleaseMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreTryAcquireMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetClearMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRemoveAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRetainAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetContainsAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetContainsMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetGetAllMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetIsEmptyMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetSizeMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicAddMessageListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicPublishMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicRemoveMessageListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCommitMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCreateMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionRollbackMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAClearRemoteTransactionMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XACollectTransactionsMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAFinalizeTransactionMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCommitMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCreateMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionPrepareMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionRollbackMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListAddMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListRemoveMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListSizeMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapContainsKeyMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapDeleteMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetForUpdateMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapIsEmptyMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetWithPredicateMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutIfAbsentMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveIfSameMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceIfSameMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSizeMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesWithPredicateMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapGetMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapPutMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveEntryMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapSizeMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapValueCountMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueOfferMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePeekMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePollMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueSizeMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueTakeMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetAddMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetRemoveMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetSizeMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.flakeidgen.impl.client.NewIdBatchMessageTask
-
- decodeRemoveResponse(ClientMessage) - Method in interface com.hazelcast.client.spi.impl.ListenerMessageCodec
-
- decompress(byte[]) - Static method in class com.hazelcast.nio.IOUtil
-
- decorateTask(Runnable, RunnableScheduledFuture<V>) - Method in class com.hazelcast.util.executor.LoggingScheduledExecutor
-
- decorateTask(Callable<V>, RunnableScheduledFuture<V>) - Method in class com.hazelcast.util.executor.LoggingScheduledExecutor
-
- decreaseCacheEntryListenerCount() - Method in class com.hazelcast.cache.impl.CacheContext
-
- decreaseEntryCount() - Method in class com.hazelcast.cache.impl.CacheContext
-
- decreaseEntryCount(long) - Method in class com.hazelcast.cache.impl.CacheContext
-
- decreaseHits(long) - Method in class com.hazelcast.monitor.impl.LocalRecordStoreStatsImpl
-
- decreaseHits(long) - Method in interface com.hazelcast.monitor.LocalRecordStoreStats
-
Decreases the number of hits of the locally owned entries of this partition.
- decreaseInvalidationListenerCount() - Method in class com.hazelcast.cache.impl.CacheContext
-
- decreaseInvalidationListenerCount() - Method in class com.hazelcast.map.impl.MapContainer
-
- decrementAndGet() - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-
- decrementAndGet() - Method in class com.hazelcast.client.proxy.ClientPNCounterProxy
-
- decrementAndGet() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- decrementAndGet() - Method in interface com.hazelcast.core.IAtomicLong
-
Atomically decrements the current value by one.
- decrementAndGet() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
-
Decrements by one the current value.
- decrementAndGet() - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
-
- decrementAndGet() - Method in class com.hazelcast.internal.jmx.AtomicLongMBean
-
- decrementAndGetAsync() - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-
- decrementAndGetAsync() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- decrementAndGetAsync() - Method in interface com.hazelcast.core.IAtomicLong
-
Atomically decrements the current value by one.
- decrementOwnedEntryCount() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-
- decrementOwnedEntryMemoryCost(long) - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-
- decrementPendingPacketCount() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-
- decrypt(String) - Method in class com.hazelcast.config.replacer.AbstractPbeReplacer
-
Decrypts given encrypted variable.
- DEFAULT_ASNYC_FILLUP - Static variable in class com.hazelcast.config.ReplicatedMapConfig
-
Default value of asynchronous fill up
- DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.CardinalityEstimatorConfig
-
The number of async backups per estimator
- DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.CollectionConfig
-
The default number of asynchronous backups
- DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.MultiMapConfig
-
The default number of asynchronous backups for this MultiMap.
- DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.QueueConfig
-
Default value of the asynchronous backup count.
- DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.RingbufferConfig
-
Default value of asynchronous backup count
- DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.SemaphoreConfig
-
Default asynchronous backup count.
- DEFAULT_BACKUP_COUNT - Static variable in class com.hazelcast.config.CacheSimpleConfig
-
The default number of backups.
- DEFAULT_BACKUP_COUNT - Static variable in class com.hazelcast.config.MapConfig
-
The number of default backup counter
- DEFAULT_BATCH_SIZE - Static variable in class com.hazelcast.config.MergePolicyConfig
-
Default batch size.
- DEFAULT_BATCH_SIZE - Static variable in class com.hazelcast.config.QueryCacheConfig
-
By default, after reaching this minimum size, node immediately sends buffered events to QueryCache
.
- DEFAULT_BUFFER_SIZE - Static variable in class com.hazelcast.config.QueryCacheConfig
-
By default, only buffer last DEFAULT_BUFFER_SIZE
events fired from a partition.
- DEFAULT_BUFFER_SIZE_BYTE - Static variable in class com.hazelcast.client.config.SocketOptions
-
default buffer size of Bytes
- DEFAULT_CACHE_ENTRY_VIEW - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- DEFAULT_CACHE_MERGE_POLICY - Static variable in class com.hazelcast.config.CacheSimpleConfig
-
Default policy for merging
- DEFAULT_CACHED_DESERIALIZED_VALUES - Static variable in class com.hazelcast.config.MapConfig
-
We want to cache values only when an index is defined.
- DEFAULT_CALL_TIMEOUT - Static variable in class com.hazelcast.spi.InvocationBuilder
-
Default call timeout.
- DEFAULT_CAPACITY - Static variable in class com.hazelcast.config.EventJournalConfig
-
Default value of capacity of the event journal.
- DEFAULT_CAPACITY - Static variable in class com.hazelcast.config.RingbufferConfig
-
Default value of capacity of the RingBuffer.
- DEFAULT_CAPACITY - Static variable in class com.hazelcast.internal.util.hashslot.impl.CapacityUtil
-
Default capacity for a hash container.
- DEFAULT_CHUNK_SIZE - Static variable in class com.hazelcast.config.JobTrackerConfig
-
Default value of chunk size.
- DEFAULT_CIPHER_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
-
- DEFAULT_CLEANUP_PERCENTAGE - Static variable in class com.hazelcast.map.impl.eviction.ExpirationManager
-
- DEFAULT_COALESCE - Static variable in class com.hazelcast.config.QueryCacheConfig
-
Default value of coalesce property.
- DEFAULT_COMMUNICATE_STATS - Static variable in class com.hazelcast.config.JobTrackerConfig
-
Default boolean value of communication statics.define how a map reduce job behaves
- DEFAULT_CONCURRENCY_LEVEL - Static variable in class com.hazelcast.config.ReplicatedMapConfig
-
Default value of concurrency level
- DEFAULT_DATA_LOAD_TIMEOUT - Static variable in class com.hazelcast.config.HotRestartPersistenceConfig
-
Default load timeout
- DEFAULT_DELAY_SECONDS - Static variable in class com.hazelcast.config.QueryCacheConfig
-
Default value of delay seconds which an event wait in the buffer of a node, before sending to QueryCache
.
- DEFAULT_DESERIALIZE_RESULT - Static variable in class com.hazelcast.spi.InvocationBuilder
-
True that the result of an operation automatically should be deserialized to an object.
- DEFAULT_DURABILITY - Static variable in class com.hazelcast.config.DurableExecutorConfig
-
Durability of Executor.
- DEFAULT_EMPTY_QUEUE_TTL - Static variable in class com.hazelcast.config.QueueConfig
-
Default value for the TTL (time to live) for empty Queue.
- DEFAULT_ENABLED - Static variable in class com.hazelcast.config.MulticastConfig
-
Whether the multicast discovery mechanism has been enabled
- DEFAULT_EVICTION_PERCENTAGE - Static variable in class com.hazelcast.config.MapConfig
-
The number of default eviction percentage
- DEFAULT_EVICTION_POLICY - Static variable in class com.hazelcast.config.EvictionConfig
-
Default Eviction Policy.
- DEFAULT_EVICTION_POLICY - Static variable in class com.hazelcast.config.MapConfig
-
Default policy for eviction.
- DEFAULT_EVICTION_POLICY - Static variable in class com.hazelcast.config.NearCacheConfig
-
- DEFAULT_EVICTION_STRATEGY - Static variable in enum com.hazelcast.internal.eviction.EvictionStrategyType
-
- DEFAULT_EXPIRATION_TASK_DELAY_IN_SECONDS - Static variable in interface com.hazelcast.internal.nearcache.NearCache
-
Default expiration task delay time as seconds
- DEFAULT_EXPIRATION_TASK_INITIAL_DELAY_IN_SECONDS - Static variable in interface com.hazelcast.internal.nearcache.NearCache
-
Default expiration task initial delay time as seconds
- DEFAULT_FETCH_SIZE - Static variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
-
- DEFAULT_GLOBAL_ORDERING_ENABLED - Static variable in class com.hazelcast.config.TopicConfig
-
Default global ordering configuration.
- DEFAULT_GROUP_NAME - Static variable in class com.hazelcast.config.GroupConfig
-
Default group name.
- DEFAULT_GROUP_NAME - Static variable in interface com.hazelcast.osgi.impl.HazelcastInternalOSGiService
-
- DEFAULT_GROUP_PASSWORD - Static variable in class com.hazelcast.config.GroupConfig
-
Default group password.
- DEFAULT_HEARTBEAT_INTERVAL_MILLIS - Static variable in class com.hazelcast.config.ProbabilisticQuorumConfigBuilder
-
Default value of heartbeat interval (in milliseconds).
- DEFAULT_HEARTBEAT_PAUSE_MILLIS - Static variable in class com.hazelcast.config.ProbabilisticQuorumConfigBuilder
-
Default duration in milliseconds corresponding to number of potentially lost/delayed heartbeats that will
be accepted before considering it to be an anomaly.
- DEFAULT_HEARTBEAT_TOLERANCE_MILLIS - Static variable in class com.hazelcast.config.RecentlyActiveQuorumConfigBuilder
-
Default duration of time window during which a heartbeat must have been received from a member, for it to be considered
present for quorum (in milliseconds).
- DEFAULT_ID - Static variable in interface com.hazelcast.osgi.impl.HazelcastInternalOSGiService
-
- DEFAULT_IN_MEMORY_FORMAT - Static variable in class com.hazelcast.config.CacheSimpleConfig
-
Default InMemory Format.
- DEFAULT_IN_MEMORY_FORMAT - Static variable in class com.hazelcast.config.MapConfig
-
Default In-Memory format is binary.
- DEFAULT_IN_MEMORY_FORMAT - Static variable in class com.hazelcast.config.QueryCacheConfig
-
By default, hold values of entries in QueryCache
as binary.
- DEFAULT_IN_MEMORY_FORMAT - Static variable in class com.hazelcast.config.ReplicatedMapConfig
-
Default value of In-memory format
- DEFAULT_IN_MEMORY_FORMAT - Static variable in class com.hazelcast.config.RingbufferConfig
-
Default value for the InMemoryFormat.
- DEFAULT_INCLUDE_VALUE - Static variable in class com.hazelcast.config.QueryCacheConfig
-
By default, also cache values of entries besides keys.
- DEFAULT_INITIAL_CAPACITY - Static variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- DEFAULT_INITIAL_CAPACITY - Static variable in class com.hazelcast.util.collection.Int2ObjectHashMap
-
The default initial capacity for constructors not explicitly supplying it.
- DEFAULT_INITIAL_CAPACITY - Static variable in class com.hazelcast.util.collection.Long2LongHashMap
-
The default initial capacity for constructors not explicitly supplying it
- DEFAULT_INITIAL_CAPACITY - Static variable in class com.hazelcast.util.collection.Long2ObjectHashMap
-
The default initial capacity for constructors not explicitly supplying it
- DEFAULT_INTERVAL_MILLISECONDS - Static variable in class com.hazelcast.client.config.ClientIcmpPingConfig
-
- DEFAULT_INVALIDATE_ON_CHANGE - Static variable in class com.hazelcast.config.NearCacheConfig
-
- DEFAULT_LOAD_FACTOR - Static variable in class com.hazelcast.internal.util.hashslot.impl.CapacityUtil
-
Default load factor.
- DEFAULT_LOAD_FACTOR - Static variable in class com.hazelcast.util.collection.Int2ObjectHashMap
-
The default load factor for constructors not explicitly supplying it.
- DEFAULT_LOAD_FACTOR - Static variable in class com.hazelcast.util.collection.Long2LongHashMap
-
The default load factor for constructors not explicitly supplying it
- DEFAULT_LOAD_FACTOR - Static variable in class com.hazelcast.util.collection.Long2ObjectHashMap
-
The default load factor for constructors not explicitly supplying it
- DEFAULT_LOCAL_UPDATE_POLICY - Static variable in class com.hazelcast.config.NearCacheConfig
-
- DEFAULT_LOOPBACK_MODE_ENABLED - Static variable in class com.hazelcast.config.MulticastConfig
-
Default flag that indicates if the loopback mode
is turned on or off.
- DEFAULT_MAP_MERGE_POLICY - Static variable in class com.hazelcast.config.MapConfig
-
Default policy for merging.
- DEFAULT_MAP_NAME - Static variable in class com.hazelcast.internal.ascii.memcache.MemcacheCommandProcessor
-
- DEFAULT_MAX_ATTEMPT - Static variable in class com.hazelcast.client.config.ClientIcmpPingConfig
-
- DEFAULT_MAX_CONCURRENT_REPLICATION_TARGETS - Static variable in class com.hazelcast.config.CRDTReplicationConfig
-
The default maximum number of members to which the CRDT states are
replicated in a single round.
- DEFAULT_MAX_ENTRY_COUNT - Static variable in class com.hazelcast.config.EvictionConfig
-
Default maximum entry count.
- DEFAULT_MAX_ENTRY_COUNT_FOR_ON_HEAP_MAP - Static variable in class com.hazelcast.config.EvictionConfig
-
Default maximum entry count for Map on-heap Near Caches.
- DEFAULT_MAX_IDLE_SECONDS - Static variable in class com.hazelcast.config.MapConfig
-
The number of default time to wait eviction in seconds.
- DEFAULT_MAX_IDLE_SECONDS - Static variable in class com.hazelcast.config.NearCacheConfig
-
Default value of the maximum idle time for eviction in seconds.
- DEFAULT_MAX_SIZE - Static variable in class com.hazelcast.config.CollectionConfig
-
Default maximum size for the Configuration.
- DEFAULT_MAX_SIZE - Static variable in class com.hazelcast.config.MaxSizeConfig
-
Default maximum size of map.
- DEFAULT_MAX_SIZE - Static variable in class com.hazelcast.config.NearCacheConfig
-
- DEFAULT_MAX_SIZE - Static variable in class com.hazelcast.config.QueueConfig
-
Default value for the maximum size of the Queue.
- DEFAULT_MAX_SIZE_POLICY - Static variable in class com.hazelcast.config.EvictionConfig
-
Default Max-Size Policy.
- DEFAULT_MAX_THREAD_SIZE - Static variable in class com.hazelcast.config.JobTrackerConfig
-
Default size of thread.
- DEFAULT_MEMORY_FORMAT - Static variable in class com.hazelcast.config.NearCacheConfig
-
Default value for the in-memory format.
- DEFAULT_MERGE_POLICY - Static variable in class com.hazelcast.config.MergePolicyConfig
-
Default merge policy.
- DEFAULT_MERGE_POLICY - Static variable in class com.hazelcast.config.ReplicatedMapConfig
-
Default policy for merging
- DEFAULT_MERGE_POLICY_CONFIG - Static variable in class com.hazelcast.config.CardinalityEstimatorConfig
-
The default merge policy used for cardinality estimators
- DEFAULT_METADATA_SPACE_PERCENTAGE - Static variable in class com.hazelcast.config.NativeMemoryConfig
-
Default metadata space percentage
- DEFAULT_MIN_BLOCK_SIZE - Static variable in class com.hazelcast.config.NativeMemoryConfig
-
Default minimum block size
- DEFAULT_MIN_EVICTION_CHECK_MILLIS - Static variable in class com.hazelcast.config.MapConfig
-
Minimum time in milliseconds which should pass before asking
if a partition of this map is evictable or not.
- DEFAULT_MIN_STD_DEVIATION - Static variable in class com.hazelcast.config.ProbabilisticQuorumConfigBuilder
-
Default minimum standard deviation (in milliseconds) to use for the normal distribution used when
calculating phi.
- DEFAULT_MULTICAST_GROUP - Static variable in class com.hazelcast.config.MulticastConfig
-
Default group of multicast.
- DEFAULT_MULTICAST_PORT - Static variable in class com.hazelcast.config.MulticastConfig
-
Default value of port.
- DEFAULT_MULTICAST_TIMEOUT_SECONDS - Static variable in class com.hazelcast.config.MulticastConfig
-
Default timeout of multicast in seconds.
- DEFAULT_MULTICAST_TTL - Static variable in class com.hazelcast.config.MulticastConfig
-
Default value of time to live of multicast.
- DEFAULT_PAGE_SIZE - Static variable in class com.hazelcast.config.NativeMemoryConfig
-
Default page size
- DEFAULT_PARALLELISM - Static variable in class com.hazelcast.config.HotRestartPersistenceConfig
-
Default level of parallelism in Hot Restart Persistence.
- DEFAULT_PARTITION_COUNT - Static variable in class com.hazelcast.monitor.impl.MemberPartitionStateImpl
-
- DEFAULT_PHI_THRESHOLD - Static variable in class com.hazelcast.config.ProbabilisticQuorumConfigBuilder
-
Default threshold for suspicion (φ) level.
- DEFAULT_POOL_SIZE - Static variable in class com.hazelcast.config.DurableExecutorConfig
-
The number of executor threads per Member for the Executor based on this configuration.
- DEFAULT_POOL_SIZE - Static variable in class com.hazelcast.config.ExecutorConfig
-
The number of executor threads per Member for the Executor based on this configuration.
- DEFAULT_POPULATE - Static variable in class com.hazelcast.config.QueryCacheConfig
-
By default, execute an initial population query prior to creation of the QueryCache
.
- DEFAULT_PORT - Static variable in class com.hazelcast.config.NetworkConfig
-
Default value of port number.
- DEFAULT_PREFETCH_COUNT - Static variable in class com.hazelcast.config.FlakeIdGeneratorConfig
-
- DEFAULT_PREFETCH_VALIDITY_MILLIS - Static variable in class com.hazelcast.config.FlakeIdGeneratorConfig
-
- DEFAULT_PRIMARY_DRIVES_BACKUP - Static variable in class com.hazelcast.map.impl.eviction.ExpirationManager
-
- DEFAULT_QUEUE_CAPACITY - Static variable in class com.hazelcast.config.ExecutorConfig
-
Capacity of queue.
- DEFAULT_QUEUE_SIZE - Static variable in class com.hazelcast.config.JobTrackerConfig
-
Default value of Queue size.
- DEFAULT_READ_BATCH_SIZE - Static variable in class com.hazelcast.client.config.ClientReliableTopicConfig
-
The default read batch size.
- DEFAULT_READ_BATCH_SIZE - Static variable in class com.hazelcast.config.ReliableTopicConfig
-
The default read batch size.
- DEFAULT_REPLICA_COUNT - Static variable in class com.hazelcast.config.PNCounterConfig
-
The default number of replicas on which state for this CRDT is kept
- DEFAULT_REPLICA_INDEX - Static variable in class com.hazelcast.spi.InvocationBuilder
-
Default replica index.
- DEFAULT_REPLICATION_DELAY_MILLIS - Static variable in class com.hazelcast.config.ReplicatedMapConfig
-
Default value of delay of replication in millisecond
- DEFAULT_REPLICATION_PERIOD_MILLIS - Static variable in class com.hazelcast.config.CRDTReplicationConfig
-
The default period between two CRDT replication rounds.
- DEFAULT_RETRY_COUNT - Static variable in class com.hazelcast.config.JobTrackerConfig
-
Default value of retry counter.
- DEFAULT_RING_BUFFER_CAPACITY - Static variable in class com.hazelcast.config.DurableExecutorConfig
-
Capacity of RingBuffer (per partition).
- DEFAULT_SAMPLE_COUNT - Static variable in interface com.hazelcast.map.impl.eviction.Evictor
-
- DEFAULT_SAMPLE_SIZE - Static variable in class com.hazelcast.config.ProbabilisticQuorumConfigBuilder
-
Default number of samples to use for calculation of mean and standard deviation of inter-arrival times.
- DEFAULT_SECRET_KEY_FACTORY_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
-
- DEFAULT_SERIALIZE_KEYS - Static variable in class com.hazelcast.config.NearCacheConfig
-
Do not serialize by default
- DEFAULT_STATISTICS_ENABLED - Static variable in class com.hazelcast.config.PNCounterConfig
-
Default value for statistics enabled.
- DEFAULT_STATISTICS_ENABLED - Static variable in class com.hazelcast.config.ReliableTopicConfig
-
Default value for statistics enabled.
- DEFAULT_STORE_INITIAL_DELAY_SECONDS - Static variable in class com.hazelcast.config.NearCachePreloaderConfig
-
Default initial delay for the Near Cache key storage.
- DEFAULT_STORE_INTERVAL_SECONDS - Static variable in class com.hazelcast.config.NearCachePreloaderConfig
-
Default interval for the Near Cache key storage (in seconds).
- DEFAULT_SYMMETRIC_PASSWORD - Static variable in class com.hazelcast.config.SymmetricEncryptionConfig
-
Default symmetric encryption password
- DEFAULT_SYMMETRIC_SALT - Static variable in class com.hazelcast.config.SymmetricEncryptionConfig
-
Default symmetric encryption salt
- DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.CardinalityEstimatorConfig
-
The number of sync backups per estimator
- DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.CollectionConfig
-
The default number of synchronous backups
- DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.MultiMapConfig
-
The default number of synchronous backups for this MultiMap.
- DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.QueueConfig
-
Default value for the sychronous backup count.
- DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.RingbufferConfig
-
Default value of synchronous backup count
- DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.SemaphoreConfig
-
Default synchronous backup count.
- DEFAULT_TASK_PERIOD_SECONDS - Static variable in class com.hazelcast.map.impl.eviction.ExpirationManager
-
- DEFAULT_TIMEOUT_MILLIS - Static variable in class com.hazelcast.transaction.TransactionOptions
-
2 minutes as default timeout value
- DEFAULT_TIMEOUT_MILLISECONDS - Static variable in class com.hazelcast.client.config.ClientIcmpPingConfig
-
- DEFAULT_TOPIC_OVERLOAD_POLICY - Static variable in class com.hazelcast.client.config.ClientReliableTopicConfig
-
The default slow consumer policy.
- DEFAULT_TOPIC_OVERLOAD_POLICY - Static variable in class com.hazelcast.config.ReliableTopicConfig
-
The default slow consumer policy.
- DEFAULT_TOPOLOGY_CHANGED_STRATEGY - Static variable in class com.hazelcast.config.JobTrackerConfig
-
Define how a map reduce job behaves.
- DEFAULT_TRY_COUNT - Static variable in class com.hazelcast.spi.InvocationBuilder
-
Default try count.
- DEFAULT_TRY_PAUSE_MILLIS - Static variable in class com.hazelcast.spi.InvocationBuilder
-
Default try pause in milliseconds.
- DEFAULT_TTL - Static variable in class com.hazelcast.client.config.ClientIcmpPingConfig
-
- DEFAULT_TTL - Static variable in interface com.hazelcast.map.impl.recordstore.RecordStore
-
Default TTL value of a record.
- DEFAULT_TTL_SECONDS - Static variable in class com.hazelcast.config.EventJournalConfig
-
Default value for the time to live property.
- DEFAULT_TTL_SECONDS - Static variable in class com.hazelcast.config.MapConfig
-
The number of default Time to Live in seconds.
- DEFAULT_TTL_SECONDS - Static variable in class com.hazelcast.config.NearCacheConfig
-
Default value of the time to live in seconds.
- DEFAULT_TTL_SECONDS - Static variable in class com.hazelcast.config.RingbufferConfig
-
Default value for the time to live property.
- DEFAULT_VALIDATION_TIMEOUT - Static variable in class com.hazelcast.config.HotRestartPersistenceConfig
-
Default validation timeout
- DEFAULT_VALUE_COLLECTION_TYPE - Static variable in class com.hazelcast.config.MultiMapConfig
-
Default value collection type of this MultiMap.
- DEFAULT_WRITE_BATCH_SIZE - Static variable in class com.hazelcast.config.MapStoreConfig
-
Default batch size for writing
- DEFAULT_WRITE_COALESCING - Static variable in class com.hazelcast.config.MapStoreConfig
-
Default write coalescing behavior
- DEFAULT_WRITE_DELAY_SECONDS - Static variable in class com.hazelcast.config.MapStoreConfig
-
Default delay seconds for writing
- DefaultAccumulatorInfoSupplier - Class in com.hazelcast.map.impl.querycache.accumulator
-
- DefaultAccumulatorInfoSupplier() - Constructor for class com.hazelcast.map.impl.querycache.accumulator.DefaultAccumulatorInfoSupplier
-
- DefaultAddressProvider - Class in com.hazelcast.client.spi.impl
-
Default address provider of Hazelcast.
- DefaultAddressProvider(ClientNetworkConfig, boolean) - Constructor for class com.hazelcast.client.spi.impl.DefaultAddressProvider
-
- DefaultAddressTranslator - Class in com.hazelcast.client.spi.impl
-
Default Address Translator is a no-op.
- DefaultAddressTranslator() - Constructor for class com.hazelcast.client.spi.impl.DefaultAddressTranslator
-
- DefaultArgumentParser - Class in com.hazelcast.query.impl
-
ArgumentParser that's used by default.
- DefaultArgumentParser() - Constructor for class com.hazelcast.query.impl.DefaultArgumentParser
-
- DefaultCacheEntryView - Class in com.hazelcast.cache.impl.merge.entry
-
- DefaultCacheEntryView() - Constructor for class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
-
- DefaultCacheEntryView(Data, Data, long, long, long, long) - Constructor for class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
-
- defaultClassLoader - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- DefaultClientConnectionManagerFactory - Class in com.hazelcast.client.impl
-
- DefaultClientConnectionManagerFactory() - Constructor for class com.hazelcast.client.impl.DefaultClientConnectionManagerFactory
-
- DefaultClientConnectionStrategy - Class in com.hazelcast.client.connection.nio
-
Default client connection strategy supporting async client start, reconnection modes and disabling reconnection.
- DefaultClientConnectionStrategy() - Constructor for class com.hazelcast.client.connection.nio.DefaultClientConnectionStrategy
-
- DefaultClientExtension - Class in com.hazelcast.client.impl
-
- DefaultClientExtension() - Constructor for class com.hazelcast.client.impl.DefaultClientExtension
-
- DefaultContext<KeyIn,ValueIn> - Class in com.hazelcast.mapreduce.impl.task
-
This is the internal default implementation of a map reduce context mappers emit values to.
- DefaultContext(CombinerFactory<KeyIn, ValueIn, ?>, MapCombineTask) - Constructor for class com.hazelcast.mapreduce.impl.task.DefaultContext
-
- DefaultCyclicBuffer<E extends Sequenced> - Class in com.hazelcast.map.impl.querycache.accumulator
-
- DefaultCyclicBuffer(int) - Constructor for class com.hazelcast.map.impl.querycache.accumulator.DefaultCyclicBuffer
-
- DefaultDiscoveryService - Class in com.hazelcast.spi.discovery.impl
-
- DefaultDiscoveryService(DiscoveryServiceSettings) - Constructor for class com.hazelcast.spi.discovery.impl.DefaultDiscoveryService
-
- DefaultDiscoveryServiceProvider - Class in com.hazelcast.spi.discovery.impl
-
- DefaultDiscoveryServiceProvider() - Constructor for class com.hazelcast.spi.discovery.impl.DefaultDiscoveryServiceProvider
-
- DefaultEntryEventFilteringStrategy - Class in com.hazelcast.map.impl.event
-
This entry event filtering strategy models the default backwards compatible Hazelcast behaviour.
- DefaultEntryEventFilteringStrategy(SerializationService, MapServiceContext) - Constructor for class com.hazelcast.map.impl.event.DefaultEntryEventFilteringStrategy
-
- defaultExecutor - Variable in class com.hazelcast.spi.impl.AbstractInvocationFuture
-
- defaultExpiryPolicy - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- DefaultGarbageCollectorStats - Class in com.hazelcast.memory
-
Default implementation of GarbageCollectorStats.
- DefaultGarbageCollectorStats() - Constructor for class com.hazelcast.memory.DefaultGarbageCollectorStats
-
- DefaultIndexProvider - Class in com.hazelcast.map.impl.query
-
- DefaultIndexProvider() - Constructor for class com.hazelcast.map.impl.query.DefaultIndexProvider
-
- DefaultMapAggregateMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task.map
-
- DefaultMapAggregateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.DefaultMapAggregateMessageTask
-
- DefaultMapOperationProvider - Class in com.hazelcast.map.impl.operation
-
Creates map operations.
- DefaultMapOperationProvider() - Constructor for class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-
- DefaultMapProjectMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task.map
-
- DefaultMapProjectMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.DefaultMapProjectMessageTask
-
- DefaultMapQueryMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task.map
-
- DefaultMapQueryMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.DefaultMapQueryMessageTask
-
- DefaultMemberGroup - Class in com.hazelcast.partition.membergroup
-
- DefaultMemberGroup() - Constructor for class com.hazelcast.partition.membergroup.DefaultMemberGroup
-
- DefaultMemberGroup(Collection<Member>) - Constructor for class com.hazelcast.partition.membergroup.DefaultMemberGroup
-
- DefaultMemoryStats - Class in com.hazelcast.memory
-
Default implementation of MemoryStats.
- DefaultMemoryStats() - Constructor for class com.hazelcast.memory.DefaultMemoryStats
-
- DefaultMessageTaskFactoryProvider - Class in com.hazelcast.client.impl.protocol
-
DO NOT EDIT THIS FILE.
- DefaultMessageTaskFactoryProvider(NodeEngine) - Constructor for class com.hazelcast.client.impl.protocol.DefaultMessageTaskFactoryProvider
-
- DefaultNearCache<K,V> - Class in com.hazelcast.internal.nearcache.impl
-
- DefaultNearCache(String, NearCacheConfig, SerializationService, TaskScheduler, ClassLoader) - Constructor for class com.hazelcast.internal.nearcache.impl.DefaultNearCache
-
- DefaultNearCache(String, NearCacheConfig, NearCacheRecordStore<K, V>, SerializationService, TaskScheduler, ClassLoader) - Constructor for class com.hazelcast.internal.nearcache.impl.DefaultNearCache
-
- DefaultNearCacheManager - Class in com.hazelcast.internal.nearcache.impl
-
- DefaultNearCacheManager(SerializationService, TaskScheduler, ClassLoader) - Constructor for class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
-
- DefaultNodeContext - Class in com.hazelcast.instance
-
- DefaultNodeContext() - Constructor for class com.hazelcast.instance.DefaultNodeContext
-
- DefaultNodeExtension - Class in com.hazelcast.instance
-
- DefaultNodeExtension(Node) - Constructor for class com.hazelcast.instance.DefaultNodeExtension
-
- DefaultObjectNamespace - Class in com.hazelcast.spi
-
- DefaultObjectNamespace() - Constructor for class com.hazelcast.spi.DefaultObjectNamespace
-
Deprecated.
- DefaultObjectNamespace(String, String) - Constructor for class com.hazelcast.spi.DefaultObjectNamespace
-
Deprecated.
- DefaultObjectNamespace(ObjectNamespace) - Constructor for class com.hazelcast.spi.DefaultObjectNamespace
-
Deprecated.
- DefaultOperationProvider - Class in com.hazelcast.cache.impl
-
- DefaultOperationProvider(String) - Constructor for class com.hazelcast.cache.impl.DefaultOperationProvider
-
- DefaultOperationQueue - Class in com.hazelcast.spi.impl.operationexecutor.impl
-
- DefaultOperationQueue() - Constructor for class com.hazelcast.spi.impl.operationexecutor.impl.DefaultOperationQueue
-
- DefaultOperationQueue(BlockingQueue<Object>, Queue<Object>) - Constructor for class com.hazelcast.spi.impl.operationexecutor.impl.DefaultOperationQueue
-
- DefaultOutOfMemoryHandler - Class in com.hazelcast.instance
-
Default OutOfMemoryHandler implementation that tries to release local resources (threads, connections, memory)
immediately and disconnects members from the rest of the cluster.
- DefaultOutOfMemoryHandler() - Constructor for class com.hazelcast.instance.DefaultOutOfMemoryHandler
-
- DefaultOutOfMemoryHandler(double) - Constructor for class com.hazelcast.instance.DefaultOutOfMemoryHandler
-
- DefaultOutOfMemoryHandler(double, MemoryInfoAccessor) - Constructor for class com.hazelcast.instance.DefaultOutOfMemoryHandler
-
- DefaultPartitioningStrategy - Class in com.hazelcast.partition.strategy
-
- DefaultPartitioningStrategy() - Constructor for class com.hazelcast.partition.strategy.DefaultPartitioningStrategy
-
- DefaultPartitionSequencer - Class in com.hazelcast.map.impl.querycache.event.sequence
-
- DefaultPartitionSequencer() - Constructor for class com.hazelcast.map.impl.querycache.event.sequence.DefaultPartitionSequencer
-
- DefaultPortableReader - Class in com.hazelcast.internal.serialization.impl
-
Can't be accessed concurrently.
- DefaultPortableWriter - Class in com.hazelcast.internal.serialization.impl
-
- defaultProvider - Variable in class com.hazelcast.map.impl.operation.MapOperationProviders
-
- DefaultPublisherContext - Class in com.hazelcast.map.impl.querycache.publisher
-
- DefaultPublisherContext(QueryCacheContext, NodeEngine, IFunction<String, String>) - Constructor for class com.hazelcast.map.impl.querycache.publisher.DefaultPublisherContext
-
- DefaultQueryCacheEventData - Class in com.hazelcast.map.impl.querycache.event
-
- DefaultQueryCacheEventData() - Constructor for class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-
- DefaultQueryCacheEventData(DefaultQueryCacheEventData) - Constructor for class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-
- DefaultRecordStore - Class in com.hazelcast.map.impl.recordstore
-
Default implementation of record-store.
- DefaultRecordStore(MapContainer, int, MapKeyLoader, ILogger) - Constructor for class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- DefaultSerializationServiceBuilder - Class in com.hazelcast.internal.serialization.impl
-
- DefaultSerializationServiceBuilder() - Constructor for class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-
- DefaultSubscriberSequencerProvider - Class in com.hazelcast.map.impl.querycache.event.sequence
-
- DefaultSubscriberSequencerProvider() - Constructor for class com.hazelcast.map.impl.querycache.event.sequence.DefaultSubscriberSequencerProvider
-
- defaultURI - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- DefaultValueCollector - Class in com.hazelcast.query.impl
-
- DefaultValueCollector() - Constructor for class com.hazelcast.query.impl.DefaultValueCollector
-
- DeferredValue<V> - Class in com.hazelcast.cache.impl
-
Thread-safe holder of value and/or its serialized form.
- define(String, byte[]) - Method in class com.hazelcast.internal.usercodedeployment.impl.ClassSource
-
- defineClass(String, byte[]) - Method in class com.hazelcast.internal.usercodedeployment.UserCodeDeploymentService
-
- defineClassFromClient(String, byte[]) - Method in class com.hazelcast.internal.usercodedeployment.impl.ClassLocator
-
- DelayedEntries - Class in com.hazelcast.map.impl.mapstore.writebehind.entry
-
Mainly contains static factory methods to create various
DelayedEntry
instances.
- DelayedEntry<K,V> - Interface in com.hazelcast.map.impl.mapstore.writebehind.entry
-
- DelegateAndSkipOnConcurrentExecutionDecorator - Class in com.hazelcast.spi.impl.executionservice.impl
-
Decorator to delegate task to an executor and prevent concurrent task execution.
- DelegateAndSkipOnConcurrentExecutionDecorator(Runnable, Executor) - Constructor for class com.hazelcast.spi.impl.executionservice.impl.DelegateAndSkipOnConcurrentExecutionDecorator
-
- DelegatingAddressPicker - Class in com.hazelcast.instance
-
Delegates picking the bind and public address for this instance
to an implementation of
MemberAddressProvider
.
- DelegatingAddressPicker(MemberAddressProvider, NetworkConfig, ILogger) - Constructor for class com.hazelcast.instance.DelegatingAddressPicker
-
- DelegatingFuture<V> - Class in com.hazelcast.util.executor
-
A
InternalCompletableFuture
implementation that delegates the real logic to an underlying
InternalCompletableFuture
and decorates it with additional behavior:
change the returned value by setting the result
always deserializing the content
caching the deserialized content so that a deserialization only happens once.
- DelegatingFuture(InternalCompletableFuture, SerializationService) - Constructor for class com.hazelcast.util.executor.DelegatingFuture
-
- DelegatingFuture(InternalCompletableFuture, SerializationService, V) - Constructor for class com.hazelcast.util.executor.DelegatingFuture
-
Creates a DelegatingFuture
- DelegatingScheduledFutureStripper<V> - Class in com.hazelcast.scheduledexecutor.impl
-
Simple adapter that unwraps the Future delegation done in
DelegatingCallableTaskDecorator
for single-run Callable tasks.
- DelegatingScheduledFutureStripper(ScheduledFuture<V>) - Constructor for class com.hazelcast.scheduledexecutor.impl.DelegatingScheduledFutureStripper
-
- DelegatingTaskScheduler - Class in com.hazelcast.spi.impl.executionservice.impl
-
- DelegatingTaskScheduler(ScheduledExecutorService, ExecutorService) - Constructor for class com.hazelcast.spi.impl.executionservice.impl.DelegatingTaskScheduler
-
- delete(Object) - Method in class com.hazelcast.cache.impl.LatencyTrackingCacheWriter
-
- delete(Object) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- delete(Object) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-
- delete(Object) - Method in class com.hazelcast.client.proxy.txn.ClientTxnMapProxy
-
- delete(Long) - Method in class com.hazelcast.collection.impl.queue.LatencyTrackingQueueStore
-
- delete(Long) - Method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
-
- delete(Object) - Method in interface com.hazelcast.core.BaseMap
-
Removes the mapping for a key from this map if it is present.
- delete(Object) - Method in interface com.hazelcast.core.IMap
-
Removes the mapping for the key from this map if it is present.
- delete(K) - Method in interface com.hazelcast.core.MapStore
-
Deletes the entry with a given key from the store.
- delete(K) - Method in class com.hazelcast.core.MapStoreAdapter
-
Deletes the entry with a given key from the store.
- delete(Object) - Method in interface com.hazelcast.core.MultiMap
-
Deletes all the entries with the given key.
- delete(Long) - Method in interface com.hazelcast.core.QueueStore
-
Deletes the entry with a given key from the store.
- delete(Object) - Method in interface com.hazelcast.core.TransactionalMap
-
- delete(K) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
-
- delete(K) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
-
- delete(K) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
-
- delete(K) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
-
- delete(K) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
-
- delete(String, String) - Method in interface com.hazelcast.internal.ascii.TextCommandService
-
- delete(String, String) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-
- delete(K) - Method in class com.hazelcast.map.impl.LatencyTrackingMapStore
-
- DELETE - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- delete(Object) - Method in class com.hazelcast.map.impl.MapStoreWrapper
-
- delete(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- delete(Data) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- delete(Data) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
- delete(Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-
- delete(Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- DELETE - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- delete(Object) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- delete(File) - Static method in class com.hazelcast.nio.IOUtil
-
Ensures that the file described by the supplied parameter does not exist
after the method returns.
- DELETE_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- deleteAll(Collection<?>) - Method in class com.hazelcast.cache.impl.LatencyTrackingCacheWriter
-
- deleteAll(Collection<Long>) - Method in class com.hazelcast.collection.impl.queue.LatencyTrackingQueueStore
-
- deleteAll(Collection<Long>) - Method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
-
- deleteAll(Collection<K>) - Method in interface com.hazelcast.core.MapStore
-
Deletes multiple entries from the store.
- deleteAll(Collection<K>) - Method in class com.hazelcast.core.MapStoreAdapter
-
Deletes multiple entries from the store.
- deleteAll(Collection<Long>) - Method in interface com.hazelcast.core.QueueStore
-
Deletes multiple entries from the store.
- deleteAll(String) - Method in interface com.hazelcast.internal.ascii.TextCommandService
-
- deleteAll(String) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-
- deleteAll(Collection<K>) - Method in class com.hazelcast.map.impl.LatencyTrackingMapStore
-
- deleteAll(Collection) - Method in class com.hazelcast.map.impl.MapStoreWrapper
-
- deleteAllCacheEntry(Set<Data>) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- deleteAsync(K) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
-
- deleteAsync(K) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
-
- deleteAsync(K) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
-
- deleteAsync(K) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
-
- deleteAsync(K) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
-
- DeleteBackupOperation - Class in com.hazelcast.multimap.impl.operations
-
- DeleteBackupOperation() - Constructor for class com.hazelcast.multimap.impl.operations.DeleteBackupOperation
-
- DeleteBackupOperation(String, Data) - Constructor for class com.hazelcast.multimap.impl.operations.DeleteBackupOperation
-
- deleteCache(String, String, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- deleteCache(String, String, boolean) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- deleteCacheConfig(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- deleteCacheConfig(String) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- deleteCacheEntry(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- deleteCacheResources(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- deleteCacheStat(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- deleteCacheStat(String) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- DeleteCommand - Class in com.hazelcast.internal.ascii.memcache
-
- DeleteCommand(String, int, boolean) - Constructor for class com.hazelcast.internal.ascii.memcache.DeleteCommand
-
- DeleteCommandParser - Class in com.hazelcast.internal.ascii.memcache
-
- DeleteCommandParser() - Constructor for class com.hazelcast.internal.ascii.memcache.DeleteCommandParser
-
- DeleteCommandProcessor - Class in com.hazelcast.internal.ascii.memcache
-
- DeleteCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.internal.ascii.memcache.DeleteCommandProcessor
-
- DELETED - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
-
- deleteInternal(Object) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- deleteInternal(Object) - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-
- deleteInternal(Object) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-
- deleteInternal(Object, boolean, EntryEventType) - Method in interface com.hazelcast.map.impl.querycache.subscriber.InternalQueryCache
-
- deleteInternal(Object, boolean, EntryEventType) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
-
- deleteInternal(Data) - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-
- DeleteOperation - Class in com.hazelcast.map.impl.operation
-
- DeleteOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.DeleteOperation
-
- DeleteOperation(String, Data, boolean) - Constructor for class com.hazelcast.map.impl.operation.DeleteOperation
-
- DeleteOperation() - Constructor for class com.hazelcast.map.impl.operation.DeleteOperation
-
- DeleteOperation - Class in com.hazelcast.multimap.impl.operations
-
- DeleteOperation() - Constructor for class com.hazelcast.multimap.impl.operations.DeleteOperation
-
- DeleteOperation(String, Data, long) - Constructor for class com.hazelcast.multimap.impl.operations.DeleteOperation
-
- deleteQuietly(File) - Static method in class com.hazelcast.nio.IOUtil
-
Ensures that the file described by the supplied parameter does not exist
after the method returns.
- deleteRecord(Data, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- deleteRecord(Data, int, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- deleteRecord(Data, int, String, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- deleteRecordStore(String, boolean) - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-
- DenseHyperLogLogEncoder - Class in com.hazelcast.cardinality.impl.hyperloglog.impl
-
1.
- DenseHyperLogLogEncoder() - Constructor for class com.hazelcast.cardinality.impl.hyperloglog.impl.DenseHyperLogLogEncoder
-
- DenseHyperLogLogEncoder(int) - Constructor for class com.hazelcast.cardinality.impl.hyperloglog.impl.DenseHyperLogLogEncoder
-
- DenseHyperLogLogEncoder(int, byte[]) - Constructor for class com.hazelcast.cardinality.impl.hyperloglog.impl.DenseHyperLogLogEncoder
-
- DenyAllPermissionCollection - Class in com.hazelcast.security.permission
-
- DenyAllPermissionCollection() - Constructor for class com.hazelcast.security.permission.DenyAllPermissionCollection
-
- deploy(HazelcastClientInstanceImpl, Connection) - Method in class com.hazelcast.client.spi.impl.ClientUserCodeDeploymentService
-
- DEPLOY_CLASSES_OP - Static variable in class com.hazelcast.internal.usercodedeployment.impl.UserCodeDeploymentSerializerHook
-
- DeployClassesMessageTask - Class in com.hazelcast.client.impl.protocol.task
-
Message task handling user code deployment from client to cluster
- DeployClassesMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.DeployClassesMessageTask
-
- DeployClassesOperation - Class in com.hazelcast.internal.usercodedeployment.impl.operation
-
Operation to distribute class definitions uploaded from client to cluster
- DeployClassesOperation(Collection<Map.Entry<String, byte[]>>) - Constructor for class com.hazelcast.internal.usercodedeployment.impl.operation.DeployClassesOperation
-
- DeployClassesOperation() - Constructor for class com.hazelcast.internal.usercodedeployment.impl.operation.DeployClassesOperation
-
- deregister(S) - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
-
- deregister(S) - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
-
Deregisters all probes for a given source object.
- deregister(String) - Method in class com.hazelcast.map.impl.InterceptorRegistry
-
- deregister(Invocation) - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationRegistry
-
Deregisters an invocation.
- deregisterAllListener(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- deregisterAllListener(String) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- deregisterAllListeners(String, String) - Method in interface com.hazelcast.spi.EventService
-
Deregisters all listeners belonging to the given service and topic.
- deregisterAllListeners(String, String) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-
- deregisterCacheEntryListener(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- deregisterCacheEntryListener(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-
- deregisterClient(HazelcastInstance) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
-
- deregisterHandler(String) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.RepairingTask
-
- deregisterListener(String, String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- deregisterListener(String, String) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.AbstractRemoveListenerMessageTask
-
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveEntryListenerMessageTask
-
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
-
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemovePartitionLostListenerMessageTask
-
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveListenerMessageTask
-
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveEntryListenerMessageTask
-
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemovePartitionLostListenerMessageTask
-
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryListenerMessageTask
-
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveListenerMessageTask
-
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistributedObjectListenerMessageTask
-
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.RemovePartitionLostListenerMessageTask
-
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveEntryListenerMessageTask
-
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveListenerMessageTask
-
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicRemoveMessageListenerMessageTask
-
- deregisterListener(String) - Method in interface com.hazelcast.client.spi.ClientListenerService
-
- deregisterListener(String) - Method in class com.hazelcast.client.spi.ClientProxy
-
- deregisterListener(String) - Method in class com.hazelcast.client.spi.impl.listener.NonSmartClientListenerService
-
- deregisterListener(String) - Method in class com.hazelcast.client.spi.impl.listener.SmartClientListenerService
-
- deregisterListener(String, String, Object) - Method in interface com.hazelcast.spi.EventService
-
Deregisters a listener with the given registration ID.
- deregisterListener(String, String, Object) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-
- deregisterPartitionListener(ClientEndpoint) - Method in class com.hazelcast.client.impl.ClientPartitionListenerService
-
- deregisterRepairingHandler(String) - Method in class com.hazelcast.map.impl.nearcache.MapNearCacheManager
-
- deregisterServer(HazelcastInstance) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
-
- DEREGISTRATION - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
-
- DeregistrationOperation - Class in com.hazelcast.spi.impl.eventservice.impl.operations
-
- DeregistrationOperation() - Constructor for class com.hazelcast.spi.impl.eventservice.impl.operations.DeregistrationOperation
-
- DeregistrationOperation(String, String, int) - Constructor for class com.hazelcast.spi.impl.eventservice.impl.operations.DeregistrationOperation
-
- DeregistrationOperationSupplier - Class in com.hazelcast.spi.impl.eventservice.impl.operations
-
- DeregistrationOperationSupplier(Registration, ClusterService) - Constructor for class com.hazelcast.spi.impl.eventservice.impl.operations.DeregistrationOperationSupplier
-
- descendingKeys() - Method in class com.hazelcast.util.ItemCounter
-
Returns a List of keys in descending value order.
- describeFlags(char) - Method in enum com.hazelcast.nio.Packet.Type
-
- DeserializingEventJournalCacheEvent<K,V> - Class in com.hazelcast.cache.impl.journal
-
- DeserializingEventJournalCacheEvent() - Constructor for class com.hazelcast.cache.impl.journal.DeserializingEventJournalCacheEvent
-
- DeserializingEventJournalCacheEvent(SerializationService, InternalEventJournalCacheEvent) - Constructor for class com.hazelcast.cache.impl.journal.DeserializingEventJournalCacheEvent
-
- DeserializingEventJournalMapEvent<K,V> - Class in com.hazelcast.map.impl.journal
-
- DeserializingEventJournalMapEvent() - Constructor for class com.hazelcast.map.impl.journal.DeserializingEventJournalMapEvent
-
- DeserializingEventJournalMapEvent(SerializationService, InternalEventJournalMapEvent) - Constructor for class com.hazelcast.map.impl.journal.DeserializingEventJournalMapEvent
-
- destroy() - Method in interface com.hazelcast.cache.HazelcastCacheManager
-
Destroys cache manager.
- destroy() - Method in interface com.hazelcast.cache.ICache
-
Closes the cache.
- destroy() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- destroy() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
Destroy all managed caches.
- destroy(String, String) - Method in class com.hazelcast.cache.impl.CacheEventHandler
-
- destroy() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Destroy is equivalent to below operations in the given order:
clear all.
close resources.
unregister all listeners.
- destroy(ObjectNamespace, int) - Method in class com.hazelcast.cache.impl.journal.RingbufferCacheEventJournalImpl
-
- destroy() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- destroy() - Method in class com.hazelcast.client.impl.querycache.ClientQueryCacheContext
-
- destroy() - Method in class com.hazelcast.client.spi.ClientProxy
-
- destroy() - Method in class com.hazelcast.client.spi.ProxyManager
-
- destroy() - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-
- destroy() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-
- destroy() - Method in class com.hazelcast.concurrent.idgen.IdGeneratorImpl
-
- destroy() - Method in interface com.hazelcast.core.DistributedObject
-
Destroys this object cluster-wide.
- destroy() - Method in interface com.hazelcast.core.MapLoaderLifecycleSupport
-
Hazelcast will call this method before shutting down.
- destroy() - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
-
- destroy() - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
-
- destroy() - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
-
- destroy() - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
-
- destroy() - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
-
- destroy() - Method in class com.hazelcast.internal.jmx.ManagementService
-
- destroy(ObjectNamespace, int) - Method in interface com.hazelcast.internal.journal.EventJournal
-
Destroys the event journal for the given object and partition ID.
- destroy() - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
-
- destroy(String, String) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.BatchInvalidator
-
- destroy(String, String) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidator
-
Removes supplied data structures invalidation queues and flushes their content.
- destroy() - Method in class com.hazelcast.internal.nearcache.impl.preloader.NearCachePreloader
-
- destroy() - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
-
- destroy() - Method in class com.hazelcast.internal.nearcache.impl.store.BaseHeapNearCacheRecordStore
-
- destroy() - Method in interface com.hazelcast.internal.nearcache.NearCache
-
Clears the record store and destroys it.
- destroy() - Method in interface com.hazelcast.internal.nearcache.NearCacheRecordStore
-
Clears the record store and destroys it.
- destroy() - Method in class com.hazelcast.internal.serialization.impl.ArrayListStreamSerializer
-
- destroy() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.TheByteArraySerializer
-
- destroy() - Method in class com.hazelcast.internal.serialization.impl.LinkedListStreamSerializer
-
- destroy(ObjectNamespace, int) - Method in class com.hazelcast.map.impl.journal.RingbufferMapEventJournalImpl
-
- destroy() - Method in class com.hazelcast.map.impl.MapStoreWrapper
-
- destroy() - Method in class com.hazelcast.map.impl.querycache.NodeQueryCacheContext
-
- destroy() - Method in interface com.hazelcast.map.impl.querycache.QueryCacheContext
-
Destroys everything in this context.
- destroy() - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
-
- destroy() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- destroy() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
- destroy(boolean) - Method in interface com.hazelcast.map.impl.recordstore.Storage
-
- destroy(boolean) - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
-
- destroy() - Method in interface com.hazelcast.map.QueryCache
-
Destroys this cache.
- destroy() - Method in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-
- destroy() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- destroy() - Method in interface com.hazelcast.nio.serialization.Serializer
-
Called when instance is shutting down.
- destroy() - Method in class com.hazelcast.query.impl.BaseIndexStore
-
- destroy() - Method in interface com.hazelcast.query.impl.Index
-
Releases all resources hold by this index, e.g.
- destroy() - Method in class com.hazelcast.query.impl.IndexImpl
-
- destroy() - Method in interface com.hazelcast.query.impl.IndexStore
-
- destroy(String) - Method in class com.hazelcast.replicatedmap.impl.PartitionContainer
-
- destroy() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-
- destroy() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- destroy() - Method in class com.hazelcast.scheduledexecutor.impl.AbstractScheduledExecutorContainerHolder
-
- destroy() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
-
- destroy() - Method in interface com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainerHolder
-
- destroy() - Method in interface com.hazelcast.security.ICredentialsFactory
-
- destroy() - Method in interface com.hazelcast.security.IPermissionPolicy
-
- DESTROY - Static variable in class com.hazelcast.security.permission.InstancePermission
-
- destroy() - Method in interface com.hazelcast.security.SecurityContext
-
- destroy() - Method in class com.hazelcast.spi.AbstractDistributedObject
-
- destroy() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
-
- destroy() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategy
-
The stop method is used to stop internal services, sockets or to destroy any
kind of internal state.
- destroy() - Method in class com.hazelcast.spi.discovery.impl.DefaultDiscoveryService
-
- destroy() - Method in class com.hazelcast.spi.discovery.impl.PredefinedDiscoveryService
-
- destroy() - Method in interface com.hazelcast.spi.discovery.integration.DiscoveryService
-
The start method is called on system startup to implement simple
lifecycle management.
- destroy() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategy
-
- destroy() - Method in class com.hazelcast.spi.impl.merge.AbstractContainerCollector
-
Destroys all collected containers.
- destroy(C) - Method in class com.hazelcast.spi.impl.merge.AbstractContainerCollector
-
Destroys the owned data in the container.
- DESTROY_CACHE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- DESTROY_QUERY_CACHE - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- destroyAllNearCaches() - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
-
- destroyAllNearCaches() - Method in interface com.hazelcast.internal.nearcache.NearCacheManager
-
- destroyAllQueryCaches(String) - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheEndToEndProvider
-
- destroyBackup(C) - Method in class com.hazelcast.spi.impl.merge.AbstractContainerCollector
-
Destroys the backup data in the container.
- destroyCache(String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- destroyContainer(int, ObjectNamespace) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
-
- destroyContainer(String) - Method in class com.hazelcast.scheduledexecutor.impl.AbstractScheduledExecutorContainerHolder
-
- destroyContainer(String) - Method in interface com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainerHolder
-
- destroyDistributedObject(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.collection.impl.collection.CollectionService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.collection.impl.list.ListService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.collection.impl.queue.QueueService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.collection.impl.set.SetService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.concurrent.idgen.IdGeneratorService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- destroyDistributedObject(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.durableexecutor.impl.DistributedDurableExecutorService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.map.impl.MapService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
-
- destroyDistributedObject(String, String) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-
- destroyDistributedObject(String, String) - Method in interface com.hazelcast.spi.ProxyService
-
- destroyDistributedObject(String) - Method in interface com.hazelcast.spi.RemoteService
-
Destroys a distributed object.
- destroyDistributedObject(String) - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.topic.impl.TopicService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.transaction.impl.xa.XAService
-
- destroyEventJournal() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- destroyIndex(String) - Method in class com.hazelcast.query.impl.Indexes
-
- destroyIndexes() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- destroyIndexes() - Method in class com.hazelcast.query.impl.Indexes
-
- destroyInternals() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- destroyInternals() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
- destroyInternals() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- destroyInternals() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
Like
RecordStore.destroy()
but does not touch state on other services
like lock service or event journal service.
- destroyJobSupervisor(JobSupervisor) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- destroyLocalDistributedObject(String, String, boolean) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-
- destroyLocally() - Method in class com.hazelcast.client.spi.ClientProxy
-
Destroys this client proxy instance locally without issuing distributed
object destroy request to the cluster as the
ClientProxy.destroy()
method
does.
- destroyLocalMapStatsImpl(String) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
-
- destroyMap(String) - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- destroyMap(MapContainer) - Method in class com.hazelcast.map.impl.PartitionContainer
-
- destroyMapStores() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- destroyMetaDataFor(String) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataGenerator
-
- destroyNearCache(String) - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
-
- destroyNearCache(String) - Method in interface com.hazelcast.internal.nearcache.NearCacheManager
-
Destroys
NearCache
instance associated with given
name
and also removes it.
- destroyNearCache(String) - Method in class com.hazelcast.map.impl.nearcache.MapNearCacheManager
-
- destroyProxy(ClientProxy) - Method in class com.hazelcast.client.spi.ProxyManager
-
Destroys the given proxy in a cluster-wide way.
- destroyProxyLocally(String, String) - Method in class com.hazelcast.client.spi.ProxyManager
-
Locally destroys the proxy identified by the given service and object ID.
- DestroyProxyMessageTask - Class in com.hazelcast.client.impl.protocol.task
-
- DestroyProxyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.DestroyProxyMessageTask
-
- DestroyQueryCacheOperation - Class in com.hazelcast.map.impl.querycache.subscriber.operation
-
This operation removes all QueryCache
resources on a node.
- DestroyQueryCacheOperation() - Constructor for class com.hazelcast.map.impl.querycache.subscriber.operation.DestroyQueryCacheOperation
-
- DestroyQueryCacheOperation(String, String) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.operation.DestroyQueryCacheOperation
-
- destroyRemotely() - Method in class com.hazelcast.client.spi.ClientProxy
-
Destroys the remote distributed object counterpart of this proxy by
issuing the destruction request to the cluster.
- destroySegments(CacheConfig) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- destroyStore(Store) - Method in class com.hazelcast.spi.impl.merge.AbstractSplitBrainHandlerService
-
Destroys the given Store
.
- DETACH_MEMBER_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-
- DETACH_MEMBER_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-
- detachAll(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
-
- Diagnostics - Class in com.hazelcast.internal.diagnostics
-
The
Diagnostics
is a debugging tool that provides insight in all kinds of potential performance and stability issues.
- Diagnostics(String, ILogger, String, HazelcastProperties) - Constructor for class com.hazelcast.internal.diagnostics.Diagnostics
-
- DiagnosticsLogWriter - Interface in com.hazelcast.internal.diagnostics
-
- DiagnosticsLogWriterImpl - Class in com.hazelcast.internal.diagnostics
-
- DiagnosticsLogWriterImpl() - Constructor for class com.hazelcast.internal.diagnostics.DiagnosticsLogWriterImpl
-
- DiagnosticsLogWriterImpl(boolean) - Constructor for class com.hazelcast.internal.diagnostics.DiagnosticsLogWriterImpl
-
- DiagnosticsPlugin - Class in com.hazelcast.internal.diagnostics
-
- DiagnosticsPlugin(ILogger) - Constructor for class com.hazelcast.internal.diagnostics.DiagnosticsPlugin
-
- difference(IntHashSet) - Method in class com.hazelcast.util.collection.IntHashSet
-
Fast Path set difference for comparison with another IntHashSet.
- difference(LongHashSet) - Method in class com.hazelcast.util.collection.LongHashSet
-
Fast Path set difference for comparison with another LongHashSet.
- DIFFERENCE_BETWEEN_TWO_SUBSEQUENT_PARTITION_CLEANUP_MILLIS - Static variable in class com.hazelcast.map.impl.eviction.ExpirationManager
-
- DIRECTORY - Static variable in class com.hazelcast.internal.diagnostics.Diagnostics
-
Configures the output directory of the performance log files.
- DISABLE_STALE_READ_ON_PARTITION_MIGRATION - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
- disablePerEntryInvalidationEvents - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- disableWanReplicationEvent - Variable in class com.hazelcast.map.impl.operation.BaseRemoveOperation
-
Used by wan-replication-service to disable wan-replication event publishing
otherwise in active-active scenarios infinite loop of event forwarding can be seen.
- disableWanReplicationEvent - Variable in class com.hazelcast.map.impl.operation.EvictBackupOperation
-
- disableWanReplicationEvent - Variable in class com.hazelcast.map.impl.operation.RemoveBackupOperation
-
- DISCARD - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
-
- DiscardableMetricsProvider - Interface in com.hazelcast.internal.metrics
-
- DiscardMergePolicy<V,T extends MergingValue<V>> - Class in com.hazelcast.spi.merge
-
Merges only entries from the destination data structure and discards all entries from the source data structure.
- DiscardMergePolicy() - Constructor for class com.hazelcast.spi.merge.DiscardMergePolicy
-
- discardMetrics(MetricsRegistry) - Method in interface com.hazelcast.internal.metrics.DiscardableMetricsProvider
-
- discardMetrics(Object...) - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
-
- discardMetrics(Object...) - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
-
- discoverLocalMetadata() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
-
- discoverLocalMetadata() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategy
-
Returns a map with discovered metadata provided by the runtime environment.
- discoverLocalMetadata() - Method in class com.hazelcast.spi.discovery.impl.DefaultDiscoveryService
-
- discoverLocalMetadata() - Method in class com.hazelcast.spi.discovery.impl.PredefinedDiscoveryService
-
- discoverLocalMetadata() - Method in interface com.hazelcast.spi.discovery.integration.DiscoveryService
-
Returns a map with discovered metadata provided by the runtime environment.
- discoverLocalMetadata() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategy
-
- discoverNodes() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategy
-
Returns a set of all discovered nodes based on the defined properties that were used
to create the DiscoveryStrategy instance.
- discoverNodes() - Method in class com.hazelcast.spi.discovery.impl.DefaultDiscoveryService
-
- discoverNodes() - Method in class com.hazelcast.spi.discovery.impl.PredefinedDiscoveryService
-
- discoverNodes() - Method in interface com.hazelcast.spi.discovery.integration.DiscoveryService
-
Returns a discovered and filtered, if aÂ
NodeFilter
is setup, set of
discovered nodes to connect to.
- discoverNodes() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategy
-
- DISCOVERY_SPI_ENABLED - Static variable in class com.hazelcast.client.spi.properties.ClientProperty
-
Enables the Discovery SPI lookup over the old native implementations.
- DISCOVERY_SPI_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
Enables the Discovery SPI lookup over the old native implementations.
- DISCOVERY_SPI_PUBLIC_IP_ENABLED - Static variable in class com.hazelcast.client.spi.properties.ClientProperty
-
Enables the Discovery Joiner to use public ips from DiscoveredNode.
- DISCOVERY_SPI_PUBLIC_IP_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
Enables the Discovery Joiner to use public ips from DiscoveredNode.
- DiscoveryAddressProvider - Class in com.hazelcast.client.spi.impl.discovery
-
- DiscoveryAddressProvider(DiscoveryService, LoggingService) - Constructor for class com.hazelcast.client.spi.impl.discovery.DiscoveryAddressProvider
-
- DiscoveryAddressTranslator - Class in com.hazelcast.client.spi.impl.discovery
-
- DiscoveryAddressTranslator(DiscoveryService, boolean) - Constructor for class com.hazelcast.client.spi.impl.discovery.DiscoveryAddressTranslator
-
- DiscoveryConfig - Class in com.hazelcast.config
-
This configuration class describes the top-level config of the discovery
SPI and its discovery strategies.
- DiscoveryConfig() - Constructor for class com.hazelcast.config.DiscoveryConfig
-
- DiscoveryConfig(DiscoveryServiceProvider, NodeFilter, String, Collection<DiscoveryStrategyConfig>) - Constructor for class com.hazelcast.config.DiscoveryConfig
-
- DiscoveryConfigReadOnly - Class in com.hazelcast.config
-
- DiscoveryJoiner - Class in com.hazelcast.internal.cluster.impl
-
- DiscoveryJoiner(Node, DiscoveryService, boolean) - Constructor for class com.hazelcast.internal.cluster.impl.DiscoveryJoiner
-
- DiscoveryMode - Enum in com.hazelcast.spi.discovery.integration
-
The
DiscoveryMode describes how the
DiscoveryStrategy
is going
to behave on discovery requests.
- DiscoveryNode - Class in com.hazelcast.spi.discovery
-
A DiscoveryNode describes a nodes addresses (private and if
necessary a public one) as well as attributes assigned to this node.
- DiscoveryNode() - Constructor for class com.hazelcast.spi.discovery.DiscoveryNode
-
- discoveryService - Variable in class com.hazelcast.instance.Node
-
- DiscoveryService - Interface in com.hazelcast.spi.discovery.integration
-
The DiscoveryService interface defines the basic entry point
into the Discovery SPI implementation.
- DiscoveryServiceProvider - Interface in com.hazelcast.spi.discovery.integration
-
The
DiscoveryServiceProvider interface provides the possibility to build
DiscoveryService
s.
- DiscoveryServiceSettings - Class in com.hazelcast.spi.discovery.integration
-
- DiscoveryServiceSettings() - Constructor for class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
-
- DiscoveryStrategy - Interface in com.hazelcast.spi.discovery
-
The DiscoveryStrategy itself is the actual implementation to discover
nodes based on whatever environment is used to run the Hazelcast cloud.
- DiscoveryStrategyConfig - Class in com.hazelcast.config
-
This configuration class describes a
DiscoveryStrategy
based on a parsed XML or configured manually using the config API
- DiscoveryStrategyConfig(String) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
-
- DiscoveryStrategyConfig(String, Map<String, Comparable>) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
-
- DiscoveryStrategyConfig(DiscoveryStrategyFactory) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
-
- DiscoveryStrategyConfig(DiscoveryStrategyFactory, Map<String, Comparable>) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
-
- DiscoveryStrategyFactory - Interface in com.hazelcast.spi.discovery
-
The DiscoveryStrategyFactory is the entry point for strategy vendors.
- dispatchEvent(Object, CacheEventListener) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- dispatchEvent(ClientEvent, ClientListener) - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- dispatchEvent(CollectionEvent, ItemListener<Data>) - Method in class com.hazelcast.collection.impl.collection.CollectionService
-
- dispatchEvent(QueueEvent, ItemListener) - Method in class com.hazelcast.collection.impl.queue.QueueService
-
- dispatchEvent(MembershipEvent, MembershipListener) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
-
- dispatchEvent(PartitionEvent, PartitionEventListener) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
-
- dispatchEvent(Object, ListenerAdapter) - Method in class com.hazelcast.map.impl.event.MapEventPublishingService
-
- dispatchEvent(Object, ListenerAdapter) - Method in class com.hazelcast.map.impl.MapService
-
- dispatchEvent(MapReduceNotification) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- dispatchEvent(EventData, EntryListener) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- dispatchEvent(QuorumEvent, QuorumListener) - Method in class com.hazelcast.quorum.impl.QuorumServiceImpl
-
- dispatchEvent(Object, Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapEventPublishingService
-
- dispatchEvent(Object, Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-
- dispatchEvent(E, T) - Method in interface com.hazelcast.spi.EventPublishingService
-
Notifies the service of a published event.
- dispatchEvent(DistributedObjectEventPacket, Object) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-
- dispatchEvent(Object, Object) - Method in class com.hazelcast.topic.impl.TopicService
-
- Disposable - Interface in com.hazelcast.nio
-
A Disposable
is a container of data and/or resources that can be disposed.
- dispose() - Method in class com.hazelcast.client.proxy.ClientScheduledFutureProxy
-
- dispose(int) - Method in class com.hazelcast.durableexecutor.impl.TaskRingBuffer
-
Disposes the sequence
- dispose() - Method in class com.hazelcast.internal.memory.impl.MemoryManagerBean
-
- dispose() - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-
- dispose() - Method in class com.hazelcast.internal.util.collection.HsaHeapMemoryManager
-
- dispose() - Method in interface com.hazelcast.internal.util.collection.Long2LongMap
-
- dispose() - Method in class com.hazelcast.internal.util.collection.Long2LongMapHsa
-
- dispose() - Method in class com.hazelcast.internal.util.collection.LongSetHsa
-
- dispose() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
-
- dispose() - Method in interface com.hazelcast.nio.Disposable
-
Disposes this object and releases any data and/or resources associated
with it.
- dispose(String) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
-
- dispose() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledFutureProxy
-
- dispose() - Method in interface com.hazelcast.scheduledexecutor.IScheduledFuture
-
- DISPOSE_BACKUP_TASK_OP - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
-
- DISPOSE_RESULT - Static variable in class com.hazelcast.durableexecutor.impl.DurableExecutorDataSerializerHook
-
- DISPOSE_RESULT_BACKUP - Static variable in class com.hazelcast.durableexecutor.impl.DurableExecutorDataSerializerHook
-
- DISPOSE_TASK_OP - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
-
- DisposeBackupTaskOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
-
- DisposeBackupTaskOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.DisposeBackupTaskOperation
-
- DisposeBackupTaskOperation(String, String) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.DisposeBackupTaskOperation
-
- disposeData(Data) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-
- disposeData(Data) - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
-
- disposeDeferredBlocks() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
This can be used to release unused resources.
- disposeDeferredBlocks() - Method in interface com.hazelcast.map.impl.recordstore.Storage
-
- disposeDeferredBlocks() - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
-
- disposeResult(long) - Method in class com.hazelcast.client.proxy.ClientDurableExecutorServiceProxy
-
- disposeResult(long) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
-
Disposes the result with the given taskId
- disposeResult(int) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorContainer
-
- disposeResult(long) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
-
- DisposeResultBackupOperation - Class in com.hazelcast.durableexecutor.impl.operations
-
- DisposeResultBackupOperation() - Constructor for class com.hazelcast.durableexecutor.impl.operations.DisposeResultBackupOperation
-
- DisposeResultOperation - Class in com.hazelcast.durableexecutor.impl.operations
-
- DisposeResultOperation() - Constructor for class com.hazelcast.durableexecutor.impl.operations.DisposeResultOperation
-
- DisposeResultOperation(String, int) - Constructor for class com.hazelcast.durableexecutor.impl.operations.DisposeResultOperation
-
- DisposeTaskOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
-
- DisposeTaskOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.DisposeTaskOperation
-
- DisposeTaskOperation(ScheduledTaskHandler) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.DisposeTaskOperation
-
- DIST_OBJECT_DESTROY - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
-
- DIST_OBJECT_INIT - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
-
- distinct() - Static method in class com.hazelcast.aggregation.Aggregators
-
- distinct(String) - Static method in class com.hazelcast.aggregation.Aggregators
-
- DISTINCT_VALUES - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
-
- DISTINCT_VALUES_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- DISTINCT_VALUES_MAPPER - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- DISTINCT_VALUES_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- distinctValues() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
-
Deprecated.
Returns an aggregation for selecting all distinct values.
This aggregation is similar to:
- DistinctValuesAggregation<Key,Value,DistinctType> - Class in com.hazelcast.mapreduce.aggregation.impl
-
The predefined distinct value aggregation.
- DistinctValuesAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.DistinctValuesAggregation
-
- DistinctValuesAggregator<I,R> - Class in com.hazelcast.aggregation.impl
-
- DistinctValuesAggregator() - Constructor for class com.hazelcast.aggregation.impl.DistinctValuesAggregator
-
- DistinctValuesAggregator(String) - Constructor for class com.hazelcast.aggregation.impl.DistinctValuesAggregator
-
- DISTRIBUTED_OBJECT_DESTROYED - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- DISTRIBUTED_OBJECT_EVENT - Static variable in class com.hazelcast.spi.impl.SpiPortableHook
-
- DISTRIBUTED_OBJECT_NS - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
-
- DistributedDurableExecutorService - Class in com.hazelcast.durableexecutor.impl
-
- DistributedDurableExecutorService(NodeEngineImpl) - Constructor for class com.hazelcast.durableexecutor.impl.DistributedDurableExecutorService
-
- DistributedExecutorService - Class in com.hazelcast.executor.impl
-
- DistributedExecutorService() - Constructor for class com.hazelcast.executor.impl.DistributedExecutorService
-
- DistributedObject - Interface in com.hazelcast.core
-
Base interface for all distributed objects.
- distributedObject - Variable in class com.hazelcast.core.DistributedObjectEvent
-
- distributedObjectCreated(DistributedObjectEvent) - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
-
- distributedObjectCreated(DistributedObjectEvent) - Method in interface com.hazelcast.core.DistributedObjectListener
-
Invoked when a DistributedObject is created.
- distributedObjectCreated(DistributedObjectEvent) - Method in class com.hazelcast.internal.jmx.ManagementService
-
- distributedObjectDestroyed(DistributedObjectEvent) - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
-
- distributedObjectDestroyed(DistributedObjectEvent) - Method in interface com.hazelcast.core.DistributedObjectListener
-
Invoked when a DistributedObject is destroyed.
- distributedObjectDestroyed(DistributedObjectEvent) - Method in class com.hazelcast.internal.jmx.ManagementService
-
- DistributedObjectDestroyedException - Exception in com.hazelcast.spi.exception
-
- DistributedObjectDestroyedException(String) - Constructor for exception com.hazelcast.spi.exception.DistributedObjectDestroyedException
-
- DistributedObjectDestroyOperation - Class in com.hazelcast.spi.impl.proxyservice.impl.operations
-
- DistributedObjectDestroyOperation() - Constructor for class com.hazelcast.spi.impl.proxyservice.impl.operations.DistributedObjectDestroyOperation
-
- DistributedObjectDestroyOperation(String, String) - Constructor for class com.hazelcast.spi.impl.proxyservice.impl.operations.DistributedObjectDestroyOperation
-
- DistributedObjectEvent - Class in com.hazelcast.core
-
DistributedObjectEvent is fired when a
DistributedObject
is created or destroyed cluster-wide.
- DistributedObjectEvent(DistributedObjectEvent.EventType, String, String, DistributedObject) - Constructor for class com.hazelcast.core.DistributedObjectEvent
-
Constructs a DistributedObject Event.
- DistributedObjectEvent.EventType - Enum in com.hazelcast.core
-
Type of event.
- DistributedObjectEventPacket - Class in com.hazelcast.spi.impl.proxyservice.impl
-
- DistributedObjectEventPacket() - Constructor for class com.hazelcast.spi.impl.proxyservice.impl.DistributedObjectEventPacket
-
- DistributedObjectEventPacket(DistributedObjectEvent.EventType, String, String) - Constructor for class com.hazelcast.spi.impl.proxyservice.impl.DistributedObjectEventPacket
-
- DistributedObjectFuture - Class in com.hazelcast.spi.impl.proxyservice.impl
-
- DistributedObjectFuture() - Constructor for class com.hazelcast.spi.impl.proxyservice.impl.DistributedObjectFuture
-
- DistributedObjectInfo - Class in com.hazelcast.client.impl.client
-
- DistributedObjectInfo() - Constructor for class com.hazelcast.client.impl.client.DistributedObjectInfo
-
- DistributedObjectInfo(String, String) - Constructor for class com.hazelcast.client.impl.client.DistributedObjectInfo
-
- DistributedObjectListener - Interface in com.hazelcast.core
-
DistributedObjectListener notifies when a
DistributedObject
is created or destroyed cluster-wide.
- DistributedObjectNamespace - Class in com.hazelcast.spi
-
- DistributedObjectNamespace() - Constructor for class com.hazelcast.spi.DistributedObjectNamespace
-
- DistributedObjectNamespace(String, String) - Constructor for class com.hazelcast.spi.DistributedObjectNamespace
-
- DistributedObjectNamespace(ObjectNamespace) - Constructor for class com.hazelcast.spi.DistributedObjectNamespace
-
- DistributedObjectUtil - Class in com.hazelcast.core
-
- DistributedScheduledExecutorService - Class in com.hazelcast.scheduledexecutor.impl
-
Scheduled executor service, middle-man responsible for managing Scheduled Executor containers.
- DistributedScheduledExecutorService() - Constructor for class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
-
- DISTRIBUTION - Static variable in class com.hazelcast.instance.GeneratedBuildProperties
-
- divideByAndCeilToInt(double, int) - Static method in class com.hazelcast.util.QuickMath
-
Divide d by k and return the smallest integer greater than or equal to the result.
- divideByAndCeilToLong(double, int) - Static method in class com.hazelcast.util.QuickMath
-
Divide d by k and return the smallest integer greater than or equal to the result.
- divideByAndRoundToInt(double, int) - Static method in class com.hazelcast.util.QuickMath
-
Divide d by k and return the int value closest to the result.
- divideByAndRoundToLong(double, int) - Static method in class com.hazelcast.util.QuickMath
-
Divide d by k and return the long value closest to the result.
- DO_NOT_REDUCE - Static variable in class com.hazelcast.query.impl.getters.AbstractMultiValueGetter
-
- doBegin(Object, TransactionDefinition) - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
-
- doCleanupAfterCompletion(Object) - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
-
- doCommit(DefaultTransactionStatus) - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
-
- doEviction() - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
-
- doEviction() - Method in interface com.hazelcast.internal.nearcache.NearCacheRecordStore
-
- doEvictionIfRequired() - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
-
- doEvictionIfRequired() - Method in interface com.hazelcast.internal.nearcache.NearCacheRecordStore
-
- doExpiration() - Method in class com.hazelcast.internal.nearcache.impl.store.BaseHeapNearCacheRecordStore
-
- doExpiration() - Method in interface com.hazelcast.internal.nearcache.NearCacheRecordStore
-
Performs expiration and evicts expired records.
- doFilter(EventFilter, Data, Object, Object, EntryEventType, String) - Method in class com.hazelcast.map.impl.event.DefaultEntryEventFilteringStrategy
-
Main entry point for filtering events according to given filter.
- doFilter(EventFilter, Data, Object, Object, EntryEventType, String) - Method in interface com.hazelcast.map.impl.event.FilteringStrategy
-
Main entry point for filtering events according to given filter.
- doFilter(EventFilter, Data, Object, Object, EntryEventType, String) - Method in class com.hazelcast.map.impl.event.QueryCacheNaturalFilteringStrategy
-
- doGetTransaction() - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
-
- doJoin() - Method in class com.hazelcast.cluster.impl.TcpIpJoiner
-
- doJoin() - Method in class com.hazelcast.internal.cluster.impl.AbstractJoiner
-
- doJoin() - Method in class com.hazelcast.internal.cluster.impl.MulticastJoiner
-
- doMatch(String, String, int) - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
-
- domLevel3 - Variable in class com.hazelcast.config.AbstractXmlConfigHelper
-
- done() - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
-
Protected method invoked when this task transitions to state
isDone
(only normally - in case of cancellation cancelled() is invoked)
The default implementation does nothing.
- doneCallback - Variable in class com.hazelcast.spi.InvocationBuilder
-
- doneProcessing() - Method in class com.hazelcast.internal.partition.MigrationInfo
-
- doPostEvictionOperations(Record, boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
Does post eviction operations like sending events
- doPostOperateOps() - Method in class com.hazelcast.map.impl.operation.EntryOperator
-
- doPutRecord(Data, R, String, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- doRemoveRecord(Data, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- doRollback(DefaultTransactionStatus) - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
-
- doRun() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-
- doRun() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
-
- doSetRollbackOnly(DefaultTransactionStatus) - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
-
- doShutdown() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- DOUBLE_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
-
Deprecated.
- DOUBLE_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
-
Deprecated.
- DOUBLE_AVG - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
-
- DOUBLE_AVG_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- DOUBLE_AVG_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- DOUBLE_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
-
- DOUBLE_MAX_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- DOUBLE_MAX_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- DOUBLE_MIN_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- DOUBLE_MIN_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- DOUBLE_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
-
Double size in bytes
- DOUBLE_SUM - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
-
- DOUBLE_SUM_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- DOUBLE_SUM_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- DoubleArraySerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.DoubleArraySerializer
-
- DoubleAverageAggregator<I> - Class in com.hazelcast.aggregation.impl
-
- DoubleAverageAggregator() - Constructor for class com.hazelcast.aggregation.impl.DoubleAverageAggregator
-
- DoubleAverageAggregator(String) - Constructor for class com.hazelcast.aggregation.impl.DoubleAverageAggregator
-
- doubleAvg() - Static method in class com.hazelcast.aggregation.Aggregators
-
- doubleAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
-
- doubleAvg() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
-
Deprecated.
Returns an aggregation to calculate the double average of all supplied values.
This aggregation is similar to:
- DoubleAvgAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
-
The predefined average aggregation for values of type double.
- DoubleAvgAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.DoubleAvgAggregation
-
- DoubleGauge - Interface in com.hazelcast.internal.metrics
-
A DoubleGauge is {link Gauge} where a particular double value is read instantaneous.
- doubleMax() - Static method in class com.hazelcast.aggregation.Aggregators
-
- doubleMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
-
- doubleMax() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
-
Deprecated.
Returns an aggregation to find the double maximum of all supplied values.
This aggregation is similar to:
- DoubleMaxAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
-
The predefined maximum aggregation for values of type double.
- DoubleMaxAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.DoubleMaxAggregation
-
- doubleMin() - Static method in class com.hazelcast.aggregation.Aggregators
-
- doubleMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
-
- doubleMin() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
-
Deprecated.
Returns an aggregation to find the double minimum of all supplied values.
This aggregation is similar to:
- DoubleMinAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
-
The predefined minimum aggregation for values of type double.
- DoubleMinAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.DoubleMinAggregation
-
- DoubleProbeFunction<S> - Interface in com.hazelcast.internal.metrics
-
A
ProbeFunction
that provides a double value and can be used to create a probe using
MetricsRegistry#register(Object, String, DoubleProbeFunction)
- DoubleSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.DoubleSerializer
-
- doubleSum() - Static method in class com.hazelcast.aggregation.Aggregators
-
- doubleSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
-
- doubleSum() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
-
Deprecated.
Returns an aggregation to calculate the double sum of all supplied values.
This aggregation is similar to:
- DoubleSumAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
-
The predefined sum aggregation for values of type double.
- DoubleSumAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.DoubleSumAggregation
-
- DoubleSumAggregator<I> - Class in com.hazelcast.aggregation.impl
-
- DoubleSumAggregator() - Constructor for class com.hazelcast.aggregation.impl.DoubleSumAggregator
-
- DoubleSumAggregator(String) - Constructor for class com.hazelcast.aggregation.impl.DoubleSumAggregator
-
- drain(int) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-
Removes items from the queue and the queue store (if configured), up to maxSize
or the size of the queue,
whichever is smaller.
- DRAIN - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-
- drain(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
-
- drain() - Method in class com.hazelcast.internal.jmx.SemaphoreMBean
-
- drain(int, Predicate<? super E>) - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
-
Drains a batch of items from the queue at the supplied index to the
supplied itemHandler
.
- drain(Predicate<? super E>) - Method in class com.hazelcast.internal.util.concurrent.ManyToOneConcurrentArrayQueue
-
- drain(Predicate<? super E>) - Method in class com.hazelcast.internal.util.concurrent.OneToOneConcurrentArrayQueue
-
- drain(Predicate<? super E>) - Method in interface com.hazelcast.internal.util.concurrent.Pipe
-
Drains the items available in the pipe to the supplied item handler.
- DRAIN_BACKUP - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-
- DRAIN_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-
- DRAIN_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-
- DrainBackupOperation - Class in com.hazelcast.collection.impl.queue.operations
-
This class stores items' ID when DrainOperation run.
- DrainBackupOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.DrainBackupOperation
-
- DrainBackupOperation(String, Set<Long>) - Constructor for class com.hazelcast.collection.impl.queue.operations.DrainBackupOperation
-
- DrainBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
-
- DrainBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.DrainBackupOperation
-
- DrainBackupOperation(String, int, String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.DrainBackupOperation
-
- drainerArrived() - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
-
Called by the drainer thread to signal that it has started draining the
queue.
- drainerDone() - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
-
Called by the drainer thread to signal that it is done draining the queue.
- drainerFailed(Throwable) - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
-
Called by the drainer thread to signal that it has failed and will drain
no more items from the queue.
- drainFromBackup(Set<Long>) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-
- DrainOperation - Class in com.hazelcast.collection.impl.queue.operations
-
This class drain items according to drain condition.
- DrainOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.DrainOperation
-
- DrainOperation(String, int) - Constructor for class com.hazelcast.collection.impl.queue.operations.DrainOperation
-
- DrainOperation - Class in com.hazelcast.concurrent.semaphore.operations
-
- DrainOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.DrainOperation
-
- DrainOperation(String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.DrainOperation
-
- drainPermits() - Method in class com.hazelcast.client.proxy.ClientSemaphoreProxy
-
- drainPermits() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-
- drainPermits() - Method in interface com.hazelcast.core.ISemaphore
-
Acquires and returns all permits that are immediately available.
- drainQueue(Queue<?>) - Static method in class com.hazelcast.util.QueueUtil
-
Drains the provided queue by the size of the queue as it is known
upfront draining.
- drainQueue(Queue<?>, int) - Static method in class com.hazelcast.util.QueueUtil
-
Drains the provided queue by the count provided in elementsToDrain
.
- drainTo(Collection<? super E>) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-
- drainTo(Collection<? super E>, int) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-
- drainTo(Collection<? super E>) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
-
- drainTo(Collection<? super E>, int) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
-
- drainTo(Collection<? super E>) - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
-
Drains a batch of items from the default queue into the supplied collection.
- drainTo(int, Collection<? super E>) - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
-
Drains a batch of items from the queue at the supplied index into the
supplied collection.
- drainTo(Collection<? super E>, int) - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
-
Drains no more than limit
items from the default queue into the
supplied collection.
- drainTo(int, Collection<? super E>, int) - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
-
Drains no more than limit
items from the queue at the supplied
index into the supplied collection.
- drainTo(Collection<? super E>, int) - Method in class com.hazelcast.internal.util.concurrent.ManyToOneConcurrentArrayQueue
-
- drainTo(Collection<? super E>) - Method in class com.hazelcast.internal.util.concurrent.MPSCQueue
-
- drainTo(Collection<? super E>, int) - Method in class com.hazelcast.internal.util.concurrent.MPSCQueue
-
- drainTo(Collection<? super E>, int) - Method in class com.hazelcast.internal.util.concurrent.OneToOneConcurrentArrayQueue
-
- drainTo(Collection<? super E>, int) - Method in interface com.hazelcast.internal.util.concurrent.Pipe
-
Drains at most
limit
available items into the provided
Collection
.
- drainTo(Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
-
Removes all elements from this queue and adds them to the given collection.
- drainTo(InputStream, OutputStream) - Static method in class com.hazelcast.nio.IOUtil
-
- dumpAllThreads() - Static method in class com.hazelcast.internal.management.ThreadDumpGenerator
-
- dumpDeadlocks() - Static method in class com.hazelcast.internal.management.ThreadDumpGenerator
-
- DUPLICATE_INSTANCE_NAME - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- DUPLICATE_TASK - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- DuplicateDetectingMultiResult - Class in com.hazelcast.query.impl
-
- DuplicateDetectingMultiResult() - Constructor for class com.hazelcast.query.impl.DuplicateDetectingMultiResult
-
- DuplicateInstanceNameException - Exception in com.hazelcast.core
-
Thrown when a duplicate instance name is detected.
- DuplicateInstanceNameException(String) - Constructor for exception com.hazelcast.core.DuplicateInstanceNameException
-
Returns the message when a duplicate instance name is detected.
- DuplicateTaskException - Exception in com.hazelcast.scheduledexecutor
-
An exception thrown when a task's name is already used before for another (or the same, if re-attempted) schedule.
- DuplicateTaskException(String) - Constructor for exception com.hazelcast.scheduledexecutor.DuplicateTaskException
-
- DURABLE_EXECUTOR_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
-
- DURABLE_EXECUTOR_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- DURABLE_EXECUTOR_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- DurableExecutorConfig - Class in com.hazelcast.config
-
- DurableExecutorConfig() - Constructor for class com.hazelcast.config.DurableExecutorConfig
-
- DurableExecutorConfig(String) - Constructor for class com.hazelcast.config.DurableExecutorConfig
-
- DurableExecutorConfig(String, int, int, int) - Constructor for class com.hazelcast.config.DurableExecutorConfig
-
- DurableExecutorConfig(String, int, int, int, String) - Constructor for class com.hazelcast.config.DurableExecutorConfig
-
- DurableExecutorConfig(DurableExecutorConfig) - Constructor for class com.hazelcast.config.DurableExecutorConfig
-
- DurableExecutorContainer - Class in com.hazelcast.durableexecutor.impl
-
- DurableExecutorContainer(NodeEngineImpl, String, int, int, TaskRingBuffer) - Constructor for class com.hazelcast.durableexecutor.impl.DurableExecutorContainer
-
- DurableExecutorContainer.TaskProcessor - Class in com.hazelcast.durableexecutor.impl
-
- DurableExecutorDataSerializerHook - Class in com.hazelcast.durableexecutor.impl
-
- DurableExecutorDataSerializerHook() - Constructor for class com.hazelcast.durableexecutor.impl.DurableExecutorDataSerializerHook
-
- DurableExecutorDisposeResultMessageTask - Class in com.hazelcast.client.impl.protocol.task.executorservice.durable
-
- DurableExecutorDisposeResultMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorDisposeResultMessageTask
-
- DurableExecutorIsShutdownMessageTask - Class in com.hazelcast.client.impl.protocol.task.executorservice.durable
-
- DurableExecutorIsShutdownMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorIsShutdownMessageTask
-
- DurableExecutorPartitionContainer - Class in com.hazelcast.durableexecutor.impl
-
- DurableExecutorPartitionContainer(NodeEngineImpl, int) - Constructor for class com.hazelcast.durableexecutor.impl.DurableExecutorPartitionContainer
-
- DurableExecutorRetrieveAndDisposeResultMessageTask - Class in com.hazelcast.client.impl.protocol.task.executorservice.durable
-
- DurableExecutorRetrieveAndDisposeResultMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveAndDisposeResultMessageTask
-
- DurableExecutorRetrieveResultMessageTask - Class in com.hazelcast.client.impl.protocol.task.executorservice.durable
-
- DurableExecutorRetrieveResultMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveResultMessageTask
-
- DurableExecutorService - Interface in com.hazelcast.durableexecutor
-
- DurableExecutorServiceFuture<V> - Interface in com.hazelcast.durableexecutor
-
A Future where one can obtain the task ID for tracking the response.
- DurableExecutorServicePermission - Class in com.hazelcast.security.permission
-
- DurableExecutorServicePermission(String, String...) - Constructor for class com.hazelcast.security.permission.DurableExecutorServicePermission
-
- DurableExecutorServiceProxy - Class in com.hazelcast.durableexecutor.impl
-
- DurableExecutorShutdownMessageTask - Class in com.hazelcast.client.impl.protocol.task.executorservice.durable
-
- DurableExecutorShutdownMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorShutdownMessageTask
-
- DurableExecutorSubmitToPartitionMessageTask - Class in com.hazelcast.client.impl.protocol.task.executorservice.durable
-
- DurableExecutorSubmitToPartitionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorSubmitToPartitionMessageTask
-
- DurableExecutorWaitNotifyKey - Class in com.hazelcast.durableexecutor.impl.operations
-
- DurableIterator() - Constructor for class com.hazelcast.durableexecutor.impl.TaskRingBuffer.DurableIterator
-
- DurationConfig() - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
-
- DurationConfig(long, TimeUnit) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
-
- durationMs - Variable in class com.hazelcast.internal.management.dto.SlowOperationInvocationDTO
-
- DYNAMIC_CONFIG_PRE_JOIN_OP - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
-
- DynamicConfigListener - Interface in com.hazelcast.internal.dynamicconfig
-
- DynamicConfigPreJoinOperation - Class in com.hazelcast.internal.dynamicconfig
-
- DynamicConfigPreJoinOperation(IdentifiedDataSerializable[], ConfigCheckMode) - Constructor for class com.hazelcast.internal.dynamicconfig.DynamicConfigPreJoinOperation
-
- DynamicConfigPreJoinOperation() - Constructor for class com.hazelcast.internal.dynamicconfig.DynamicConfigPreJoinOperation
-
- DynamicConfigurationAwareConfig - Class in com.hazelcast.internal.dynamicconfig
-
- DynamicConfigurationAwareConfig(Config) - Constructor for class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- DynamicSecurityConfig - Class in com.hazelcast.internal.dynamicconfig
-
SecurityConfig
wrapper that supports dynamically updating
client permissions.
- DynamicSecurityConfig(SecurityConfig, SecurityService) - Constructor for class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
-
- Echo - Class in com.hazelcast.console
-
Echoes to screen.
- Echo() - Constructor for class com.hazelcast.console.Echo
-
- Echo(String) - Constructor for class com.hazelcast.console.Echo
-
- element() - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-
- element() - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
-
- element() - Method in class com.hazelcast.mapreduce.impl.ListKeyValueSource
-
- element() - Method in class com.hazelcast.mapreduce.impl.MapKeyValueSource
-
- element() - Method in class com.hazelcast.mapreduce.impl.MultiMapKeyValueSource
-
- element() - Method in class com.hazelcast.mapreduce.impl.SetKeyValueSource
-
- element() - Method in class com.hazelcast.mapreduce.KeyValueSource
-
Deprecated.
Returns the current index element
Calls to this method won't change state.
- ElementParser - Class in com.hazelcast.buildutils
-
Originally taken from JBOSS project (thanks guys, great work)
Original class: org.jboss.osgi.metadata.spi.ElementParser -> JBossOSGi Resolver Metadata
- elements() - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
-
- elements() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
-
- elements() - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
-
- elements() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
-
Returns an enumeration of the values in this table.
- emit(K, V) - Method in interface com.hazelcast.mapreduce.Context
-
Deprecated.
Emits a key-value pair to the intermediate working space.
- emit(KeyIn, ValueIn) - Method in class com.hazelcast.mapreduce.impl.task.DefaultContext
-
- empty() - Static method in class com.hazelcast.query.impl.getters.Extractors
-
- EMPTY_LOCAL_MAP_STATS - Static variable in class com.hazelcast.map.impl.LocalMapStatsProvider
-
- EMPTY_MAP_DATA_STORE - Static variable in class com.hazelcast.map.impl.mapstore.MapDataStores
-
- emptyCollection(MultiMapConfig.ValueCollectionType) - Static method in class com.hazelcast.multimap.impl.ValueCollectionFactory
-
- emptyDelayedEntry() - Static method in class com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntries
-
- EmptyDynamicConfigListener - Class in com.hazelcast.internal.dynamicconfig
-
- EmptyDynamicConfigListener() - Constructor for class com.hazelcast.internal.dynamicconfig.EmptyDynamicConfigListener
-
- EmptyIterator() - Constructor for class com.hazelcast.spi.impl.merge.AbstractContainerCollector.EmptyIterator
-
- emptyMapStoreManager() - Static method in class com.hazelcast.map.impl.mapstore.MapStoreManagers
-
- EmptyOptimizer - Class in com.hazelcast.query.impl.predicates
-
Optimizer which just returns the original predicate.
- EmptyOptimizer() - Constructor for class com.hazelcast.query.impl.predicates.EmptyOptimizer
-
- EmptyStatement - Class in com.hazelcast.util
-
This class makes CheckStyle happy, if you have an ignored or expected exception,
but need at least a single statement in the catch
clause.
- emptyStore() - Static method in class com.hazelcast.map.impl.mapstore.MapDataStores
-
Used for providing neutral null behaviour.
- ENABLE_JMX - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
- enableCompression - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-
- ENABLED - Static variable in class com.hazelcast.client.impl.statistics.Statistics
-
Use to enable the client statistics collection.
- enabled - Variable in class com.hazelcast.config.QuorumConfigBuilder
-
Whether this quorum config is enabled or not
- enabled(boolean) - Method in class com.hazelcast.config.QuorumConfigBuilder
-
- ENABLED - Static variable in class com.hazelcast.internal.diagnostics.Diagnostics
-
Use the
Diagnostics
to see internal performance metrics and cluster related information.
- ENABLED - Static variable in class com.hazelcast.internal.diagnostics.SystemLogPlugin
-
If this plugin is enabled.
- enableManagement(String, boolean) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
-
- enableManagement(String, boolean) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
-
- enableSharedObject - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-
- enableStatistics(String, boolean) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
-
- enableStatistics(String, boolean) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
-
- encode(byte[]) - Static method in class com.hazelcast.util.Base64
-
Encodes hex octects into Base64
- encodeAddRequest(boolean) - Method in interface com.hazelcast.client.spi.impl.ListenerMessageCodec
-
- encodeAuth(byte, Address, String, String, byte, List<Member>) - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
-
- encodeAuth(byte, Address, String, String, byte, List<Member>) - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationCustomCredentialsMessageTask
-
- encodeAuth(byte, Address, String, String, byte, List<Member>) - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationMessageTask
-
- encodeBatchInvalidation(String, List<Data>, List<String>, List<UUID>, List<Long>) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.AbstractBaseNearCacheInvalidationListener
-
- encodeEvent(Data, Data, Data, Data, int, String, int) - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapAddEntryListenerMessageTask
-
- encodeEvent(Data, Data, Data, Data, int, String, int) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerMessageTask
-
- encodeEvent(Data, Data, Data, Data, int, String, int) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyMessageTask
-
- encodeEvent(Data, Data, Data, Data, int, String, int) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyWithPredicateMessageTask
-
- encodeEvent(Data, Data, Data, Data, int, String, int) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerWithPredicateMessageTask
-
- encodeEvent(Data, Data, Data, Data, int, String, int) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddNearCacheInvalidationListenerMessageTask
-
- encodeEvent(Data, Data, Data, Data, int, String, int) - Method in class com.hazelcast.client.impl.protocol.task.map.Pre38MapAddNearCacheEntryListenerMessageTask
-
- encodeEvent(Data, Data, Data, int, String, int) - Method in class com.hazelcast.client.impl.protocol.task.multimap.AbstractMultiMapAddEntryListenerMessageTask
-
- encodeEvent(Data, Data, Data, int, String, int) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerMessageTask
-
- encodeEvent(Data, Data, Data, int, String, int) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerToKeyMessageTask
-
- encodeEvent(Data, Data, Data, Data, int, String, int) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
-
- encodeEvent(Data, Data, Data, Data, int, String, int) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerMessageTask
-
- encodeEvent(Data, Data, Data, Data, int, String, int) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyMessageTask
-
- encodeEvent(Data, Data, Data, Data, int, String, int) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask
-
- encodeEvent(Data, Data, Data, Data, int, String, int) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerWithPredicateMessageTask
-
- encodeEvent(Data, Data, Data, Data, int, String, int) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddNearCacheListenerMessageTask
-
- encodeRemoveRequest(String) - Method in interface com.hazelcast.client.spi.impl.ListenerMessageCodec
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.AddMembershipListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionLostListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAddAndGetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAlterAndGetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAlterMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongApplyMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongCompareAndSetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongDecrementAndGetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndAddMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndAlterMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndIncrementMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndSetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongIncrementAndGetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongSetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceAlterAndGetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceAlterMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceApplyMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceClearMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceCompareAndSetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceContainsMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetAndAlterMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetAndSetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceIsNullMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceSetAndGetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceSetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationCustomCredentialsMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddEntryListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddNearCacheInvalidationListenerTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddPartitionLostListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheClearMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheContainsKeyMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheCreateConfigMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheDestroyMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEntryProcessorMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEventJournalReadTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEventJournalSubscribeTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheFetchNearCacheInvalidationMetadataTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndRemoveMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndReplaceMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetConfigMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheIterateEntriesMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheIterateMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheListenerRegistrationMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheLoadAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheManagementConfigMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutIfAbsentMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllKeysMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveEntryListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemovePartitionLostListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheReplaceMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheSizeMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.Pre38CacheAddInvalidationListenerTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorAddMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorEstimateMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.ClientStatisticsMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionAwaitMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionBeforeAwaitMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionSignalAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionSignalMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchAwaitMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchCountDownMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchGetCountMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchTrySetCountMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterAddMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetConfiguredReplicaCountMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.CreateProxiesMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.CreateProxyMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.DeployClassesMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.DestroyProxyMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddCacheConfigMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddCardinalityEstimatorConfigMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddDurableExecutorConfigMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddEventJournalConfigMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddExecutorConfigMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddFlakeIdGeneratorConfigMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddListConfigMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddLockConfigMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddMapConfigMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddMultiMapConfigMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddQueueConfigMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddReliableTopicConfigMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddReplicatedMapConfigMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddRingbufferConfigMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddScheduledExecutorConfigMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddSemaphoreConfigMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddSetConfigMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddTopicConfigMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorDisposeResultMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorIsShutdownMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveAndDisposeResultMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveResultMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorShutdownMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorSubmitToPartitionMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnAddressMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnPartitionMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceIsShutdownMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceShutdownMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToAddressMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToPartitionMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.GetDistributedObjectsMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.GetPartitionsMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddAllWithIndexMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddWithIndexMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListClearMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRemoveAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRetainAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListContainsAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListContainsMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListGetAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListGetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListIndexOfMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListIsEmptyMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListIteratorMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListLastIndexOfMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListListIteratorMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveWithIndexMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListSetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListSizeMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListSubMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.lock.LockForceUnlockMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.lock.LockGetLockCountMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.lock.LockGetRemainingLeaseTimeMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.lock.LockIsLockedByCurrentThreadMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.lock.LockIsLockedMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.lock.LockLockMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.lock.LockTryLockMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.lock.LockUnlockMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyWithPredicateMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerWithPredicateMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddIndexMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddInterceptorMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddNearCacheInvalidationListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddPartitionLostListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAggregateMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAggregateWithPredicateMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearNearCacheMessageTask
-
Deprecated.
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsKeyMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsValueMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapDeleteMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapDestroyCacheMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPagingPredicateMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPredicateMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntrySetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEventJournalReadTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEventJournalSubscribeTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnAllKeysMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeyMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeysMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteWithPredicateMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchEntriesMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchKeysMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchNearCacheInvalidationMetadataTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchWithQueryMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapFlushMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapForceUnlockMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetEntryViewMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsEmptyMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsLockedMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPagingPredicateMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPredicateMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadGivenKeysMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapLockMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapMadePublishableMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapProjectionMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapProjectionWithPredicateMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateWithValueMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutIfAbsentMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutTransientMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveEntryListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveIfSameMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveInterceptorMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemovePartitionLostListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapReplaceIfSameMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapReplaceMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetReadCursorMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapSizeMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapSubmitToKeyMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryLockMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryPutMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryRemoveMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapUnlockMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPagingPredicateMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPredicateMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.Pre38MapAddNearCacheEntryListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceCancelMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForCustomMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForListMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMapMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMultiMapMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForSetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceJobProcessInformationMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerToKeyMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapClearMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsEntryMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsKeyMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsValueMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapDeleteMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapEntrySetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapForceUnlockMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapGetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapIsLockedMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapKeySetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapLockMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapPutMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapSizeMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapTryLockMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapUnlockMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValueCountMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValuesMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.NoSuchMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.PingMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueClearMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRemoveAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRetainAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMaxSizeMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIsEmptyMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIteratorMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueOfferMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePeekMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePollMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePutMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemainingCapacityMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueSizeMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueTakeMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistributedObjectListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.RemovePartitionLostListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerWithPredicateMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddNearCacheListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapClearMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsKeyMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsValueMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapEntrySetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapGetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapIsEmptyMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapKeySetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveEntryListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapSizeMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapValuesMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferCapacityMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferHeadSequenceMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadManyMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadOneMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferRemainingCapacityMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferSizeMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferTailSequenceMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorGetAllScheduledMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorShutdownMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToAddressMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToPartitionMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromAddressMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromPartitionMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromAddressMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromPartitionMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromAddressMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromPartitionMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromAddressMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromPartitionMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromAddressMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromPartitionMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromAddressMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromPartitionMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromAddressMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromPartitionMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreAcquireMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreAvailablePermitsMessageTasks
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreDrainPermitsMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreIncreasePermitsMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreInitMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreReducePermitsMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreReleaseMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreTryAcquireMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetClearMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRemoveAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRetainAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetContainsAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetContainsMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetGetAllMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetIsEmptyMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetSizeMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicAddMessageListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicPublishMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicRemoveMessageListenerMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCommitMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCreateMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionRollbackMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAClearRemoteTransactionMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XACollectTransactionsMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAFinalizeTransactionMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCommitMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCreateMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionPrepareMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionRollbackMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListAddMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListRemoveMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListSizeMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapContainsKeyMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapDeleteMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetForUpdateMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapIsEmptyMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetWithPredicateMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutIfAbsentMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveIfSameMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceIfSameMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSizeMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesWithPredicateMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapGetMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapPutMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveEntryMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapSizeMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapValueCountMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueOfferMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePeekMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePollMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueSizeMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueTakeMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetAddMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetRemoveMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetSizeMessageTask
-
- encodeResponse(Object) - Method in class com.hazelcast.flakeidgen.impl.client.NewIdBatchMessageTask
-
- encodeSingleInvalidation(String, Data, String, UUID, long) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.AbstractBaseNearCacheInvalidationListener
-
- encrypt(String, int) - Method in class com.hazelcast.config.replacer.AbstractPbeReplacer
-
- encrypt(String...) - Static method in class com.hazelcast.config.replacer.EncryptionReplacer
-
- EncryptionReplacer - Class in com.hazelcast.config.replacer
-
This class is an
example ConfigReplacer
implementation which decrypts
encrypted values.
- EncryptionReplacer() - Constructor for class com.hazelcast.config.replacer.EncryptionReplacer
-
- end(Xid, int) - Method in class com.hazelcast.client.proxy.txn.xa.XAResourceProxy
-
- END - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
-
- end(Xid, int) - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
-
- END_FLAG - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
-
End Flag
- EndiannessUtil - Class in com.hazelcast.internal.memory.impl
-
A utility class with methods that read/write multibyte values from/to byte-addressed memory, with
explicitly specified endianness.
- endpoint - Variable in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-
- Endpoint - Interface in com.hazelcast.core
-
Endpoint represents a peer in the cluster.
- endSection() - Method in interface com.hazelcast.internal.diagnostics.DiagnosticsLogWriter
-
- endSection() - Method in class com.hazelcast.internal.diagnostics.DiagnosticsLogWriterImpl
-
- enforcePartitionTableWarmup(MapReduceService) - Static method in class com.hazelcast.mapreduce.impl.MapReduceUtil
-
- enqueue(TextCommand) - Method in class com.hazelcast.nio.ascii.TextEncoder
-
- enqueueSuspended(TaskDefinition) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
-
- enqueueSuspended(ScheduledTaskDescriptor, boolean) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
-
- ensure(long, int) - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray12byteKey
-
Ensures that there is a mapping from (key1, key2)
to a slot in the array.
- ensure(long, long) - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray16byteKey
-
Ensures that there is a mapping from (key1, key2)
to a slot in the array.
- ensure(long) - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray8byteKey
-
Ensures that there is a mapping from the given key to a slot in the array.
- ensure(long, int) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray12byteKeyImpl
-
Ensures that there is a mapping from (key1, key2)
to a slot in the array.
- ensure(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyImpl
-
Ensures that there is a mapping from (key1, key2)
to a slot in the array.
- ensure(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyNoValue
-
- ensure(long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray8byteKeyImpl
-
Ensures that there is a mapping from the given key to a slot in the array.
- ensure0(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
-
- ensureBackupLogsExist() - Method in class com.hazelcast.transaction.impl.TransactionImpl
-
Some data-structures like the Transaction List rely on (empty) backup logs to be created before any change on the
data-structure is made.
- ensureMember(Address) - Method in class com.hazelcast.spi.CallsPerMember
-
Makes sure that a list of counters is created for a member.
- ensureOpen() - Method in class com.hazelcast.cache.impl.AbstractClusterWideIterator
-
- ensureOpen() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- ensureOpenIfAvailable(ICacheInternal<K, V>) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- ensureQuorumPresent(String, QuorumType) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- ensureQuorumPresent(Operation) - Method in class com.hazelcast.quorum.impl.QuorumServiceImpl
-
Ensures that the quorum for the given operation is present.
- ensureQuorumPresent(String, QuorumType) - Method in class com.hazelcast.quorum.impl.QuorumServiceImpl
-
- ensureQuorumPresent(String, QuorumType) - Method in interface com.hazelcast.quorum.QuorumService
-
Ensures that the quorum with the given name is present.
- ensureQuorumPresent(String, QuorumType) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-
- ensureQuorumPresent(String, QuorumType) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
-
- ensureReserve(long) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-
- ENTERPRISE_CACHE_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- ENTERPRISE_CACHE_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- ENTERPRISE_HOTRESTART_BACKUP_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- ENTERPRISE_HOTRESTART_BACKUP_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- ENTERPRISE_HOTRESTART_CLUSTER_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- ENTERPRISE_HOTRESTART_CLUSTER_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- ENTERPRISE_LICENSE_KEY - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
- ENTERPRISE_MAP_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- ENTERPRISE_MAP_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- ENTERPRISE_MAP_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- ENTERPRISE_MAP_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- ENTERPRISE_SECURITY_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- ENTERPRISE_SECURITY_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- ENTERPRISE_WAN_REPLICATION_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- ENTERPRISE_WAN_REPLICATION_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- ENTRIES - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- entries() - Method in class com.hazelcast.map.impl.MapEntries
-
- entries() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntries
-
- ENTRIES_WITH_CURSOR - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- ENTRY_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- ENTRY_EVENT - Static variable in class com.hazelcast.spi.impl.SpiPortableHook
-
- ENTRY_EVENT_FILTER - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- ENTRY_ITERATION_RESULT - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- ENTRY_ITERATOR - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- ENTRY_LISTENER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
-
- ENTRY_OFFLOADABLE_SET_UNLOCK - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- ENTRY_OPERATION - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- ENTRY_PROCESSOR - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- ENTRY_PROCESSOR - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- ENTRY_REMOVING_PROCESSOR - Static variable in class com.hazelcast.map.impl.EntryRemovingProcessor
-
- ENTRY_REMOVING_PROCESSOR - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- ENTRY_SET - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- ENTRY_SET - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
-
- ENTRY_SET_RESPONSE - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- ENTRY_VIEW - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- ENTRY_VIEW - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
-
- EntryAdapter<K,V> - Class in com.hazelcast.core
-
- EntryAdapter() - Constructor for class com.hazelcast.core.EntryAdapter
-
- entryAdded(EntryEvent) - Method in class com.hazelcast.client.console.ClientConsoleApp
-
- entryAdded(EntryEvent<Object, Object>) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
-
- entryAdded(EntryEvent) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
-
- entryAdded(EntryEvent) - Method in class com.hazelcast.console.ConsoleApp
-
- entryAdded(EntryEvent<K, V>) - Method in class com.hazelcast.core.EntryAdapter
-
- entryAdded(EntryEvent<K, V>) - Method in class com.hazelcast.map.impl.MapListenerAdapter
-
- entryAdded(EntryEvent<K, V>) - Method in interface com.hazelcast.map.listener.EntryAddedListener
-
Invoked upon addition of an entry.
- EntryAddedListener<K,V> - Interface in com.hazelcast.map.listener
-
Invoked upon addition of an entry.
- EntryBackupOperation - Class in com.hazelcast.map.impl.operation
-
- EntryBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.EntryBackupOperation
-
- EntryBackupOperation(String, Data, EntryBackupProcessor) - Constructor for class com.hazelcast.map.impl.operation.EntryBackupOperation
-
- EntryBackupProcessor<K,V> - Interface in com.hazelcast.map
-
Processes an entry on a backup partition.
- entryBackupProcessor - Variable in class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
-
- EntryConverter - Class in com.hazelcast.internal.ascii.memcache
-
- EntryConverter(TextCommandService, ILogger) - Constructor for class com.hazelcast.internal.ascii.memcache.EntryConverter
-
- EntryCostEstimator<K,V> - Interface in com.hazelcast.map.impl
-
Owned entry cost estimator general contract.
- EntryCountCacheEvictionChecker - Class in com.hazelcast.cache.impl.maxsize.impl
-
- EntryCountCacheEvictionChecker(int, CacheRecordMap, int) - Constructor for class com.hazelcast.cache.impl.maxsize.impl.EntryCountCacheEvictionChecker
-
- EntryCountNearCacheEvictionChecker - Class in com.hazelcast.internal.nearcache.impl.maxsize
-
- EntryCountNearCacheEvictionChecker(int, SampleableNearCacheRecordMap) - Constructor for class com.hazelcast.internal.nearcache.impl.maxsize.EntryCountNearCacheEvictionChecker
-
- EntryEvent<K,V> - Class in com.hazelcast.core
-
Map Entry event.
- EntryEvent(Object, Member, int, K, V) - Constructor for class com.hazelcast.core.EntryEvent
-
Constructs an entry event.
- EntryEvent(Object, Member, int, K, V, V) - Constructor for class com.hazelcast.core.EntryEvent
-
Constructs an entry event.
- EntryEvent(Object, Member, int, K, V, V, V) - Constructor for class com.hazelcast.core.EntryEvent
-
Constructs an entry event.
- EntryEventData - Class in com.hazelcast.map.impl.event
-
An entry's event data.
- EntryEventData() - Constructor for class com.hazelcast.map.impl.event.EntryEventData
-
- EntryEventData(String, String, Address, Data, Data, Data, int) - Constructor for class com.hazelcast.map.impl.event.EntryEventData
-
- EntryEventData(String, String, Address, Data, Data, Data, Data, int) - Constructor for class com.hazelcast.map.impl.event.EntryEventData
-
- EntryEventDataCache - Interface in com.hazelcast.map.impl.event
-
- EntryEventFilter - Class in com.hazelcast.map.impl
-
Event filter which matches events for a specified entry key.
- EntryEventFilter(boolean, Data) - Constructor for class com.hazelcast.map.impl.EntryEventFilter
-
- EntryEventFilter() - Constructor for class com.hazelcast.map.impl.EntryEventFilter
-
- EntryEventType - Enum in com.hazelcast.core
-
Type of entry event.
- entryEvicted(EntryEvent) - Method in class com.hazelcast.client.console.ClientConsoleApp
-
- entryEvicted(EntryEvent<Object, Object>) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
-
- entryEvicted(EntryEvent) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
-
- entryEvicted(EntryEvent) - Method in class com.hazelcast.console.ConsoleApp
-
- entryEvicted(EntryEvent<K, V>) - Method in class com.hazelcast.core.EntryAdapter
-
- entryEvicted(EntryEvent<K, V>) - Method in class com.hazelcast.map.impl.MapListenerAdapter
-
- entryEvicted(EntryEvent<K, V>) - Method in interface com.hazelcast.map.listener.EntryEvictedListener
-
Invoked upon eviction of an entry.
- EntryEvictedListener<K,V> - Interface in com.hazelcast.map.listener
-
Invoked upon eviction of an entry.
- entryExpired(EntryEvent<K, V>) - Method in class com.hazelcast.map.impl.MapListenerAdapter
-
- entryExpired(EntryEvent<K, V>) - Method in interface com.hazelcast.map.listener.EntryExpiredListener
-
Invoked upon expiration of an entry.
- EntryExpiredListener<K,V> - Interface in com.hazelcast.map.listener
-
Listener which is notified after removal of an entry due to the expiration-based-eviction.
- EntryListener<K,V> - Interface in com.hazelcast.core
-
Map Entry listener to get notified when a map entry
is added, removed, updated or evicted.
- EntryListenerAdaptors - Class in com.hazelcast.map.impl
-
- EntryListenerConfig - Class in com.hazelcast.config
-
Configuration for EntryListener
- EntryListenerConfig() - Constructor for class com.hazelcast.config.EntryListenerConfig
-
- EntryListenerConfig(String, boolean, boolean) - Constructor for class com.hazelcast.config.EntryListenerConfig
-
- EntryListenerConfig(EntryListener, boolean, boolean) - Constructor for class com.hazelcast.config.EntryListenerConfig
-
- EntryListenerConfig(MapListener, boolean, boolean) - Constructor for class com.hazelcast.config.EntryListenerConfig
-
- EntryListenerConfig(EntryListenerConfig) - Constructor for class com.hazelcast.config.EntryListenerConfig
-
- EntryListenerConfig.MapListenerToEntryListenerAdapter - Class in com.hazelcast.config
-
Wraps a MapListener into an EntryListener.
- EntryListenerConfigReadOnly - Class in com.hazelcast.config
-
- EntryListenerConfigReadOnly(EntryListenerConfig) - Constructor for class com.hazelcast.config.EntryListenerConfigReadOnly
-
Deprecated.
- entryMerged(EntryEvent<K, V>) - Method in class com.hazelcast.map.impl.MapListenerAdapter
-
- entryMerged(EntryEvent<K, V>) - Method in interface com.hazelcast.map.listener.EntryMergedListener
-
Invoked after WAN replicated entry is merged.
- EntryMergedListener<K,V> - Interface in com.hazelcast.map.listener
-
Invoked after WAN replicated entry is merged.
- EntryObject - Class in com.hazelcast.query
-
This class provides functionality related to build predicate.
- EntryObject(PredicateBuilder) - Constructor for class com.hazelcast.query.EntryObject
-
- EntryOffloadableLockMismatchException - Exception in com.hazelcast.map.impl.operation
-
Actor of the EntryOffloadableOperation -> EntryOffloadableSetUnlockOperation combined operations flow.
- EntryOffloadableLockMismatchException(String) - Constructor for exception com.hazelcast.map.impl.operation.EntryOffloadableLockMismatchException
-
- EntryOffloadableSetUnlockOperation - Class in com.hazelcast.map.impl.operation
-
Set & Unlock processing for the EntryOperation
See the javadoc on
EntryOperation
- EntryOffloadableSetUnlockOperation() - Constructor for class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
-
- EntryOffloadableSetUnlockOperation(String, EntryEventType, Data, Data, Data, String, long, long, EntryBackupProcessor) - Constructor for class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
-
- EntryOperation - Class in com.hazelcast.map.impl.operation
-
Contains implementation of the off-loadable contract for EntryProcessor execution on a single key.
- EntryOperation() - Constructor for class com.hazelcast.map.impl.operation.EntryOperation
-
- EntryOperation(String, Data, EntryProcessor) - Constructor for class com.hazelcast.map.impl.operation.EntryOperation
-
- EntryOperator - Class in com.hazelcast.map.impl.operation
-
- EntryProcessor<K,V> - Interface in com.hazelcast.map
-
- entryProcessor - Variable in class com.hazelcast.map.impl.operation.MultipleEntryOperation
-
- entryProcessor - Variable in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-
- entryRemoved(EntryEvent) - Method in class com.hazelcast.client.console.ClientConsoleApp
-
- entryRemoved(EntryEvent<Object, Object>) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
-
- entryRemoved(EntryEvent) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
-
- entryRemoved(EntryEvent) - Method in class com.hazelcast.console.ConsoleApp
-
- entryRemoved(EntryEvent<K, V>) - Method in class com.hazelcast.core.EntryAdapter
-
- entryRemoved(EntryEvent<K, V>) - Method in class com.hazelcast.map.impl.MapListenerAdapter
-
- entryRemoved(EntryEvent<K, V>) - Method in interface com.hazelcast.map.listener.EntryRemovedListener
-
Invoked upon removal of an entry.
- EntryRemovedListener<K,V> - Interface in com.hazelcast.map.listener
-
Invoked upon removal of an entry.
- EntryRemovingProcessor - Class in com.hazelcast.map.impl
-
- EntryRemovingProcessor() - Constructor for class com.hazelcast.map.impl.EntryRemovingProcessor
-
- entrySet() - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- entrySet(Predicate) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- entrySet() - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-
- entrySet() - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
-
- entrySet() - Method in class com.hazelcast.cluster.impl.VectorClock
-
Returns a set of replica logical timestamps for this vector clock.
- entrySet() - Method in interface com.hazelcast.core.IMap
-
Returns a
Set
clone of the mappings contained in this map.
- entrySet(Predicate) - Method in interface com.hazelcast.core.IMap
-
Queries the map based on the specified predicate and returns the matching entries.
- entrySet() - Method in interface com.hazelcast.core.MultiMap
-
Returns the set of key-value pairs in the multimap.
- entrySet() - Method in interface com.hazelcast.core.ReplicatedMap
-
Returns a lazy
Set
view of the mappings contained in this map.
A LazySet is optimized for querying speed (preventing eager deserialization
and hashing on HashSet insertion) and does
NOT provide all operations.
- entrySet() - Method in class com.hazelcast.internal.dynamicconfig.AggregatingMap
-
- entrySet(String) - Method in class com.hazelcast.internal.jmx.MapMBean
-
- entrySet() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
-
- entrySet() - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- entrySet(Predicate) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- entrySet() - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
-
- entrySet(Predicate) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
-
- entrySet() - Method in interface com.hazelcast.map.impl.querycache.subscriber.QueryCacheRecordStore
-
- entrySet() - Method in interface com.hazelcast.map.QueryCache
-
- entrySet(Predicate) - Method in interface com.hazelcast.map.QueryCache
-
- entrySet() - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- entrySet(boolean) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- entrySet() - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
-
- entrySet(boolean) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- entrySet() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- entrySet() - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationRegistry
-
Intention to expose the entry set is to mutate it.
- entrySet() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
-
This set's iterator also implements Map.Entry
so the next()
method can just return the iterator
instance itself with no heap allocation.
- entrySet() - Method in class com.hazelcast.util.collection.InternalListMultiMap
-
- entrySet() - Method in class com.hazelcast.util.collection.InternalSetMultimap
-
- entrySet() - Method in class com.hazelcast.util.collection.Long2LongHashMap
-
This set's iterator also implements Map.Entry
so the next()
method can just return the iterator
instance itself with no heap allocation.
- entrySet() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
-
This set's iterator also implements Map.Entry
so the next()
method can just return the iterator
instance itself with no heap allocation.
- entrySet() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
-
Returns a
Set
view of the mappings contained in this map.
- entrySetInternal() - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-
- EntrySetOperation - Class in com.hazelcast.multimap.impl.operations
-
- EntrySetOperation() - Constructor for class com.hazelcast.multimap.impl.operations.EntrySetOperation
-
- EntrySetOperation(String) - Constructor for class com.hazelcast.multimap.impl.operations.EntrySetOperation
-
- EntrySetOperation - Class in com.hazelcast.replicatedmap.impl.operation
-
- EntrySetOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.EntrySetOperation
-
- EntrySetOperation(String) - Constructor for class com.hazelcast.replicatedmap.impl.operation.EntrySetOperation
-
- EntrySetResponse - Class in com.hazelcast.multimap.impl.operations
-
- EntrySetResponse() - Constructor for class com.hazelcast.multimap.impl.operations.EntrySetResponse
-
- EntrySetResponse(Map<Data, Collection<MultiMapRecord>>, NodeEngine) - Constructor for class com.hazelcast.multimap.impl.operations.EntrySetResponse
-
- EntryTaskScheduler<K,V> - Interface in com.hazelcast.util.scheduler
-
Schedules (or reschedules) the execution of given entry.
- EntryTaskSchedulerFactory - Class in com.hazelcast.util.scheduler
-
Factory for EntryTaskSchedulers.
- entryUpdated(EntryEvent) - Method in class com.hazelcast.client.console.ClientConsoleApp
-
- entryUpdated(EntryEvent<Object, Object>) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
-
- entryUpdated(EntryEvent) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
-
- entryUpdated(EntryEvent) - Method in class com.hazelcast.console.ConsoleApp
-
- entryUpdated(EntryEvent<K, V>) - Method in class com.hazelcast.core.EntryAdapter
-
- entryUpdated(EntryEvent<K, V>) - Method in class com.hazelcast.map.impl.MapListenerAdapter
-
- entryUpdated(EntryEvent<K, V>) - Method in interface com.hazelcast.map.listener.EntryUpdatedListener
-
Invoked upon update of an entry.
- EntryUpdatedListener<K,V> - Interface in com.hazelcast.map.listener
-
Invoked upon update of an entry.
- EntryView<K,V> - Interface in com.hazelcast.core
-
Represents a read-only view of a data structure entry.
- EntryViews - Class in com.hazelcast.map.impl
-
A class providing static factory methods that create various entry view objects.
- ENUM_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
-
- EnumSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.EnumSerializer
-
- EOF - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- equal(long, long, long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
-
- equal(Comparable) - Method in class com.hazelcast.query.EntryObject
-
- equal(String, Comparable) - Static method in class com.hazelcast.query.Predicates
-
Creates an equal predicate that will pass items if the given value
and the value stored under
the given item attribute
are equal.
- EQUAL_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
-
- EqualPredicate - Class in com.hazelcast.query.impl.predicates
-
Equal Predicate
- EqualPredicate() - Constructor for class com.hazelcast.query.impl.predicates.EqualPredicate
-
- EqualPredicate(String) - Constructor for class com.hazelcast.query.impl.predicates.EqualPredicate
-
- EqualPredicate(String, Comparable) - Constructor for class com.hazelcast.query.impl.predicates.EqualPredicate
-
- equals(Object) - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-
- equals(Object) - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-
- equals(Object) - Method in class com.hazelcast.cache.impl.CachePartitionEventData
-
- equals(Object) - Method in class com.hazelcast.cache.impl.DeferredValue
-
- equals(Object) - Method in class com.hazelcast.cache.impl.event.CachePartitionLostEventFilter
-
- equals(Object) - Method in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
-
- equals(Object) - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorContainer
-
- equals(Object) - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
-
- equals(Object) - Method in class com.hazelcast.client.config.ProxyFactoryConfig
-
- equals(Object) - Method in class com.hazelcast.client.connection.nio.ClientConnection
-
- equals(Object) - Method in class com.hazelcast.client.impl.client.ClientPrincipal
-
- equals(Object) - Method in class com.hazelcast.client.impl.client.DistributedObjectInfo
-
- equals(Object) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
-
- equals(Object) - Method in class com.hazelcast.client.spi.ClientProxy
-
- equals(Object) - Method in class com.hazelcast.client.spi.impl.listener.ClientEventRegistration
-
- equals(Object) - Method in class com.hazelcast.client.spi.impl.listener.ClientRegistrationKey
-
- equals(Object) - Method in class com.hazelcast.cluster.impl.VectorClock
-
- equals(Object) - Method in class com.hazelcast.collection.impl.collection.CollectionEventFilter
-
- equals(Object) - Method in class com.hazelcast.collection.impl.collection.CollectionItem
-
- equals(Object) - Method in class com.hazelcast.collection.impl.collection.TxCollectionItem
-
- equals(Object) - Method in class com.hazelcast.collection.impl.queue.QueueEventFilter
-
- equals(Object) - Method in class com.hazelcast.collection.impl.queue.QueueItem
-
- equals(Object) - Method in class com.hazelcast.collection.impl.queue.QueueWaitNotifyKey
-
- equals(Object) - Method in class com.hazelcast.collection.impl.txnqueue.TxQueueItem
-
- equals(Object) - Method in class com.hazelcast.concurrent.lock.ConditionKey
-
- equals(Object) - Method in class com.hazelcast.concurrent.lock.InternalLockNamespace
-
- equals(Object) - Method in class com.hazelcast.concurrent.lock.LockWaitNotifyKey
-
- equals(Object) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreWaitNotifyKey
-
- equals(Object) - Method in class com.hazelcast.config.AbstractCacheConfig
-
- equals(Object) - Method in class com.hazelcast.config.AtomicLongConfig
-
- equals(Object) - Method in class com.hazelcast.config.AtomicReferenceConfig
-
- equals(Object) - Method in class com.hazelcast.config.CacheConfig
-
- equals(Object) - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
-
- equals(Object) - Method in class com.hazelcast.config.CacheSimpleConfig
-
- equals(Object) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
-
- equals(Object) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
-
- equals(Object) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
-
- equals(Object) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- equals(Object) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
- equals(Object) - Method in class com.hazelcast.config.ClassFilter
-
- equals(Object) - Method in class com.hazelcast.config.CollectionConfig
-
- equals(Object) - Method in class com.hazelcast.config.CountDownLatchConfig
-
- equals(Object) - Method in class com.hazelcast.config.CredentialsFactoryConfig
-
- equals(Object) - Method in class com.hazelcast.config.DurableExecutorConfig
-
- equals(Object) - Method in class com.hazelcast.config.EntryListenerConfig
-
- equals(Object) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
-
- equals(Object) - Method in class com.hazelcast.config.EventJournalConfig
-
- equals(Object) - Method in class com.hazelcast.config.EvictionConfig
-
- equals(Object) - Method in class com.hazelcast.config.ExecutorConfig
-
- equals(Object) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
- equals(Object) - Method in class com.hazelcast.config.GlobalSerializerConfig
-
- equals(Object) - Method in class com.hazelcast.config.GroupConfig
-
- equals(Object) - Method in class com.hazelcast.config.HotRestartConfig
-
- equals(Object) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
- equals(Object) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
-
- equals(Object) - Method in class com.hazelcast.config.InterfacesConfig
-
- equals(Object) - Method in class com.hazelcast.config.ItemListenerConfig
-
- equals(Object) - Method in class com.hazelcast.config.JavaSerializationFilterConfig
-
- equals(Object) - Method in class com.hazelcast.config.ListenerConfig
-
- equals(Object) - Method in class com.hazelcast.config.LockConfig
-
- equals(Object) - Method in class com.hazelcast.config.LoginModuleConfig
-
- equals(Object) - Method in class com.hazelcast.config.MapAttributeConfig
-
- equals(Object) - Method in class com.hazelcast.config.MapConfig
-
- equals(Object) - Method in class com.hazelcast.config.MapIndexConfig
-
- equals(Object) - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
-
- equals(Object) - Method in class com.hazelcast.config.MapStoreConfig
-
- equals(Object) - Method in class com.hazelcast.config.MaxSizeConfig
-
- equals(Object) - Method in class com.hazelcast.config.MemberAddressProviderConfig
-
- equals(Object) - Method in class com.hazelcast.config.MemberGroupConfig
-
- equals(Object) - Method in class com.hazelcast.config.MergePolicyConfig
-
- equals(Object) - Method in class com.hazelcast.config.MulticastConfig
-
- equals(Object) - Method in class com.hazelcast.config.MultiMapConfig
-
- equals(Object) - Method in class com.hazelcast.config.NativeMemoryConfig
-
- equals(Object) - Method in class com.hazelcast.config.NearCacheConfig
-
- equals(Object) - Method in class com.hazelcast.config.NearCachePreloaderConfig
-
- equals(Object) - Method in class com.hazelcast.config.PartitionGroupConfig
-
- equals(Object) - Method in class com.hazelcast.config.PartitioningStrategyConfig
-
- equals(Object) - Method in class com.hazelcast.config.PermissionConfig
-
- equals(Object) - Method in class com.hazelcast.config.PermissionPolicyConfig
-
- equals(Object) - Method in class com.hazelcast.config.PNCounterConfig
-
- equals(Object) - Method in class com.hazelcast.config.PredicateConfig
-
- equals(Object) - Method in class com.hazelcast.config.QueryCacheConfig
-
- equals(Object) - Method in class com.hazelcast.config.QueueConfig
-
- equals(Object) - Method in class com.hazelcast.config.QueueStoreConfig
-
- equals(Object) - Method in class com.hazelcast.config.ReliableTopicConfig
-
- equals(Object) - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- equals(Object) - Method in class com.hazelcast.config.RingbufferConfig
-
- equals(Object) - Method in class com.hazelcast.config.RingbufferStoreConfig
-
- equals(Object) - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
- equals(Object) - Method in class com.hazelcast.config.SecurityConfig
-
- equals(Object) - Method in class com.hazelcast.config.SemaphoreConfig
-
- equals(Object) - Method in class com.hazelcast.config.SerializerConfig
-
- equals(Object) - Method in class com.hazelcast.config.ServiceConfig
-
- equals(Object) - Method in class com.hazelcast.config.ServicesConfig
-
- equals(Object) - Method in class com.hazelcast.config.SocketInterceptorConfig
-
- equals(Object) - Method in class com.hazelcast.config.TcpIpConfig
-
- equals(Object) - Method in class com.hazelcast.config.TopicConfig
-
- equals(Object) - Method in class com.hazelcast.config.WanReplicationRef
-
- equals(Object) - Method in class com.hazelcast.core.LifecycleEvent
-
- equals(Object) - Method in class com.hazelcast.core.PartitionAwareKey
-
- equals(Object) - Method in class com.hazelcast.durableexecutor.impl.operations.DurableExecutorWaitNotifyKey
-
- equals(Object) - Method in class com.hazelcast.hotrestart.BackupTaskStatus
-
- equals(Object) - Method in class com.hazelcast.instance.AbstractMember
-
- equals(Object) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- equals(Object) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- equals(Object) - Method in class com.hazelcast.internal.ascii.memcache.MemcacheEntry
-
- equals(Object) - Method in class com.hazelcast.internal.cluster.impl.ClusterStateChange
-
- equals(Object) - Method in class com.hazelcast.internal.cluster.impl.MembersViewMetadata
-
- equals(Object) - Method in class com.hazelcast.internal.cluster.MemberInfo
-
- equals(Object) - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
-
- equals(Object) - Method in class com.hazelcast.internal.eviction.EvictionPolicyComparator
-
- equals(Object) - Method in class com.hazelcast.internal.management.MonitoredThread
-
- equals(Object) - Method in class com.hazelcast.internal.partition.impl.ReplicaFragmentSyncInfo
-
- equals(Object) - Method in class com.hazelcast.internal.partition.MigrationInfo
-
- equals(Object) - Method in class com.hazelcast.internal.partition.NonFragmentedServiceNamespace
-
- equals(Object) - Method in class com.hazelcast.internal.partition.PartitionTableView
-
- equals(Object) - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
-
- equals(Object) - Method in class com.hazelcast.internal.serialization.impl.FieldDefinitionImpl
-
- equals(Object) - Method in class com.hazelcast.internal.serialization.impl.HeapData
-
- equals(Object) - Method in class com.hazelcast.map.eviction.LFUEvictionPolicy
-
- equals(Object) - Method in class com.hazelcast.map.eviction.LRUEvictionPolicy
-
- equals(Object) - Method in class com.hazelcast.map.eviction.RandomEvictionPolicy
-
- equals(Object) - Method in class com.hazelcast.map.impl.EntryEventFilter
-
- equals(Object) - Method in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
-
- equals(Object) - Method in class com.hazelcast.map.impl.LazyMapEntry
-
- equals(Object) - Method in class com.hazelcast.map.impl.MapEntrySimple
-
- equals(Object) - Method in class com.hazelcast.map.impl.MapPartitionLostEventFilter
-
- equals(Object) - Method in class com.hazelcast.map.impl.MapRecordKey
-
- equals(Object) - Method in class com.hazelcast.map.impl.operation.MapFlushWaitNotifyKey
-
- equals(Object) - Method in class com.hazelcast.map.impl.query.QueryEventFilter
-
- equals(Object) - Method in class com.hazelcast.map.impl.query.QueryResultRow
-
- equals(Object) - Method in class com.hazelcast.map.impl.querycache.event.BatchEventData
-
- equals(Object) - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-
- equals(Object) - Method in class com.hazelcast.map.impl.record.AbstractRecord
-
- equals(Object) - Method in class com.hazelcast.map.impl.recordstore.LazyEntryViewFromRecord
-
- equals(Object) - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- equals(Object) - Method in class com.hazelcast.mapreduce.impl.task.JobPartitionStateImpl
-
- equals(Object) - Method in class com.hazelcast.memory.MemorySize
-
- equals(Object) - Method in class com.hazelcast.multimap.impl.MultiMapEventFilter
-
- equals(Object) - Method in class com.hazelcast.multimap.impl.MultiMapRecord
-
- equals(Object) - Method in class com.hazelcast.nio.Address
-
- equals(Object) - Method in class com.hazelcast.nio.Packet
-
- equals(Object) - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- equals(Object) - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
-
- equals(Object) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
-
- equals(Object) - Method in class com.hazelcast.query.impl.CachedQueryEntry
-
- equals(Object) - Method in class com.hazelcast.query.impl.IndexImpl.NullObject
-
- equals(Object) - Method in class com.hazelcast.query.impl.IndexInfo
-
- equals(Object) - Method in class com.hazelcast.query.impl.QueryEntry
-
- equals(Object) - Method in class com.hazelcast.query.SqlPredicate
-
- equals(Object) - Method in class com.hazelcast.quorum.impl.ProbabilisticQuorumFunction
-
- equals(Object) - Method in class com.hazelcast.quorum.impl.RecentlyActiveQuorumFunction
-
- equals(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-
- equals(Object) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- equals(Object) - Method in class com.hazelcast.ringbuffer.impl.RingbufferWaitNotifyKey
-
- equals(Object) - Method in class com.hazelcast.scheduledexecutor.impl.DelegatingScheduledFutureStripper
-
- equals(Object) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorWaitNotifyKey
-
- equals(Object) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskDescriptor
-
- equals(Object) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskHandlerImpl
-
- equals(Object) - Method in class com.hazelcast.scheduledexecutor.impl.TaskDefinition
-
- equals(Object) - Method in class com.hazelcast.security.AbstractCredentials
-
- equals(Object) - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
-
- equals(Object) - Method in class com.hazelcast.security.permission.AllPermissions
-
- equals(Object) - Method in class com.hazelcast.security.permission.ClusterPermission
-
- equals(Object) - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
-
- equals(Object) - Method in class com.hazelcast.security.permission.InstancePermission
-
- equals(Object) - Method in class com.hazelcast.spi.AbstractDistributedObject
-
- equals(Object) - Method in class com.hazelcast.spi.AbstractWaitNotifyKey
-
- equals(Object) - Method in class com.hazelcast.spi.DefaultObjectNamespace
-
Deprecated.
- equals(Object) - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
-
- equals(Object) - Method in class com.hazelcast.spi.impl.eventservice.impl.TrueEventFilter
-
- equals(Object) - Method in class com.hazelcast.spi.impl.merge.AbstractCollectionMergingValueImpl
-
- equals(Object) - Method in class com.hazelcast.spi.impl.merge.AbstractMergingEntryImpl
-
- equals(Object) - Method in class com.hazelcast.spi.impl.merge.AbstractMergingValueImpl
-
- equals(Object) - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
-
- equals(Object) - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
-
- equals(Object) - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
-
- equals(Object) - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
-
- equals(Object) - Method in class com.hazelcast.spi.impl.merge.RingbufferMergingValueImpl
-
- equals(Object) - Method in class com.hazelcast.spi.impl.servicemanager.ServiceInfo
-
- equals(Object) - Method in class com.hazelcast.spi.PartitionMigrationEvent
-
- equals(Object) - Method in class com.hazelcast.transaction.impl.TransactionalObjectKey
-
- equals(Object) - Method in class com.hazelcast.transaction.impl.xa.SerializableXID
-
- equals(Object) - Method in class com.hazelcast.util.collection.IntHashSet
-
- equals(Object) - Method in class com.hazelcast.util.collection.LongHashSet
- equals(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap.SimpleEntry
-
- equals(Object) - Method in class com.hazelcast.util.ItemCounter
-
- equals(Object) - Method in class com.hazelcast.util.MutableLong
-
- equals(Object) - Method in class com.hazelcast.util.SampleableConcurrentHashMap.SamplingEntry
-
- equals(Object) - Method in class com.hazelcast.util.scheduler.ScheduledEntry
-
- equals(Object) - Method in class com.hazelcast.version.MemberVersion
-
- equals(Object) - Method in class com.hazelcast.version.Version
-
- equalsIgnoreCase(String, String) - Static method in class com.hazelcast.util.StringUtil
-
- ERROR - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
-
- ERROR_RESPONSE - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
-
- ErrorCommand - Class in com.hazelcast.internal.ascii.memcache
-
- ErrorCommand(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.internal.ascii.memcache.ErrorCommand
-
- ErrorCommand(TextCommandConstants.TextCommandType, String) - Constructor for class com.hazelcast.internal.ascii.memcache.ErrorCommand
-
- ErrorCommandProcessor - Class in com.hazelcast.internal.ascii.memcache
-
- ErrorCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.internal.ascii.memcache.ErrorCommandProcessor
-
- errorHandler(ChannelErrorHandler) - Method in class com.hazelcast.internal.networking.nio.NioEventLoopGroup.Context
-
- ErrorResponse - Class in com.hazelcast.spi.impl.operationservice.impl.responses
-
- ErrorResponse() - Constructor for class com.hazelcast.spi.impl.operationservice.impl.responses.ErrorResponse
-
- ErrorResponse(Throwable, long, boolean) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.responses.ErrorResponse
-
- escapeMetricNamePart(String) - Static method in class com.hazelcast.internal.metrics.MetricsUtil
-
Escapes a user-supplied string value that is to be used as metrics key
tag or value.
- escapeSpecialCharacters(StringBuilder) - Static method in class com.hazelcast.client.impl.statistics.Statistics
-
- escapeSpecialCharacters(StringBuilder, int) - Static method in class com.hazelcast.client.impl.statistics.Statistics
-
- estimate() - Method in interface com.hazelcast.cardinality.CardinalityEstimator
-
Estimates the cardinality of the aggregation so far.
- estimate() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorContainer
-
- ESTIMATE - Static variable in class com.hazelcast.cardinality.impl.CardinalityEstimatorDataSerializerHook
-
- estimate() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorProxy
-
- estimate() - Method in interface com.hazelcast.cardinality.impl.hyperloglog.HyperLogLog
-
Computes a new estimate for the current status of the registers.
- estimate() - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.DenseHyperLogLogEncoder
-
- estimate() - Method in interface com.hazelcast.cardinality.impl.hyperloglog.impl.HyperLogLogEncoder
-
Computes a new estimate for the current status of the registers.
- estimate() - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.HyperLogLogImpl
-
- estimate() - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.SparseHyperLogLogEncoder
-
- estimate() - Method in class com.hazelcast.client.proxy.ClientCardinalityEstimatorProxy
-
- estimateAsync() - Method in interface com.hazelcast.cardinality.CardinalityEstimator
-
Estimates the cardinality of the aggregation so far.
- estimateAsync() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorProxy
-
- estimateAsync() - Method in class com.hazelcast.client.proxy.ClientCardinalityEstimatorProxy
-
- estimatedSize() - Method in class com.hazelcast.query.impl.AndResultSet
-
- estimatedSize() - Method in class com.hazelcast.query.impl.OrResultSet
-
- EstimateOperation - Class in com.hazelcast.cardinality.impl.operations
-
- EstimateOperation() - Constructor for class com.hazelcast.cardinality.impl.operations.EstimateOperation
-
- EstimateOperation(String) - Constructor for class com.hazelcast.cardinality.impl.operations.EstimateOperation
-
- eval(Object) - Method in class com.hazelcast.cache.impl.CacheEventListenerAdaptor
-
- eval(Object) - Method in class com.hazelcast.cache.impl.event.CachePartitionLostEventFilter
-
- eval(Object) - Method in class com.hazelcast.collection.impl.collection.CollectionEventFilter
-
- eval(Object) - Method in class com.hazelcast.collection.impl.queue.QueueEventFilter
-
- eval(Object) - Method in class com.hazelcast.map.impl.EntryEventFilter
-
- eval(Object) - Method in class com.hazelcast.map.impl.EventListenerFilter
-
- eval(Object) - Method in class com.hazelcast.map.impl.MapPartitionLostEventFilter
-
- eval(Object) - Method in class com.hazelcast.map.impl.nearcache.invalidation.UuidFilter
-
- eval(Object) - Method in class com.hazelcast.map.impl.query.QueryEventFilter
-
- eval(Object) - Method in class com.hazelcast.multimap.impl.MultiMapEventFilter
-
- eval(Object) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedEntryEventFilter
-
- eval(Object) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedQueryEventFilter
-
- eval(Object) - Method in interface com.hazelcast.spi.EventFilter
-
Returns true
if the event
matches this filter.
- eval(Object) - Method in class com.hazelcast.spi.impl.eventservice.impl.TrueEventFilter
-
- evaluate(Iterable<C>) - Method in class com.hazelcast.internal.eviction.impl.evaluator.EvictionPolicyEvaluator
-
Selects the best candidate to be evicted.
- evaluate(Key) - Method in interface com.hazelcast.mapreduce.KeyPredicate
-
Deprecated.
This method evaluates whether or not to select a key.
- evaluateQueryEventFilter(EventFilter, Data, Object, String) - Method in class com.hazelcast.map.impl.event.AbstractFilteringStrategy
-
- EVENT_ENVELOPE - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
-
- EVENT_JOURNAL_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
-
- EVENT_JOURNAL_DESERIALIZING_CACHE_EVENT - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- EVENT_JOURNAL_DESERIALIZING_MAP_EVENT - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- EVENT_JOURNAL_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- EVENT_JOURNAL_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- EVENT_JOURNAL_INITIAL_SUBSCRIBER_STATE - Static variable in class com.hazelcast.internal.journal.EventJournalDataSerializerHook
-
- EVENT_JOURNAL_INTERNAL_CACHE_EVENT - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- EVENT_JOURNAL_INTERNAL_MAP_EVENT - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- EVENT_JOURNAL_READ - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- EVENT_JOURNAL_READ_OPERATION - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- EVENT_JOURNAL_READ_RESULT_SET - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- EVENT_JOURNAL_READ_RESULT_SET - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- EVENT_JOURNAL_SUBSCRIBE_OPERATION - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- EVENT_JOURNAL_SUBSCRIBE_OPERATION - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- EVENT_LISTENER_FILTER - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- EVENT_QUEUE_CAPACITY - Static variable in class com.hazelcast.client.spi.properties.ClientProperty
-
Capacity of the executor that handles the incoming event packets.
- EVENT_QUEUE_CAPACITY - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
- EVENT_QUEUE_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
The timeout for offering an event to the event executor for processing.
- EVENT_SYNC_FREQUENCY_PROP - Static variable in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-
Usually remote events are sent asynchronously.
- EVENT_SYNC_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
To prevent overloading of the outbound connections, once in a while an event is made synchronous by wrapping it in a
fake operation and waiting for a fake response.
- EVENT_THREAD_COUNT - Static variable in class com.hazelcast.client.spi.properties.ClientProperty
-
Number of the threads to handle the incoming event packets.
- EVENT_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
- EVENT_TYPE - Static variable in class com.hazelcast.map.EventLostEvent
-
Event type ID.
- eventCount() - Method in class com.hazelcast.internal.networking.nio.NioThread
-
- EventData - Interface in com.hazelcast.map.impl.event
-
General contract for map event data.
- eventDataExcludingValues() - Method in interface com.hazelcast.map.impl.event.EntryEventDataCache
-
- eventDataIncludingValues() - Method in interface com.hazelcast.map.impl.event.EntryEventDataCache
-
- EventEnvelope - Class in com.hazelcast.spi.impl.eventservice.impl
-
An Envelope around an event object.
- EventEnvelope() - Constructor for class com.hazelcast.spi.impl.eventservice.impl.EventEnvelope
-
- eventFilter - Variable in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidator
-
- EventFilter - Interface in com.hazelcast.spi
-
A predicate that can filter out events.
- EventHandler<E> - Interface in com.hazelcast.client.spi
-
- eventJournal - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-
- EventJournal<E> - Interface in com.hazelcast.internal.journal
-
The event journal is a container for events related to a data structure.
- EventJournalCacheEvent<K,V> - Interface in com.hazelcast.cache.journal
-
The event for the cache event journal.
- eventJournalConfig - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- EventJournalConfig - Class in com.hazelcast.config
-
Configuration for an event journal.
- EventJournalConfig() - Constructor for class com.hazelcast.config.EventJournalConfig
-
- EventJournalConfig(EventJournalConfig) - Constructor for class com.hazelcast.config.EventJournalConfig
-
- eventJournalConfig - Variable in class com.hazelcast.map.impl.MapContainer
-
- EventJournalDataSerializerHook - Class in com.hazelcast.internal.journal
-
Data serializer hook for common classes related to the
EventJournal
.
- EventJournalDataSerializerHook() - Constructor for class com.hazelcast.internal.journal.EventJournalDataSerializerHook
-
- EventJournalInitialSubscriberState - Class in com.hazelcast.internal.journal
-
The response for the event journal subcription.
- EventJournalInitialSubscriberState() - Constructor for class com.hazelcast.internal.journal.EventJournalInitialSubscriberState
-
- EventJournalInitialSubscriberState(long, long) - Constructor for class com.hazelcast.internal.journal.EventJournalInitialSubscriberState
-
- EventJournalMapEvent<K,V> - Interface in com.hazelcast.map.journal
-
The event for the map event journal.
- EventJournalReader<E> - Interface in com.hazelcast.internal.journal
-
This interface provides methods to subscribe and read from an event journal.
- EventJournalReadOperation<T,J> - Class in com.hazelcast.internal.journal
-
Reads from the map event journal in batches.
- EventJournalReadOperation() - Constructor for class com.hazelcast.internal.journal.EventJournalReadOperation
-
- EventJournalReadOperation(String, long, int, int) - Constructor for class com.hazelcast.internal.journal.EventJournalReadOperation
-
- EventListenerFilter - Class in com.hazelcast.map.impl
-
Event filter matching events of specified types.
- EventListenerFilter() - Constructor for class com.hazelcast.map.impl.EventListenerFilter
-
- EventListenerFilter(int, EventFilter) - Constructor for class com.hazelcast.map.impl.EventListenerFilter
-
- EventLoopGroup - Interface in com.hazelcast.internal.networking
-
The EventLoopGroup is responsible for processing registered channels.
- eventLost(EventLostEvent) - Method in interface com.hazelcast.map.listener.EventLostListener
-
Invoked upon lost of event or events.
- EventLostEvent - Class in com.hazelcast.map
-
This event is fired in case of an event lost detection.
- EventLostEvent(String, Member, int) - Constructor for class com.hazelcast.map.EventLostEvent
-
- EventLostListener - Interface in com.hazelcast.map.listener
-
Invoked upon lost of event or events.
- EventProcessor - Class in com.hazelcast.spi.impl.eventservice.impl
-
An event processor responsible of fetching the registration and service responsible for the published event
and processing it.
- EventProcessor(EventServiceImpl, EventEnvelope, int) - Constructor for class com.hazelcast.spi.impl.eventservice.impl.EventProcessor
-
- EventPublisherAccumulatorProcessor - Class in com.hazelcast.map.impl.querycache.publisher
-
Publish events which will be received by subscriber sides.
- EventPublisherAccumulatorProcessor(QueryCacheEventService) - Constructor for class com.hazelcast.map.impl.querycache.publisher.EventPublisherAccumulatorProcessor
-
- EventPublisherAccumulatorProcessor(AccumulatorInfo, QueryCacheEventService) - Constructor for class com.hazelcast.map.impl.querycache.publisher.EventPublisherAccumulatorProcessor
-
- EventPublisherHelper - Class in com.hazelcast.map.impl.querycache.subscriber
-
Helper class for publishing events to QueryCache
listeners.
- eventPublishingService - Variable in class com.hazelcast.map.impl.MapService
-
- EventPublishingService<E,T> - Interface in com.hazelcast.spi
-
A service for publishing events.
- eventQueueCapacity - Variable in class com.hazelcast.internal.management.dto.EventServiceDTO
-
- EventQueuePlugin - Class in com.hazelcast.internal.diagnostics
-
The EventQueuePlugin checks the event queue and samples the event types if the size is above a certain threshold.
- EventQueuePlugin(NodeEngineImpl, StripedExecutor) - Constructor for class com.hazelcast.internal.diagnostics.EventQueuePlugin
-
- EventQueuePlugin(ILogger, StripedExecutor, HazelcastProperties) - Constructor for class com.hazelcast.internal.diagnostics.EventQueuePlugin
-
- eventQueueSize - Variable in class com.hazelcast.internal.management.dto.EventServiceDTO
-
- EventRegistration - Interface in com.hazelcast.spi
-
The result of a Event Registration.
- eventsBatchingEnabled - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- eventsEnabled - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- eventService - Variable in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidator
-
- eventService - Variable in class com.hazelcast.map.impl.event.MapEventPublisherImpl
-
- eventService - Variable in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-
- EventService - Interface in com.hazelcast.spi
-
Component responsible for handling events like topic events or map.listener events.
- EventServiceDTO - Class in com.hazelcast.internal.management.dto
-
- EventServiceDTO() - Constructor for class com.hazelcast.internal.management.dto.EventServiceDTO
-
- EventServiceDTO(EventService) - Constructor for class com.hazelcast.internal.management.dto.EventServiceDTO
-
- EventServiceImpl - Class in com.hazelcast.spi.impl.eventservice.impl
-
Service responsible for routing and dispatching local and remote events and keeping track of listener
registrations.
- EventServiceImpl(NodeEngineImpl) - Constructor for class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-
- EventServiceMBean - Class in com.hazelcast.internal.jmx
-
- EventServiceMBean(HazelcastInstance, EventService, ManagementService) - Constructor for class com.hazelcast.internal.jmx.EventServiceMBean
-
- EventServiceSegment<S> - Class in com.hazelcast.spi.impl.eventservice.impl
-
Segment of the event service.
- EventServiceSegment(String, S) - Constructor for class com.hazelcast.spi.impl.eventservice.impl.EventServiceSegment
-
- eventThreadCount - Variable in class com.hazelcast.internal.management.dto.EventServiceDTO
-
- eventType - Variable in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
-
- eventType - Variable in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
-
- eventType - Variable in class com.hazelcast.map.impl.operation.BasePutOperation
-
- evict(K) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- evict(K) - Method in interface com.hazelcast.core.IMap
-
Evicts the specified key from this map.
- evict(K) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
-
- evict(K) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
-
- evict(K) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
-
- evict(K) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
-
- evict(K) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
-
- evict(S, EvictionPolicyEvaluator<A, E>, EvictionChecker, EvictionListener<A, E>) - Method in class com.hazelcast.internal.eviction.impl.strategy.sampling.SamplingEvictionStrategy
-
Does eviction if required.
- evict(RecordStore, Data) - Method in interface com.hazelcast.map.impl.eviction.Evictor
-
Evict supplied record-store.
- evict(RecordStore, Data) - Method in class com.hazelcast.map.impl.eviction.EvictorImpl
-
- EVICT - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- evict(Data) - Method in class com.hazelcast.map.impl.operation.MapOperation
-
- evict(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- evict(Data, boolean) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- evict(Data, boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
- evict(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- evict(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- evict(Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
-
- EVICT_ALL - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- EVICT_ALL_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- EVICT_ALL_FACTORY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- EVICT_ALWAYS - Static variable in interface com.hazelcast.internal.eviction.EvictionChecker
-
- EVICT_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- EVICT_BATCH_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- Evictable<V> - Interface in com.hazelcast.internal.eviction
-
Interface for entries, records or whatever that can be evicted.
- EvictableEntryView<K,V> - Interface in com.hazelcast.internal.eviction
-
Contract point (from the end user perspective) for serving/accessing entries that can be evicted.
- EvictableStore<A,E extends Evictable> - Interface in com.hazelcast.internal.eviction
-
Interface for store implementations that holds
Evictable
entries to evict.
- evictAll() - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- evictAll() - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-
- evictAll() - Method in interface com.hazelcast.core.IMap
-
Evicts all keys from this map except the locked ones.
- evictAll() - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
-
- evictAll() - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
-
- evictAll() - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
-
- evictAll() - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
-
- evictAll() - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
-
- evictAll() - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- evictAll(boolean) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- evictAll(boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
Evicts all keys except locked ones.
- EvictAllBackupOperation - Class in com.hazelcast.map.impl.operation
-
Operation which evicts all keys except locked ones.
- EvictAllBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.EvictAllBackupOperation
-
- EvictAllBackupOperation(String) - Constructor for class com.hazelcast.map.impl.operation.EvictAllBackupOperation
-
- evictAllInternal() - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-
- EvictAllOperation - Class in com.hazelcast.map.impl.operation
-
Operation which evicts all keys except locked ones.
- EvictAllOperation() - Constructor for class com.hazelcast.map.impl.operation.EvictAllOperation
-
- EvictAllOperation(String) - Constructor for class com.hazelcast.map.impl.operation.EvictAllOperation
-
- EvictAllOperationFactory - Class in com.hazelcast.map.impl.operation
-
Operation factory for evict all operations.
- EvictAllOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.EvictAllOperationFactory
-
- EvictAllOperationFactory(String) - Constructor for class com.hazelcast.map.impl.operation.EvictAllOperationFactory
-
- EvictBackupOperation - Class in com.hazelcast.map.impl.operation
-
- EvictBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.EvictBackupOperation
-
- EvictBackupOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.EvictBackupOperation
-
- EvictBackupOperation(String, Data, boolean) - Constructor for class com.hazelcast.map.impl.operation.EvictBackupOperation
-
- EvictBackupOperation(String, Data, boolean, boolean) - Constructor for class com.hazelcast.map.impl.operation.EvictBackupOperation
-
- EvictBatchBackupOperation - Class in com.hazelcast.map.impl.operation
-
Used to transfer expired keys from owner replica to backup replicas.
- EvictBatchBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.EvictBatchBackupOperation
-
- EvictBatchBackupOperation(String, Collection<ExpiredKey>, int) - Constructor for class com.hazelcast.map.impl.operation.EvictBatchBackupOperation
-
- evictEntries(Data) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
Evicts entries from this record-store.
- evictExpiredEntries(int, boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
Do expiration operations.
- evictIfRequired() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- evictIfRequired() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Evict cache record store if eviction is required.
- evictInternal(Object) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- evictInternal(Object) - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-
- evictInternal(S, EvictionPolicyEvaluator<A, E>, EvictionListener<A, E>) - Method in class com.hazelcast.internal.eviction.impl.strategy.sampling.SamplingEvictionStrategy
-
- evictInternal(Object) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-
- EVICTION - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
-
- EvictionCandidate<A,E extends Evictable> - Interface in com.hazelcast.internal.eviction
-
Interface for entries, records or whatever that can be evictable via its accessor (key or ID).
- evictionChecker - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- EvictionChecker - Interface in com.hazelcast.internal.eviction
-
Checks whether a specific max size threshold is exceeded or not
according to configured
MaxSizeConfig.MaxSizePolicy
and indicates whether eviction is required.
- evictionChecker - Variable in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
-
- EvictionChecker - Class in com.hazelcast.map.impl.eviction
-
- EvictionChecker(MemoryInfoAccessor, MapServiceContext) - Constructor for class com.hazelcast.map.impl.eviction.EvictionChecker
-
- evictionChecker - Variable in class com.hazelcast.map.impl.eviction.EvictorImpl
-
- evictionCheckers - Variable in class com.hazelcast.internal.eviction.CompositeEvictionChecker
-
- evictionConfig - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- EvictionConfig - Class in com.hazelcast.config
-
Configuration for eviction.
- EvictionConfig() - Constructor for class com.hazelcast.config.EvictionConfig
-
- EvictionConfig(int, EvictionConfig.MaxSizePolicy, EvictionPolicy) - Constructor for class com.hazelcast.config.EvictionConfig
-
- EvictionConfig(int, EvictionConfig.MaxSizePolicy, String) - Constructor for class com.hazelcast.config.EvictionConfig
-
- EvictionConfig(int, EvictionConfig.MaxSizePolicy, EvictionPolicyComparator) - Constructor for class com.hazelcast.config.EvictionConfig
-
- EvictionConfig(EvictionConfig) - Constructor for class com.hazelcast.config.EvictionConfig
-
- EvictionConfig.MaxSizePolicy - Enum in com.hazelcast.config
-
Maximum Size Policy
- EvictionConfigHolder - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
-
- EvictionConfigHolder(int, String, String, String, Data) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.EvictionConfigHolder
-
- EvictionConfigReadOnly - Class in com.hazelcast.config
-
- EvictionConfigReadOnly(EvictionConfig) - Constructor for class com.hazelcast.config.EvictionConfigReadOnly
-
Deprecated.
- EvictionConfiguration - Interface in com.hazelcast.internal.eviction
-
Interface for configuration information about eviction.
- evictionDisabled - Variable in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
-
- EvictionListener<A,E extends Evictable> - Interface in com.hazelcast.internal.eviction
-
Interface for entries, records or whatever that can be evicted via its accessor (key or ID).
- EvictionOperation - Class in com.hazelcast.replicatedmap.impl.operation
-
Evicts set of entries from the record store.
- EvictionOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.EvictionOperation
-
- EvictionOperation(ReplicatedRecordStore, Collection<ScheduledEntry<Object, Object>>) - Constructor for class com.hazelcast.replicatedmap.impl.operation.EvictionOperation
-
- evictionPolicy - Variable in class com.hazelcast.config.EvictionConfig
-
- EvictionPolicy - Enum in com.hazelcast.config
-
Eviction Policy enum.
- EvictionPolicyComparator<K,V,E extends EvictableEntryView<K,V>> - Class in com.hazelcast.internal.eviction
-
A kind of
Comparator
to be used while comparing
entries to be evicted.
- EvictionPolicyComparator() - Constructor for class com.hazelcast.internal.eviction.EvictionPolicyComparator
-
- evictionPolicyEvaluator - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- EvictionPolicyEvaluator<A,E extends Evictable> - Class in com.hazelcast.internal.eviction.impl.evaluator
-
- EvictionPolicyEvaluator(EvictionPolicyComparator) - Constructor for class com.hazelcast.internal.eviction.impl.evaluator.EvictionPolicyEvaluator
-
- evictionPolicyEvaluator - Variable in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
-
- EvictionPolicyEvaluatorProvider - Class in com.hazelcast.internal.eviction
-
- EvictionPolicyType - Enum in com.hazelcast.internal.eviction
-
- EVICTIONS - Static variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- evictions - Variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- evictionStrategy - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- evictionStrategy - Variable in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
-
- EvictionStrategyType - Enum in com.hazelcast.internal.eviction
-
Enum for Eviction Strategy types
- EvictOperation - Class in com.hazelcast.map.impl.operation
-
- EvictOperation(String, Data, boolean) - Constructor for class com.hazelcast.map.impl.operation.EvictOperation
-
- EvictOperation() - Constructor for class com.hazelcast.map.impl.operation.EvictOperation
-
- Evictor - Interface in com.hazelcast.map.impl.eviction
-
- evictor - Variable in class com.hazelcast.map.impl.MapContainer
-
- EvictorImpl - Class in com.hazelcast.map.impl.eviction
-
Evictor helper methods.
- EvictorImpl(MapEvictionPolicy, EvictionChecker, IPartitionService) - Constructor for class com.hazelcast.map.impl.eviction.EvictorImpl
-
- evictRecords(Collection<Record>) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- ExceptionAction - Enum in com.hazelcast.spi
-
The possible actions that can be taken when a certain exception is thrown.
- ExceptionUtil - Class in com.hazelcast.util
-
Contains various exception related utility methods.
- ExceptionUtil.RuntimeExceptionFactory - Interface in com.hazelcast.util
-
Interface used by rethrow/peel to wrap the peeled exception
- execute(Runnable) - Method in class com.hazelcast.client.impl.protocol.task.AbstractAddressMessageTask
-
- execute(Runnable) - Method in class com.hazelcast.client.impl.protocol.task.AbstractPartitionMessageTask
-
- execute(Runnable) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheScheduler
-
- execute(Runnable) - Method in class com.hazelcast.client.proxy.ClientDurableExecutorServiceProxy
-
- execute(Runnable) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-
- execute(Runnable, MemberSelector) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-
- execute(Runnable) - Method in class com.hazelcast.client.spi.impl.ClientExecutionServiceImpl
-
- execute(Runnable, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
-
Executes a task on a randomly selected member.
- execute(Callable) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorContainer
-
- execute(Runnable) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
-
- execute(String, String, Callable, Operation) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
-
- execute(Runnable, MemberSelector) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- execute(Runnable) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- execute(Aggregator, Collection<QueryableEntry>, Collection<Integer>) - Method in interface com.hazelcast.map.impl.query.AccumulationExecutor
-
- execute(Aggregator, Collection<QueryableEntry>, Collection<Integer>) - Method in class com.hazelcast.map.impl.query.CallerRunsAccumulationExecutor
-
- execute(String, Predicate, Collection<Integer>, Result) - Method in class com.hazelcast.map.impl.query.CallerRunsPartitionScanExecutor
-
- execute(String, Predicate, int, int, int) - Method in class com.hazelcast.map.impl.query.CallerRunsPartitionScanExecutor
-
- execute(Query, Target) - Method in interface com.hazelcast.map.impl.query.MapQueryEngine
-
Executes the given query on the given target.
- execute(Query, Target) - Method in class com.hazelcast.map.impl.query.MapQueryEngineImpl
-
- execute(Aggregator, Collection<QueryableEntry>, Collection<Integer>) - Method in class com.hazelcast.map.impl.query.ParallelAccumulationExecutor
-
- execute(String, Predicate, Collection<Integer>, Result) - Method in class com.hazelcast.map.impl.query.ParallelPartitionScanExecutor
-
- execute(String, Predicate, int, int, int) - Method in class com.hazelcast.map.impl.query.ParallelPartitionScanExecutor
-
Executes the predicate on a partition chunk.
- execute(String, Predicate, Collection<Integer>, Result) - Method in interface com.hazelcast.map.impl.query.PartitionScanExecutor
-
- execute(String, Predicate, int, int, int) - Method in interface com.hazelcast.map.impl.query.PartitionScanExecutor
-
Executes the predicate on a partition chunk.
- execute(Runnable) - Method in interface com.hazelcast.map.impl.querycache.QueryCacheScheduler
-
Executes a task.
- execute(Runnable) - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeQueryCacheScheduler
-
- execute(String, Runnable) - Method in interface com.hazelcast.spi.ExecutionService
-
- execute(Runnable) - Method in class com.hazelcast.spi.impl.executionservice.impl.DelegatingTaskScheduler
-
- execute(String, Runnable) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
-
- execute(Operation) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
-
- execute(PartitionSpecificRunnable) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
-
- execute(Operation) - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
-
Executes the given
Operation
at some point in the future.
- execute(PartitionSpecificRunnable) - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
-
- execute(PartitionSpecificRunnable) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-
- execute(Operation) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-
- execute(PartitionSpecificRunnable) - Method in interface com.hazelcast.spi.impl.operationservice.InternalOperationService
-
Executes a PartitionSpecificRunnable.
- execute(Operation) - Method in interface com.hazelcast.spi.OperationService
-
Executes an operation in the operation executor pool.
- execute(TransactionalTaskContext) - Method in interface com.hazelcast.transaction.TransactionalTask
-
Executes the transactional logic.
- execute(Runnable) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-
- execute(Runnable) - Method in class com.hazelcast.util.executor.StripedExecutor
-
- executeAll() - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorPartitionContainer
-
- executeAsync(Runnable) - Method in interface com.hazelcast.nio.IOService
-
- executeAsync(Runnable) - Method in class com.hazelcast.nio.NodeIOService
-
- executedLocally() - Method in class com.hazelcast.spi.Operation
-
Returns true
if local member is the caller.
- executedOperationCount - Variable in class com.hazelcast.internal.management.dto.OperationServiceDTO
-
- executedOperationsCount() - Method in class com.hazelcast.spi.impl.operationexecutor.OperationRunner
-
- executeDurable(String, Runnable) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
-
- executeDurable(String, Runnable) - Method in interface com.hazelcast.spi.impl.executionservice.InternalExecutionService
-
- executeEventCallback(Runnable) - Method in interface com.hazelcast.spi.EventService
-
Executes an event callback on a random event thread.
- executeEventCallback(Runnable) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-
Executes an event callback on a random event thread.
- executeLocallyWithRetry(NodeEngine, Operation) - Static method in class com.hazelcast.internal.util.InvocationUtil
-
Constructs a local execution with retry logic.
- executeMappingPhase(KeyValueSource<KeyIn, ValueIn>, Mapper<KeyIn, ValueIn, KeyOut, ValueOut>, Context<KeyOut, ValueOut>) - Method in class com.hazelcast.mapreduce.impl.task.KeyValueSourceMappingPhase
-
- executeMappingPhase(KeyValueSource<KeyIn, ValueIn>, Mapper<KeyIn, ValueIn, KeyOut, ValueOut>, Context<KeyOut, ValueOut>) - Method in class com.hazelcast.mapreduce.impl.task.MappingPhase
-
- executeOnAllMembers(Runnable) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-
- executeOnAllMembers(Runnable) - Method in interface com.hazelcast.core.IExecutorService
-
Executes a task on all of the known cluster members.
- executeOnAllMembers(Runnable) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- executeOnEntries(EntryProcessor) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- executeOnEntries(EntryProcessor, Predicate) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- executeOnEntries(EntryProcessor) - Method in interface com.hazelcast.core.IMap
-
Applies the user defined
EntryProcessor
to the all entries in the map.
- executeOnEntries(EntryProcessor, Predicate) - Method in interface com.hazelcast.core.IMap
-
Applies the user defined
EntryProcessor
to the entries in the map which satisfy provided predicate.
- executeOnEntries(EntryProcessor) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
-
- executeOnEntries(EntryProcessor, Predicate) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
-
- executeOnEntries(EntryProcessor) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
-
- executeOnEntries(EntryProcessor, Predicate) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
-
- executeOnEntries(EntryProcessor) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
-
- executeOnEntries(EntryProcessor, Predicate) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
-
- executeOnEntries(EntryProcessor) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
-
- executeOnEntries(EntryProcessor, Predicate) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
-
- executeOnEntries(EntryProcessor) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
-
- executeOnEntries(EntryProcessor, Predicate) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
-
- executeOnEntries(EntryProcessor) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- executeOnEntries(EntryProcessor, Predicate) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- executeOnEntriesInternal(EntryProcessor, Predicate, List<Data>) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-
- executeOnKey(K, EntryProcessor) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- executeOnKey(K, EntryProcessor) - Method in interface com.hazelcast.core.IMap
-
Applies the user defined EntryProcessor
to the entry mapped by the key
.
- executeOnKey(K, EntryProcessor) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
-
- executeOnKey(K, EntryProcessor) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
-
- executeOnKey(K, EntryProcessor) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
-
- executeOnKey(K, EntryProcessor) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
-
- executeOnKey(K, EntryProcessor) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
-
- executeOnKey(K, EntryProcessor) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- executeOnKeyInternal(Object, EntryProcessor) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- executeOnKeyInternal(Object, EntryProcessor) - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-
- executeOnKeyInternal(Object, EntryProcessor) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-
- executeOnKeyInternal(Object, EntryProcessor, ExecutionCallback<Object>) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-
- executeOnKeyOwner(Runnable, Object) - Method in class com.hazelcast.client.proxy.ClientDurableExecutorServiceProxy
-
- executeOnKeyOwner(Runnable, Object) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-
- executeOnKeyOwner(Runnable, Object) - Method in interface com.hazelcast.core.IExecutorService
-
Executes a task on the owner of the specified key.
- executeOnKeyOwner(Runnable, Object) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
-
Executes a task on the owner of the specified key.
- executeOnKeyOwner(Runnable, Object) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
-
- executeOnKeyOwner(Runnable, Object) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- executeOnKeys(Set<K>, EntryProcessor) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- executeOnKeys(Set<K>, EntryProcessor) - Method in interface com.hazelcast.core.IMap
-
Applies the user defined
EntryProcessor
to the entries mapped by the collection of keys.
- executeOnKeys(Set<K>, EntryProcessor) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
-
- executeOnKeys(Set<K>, EntryProcessor) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
-
- executeOnKeys(Set<K>, EntryProcessor) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
-
- executeOnKeys(Set<K>, EntryProcessor) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
-
- executeOnKeys(Set<K>, EntryProcessor) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
-
- executeOnKeys(Set<K>, EntryProcessor) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- executeOnKeysInternal(Set<K>, Set<Data>, EntryProcessor) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-
- executeOnMember(Runnable, Member) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-
- executeOnMember(Runnable, Member) - Method in interface com.hazelcast.core.IExecutorService
-
Executes a task on the specified member.
- executeOnMember(Runnable, Member) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- executeOnMembers(Runnable, Collection<Member>) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-
- executeOnMembers(Runnable, MemberSelector) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-
- executeOnMembers(Runnable, Collection<Member>) - Method in interface com.hazelcast.core.IExecutorService
-
Executes a task on each of the specified members.
- executeOnMembers(Runnable, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
-
Executes a task on each of the selected members.
- executeOnMembers(Runnable, MemberSelector) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- executeOnMembers(Runnable, Collection<Member>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- executeOnPartitionThreads(Runnable) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
-
- executeOnPartitionThreads(Runnable) - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
-
Executes the task on every partition thread.
- executeOperation(Operation) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientInvokerWrapper
-
- executeOperation(Operation) - Method in interface com.hazelcast.map.impl.querycache.InvokerWrapper
-
- executeOperation(Operation) - Method in class com.hazelcast.map.impl.querycache.NodeInvokerWrapper
-
- executeOperation(Collection<Member>, OperationFactory, MapReduceService, NodeEngine) - Static method in class com.hazelcast.mapreduce.impl.MapReduceUtil
-
- executeOperation(Operation, Address, MapReduceService, NodeEngine) - Static method in class com.hazelcast.mapreduce.impl.MapReduceUtil
-
- executeRun() - Method in class com.hazelcast.util.executor.HazelcastManagedThread
-
Does the actual run and can be overridden to customize.
- ExecuteScriptRequest - Class in com.hazelcast.internal.management.request
-
Request for executing scripts on the nodes from Management Center.
- ExecuteScriptRequest() - Constructor for class com.hazelcast.internal.management.request.ExecuteScriptRequest
-
- ExecuteScriptRequest(String, String, Set<String>) - Constructor for class com.hazelcast.internal.management.request.ExecuteScriptRequest
-
- executeTransaction(TransactionalTask<T>) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- executeTransaction(TransactionalTask<T>) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-
- executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-
- executeTransaction(TransactionalTask<T>) - Method in interface com.hazelcast.client.spi.ClientTransactionManagerService
-
- executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in interface com.hazelcast.client.spi.ClientTransactionManagerService
-
- executeTransaction(TransactionalTask<T>) - Method in class com.hazelcast.client.spi.impl.ClientTransactionManagerServiceImpl
-
- executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in class com.hazelcast.client.spi.impl.ClientTransactionManagerServiceImpl
-
- executeTransaction(TransactionalTask<T>) - Method in interface com.hazelcast.core.HazelcastInstance
-
Executes the given transactional task in current thread using default options
and returns the result of the task.
- executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in interface com.hazelcast.core.HazelcastInstance
-
Executes the given transactional task in current thread using given options
and returns the result of the task.
- executeTransaction(TransactionalTask<T>) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- executeTransaction(TransactionalTask<T>) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-
- executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in interface com.hazelcast.transaction.TransactionManagerService
-
- executeWithDelay() - Method in class com.hazelcast.util.scheduler.CoalescingDelayedTrigger
-
invoke delayed execution.
- EXECUTION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- ExecutionCallback<V> - Interface in com.hazelcast.core
-
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
- executionCallback - Variable in class com.hazelcast.spi.InvocationBuilder
-
- ExecutionExceptionDecorator(Throwable) - Constructor for exception com.hazelcast.scheduledexecutor.impl.ScheduledTaskResult.ExecutionExceptionDecorator
-
- ExecutionService - Interface in com.hazelcast.spi
-
A Service responsible for providing access to 'system' executors and customer executors.
- ExecutionServiceImpl - Class in com.hazelcast.spi.impl.executionservice.impl
-
- ExecutionServiceImpl(NodeEngineImpl) - Constructor for class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
-
- EXECUTOR_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
-
- EXECUTOR_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- EXECUTOR_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- EXECUTOR_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- EXECUTOR_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- ExecutorConfig - Class in com.hazelcast.config
-
- ExecutorConfig() - Constructor for class com.hazelcast.config.ExecutorConfig
-
- ExecutorConfig(String) - Constructor for class com.hazelcast.config.ExecutorConfig
-
- ExecutorConfig(String, int) - Constructor for class com.hazelcast.config.ExecutorConfig
-
- ExecutorConfig(ExecutorConfig) - Constructor for class com.hazelcast.config.ExecutorConfig
-
- ExecutorConfigReadOnly - Class in com.hazelcast.config
-
- ExecutorConfigReadOnly(ExecutorConfig) - Constructor for class com.hazelcast.config.ExecutorConfigReadOnly
-
Deprecated.
- ExecutorDataSerializerHook - Class in com.hazelcast.executor.impl
-
- ExecutorDataSerializerHook() - Constructor for class com.hazelcast.executor.impl.ExecutorDataSerializerHook
-
- executorService - Variable in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-
- ExecutorServiceCancelOnAddressMessageTask - Class in com.hazelcast.client.impl.protocol.task.executorservice
-
- ExecutorServiceCancelOnAddressMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnAddressMessageTask
-
- ExecutorServiceCancelOnPartitionMessageTask - Class in com.hazelcast.client.impl.protocol.task.executorservice
-
- ExecutorServiceCancelOnPartitionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnPartitionMessageTask
-
- ExecutorServiceIsShutdownMessageTask - Class in com.hazelcast.client.impl.protocol.task.executorservice
-
- ExecutorServiceIsShutdownMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceIsShutdownMessageTask
-
- ExecutorServiceMBean - Class in com.hazelcast.internal.jmx
-
- ExecutorServiceMBean(IExecutorService, ManagementService) - Constructor for class com.hazelcast.internal.jmx.ExecutorServiceMBean
-
- ExecutorServicePermission - Class in com.hazelcast.security.permission
-
- ExecutorServicePermission(String, String...) - Constructor for class com.hazelcast.security.permission.ExecutorServicePermission
-
- ExecutorServiceProxy - Class in com.hazelcast.executor.impl
-
- ExecutorServiceProxy(String, NodeEngine, DistributedExecutorService) - Constructor for class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- ExecutorServiceShutdownMessageTask - Class in com.hazelcast.client.impl.protocol.task.executorservice
-
- ExecutorServiceShutdownMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceShutdownMessageTask
-
- ExecutorServiceSubmitToAddressMessageTask - Class in com.hazelcast.client.impl.protocol.task.executorservice
-
- ExecutorServiceSubmitToAddressMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToAddressMessageTask
-
- ExecutorServiceSubmitToPartitionMessageTask - Class in com.hazelcast.client.impl.protocol.task.executorservice
-
- ExecutorServiceSubmitToPartitionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToPartitionMessageTask
-
- ExecutorType - Enum in com.hazelcast.util.executor
-
- existInMemory(Data) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- existInMemory(Data) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
Checks if the key exist in memory without trying to load data from map-loader
- exists() - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-
- EXPAND_THRESHOLD_OFFSET - Static variable in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
-
- expansionThreshold() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray
-
Array expansion and rehashing will be triggered when size
reaches this value.
- expansionThreshold() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
-
- Expirable - Interface in com.hazelcast.internal.eviction
-
Expiring Data model interface.
- EXPIRATION_TIME - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
-
- ExpirationChecker<E extends Expirable> - Interface in com.hazelcast.internal.eviction
-
Interface for entries, records or whatever that can be checked for expiration.
- ExpirationManager - Class in com.hazelcast.map.impl.eviction
-
This class is responsible for gradual cleanup of expired entries.
- ExpirationManager(PartitionContainer[], NodeEngine) - Constructor for class com.hazelcast.map.impl.eviction.ExpirationManager
-
- expirationTaskFuture - Variable in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
-
- expirationTime - Variable in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-
- expirationTime - Variable in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
-
- expirationTime - Variable in class com.hazelcast.map.impl.record.RecordInfo
-
- ExpirationTimeMergePolicy<V,T extends MergingExpirationTime<V>> - Class in com.hazelcast.spi.merge
-
Merges data structure entries from source to destination data structure if the source entry
will expire later than the destination entry.
- ExpirationTimeMergePolicy() - Constructor for class com.hazelcast.spi.merge.ExpirationTimeMergePolicy
-
- ExpirationTimeSetter - Class in com.hazelcast.map.impl
-
Utility methods for setting TTL and max idle seconds.
- ExpiredKey - Class in com.hazelcast.map.impl.recordstore
-
Holds expired key and related metadata.
- ExpiredKey(Data, long) - Constructor for class com.hazelcast.map.impl.recordstore.ExpiredKey
-
- EXPIRIES - Static variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- expiries - Variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- EXPIRY_POLICY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- expiryPolicy - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-
- expiryPolicyFactory - Variable in class com.hazelcast.config.AbstractCacheConfig
-
The Factory
for the ExpiryPolicy
.
- ExpiryPolicyFactoryConfig() - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
-
- ExpiryPolicyFactoryConfig(String) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
-
- ExpiryPolicyFactoryConfig(CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
-
- EXPLICIT_SUSPICION - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
-
- ExplicitSuspicionOp - Class in com.hazelcast.internal.cluster.impl.operations
-
An operation which is sent by a member that wants to be explicitly suspected by the target.
- ExplicitSuspicionOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.ExplicitSuspicionOp
-
- ExplicitSuspicionOp(MembersViewMetadata) - Constructor for class com.hazelcast.internal.cluster.impl.operations.ExplicitSuspicionOp
-
- expression - Variable in class com.hazelcast.query.impl.predicates.LikePredicate
-
- extendLeaseTime(Data, String, long, long) - Method in interface com.hazelcast.concurrent.lock.LockStore
-
Extend the lease time for an already locked key.
- extendLeaseTime(Data, String, long, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- extendLeaseTime(Data, String, long, long) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
-
- extendLock(Data, String, long, long) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- extendLock(Data, String, long, long) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
- extendLock(Data, String, long, long) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- ExternalizableSerializer(boolean, ClassNameFilter) - Constructor for class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.ExternalizableSerializer
-
- extract(ValueIn) - Method in interface com.hazelcast.mapreduce.aggregation.PropertyExtractor
-
Deprecated.
This method is called for every value that is about to be supplied to
an aggregation (maybe filtered through an
Predicate
or
KeyPredicate
).
- extract(T, A, ValueCollector) - Method in class com.hazelcast.query.extractor.ValueExtractor
-
Extracts a value from the given target object.
- extract(InternalSerializationService, Object, String) - Method in class com.hazelcast.query.impl.getters.Extractors
-
- Extractable - Interface in com.hazelcast.query.impl
-
Enables extracting attribute values and types and their type from an object, usually from an Entry
- extractAndAppendResult(Collection<AccumulatedResults>, QueryResult) - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapQueryMessageTask
-
- extractAndAppendResult(Collection<AggregationResult>, AggregationResult) - Method in class com.hazelcast.client.impl.protocol.task.map.DefaultMapAggregateMessageTask
-
- extractAndAppendResult(Collection<QueryResult>, QueryResult) - Method in class com.hazelcast.client.impl.protocol.task.map.DefaultMapProjectMessageTask
-
- extractAndAppendResult(Collection<QueryResultRow>, QueryResult) - Method in class com.hazelcast.client.impl.protocol.task.map.DefaultMapQueryMessageTask
-
- extractAndPopulateResult(InternalCompletableFuture, MetaDataFetcher.ResultHolder) - Method in class com.hazelcast.client.cache.impl.nearcache.invalidation.ClientCacheMetaDataFetcher
-
- extractAndPopulateResult(InternalCompletableFuture, MetaDataFetcher.ResultHolder) - Method in class com.hazelcast.client.map.impl.nearcache.invalidation.ClientMapMetaDataFetcher
-
- extractAndPopulateResult(InternalCompletableFuture, MetaDataFetcher.ResultHolder) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataFetcher
-
- extractAndPopulateResult(InternalCompletableFuture, MetaDataFetcher.ResultHolder) - Method in class com.hazelcast.map.impl.nearcache.invalidation.MemberMapMetaDataFetcher
-
- extractArgumentsFromAttributeName(String) - Static method in class com.hazelcast.query.impl.getters.ExtractorHelper
-
- extractAttributeNameNameWithoutArguments(String) - Static method in class com.hazelcast.query.impl.getters.ExtractorHelper
-
- extractFrom(Object) - Method in class com.hazelcast.query.impl.getters.AbstractMultiValueGetter
-
- extractFrom(Object) - Method in class com.hazelcast.query.impl.getters.FieldGetter
-
- extractInt(long, boolean) - Static method in class com.hazelcast.nio.Bits
-
- ExtractorHelper - Class in com.hazelcast.query.impl.getters
-
- extractors - Variable in class com.hazelcast.map.impl.MapContainer
-
- Extractors - Class in com.hazelcast.query.impl.getters
-
- Extractors(List<MapAttributeConfig>, ClassLoader) - Constructor for class com.hazelcast.query.impl.getters.Extractors
-
- extractors - Variable in class com.hazelcast.query.impl.QueryableEntry
-
- extractPartitionAware(OperationFactory) - Static method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionAwareFactoryAccessor
-
- extractShort(int, boolean) - Static method in class com.hazelcast.nio.Bits
-
- extractValue(Object, String) - Static method in class com.hazelcast.query.impl.getters.ReflectionHelper
-
- GarbageCollectionMetricSet - Class in com.hazelcast.internal.metrics.metricsets
-
- GarbageCollectorStats - Interface in com.hazelcast.memory
-
Garbage collector statistics for the JVM which current HazelcastInstance
belongs to.
- Gauge - Interface in com.hazelcast.internal.metrics
-
A Gauge is
Metric
where a particular value is read instantaneous.
- GCStatsSupport - Class in com.hazelcast.memory
-
Used to gather garbage collection statistics.
- generate(Config) - Method in class com.hazelcast.config.ConfigXmlGenerator
-
Generates the XML string based on some Config.
- GeneratedBuildProperties - Class in com.hazelcast.instance
-
This class is generated in a build-time from a template stored at
src/main/template/com/hazelcast/instance/GeneratedBuildProperties.
- generateInterceptorId(String, MapInterceptor) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
-
- generateListenerName(String, String) - Static method in class com.hazelcast.map.impl.querycache.ListenerRegistrationHelper
-
- GENERIC_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
-
- GENERIC_OPERATION_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
The number of generic operation handler threads per member.
- GENERIC_PARTITION_ID - Static variable in class com.hazelcast.spi.Operation
-
Marks an
Operation
as non-partition-specific.
- GenericOperation - Class in com.hazelcast.ringbuffer.impl.operations
-
Ring buffer operations which don't need to send any parameters and which can be determined by only sending the operation
type which is a byte of information.
- GenericOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.GenericOperation
-
- GenericOperation(String, byte) - Constructor for class com.hazelcast.ringbuffer.impl.operations.GenericOperation
-
- GenericOperationThread - Class in com.hazelcast.spi.impl.operationexecutor.impl
-
- GenericOperationThread(String, int, OperationQueue, ILogger, NodeExtension, OperationRunner, boolean, ClassLoader) - Constructor for class com.hazelcast.spi.impl.operationexecutor.impl.GenericOperationThread
-
- geQueryCacheConfigurator() - Method in class com.hazelcast.map.impl.querycache.subscriber.AbstractSubscriberContext
-
- geQueryCacheConfigurator() - Method in interface com.hazelcast.map.impl.querycache.subscriber.SubscriberContext
-
- get(K, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Retrieves the mapped value of the given key using a custom ExpiryPolicy
.
- get(Data, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- GET - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- get() - Method in class com.hazelcast.cache.impl.CacheEntryProcessorResult
-
- get(K) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- get(SerializationService) - Method in class com.hazelcast.cache.impl.DeferredValue
-
- get(Data, ExpiryPolicy) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Gets the value to which the specified key is mapped,
or null
if this cache contains no mapping for the key.
- get() - Method in class com.hazelcast.cache.impl.operation.AddCacheConfigOperationSupplier
-
- get(K) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-
- get() - Method in class com.hazelcast.client.impl.AddInterceptorOperationSupplier
-
- get() - Method in class com.hazelcast.client.impl.CollectRemoteTransactionsOperationSupplier
-
- get() - Method in class com.hazelcast.client.impl.protocol.task.CreateProxiesMessageTask
-
- get() - Method in class com.hazelcast.client.impl.protocol.task.DeployClassesMessageTask
-
- get() - Method in class com.hazelcast.client.impl.ReAuthenticationOperationSupplier
-
- get() - Method in class com.hazelcast.client.impl.RemoveInterceptorOperationSupplier
-
- get() - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-
- get() - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-
- get(int) - Method in class com.hazelcast.client.proxy.ClientListProxy
-
- get(Object) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- get(K) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-
- get() - Method in class com.hazelcast.client.proxy.ClientPNCounterProxy
-
- get(Object) - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
-
- get() - Method in class com.hazelcast.client.proxy.ClientScheduledFutureProxy
-
- get(long, TimeUnit) - Method in class com.hazelcast.client.proxy.ClientScheduledFutureProxy
-
- get(Object) - Method in class com.hazelcast.client.proxy.txn.ClientTxnMapProxy
-
- get(K) - Method in class com.hazelcast.client.proxy.txn.ClientTxnMultiMapProxy
-
- get() - Method in class com.hazelcast.client.spi.impl.ClientResponseHandlerSupplier
-
- get() - Method in class com.hazelcast.client.util.ClientDelegatingFuture
-
- get(long, TimeUnit) - Method in class com.hazelcast.client.util.ClientDelegatingFuture
-
- get(int) - Method in class com.hazelcast.collection.impl.list.ListContainer
-
- get(int) - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
-
- get() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongContainer
-
- GET - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-
- get() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- get() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceContainer
-
- GET - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-
- get() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- get(String) - Static method in enum com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
-
- get(Object) - Method in interface com.hazelcast.core.BaseMap
-
Returns the value for the specified key, or null
if this map does not contain this key.
- get(K) - Method in interface com.hazelcast.core.BaseMultiMap
-
Returns the collection of values associated with the key.
- get() - Method in interface com.hazelcast.core.IAtomicLong
-
Gets the current value.
- get() - Method in interface com.hazelcast.core.IAtomicReference
-
Gets the current value.
- get(Object) - Method in interface com.hazelcast.core.IMap
-
Returns the value for the specified key, or null
if this map does not contain this key.
- get(K) - Method in interface com.hazelcast.core.MultiMap
-
Returns the collection of values associated with the key.
- get(Object) - Method in interface com.hazelcast.core.TransactionalMap
-
- get(K) - Method in interface com.hazelcast.core.TransactionalMultiMap
-
Returns the collection of values associated with the key.
- get() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
-
Returns the current value of the counter.
- get(VectorClock) - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
-
Returns the current value of the counter.
- get() - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
-
- get(K) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
-
- get(K) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
-
- get(K) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
-
- get(K) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
-
- get(K) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
-
- get(String, String) - Method in interface com.hazelcast.internal.ascii.TextCommandService
-
- get(String, String) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-
- get() - Method in class com.hazelcast.internal.dynamicconfig.AddDynamicConfigOperationSupplier
-
- get(Object) - Method in class com.hazelcast.internal.dynamicconfig.AggregatingMap
-
- get() - Method in class com.hazelcast.internal.jmx.suppliers.LocalMapStatsSupplier
-
- get() - Method in class com.hazelcast.internal.jmx.suppliers.LocalMultiMapStatsSupplier
-
- get() - Method in class com.hazelcast.internal.jmx.suppliers.LocalQueueStatsSupplier
-
- get() - Method in interface com.hazelcast.internal.jmx.suppliers.StatsSupplier
-
- get(S) - Method in interface com.hazelcast.internal.metrics.DoubleProbeFunction
-
Gets the current value of the source object.
- get(S) - Method in interface com.hazelcast.internal.metrics.LongProbeFunction
-
Gets the current value of the source object as a long.
- get(K) - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
-
- get(K) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
-
- get(K) - Method in interface com.hazelcast.internal.nearcache.NearCache
-
Gets the value associated with the given key
.
- get(K) - Method in interface com.hazelcast.internal.nearcache.NearCacheRecordStore
-
Gets the value associated with the given key
.
- get() - Method in class com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolThreadLocal
-
- get(long) - Method in interface com.hazelcast.internal.util.collection.Long2LongMap
-
- get(long) - Method in class com.hazelcast.internal.util.collection.Long2LongMapHsa
-
- get() - Method in interface com.hazelcast.internal.util.counters.Counter
-
Gets the current value of the counter.
- get() - Method in class com.hazelcast.internal.util.counters.MwCounter
-
- get(long, int) - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray12byteKey
-
Returns the address of the value block mapped by (key1, key2)
.
- get(long, long) - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray16byteKey
-
Returns the address of the value block mapped by (key1, key2)
.
- get(long) - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray8byteKey
-
Returns the address of the value block mapped by the given key.
- get(long, int) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray12byteKeyImpl
-
- get(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyImpl
-
- get(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyNoValue
-
- get(long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray8byteKeyImpl
-
- get() - Static method in class com.hazelcast.internal.util.RuntimeAvailableProcessors
-
Returns the number of available processors.
- get() - Static method in class com.hazelcast.internal.util.ThreadLocalRandomProvider
-
Returns the current thread's
Random
.
- GET - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- get(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- get(Class<? extends Result>) - Method in class com.hazelcast.map.impl.query.ResultProcessorRegistry
-
- get(long) - Method in interface com.hazelcast.map.impl.querycache.accumulator.CyclicBuffer
-
Returns the element in this buffer which has the supplied sequence
.
- get(long) - Method in class com.hazelcast.map.impl.querycache.accumulator.DefaultCyclicBuffer
-
- get(Object) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
-
- get(Data) - Method in interface com.hazelcast.map.impl.querycache.subscriber.QueryCacheRecordStore
-
- get(Data, boolean) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- get(Data, boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
- get(K) - Method in interface com.hazelcast.map.impl.recordstore.Storage
-
- get(Data) - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
-
- get(Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-
- get(Object) - Method in interface com.hazelcast.map.QueryCache
-
- GET - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- get(K) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- get(K) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxy
-
- get(byte) - Static method in enum com.hazelcast.nio.serialization.FieldType
-
- get(String) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
-
- get(String) - Method in class com.hazelcast.query.EntryObject
-
- GET - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
-
- get(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- get(Object) - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
-
- get(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- get(Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- get(int) - Method in class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
-
- get(int) - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
-
- get(int) - Method in interface com.hazelcast.ringbuffer.ReadResultSet
-
Gets the item at the given index.
- get() - Method in class com.hazelcast.scheduledexecutor.impl.DelegatingScheduledFutureStripper
-
- get(long, TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.DelegatingScheduledFutureStripper
-
- get(String) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
-
- get() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledFutureProxy
-
- get(long, TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledFutureProxy
-
- get(int) - Method in interface com.hazelcast.security.Parameters
-
- get() - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
-
- get(long, TimeUnit) - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
-
PLEASE NOTE: It's legal to override this method, but please bear in mind that you should call super.get() or
implement the done() and cancelled() callbacks to be notified if this future gets done or cancelled.
- get() - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
-
- get(long, TimeUnit) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
-
- get() - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.DeregistrationOperationSupplier
-
- get() - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.RegistrationOperationSupplier
-
- get() - Method in class com.hazelcast.spi.impl.operationservice.impl.InboundResponseHandlerSupplier
-
- get(long) - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationRegistry
-
Gets the invocation for the given call ID.
- get() - Method in class com.hazelcast.spi.impl.proxyservice.impl.DistributedObjectFuture
-
- get(int) - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
-
- get(String) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
Returns the value for the given key.
- get(Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
-
- get(Object, Class<T>) - Method in class com.hazelcast.spring.cache.HazelcastCache
-
- get(Object, Callable<T>) - Method in class com.hazelcast.spring.cache.HazelcastCache
-
- get(Object) - Method in interface com.hazelcast.transaction.impl.Transaction
-
- get(Object) - Method in class com.hazelcast.transaction.impl.TransactionImpl
-
- get(Object) - Method in class com.hazelcast.transaction.impl.TransactionLog
-
- get(Object) - Method in class com.hazelcast.transaction.impl.xa.XATransaction
-
- get(int, int) - Method in class com.hazelcast.util.collection.BiInt2ObjectMap
-
Retrieve a value from the map.
- get(K1, K2) - Method in class com.hazelcast.util.collection.ComposedKeyMap
-
- get(Object) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
-
- get(int) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
-
- get(K) - Method in class com.hazelcast.util.collection.InternalListMultiMap
-
Return collection of values associated with a given key
- get(K) - Method in class com.hazelcast.util.collection.InternalSetMultimap
-
Return Set of values associated with a given key
- get(long) - Method in class com.hazelcast.util.collection.Long2LongHashMap
-
- get(Object) - Method in class com.hazelcast.util.collection.Long2LongHashMap
-
- get(Object) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
-
- get(long) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
-
- get(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
-
Returns the value to which the specified key is mapped,
or null
if this map contains no mapping for the key.
- get() - Method in class com.hazelcast.util.executor.CompletedFuture
-
- get(long, TimeUnit) - Method in class com.hazelcast.util.executor.CompletedFuture
-
- get() - Method in class com.hazelcast.util.executor.DelegatingFuture
-
- get(long, TimeUnit) - Method in class com.hazelcast.util.executor.DelegatingFuture
-
- get() - Method in interface com.hazelcast.util.function.Supplier
-
- get(T) - Method in class com.hazelcast.util.ItemCounter
-
Get current counter for an item item
- get(K) - Method in interface com.hazelcast.util.scheduler.EntryTaskScheduler
-
Return the entry for the scheduled key or null if there is none
- get(K) - Method in class com.hazelcast.util.scheduler.SecondsBasedEntryTaskScheduler
-
- get0(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
-
- GET_ALL - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- GET_ALL - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- GET_ALL - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- GET_ALL_FACTORY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- GET_ALL_SCHEDULED_ON_MEMBER - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
-
- GET_ALL_SCHEDULED_ON_PARTITION - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
-
- GET_ALL_SCHEDULED_ON_PARTITION_OPERATION_FACTORY - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
-
- GET_AND_ADD - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-
- GET_AND_ALTER - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-
- GET_AND_ALTER - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-
- GET_AND_REMOVE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- GET_AND_REPLACE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- GET_AND_SET - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-
- GET_AND_SET - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-
- GET_CACHE_ENTRY_VIEW_PROCESSOR - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- GET_CACHE_TIME_TAKEN_NANOS - Static variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- GET_CONFIG - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- GET_CONNECTED_CLIENTS - Static variable in class com.hazelcast.client.impl.ClientDataSerializerHook
-
- GET_COUNT_OPERATION - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-
- GET_DELAY_OP - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
-
- GET_ENTRY_VIEW - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- GET_LOCK_COUNT - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
-
- GET_REMAINING_LEASETIME - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
-
- GET_RESULT - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
-
- GET_RESULT_OPERATION - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-
- GET_STATS_OP - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
-
- getAcceptableHeartbeatPauseMillis() - Method in class com.hazelcast.quorum.impl.ProbabilisticQuorumFunction
-
- getAccessHit() - Method in interface com.hazelcast.cache.CacheEntryView
-
Gets the count of how many time this cache entry has been accessed.
- getAccessHit() - Method in class com.hazelcast.cache.impl.CacheEventContext
-
- getAccessHit() - Method in class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
-
- getAccessHit() - Method in class com.hazelcast.cache.impl.merge.entry.LazyCacheEntryView
-
- getAccessHit() - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-
- getAccessHit() - Method in interface com.hazelcast.internal.eviction.Evictable
-
- getAccessHit() - Method in interface com.hazelcast.internal.eviction.EvictableEntryView
-
- getAccessHit() - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest.CacheBrowserEntryView
-
- getAccessHit() - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
-
- getAccessHit() - Method in class com.hazelcast.internal.nearcache.impl.store.HeapNearCacheRecordMap.NearCacheEvictableSamplingEntry
-
- getAccessKey() - Method in class com.hazelcast.config.AwsConfig
-
Gets the access key to access AWS.
- getAccessor() - Method in interface com.hazelcast.internal.eviction.EvictionCandidate
-
The accessor (key or ID) of
Evictable
entry or record or whatever.
- getAccessor() - Method in class com.hazelcast.internal.memory.impl.MemoryManagerBean
-
- getAccessor() - Method in interface com.hazelcast.internal.memory.MemoryManager
-
- getAccessor() - Method in class com.hazelcast.internal.nearcache.impl.store.HeapNearCacheRecordMap.NearCacheEvictableSamplingEntry
-
- getAccessor() - Method in class com.hazelcast.internal.util.collection.HsaHeapMemoryManager
-
- getAccumulatorInfoOrNull(String, String) - Method in interface com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfoSupplier
-
- getAccumulatorInfoOrNull(String, String) - Method in class com.hazelcast.map.impl.querycache.accumulator.DefaultAccumulatorInfoSupplier
-
- getAccumulatorInfoSupplier() - Method in class com.hazelcast.map.impl.querycache.publisher.DefaultPublisherContext
-
- getAccumulatorInfoSupplier() - Method in interface com.hazelcast.map.impl.querycache.publisher.PublisherContext
-
- getAccumulatorInfoSupplier() - Method in class com.hazelcast.map.impl.querycache.subscriber.AbstractSubscriberContext
-
- getAccumulatorInfoSupplier() - Method in interface com.hazelcast.map.impl.querycache.subscriber.SubscriberContext
-
- getAccumulatorOrNull(QueryCacheContext, String, String, int) - Static method in class com.hazelcast.map.impl.querycache.utils.QueryCacheUtil
-
Returns Accumulator
of a partition.
- getAccumulatorRegistryOrNull(QueryCacheContext, String, String) - Static method in class com.hazelcast.map.impl.querycache.utils.QueryCacheUtil
-
Returns PartitionAccumulatorRegistry
of a QueryCache
.
- getAccumulators(QueryCacheContext, String, String) - Static method in class com.hazelcast.map.impl.querycache.utils.QueryCacheUtil
-
Returns accumulators of a QueryCache
.
- getAcknowledgeType() - Method in class com.hazelcast.wan.WanReplicationEvent
-
- getAcquireTime() - Method in interface com.hazelcast.concurrent.lock.LockResource
-
- getActions() - Method in class com.hazelcast.config.PermissionConfig
-
- getActions() - Method in class com.hazelcast.security.permission.AllPermissions
-
- getActions() - Method in class com.hazelcast.security.permission.ConfigPermission
-
- getActions() - Method in class com.hazelcast.security.permission.InstancePermission
-
- getActions() - Method in class com.hazelcast.security.permission.TransactionPermission
-
- getActiveConnection(Address) - Method in interface com.hazelcast.client.connection.ClientConnectionManager
-
- getActiveConnection(Address) - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-
- getActiveConnectionCount() - Method in class com.hazelcast.internal.jmx.ConnectionManagerMBean
-
- getActiveConnectionCount() - Method in interface com.hazelcast.nio.ConnectionManager
-
Gets the number of active connections.
- getActiveConnectionCount() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- getActiveConnections() - Method in interface com.hazelcast.client.connection.ClientConnectionManager
-
- getActiveConnections() - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-
- getActiveConnections() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- getActiveMigration() - Method in class com.hazelcast.internal.partition.PartitionRuntimeState
-
- getActivePartitionCount() - Method in class com.hazelcast.internal.jmx.PartitionServiceMBean
-
- getActivePartitionCount() - Method in class com.hazelcast.internal.management.dto.PartitionServiceBeanDTO
-
- getActivePublisherName() - Method in class com.hazelcast.monitor.impl.WanSyncStateImpl
-
- getActivePublisherName() - Method in interface com.hazelcast.monitor.WanSyncState
-
- getActiveRegistrations(String) - Method in class com.hazelcast.client.spi.impl.listener.AbstractClientListenerService
-
- getActiveRegistrations(String) - Method in class com.hazelcast.client.spi.impl.listener.NonSmartClientListenerService
-
- getActiveRegistrations(String) - Method in class com.hazelcast.client.spi.impl.listener.SmartClientListenerService
-
- getActiveWanConfigName() - Method in class com.hazelcast.monitor.impl.WanSyncStateImpl
-
- getActiveWanConfigName() - Method in interface com.hazelcast.monitor.WanSyncState
-
- getActualDelayMillis() - Method in class com.hazelcast.util.scheduler.ScheduledEntry
-
- getActualDelaySeconds() - Method in class com.hazelcast.util.scheduler.ScheduledEntry
-
- getAddress() - Method in class com.hazelcast.client.impl.protocol.task.AbstractAddressMessageTask
-
- getAddress() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetConfigMessageTask
-
- getAddress() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterAddMessageTask
-
- getAddress() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetMessageTask
-
- getAddress() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToAddressMessageTask
-
- getAddress() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromAddressMessageTask
-
- getAddress() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromAddressMessageTask
-
- getAddress() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromAddressMessageTask
-
- getAddress() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromAddressMessageTask
-
- getAddress() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromAddressMessageTask
-
- getAddress() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromAddressMessageTask
-
- getAddress() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromAddressMessageTask
-
- getAddress() - Method in interface com.hazelcast.core.Member
-
Returns the Address of this Member.
- getAddress() - Method in class com.hazelcast.instance.AbstractMember
-
- getAddress() - Method in class com.hazelcast.internal.cluster.impl.JoinMessage
-
- getAddress() - Method in class com.hazelcast.internal.cluster.MemberInfo
-
- getAddress() - Method in class com.hazelcast.internal.management.ManagementCenterIdentifier
-
- getAddress(int, int) - Method in class com.hazelcast.internal.partition.PartitionTableView
-
- getAddress() - Method in class com.hazelcast.mapreduce.impl.notification.MemberAwareMapReduceNotification
-
- getAddress() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- getAddress() - Method in interface com.hazelcast.monitor.MemberState
-
- getAddress() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskHandlerImpl
-
- getAddress() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
-
Returns the address of the member the task is associated with.
- getAddress() - Method in class com.hazelcast.util.AddressUtil.AddressHolder
-
- getAddress() - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
-
- getAddresses() - Method in class com.hazelcast.client.config.ClientConfig
-
Deprecated.
- getAddresses() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Returns the list of candidate addresses that client will use to establish initial connection
- getAddresses() - Method in class com.hazelcast.internal.cluster.impl.MembersView
-
- getAddresses(int) - Method in class com.hazelcast.internal.partition.PartitionTableView
-
- getAddressHolder(String) - Static method in class com.hazelcast.util.AddressUtil
-
- getAddressHolder(String, int) - Static method in class com.hazelcast.util.AddressUtil
-
- getAddressMatcher(String) - Static method in class com.hazelcast.util.AddressUtil
-
Gets an AddressMatcher for a given addresses.
- getAdjustedTTLSeconds(int) - Method in interface com.hazelcast.internal.ascii.TextCommandService
-
- getAdjustedTTLSeconds(int) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-
- getAggregator() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapQueryMessageTask
-
- getAggregator() - Method in class com.hazelcast.client.impl.protocol.task.map.DefaultMapProjectMessageTask
-
- getAggregator() - Method in class com.hazelcast.client.impl.protocol.task.map.DefaultMapQueryMessageTask
-
- getAggregator() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAggregateMessageTask
-
- getAggregator() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAggregateWithPredicateMessageTask
-
- getAggregator() - Method in class com.hazelcast.map.impl.query.AggregationResult
-
- getAggregator() - Method in class com.hazelcast.map.impl.query.Query
-
- getAlgorithm() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-
- getAll(Set<? extends K>, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Gets a collection of entries from the cache with custom expiry policy, returning them as
Map
of the values associated with the set of keys requested.
- getAll(Set<Data>, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- getAll(Set<? extends K>) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- getAll(Set<Data>, ExpiryPolicy) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Gets a collection of entries from the store, returning them as
Map
of the values associated with the set of keys requested.
- getAll(Set<? extends K>) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-
- getAll(Set<K>) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- getAll() - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-
- getAll(Set<K>) - Method in interface com.hazelcast.core.IMap
-
Returns the entries for the given keys.
- getAll(Set<K>) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
-
- getAll(Set<K>) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
-
- getAll(Set<K>) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
-
- getAll(Set<K>) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
-
- getAll(Set<K>) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
-
- getAll(String, Set<String>) - Method in interface com.hazelcast.internal.ascii.TextCommandService
-
- getAll(String, Set<String>) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-
- getAll(Set<K>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- getAll() - Method in class com.hazelcast.map.impl.querycache.publisher.MapListenerRegistry
-
- getAll() - Method in class com.hazelcast.map.impl.querycache.publisher.MapPublisherRegistry
-
- getAll() - Method in class com.hazelcast.map.impl.querycache.publisher.PartitionAccumulatorRegistry
-
- getAll() - Method in class com.hazelcast.map.impl.querycache.publisher.PublisherRegistry
-
- getAll() - Method in class com.hazelcast.map.impl.querycache.publisher.QueryCacheListenerRegistry
-
- getAll() - Method in interface com.hazelcast.map.impl.querycache.Registry
-
Returns map of all registered items in this registry.
- getAll() - Method in class com.hazelcast.map.impl.querycache.subscriber.MapSubscriberRegistry
-
- getAll(Set) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
-
- getAll() - Method in class com.hazelcast.map.impl.querycache.subscriber.SubscriberRegistry
-
- getAll(Set<Data>) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- getAll(Set<Data>) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
- getAll(Set<K>) - Method in interface com.hazelcast.map.QueryCache
-
- getAllDistributedObjects() - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-
- getAllDistributedObjects() - Method in interface com.hazelcast.spi.ProxyService
-
- getAllDone(Collection<Future>) - Static method in class com.hazelcast.util.FutureUtil
-
Get all futures that are done
- getAllHazelcastClients() - Static method in class com.hazelcast.client.HazelcastClient
-
Gets an immutable collection of all client HazelcastInstances created in this JVM.
- getAllHazelcastClients() - Static method in class com.hazelcast.client.HazelcastClientManager
-
- getAllHazelcastInstances() - Static method in class com.hazelcast.core.Hazelcast
-
Returns all active/running HazelcastInstances on this JVM.
- getAllHazelcastInstances() - Static method in class com.hazelcast.instance.HazelcastInstanceFactory
-
- getAllHazelcastInstances() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
-
- getAllInterfaces(Class<?>) - Static method in class com.hazelcast.nio.ClassLoaderUtil
-
- getAllInternal(Set<? extends K>, Collection<Data>, ExpiryPolicy, List<Object>, long) - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
-
- getAllInternal(Set<K>, Map<Integer, List<Data>>, List<Object>) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- getAllInternal(Set<K>, Map<Integer, List<Data>>, List<Object>) - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-
- getAllInternal(Set<K>, List<Data>, List<Object>) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-
- getAllInternal(Data) - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-
- getAllKeys() - Method in class com.hazelcast.mapreduce.KeyValueSource
-
Deprecated.
- getAllKeys0() - Method in class com.hazelcast.mapreduce.KeyValueSource
-
Deprecated.
This method is meant to be overridden to implement collecting of all clusterwide available keys
and return them from
KeyValueSource.getAllKeys()
.
- getAllLocks() - Method in interface com.hazelcast.concurrent.lock.LockService
-
- getAllLocks() - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- getAllNamespaces(int) - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-
- getAllNamespaces(int) - Method in class com.hazelcast.concurrent.lock.LockStoreContainer
-
- getAllNamespaces(int) - Method in class com.hazelcast.map.impl.PartitionContainer
-
- getAllNamespaces(int) - Method in class com.hazelcast.multimap.impl.MultiMapPartitionContainer
-
- getAllocator() - Method in class com.hazelcast.internal.memory.impl.MemoryManagerBean
-
- getAllocator() - Method in interface com.hazelcast.internal.memory.MemoryManager
-
- getAllocator() - Method in class com.hazelcast.internal.util.collection.HsaHeapMemoryManager
-
- getAllocatorType() - Method in class com.hazelcast.config.NativeMemoryConfig
-
- GetAllOperation - Class in com.hazelcast.map.impl.operation
-
- GetAllOperation() - Constructor for class com.hazelcast.map.impl.operation.GetAllOperation
-
- GetAllOperation(String, List<Data>) - Constructor for class com.hazelcast.map.impl.operation.GetAllOperation
-
- GetAllOperation - Class in com.hazelcast.multimap.impl.operations
-
- GetAllOperation() - Constructor for class com.hazelcast.multimap.impl.operations.GetAllOperation
-
- GetAllOperation(String, Data) - Constructor for class com.hazelcast.multimap.impl.operations.GetAllOperation
-
- getAllRecordStores() - Method in class com.hazelcast.map.impl.PartitionContainer
-
- getAllReplicatedRecordStores(String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-
- getAllScheduledFutures() - Method in class com.hazelcast.client.proxy.ClientScheduledExecutorProxy
-
- getAllScheduledFutures() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorServiceProxy
-
- getAllScheduledFutures() - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
-
Fetches and returns all scheduled (not disposed yet) futures from all members in the cluster.
- GetAllScheduledOnMemberOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
-
- GetAllScheduledOnMemberOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnMemberOperation
-
- GetAllScheduledOnMemberOperation(String) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnMemberOperation
-
- GetAllScheduledOnPartitionOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
-
- GetAllScheduledOnPartitionOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnPartitionOperation
-
- GetAllScheduledOnPartitionOperation(String) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnPartitionOperation
-
- GetAllScheduledOnPartitionOperationFactory - Class in com.hazelcast.scheduledexecutor.impl.operations
-
- GetAllScheduledOnPartitionOperationFactory() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnPartitionOperationFactory
-
- GetAllScheduledOnPartitionOperationFactory(String) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnPartitionOperationFactory
-
- getAllServiceNamespaces(PartitionReplicationEvent) - Method in class com.hazelcast.cache.impl.CacheService
-
- getAllServiceNamespaces(PartitionReplicationEvent) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- getAllServiceNamespaces(PartitionReplicationEvent) - Method in class com.hazelcast.map.impl.MapService
-
- getAllServiceNamespaces(PartitionReplicationEvent) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- getAllServiceNamespaces(PartitionReplicationEvent) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
-
- getAllServiceNamespaces(PartitionReplicationEvent) - Method in interface com.hazelcast.spi.FragmentedMigrationAwareService
-
Returns all known namespaces for given replication event.
- getAllServiceNamespaces(PartitionReplicationEvent) - Method in class com.hazelcast.spi.impl.CountingMigrationAwareService
-
- getAllTextConnections() - Method in interface com.hazelcast.nio.ConnectionManager
-
Gets the number of text connections (rest/memcache)
- getAllTextConnections() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- getAllThreads() - Static method in class com.hazelcast.internal.management.ThreadDumpGenerator
-
- getAnchor() - Method in class com.hazelcast.query.PagingPredicate
-
Retrieve the anchor object which is the last value object on the previous page.
- getAndAdd(long) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-
- getAndAdd(long) - Method in class com.hazelcast.client.proxy.ClientPNCounterProxy
-
- getAndAdd(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongContainer
-
- getAndAdd(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- getAndAdd(long) - Method in interface com.hazelcast.core.IAtomicLong
-
Atomically adds the given value to the current value.
- getAndAdd(long) - Method in interface com.hazelcast.crdt.pncounter.PNCounter
-
Adds the given value to the current value.
- getAndAdd(long, VectorClock) - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
-
Adds the given value to the current value.
- getAndAdd(long) - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
-
- getAndAdd(long) - Method in class com.hazelcast.internal.jmx.AtomicLongMBean
-
- getAndAddAsync(long) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-
- getAndAddAsync(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- getAndAddAsync(long) - Method in interface com.hazelcast.core.IAtomicLong
-
Atomically adds the given value to the current value.
- GetAndAddOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-
- GetAndAddOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
-
- GetAndAddOperation(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
-
- getAndAdvance() - Method in interface com.hazelcast.map.impl.querycache.accumulator.CyclicBuffer
-
Returns next unread event from this buffer and advances head sequence of this buffer by one.
- getAndAdvance() - Method in class com.hazelcast.map.impl.querycache.accumulator.DefaultCyclicBuffer
-
- getAndAlter(IFunction<Long, Long>) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-
- getAndAlter(IFunction<E, E>) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-
- getAndAlter(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- getAndAlter(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- getAndAlter(IFunction<Long, Long>) - Method in interface com.hazelcast.core.IAtomicLong
-
Alters the currently stored value by applying a function on it on and gets the old value.
- getAndAlter(IFunction<E, E>) - Method in interface com.hazelcast.core.IAtomicReference
-
Alters the currently stored reference by applying a function on it on and gets the old value.
- getAndAlterAsync(IFunction<Long, Long>) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-
- getAndAlterAsync(IFunction<E, E>) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-
- getAndAlterAsync(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- getAndAlterAsync(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- getAndAlterAsync(IFunction<Long, Long>) - Method in interface com.hazelcast.core.IAtomicLong
-
Alters the currently stored value by applying a function on it on and gets the old value.
- getAndAlterAsync(IFunction<E, E>) - Method in interface com.hazelcast.core.IAtomicReference
-
Alters the currently stored reference by applying a function on it on and gets the old value.
- GetAndAlterOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-
- GetAndAlterOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetAndAlterOperation
-
- GetAndAlterOperation(String, IFunction<Long, Long>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetAndAlterOperation
-
- GetAndAlterOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-
- GetAndAlterOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.GetAndAlterOperation
-
- GetAndAlterOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.GetAndAlterOperation
-
- getAndDecrement() - Method in class com.hazelcast.client.proxy.ClientPNCounterProxy
-
- getAndDecrement() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
-
Decrements by one the current value.
- getAndDecrement() - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
-
- getAndInc() - Method in class com.hazelcast.util.MutableInteger
-
- getAndIncrement() - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-
- getAndIncrement() - Method in class com.hazelcast.client.proxy.ClientPNCounterProxy
-
- getAndIncrement() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- getAndIncrement() - Method in interface com.hazelcast.core.IAtomicLong
-
Atomically increments the current value by one.
- getAndIncrement() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
-
Increments by one the current value.
- getAndIncrement() - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
-
- getAndIncrement() - Method in class com.hazelcast.internal.jmx.AtomicLongMBean
-
- getAndIncrementAsync() - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-
- getAndIncrementAsync() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- getAndIncrementAsync() - Method in interface com.hazelcast.core.IAtomicLong
-
Atomically increments the current value by one.
- getAndPut(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Associates the specified value with the specified key in this cache using a custom ExpiryPolicy
,
returning an existing value if one existed.
- getAndPut(Data, Object, ExpiryPolicy, String, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- getAndPut(K, V) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- getAndPut(Data, Object, ExpiryPolicy, String, int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Associates the specified value with the specified key in this cache,
returning an existing value if one existed.
- getAndPut(K, V) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-
- getAndPutAsync(K, V) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously associates the specified value with the specified key in this cache,
returning an existing value if one existed.
- getAndPutAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously associates the specified value with the specified key in this cache,
returning an existing value if one existed using a custom ExpiryPolicy
.
- getAndRemove(Data, String, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- getAndRemove(Data, String, int, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- getAndRemove(K) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- getAndRemove(Data, String, int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Atomically removes the entry for a key only if it is currently mapped to some
value.
- getAndRemove(K) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-
- getAndRemoveAsync(K) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously removes the entry for a key and returns the previously assigned value or null
if no value was assigned.
- getAndReplace(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Atomically replaces the assigned value of the given key by the specified value using a
custom ExpiryPolicy
and returns the previously assigned value.
- getAndReplace(Data, Object, ExpiryPolicy, String, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- getAndReplace(K, V) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- getAndReplace(Data, Object, ExpiryPolicy, String, int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Atomically replaces the value for a given key if and only if there is a
value currently mapped by the key.
- getAndReplace(K, V) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-
- getAndReplaceAsync(K, V) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously replaces the assigned value of the given key by the specified value and returns
the previously assigned value.
- getAndReplaceAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously replaces the assigned value of the given key by the specified value using a
custom ExpiryPolicy
and returns the previously assigned value.
- getAndSet(long) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-
- getAndSet(E) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-
- getAndSet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongContainer
-
- getAndSet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- getAndSet(Data) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceContainer
-
- getAndSet(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- getAndSet(long) - Method in interface com.hazelcast.core.IAtomicLong
-
Atomically sets the given value and returns the old value.
- getAndSet(E) - Method in interface com.hazelcast.core.IAtomicReference
-
Gets the old value and sets the new value.
- getAndSet(long) - Method in class com.hazelcast.internal.jmx.AtomicLongMBean
-
- getAndSet(T, long) - Method in class com.hazelcast.util.ItemCounter
-
Set counter for item and return previous value
- getAndSetAsync(long) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-
- getAndSetAsync(E) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-
- getAndSetAsync(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- getAndSetAsync(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- getAndSetAsync(long) - Method in interface com.hazelcast.core.IAtomicLong
-
Atomically sets the given value and returns the old value.
- getAndSetAsync(E) - Method in interface com.hazelcast.core.IAtomicReference
-
Gets the value and sets the new value.
- GetAndSetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-
- GetAndSetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
-
- GetAndSetOperation(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
-
- GetAndSetOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-
- GetAndSetOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
-
- GetAndSetOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
-
- getAndSubtract(long) - Method in class com.hazelcast.client.proxy.ClientPNCounterProxy
-
- getAndSubtract(long) - Method in interface com.hazelcast.crdt.pncounter.PNCounter
-
Subtracts the given value from the current value.
- getAndSubtract(long, VectorClock) - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
-
Subtracts the given value from the current value.
- getAndSubtract(long) - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
-
- getArray(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
-
Returns a field in a Json object as an array.
- getArray(JsonObject, String, JsonArray) - Static method in class com.hazelcast.util.JsonUtil
-
Returns a field in a Json object as an array.
- getAsDataList() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-
Returns data in the queue.
- getAsReadOnly() - Method in class com.hazelcast.config.AtomicLongConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.AtomicReferenceConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.CacheConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.CacheEvictionConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.CollectionConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.CountDownLatchConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.DiscoveryConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.EntryListenerConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.EvictionConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.ExecutorConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.ItemListenerConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.JobTrackerConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.ListConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.ListenerConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.LockConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.MapAttributeConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.MapConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.MapIndexConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.MapStoreConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.MaxSizeConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.MergePolicyConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.MultiMapConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.NearCacheConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.PartitioningStrategyConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.PredicateConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.QueryCacheConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.QueueConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.QueueStoreConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.ReliableTopicConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.RingbufferConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.RingbufferStoreConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.SemaphoreConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.SetConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.TopicConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.WanReplicationRef
-
- getAssignment() - Method in class com.hazelcast.mapreduce.impl.operation.KeysAssignmentResult
-
- getAsync(K) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously retrieves the mapped value of the given key using a custom
ExpiryPolicy
.
- getAsync(K, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously gets an entry from cache using a custom ExpiryPolicy
.
- getAsync() - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-
- getAsync() - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-
- getAsync(K) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- getAsync() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- getAsync() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- getAsync() - Method in interface com.hazelcast.core.IAtomicLong
-
Gets the current value.
- getAsync() - Method in interface com.hazelcast.core.IAtomicReference
-
Gets the current value.
- getAsync(K) - Method in interface com.hazelcast.core.IMap
-
Asynchronously gets the given key.
- getAsync(K) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
-
- getAsync(K) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
-
- getAsync(K) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
-
- getAsync(K) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
-
- getAsync(K) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
-
- getAsync(K) - Method in interface com.hazelcast.map.impl.LegacyAsyncMap
-
- getAsync(K) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- getAsyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.AbstractCacheOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.CacheMergeOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.CachePutAllOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorContainer
-
- getAsyncBackupCount() - Method in class com.hazelcast.cardinality.impl.operations.CardinalityEstimatorBackupAwareOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionBackupAwareOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.collection.impl.queue.operations.QueueBackupAwareOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBackupAwareOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBackupAwareOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- getAsyncBackupCount() - Method in interface com.hazelcast.concurrent.lock.LockStoreInfo
-
- getAsyncBackupCount() - Method in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreBackupAwareOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDetachMemberOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
-
- getAsyncBackupCount() - Method in class com.hazelcast.config.CacheConfig
-
Gets the number of asynchronous backups for this
ICache
.
- getAsyncBackupCount() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the number of asynchronous backups for this
ICache
.
- getAsyncBackupCount() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
Gets the number of synchronous backups.
- getAsyncBackupCount() - Method in class com.hazelcast.config.CollectionConfig
-
Gets the number of asynchronous backups.
- getAsyncBackupCount() - Method in class com.hazelcast.config.MapConfig
-
Returns the asynchronous backup count for this
IMap
.
- getAsyncBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
-
Gets the number of asynchronous backups for this MultiMap.
- getAsyncBackupCount() - Method in class com.hazelcast.config.QueueConfig
-
Get the number of asynchronous backups for this queue.
- getAsyncBackupCount() - Method in class com.hazelcast.config.RingbufferConfig
-
Gets the number of asynchronous backups.
- getAsyncBackupCount() - Method in class com.hazelcast.config.SemaphoreConfig
-
Returns the number of asynchronous backups.
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.MapContainer
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.BasePutOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.BaseRemoveOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.ClearOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.EntryOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.EvictOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.MapFlushOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.MergeOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.PutAllOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.multimap.impl.operations.AbstractMultiMapOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.ringbuffer.impl.operations.AddOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.ringbuffer.impl.operations.MergeOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.scheduledexecutor.impl.operations.AbstractBackupAwareSchedulerOperation
-
- getAsyncBackupCount() - Method in interface com.hazelcast.spi.BackupAwareOperation
-
The asynchronous backup count.
- getAsyncBackupCount() - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionOperation
-
- getAsyncExecutorMBean() - Method in class com.hazelcast.internal.jmx.InstanceMBean
-
- getAsyncInternal(Object, ExpiryPolicy, ExecutionCallback<V>) - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
-
- getAsyncInternal(Object) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- getAsyncInternal(Object) - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-
- getAsyncInternal(Object) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-
- getAtomicLong(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getAtomicLong(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-
- getAtomicLong(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates cluster-wide atomic long.
- getAtomicLong(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getAtomicLong(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getAtomicLongConfig(String) - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getAtomicLongConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the AtomicLongConfig for the given name, creating one
if necessary and adding it to the collection of known configurations.
- getAtomicLongConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getAtomicLongConfigs() - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getAtomicLongConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of AtomicLong configurations, mapped by config name.
- getAtomicLongConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
-
- getAtomicLongConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
-
Returns all registered AtomicLong configurations.
- getAtomicLongConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getAtomicNumber() - Method in class com.hazelcast.client.console.ClientConsoleApp
-
- getAtomicNumber() - Method in class com.hazelcast.console.ConsoleApp
-
- getAtomicReference(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getAtomicReference(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-
- getAtomicReference(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates cluster-wide atomic reference.
- getAtomicReference(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getAtomicReference(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getAtomicReferenceConfig(String) - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getAtomicReferenceConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the AtomicReferenceConfig for the given name, creating one
if necessary and adding it to the collection of known configurations.
- getAtomicReferenceConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getAtomicReferenceConfigs() - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getAtomicReferenceConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of AtomicReference configurations, mapped by config name.
- getAtomicReferenceConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
-
- getAtomicReferenceConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
-
Returns all registered AtomicReference configurations.
- getAtomicReferenceConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getAttribute(Node, String) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- getAttribute() - Method in class com.hazelcast.config.MapIndexConfig
-
Gets the attribute that is going to be indexed.
- getAttribute(String) - Method in class com.hazelcast.instance.AbstractMember
-
- getAttribute(String) - Method in class com.hazelcast.internal.jmx.HazelcastMBean
-
- getAttribute() - Method in class com.hazelcast.query.PredicateBuilder
-
- getAttributeName() - Method in interface com.hazelcast.query.impl.Index
-
- getAttributeName() - Method in class com.hazelcast.query.impl.IndexImpl
-
- getAttributeName() - Method in class com.hazelcast.query.impl.IndexInfo
-
- getAttributes() - Method in class com.hazelcast.config.MemberAttributeConfig
-
- getAttributes() - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
-
Deprecated.
- getAttributes() - Method in interface com.hazelcast.core.Member
-
Returns configured attributes for this member.
This method might not be available on all native clients.
- getAttributes() - Method in class com.hazelcast.instance.AbstractMember
-
- getAttributes() - Method in class com.hazelcast.internal.cluster.impl.JoinRequest
-
- getAttributes() - Method in class com.hazelcast.internal.cluster.MemberInfo
-
- getAttributes(String[]) - Method in class com.hazelcast.internal.jmx.HazelcastMBean
-
- getAttributeType(String) - Method in interface com.hazelcast.query.impl.Extractable
-
- getAttributeType(Class) - Static method in class com.hazelcast.query.impl.getters.ReflectionHelper
-
- getAttributeType(String) - Method in class com.hazelcast.query.impl.QueryableEntry
-
- getAttributeValue(String) - Method in interface com.hazelcast.query.impl.Extractable
-
- getAttributeValue(String) - Method in class com.hazelcast.query.impl.QueryableEntry
-
- getAuthenticationCorrelationId() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- getAvailable() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
-
- getAvailable() - Method in class com.hazelcast.internal.jmx.SemaphoreMBean
-
- getAvailableMemory() - Method in class com.hazelcast.map.impl.eviction.EvictionChecker
-
- getAverageGetTime() - Method in interface com.hazelcast.cache.CacheStatistics
-
The mean time to execute gets.
- getAverageGetTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getAverageGetTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- getAverageGetTime() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- getAverageGetTime() - Method in interface com.hazelcast.monitor.LocalCacheStats
-
Returns the mean time to execute gets on the cache.
- getAveragePutTime() - Method in interface com.hazelcast.cache.CacheStatistics
-
The mean time to execute puts.
- getAveragePutTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getAveragePutTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- getAveragePutTime() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- getAveragePutTime() - Method in interface com.hazelcast.monitor.LocalCacheStats
-
Returns the mean time to execute puts on the cache.
- getAverageRemoveTime() - Method in interface com.hazelcast.cache.CacheStatistics
-
The mean time to execute removes.
- getAverageRemoveTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getAverageRemoveTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- getAverageRemoveTime() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- getAverageRemoveTime() - Method in interface com.hazelcast.monitor.LocalCacheStats
-
Returns the mean time to execute removes on the cache.
- getAvgAge() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- getAvgAge() - Method in interface com.hazelcast.monitor.LocalQueueStats
-
Returns the average age of the items in this member.
- getAwsConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
- getAwsConfig() - Method in class com.hazelcast.config.JoinConfig
-
- getAwsConfig() - Method in class com.hazelcast.config.WanPublisherConfig
-
- getBackupAcks() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.NormalResponse
-
Returns the number of backups that needs to acknowledge before the invocation completes.
- getBackupCount() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorContainer
-
- getBackupCount() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- getBackupCount() - Method in interface com.hazelcast.concurrent.lock.LockStoreInfo
-
- getBackupCount() - Method in class com.hazelcast.config.CacheConfig
-
Gets the number of synchronous backups for this
ICache
.
- getBackupCount() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the number of synchronous backups for this
ICache
.
- getBackupCount() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
Gets the number of synchronous backups.
- getBackupCount() - Method in class com.hazelcast.config.CollectionConfig
-
Gets the number of synchronous backups for this collection.
- getBackupCount() - Method in class com.hazelcast.config.MapConfig
-
Returns the backupCount for this
IMap
- getBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
-
Gets the number of synchronous backups for this MultiMap.
- getBackupCount() - Method in class com.hazelcast.config.QueueConfig
-
Get the number of synchronous backups for this queue.
- getBackupCount() - Method in class com.hazelcast.config.RingbufferConfig
-
Gets the number of synchronous backups.
- getBackupCount() - Method in class com.hazelcast.config.SemaphoreConfig
-
Returns the number of synchronous backups.
- getBackupCount() - Method in class com.hazelcast.map.impl.MapContainer
-
- getBackupCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getBackupCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getBackupCount() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the number of backups per entry.
- getBackupDir() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Base directory for hot backups.
- getBackupEntryCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getBackupEntryCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getBackupEntryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the number of backup entries hold by this member.
- getBackupEntryMemoryCost() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getBackupEntryMemoryCost() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getBackupEntryMemoryCost() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns memory cost (number of bytes) of backup entries in this member.
- getBackupHandler() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-
- getBackupItemCount() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- getBackupItemCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
-
Returns the number of backup items in this member.
- getBackupMap() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-
Return the map containing queue items when this instance is
a backup replica.
- getBackupOp() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
-
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperation
-
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
-
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
-
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
-
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheLegacyMergeOperation
-
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheMergeOperation
-
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CachePutAllOperation
-
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
-
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CachePutOperation
-
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
-
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveOperation
-
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheReplaceOperation
-
- getBackupOperation() - Method in class com.hazelcast.cardinality.impl.operations.AggregateOperation
-
- getBackupOperation() - Method in class com.hazelcast.cardinality.impl.operations.MergeOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionClearOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionCompareAndRemoveOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionMergeOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionRemoveOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.list.operations.ListAddOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.list.operations.ListRemoveOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.list.operations.ListSetOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.queue.operations.AddAllOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.queue.operations.ClearOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.queue.operations.DrainOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.queue.operations.OfferOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.queue.operations.PollOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.queue.operations.QueueMergeOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.queue.operations.RemoveOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnCommitOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPollOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPrepareOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.MergeOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.SetOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomicreference.operations.MergeOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetAndGetOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.lock.operations.LockOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.lock.operations.SignalOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.IncreaseOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.InitOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDetachMemberOperation
-
- getBackupOperation() - Method in class com.hazelcast.durableexecutor.impl.operations.DisposeResultOperation
-
- getBackupOperation() - Method in class com.hazelcast.durableexecutor.impl.operations.PutResultOperation
-
- getBackupOperation() - Method in class com.hazelcast.durableexecutor.impl.operations.TaskOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.BasePutOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.BaseRemoveOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.ClearOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.EntryOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.EvictOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.LegacyMergeOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.MapFlushOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.MergeOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.MultipleEntryWithPredicateOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.PutAllOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.operations.ClearOperation
-
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.operations.DeleteOperation
-
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.operations.MergeOperation
-
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.operations.PutOperation
-
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.operations.RemoveAllOperation
-
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.operations.RemoveOperation
-
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.txn.TxnCommitOperation
-
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareOperation
-
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.txn.TxnPutOperation
-
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
-
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
-
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.txn.TxnRollbackOperation
-
- getBackupOperation() - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
-
- getBackupOperation() - Method in class com.hazelcast.ringbuffer.impl.operations.AddOperation
-
- getBackupOperation() - Method in class com.hazelcast.ringbuffer.impl.operations.MergeOperation
-
- getBackupOperation() - Method in class com.hazelcast.scheduledexecutor.impl.operations.CancelTaskOperation
-
- getBackupOperation() - Method in class com.hazelcast.scheduledexecutor.impl.operations.DisposeTaskOperation
-
- getBackupOperation() - Method in class com.hazelcast.scheduledexecutor.impl.operations.MergeOperation
-
- getBackupOperation() - Method in class com.hazelcast.scheduledexecutor.impl.operations.ScheduleTaskOperation
-
- getBackupOperation() - Method in class com.hazelcast.scheduledexecutor.impl.operations.SyncStateOperation
-
- getBackupOperation() - Method in interface com.hazelcast.spi.BackupAwareOperation
-
- getBackupOperation() - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
-
- getBackupOperation() - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionOperation
-
- getBackupOperation() - Method in class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionOperation
-
- getBackupProcessor() - Method in class com.hazelcast.map.AbstractEntryProcessor
-
- getBackupProcessor() - Method in interface com.hazelcast.map.EntryProcessor
-
Get the entry processor to be applied to backup entries.
- getBackupTaskStatus() - Method in interface com.hazelcast.hotrestart.HotRestartService
-
Returns the local hot restart backup task status (not the cluster backup status).
- getBackupTaskStatus() - Method in class com.hazelcast.hotrestart.NoOpHotRestartService
-
- getBackupTaskStatus() - Method in interface com.hazelcast.monitor.HotRestartState
-
Returns the local hot restart backup task status (not the cluster backup status).
- getBackupTaskStatus() - Method in class com.hazelcast.monitor.impl.HotRestartStateImpl
-
- getBalancerIntervalSeconds() - Method in interface com.hazelcast.nio.IOService
-
- getBalancerIntervalSeconds() - Method in class com.hazelcast.nio.NodeIOService
-
- getBaseDir() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Base directory for all Hot Restart stores.
- getBaseName(String) - Static method in class com.hazelcast.partition.strategy.StringPartitioningStrategy
-
- getBatch() - Method in class com.hazelcast.map.impl.iterator.AbstractCursor
-
- getBatchCount() - Method in class com.hazelcast.monitor.impl.LocalFlakeIdGeneratorStatsImpl
-
- getBatchCount() - Method in interface com.hazelcast.monitor.LocalFlakeIdGeneratorStats
-
- getBatchEventData() - Method in class com.hazelcast.map.impl.querycache.event.BatchIMapEvent
-
- getBatchSize() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
-
- getBatchSize() - Method in class com.hazelcast.config.MergePolicyConfig
-
Returns the batch size, which will be used to determine the number of entries to be sent in a merge operation.
- getBatchSize() - Method in class com.hazelcast.config.QueryCacheConfig
-
After reaching this size, node sends buffered events to QueryCache
.
- getBatchSize() - Method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
-
- getBatchSize(String) - Method in class com.hazelcast.spi.impl.merge.AbstractMergeRunnable
-
This batch size can only be used with
SplitBrainMergePolicy
,
legacy merge policies don't support batch data sending.
- getBindAddress() - Method in interface com.hazelcast.instance.AddressPicker
-
Returns a server socket listener address.
- getBindAddress() - Method in class com.hazelcast.instance.DelegatingAddressPicker
-
- getBindAddress() - Method in interface com.hazelcast.spi.MemberAddressProvider
-
What address should Hazelcast bind to.
- getBindings() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
-
- getBlacklist() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
-
- getBlacklistedPrefixes() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Return currently configured blacklist prefixes.
- getBoolean() - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-
- getBoolean(Object, long) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Returns the boolean value at the supplied offset from the supplied object's base address.
- getBoolean(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- getBoolean(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- getBoolean(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- getBoolean(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- getBoolean(long) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
-
Reads the boolean value from given address.
- getBoolean(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
- getBoolean(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
-
Returns a field in a Json object as a boolean.
- getBoolean(JsonObject, String, boolean) - Static method in class com.hazelcast.util.JsonUtil
-
Returns a field in a Json object as a boolean.
- getBooleanAttribute(String) - Method in class com.hazelcast.client.impl.MemberImpl
-
- getBooleanAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- getBooleanAttribute(String) - Method in interface com.hazelcast.core.Member
-
Returns the value of the specified key for this member, or
null if the value is undefined.
- getBooleanAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
-
- getBooleanValue(String) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- getBooleanVolatile(Object, long) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
-
Reads the boolean value as volatile from given object by its offset.
- getBooleanVolatile(long) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
-
Reads the boolean value as volatile from given object by its offset.
- getBooleanVolatile(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- getBooleanVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- getBooleanVolatile(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- getBooleanVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- getBranchQualifier() - Method in class com.hazelcast.transaction.impl.xa.SerializableXID
-
- getBrokenSequences() - Method in class com.hazelcast.map.impl.querycache.subscriber.SubscriberAccumulator
-
- getBufferSize() - Method in class com.hazelcast.client.config.SocketOptions
-
Gets the SO_SNDBUF and SO_RCVBUF options to the specified value in KB
- getBufferSize() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
-
- getBufferSize() - Method in class com.hazelcast.config.QueryCacheConfig
-
Returns the maximum number of events which can be stored in a buffer of partition.
- getBufferSize() - Method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
-
- getBuild() - Method in class com.hazelcast.instance.BuildInfo
-
- getBuild() - Method in class com.hazelcast.instance.JetBuildInfo
-
- getBuild() - Method in class com.hazelcast.internal.jmx.InstanceMBean
-
- getBuildInfo() - Static method in class com.hazelcast.instance.BuildInfoProvider
-
Parses hazelcast-runtime.properties
for BuildInfo
; also checks for overrides in System.properties.
- getBuildInfo() - Method in class com.hazelcast.instance.Node
-
- getBuildNumber() - Method in class com.hazelcast.instance.BuildInfo
-
- getBuildNumber() - Method in class com.hazelcast.internal.cluster.impl.JoinMessage
-
- getBuiltinDefinitions() - Method in class com.hazelcast.internal.partition.impl.PartitionPortableHook
-
- getBuiltinDefinitions() - Method in interface com.hazelcast.internal.serialization.PortableHook
-
- getBuiltinDefinitions() - Method in class com.hazelcast.map.impl.client.MapPortableHook
-
- getBuiltinDefinitions() - Method in class com.hazelcast.mapreduce.impl.MapReducePortableHook
-
- getBuiltinDefinitions() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- getBuiltinDefinitions() - Method in class com.hazelcast.ringbuffer.impl.client.RingbufferPortableHook
-
- getBuiltinDefinitions() - Method in class com.hazelcast.spi.impl.SpiPortableHook
-
- getBulkLoad() - Method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
-
- getByCompositeKey(K) - Method in class com.hazelcast.util.scheduler.SecondsBasedEntryTaskScheduler
-
Returns one scheduled entry for the given key
with no guaranteed ordering
- getById(int) - Static method in enum com.hazelcast.client.impl.protocol.AuthenticationStatus
-
- getById(int) - Static method in enum com.hazelcast.config.WanAcknowledgeType
-
- getById(int) - Static method in enum com.hazelcast.ringbuffer.OverflowPolicy
-
Returns the OverflowPolicy for the given ID.
- getById(int) - Static method in enum com.hazelcast.scheduledexecutor.impl.TaskDefinition.Type
-
- getById(byte) - Static method in enum com.hazelcast.util.IterationType
-
Returns the IterationType for the given ID.
- getByStatus(int) - Static method in enum com.hazelcast.wan.WanSyncStatus
-
- getByte(int) - Method in interface com.hazelcast.client.impl.protocol.util.ClientProtocolBuffer
-
Get the value at a given index.
- getByte() - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-
- getByte(int) - Method in class com.hazelcast.client.impl.protocol.util.SafeBuffer
-
- getByte(int) - Method in class com.hazelcast.client.impl.protocol.util.UnsafeBuffer
-
- getByte(R, long) - Method in interface com.hazelcast.internal.memory.ByteAccessStrategy
-
Return byte from external resource
- getByte(Object, long) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Returns the byte value at the supplied offset from the supplied object's base address.
- getByte(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- getByte(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- getByte(byte[], long) - Method in class com.hazelcast.internal.memory.impl.ByteArrayAccessStrategy
-
- getByte(MemoryAccessor, long) - Method in class com.hazelcast.internal.memory.impl.CustomByteAccessStrategy
-
- getByte(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- getByte(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- getByte(long) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
-
Reads the byte value from given address.
- getByteArray() - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-
- getByteArray(String, String) - Method in interface com.hazelcast.internal.ascii.TextCommandService
-
- getByteArray(String, String) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-
- getByteAttribute(String) - Method in class com.hazelcast.client.impl.MemberImpl
-
- getByteAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- getByteAttribute(String) - Method in interface com.hazelcast.core.Member
-
Returns the value of the specified key for this member or
null if the value is undefined.
- getByteAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
-
- getByteBuffer() - Method in class com.hazelcast.internal.networking.InitResult
-
- getByteOrder() - Method in class com.hazelcast.config.SerializationConfig
-
Note that result of useNativeByteOrder is not reflected to return value of this method.
- getByteOrder() - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-
- getByteOrder() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-
- getByteOrder() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
-
- getByteOrder() - Method in interface com.hazelcast.internal.serialization.InputOutputFactory
-
- getByteOrder() - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
-
Returns the byte order used when serializing/deserializing objects.
- getByteOrder() - Method in interface com.hazelcast.internal.serialization.PortableContext
-
- getByteOrder() - Method in interface com.hazelcast.nio.ObjectDataInput
-
- getByteOrder() - Method in interface com.hazelcast.nio.ObjectDataOutput
-
- getBytes(int, byte[]) - Method in interface com.hazelcast.client.impl.protocol.util.ClientProtocolBuffer
-
Get from the underlying buffer into a supplied byte array.
- getBytes(int, byte[], int, int) - Method in interface com.hazelcast.client.impl.protocol.util.ClientProtocolBuffer
-
Get bytes from the underlying buffer into a supplied byte array.
- getBytes(int, byte[]) - Method in class com.hazelcast.client.impl.protocol.util.SafeBuffer
-
- getBytes(int, byte[], int, int) - Method in class com.hazelcast.client.impl.protocol.util.SafeBuffer
-
- getBytes(int, byte[]) - Method in class com.hazelcast.client.impl.protocol.util.UnsafeBuffer
-
- getBytes(int, byte[], int, int) - Method in class com.hazelcast.client.impl.protocol.util.UnsafeBuffer
-
- getBytes() - Method in class com.hazelcast.internal.ascii.memcache.MemcacheEntry
-
- getBytes() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-
- getByteVolatile(Object, long) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
-
Reads the byte value as volatile from given object by its offset.
- getByteVolatile(long) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
-
Reads the byte value as volatile from given object by its offset.
- getByteVolatile(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- getByteVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- getByteVolatile(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- getByteVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- getByType(int) - Static method in enum com.hazelcast.cache.CacheEventType
-
- getByType(int) - Static method in enum com.hazelcast.config.WANQueueFullBehavior
-
Returns the EntryEventType as an enum.
- getByType(int) - Static method in enum com.hazelcast.core.EntryEventType
-
- getByType(int) - Static method in enum com.hazelcast.core.ItemEventType
-
- getByValue(int) - Static method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
-
- getCache(String, Class<K>, Class<V>) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- getCache(String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- getCache(String) - Method in class com.hazelcast.client.impl.ClientICacheManager
-
- getCache(String) - Method in interface com.hazelcast.core.ICacheManager
-
Returns the cache instance with the specified prefixed cache name.
- getCache(String) - Method in class com.hazelcast.instance.HazelcastInstanceCacheManager
-
- getCache(String) - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
-
- getCacheByFullName(String) - Method in class com.hazelcast.client.impl.ClientICacheManager
-
- getCacheByFullName(String) - Method in class com.hazelcast.instance.HazelcastInstanceCacheManager
-
- getCacheConfig(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- getCacheConfig(String, String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- getCacheConfig(String, String) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
-
- getCacheConfig(String) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- getCacheConfig(String, String) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
-
- getCacheConfig(String) - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getCacheConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the CacheSimpleConfig for the given name, creating one
if necessary and adding it to the collection of known configurations.
- getCacheConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getCacheConfigs() - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- getCacheConfigs() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-
- getCacheConfigs() - Method in interface com.hazelcast.cache.impl.ICacheService
-
- getCacheConfigs() - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getCacheConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of cache configurations, mapped by config name.
- getCacheConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getCacheContext(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- getCacheDeserializedValues() - Method in class com.hazelcast.config.MapConfig
-
Get current value cache settings
- getCachedValue(Record) - Static method in class com.hazelcast.map.impl.record.Records
-
Get current cached value from the record.
- getCachedValueUnsafe() - Method in class com.hazelcast.map.impl.record.AbstractRecord
-
- getCachedValueUnsafe() - Method in interface com.hazelcast.map.impl.record.Record
-
Get current cache value or null.
- getCacheEntryEventFilterFactory() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- getCacheEntryListener() - Method in interface com.hazelcast.cache.impl.CacheEntryListenerProvider
-
Gets wrapped CacheEntryListener
- getCacheEntryListener() - Method in class com.hazelcast.cache.impl.CacheEventListenerAdaptor
-
- getCacheEntryListenerConfigurations() - Method in class com.hazelcast.config.AbstractCacheConfig
-
- getCacheEntryListenerConfigurations() - Method in class com.hazelcast.config.CacheConfigReadOnly
-
Deprecated.
- getCacheEntryListenerCount() - Method in class com.hazelcast.cache.impl.CacheContext
-
- getCacheEntryListenerFactory() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- getCacheEntryListeners() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- getCacheEntryListeners() - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-
Deprecated.
- GetCacheEntryRequest - Class in com.hazelcast.internal.management.request
-
Request for fetching cache entries.
- GetCacheEntryRequest() - Constructor for class com.hazelcast.internal.management.request.GetCacheEntryRequest
-
- GetCacheEntryRequest(String, String, String) - Constructor for class com.hazelcast.internal.management.request.GetCacheEntryRequest
-
- GetCacheEntryRequest.CacheBrowserEntryView - Class in com.hazelcast.internal.management.request
-
- GetCacheEntryRequest.GetCacheEntryViewEntryProcessor - Class in com.hazelcast.internal.management.request
-
- GetCacheEntryViewEntryProcessor() - Constructor for class com.hazelcast.internal.management.request.GetCacheEntryRequest.GetCacheEntryViewEntryProcessor
-
- getCacheEventHandler() - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- getCacheEventJournalConfig(String) - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getCacheEventJournalConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the cache event journal config for the given name, creating one
if necessary and adding it to the collection of known configurations.
- getCacheEventJournalConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getCacheEventJournalConfigs() - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getCacheEventJournalConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of cache event journal configurations, mapped by config
name.
- getCacheEventJournalConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
-
- getCacheEventJournalConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
-
Returns all registered CacheEventJournal configurations.
- getCacheEventJournalConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getCacheEventType() - Method in interface com.hazelcast.cache.impl.CacheEventData
-
Gets cache event type of this event data.
- getCacheEventType() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-
- getCacheEvictions() - Method in interface com.hazelcast.cache.CacheStatistics
-
The total number of evictions from the cache.
- getCacheEvictions() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getCacheEvictions() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- getCacheEvictions() - Method in class com.hazelcast.client.cache.impl.ClientCacheStatisticsImpl
-
- getCacheEvictions() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- getCacheEvictions() - Method in interface com.hazelcast.monitor.LocalCacheStats
-
Returns the number of evictions on the cache.
- getCacheExpiries() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
The total number of expiries from the cache.
- getCacheExpiries() - Method in class com.hazelcast.client.cache.impl.ClientCacheStatisticsImpl
-
- getCacheGets() - Method in interface com.hazelcast.cache.CacheStatistics
-
The total number of requests to the cache.
- getCacheGets() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getCacheGets() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- getCacheGets() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- getCacheGets() - Method in interface com.hazelcast.monitor.LocalCacheStats
-
Returns the number of gets on the cache.
- getCacheGetTimeTakenNanos() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getCacheHitPercentage() - Method in interface com.hazelcast.cache.CacheStatistics
-
This is a measure of cache efficiency.
- getCacheHitPercentage() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getCacheHitPercentage() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- getCacheHitPercentage() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- getCacheHitPercentage() - Method in interface com.hazelcast.monitor.LocalCacheStats
-
Returns the percentage of hits (successful get operations) on the cache.
- getCacheHits() - Method in interface com.hazelcast.cache.CacheStatistics
-
The number of get requests that were satisfied by the cache.
- getCacheHits() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getCacheHits() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- getCacheHits() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- getCacheHits() - Method in interface com.hazelcast.monitor.LocalCacheStats
-
Returns the number of hits (successful get operations) on the cache.
- getCacheId() - Method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
-
- getCacheId() - Method in interface com.hazelcast.map.impl.querycache.subscriber.InternalQueryCache
-
- getCacheId() - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
-
- getCacheLoader() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Get classname of a class to be used as CacheLoader
.
- getCacheLoaderFactory() - Method in class com.hazelcast.config.AbstractCacheConfig
-
- getCacheLoaderFactory() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the factory for the CacheLoader
.
- getCacheManager(URI, ClassLoader, Properties) - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- getCacheManager(URI, ClassLoader) - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- getCacheManager() - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- getCacheManager(URI, ClassLoader, Properties) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- getCacheManager(URI, ClassLoader) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- getCacheManager() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- getCacheManager() - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-
- getCacheManager() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getCacheManager() - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-
- getCacheManager() - Method in interface com.hazelcast.core.HazelcastInstance
-
Obtain the
ICacheManager
that provides access to JSR-107 (JCache) caches configured on a Hazelcast cluster.
- getCacheManager() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getCacheManager() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getCacheManager(HazelcastInstance, String, Properties) - Static method in class com.hazelcast.spring.cache.SpringHazelcastCachingProvider
-
Creates a CacheManager
on an existing HazelcastInstance.
- getCacheManager(String, Properties) - Static method in class com.hazelcast.spring.cache.SpringHazelcastCachingProvider
-
- getCacheMisses() - Method in interface com.hazelcast.cache.CacheStatistics
-
A miss is a get request that is not satisfied.
- getCacheMisses() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getCacheMisses() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- getCacheMisses() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- getCacheMisses() - Method in interface com.hazelcast.monitor.LocalCacheStats
-
Returns the number of missed cache accesses on the cache.
- getCacheMissPercentage() - Method in interface com.hazelcast.cache.CacheStatistics
-
Returns the percentage of cache accesses that did not find a requested entry
in the cache.
- getCacheMissPercentage() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getCacheMissPercentage() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- getCacheMissPercentage() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- getCacheMissPercentage() - Method in interface com.hazelcast.monitor.LocalCacheStats
-
Returns the percentage of missed cache accesses on the cache.
- getCacheName() - Method in class com.hazelcast.cache.impl.CacheEventContext
-
- getCacheName() - Method in class com.hazelcast.config.EventJournalConfig
-
Returns the cache name to which this config applies.
- getCacheName() - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheRequest
-
- getCacheNames() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- getCacheNames() - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
-
- getCacheNameWithPrefix(String) - Method in interface com.hazelcast.cache.HazelcastCacheManager
-
Gets cache name by adding manager prefix.
- getCacheNameWithPrefix(String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- getCacheOperationProvider(String, InMemoryFormat) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- getCacheOperationProvider(String, InMemoryFormat) - Method in interface com.hazelcast.cache.impl.ICacheService
-
Creates cache operations according to the storage-type of the cache
- getCachePuts() - Method in interface com.hazelcast.cache.CacheStatistics
-
The total number of puts to the cache.
- getCachePuts() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getCachePuts() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- getCachePuts() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- getCachePuts() - Method in interface com.hazelcast.monitor.LocalCacheStats
-
Returns the number of puts to the queue.
- getCachePutTimeTakenNanos() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getCacheRemovals() - Method in interface com.hazelcast.cache.CacheStatistics
-
The total number of removals from the cache.
- getCacheRemovals() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getCacheRemovals() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- getCacheRemovals() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- getCacheRemovals() - Method in interface com.hazelcast.monitor.LocalCacheStats
-
Returns the number of removals from the queue.
- getCacheRemoveTimeTakenNanos() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getCacheService() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-
- getCacheService() - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
-
- getCacheSimpleConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
-
- getCacheSimpleConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
-
Returns all registered cache configurations.
- getCacheStats() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- getCacheStats() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Gets the Cache statistics associated with this
CacheService
.
- getCacheTimeTakenNanos - Variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getCacheUnchecked(String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- getCacheWanEventPublisher() - Method in class com.hazelcast.cache.impl.CacheService
-
- getCacheWanEventPublisher() - Method in interface com.hazelcast.cache.impl.ICacheService
-
Returns the WAN event publisher responsible for publishing
primary and backup WAN events for caches.
- getCacheWriter() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Get classname of a class to be used as CacheWriter
.
- getCacheWriterFactory() - Method in class com.hazelcast.config.AbstractCacheConfig
-
- getCacheWriterFactory() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the factory for the CacheWriter
.
- getCachingProvider() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- getCaller() - Method in class com.hazelcast.collection.impl.collection.CollectionEvent
-
- getCaller() - Method in interface com.hazelcast.map.impl.event.EventData
-
- getCaller() - Method in class com.hazelcast.map.impl.querycache.event.BatchEventData
-
- getCaller() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-
- getCaller() - Method in class com.hazelcast.map.impl.querycache.event.LocalCacheWideEventData
-
- getCaller() - Method in class com.hazelcast.map.impl.querycache.event.LocalEntryEventData
-
- getCallerAddress() - Method in class com.hazelcast.spi.Operation
-
- getCallerUuid() - Method in class com.hazelcast.spi.Operation
-
- getCallerUuid() - Method in class com.hazelcast.transaction.impl.operations.CreateTxBackupLogOperation
-
- getCallId() - Method in class com.hazelcast.client.spi.impl.listener.ClientEventRegistration
-
Call ID of first event registration request
- getCallId() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.Response
-
Returns the call ID of the operation this response belongs to.
- getCallId() - Method in class com.hazelcast.spi.Operation
-
Gets the call ID of this operation.
- getCallIdSequence() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getCallTimeout() - Method in class com.hazelcast.spi.InvocationBuilder
-
- getCallTimeout() - Method in class com.hazelcast.spi.Operation
-
Gets the call timeout in milliseconds.
- getCancelledTaskCount() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-
- getCancelledTaskCount() - Method in interface com.hazelcast.monitor.LocalExecutorStats
-
Returns the number of cancelled operations on the executor service.
- getCapacity() - Method in class com.hazelcast.config.DurableExecutorConfig
-
Gets the ring buffer capacity of the executor task.
- getCapacity() - Method in class com.hazelcast.config.EventJournalConfig
-
Gets the capacity of the event journal.
- getCapacity() - Method in class com.hazelcast.config.RingbufferConfig
-
Gets the capacity of the ringbuffer.
- getCapacity() - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Gets the capacity of the executor
- getCapacity() - Method in class com.hazelcast.ringbuffer.impl.ArrayRingbuffer
-
- getCapacity() - Method in interface com.hazelcast.ringbuffer.impl.Ringbuffer
-
Returns the capacity of this ringbuffer.
- getCapacity() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-
Returns the capacity of this ringbuffer.
- getCapacity() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
-
Returns the capacity of this ringbuffer.
- getCardinalityEstimator(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getCardinalityEstimator(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-
- getCardinalityEstimator(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
- getCardinalityEstimator(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getCardinalityEstimator(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getCardinalityEstimatorConfig(String) - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getCardinalityEstimatorConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the CardinalityEstimatorConfig for the given name, creating one
if necessary and adding it to the collection of known configurations.
- getCardinalityEstimatorConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getCardinalityEstimatorConfigs() - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getCardinalityEstimatorConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of cardinality estimator configurations, mapped by config
name.
- getCardinalityEstimatorConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
-
- getCardinalityEstimatorConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
-
Returns all registered cardinality estimator configurations.
- getCardinalityEstimatorConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getCardinalityEstimatorContainer(String) - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorService
-
- getCardinalityEstimatorContainer() - Method in class com.hazelcast.cardinality.impl.operations.AbstractCardinalityEstimatorOperation
-
- getCause() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.ErrorResponse
-
- getChannel() - Method in class com.hazelcast.internal.networking.nio.NioPipeline
-
- getChannel() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- getChannelFactory() - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- getChannelFactory() - Method in interface com.hazelcast.instance.NodeExtension
-
Returns ChannelFactory instance to be used by this Node.
- getChannelFactory() - Method in interface com.hazelcast.nio.IOService
-
- getChannelFactory() - Method in class com.hazelcast.nio.NodeIOService
-
- getChar(Object, long) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Returns the char value at the supplied offset from the supplied object's base address.
- getChar(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- getChar(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- getChar(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- getChar(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- getChar(long) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
-
Reads the char value from given address.
- getCharVolatile(Object, long) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
-
Reads the char value as volatile from given object by its offset.
- getCharVolatile(long) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
-
Reads the char value as volatile from given object by its offset.
- getCharVolatile(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- getCharVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- getCharVolatile(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- getCharVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- getChunk() - Method in class com.hazelcast.mapreduce.impl.notification.IntermediateChunkNotification
-
- getChunk() - Method in class com.hazelcast.mapreduce.impl.notification.LastChunkNotification
-
- getChunkSize() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.AbstractMapReduceTask
-
- getChunkSize() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForCustomMessageTask
-
- getChunkSize() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForListMessageTask
-
- getChunkSize() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMapMessageTask
-
- getChunkSize() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMultiMapMessageTask
-
- getChunkSize() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForSetMessageTask
-
- getChunkSize() - Method in class com.hazelcast.config.JobTrackerConfig
-
Gets the number of emitted values before a chunk is send to the reducers.
- getChunkSize() - Method in class com.hazelcast.mapreduce.impl.task.JobTaskConfiguration
-
- getChunkSize() - Method in class com.hazelcast.mapreduce.impl.task.MapCombineTask
-
- getClassCacheMode() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Return the current ClassCacheMode
- getClassDataOrNull(String) - Method in class com.hazelcast.internal.usercodedeployment.impl.ClassDataProvider
-
- getClassDataOrNull(String) - Method in class com.hazelcast.internal.usercodedeployment.UserCodeDeploymentService
-
- getClassDefinitionList() - Method in class com.hazelcast.client.spi.impl.ClientUserCodeDeploymentService
-
- getClassDefinitions() - Method in class com.hazelcast.config.SerializationConfig
-
- getClasses() - Method in class com.hazelcast.config.ClassFilter
-
Returns unmodifiable set of class names.
- getClassId() - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
-
- getClassId() - Method in class com.hazelcast.internal.serialization.impl.FieldDefinitionImpl
-
- getClassId() - Method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
-
- getClassId() - Method in class com.hazelcast.mapreduce.impl.task.TransferableJobProcessInformation
-
- getClassId() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Returns the class ID.
- getClassId() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- getClassId() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
-
- getClassId() - Method in interface com.hazelcast.nio.serialization.Portable
-
Returns class identifier for this portable class.
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntries
-
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapKeys
-
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
-
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapValueCollection
-
- getClassId() - Method in class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
-
- getClassId() - Method in class com.hazelcast.security.UsernamePasswordCredentials
-
- getClassId() - Method in class com.hazelcast.spi.impl.PortableCachePartitionLostEvent
-
- getClassId() - Method in class com.hazelcast.spi.impl.PortableCollection
-
- getClassId() - Method in class com.hazelcast.spi.impl.PortableDistributedObjectEvent
-
- getClassId() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
-
- getClassId() - Method in class com.hazelcast.spi.impl.PortableItemEvent
-
- getClassId() - Method in class com.hazelcast.spi.impl.PortableMapPartitionLostEvent
-
- getClassId() - Method in class com.hazelcast.spi.impl.PortablePartitionLostEvent
-
- getClassLoader() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- getClassLoader() - Method in class com.hazelcast.client.config.ClientConfig
-
Gets the classLoader
- getClassLoader() - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getClassLoader() - Method in class com.hazelcast.config.Config
-
Returns the class-loader that will be used in serialization.
- getClassLoader() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getClassLoader() - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
-
- getClassLoader() - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService.Builder
-
- getClassLoader() - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-
- getClassLoader() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-
- getClassLoader() - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
-
- getClassLoader() - Method in interface com.hazelcast.nio.ObjectDataInput
-
Returns class loader that internally used for objects.
- getClassName() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
-
- getClassName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.ListenerConfigHolder
-
- getClassName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
-
- getClassName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.PredicateConfigHolder
-
- getClassName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueueStoreConfigHolder
-
- getClassName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.RingbufferStoreConfigHolder
-
- getClassName() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
-
- getClassName() - Method in class com.hazelcast.config.CredentialsFactoryConfig
-
- getClassName() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
-
- getClassName() - Method in class com.hazelcast.config.GlobalSerializerConfig
-
- getClassName() - Method in class com.hazelcast.config.ListenerConfig
-
Returns the name of the class of the EventListener.
- getClassName() - Method in class com.hazelcast.config.LoginModuleConfig
-
- getClassName() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns the name of the MapStore implementation class
- getClassName() - Method in class com.hazelcast.config.MemberAddressProviderConfig
-
- getClassName() - Method in class com.hazelcast.config.PermissionPolicyConfig
-
- getClassName() - Method in class com.hazelcast.config.PredicateConfig
-
Returns the name of the class of the Predicate.
- getClassName() - Method in class com.hazelcast.config.QueueStoreConfig
-
- getClassName() - Method in class com.hazelcast.config.RingbufferStoreConfig
-
- getClassName() - Method in class com.hazelcast.config.SecurityInterceptorConfig
-
- getClassName() - Method in class com.hazelcast.config.SerializerConfig
-
Returns the class name of the serializer implementation.
- getClassName() - Method in class com.hazelcast.config.ServiceConfig
-
- getClassName() - Method in class com.hazelcast.config.SocketInterceptorConfig
-
- getClassName() - Method in class com.hazelcast.config.WanConsumerConfig
-
Get the fully qualified class name of the class implementing WanReplicationConsumer.
- getClassName() - Method in class com.hazelcast.config.WanPublisherConfig
-
- getClassNames() - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
-
- getClassType() - Method in class com.hazelcast.config.LegacyCacheConfig
-
- getClassType() - Method in class com.hazelcast.config.LegacyCacheEvictionConfig
-
- getClassType() - Method in interface com.hazelcast.nio.serialization.TypedDataSerializable
-
- getClassVersion(int, int) - Method in interface com.hazelcast.internal.serialization.PortableContext
-
- getClassVersion() - Method in interface com.hazelcast.nio.serialization.VersionedPortable
-
Returns version for this Portable class
- getClient() - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-
- getClient() - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientInvokerWrapper
-
- getClient() - Method in class com.hazelcast.client.proxy.txn.TransactionContextProxy
-
- getClient() - Method in class com.hazelcast.client.proxy.txn.xa.XATransactionContextProxy
-
- getClient() - Method in class com.hazelcast.client.spi.ClientProxy
-
- getClient() - Method in interface com.hazelcast.client.spi.ClientTransactionContext
-
- getClient() - Method in class com.hazelcast.client.spi.impl.ClientTransactionManagerServiceImpl
-
- getClientBlockUnmappedActions() - Method in class com.hazelcast.config.SecurityConfig
-
- getClientBlockUnmappedActions() - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
-
- getClientClusterService() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getClientConfig() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getClientConfig() - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-
- getClientConfig() - Method in class com.hazelcast.client.spi.ClientContext
-
- getClientEndpointCount() - Method in interface com.hazelcast.client.ClientEngine
-
- getClientEndpointCount() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getClientEndpointCount() - Method in class com.hazelcast.internal.jmx.ClientEngineMBean
-
- getClientEngine() - Method in interface com.hazelcast.nio.IOService
-
- getClientEngine() - Method in class com.hazelcast.nio.NodeIOService
-
- getClientEngineMBean() - Method in class com.hazelcast.internal.jmx.InstanceMBean
-
- getClientExceptionFactory() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getClientExceptionFactory() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getClientExecutionService() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getClientExecutorMBean() - Method in class com.hazelcast.internal.jmx.InstanceMBean
-
- getClientExtension() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getClientIcmpPingConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
ICMP ping is used to detect if machine that a remote hazelcast member runs on alive or not
- getClientLoginModuleConfigs() - Method in class com.hazelcast.config.SecurityConfig
-
- getClientLoginModuleConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
-
- getClientManagementExecutor() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getClientMessage() - Method in class com.hazelcast.client.spi.impl.ClientInvocation
-
- getClientPartitionService() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getClientPermissionConfigs() - Method in class com.hazelcast.config.SecurityConfig
-
- getClientPermissionConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
-
Returns existing client permissions as an unmodifiable
Set
.
- getClientPermissionConfigs() - Method in interface com.hazelcast.security.SecurityService
-
Returns latest client permission configuration.
- getClientPolicyConfig() - Method in class com.hazelcast.config.SecurityConfig
-
- getClientPolicyConfig() - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
-
- getClientProxyClass() - Method in interface com.hazelcast.client.spi.ClientProxyDescriptor
-
- getClientProxyFactory(String) - Method in class com.hazelcast.client.spi.ProxyManager
-
- getClients() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getClients() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- getClients() - Method in interface com.hazelcast.monitor.MemberState
-
- getClientService() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getClientService() - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-
- getClientService() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the client service of this Hazelcast instance.
- getClientService() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getClientService() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getClientStatistics() - Method in interface com.hazelcast.client.ClientEndpoint
-
- getClientStatistics() - Method in interface com.hazelcast.client.ClientEngine
-
The statistics is a String that is composed of key=value pairs separated by ',' .
- getClientStatistics() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- getClientStatistics() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getClientStats() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.AbstractTransactionalMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCommitMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCreateMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionRollbackMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListAddMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListRemoveMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListSizeMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapContainsKeyMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapDeleteMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetForUpdateMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapIsEmptyMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetWithPredicateMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutIfAbsentMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveIfSameMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceIfSameMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSetMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSizeMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesWithPredicateMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapGetMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapPutMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveEntryMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapSizeMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapValueCountMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueOfferMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePeekMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePollMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueSizeMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueTakeMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetAddMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetRemoveMessageTask
-
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetSizeMessageTask
-
- getClientType() - Method in class com.hazelcast.client.ClientEvent
-
- getClientType() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- getClientType() - Method in class com.hazelcast.client.impl.ClientImpl
-
- getClientType() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
-
- getClientType() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationCustomCredentialsMessageTask
-
- getClientType() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationMessageTask
-
- getClientType() - Method in interface com.hazelcast.core.Client
-
Returns the type of this client.
- getClientVersion() - Method in interface com.hazelcast.client.ClientEndpoint
-
- getClientVersion() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- getCloseCause() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-
- getCloseCause() - Method in interface com.hazelcast.nio.Connection
-
Gets the cause this Connection was closed.
- getCloseCause() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- getClosedTime() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-
Closed time is the first time connection.close called.
- getCloseReason() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-
- getCloseReason() - Method in interface com.hazelcast.nio.Connection
-
Gets the reason this Connection was closed.
- getCloseReason() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- getCluster() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getCluster() - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-
- getCluster() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the Cluster that this Hazelcast instance is part of.
- getCluster() - Method in class com.hazelcast.core.InitialMembershipEvent
-
Returns the cluster of the event.
- getCluster() - Method in class com.hazelcast.core.MembershipEvent
-
Returns the cluster of the event.
- getCluster() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getCluster() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getClusterClock() - Method in interface com.hazelcast.internal.cluster.ClusterService
-
- getClusterClock() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
-
- getClusterDataRecoveryPolicy() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Returns the policy to be used when the cluster is started
- getClusterHeartbeatManager() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
-
- getClusterHotRestartStatus() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- getClusterHotRestartStatus() - Method in interface com.hazelcast.monitor.MemberState
-
- getClusterId() - Method in interface com.hazelcast.internal.cluster.ClusterService
-
Returns UUID for the cluster.
- getClusterId() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
-
- getClusterJoinManager() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
-
- getClusterName() - Method in class com.hazelcast.internal.management.ManagementCenterIdentifier
-
- getClusterName() - Method in class com.hazelcast.monitor.TimedMemberState
-
- getClusterService() - Method in interface com.hazelcast.client.ClientEngine
-
- getClusterService() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getClusterService() - Method in class com.hazelcast.client.spi.ClientContext
-
- getClusterService() - Method in class com.hazelcast.instance.Node
-
- getClusterService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getClusterService() - Method in interface com.hazelcast.spi.NodeEngine
-
Gets the ClusterService.
- getClusterStartTime() - Method in class com.hazelcast.internal.cluster.impl.ClusterClockImpl
-
- getClusterState() - Method in class com.hazelcast.client.proxy.ClientClusterProxy
-
- getClusterState() - Method in interface com.hazelcast.core.Cluster
-
Returns the state of the cluster.
- getClusterState() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
-
- getClusterState() - Method in class com.hazelcast.monitor.impl.NodeStateImpl
-
- getClusterState() - Method in interface com.hazelcast.monitor.NodeState
-
- getClusterStateManager() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
-
- GetClusterStateRequest - Class in com.hazelcast.internal.management.request
-
Request coming from Management Center for getting the
ClusterState
- GetClusterStateRequest() - Constructor for class com.hazelcast.internal.management.request.GetClusterStateRequest
-
- getClusterTime() - Method in class com.hazelcast.client.proxy.ClientClusterProxy
-
- getClusterTime() - Method in interface com.hazelcast.client.spi.ClientClusterService
-
Returns the cluster-time.
- getClusterTime() - Method in class com.hazelcast.client.spi.impl.ClientClusterServiceImpl
-
- getClusterTime() - Method in interface com.hazelcast.core.Cluster
-
Returns the cluster-wide time in milliseconds.
- getClusterTime() - Method in interface com.hazelcast.internal.cluster.ClusterClock
-
Returns the cluster-time in milliseconds.
- getClusterTime() - Method in class com.hazelcast.internal.cluster.impl.ClusterClockImpl
-
- getClusterTime() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
-
- getClusterTime() - Method in class com.hazelcast.internal.jmx.InstanceMBean
-
- getClusterUpTime() - Method in interface com.hazelcast.internal.cluster.ClusterClock
-
Returns the cluster up-time in milliseconds.
- getClusterUpTime() - Method in class com.hazelcast.internal.cluster.impl.ClusterClockImpl
-
- getClusterVersion() - Method in class com.hazelcast.client.proxy.ClientClusterProxy
-
- getClusterVersion() - Method in interface com.hazelcast.core.Cluster
-
The cluster version indicates the operating version of the cluster.
- getClusterVersion() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
-
- getClusterVersion() - Method in class com.hazelcast.internal.cluster.impl.ClusterStateManager
-
- getClusterVersion() - Method in class com.hazelcast.internal.cluster.impl.SplitBrainJoinMessage
-
- getClusterVersion() - Method in class com.hazelcast.monitor.impl.NodeStateImpl
-
- getClusterVersion() - Method in interface com.hazelcast.monitor.NodeState
-
- getCmdGet() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-
- getCmdSet() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-
- getCmdTouch() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-
- getCodec() - Method in class com.hazelcast.client.spi.impl.listener.ClientEventRegistration
-
- getCodec() - Method in class com.hazelcast.client.spi.impl.listener.ClientRegistrationKey
-
- getCollator() - Method in interface com.hazelcast.mapreduce.aggregation.Aggregation
-
Deprecated.
Returns the Collator implementation used in this aggregation.
- getCollator() - Method in interface com.hazelcast.mapreduce.aggregation.impl.AggType
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalAvgAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalMaxAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalMinAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalSumAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerAvgAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerMaxAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerMinAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerSumAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.ComparableMaxAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.ComparableMinAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.CountAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.DistinctValuesAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleAvgAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleMaxAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleMinAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleSumAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerAvgAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerMaxAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerMinAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerSumAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongAvgAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongMaxAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongMinAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongSumAggregation
-
- getCollected() - Method in class com.hazelcast.mapreduce.impl.task.DefaultContext
-
- getCollectedContainers() - Method in class com.hazelcast.spi.impl.merge.AbstractContainerCollector
-
Returns the collected containers by partition ID.
- getCollection() - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-
- getCollection() - Method in class com.hazelcast.collection.impl.list.ListContainer
-
- getCollection() - Method in class com.hazelcast.collection.impl.set.SetContainer
-
- getCollection() - Method in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
-
- getCollection() - Method in class com.hazelcast.collection.impl.txnlist.TransactionalListProxy
-
- getCollection() - Method in class com.hazelcast.collection.impl.txnset.TransactionalSetProxy
-
- getCollection(boolean) - Method in class com.hazelcast.multimap.impl.MultiMapValue
-
- getCollection() - Method in class com.hazelcast.multimap.impl.operations.MultiMapResponse
-
- getCollection() - Method in class com.hazelcast.spi.impl.PortableCollection
-
- getCollection() - Method in class com.hazelcast.spi.impl.SerializableList
-
- getCombinerFactory() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.AbstractMapReduceTask
-
- getCombinerFactory() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForCustomMessageTask
-
- getCombinerFactory() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForListMessageTask
-
- getCombinerFactory() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMapMessageTask
-
- getCombinerFactory() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMultiMapMessageTask
-
- getCombinerFactory() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForSetMessageTask
-
- getCombinerFactory() - Method in interface com.hazelcast.mapreduce.aggregation.Aggregation
-
Deprecated.
Returns the CombinerFactory for this aggregation to pre-reduce values on mapping
nodes.
- getCombinerFactory() - Method in interface com.hazelcast.mapreduce.aggregation.impl.AggType
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalAvgAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalMaxAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalMinAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalSumAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerAvgAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerMaxAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerMinAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerSumAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.ComparableMaxAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.ComparableMinAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.CountAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DistinctValuesAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleAvgAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleMaxAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleMinAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleSumAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerAvgAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerMaxAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerMinAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerSumAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongAvgAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongMaxAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongMinAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongSumAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.impl.task.JobTaskConfiguration
-
- GetCommand - Class in com.hazelcast.internal.ascii.memcache
-
- GetCommand(TextCommandConstants.TextCommandType, String) - Constructor for class com.hazelcast.internal.ascii.memcache.GetCommand
-
- GetCommand(String) - Constructor for class com.hazelcast.internal.ascii.memcache.GetCommand
-
- getCommand() - Method in class com.hazelcast.scheduledexecutor.impl.TaskDefinition
-
- getCommandHandler() - Method in class com.hazelcast.internal.management.ManagementCenterService
-
- GetCommandParser - Class in com.hazelcast.internal.ascii.memcache
-
- GetCommandParser() - Constructor for class com.hazelcast.internal.ascii.memcache.GetCommandParser
-
- GetCommandProcessor - Class in com.hazelcast.internal.ascii.memcache
-
- GetCommandProcessor(TextCommandService, EntryConverter) - Constructor for class com.hazelcast.internal.ascii.memcache.GetCommandProcessor
-
- getCommittedHeap() - Method in class com.hazelcast.memory.DefaultMemoryStats
-
- getCommittedHeap() - Method in interface com.hazelcast.memory.MemoryStats
-
Returns the amount of memory in bytes that is committed for
the Java virtual machine to use.
- getCommittedHeap() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- getCommittedNative() - Method in class com.hazelcast.memory.DefaultMemoryStats
-
- getCommittedNative() - Method in interface com.hazelcast.memory.MemoryStats
-
Returns the amount of native memory in bytes that is committed for
current HazelcastInstance to use.
- getCommittedNative() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- getComparator() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.EvictionConfigHolder
-
- getComparator() - Method in class com.hazelcast.config.EvictionConfig
-
- getComparator() - Method in interface com.hazelcast.internal.eviction.EvictionConfiguration
-
- getComparator() - Method in class com.hazelcast.query.PagingPredicate
-
- getComparatorClassName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.EvictionConfigHolder
-
- getComparatorClassName() - Method in class com.hazelcast.config.EvictionConfig
-
- getComparatorClassName() - Method in interface com.hazelcast.internal.eviction.EvictionConfiguration
-
- getCompletableFuture() - Method in class com.hazelcast.mapreduce.impl.task.TrackableJobFuture
-
- getCompletableFuture() - Method in interface com.hazelcast.mapreduce.TrackableJob
-
Deprecated.
Returns the
ICompletableFuture
to add callbacks
or wait for the resulting value of the tracked job.
- getCompleted() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
-
- getCompletedMigrations() - Method in class com.hazelcast.internal.partition.PartitionRuntimeState
-
- getCompletedTaskCount() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-
- getCompletedTaskCount() - Method in interface com.hazelcast.monitor.LocalExecutorStats
-
Returns the number of completed operations on the executor service.
- getCompletedTaskCount() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-
- getCompletedTaskCount() - Method in interface com.hazelcast.util.executor.ManagedExecutorService
-
- getCompletionId() - Method in class com.hazelcast.cache.impl.CacheEventContext
-
- getCompletionId() - Method in class com.hazelcast.cache.impl.CacheEventSet
-
- getCompletionId() - Method in class com.hazelcast.cache.impl.operation.AbstractMutatingCacheOperation
-
- getCompletionId() - Method in class com.hazelcast.cache.impl.operation.CachePutAllOperation
-
- getCompletionId() - Method in interface com.hazelcast.cache.impl.operation.MutableOperation
-
- getConcurrencyLevel() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- getConditionId() - Method in class com.hazelcast.concurrent.lock.ConditionKey
-
- getConfig() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- getConfig() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Gets the configuration of the cache that this store belongs to.
- getConfig() - Method in interface com.hazelcast.client.ClientEngine
-
- getConfig() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getConfig() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getConfig() - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-
- getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AbstractAddConfigMessageTask
-
- getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddCacheConfigMessageTask
-
- getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddCardinalityEstimatorConfigMessageTask
-
- getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddDurableExecutorConfigMessageTask
-
- getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddEventJournalConfigMessageTask
-
- getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddExecutorConfigMessageTask
-
- getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddFlakeIdGeneratorConfigMessageTask
-
- getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddListConfigMessageTask
-
- getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddLockConfigMessageTask
-
- getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddMapConfigMessageTask
-
- getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddMultiMapConfigMessageTask
-
- getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddQueueConfigMessageTask
-
- getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddReliableTopicConfigMessageTask
-
- getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddReplicatedMapConfigMessageTask
-
- getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddRingbufferConfigMessageTask
-
- getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddScheduledExecutorConfigMessageTask
-
- getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddSemaphoreConfigMessageTask
-
- getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddSetConfigMessageTask
-
- getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddTopicConfigMessageTask
-
- getConfig(NodeEngine) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-
- getConfig() - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-
- getConfig() - Method in class com.hazelcast.collection.impl.list.ListContainer
-
- getConfig(NodeEngine) - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
-
- getConfig() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-
- getConfig() - Method in class com.hazelcast.collection.impl.set.SetContainer
-
- getConfig(NodeEngine) - Method in class com.hazelcast.collection.impl.set.SetProxyImpl
-
- getConfig() - Method in class com.hazelcast.config.LegacyCacheEvictionConfig
-
- getConfig() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the configuration of this Hazelcast instance.
- getConfig() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getConfig() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getConfig() - Method in class com.hazelcast.instance.Node
-
- getConfig() - Method in class com.hazelcast.internal.jmx.InstanceMBean
-
- getConfig() - Method in class com.hazelcast.internal.jmx.MapMBean
-
- getConfig() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
-
- getConfig() - Method in class com.hazelcast.internal.jmx.QueueMBean
-
- getConfig() - Method in class com.hazelcast.internal.jmx.ReliableTopicMBean
-
- getConfig() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
-
- getConfig() - Method in class com.hazelcast.internal.jmx.TopicMBean
-
- getConfig() - Method in class com.hazelcast.internal.management.dto.WanPublisherConfigDTO
-
- getConfig() - Method in class com.hazelcast.internal.management.dto.WanReplicationConfigDTO
-
- getConfig() - Method in class com.hazelcast.quorum.impl.QuorumImpl
-
- getConfig() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-
- getConfig() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getConfig() - Method in interface com.hazelcast.spi.NodeEngine
-
Returns the Config that was used to create the HazelcastInstance.
- getConfigAndReset() - Method in class com.hazelcast.config.LegacyCacheConfig
-
- getConfigCheck() - Method in class com.hazelcast.internal.cluster.impl.JoinMessage
-
- getConfigClassLoader() - Method in class com.hazelcast.instance.Node
-
- getConfigClassLoader() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
-
- getConfigClassLoader() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getConfigClassLoader() - Method in interface com.hazelcast.spi.NodeEngine
-
Returns the Config ClassLoader.
- getConfigFromLocation(String, ClassLoader, String) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCachingProvider
-
- getConfigFromLocation(URI, ClassLoader, String) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCachingProvider
-
- getConfigObject() - Method in class com.hazelcast.config.ServiceConfig
-
- getConfigPatternMatcher() - Method in class com.hazelcast.client.config.ClientConfig
-
Returns the pattern matcher which is used to match item names to
configuration objects.
- getConfigPatternMatcher() - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getConfigPatternMatcher() - Method in class com.hazelcast.config.Config
-
Returns the pattern matcher which is used to match item names to
configuration objects.
- getConfigPatternMatcher() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getConfigs() - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- getConfigSource() - Method in class com.hazelcast.internal.jmx.InstanceMBean
-
- getConfiguration(Class<C>) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- getConfiguration(Class<C>) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-
- getConfiguration() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- getConfigurationFile() - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getConfigurationFile() - Method in class com.hazelcast.config.Config
-
Returns the
File
to the XML configuration, which has been
parsed to create this
Config
instance.
- getConfigurationFile() - Method in class com.hazelcast.config.XmlConfigLocator
-
- getConfigurationFile() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getConfigurationMembers(Config) - Static method in class com.hazelcast.cluster.impl.TcpIpJoiner
-
- getConfigurationProperties() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategyFactory
-
Returns a set of the expected configuration properties.
- getConfigurationProperties() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategyFactory
-
- getConfigurationService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getConfigurationUrl() - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getConfigurationUrl() - Method in class com.hazelcast.config.Config
-
Returns the
URL
to the XML configuration, which has been parsed
to create this
Config
instance.
- getConfigurationUrl() - Method in class com.hazelcast.config.XmlConfigLocator
-
- getConfigurationUrl() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getConfiguredString() - Static method in enum com.hazelcast.internal.networking.nio.SelectorMode
-
- getConfiguredValue() - Static method in enum com.hazelcast.internal.networking.nio.SelectorMode
-
- getConn() - Method in class com.hazelcast.nio.Packet
-
Gets the Connection this Packet was send with.
- getConnectedClients() - Method in class com.hazelcast.client.impl.ClientServiceProxy
-
- getConnectedClients() - Method in interface com.hazelcast.core.ClientService
-
Returns all connected clients to this member.
- GetConnectedClientsOperation - Class in com.hazelcast.client.impl.operations
-
- GetConnectedClientsOperation() - Constructor for class com.hazelcast.client.impl.operations.GetConnectedClientsOperation
-
- getConnectedClientStats() - Method in interface com.hazelcast.client.ClientEngine
-
Returns Map which contains number of connected clients to the cluster.
- getConnectedClientStats() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getConnectedServerVersion() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-
- getConnectedServerVersion() - Method in class com.hazelcast.client.spi.ClientProxy
-
- getConnectedServerVersionString() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-
- getConnection() - Method in interface com.hazelcast.client.ClientEndpoint
-
- getConnection() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- getConnection() - Method in class com.hazelcast.client.proxy.txn.TransactionContextProxy
-
- getConnection() - Method in class com.hazelcast.client.proxy.txn.xa.XATransactionContextProxy
-
- getConnection() - Method in interface com.hazelcast.client.spi.ClientTransactionContext
-
- getConnection(Address) - Method in interface com.hazelcast.nio.ConnectionManager
-
Gets the connection for a given address.
- getConnection(Address) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- getConnection() - Method in class com.hazelcast.spi.Operation
-
- getConnectionAttemptLimit() - Method in class com.hazelcast.client.config.ClientConfig
-
Deprecated.
- getConnectionAttemptLimit() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
- getConnectionAttemptPeriod() - Method in class com.hazelcast.client.config.ClientConfig
-
Deprecated.
- getConnectionAttemptPeriod() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Period for the next attempt to find a member to connect.
- getConnectionCount() - Method in class com.hazelcast.internal.jmx.ConnectionManagerMBean
-
- getConnectionCount() - Method in interface com.hazelcast.nio.ConnectionManager
-
Gets the total number of connections.
- getConnectionCount() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- getConnectionId() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- getConnectionListener() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getConnectionManager() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-
- getConnectionManager() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getConnectionManager() - Method in class com.hazelcast.client.spi.ClientContext
-
- getConnectionManager() - Method in class com.hazelcast.instance.Node
-
- getConnectionManager() - Method in class com.hazelcast.internal.jmx.ConnectionManagerMBean
-
- getConnectionManager() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- getConnectionManagerBean() - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
-
- getConnectionManagerMBean() - Method in class com.hazelcast.internal.jmx.InstanceMBean
-
- getConnectionMonitorInterval() - Method in interface com.hazelcast.nio.IOService
-
- getConnectionMonitorInterval() - Method in class com.hazelcast.nio.NodeIOService
-
- getConnectionMonitorMaxFaults() - Method in interface com.hazelcast.nio.IOService
-
- getConnectionMonitorMaxFaults() - Method in class com.hazelcast.nio.NodeIOService
-
- getConnectionStrategyConfig() - Method in class com.hazelcast.client.config.ClientConfig
-
- getConnectionTimeout() - Method in class com.hazelcast.client.config.ClientConfig
-
Deprecated.
- getConnectionTimeout() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Timeout value in millis for nodes to accept client connection requests.
- getConnectionTimeoutSeconds() - Method in class com.hazelcast.config.AwsConfig
-
Gets the connection timeout in seconds.
- getConnectionTimeoutSeconds() - Method in class com.hazelcast.config.TcpIpConfig
-
Returns the connection timeout.
- getConnTimeoutSeconds() - Method in class com.hazelcast.cluster.impl.TcpIpJoiner
-
- getContainer() - Method in class com.hazelcast.collection.impl.queue.operations.QueueOperation
-
- getContainer() - Method in class com.hazelcast.collection.impl.queue.QueueItem
-
- getContainer(String) - Method in class com.hazelcast.scheduledexecutor.impl.AbstractScheduledExecutorContainerHolder
-
- getContainer() - Method in class com.hazelcast.scheduledexecutor.impl.operations.AbstractSchedulerOperation
-
- getContainer(String) - Method in interface com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainerHolder
-
- getContainerConstructorFunction() - Method in class com.hazelcast.scheduledexecutor.impl.AbstractScheduledExecutorContainerHolder
-
- getContainerConstructorFunction() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorMemberBin
-
- getContainerConstructorFunction() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorPartition
-
- getContainerMap() - Method in class com.hazelcast.collection.impl.collection.CollectionService
-
- getContainerMap() - Method in class com.hazelcast.collection.impl.list.ListService
-
- getContainerMap() - Method in class com.hazelcast.collection.impl.set.SetService
-
- getContainerOrNull(int, ObjectNamespace) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
-
Returns the ringbuffer container if it already exists for the
given partitionId
and namespace
.
- getContainers() - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
-
- getContainers() - Method in class com.hazelcast.scheduledexecutor.impl.AbstractScheduledExecutorContainerHolder
-
- getContentType() - Method in class com.hazelcast.internal.ascii.rest.RestValue
-
- getContext() - Method in class com.hazelcast.client.spi.ClientProxy
-
- getContext() - Method in class com.hazelcast.client.spi.ProxyManager
-
- getContext() - Method in class com.hazelcast.map.impl.querycache.publisher.DefaultPublisherContext
-
- getContext() - Method in interface com.hazelcast.map.impl.querycache.publisher.PublisherContext
-
- getContext() - Method in class com.hazelcast.map.impl.querycache.subscriber.MapSubscriberRegistry
-
- getContext() - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheRequest
-
- getContext() - Method in class com.hazelcast.map.impl.querycache.subscriber.SubscriberAccumulatorFactory
-
- getContext() - Method in class com.hazelcast.map.impl.querycache.subscriber.SubscriberRegistry
-
- getConverter() - Method in enum com.hazelcast.query.impl.AttributeType
-
- getConverter() - Method in interface com.hazelcast.query.impl.Index
-
- getConverter() - Method in class com.hazelcast.query.impl.IndexImpl
-
Provides comparable null object.
- getCorrelationId() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
-
Returns the correlation ID field.
- getCost() - Method in interface com.hazelcast.core.EntryView
-
Returns the cost (in bytes) of the entry.
- getCost() - Method in class com.hazelcast.map.impl.record.AbstractRecord
-
- getCost() - Method in interface com.hazelcast.map.impl.record.Record
-
Returns heap cost of this record in bytes.
- getCost() - Method in class com.hazelcast.map.impl.recordstore.LazyEntryViewFromRecord
-
- getCost() - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- getCost() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-
- getCost() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
-
- getCost() - Method in interface com.hazelcast.spi.merge.MergingCosts
-
Returns the memory cost of the merge data.
- getCount() - Method in class com.hazelcast.cache.impl.CacheEntryIterationResult
-
- getCount() - Method in class com.hazelcast.cache.impl.CacheKeyIterationResult
-
- getCount() - Method in class com.hazelcast.client.proxy.ClientCountDownLatchProxy
-
- getCount() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
-
- getCount() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
-
- getCount(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- getCount() - Method in interface com.hazelcast.core.ICountDownLatch
-
Returns the current count.
- getCount() - Method in class com.hazelcast.internal.jmx.CountDownLatchMBean
-
- getCount() - Method in class com.hazelcast.map.impl.iterator.MapKeysWithCursor
-
- getCountDownLatch(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getCountDownLatch(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-
- getCountDownLatch(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates cluster-wide CountDownLatch.
- getCountDownLatch(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getCountDownLatch(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getCountDownLatchConfig(String) - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getCountDownLatchConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the CountDownLatchConfig for the given name, creating one
if necessary and adding it to the collection of known configurations.
- getCountDownLatchConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getCountDownLatchConfigs() - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getCountDownLatchConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of CountDownLatch configurations, mapped by config name.
- getCountDownLatchConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
-
- getCountDownLatchConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
-
Returns all registered CountDownLatchConfig configurations.
- getCountDownLatchConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getCountDownLatchContainer(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- getCounter(String) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
-
Returns the counter with the given name
.
- GetCountOperation - Class in com.hazelcast.concurrent.countdownlatch.operations
-
- GetCountOperation() - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.GetCountOperation
-
- GetCountOperation(String) - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.GetCountOperation
-
- getCRDTReplicationConfig() - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getCRDTReplicationConfig() - Method in class com.hazelcast.config.Config
-
- getCRDTReplicationConfig() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getCreationTime() - Method in interface com.hazelcast.cache.CacheStatistics
-
Gets the cache creation time.
- getCreationTime() - Method in class com.hazelcast.cache.impl.CacheEventContext
-
- getCreationTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getCreationTime() - Method in class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
-
- getCreationTime() - Method in class com.hazelcast.cache.impl.merge.entry.LazyCacheEntryView
-
- getCreationTime() - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-
- getCreationTime() - Method in class com.hazelcast.collection.impl.collection.CollectionItem
-
- getCreationTime() - Method in class com.hazelcast.collection.impl.queue.QueueItem
-
- getCreationTime() - Method in interface com.hazelcast.core.EntryView
-
Returns the creation time of the entry.
- getCreationTime() - Method in interface com.hazelcast.internal.eviction.Evictable
-
Gets the creation time of this
Evictable
in milliseconds.
- getCreationTime() - Method in interface com.hazelcast.internal.eviction.EvictableEntryView
-
- getCreationTime() - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest.CacheBrowserEntryView
-
- getCreationTime() - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
-
- getCreationTime() - Method in class com.hazelcast.internal.nearcache.impl.store.HeapNearCacheRecordMap.NearCacheEvictableSamplingEntry
-
- getCreationTime() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-
- getCreationTime() - Method in interface com.hazelcast.map.impl.querycache.event.QueryCacheEventData
-
- getCreationTime() - Method in class com.hazelcast.map.impl.record.AbstractRecord
-
- getCreationTime() - Method in interface com.hazelcast.map.impl.record.Record
-
- getCreationTime() - Method in class com.hazelcast.map.impl.record.RecordInfo
-
- getCreationTime() - Method in class com.hazelcast.map.impl.recordstore.ExpiredKey
-
- getCreationTime() - Method in class com.hazelcast.map.impl.recordstore.LazyEntryViewFromRecord
-
- getCreationTime() - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalFlakeIdGeneratorStatsImpl
-
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalOperationStatsImpl
-
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalPNCounterStatsImpl
-
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalTopicStatsImpl
-
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalWanStatsImpl
-
- getCreationTime() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-
- getCreationTime() - Method in class com.hazelcast.monitor.impl.WanSyncStateImpl
-
- getCreationTime() - Method in interface com.hazelcast.monitor.LocalInstanceStats
-
Returns the creation time of this distributed object instance on this member.
- getCreationTime() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the creation time of this map on this member.
- getCreationTime() - Method in interface com.hazelcast.monitor.LocalTopicStats
-
Returns the creation time of this topic on this member
- getCreationTime() - Method in interface com.hazelcast.monitor.NearCacheStats
-
Returns the creation time of this Near Cache on this member.
- getCreationTime() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- getCreationTime() - Method in class com.hazelcast.multimap.impl.MultiMapMergeContainer
-
- getCreationTime() - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
-
- getCreationTime() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-
- getCreationTime() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- getCreationTime() - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
-
- getCreationTime() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
-
- getCreationTime() - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
-
- getCreationTime() - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
-
- getCreationTime() - Method in interface com.hazelcast.spi.merge.MergingCreationTime
-
Returns the creation time of the merge data.
- getCredentials() - Method in interface com.hazelcast.client.ClientEndpoint
-
- getCredentials() - Method in class com.hazelcast.client.config.ClientConfig
-
- getCredentials() - Method in class com.hazelcast.client.config.ClientSecurityConfig
-
- getCredentials() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- getCredentials() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getCredentials() - Method in class com.hazelcast.internal.cluster.impl.JoinRequest
-
- getCredentialsClassname() - Method in class com.hazelcast.client.config.ClientSecurityConfig
-
- getCredentialsFactory() - Method in interface com.hazelcast.security.SecurityContext
-
- getCurrConnections() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-
- getCurrentClientConnections() - Method in class com.hazelcast.internal.jmx.ConnectionManagerMBean
-
- getCurrentClientConnections() - Method in interface com.hazelcast.nio.ConnectionManager
-
Gets the number of client connections.
- getCurrentClientConnections() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- getCurrentClusterHotRestartStatus() - Method in interface com.hazelcast.hotrestart.InternalHotRestartService
-
Returns latest Hot Restart status as Management Center DTO.
- getCurrentClusterHotRestartStatus() - Method in class com.hazelcast.hotrestart.NoopInternalHotRestartService
-
- getCurrentId() - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-
- getCurrentId() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-
- getCurrentMembers() - Method in class com.hazelcast.quorum.QuorumEvent
-
Returns the snapshot of member list at the time quorum happened
- getCurrentMembersAndMembersRemovedInNotJoinableState() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
-
- getCurrentReplicaIndex() - Method in class com.hazelcast.spi.PartitionMigrationEvent
-
Gets the index of the partition replica that current member owns currently, before migration starts.
- getCurrentState() - Method in class com.hazelcast.client.util.ClientStateListener
-
- getCurrentTargetReplicaAddress() - Method in class com.hazelcast.client.proxy.ClientPNCounterProxy
-
Returns the current target replica address to which this proxy is
sending invocations.
- getCurrentTargetReplicaAddress() - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
-
Returns the current target replica address to which this proxy is
sending invocations.
- getCurrentValue() - Method in class com.hazelcast.internal.jmx.AtomicLongMBean
-
- getCurrentVectorClock() - Method in interface com.hazelcast.crdt.CRDT
-
Returns the current vector clock which reflects the current CRDT state.
- getCurrentVectorClock() - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
-
- getData() - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-
- getData() - Method in class com.hazelcast.collection.impl.collection.CollectionEvent
-
- getData() - Method in class com.hazelcast.collection.impl.queue.QueueItem
-
- getData() - Method in class com.hazelcast.internal.ascii.rest.HttpPostCommand
-
- getDataEntrySet() - Method in class com.hazelcast.multimap.impl.operations.EntrySetResponse
-
- getDataFromMap(long) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-
- getDataItems() - Method in class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
-
- getDataItems() - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
-
- getDataKey() - Method in class com.hazelcast.cache.impl.CacheEventContext
-
- getDataKey() - Method in interface com.hazelcast.cache.impl.CacheEventData
-
Gets cache entry key as
Data
.
- getDataKey() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-
- getDataKey() - Method in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
-
- getDataKey() - Method in class com.hazelcast.map.impl.event.EntryEventData
-
- getDataKey() - Method in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
-
- getDataKey() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-
- getDataKey() - Method in interface com.hazelcast.map.impl.querycache.event.QueryCacheEventData
-
- getDataList() - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-
- getDataLoadTimeoutSeconds() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Returns configured data load timeout for hot-restart process.
- getDataMemberCount() - Method in class com.hazelcast.internal.cluster.impl.JoinMessage
-
- getDataMergingValue() - Method in class com.hazelcast.map.impl.event.EntryEventData
-
- getDataNewValue() - Method in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
-
- getDataNewValue() - Method in class com.hazelcast.map.impl.event.EntryEventData
-
- getDataNewValue() - Method in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
-
- getDataNewValue() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-
- getDataNewValue() - Method in interface com.hazelcast.map.impl.querycache.event.QueryCacheEventData
-
- getDataOffset() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
-
Returns the setDataOffset field.
- getDataOldValue() - Method in class com.hazelcast.cache.impl.CacheEventContext
-
- getDataOldValue() - Method in interface com.hazelcast.cache.impl.CacheEventData
-
Gets the old value of entry as
Data
, if available.
- getDataOldValue() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-
- getDataOldValue() - Method in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
-
- getDataOldValue() - Method in class com.hazelcast.map.impl.event.EntryEventData
-
- getDataOldValue() - Method in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
-
- getDataOldValue() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-
- getDataOldValue() - Method in interface com.hazelcast.map.impl.querycache.event.QueryCacheEventData
-
- getDataRecoveryPolicy() - Method in class com.hazelcast.internal.management.dto.ClusterHotRestartStatusDTO
-
- getDataSerializableFactories() - Method in class com.hazelcast.config.SerializationConfig
-
- getDataSerializableFactories() - Method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1.AbstractBuilder
-
- getDataSerializableFactoryClasses() - Method in class com.hazelcast.config.SerializationConfig
-
- getDataStructureName(Store) - Method in class com.hazelcast.spi.impl.merge.AbstractMergeRunnable
-
- getDataValue() - Method in class com.hazelcast.cache.impl.CacheEventContext
-
- getDataValue() - Method in interface com.hazelcast.cache.impl.CacheEventData
-
Gets cache entry value as
Data
.
- getDataValue() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-
- getDecodedDataLength(byte[]) - Static method in class com.hazelcast.util.Base64
-
returns length of decoded data given an
array containing encoded data.
- getDecoder() - Method in class com.hazelcast.internal.ascii.AbstractTextCommand
-
- getDecoder() - Method in interface com.hazelcast.internal.ascii.TextCommand
-
- getDecrHits() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-
- getDecrMisses() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-
- getDefault() - Static method in enum com.hazelcast.cache.BuiltInCacheMergePolicies
-
- getDefault() - Static method in class com.hazelcast.transaction.TransactionOptions
-
Creates a new TransactionOptions configured with default settings.
- getDefaultClassLoader() - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- getDefaultClassLoader() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- getDefaultGlobalMemoryAccessor() - Static method in class com.hazelcast.internal.memory.GlobalMemoryAccessorRegistry
-
- getDefaultHazelcastInstance() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
-
- getDefaultInstance() - Method in class com.hazelcast.cache.impl.HazelcastServerCachingProvider
-
- getDefaultMapServiceConstructor() - Static method in class com.hazelcast.map.impl.MapServiceConstructor
-
- getDefaultProperties() - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- getDefaultProperties() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- getDefaultReadTimeout() - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
-
Return default cache value retrieval timeout in milliseconds.
- getDefaultURI() - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- getDefaultURI() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- getDefaultValue() - Method in class com.hazelcast.spi.properties.HazelcastProperty
-
Returns the default value of the property.
- getDefinition() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskDescriptor
-
- getDelay(TimeUnit) - Method in class com.hazelcast.client.proxy.ClientScheduledFutureProxy
-
- getDelay(TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.DelegatingScheduledFutureStripper
-
- getDelay(String, TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
-
- getDelay(TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledFutureProxy
-
- GetDelayOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
-
- GetDelayOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.GetDelayOperation
-
- GetDelayOperation(ScheduledTaskHandler, TimeUnit) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.GetDelayOperation
-
- getDelaySeconds() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
-
- getDelaySeconds() - Method in class com.hazelcast.config.QueryCacheConfig
-
Returns the minimum number of delay seconds which an event waits in the buffer of node
before sending to a QueryCache
- getDelaySeconds() - Method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
-
- getDelegate() - Method in interface com.hazelcast.map.impl.querycache.subscriber.InternalQueryCache
-
- getDelegate() - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
-
- getDelegatedInstance() - Method in interface com.hazelcast.osgi.HazelcastOSGiInstance
-
- getDeleteHits() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-
- getDeleteMisses() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-
- getDeprecatedName() - Method in class com.hazelcast.spi.properties.HazelcastProperty
-
- getDeserializedKey() - Method in class com.hazelcast.spi.impl.merge.AbstractMergingEntryImpl
-
- getDeserializedKey() - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
-
- getDeserializedKey() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
-
- getDeserializedKey() - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
-
- getDeserializedKey() - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
-
- getDeserializedKey() - Method in interface com.hazelcast.spi.merge.MergingEntry
-
Returns the deserialized merging key.
- getDeserializedValue() - Method in class com.hazelcast.spi.impl.merge.AbstractCollectionMergingValueImpl
-
- getDeserializedValue() - Method in class com.hazelcast.spi.impl.merge.AbstractMergingEntryImpl
-
- getDeserializedValue() - Method in class com.hazelcast.spi.impl.merge.AbstractMergingValueImpl
-
- getDeserializedValue() - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
-
- getDeserializedValue() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
-
- getDeserializedValue() - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
-
- getDeserializedValue() - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
-
- getDeserializedValue() - Method in class com.hazelcast.spi.impl.merge.RingbufferMergingValueImpl
-
- getDeserializedValue() - Method in interface com.hazelcast.spi.merge.MergingValue
-
Returns the deserialized merging value.
- getDestination() - Method in class com.hazelcast.internal.partition.MigrationInfo
-
- getDestinationCurrentReplicaIndex() - Method in class com.hazelcast.internal.partition.MigrationInfo
-
- getDestinationNewReplicaIndex() - Method in class com.hazelcast.internal.partition.MigrationInfo
-
- getDestinationUuid() - Method in class com.hazelcast.internal.partition.MigrationInfo
-
- getDiagnostics() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getDirectory() - Method in class com.hazelcast.config.NearCachePreloaderConfig
-
- getDirtyEntryCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getDirtyEntryCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getDirtyEntryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the number of entries that the member owns and are dirty (updated but not persisted yet).
- getDiscoveryConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Returns the configuration of the Hazelcast Discovery SPI and configured discovery providers
- getDiscoveryConfig() - Method in class com.hazelcast.config.JoinConfig
-
- getDiscoveryConfig() - Method in class com.hazelcast.config.WanPublisherConfig
-
- getDiscoveryConfig() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
-
- getDiscoveryMode() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
-
- getDiscoveryNode() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
-
- getDiscoveryService() - Method in class com.hazelcast.instance.Node
-
- getDiscoveryServiceProvider() - Method in class com.hazelcast.config.DiscoveryConfig
-
- getDiscoveryStrategies() - Method in class com.hazelcast.spi.discovery.impl.DefaultDiscoveryService
-
- getDiscoveryStrategyConfigs() - Method in class com.hazelcast.config.DiscoveryConfig
-
- getDiscoveryStrategyFactory() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
-
- getDiscoveryStrategyType() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategyFactory
-
- getDiscoveryStrategyType() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategyFactory
-
- getDistributedObject(String, String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getDistributedObject(String, String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-
- getDistributedObject() - Method in class com.hazelcast.client.spi.impl.listener.LazyDistributedObjectEvent
-
- getDistributedObject() - Method in class com.hazelcast.core.DistributedObjectEvent
-
Returns the DistributedObject instance.
- getDistributedObject(String, String) - Method in interface com.hazelcast.core.HazelcastInstance
-
- getDistributedObject(String, String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getDistributedObject(String, String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getDistributedObject(String, String) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-
- getDistributedObject(String, String) - Method in interface com.hazelcast.spi.ProxyService
-
- getDistributedObjectName(String) - Static method in class com.hazelcast.cache.CacheUtil
-
Convenience method to obtain the name of Hazelcast distributed object corresponding to the cache identified
by the given cacheName
, assuming null URI
and ClassLoader
prefixes.
- getDistributedObjectName(String, URI, ClassLoader) - Static method in class com.hazelcast.cache.CacheUtil
-
Convenience method to obtain the name of Hazelcast distributed object corresponding to the cache identified
by the given arguments.
- getDistributedObjectName() - Method in interface com.hazelcast.client.impl.client.SecureRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.AddMembershipListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionLostListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAddAndGetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAlterAndGetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAlterMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongApplyMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongCompareAndSetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongDecrementAndGetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndAddMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndAlterMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndIncrementMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndSetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongIncrementAndGetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongSetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceAlterAndGetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceAlterMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceApplyMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceClearMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceCompareAndSetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceContainsMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetAndAlterMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetAndSetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceIsNullMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceSetAndGetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceSetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationCustomCredentialsMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddEntryListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddNearCacheInvalidationListenerTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddPartitionLostListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheClearMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheContainsKeyMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheCreateConfigMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheDestroyMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEntryProcessorMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEventJournalReadTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEventJournalSubscribeTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheFetchNearCacheInvalidationMetadataTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndRemoveMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndReplaceMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetConfigMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheIterateEntriesMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheIterateMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheListenerRegistrationMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheLoadAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheManagementConfigMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutIfAbsentMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllKeysMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveEntryListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemovePartitionLostListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheReplaceMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheSizeMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.Pre38CacheAddInvalidationListenerTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorAddMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorEstimateMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ClientStatisticsMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionAwaitMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionBeforeAwaitMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionSignalAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionSignalMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchAwaitMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchCountDownMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchGetCountMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchTrySetCountMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterAddMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetConfiguredReplicaCountMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.CreateProxiesMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.CreateProxyMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.DeployClassesMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.DestroyProxyMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AbstractAddConfigMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorDisposeResultMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorIsShutdownMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveAndDisposeResultMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveResultMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorShutdownMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorSubmitToPartitionMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnAddressMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnPartitionMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceIsShutdownMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceShutdownMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToAddressMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToPartitionMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.GetDistributedObjectsMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.GetPartitionsMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddAllWithIndexMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddWithIndexMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListClearMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRemoveAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRetainAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListContainsAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListContainsMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListGetAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListGetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListIndexOfMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListIsEmptyMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListIteratorMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListLastIndexOfMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListListIteratorMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveWithIndexMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListSetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListSizeMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListSubMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockForceUnlockMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockGetLockCountMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockGetRemainingLeaseTimeMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockIsLockedByCurrentThreadMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockIsLockedMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockLockMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockTryLockMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockUnlockMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyWithPredicateMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerWithPredicateMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddIndexMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddInterceptorMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddNearCacheInvalidationListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddPartitionLostListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAggregateMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAggregateWithPredicateMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearNearCacheMessageTask
-
Deprecated.
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsKeyMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsValueMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapDeleteMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapDestroyCacheMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPagingPredicateMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPredicateMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntrySetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEventJournalReadTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEventJournalSubscribeTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnAllKeysMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeyMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeysMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteWithPredicateMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchEntriesMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchKeysMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchNearCacheInvalidationMetadataTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchWithQueryMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFlushMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapForceUnlockMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetEntryViewMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsEmptyMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsLockedMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPagingPredicateMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPredicateMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadGivenKeysMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLockMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapMadePublishableMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapProjectionMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapProjectionWithPredicateMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateWithValueMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutIfAbsentMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutTransientMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveEntryListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveIfSameMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveInterceptorMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemovePartitionLostListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapReplaceIfSameMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapReplaceMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetReadCursorMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSizeMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSubmitToKeyMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryLockMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryPutMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryRemoveMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapUnlockMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPagingPredicateMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPredicateMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.Pre38MapAddNearCacheEntryListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceCancelMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForCustomMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForListMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMapMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMultiMapMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForSetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceJobProcessInformationMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerToKeyMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapClearMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsEntryMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsKeyMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsValueMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapDeleteMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapEntrySetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapForceUnlockMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapGetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapIsLockedMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapKeySetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapLockMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapPutMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapSizeMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapTryLockMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapUnlockMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValueCountMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValuesMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.NoSuchMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.PingMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueClearMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRemoveAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRetainAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMaxSizeMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIsEmptyMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIteratorMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueOfferMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePeekMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePollMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePutMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemainingCapacityMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueSizeMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueTakeMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistributedObjectListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.RemovePartitionLostListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerWithPredicateMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddNearCacheListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapClearMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsKeyMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsValueMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapEntrySetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapGetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapIsEmptyMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapKeySetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveEntryListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapSizeMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapValuesMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferCapacityMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferHeadSequenceMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadManyMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadOneMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferRemainingCapacityMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferSizeMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferTailSequenceMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorGetAllScheduledMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorShutdownMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToAddressMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToPartitionMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromAddressMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromPartitionMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromAddressMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromPartitionMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromAddressMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromPartitionMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromAddressMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromPartitionMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromAddressMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromPartitionMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromAddressMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromPartitionMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromAddressMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromPartitionMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreAcquireMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreAvailablePermitsMessageTasks
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreDrainPermitsMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreIncreasePermitsMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreInitMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreReducePermitsMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreReleaseMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreTryAcquireMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetClearMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRemoveAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRetainAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetContainsAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetContainsMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetGetAllMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetIsEmptyMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetSizeMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicAddMessageListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicPublishMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicRemoveMessageListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCommitMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCreateMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionRollbackMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAClearRemoteTransactionMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XACollectTransactionsMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAFinalizeTransactionMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCommitMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCreateMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionPrepareMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionRollbackMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListAddMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListRemoveMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListSizeMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapContainsKeyMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapDeleteMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetForUpdateMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapIsEmptyMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetWithPredicateMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutIfAbsentMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveIfSameMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceIfSameMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSizeMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesWithPredicateMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapGetMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapPutMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveEntryMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapSizeMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapValueCountMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueOfferMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePeekMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePollMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueSizeMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueTakeMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetAddMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetRemoveMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetSizeMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.spi.ClientProxy
-
- getDistributedObjectName() - Method in class com.hazelcast.flakeidgen.impl.client.NewIdBatchMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.spi.AbstractDistributedObject
-
- getDistributedObjectNames() - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyRegistry
-
- getDistributedObjectNames(String) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-
- getDistributedObjectNames(String) - Method in interface com.hazelcast.spi.ProxyService
-
- getDistributedObjects() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getDistributedObjects() - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-
- getDistributedObjects() - Method in class com.hazelcast.client.spi.ProxyManager
-
- getDistributedObjects() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns all
DistributedObject
's such as; queue, map, set, list, topic, lock, multimap.
- getDistributedObjects() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getDistributedObjects() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getDistributedObjects(Collection<DistributedObject>) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyRegistry
-
Gets the DistributedObjects in this registry.
- getDistributedObjects(String) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-
- getDistributedObjects(String) - Method in interface com.hazelcast.spi.ProxyService
-
- GetDistributedObjectsMessageTask - Class in com.hazelcast.client.impl.protocol.task
-
- GetDistributedObjectsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.GetDistributedObjectsMessageTask
-
- getDistributedObjectType() - Method in interface com.hazelcast.client.impl.client.SecureRequest
-
- getDistributedObjectType() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-
- getDistributedObjectType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapForceUnlockMessageTask
-
- getDistributedObjectType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsLockedMessageTask
-
- getDistributedObjectType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLockMessageTask
-
- getDistributedObjectType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryLockMessageTask
-
- getDistributedObjectType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapUnlockMessageTask
-
- getDistributedObjectType() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapForceUnlockMessageTask
-
- getDistributedObjectType() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapIsLockedMessageTask
-
- getDistributedObjectType() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapLockMessageTask
-
- getDistributedObjectType() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapTryLockMessageTask
-
- getDistributedObjectType() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapUnlockMessageTask
-
- getDouble(Object, long) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Returns the double value at the supplied offset from the supplied object's base address.
- getDouble(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- getDouble(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- getDouble(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- getDouble(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- getDouble(long) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
-
Reads the double value from given address.
- getDouble(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
- getDouble(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
-
Returns a field in a Json object as a double.
- getDouble(JsonObject, String, double) - Static method in class com.hazelcast.util.JsonUtil
-
Returns a field in a Json object as a double.
- getDoubleAttribute(String) - Method in class com.hazelcast.client.impl.MemberImpl
-
- getDoubleAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- getDoubleAttribute(String) - Method in interface com.hazelcast.core.Member
-
Returns the value of the specified key for this member or
null if value is undefined.
- getDoubleAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
-
- getDoubleValue(String, String) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- getDoubleValue(String, String, double) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- getDoubleVolatile(Object, long) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
-
Reads the double value as volatile from given object by its offset.
- getDoubleVolatile(long) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
-
Reads the double value as volatile from given object by its offset.
- getDoubleVolatile(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- getDoubleVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- getDoubleVolatile(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- getDoubleVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- getDroppedCount() - Method in class com.hazelcast.wan.impl.WanEventCounter.EventCounter
-
Returns the number of dropped entry events
- getDurability() - Method in class com.hazelcast.config.DurableExecutorConfig
-
Gets the durability of the executor
- getDurability() - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Gets the durability of the executor
- getDurability() - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorContainer
-
- getDurability() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
-
- getDurability() - Method in class com.hazelcast.transaction.TransactionOptions
-
Gets the transaction durability.
- getDurable(String) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
-
- getDurable(String) - Method in interface com.hazelcast.spi.impl.executionservice.InternalExecutionService
-
- getDurableExecutorConfig(String) - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getDurableExecutorConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the DurableExecutorConfig for the given name, creating one
if necessary and adding it to the collection of known configurations.
- getDurableExecutorConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getDurableExecutorConfigs() - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getDurableExecutorConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of durable executor configurations, mapped by config
name.
- getDurableExecutorConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
-
- getDurableExecutorConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
-
Returns all registered durable executor configurations.
- getDurableExecutorConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getDurableExecutorService(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getDurableExecutorService(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-
- getDurableExecutorService(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the durable executor service for the given name.
- getDurableExecutorService(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getDurableExecutorService(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getDurationAmount() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
-
- getDurationConfig() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
-
- getEmpty() - Method in class com.hazelcast.internal.jmx.suppliers.LocalMapStatsSupplier
-
- getEmpty() - Method in class com.hazelcast.internal.jmx.suppliers.LocalMultiMapStatsSupplier
-
- getEmpty() - Method in class com.hazelcast.internal.jmx.suppliers.LocalQueueStatsSupplier
-
- getEmpty() - Method in interface com.hazelcast.internal.jmx.suppliers.StatsSupplier
-
- getEmptyPollOperationCount() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- getEmptyPollOperationCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
-
Returns number of null returning poll operations.
- getEmptyQueueTtl() - Method in class com.hazelcast.config.QueueConfig
-
Returns the TTL (time to live) for emptying the Queue.
- getEncoder() - Method in class com.hazelcast.internal.ascii.AbstractTextCommand
-
- getEncoder() - Method in interface com.hazelcast.internal.ascii.TextCommand
-
- getEncoder() - Method in class com.hazelcast.nio.ascii.TextDecoder
-
- getEncodingType() - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.DenseHyperLogLogEncoder
-
- getEncodingType() - Method in interface com.hazelcast.cardinality.impl.hyperloglog.impl.HyperLogLogEncoder
-
Returns the encoding type of this instance; see: HyperLogLogEncoding
- getEncodingType() - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.SparseHyperLogLogEncoder
-
- getEndpoint(Connection) - Method in interface com.hazelcast.client.ClientEndpointManager
-
Gets the endpoint for a given connection.
- getEndPoint() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-
- getEndpoint(Connection) - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
-
- getEndpoint() - Method in class com.hazelcast.internal.partition.PartitionRuntimeState
-
- getEndPoint() - Method in interface com.hazelcast.nio.Connection
-
Gets the
Address
of the other side of this Connection.
- getEndPoint() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- getEndPoint() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionErrorHandler
-
- getEndpoint() - Method in class com.hazelcast.security.AbstractCredentials
-
- getEndpoint() - Method in interface com.hazelcast.security.Credentials
-
Returns IP address of endpoint.
- getEndpointManager() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getEndpoints() - Method in interface com.hazelcast.client.ClientEndpointManager
-
Returns the current endpoints.
- getEndpoints(String) - Method in interface com.hazelcast.client.ClientEndpointManager
-
Gets all the endpoints for a given client.
- getEndpoints(String) - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
-
- getEndpoints() - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
-
- getEndpoints() - Method in class com.hazelcast.config.PermissionConfig
-
- getEndToEndQueryCacheProvider() - Method in class com.hazelcast.map.impl.querycache.subscriber.AbstractSubscriberContext
-
- getEndToEndQueryCacheProvider() - Method in interface com.hazelcast.map.impl.querycache.subscriber.SubscriberContext
-
- getEngineByExtension(String) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
-
- getEngineByMimeType(String) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
-
- getEngineByName(String) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
-
- getEngineFactories() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
-
- getEngineName() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
-
- getEngineVersion() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
-
- getEntries() - Method in class com.hazelcast.cache.impl.CacheEntryIterationResult
-
- getEntries() - Method in class com.hazelcast.query.impl.QueryableEntriesSegment
-
- getEntryCostEstimator() - Method in interface com.hazelcast.map.impl.recordstore.Storage
-
- getEntryCostEstimator() - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
-
- getEntryCount() - Method in class com.hazelcast.cache.impl.CacheContext
-
- getEntryCount() - Method in class com.hazelcast.cache.impl.CacheEntryCountResolver
-
- getEntryEventDataCache() - Method in class com.hazelcast.map.impl.event.DefaultEntryEventFilteringStrategy
-
- getEntryEventDataCache() - Method in interface com.hazelcast.map.impl.event.FilteringStrategy
-
- getEntryEventDataCache() - Method in class com.hazelcast.map.impl.event.QueryCacheNaturalFilteringStrategy
-
- getEntryKey() - Method in class com.hazelcast.util.SampleableConcurrentHashMap.SamplingEntry
-
- getEntryListenerConfigs() - Method in class com.hazelcast.config.MapConfig
-
- getEntryListenerConfigs() - Method in class com.hazelcast.config.MapConfigReadOnly
-
Deprecated.
- getEntryListenerConfigs() - Method in class com.hazelcast.config.MultiMapConfig
-
Gets the list of entry listeners (listens for when entries are added or removed) for this MultiMap.
- getEntryListenerConfigs() - Method in class com.hazelcast.config.MultiMapConfigReadOnly
-
Deprecated.
- getEntryListenerConfigs() - Method in class com.hazelcast.config.QueryCacheConfig
-
- getEntryObject() - Method in class com.hazelcast.query.PredicateBuilder
-
- getEntryValue() - Method in class com.hazelcast.util.SampleableConcurrentHashMap.SamplingEntry
-
- getEntryView(K) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- getEntryView(K) - Method in interface com.hazelcast.core.IMap
-
Returns the EntryView
for the specified key.
- getEntryView(K) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- getEntryView() - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
-
- GetEntryViewOperation - Class in com.hazelcast.map.impl.operation
-
- GetEntryViewOperation() - Constructor for class com.hazelcast.map.impl.operation.GetEntryViewOperation
-
- GetEntryViewOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.GetEntryViewOperation
-
- getEnum(HazelcastProperty, Class<E>) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
- getEstimate() - Method in interface com.hazelcast.map.impl.EntryCostEstimator
-
Returns the memory cost estimation so far
- getEvent() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventEnvelope
-
- getEvent() - Method in class com.hazelcast.spi.impl.eventservice.impl.LocalEventDispatcher
-
- getEventCount() - Method in class com.hazelcast.internal.networking.nio.NioThread
-
Returns the total number of selection-key events that have been processed by this thread.
- getEventCounterMap() - Method in class com.hazelcast.wan.impl.WanEventCounter
-
- getEventData() - Method in class com.hazelcast.map.impl.querycache.event.SingleIMapEvent
-
- getEventExecutor() - Method in class com.hazelcast.client.spi.impl.listener.AbstractClientListenerService
-
- getEventExecutor() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-
- getEventFilter() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapAddEntryListenerMessageTask
-
- getEventFilter() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerMessageTask
-
- getEventFilter() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyMessageTask
-
- getEventFilter() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyWithPredicateMessageTask
-
- getEventFilter() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerWithPredicateMessageTask
-
- getEventFilter() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddNearCacheInvalidationListenerMessageTask
-
- getEventFilter() - Method in class com.hazelcast.client.impl.protocol.task.map.Pre38MapAddNearCacheEntryListenerMessageTask
-
- getEventFilter() - Method in class com.hazelcast.map.impl.EventListenerFilter
-
- getEventFilter() - Method in class com.hazelcast.map.impl.querycache.publisher.PartitionAccumulatorRegistry
-
- getEventHandler() - Method in class com.hazelcast.client.spi.impl.ClientInvocation
-
- getEventId() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventEnvelope
-
The event ID.
- getEventJournal() - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- getEventJournal() - Method in interface com.hazelcast.cache.impl.ICacheService
-
Returns an interface for interacting with the cache event journals.
- getEventJournal() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- getEventJournalConfig(ObjectNamespace) - Method in class com.hazelcast.cache.impl.journal.RingbufferCacheEventJournalImpl
-
Returns the event journal configuration or null
if there is none or the journal is disabled
for the given namespace
.
- getEventJournalConfig(ObjectNamespace) - Method in interface com.hazelcast.internal.journal.EventJournal
-
Returns the event journal configuration or null
if there is none or the journal is disabled
for the given namespace
.
- getEventJournalConfig(ObjectNamespace) - Method in class com.hazelcast.map.impl.journal.RingbufferMapEventJournalImpl
-
- getEventJournalConfig() - Method in class com.hazelcast.map.impl.MapContainer
-
- getEventLoopGroup() - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-
- getEventLoopGroup() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- getEventObject() - Method in class com.hazelcast.wan.WanReplicationEvent
-
Gets the event object.
- getEventOperationCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getEventOperationCount() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- getEventOperationCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getEventOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the number of Events Received
- getEventOperationCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
-
Returns number of event operations
- getEventPublishingService() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-
- getEventQueueCapacity() - Method in class com.hazelcast.internal.jmx.EventServiceMBean
-
- getEventQueueCapacity() - Method in interface com.hazelcast.spi.EventService
-
Returns the queue capacity per event thread.
- getEventQueueCapacity() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-
- getEventQueueSize() - Method in class com.hazelcast.internal.jmx.EventServiceMBean
-
- getEventQueueSize() - Method in interface com.hazelcast.spi.EventService
-
Returns the current total event queue size.
- getEventQueueSize() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-
- getEvents() - Method in class com.hazelcast.cache.impl.CacheEventSet
-
- getEvents() - Method in class com.hazelcast.map.impl.querycache.event.BatchEventData
-
- getEventService() - Method in interface com.hazelcast.client.ClientEngine
-
- getEventService() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getEventService() - Method in class com.hazelcast.map.impl.querycache.subscriber.AbstractSubscriberContext
-
- getEventService() - Method in interface com.hazelcast.map.impl.querycache.subscriber.SubscriberContext
-
- getEventService() - Method in interface com.hazelcast.nio.IOService
-
- getEventService() - Method in class com.hazelcast.nio.NodeIOService
-
- getEventService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getEventService() - Method in interface com.hazelcast.spi.NodeEngine
-
Gets the EventService.
- getEventServiceBean() - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
-
- getEventServiceMBean() - Method in class com.hazelcast.internal.jmx.InstanceMBean
-
- getEventSource() - Method in class com.hazelcast.partition.PartitionLostEvent
-
Returns the address of the node that dispatches the event
- getEventSource() - Method in class com.hazelcast.spi.partition.IPartitionLostEvent
-
The address of the node that detects the partition lost.
- getEventThreadCount() - Method in class com.hazelcast.internal.jmx.EventServiceMBean
-
- getEventThreadCount() - Method in interface com.hazelcast.spi.EventService
-
Returns the event thread count.
- getEventThreadCount() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-
- getEventType() - Method in class com.hazelcast.cache.impl.CacheEventContext
-
- getEventType() - Method in class com.hazelcast.cache.impl.CacheEventSet
-
- getEventType() - Method in class com.hazelcast.cache.impl.event.AbstractICacheEvent
-
- getEventType() - Method in interface com.hazelcast.cache.impl.event.ICacheEvent
-
Return the event type
- getEventType() - Method in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
-
Return the integer defining the event type.
- getEventType() - Method in class com.hazelcast.client.ClientEvent
-
- getEventType() - Method in class com.hazelcast.collection.impl.collection.CollectionEvent
-
- getEventType() - Method in class com.hazelcast.collection.impl.queue.QueueEvent
-
- getEventType() - Method in class com.hazelcast.core.AbstractIMapEvent
-
- getEventType() - Method in class com.hazelcast.core.DistributedObjectEvent
-
- getEventType() - Method in interface com.hazelcast.core.IMapEvent
-
Return the event type
- getEventType() - Method in class com.hazelcast.core.ItemEvent
-
Returns the event type.
- getEventType() - Method in class com.hazelcast.core.MembershipEvent
-
Returns the membership event type;
#MEMBER_ADDED
#MEMBER_REMOVED
#MEMBER_ATTRIBUTE_CHANGED
- getEventType() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidation
-
- getEventType() - Method in class com.hazelcast.map.EventLostEvent
-
Intentionally returns null
.
- getEventType() - Method in interface com.hazelcast.map.impl.event.EventData
-
- getEventType() - Method in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
-
Return the integer defining the event type.
- getEventType() - Method in class com.hazelcast.map.impl.operation.EntryOperator
-
- getEventType() - Method in class com.hazelcast.map.impl.operation.WanEventHolder
-
- getEventType() - Method in class com.hazelcast.map.impl.querycache.event.BatchEventData
-
- getEventType() - Method in class com.hazelcast.map.impl.querycache.event.BatchIMapEvent
-
- getEventType() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-
- getEventType() - Method in class com.hazelcast.map.impl.querycache.event.LocalCacheWideEventData
-
- getEventType() - Method in class com.hazelcast.map.impl.querycache.event.LocalEntryEventData
-
- getEventType() - Method in class com.hazelcast.map.impl.querycache.event.SingleIMapEvent
-
- getEventType() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
-
- getEventType() - Method in class com.hazelcast.spi.impl.PortableDistributedObjectEvent
-
- getEventType() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
-
- getEventType() - Method in class com.hazelcast.spi.impl.PortableItemEvent
-
- getEventType() - Method in class com.hazelcast.spi.impl.proxyservice.impl.DistributedObjectEventPacket
-
- getEvictable() - Method in interface com.hazelcast.internal.eviction.EvictionCandidate
-
The value of
Evictable
entry or record or whatever.
- getEvictable() - Method in class com.hazelcast.internal.nearcache.impl.store.HeapNearCacheRecordMap.NearCacheEvictableSamplingEntry
-
- getEvictionConfig() - Method in class com.hazelcast.config.CacheConfig
-
- getEvictionConfig() - Method in class com.hazelcast.config.CacheConfigReadOnly
-
Deprecated.
- getEvictionConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the eviction configuration for this
ICache
.
- getEvictionConfig() - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-
Deprecated.
- getEvictionConfig() - Method in class com.hazelcast.config.NearCacheConfig
-
Returns the eviction configuration for this Near Cache.
- getEvictionConfig() - Method in class com.hazelcast.config.NearCacheConfigReadOnly
-
Deprecated.
- getEvictionConfig() - Method in class com.hazelcast.config.QueryCacheConfig
-
- getEvictionConfig(Node) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
-
- getEvictionConfigHolder() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.NearCacheConfigHolder
-
- getEvictionConfigHolder() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
-
- getEvictionCriteriaNumber() - Method in class com.hazelcast.map.impl.SimpleEntryView
-
Needed for client protocol compatibility.
- getEvictionPercentage() - Method in class com.hazelcast.config.MapConfig
-
- getEvictionPolicy() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.EvictionConfigHolder
-
- getEvictionPolicy() - Method in class com.hazelcast.config.EvictionConfig
-
- getEvictionPolicy() - Method in class com.hazelcast.config.MapConfig
-
- getEvictionPolicy() - Method in class com.hazelcast.config.NearCacheConfig
-
- getEvictionPolicy() - Method in interface com.hazelcast.internal.eviction.EvictionConfiguration
-
Gets the eviction policy.
- getEvictionPolicyComparator() - Method in class com.hazelcast.internal.eviction.impl.evaluator.EvictionPolicyEvaluator
-
- getEvictionPolicyEvaluator(EvictionConfiguration, ClassLoader) - Static method in class com.hazelcast.internal.eviction.EvictionPolicyEvaluatorProvider
-
- getEvictionPolicyType() - Method in class com.hazelcast.config.EvictionConfig
-
- getEvictionPolicyType() - Method in interface com.hazelcast.internal.eviction.EvictionConfiguration
-
- getEvictions() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-
- getEvictions() - Method in interface com.hazelcast.monitor.NearCacheStats
-
Returns the number of evictions of Near Cache entries owned by this member.
- getEvictionStrategyType() - Method in class com.hazelcast.config.EvictionConfig
-
- getEvictionStrategyType() - Method in interface com.hazelcast.internal.eviction.EvictionConfiguration
-
Gets the type of eviction strategy.
- getEvictor() - Method in class com.hazelcast.map.impl.MapContainer
-
- getException() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskResult
-
- getExcludedMemberUuids() - Method in interface com.hazelcast.hotrestart.InternalHotRestartService
-
Returns UUIDs of the members that have been excluded during the cluster start.
- getExcludedMemberUuids() - Method in class com.hazelcast.hotrestart.NoopInternalHotRestartService
-
- getExcludedMemberUuids() - Method in class com.hazelcast.internal.cluster.impl.JoinRequest
-
- getExecutedCount() - Method in class com.hazelcast.internal.jmx.ManagedExecutorServiceMBean
-
- getExecutedOperationCount() - Method in class com.hazelcast.internal.jmx.OperationServiceMBean
-
- getExecutedOperationCount() - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
-
- getExecutedOperationCount() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
-
Returns the number of executed operations.
- getExecutedOperationCount() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-
- getExecutedOperationCount() - Method in interface com.hazelcast.spi.impl.operationservice.InternalOperationService
-
Returns the number of executed operations.
- getExecutionCallback() - Method in class com.hazelcast.spi.InvocationBuilder
-
Gets the ExecutionCallback.
- getExecutionService() - Method in class com.hazelcast.client.spi.ClientContext
-
- getExecutionService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getExecutionService() - Method in interface com.hazelcast.spi.NodeEngine
-
Gets the ExecutionService.
- getExecutor() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
-
Gets the Executor that is going to process the events.
- getExecutor() - Method in class com.hazelcast.config.ReliableTopicConfig
-
Gets the Executor that is going to process the events.
- getExecutor(String) - Method in interface com.hazelcast.spi.ExecutionService
-
- getExecutor(String) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
-
- getExecutorConfig(String) - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getExecutorConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the ExecutorConfig for the given name, creating one
if necessary and adding it to the collection of known configurations.
- getExecutorConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getExecutorConfigs() - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getExecutorConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of executor configurations, mapped by config name.
- getExecutorConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
-
- getExecutorConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
-
Returns all registered executor configurations.
- getExecutorConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getExecutorName() - Method in interface com.hazelcast.core.Offloadable
-
Returns the name of the executor to which the processing unit will be off-loaded.
- getExecutorPoolSize() - Method in class com.hazelcast.client.config.ClientConfig
-
Pool size for internal ExecutorService which handles responses etc.
- getExecutorService(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getExecutorService(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-
- getExecutorService(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the distributed executor service for the given name.
- getExecutorService(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getExecutorService(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getExecutorService(String) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- getExistingRecordStore(int, String) - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- getExistingRecordStore(String) - Method in class com.hazelcast.map.impl.PartitionContainer
-
- getExpiration() - Method in class com.hazelcast.internal.ascii.memcache.DeleteCommand
-
- getExpiration() - Method in class com.hazelcast.internal.ascii.memcache.SetCommand
-
- getExpiration() - Method in class com.hazelcast.internal.ascii.memcache.TouchCommand
-
- getExpirationManager() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- getExpirations() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-
- getExpirations() - Method in interface com.hazelcast.monitor.NearCacheStats
-
Returns the number of TTL and max-idle expirations of Near Cache entries owned by this member.
- getExpirationTime() - Method in interface com.hazelcast.cache.CacheEntryView
-
Gets the expiration time in milliseconds of the cache entry.
- getExpirationTime() - Method in class com.hazelcast.cache.impl.CacheEventContext
-
- getExpirationTime() - Method in class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
-
- getExpirationTime() - Method in class com.hazelcast.cache.impl.merge.entry.LazyCacheEntryView
-
- getExpirationTime() - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-
- getExpirationTime() - Method in interface com.hazelcast.concurrent.lock.LockResource
-
- getExpirationTime() - Method in interface com.hazelcast.core.EntryView
-
Returns the expiration time of the entry.
- getExpirationTime() - Method in interface com.hazelcast.internal.eviction.Expirable
-
Gets the expiration time in milliseconds.
- getExpirationTime() - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest.CacheBrowserEntryView
-
- getExpirationTime() - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
-
- getExpirationTime() - Method in class com.hazelcast.map.impl.record.AbstractRecord
-
- getExpirationTime() - Method in interface com.hazelcast.map.impl.record.Record
-
- getExpirationTime() - Method in class com.hazelcast.map.impl.record.RecordInfo
-
- getExpirationTime() - Method in class com.hazelcast.map.impl.recordstore.LazyEntryViewFromRecord
-
- getExpirationTime() - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- getExpirationTime() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-
- getExpirationTime() - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
-
- getExpirationTime() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
-
- getExpirationTime() - Method in interface com.hazelcast.spi.merge.MergingExpirationTime
-
Returns the expiration time of the merge data.
- getExpiredKeys() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
- getExpiryForAccess() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-
- getExpiryForCreation() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-
- getExpiryForUpdate() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-
- getExpiryPolicy(ExpiryPolicy) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- getExpiryPolicyFactory() - Method in class com.hazelcast.config.AbstractCacheConfig
-
- getExpiryPolicyFactoryConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the factory configuration for the ExpiryPolicy
.
- getExpiryPolicyType() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
-
- getExtensions() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
-
- getExtractor() - Method in class com.hazelcast.config.MapAttributeConfig
-
Gets the full class name of the extractor in a String format, e.g.
- getExtractors() - Method in class com.hazelcast.map.impl.MapContainer
-
- getExtractors(String) - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- getFactories() - Method in class com.hazelcast.client.impl.protocol.DefaultMessageTaskFactoryProvider
-
- getFactories() - Method in interface com.hazelcast.client.impl.protocol.MessageTaskFactoryProvider
-
- getFactoryClassName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
-
- getFactoryClassName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueueStoreConfigHolder
-
- getFactoryClassName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.RingbufferStoreConfigHolder
-
- getFactoryClassName() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns the name of the MapStoreFactory implementation class
- getFactoryClassName() - Method in class com.hazelcast.config.MCMutualAuthConfig
-
Returns the name of the implementation class.
- getFactoryClassName() - Method in class com.hazelcast.config.QueueStoreConfig
-
- getFactoryClassName() - Method in class com.hazelcast.config.RingbufferStoreConfig
-
- getFactoryClassName() - Method in class com.hazelcast.config.SSLConfig
-
Returns the name of the implementation class.
- getFactoryId() - Method in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.aggregation.impl.BigDecimalAverageAggregator
-
- getFactoryId() - Method in class com.hazelcast.aggregation.impl.BigDecimalSumAggregator
-
- getFactoryId() - Method in class com.hazelcast.aggregation.impl.BigIntegerAverageAggregator
-
- getFactoryId() - Method in class com.hazelcast.aggregation.impl.BigIntegerSumAggregator
-
- getFactoryId() - Method in class com.hazelcast.aggregation.impl.CountAggregator
-
- getFactoryId() - Method in class com.hazelcast.aggregation.impl.DistinctValuesAggregator
-
- getFactoryId() - Method in class com.hazelcast.aggregation.impl.DoubleAverageAggregator
-
- getFactoryId() - Method in class com.hazelcast.aggregation.impl.DoubleSumAggregator
-
- getFactoryId() - Method in class com.hazelcast.aggregation.impl.FixedSumAggregator
-
- getFactoryId() - Method in class com.hazelcast.aggregation.impl.FloatingPointSumAggregator
-
- getFactoryId() - Method in class com.hazelcast.aggregation.impl.IntegerAverageAggregator
-
- getFactoryId() - Method in class com.hazelcast.aggregation.impl.IntegerSumAggregator
-
- getFactoryId() - Method in class com.hazelcast.aggregation.impl.LongAverageAggregator
-
- getFactoryId() - Method in class com.hazelcast.aggregation.impl.LongSumAggregator
-
- getFactoryId() - Method in class com.hazelcast.aggregation.impl.MaxAggregator
-
- getFactoryId() - Method in class com.hazelcast.aggregation.impl.MaxByAggregator
-
- getFactoryId() - Method in class com.hazelcast.aggregation.impl.MinAggregator
-
- getFactoryId() - Method in class com.hazelcast.aggregation.impl.MinByAggregator
-
- getFactoryId() - Method in class com.hazelcast.aggregation.impl.NumberAverageAggregator
-
- getFactoryId() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.CacheClearResponse
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.CacheEntryIterationResult
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.CacheEventListenerAdaptor
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.CacheEventSet
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.CacheKeyIterationResult
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.event.CachePartitionLostEventFilter
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.journal.CacheEventJournalReadOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.journal.CacheEventJournalReadResultSetImpl
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.journal.CacheEventJournalSubscribeOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.AbstractCacheOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.AddCacheConfigOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
-
Deprecated.
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheDestroyOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheGetConfigOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheGetInvalidationMetaDataOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheGetInvalidationMetaDataOperation.MetaDataResponse
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheListenerRegistrationOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheMergeOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheMergeOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheNearCacheStateHolder
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CachePutAllBackupOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CachePutAllOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.OnJoinCacheOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.PreJoinCacheConfig
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-
- getFactoryId() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorContainer
-
- getFactoryId() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.DenseHyperLogLogEncoder
-
- getFactoryId() - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.HyperLogLogImpl
-
- getFactoryId() - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.SparseHyperLogLogEncoder
-
- getFactoryId() - Method in class com.hazelcast.cardinality.impl.operations.AbstractCardinalityEstimatorOperation
-
- getFactoryId() - Method in class com.hazelcast.cardinality.impl.operations.ReplicationOperation
-
- getFactoryId() - Method in class com.hazelcast.client.impl.ClientDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.client.impl.operations.AbstractClientOperation
-
- getFactoryId() - Method in class com.hazelcast.client.impl.operations.OperationFactoryWrapper
-
- getFactoryId() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsOperation
-
- getFactoryId() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsOperation
-
- getFactoryId() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.cluster.impl.VectorClock
-
- getFactoryId() - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-
- getFactoryId() - Method in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.collection.impl.collection.CollectionEvent
-
- getFactoryId() - Method in class com.hazelcast.collection.impl.collection.CollectionEventFilter
-
- getFactoryId() - Method in class com.hazelcast.collection.impl.collection.CollectionItem
-
- getFactoryId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionOperation
-
- getFactoryId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionReplicationOperation
-
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.operations.OfferBackupOperation
-
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.operations.OfferOperation
-
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.operations.PeekOperation
-
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.operations.PollBackupOperation
-
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.operations.PollOperation
-
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.operations.QueueOperation
-
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.operations.QueueReplicationOperation
-
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.QueueEvent
-
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.QueueEventFilter
-
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.QueueItem
-
- getFactoryId() - Method in class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
-
- getFactoryId() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AbstractAtomicLongOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.concurrent.atomicreference.operations.AbstractAtomicReferenceOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
-
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.LockDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.operations.LockReplicationOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreReplicationOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
-
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.config.AbstractBasicConfig
-
- getFactoryId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
-
- getFactoryId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
-
- getFactoryId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
-
- getFactoryId() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- getFactoryId() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- getFactoryId() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
- getFactoryId() - Method in class com.hazelcast.config.CollectionConfig
-
- getFactoryId() - Method in class com.hazelcast.config.ConfigDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.config.CountDownLatchConfig
-
- getFactoryId() - Method in class com.hazelcast.config.DurableExecutorConfig
-
- getFactoryId() - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
-
- getFactoryId() - Method in class com.hazelcast.config.EventJournalConfig
-
- getFactoryId() - Method in class com.hazelcast.config.ExecutorConfig
-
- getFactoryId() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
- getFactoryId() - Method in class com.hazelcast.config.HotRestartConfig
-
- getFactoryId() - Method in class com.hazelcast.config.ListenerConfig
-
- getFactoryId() - Method in class com.hazelcast.config.LockConfig
-
- getFactoryId() - Method in class com.hazelcast.config.MapAttributeConfig
-
- getFactoryId() - Method in class com.hazelcast.config.MapConfig
-
- getFactoryId() - Method in class com.hazelcast.config.MapIndexConfig
-
- getFactoryId() - Method in class com.hazelcast.config.MapStoreConfig
-
- getFactoryId() - Method in class com.hazelcast.config.MergePolicyConfig
-
- getFactoryId() - Method in class com.hazelcast.config.MultiMapConfig
-
- getFactoryId() - Method in class com.hazelcast.config.NearCacheConfig
-
- getFactoryId() - Method in class com.hazelcast.config.NearCachePreloaderConfig
-
- getFactoryId() - Method in class com.hazelcast.config.PartitioningStrategyConfig
-
- getFactoryId() - Method in class com.hazelcast.config.PNCounterConfig
-
- getFactoryId() - Method in class com.hazelcast.config.PredicateConfig
-
- getFactoryId() - Method in class com.hazelcast.config.QueryCacheConfig
-
- getFactoryId() - Method in class com.hazelcast.config.QueueConfig
-
- getFactoryId() - Method in class com.hazelcast.config.QueueStoreConfig
-
- getFactoryId() - Method in class com.hazelcast.config.QuorumConfig
-
- getFactoryId() - Method in class com.hazelcast.config.ReliableTopicConfig
-
- getFactoryId() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- getFactoryId() - Method in class com.hazelcast.config.RingbufferConfig
-
- getFactoryId() - Method in class com.hazelcast.config.RingbufferStoreConfig
-
- getFactoryId() - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
- getFactoryId() - Method in class com.hazelcast.config.SemaphoreConfig
-
- getFactoryId() - Method in class com.hazelcast.config.TopicConfig
-
- getFactoryId() - Method in class com.hazelcast.config.WanConsumerConfig
-
- getFactoryId() - Method in class com.hazelcast.config.WanPublisherConfig
-
- getFactoryId() - Method in class com.hazelcast.config.WanReplicationConfig
-
- getFactoryId() - Method in class com.hazelcast.crdt.AbstractCRDTReplicationOperation
-
- getFactoryId() - Method in class com.hazelcast.crdt.CRDTDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.crdt.pncounter.operations.AbstractPNCounterOperation
-
- getFactoryId() - Method in class com.hazelcast.crdt.pncounter.operations.CRDTTimestampedLong
-
- getFactoryId() - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
-
- getFactoryId() - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.durableexecutor.impl.operations.ReplicationOperation
-
- getFactoryId() - Method in class com.hazelcast.executor.impl.ExecutorDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.executor.impl.operations.CancellationOperation
-
- getFactoryId() - Method in class com.hazelcast.executor.impl.operations.ShutdownOperation
-
- getFactoryId() - Method in class com.hazelcast.executor.impl.RunnableAdapter
-
- getFactoryId() - Method in class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.instance.MemberImpl
-
- getFactoryId() - Method in class com.hazelcast.internal.ascii.memcache.MemcacheEntry
-
- getFactoryId() - Method in class com.hazelcast.internal.ascii.rest.RestValue
-
- getFactoryId() - Method in class com.hazelcast.internal.ascii.TextProtocolsDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.BindMessage
-
- getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.ClusterStateChange
-
- getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.ClusterStateTransactionLogRecord
-
- getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.ConfigCheck
-
- getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.JoinMessage
-
- getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.MembersView
-
- getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.MembersViewMetadata
-
- getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.operations.AbstractJoinOperation
-
- getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.operations.CommitClusterStateOp
-
- getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.operations.LockClusterStateOp
-
- getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.operations.RollbackClusterStateOp
-
- getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.SplitBrainJoinMessage
-
- getFactoryId() - Method in class com.hazelcast.internal.cluster.MemberInfo
-
- getFactoryId() - Method in class com.hazelcast.internal.dynamicconfig.AbstractDynamicConfigOperation
-
- getFactoryId() - Method in class com.hazelcast.internal.journal.EventJournalDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.internal.journal.EventJournalInitialSubscriberState
-
- getFactoryId() - Method in class com.hazelcast.internal.management.dto.MapConfigDTO
-
- getFactoryId() - Method in class com.hazelcast.internal.management.dto.PermissionConfigDTO
-
- getFactoryId() - Method in class com.hazelcast.internal.management.ManagementDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.internal.management.operation.AbstractManagementOperation
-
- getFactoryId() - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest.CacheBrowserEntryView
-
- getFactoryId() - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest.GetCacheEntryViewEntryProcessor
-
- getFactoryId() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidation
-
- getFactoryId() - Method in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.internal.partition.impl.PartitionPortableHook
-
- getFactoryId() - Method in class com.hazelcast.internal.partition.MigrationInfo
-
- getFactoryId() - Method in class com.hazelcast.internal.partition.NonFragmentedServiceNamespace
-
- getFactoryId() - Method in class com.hazelcast.internal.partition.PartitionRuntimeState
-
- getFactoryId() - Method in class com.hazelcast.internal.partition.ReplicaFragmentMigrationState
-
- getFactoryId() - Method in interface com.hazelcast.internal.serialization.DataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
-
- getFactoryId(String, int) - Static method in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- getFactoryId() - Method in class com.hazelcast.internal.serialization.impl.FieldDefinitionImpl
-
- getFactoryId() - Method in interface com.hazelcast.internal.serialization.PortableHook
-
- getFactoryId() - Method in class com.hazelcast.internal.usercodedeployment.impl.ClassData
-
- getFactoryId() - Method in class com.hazelcast.internal.usercodedeployment.impl.operation.ClassDataFinderOperation
-
- getFactoryId() - Method in class com.hazelcast.internal.usercodedeployment.impl.operation.DeployClassesOperation
-
- getFactoryId() - Method in class com.hazelcast.internal.usercodedeployment.impl.UserCodeDeploymentSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.map.eviction.LFUEvictionPolicy
-
- getFactoryId() - Method in class com.hazelcast.map.eviction.LRUEvictionPolicy
-
- getFactoryId() - Method in class com.hazelcast.map.eviction.RandomEvictionPolicy
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapPortableHook
-
- getFactoryId() - Method in class com.hazelcast.map.impl.EntryEventFilter
-
- getFactoryId() - Method in class com.hazelcast.map.impl.EntryRemovingProcessor
-
- getFactoryId() - Method in class com.hazelcast.map.impl.EventListenerFilter
-
- getFactoryId() - Method in class com.hazelcast.map.impl.iterator.AbstractCursor
-
- getFactoryId() - Method in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
-
- getFactoryId() - Method in class com.hazelcast.map.impl.journal.MapEventJournalReadOperation
-
- getFactoryId() - Method in class com.hazelcast.map.impl.journal.MapEventJournalReadResultSetImpl
-
- getFactoryId() - Method in class com.hazelcast.map.impl.LazyMapEntry
-
- getFactoryId() - Method in class com.hazelcast.map.impl.LockAwareLazyMapEntry
-
- getFactoryId() - Method in class com.hazelcast.map.impl.MapDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.map.impl.MapEntries
-
- getFactoryId() - Method in class com.hazelcast.map.impl.MapKeySet
-
- getFactoryId() - Method in class com.hazelcast.map.impl.MapPartitionLostEventFilter
-
- getFactoryId() - Method in class com.hazelcast.map.impl.MapValueCollection
-
- getFactoryId() - Method in class com.hazelcast.map.impl.nearcache.invalidation.UuidFilter
-
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.AbstractMapOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.AccumulatorConsumerOperation
-
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.AddInterceptorOperation
-
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.MapGetInvalidationMetaDataOperation
-
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.MapGetInvalidationMetaDataOperation.MetaDataResponse
-
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.MapNearCacheStateHolder
-
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.MapOperation
-
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.MapReplicationOperation
-
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.MapReplicationStateHolder
-
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.MergeOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation
-
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation.InterceptorInfo
-
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.PutAllPartitionAwareOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.RemoveInterceptorOperation
-
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.WriteBehindStateHolder
-
- getFactoryId() - Method in class com.hazelcast.map.impl.query.AggregationResult
-
- getFactoryId() - Method in class com.hazelcast.map.impl.query.Query
-
- getFactoryId() - Method in class com.hazelcast.map.impl.query.QueryResult
-
- getFactoryId() - Method in class com.hazelcast.map.impl.query.QueryResultRow
-
- getFactoryId() - Method in class com.hazelcast.map.impl.query.ResultSegment
-
- getFactoryId() - Method in class com.hazelcast.map.impl.query.Target
-
- getFactoryId() - Method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
-
- getFactoryId() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.DestroyQueryCacheOperation
-
- getFactoryId() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.MadePublishableOperation
-
- getFactoryId() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.MadePublishableOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.PublisherCreateOperation
-
- getFactoryId() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.ReadAndResetAccumulatorOperation
-
- getFactoryId() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.SetReadCursorOperation
-
- getFactoryId() - Method in class com.hazelcast.map.impl.record.RecordInfo
-
- getFactoryId() - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- getFactoryId() - Method in class com.hazelcast.map.impl.tx.MapTransactionLogRecord
-
- getFactoryId() - Method in class com.hazelcast.map.impl.tx.VersionedValue
-
- getFactoryId() - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
-
- getFactoryId() - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
-
- getFactoryId() - Method in class com.hazelcast.map.merge.HigherHitsMapMergePolicy
-
- getFactoryId() - Method in class com.hazelcast.map.merge.IgnoreMergingEntryMapMergePolicy
-
- getFactoryId() - Method in class com.hazelcast.map.merge.LatestUpdateMapMergePolicy
-
- getFactoryId() - Method in class com.hazelcast.map.merge.PassThroughMergePolicy
-
- getFactoryId() - Method in class com.hazelcast.map.merge.PutIfAbsentMapMergePolicy
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.aggregation.impl.AcceptAllSupplier
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.aggregation.impl.AvgTuple
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.aggregation.impl.KeyPredicateSupplier
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.aggregation.impl.PredicateSupplier
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.aggregation.impl.SetAdapter
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.CombinerResultList
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.HashMapAdapter
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.ListKeyValueSource
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.MapKeyValueSource
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.MapReducePortableHook
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.MultiMapKeyValueSource
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.notification.IntermediateChunkNotification
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.notification.LastChunkNotification
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.notification.ReducingFinishedNotification
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.CancelJobSupervisorOperation
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.FireNotificationOperation
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.GetResultOperation
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.GetResultOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.KeysAssignmentOperation
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.KeysAssignmentResult
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.KeyValueJobOperation
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.NotifyRemoteExceptionOperation
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.PostPonePartitionProcessing
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.ProcessStatsUpdateOperation
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestMemberIdAssignment
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionMapping
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionProcessed
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionReducing
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionResult
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.StartProcessingJobOperation
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.SetKeyValueSource
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.task.TransferableJobProcessInformation
-
- getFactoryId() - Method in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.multimap.impl.MultiMapEventFilter
-
- getFactoryId() - Method in class com.hazelcast.multimap.impl.MultiMapMergeContainer
-
- getFactoryId() - Method in class com.hazelcast.multimap.impl.MultiMapRecord
-
- getFactoryId() - Method in class com.hazelcast.multimap.impl.operations.AbstractMultiMapOperation
-
- getFactoryId() - Method in class com.hazelcast.multimap.impl.operations.EntrySetResponse
-
- getFactoryId() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.multimap.impl.operations.MultiMapReplicationOperation
-
- getFactoryId() - Method in class com.hazelcast.multimap.impl.operations.MultiMapResponse
-
- getFactoryId() - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLogRecord
-
- getFactoryId() - Method in class com.hazelcast.nio.Address
-
- getFactoryId() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Returns the factory ID.
- getFactoryId() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- getFactoryId() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
-
- getFactoryId() - Method in interface com.hazelcast.nio.serialization.IdentifiedDataSerializable
-
Returns DataSerializableFactory factory ID for this class.
- getFactoryId() - Method in interface com.hazelcast.nio.serialization.Portable
-
Returns PortableFactory ID for this portable class
- getFactoryId() - Method in class com.hazelcast.projection.impl.IdentityProjection
-
- getFactoryId() - Method in class com.hazelcast.projection.impl.MultiAttributeProjection
-
- getFactoryId() - Method in class com.hazelcast.projection.impl.ProjectionDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.projection.impl.SingleAttributeProjection
-
- getFactoryId() - Method in class com.hazelcast.query.impl.FalsePredicate
-
- getFactoryId() - Method in class com.hazelcast.query.impl.IndexImpl.NullObject
-
- getFactoryId() - Method in class com.hazelcast.query.impl.IndexInfo
-
- getFactoryId() - Method in class com.hazelcast.query.impl.MapIndexInfo
-
- getFactoryId() - Method in class com.hazelcast.query.impl.predicates.AbstractPredicate
-
- getFactoryId() - Method in class com.hazelcast.query.impl.predicates.AndPredicate
-
- getFactoryId() - Method in class com.hazelcast.query.impl.predicates.InstanceOfPredicate
-
- getFactoryId() - Method in class com.hazelcast.query.impl.predicates.NotPredicate
-
- getFactoryId() - Method in class com.hazelcast.query.impl.predicates.OrPredicate
-
- getFactoryId() - Method in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.query.PagingPredicate
-
- getFactoryId() - Method in class com.hazelcast.query.PartitionPredicate
-
- getFactoryId() - Method in class com.hazelcast.query.SqlPredicate
-
- getFactoryId() - Method in class com.hazelcast.query.TruePredicate
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntries
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapKeys
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapValueCollection
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.operation.AbstractSerializableOperation
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperation
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.operation.MergeOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.operation.PutAllOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.operation.VersionResponsePair
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.merge.HigherHitsMapMergePolicy
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.merge.LatestUpdateMapMergePolicy
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.merge.PassThroughMergePolicy
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.merge.PutIfAbsentMapMergePolicy
-
- getFactoryId() - Method in class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
-
- getFactoryId() - Method in class com.hazelcast.ringbuffer.impl.client.RingbufferPortableHook
-
- getFactoryId() - Method in class com.hazelcast.ringbuffer.impl.operations.AbstractRingBufferOperation
-
- getFactoryId() - Method in class com.hazelcast.ringbuffer.impl.operations.MergeOperation
-
- getFactoryId() - Method in class com.hazelcast.ringbuffer.impl.operations.ReplicationOperation
-
- getFactoryId() - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
-
- getFactoryId() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-
- getFactoryId() - Method in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.scheduledexecutor.impl.NamedTaskDecorator
-
- getFactoryId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.AbstractSchedulerOperation
-
- getFactoryId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnPartitionOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.ReplicationOperation
-
- getFactoryId() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledRunnableAdapter
-
- getFactoryId() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskDescriptor
-
- getFactoryId() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskHandlerImpl
-
- getFactoryId() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskResult
-
- getFactoryId() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskStatisticsImpl
-
- getFactoryId() - Method in class com.hazelcast.scheduledexecutor.impl.TaskDefinition
-
- getFactoryId() - Method in class com.hazelcast.security.UsernamePasswordCredentials
-
- getFactoryId() - Method in class com.hazelcast.spi.AbstractLocalOperation
-
- getFactoryId() - Method in class com.hazelcast.spi.DistributedObjectNamespace
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.BinaryOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventEnvelope
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.OnJoinRegistrationOperation
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.SendEventOperation
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.eventservice.impl.TrueEventFilter
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.merge.AbstractCollectionMergingValueImpl
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.merge.AbstractMergingEntryImpl
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.merge.AbstractMergingValueImpl
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.merge.AbstractSplitBrainMergePolicy
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.merge.RingbufferMergingValueImpl
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation.PartitionResponse
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.CallTimeoutResponse
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.Response
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.PortableCachePartitionLostEvent
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.PortableCollection
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.PortableDistributedObjectEvent
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.PortableItemEvent
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.PortableMapPartitionLostEvent
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.PortablePartitionLostEvent
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.DistributedObjectDestroyOperation
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.InitializeDistributedObjectOperation
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.PostJoinProxyOperation
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.SerializableList
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.SpiDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.SpiPortableHook
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
-
- getFactoryId() - Method in class com.hazelcast.spi.OperationControl
-
- getFactoryId() - Method in class com.hazelcast.topic.impl.PublishOperation
-
- getFactoryId() - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicMessage
-
- getFactoryId() - Method in class com.hazelcast.topic.impl.TopicDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.topic.impl.TopicEvent
-
- getFactoryId() - Method in class com.hazelcast.transaction.impl.operations.AbstractTxOperation
-
- getFactoryId() - Method in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.transaction.impl.xa.operations.AbstractXAOperation
-
- getFactoryId() - Method in class com.hazelcast.transaction.impl.xa.operations.XaReplicationOperation
-
- getFactoryId() - Method in class com.hazelcast.transaction.impl.xa.XATransactionDTO
-
- getFactoryId() - Method in class com.hazelcast.version.MemberVersion
-
- getFactoryId() - Method in class com.hazelcast.version.Version
-
- getFactoryId() - Method in class com.hazelcast.wan.impl.WanDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.wan.WanReplicationEvent
-
- getFactoryImpl() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
-
- getFactoryImplementation() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
-
- getFactoryImplementation() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueueStoreConfigHolder
-
- getFactoryImplementation() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.RingbufferStoreConfigHolder
-
- getFactoryImplementation() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns the map store factory implementation object.
- getFactoryImplementation() - Method in class com.hazelcast.config.MCMutualAuthConfig
-
Returns the factory implementation object.
- getFactoryImplementation() - Method in class com.hazelcast.config.QueueStoreConfig
-
- getFactoryImplementation() - Method in class com.hazelcast.config.RingbufferStoreConfig
-
- getFactoryImplementation() - Method in class com.hazelcast.config.SSLConfig
-
Returns the factory implementation object.
- getField(String) - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
-
- getField(int) - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
-
- getField(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Gets the FieldDefinition for a particular field.
- getField(int) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Gets the FieldDefinition for a given fieldIndex.
- getFieldClassId(String) - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
-
- getFieldClassId(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-
- getFieldClassId(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Gets the class ID of a field.
- getFieldClassId(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- getFieldCount() - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
-
- getFieldCount() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Returns the field count.
- getFieldDefinition(ClassDefinition, String) - Method in interface com.hazelcast.internal.serialization.PortableContext
-
- getFieldNames() - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
-
- getFieldNames() - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-
- getFieldNames() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Returns a Set of all field names.
- getFieldNames() - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- getFieldType(String) - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
-
- getFieldType(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-
- getFieldType(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Get the FieldType for a given fieldName.
- getFieldType(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- getFileFromResources(String) - Static method in class com.hazelcast.nio.IOUtil
-
- getFileFromResourcesAsStream(String) - Static method in class com.hazelcast.nio.IOUtil
-
- getFilter() - Method in class com.hazelcast.client.impl.querycache.subscriber.ListenerInfo
-
- getFilter() - Method in interface com.hazelcast.spi.EventRegistration
-
- getFilter() - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
-
- getFilters() - Method in class com.hazelcast.config.WanReplicationRef
-
Return the list of class names implementing the CacheWanEventFilter or MapWanEventFilter for filtering WAN replication
events.
- getFirst() - Method in class com.hazelcast.mapreduce.aggregation.impl.AvgTuple
-
- getFirst(Iterable<T>, T) - Static method in class com.hazelcast.util.IterableUtil
-
- getFlag() - Method in class com.hazelcast.internal.ascii.memcache.MemcacheEntry
-
- getFlag() - Method in class com.hazelcast.internal.ascii.memcache.SetCommand
-
- getFlags() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
-
Returns the flags field value.
- getFlags() - Method in class com.hazelcast.nio.Packet
-
- getFlags() - Method in class com.hazelcast.query.impl.predicates.ILikePredicate
-
- getFlags() - Method in class com.hazelcast.query.impl.predicates.LikePredicate
-
- getFlakeIdGenerator(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getFlakeIdGenerator(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-
- getFlakeIdGenerator(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates a cluster-wide unique ID generator.
- getFlakeIdGenerator(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getFlakeIdGenerator(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getFlakeIdGeneratorConfig(String) - Method in class com.hazelcast.client.config.ClientConfig
-
Returns the
ClientFlakeIdGeneratorConfig
for the given name, creating
one if necessary and adding it to the collection of known configurations.
- getFlakeIdGeneratorConfig(String) - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getFlakeIdGeneratorConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the
FlakeIdGeneratorConfig
for the given name, creating
one if necessary and adding it to the collection of known configurations.
- getFlakeIdGeneratorConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getFlakeIdGeneratorConfigMap() - Method in class com.hazelcast.client.config.ClientConfig
-
- getFlakeIdGeneratorConfigs() - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getFlakeIdGeneratorConfigs() - Method in class com.hazelcast.config.Config
-
- getFlakeIdGeneratorConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
-
- getFlakeIdGeneratorConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
-
Returns all registered FlakeIdGenerator configurations.
- getFlakeIdGeneratorConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getFloat(Object, long) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Returns the float value at the supplied offset from the supplied object's base address.
- getFloat(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- getFloat(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- getFloat(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- getFloat(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- getFloat(long) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
-
Reads the float value from given address.
- getFloat(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
- getFloat(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
-
Returns a field in a Json object as a float.
- getFloat(JsonObject, String, float) - Static method in class com.hazelcast.util.JsonUtil
-
Returns a field in a Json object as a float.
- getFloatAttribute(String) - Method in class com.hazelcast.client.impl.MemberImpl
-
- getFloatAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- getFloatAttribute(String) - Method in interface com.hazelcast.core.Member
-
Returns the value of the specified key for this member or
null if value is undefined.
- getFloatAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
-
- getFloatVolatile(Object, long) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
-
Reads the float value as volatile from given object by its offset.
- getFloatVolatile(long) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
-
Reads the float value as volatile from given object by its offset.
- getFloatVolatile(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- getFloatVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- getFloatVolatile(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- getFloatVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- getFlushSequences() - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
-
- getFormatId() - Method in class com.hazelcast.transaction.impl.xa.SerializableXID
-
- getForUpdate(Object) - Method in class com.hazelcast.client.proxy.txn.ClientTxnMapProxy
-
- getForUpdate(Object) - Method in interface com.hazelcast.core.TransactionalMap
-
Locks the key and then gets and returns the value to which the specified key is mapped.
- getForUpdate(Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-
- getFrameLength() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
-
Returns the frame length field.
- getFreeHeap() - Method in class com.hazelcast.memory.DefaultMemoryStats
-
- getFreeHeap() - Method in interface com.hazelcast.memory.MemoryStats
-
Returns the amount of free memory in the JVM in bytes.
- getFreeHeap() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- getFreeMemory() - Method in class com.hazelcast.map.impl.eviction.EvictionChecker
-
- getFreeMemory() - Method in interface com.hazelcast.util.MemoryInfoAccessor
-
Returns the amount of free memory in the Java virtual machine in bytes.
- getFreeMemory() - Method in class com.hazelcast.util.RuntimeMemoryInfoAccessor
-
- getFreeNative() - Method in class com.hazelcast.memory.DefaultMemoryStats
-
- getFreeNative() - Method in interface com.hazelcast.memory.MemoryStats
-
Returns the amount of free native memory in current HazelcastInstance in bytes.
- getFreeNative() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- getFreePhysical() - Method in class com.hazelcast.memory.DefaultMemoryStats
-
- getFreePhysical() - Method in interface com.hazelcast.memory.MemoryStats
-
Returns free physical memory available in OS.
- getFreePhysical() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- getFromCache(String) - Static method in class com.hazelcast.internal.usercodedeployment.impl.ThreadLocalClassCache
-
- getFuture() - Method in class com.hazelcast.client.util.ClientDelegatingFuture
-
- getFuture() - Method in class com.hazelcast.spi.impl.operationservice.impl.batching.PartitionAwareCallableBatchingRunnable
-
- getFuture() - Method in class com.hazelcast.util.executor.DelegatingFuture
-
- getGCStats() - Method in class com.hazelcast.memory.DefaultMemoryStats
-
- getGCStats() - Static method in class com.hazelcast.memory.GCStatsSupport
-
- getGCStats() - Method in interface com.hazelcast.memory.MemoryStats
-
Returns the garbage collector statistics for the JVM
- getGCStats() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- getGCStats() - Method in interface com.hazelcast.monitor.LocalMemoryStats
-
- getGenericOperationRunners() - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
-
- getGenericOperationRunners() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
-
Gets all the generic operation handlers.
- getGenericThreadCount() - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
-
- getGenericThreadCount() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
-
Returns the number of generic threads.
- getGenericThreadCount() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-
- getGenericThreadCount() - Method in interface com.hazelcast.spi.impl.operationservice.InternalOperationService
-
Returns the number of generic threads.
- getGetHits() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-
- getGetMisses() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-
- getGetOperationCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getGetOperationCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getGetOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the number of get operations
- getGlobalMemoryAccessor(GlobalMemoryAccessorType) - Static method in class com.hazelcast.internal.memory.GlobalMemoryAccessorRegistry
-
- getGlobalSerializerConfig() - Method in class com.hazelcast.config.SerializationConfig
-
- getGlobalTaskScheduler() - Method in interface com.hazelcast.spi.ExecutionService
-
- getGlobalTaskScheduler() - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
-
- getGlobalTransactionId() - Method in class com.hazelcast.transaction.impl.xa.SerializableXID
-
- getGroupConfig() - Method in class com.hazelcast.client.config.ClientConfig
-
- getGroupConfig() - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getGroupConfig() - Method in class com.hazelcast.config.Config
-
Returns the configuration for hazelcast groups.
- getGroupConfig() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getGroupName() - Method in interface com.hazelcast.client.spi.ClientTransactionManagerService
-
- getGroupName() - Method in class com.hazelcast.client.spi.impl.ClientTransactionManagerServiceImpl
-
- getGroupName() - Method in class com.hazelcast.config.WanPublisherConfig
-
Return the group name of this publisher.
- getGroupName() - Method in class com.hazelcast.internal.jmx.InstanceMBean
-
- getGroupName() - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-
- getGroupName() - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
-
- getGroupType() - Method in class com.hazelcast.config.PartitionGroupConfig
-
Returns the MemberGroupType configured.
- getHandler() - Method in class com.hazelcast.client.proxy.ClientScheduledFutureProxy
-
- getHandler() - Method in class com.hazelcast.client.spi.impl.listener.ClientRegistrationKey
-
- getHandler() - Method in class com.hazelcast.internal.networking.InitResult
-
- getHandler() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledFutureProxy
-
- getHandler() - Method in interface com.hazelcast.scheduledexecutor.IScheduledFuture
-
Returns the scheduled future resource handler.
- getHandlers() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.RepairingTask
-
- getHazelcastClientByName(String) - Static method in class com.hazelcast.client.HazelcastClient
-
Returns an existing HazelcastClient with instanceName.
- getHazelcastClientByName(String) - Static method in class com.hazelcast.client.HazelcastClientManager
-
- getHazelcastInstance() - Method in interface com.hazelcast.cache.HazelcastCacheManager
-
- getHazelcastInstance() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- getHazelcastInstance() - Method in class com.hazelcast.client.spi.ClientContext
-
- getHazelcastInstance() - Method in class com.hazelcast.client.spi.ProxyManager
-
- getHazelcastInstance(String) - Static method in class com.hazelcast.instance.HazelcastInstanceFactory
-
- getHazelcastInstance() - Method in class com.hazelcast.internal.jmx.InstanceMBean
-
- getHazelcastInstance() - Method in class com.hazelcast.internal.management.ManagementCenterService
-
- getHazelcastInstance() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getHazelcastInstance() - Method in interface com.hazelcast.spi.NodeEngine
-
Returns the HazelcastInstance that this
NodeEngine
belongs to.
- getHazelcastInstance() - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
-
- getHazelcastInstanceByName(String) - Static method in class com.hazelcast.core.Hazelcast
-
Returns an existing HazelcastInstance with instanceName.
- getHazelcastInstanceByName(String) - Method in interface com.hazelcast.osgi.HazelcastOSGiService
-
- getHazelcastName() - Method in interface com.hazelcast.nio.IOService
-
- getHazelcastName() - Method in class com.hazelcast.nio.NodeIOService
-
- getHeadSeq() - Method in exception com.hazelcast.ringbuffer.StaleSequenceException
-
Returns the last known head sequence.
- getHeadSequence() - Method in interface com.hazelcast.map.impl.querycache.accumulator.CyclicBuffer
-
Returns the sequence number of the element in the head index of this buffer if there exists any,
otherwise -1L
will be returned.
- getHeadSequence() - Method in class com.hazelcast.map.impl.querycache.accumulator.DefaultCyclicBuffer
-
- getHeadSequence() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
-
Returns the sequence of the head.
- getHeapCost() - Method in class com.hazelcast.internal.serialization.impl.HeapData
-
- getHeapCost() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getHeapCost() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getHeapCost() - Method in interface com.hazelcast.monitor.LocalMapStats
-
- getHeapCost() - Method in interface com.hazelcast.nio.serialization.Data
-
Returns approximate heap cost of this Data object in bytes.
- getHeartbeatBroadcastPeriodMillis() - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationMonitor
-
- getHeartbeatIntervalMillis() - Method in class com.hazelcast.internal.cluster.impl.ClusterHeartbeatManager
-
- getHeartbeatIntervalMillis() - Method in class com.hazelcast.quorum.impl.ProbabilisticQuorumFunction
-
- getHeartbeatPerMember() - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationMonitor
-
- getHeartbeatToleranceMillis() - Method in class com.hazelcast.quorum.impl.RecentlyActiveQuorumFunction
-
- getHits() - Method in interface com.hazelcast.core.EntryView
-
Returns number of hits of the entry.
- getHits() - Method in class com.hazelcast.map.impl.record.AbstractRecord
-
- getHits() - Method in interface com.hazelcast.map.impl.record.Record
-
- getHits() - Method in class com.hazelcast.map.impl.record.RecordInfo
-
- getHits() - Method in class com.hazelcast.map.impl.recordstore.LazyEntryViewFromRecord
-
- getHits() - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- getHits() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getHits() - Method in class com.hazelcast.monitor.impl.LocalRecordStoreStatsImpl
-
- getHits() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getHits() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-
- getHits() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the number of hits (reads) of locally owned entries, including those
which are no longer in the map (for example, may have been evicted).
- getHits() - Method in interface com.hazelcast.monitor.LocalRecordStoreStats
-
Returns the number of hits (reads) of the locally owned entries of this partition.
- getHits() - Method in interface com.hazelcast.monitor.NearCacheStats
-
Returns the number of hits (reads) of Near Cache entries owned by this member.
- getHits() - Method in class com.hazelcast.multimap.impl.MultiMapMergeContainer
-
- getHits() - Method in class com.hazelcast.multimap.impl.MultiMapValue
-
- getHits() - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
-
- getHits() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-
- getHits() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- getHits() - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
-
- getHits() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
-
- getHits() - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
-
- getHits() - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
-
- getHits() - Method in interface com.hazelcast.spi.merge.MergingHits
-
Returns the access hits of the merge data.
- getHost() - Method in class com.hazelcast.nio.Address
-
- getHost() - Method in class com.hazelcast.spi.discovery.multicast.impl.MulticastMemberInfo
-
- getHostHeader() - Method in class com.hazelcast.config.AwsConfig
-
Gets the host header; the address where the EC2 API can be found.
- getHotRestartConfig() - Method in class com.hazelcast.config.AbstractCacheConfig
-
Gets the HotRestartConfig
for this CacheConfiguration
- getHotRestartConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the HotRestartConfig
for this CacheSimpleConfig
- getHotRestartConfig() - Method in class com.hazelcast.config.MapConfig
-
Gets the HotRestartConfig
for this MapConfig
- getHotRestartPersistenceConfig() - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
-
- getHotRestartPersistenceConfig() - Method in class com.hazelcast.config.Config
-
Returns the Hot Restart configuration for this hazelcast instance
- getHotRestartPersistenceConfig() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
-
- getHotRestartService() - Method in class com.hazelcast.client.proxy.ClientClusterProxy
-
- getHotRestartService() - Method in interface com.hazelcast.core.Cluster
-
Returns the Hot Restart service for interacting with Hot Restart.
- getHotRestartService() - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- getHotRestartService() - Method in interface com.hazelcast.instance.NodeExtension
-
Returns the public hot restart service
- getHotRestartService() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
-
- getHotRestartState() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- getHotRestartState() - Method in interface com.hazelcast.monitor.MemberState
-
- getHotRestartStatus() - Method in class com.hazelcast.internal.management.dto.ClusterHotRestartStatusDTO
-
- getIamRole() - Method in class com.hazelcast.config.AwsConfig
-
Gets the iamRole name
- getIcmpFailureDetector() - Method in class com.hazelcast.internal.cluster.impl.ClusterHeartbeatManager
-
- getIcmpFailureDetectorConfig() - Method in class com.hazelcast.config.NetworkConfig
-
- getId() - Method in class com.hazelcast.aggregation.impl.BigDecimalAverageAggregator
-
- getId() - Method in class com.hazelcast.aggregation.impl.BigDecimalSumAggregator
-
- getId() - Method in class com.hazelcast.aggregation.impl.BigIntegerAverageAggregator
-
- getId() - Method in class com.hazelcast.aggregation.impl.BigIntegerSumAggregator
-
- getId() - Method in class com.hazelcast.aggregation.impl.CountAggregator
-
- getId() - Method in class com.hazelcast.aggregation.impl.DistinctValuesAggregator
-
- getId() - Method in class com.hazelcast.aggregation.impl.DoubleAverageAggregator
-
- getId() - Method in class com.hazelcast.aggregation.impl.DoubleSumAggregator
-
- getId() - Method in class com.hazelcast.aggregation.impl.FixedSumAggregator
-
- getId() - Method in class com.hazelcast.aggregation.impl.FloatingPointSumAggregator
-
- getId() - Method in class com.hazelcast.aggregation.impl.IntegerAverageAggregator
-
- getId() - Method in class com.hazelcast.aggregation.impl.IntegerSumAggregator
-
- getId() - Method in class com.hazelcast.aggregation.impl.LongAverageAggregator
-
- getId() - Method in class com.hazelcast.aggregation.impl.LongSumAggregator
-
- getId() - Method in class com.hazelcast.aggregation.impl.MaxAggregator
-
- getId() - Method in class com.hazelcast.aggregation.impl.MaxByAggregator
-
- getId() - Method in class com.hazelcast.aggregation.impl.MinAggregator
-
- getId() - Method in class com.hazelcast.aggregation.impl.MinByAggregator
-
- getId() - Method in class com.hazelcast.aggregation.impl.NumberAverageAggregator
-
- getId() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-
- getId() - Method in class com.hazelcast.cache.impl.CacheClearResponse
-
- getId() - Method in class com.hazelcast.cache.impl.CacheEntryIterationResult
-
- getId() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-
- getId() - Method in class com.hazelcast.cache.impl.CacheEventListenerAdaptor
-
- getId() - Method in class com.hazelcast.cache.impl.CacheEventSet
-
- getId() - Method in class com.hazelcast.cache.impl.CacheKeyIterationResult
-
- getId() - Method in class com.hazelcast.cache.impl.CachePartitionEventData
-
- getId() - Method in class com.hazelcast.cache.impl.event.CachePartitionLostEventFilter
-
- getId() - Method in class com.hazelcast.cache.impl.journal.CacheEventJournalReadOperation
-
- getId() - Method in class com.hazelcast.cache.impl.journal.CacheEventJournalReadResultSetImpl
-
- getId() - Method in class com.hazelcast.cache.impl.journal.CacheEventJournalSubscribeOperation
-
- getId() - Method in class com.hazelcast.cache.impl.journal.DeserializingEventJournalCacheEvent
-
- getId() - Method in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
-
- getId() - Method in class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
-
- getId() - Method in class com.hazelcast.cache.impl.operation.AddCacheConfigOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheBackupEntryProcessorOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheContainsKeyOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
-
Deprecated.
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheDestroyOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheEntryIteratorOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperationFactory
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheGetConfigOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheGetInvalidationMetaDataOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheGetInvalidationMetaDataOperation.MetaDataResponse
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheGetOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheKeyIteratorOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheLegacyMergeOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheListenerRegistrationOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperationFactory
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheMergeOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheMergeOperationFactory
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheNearCacheStateHolder
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CachePutAllBackupOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CachePutAllOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CachePutBackupOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CachePutOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperationFactory
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheReplaceOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheSizeOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
-
- getId() - Method in class com.hazelcast.cache.impl.operation.OnJoinCacheOperation
-
- getId() - Method in class com.hazelcast.cache.impl.PreJoinCacheConfig
-
- getId() - Method in class com.hazelcast.cache.impl.record.CacheDataRecord
-
- getId() - Method in class com.hazelcast.cache.impl.record.CacheObjectRecord
-
- getId() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorContainer
-
- getId() - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.DenseHyperLogLogEncoder
-
- getId() - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.HyperLogLogImpl
-
- getId() - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.SparseHyperLogLogEncoder
-
- getId() - Method in class com.hazelcast.cardinality.impl.operations.AggregateBackupOperation
-
- getId() - Method in class com.hazelcast.cardinality.impl.operations.AggregateOperation
-
- getId() - Method in class com.hazelcast.cardinality.impl.operations.EstimateOperation
-
- getId() - Method in class com.hazelcast.cardinality.impl.operations.MergeBackupOperation
-
- getId() - Method in class com.hazelcast.cardinality.impl.operations.MergeOperation
-
- getId() - Method in class com.hazelcast.cardinality.impl.operations.ReplicationOperation
-
- getId() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getId() - Method in class com.hazelcast.client.impl.operations.ClientDisconnectionOperation
-
- getId() - Method in class com.hazelcast.client.impl.operations.ClientReAuthOperation
-
- getId() - Method in class com.hazelcast.client.impl.operations.GetConnectedClientsOperation
-
- getId() - Method in class com.hazelcast.client.impl.operations.OnJoinClientOperation
-
- getId() - Method in class com.hazelcast.client.impl.operations.OperationFactoryWrapper
-
- getId() - Method in enum com.hazelcast.client.impl.protocol.AuthenticationStatus
-
- getId() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsOperation
-
- getId() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsOperationFactory
-
- getId() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsOperation
-
- getId() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsOperationFactory
-
- getId() - Method in class com.hazelcast.client.impl.querycache.subscriber.ListenerInfo
-
- getId() - Method in class com.hazelcast.client.spi.ClientProxy
-
Deprecated.
- getId() - Method in class com.hazelcast.cluster.impl.VectorClock
-
- getId() - Method in enum com.hazelcast.cluster.MemberAttributeOperationType
-
Gets the ID of the MemberAttributeOperationType.
- getId() - Method in class com.hazelcast.collection.impl.collection.CollectionEvent
-
- getId() - Method in class com.hazelcast.collection.impl.collection.CollectionEventFilter
-
- getId() - Method in class com.hazelcast.collection.impl.collection.CollectionItem
-
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllOperation
-
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddOperation
-
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionClearBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionClearOperation
-
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionCompareAndRemoveOperation
-
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionContainsOperation
-
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionGetAllOperation
-
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionIsEmptyOperation
-
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionMergeBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionMergeOperation
-
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionRemoveBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionRemoveOperation
-
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionSizeOperation
-
- getId() - Method in class com.hazelcast.collection.impl.collection.TxCollectionItem
-
- getId() - Method in class com.hazelcast.collection.impl.list.ListContainer
-
- getId() - Method in class com.hazelcast.collection.impl.list.operations.ListAddAllOperation
-
- getId() - Method in class com.hazelcast.collection.impl.list.operations.ListAddOperation
-
- getId() - Method in class com.hazelcast.collection.impl.list.operations.ListGetOperation
-
- getId() - Method in class com.hazelcast.collection.impl.list.operations.ListIndexOfOperation
-
- getId() - Method in class com.hazelcast.collection.impl.list.operations.ListRemoveOperation
-
- getId() - Method in class com.hazelcast.collection.impl.list.operations.ListReplicationOperation
-
- getId() - Method in class com.hazelcast.collection.impl.list.operations.ListSetBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.list.operations.ListSetOperation
-
- getId() - Method in class com.hazelcast.collection.impl.list.operations.ListSubOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.AddAllBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.AddAllOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.CheckAndEvictOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.ClearBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.ClearOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.ContainsOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.DrainBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.DrainOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.IsEmptyOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.IteratorOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.OfferBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.OfferOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.PeekOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.PollBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.PollOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.QueueMergeBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.QueueMergeOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.QueueReplicationOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.RemainingCapacityOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.RemoveBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.RemoveOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.SizeOperation
-
- getId() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-
- getId() - Method in class com.hazelcast.collection.impl.queue.QueueEvent
-
- getId() - Method in class com.hazelcast.collection.impl.queue.QueueEventFilter
-
- getId() - Method in class com.hazelcast.collection.impl.queue.QueueItem
-
- getId() - Method in class com.hazelcast.collection.impl.set.operations.SetReplicationOperation
-
- getId() - Method in class com.hazelcast.collection.impl.set.SetContainer
-
- getId() - Method in class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
-
- getId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveAddOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveRemoveOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTransactionRollbackOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.QueueTransactionRollbackOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnCommitBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnCommitOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPeekOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPollBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPollOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPrepareBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPrepareOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackBackupOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackOperation
-
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.QueueTransactionLogRecord
-
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.TxQueueItem
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AddBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AlterAndGetOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AlterOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.ApplyOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAlterOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.MergeBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.MergeOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.SetBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.SetOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.AlterAndGetOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.AlterOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.ContainsOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndAlterOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.IsNullOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.MergeBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.MergeOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetAndGetOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetOperation
-
- getId() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
-
- getId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
-
- getId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
-
- getId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
-
- getId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.GetCountOperation
-
- getId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.AwaitBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.GetLockCountOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.GetRemainingLeaseTimeOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.IsLockedOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.LocalLockCleanupOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.LockBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.LockOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.LockReplicationOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.SignalBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.SignalOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.UnlockBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.UnlockIfLeaseExpiredOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.AvailableOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.IncreaseBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.IncreaseOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.InitBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.InitOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDetachMemberBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDetachMemberOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreReplicationOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
-
- getId() - Method in class com.hazelcast.config.AtomicLongConfig
-
- getId() - Method in class com.hazelcast.config.AtomicReferenceConfig
-
- getId() - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
-
- getId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
-
- getId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
-
- getId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
-
- getId() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- getId() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- getId() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
- getId() - Method in class com.hazelcast.config.CountDownLatchConfig
-
- getId() - Method in class com.hazelcast.config.DurableExecutorConfig
-
- getId() - Method in class com.hazelcast.config.EntryListenerConfig
-
- getId() - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
-
- getId() - Method in class com.hazelcast.config.EventJournalConfig
-
- getId() - Method in class com.hazelcast.config.ExecutorConfig
-
- getId() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
- getId() - Method in class com.hazelcast.config.HotRestartConfig
-
- getId() - Method in class com.hazelcast.config.ItemListenerConfig
-
- getId() - Method in class com.hazelcast.config.ListConfig
-
- getId() - Method in class com.hazelcast.config.ListenerConfig
-
- getId() - Method in class com.hazelcast.config.LockConfig
-
- getId() - Method in class com.hazelcast.config.MapAttributeConfig
-
- getId() - Method in class com.hazelcast.config.MapConfig
-
- getId() - Method in class com.hazelcast.config.MapIndexConfig
-
- getId() - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
-
- getId() - Method in class com.hazelcast.config.MapStoreConfig
-
- getId() - Method in class com.hazelcast.config.MergePolicyConfig
-
- getId() - Method in class com.hazelcast.config.MultiMapConfig
-
- getId() - Method in class com.hazelcast.config.NearCacheConfig
-
- getId() - Method in class com.hazelcast.config.NearCacheConfigReadOnly
-
Deprecated.
- getId() - Method in class com.hazelcast.config.NearCachePreloaderConfig
-
- getId() - Method in class com.hazelcast.config.PartitioningStrategyConfig
-
- getId() - Method in class com.hazelcast.config.PNCounterConfig
-
- getId() - Method in class com.hazelcast.config.PredicateConfig
-
- getId() - Method in class com.hazelcast.config.QueryCacheConfig
-
- getId() - Method in class com.hazelcast.config.QueueConfig
-
- getId() - Method in class com.hazelcast.config.QueueStoreConfig
-
- getId() - Method in class com.hazelcast.config.QuorumConfig
-
- getId() - Method in class com.hazelcast.config.QuorumListenerConfig
-
- getId() - Method in class com.hazelcast.config.ReliableTopicConfig
-
- getId() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- getId() - Method in class com.hazelcast.config.RingbufferConfig
-
- getId() - Method in class com.hazelcast.config.RingbufferStoreConfig
-
- getId() - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
- getId() - Method in class com.hazelcast.config.SemaphoreConfig
-
- getId() - Method in class com.hazelcast.config.SetConfig
-
- getId() - Method in class com.hazelcast.config.TopicConfig
-
- getId() - Method in enum com.hazelcast.config.WanAcknowledgeType
-
- getId() - Method in class com.hazelcast.config.WanConsumerConfig
-
- getId() - Method in class com.hazelcast.config.WanPublisherConfig
-
- getId() - Method in enum com.hazelcast.config.WANQueueFullBehavior
-
- getId() - Method in class com.hazelcast.config.WanReplicationConfig
-
- getId() - Method in class com.hazelcast.crdt.pncounter.operations.AddOperation
-
- getId() - Method in class com.hazelcast.crdt.pncounter.operations.CRDTTimestampedLong
-
- getId() - Method in class com.hazelcast.crdt.pncounter.operations.GetOperation
-
- getId() - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
-
- getId() - Method in class com.hazelcast.crdt.pncounter.PNCounterReplicationOperation
-
- getId() - Method in class com.hazelcast.durableexecutor.impl.operations.DisposeResultBackupOperation
-
- getId() - Method in class com.hazelcast.durableexecutor.impl.operations.DisposeResultOperation
-
- getId() - Method in class com.hazelcast.durableexecutor.impl.operations.PutResultBackupOperation
-
- getId() - Method in class com.hazelcast.durableexecutor.impl.operations.PutResultOperation
-
- getId() - Method in class com.hazelcast.durableexecutor.impl.operations.ReplicationOperation
-
- getId() - Method in class com.hazelcast.durableexecutor.impl.operations.RetrieveAndDisposeResultOperation
-
- getId() - Method in class com.hazelcast.durableexecutor.impl.operations.RetrieveResultOperation
-
- getId() - Method in class com.hazelcast.durableexecutor.impl.operations.ShutdownOperation
-
- getId() - Method in class com.hazelcast.durableexecutor.impl.operations.TaskBackupOperation
-
- getId() - Method in class com.hazelcast.durableexecutor.impl.operations.TaskOperation
-
- getId() - Method in class com.hazelcast.executor.impl.operations.CallableTaskOperation
-
- getId() - Method in class com.hazelcast.executor.impl.operations.CancellationOperation
-
- getId() - Method in class com.hazelcast.executor.impl.operations.MemberCallableTaskOperation
-
- getId() - Method in class com.hazelcast.executor.impl.operations.ShutdownOperation
-
- getId() - Method in class com.hazelcast.executor.impl.RunnableAdapter
-
- getId() - Method in class com.hazelcast.instance.MemberImpl
-
- getId() - Method in class com.hazelcast.internal.ascii.memcache.MemcacheEntry
-
- getId() - Method in class com.hazelcast.internal.ascii.rest.RestValue
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.BindMessage
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.ClusterStateChange
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.ClusterStateTransactionLogRecord
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.ConfigCheck
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.JoinMessage
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.JoinRequest
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.MembersView
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.MembersViewMetadata
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.AuthenticationFailureOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.AuthorizationOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.BeforeJoinCheckFailureOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.CommitClusterStateOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.ConfigMismatchOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.ExplicitSuspicionOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.FetchMembersViewOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.FinalizeJoinOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.GroupMismatchOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.HeartbeatComplaintOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.HeartbeatOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.JoinMastershipClaimOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.JoinRequestOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.LockClusterStateOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.MasterConfirmationOp
-
Deprecated.
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.MasterResponseOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.MemberAttributeChangedOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.MembersUpdateOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.MergeClustersOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.OnJoinOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.PromoteLiteMemberOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.RollbackClusterStateOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.ShutdownNodeOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.SplitBrainMergeValidationOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.TriggerExplicitSuspicionOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.TriggerMemberListPublishOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.operations.WhoisMasterOp
-
- getId() - Method in class com.hazelcast.internal.cluster.impl.SplitBrainJoinMessage
-
- getId() - Method in class com.hazelcast.internal.cluster.MemberInfo
-
- getId() - Method in class com.hazelcast.internal.dynamicconfig.AddDynamicConfigOperation
-
- getId() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigPreJoinOperation
-
- getId() - Method in class com.hazelcast.internal.journal.EventJournalInitialSubscriberState
-
- getId() - Method in class com.hazelcast.internal.management.dto.MapConfigDTO
-
- getId() - Method in class com.hazelcast.internal.management.dto.PermissionConfigDTO
-
- getId() - Method in class com.hazelcast.internal.management.operation.AddWanConfigOperation
-
- getId() - Method in class com.hazelcast.internal.management.operation.ScriptExecutorOperation
-
- getId() - Method in class com.hazelcast.internal.management.operation.UpdateManagementCenterUrlOperation
-
- getId() - Method in class com.hazelcast.internal.management.operation.UpdateMapConfigOperation
-
- getId() - Method in class com.hazelcast.internal.management.operation.UpdatePermissionConfigOperation
-
- getId() - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest.CacheBrowserEntryView
-
- getId() - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest.GetCacheEntryViewEntryProcessor
-
- getId() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.BatchNearCacheInvalidation
-
- getId() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.SingleNearCacheInvalidation
-
- getId() - Method in class com.hazelcast.internal.partition.MigrationInfo
-
- getId() - Method in class com.hazelcast.internal.partition.NonFragmentedServiceNamespace
-
- getId() - Method in class com.hazelcast.internal.partition.operation.AssignPartitions
-
- getId() - Method in class com.hazelcast.internal.partition.operation.FetchPartitionStateOperation
-
- getId() - Method in class com.hazelcast.internal.partition.operation.FinalizeMigrationOperation
-
- getId() - Method in class com.hazelcast.internal.partition.operation.HasOngoingMigration
-
- getId() - Method in class com.hazelcast.internal.partition.operation.MigrationCommitOperation
-
- getId() - Method in class com.hazelcast.internal.partition.operation.MigrationOperation
-
- getId() - Method in class com.hazelcast.internal.partition.operation.MigrationRequestOperation
-
- getId() - Method in class com.hazelcast.internal.partition.operation.PartitionBackupReplicaAntiEntropyOperation
-
- getId() - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncRequest
-
- getId() - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncResponse
-
- getId() - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncRetryResponse
-
- getId() - Method in class com.hazelcast.internal.partition.operation.PartitionStateOperation
-
- getId() - Method in class com.hazelcast.internal.partition.operation.PromotionCommitOperation
-
- getId() - Method in class com.hazelcast.internal.partition.operation.SafeStateCheckOperation
-
- getId() - Method in class com.hazelcast.internal.partition.operation.ShutdownRequestOperation
-
- getId() - Method in class com.hazelcast.internal.partition.operation.ShutdownResponseOperation
-
- getId() - Method in class com.hazelcast.internal.partition.PartitionRuntimeState
-
- getId() - Method in class com.hazelcast.internal.partition.