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

A

AbstractBasicConfig<T extends AbstractBasicConfig> - Class in com.hazelcast.config
Provides a basic configuration for a split-brain aware data structure.
AbstractBasicConfig() - Constructor for class com.hazelcast.config.AbstractBasicConfig
 
AbstractBasicConfig(String) - Constructor for class com.hazelcast.config.AbstractBasicConfig
 
AbstractBasicConfig(AbstractBasicConfig) - Constructor for class com.hazelcast.config.AbstractBasicConfig
 
AbstractCacheConfig<K,V> - Class in com.hazelcast.config
Base class for CacheConfig
AbstractCacheConfig() - Constructor for class com.hazelcast.config.AbstractCacheConfig
 
AbstractCacheConfig(CompleteConfiguration<K, V>) - Constructor for class com.hazelcast.config.AbstractCacheConfig
 
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
 
AbstractCRDTReplicationOperation<T extends IdentifiedDataSerializable> - Class in com.hazelcast.crdt
Base class for CRDT replication operations.
AbstractCRDTReplicationOperation() - Constructor for class com.hazelcast.crdt.AbstractCRDTReplicationOperation
 
AbstractCRDTReplicationOperation(Map<String, T>) - Constructor for class com.hazelcast.crdt.AbstractCRDTReplicationOperation
Constructs the replication operation.
AbstractCredentials - Class in com.hazelcast.security
Abstract implementation of Credentials
AbstractCredentials() - Constructor for class com.hazelcast.security.AbstractCredentials
 
AbstractCredentials(String) - Constructor for class com.hazelcast.security.AbstractCredentials
 
AbstractDiscoveryStrategy - Class in com.hazelcast.spi.discovery
An common abstract superclass for DiscoveryStrategy implementations, offering convenient access to configuration properties (which may be overridden on the system's environment or JVM properties), as well as a ILogger instance.
AbstractDiscoveryStrategy(ILogger, Map<String, Comparable>) - Constructor for class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
 
AbstractDistributedObject<S extends RemoteService> - Class in com.hazelcast.spi
Abstract DistributedObject implementation.
AbstractDistributedObject(NodeEngine, S) - Constructor for class com.hazelcast.spi.AbstractDistributedObject
 
AbstractEntryProcessor<K,V> - Class in com.hazelcast.map
An abstract EntryProcessor that already has implemented the AbstractEntryProcessor.getBackupProcessor().
AbstractEntryProcessor() - Constructor for class com.hazelcast.map.AbstractEntryProcessor
Creates an AbstractEntryProcessor that applies the EntryProcessor.process(java.util.Map.Entry) to primary and backups.
AbstractEntryProcessor(boolean) - Constructor for class com.hazelcast.map.AbstractEntryProcessor
Creates an AbstractEntryProcessor.
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
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.
AbstractLocalOperation - Class in com.hazelcast.spi
Abstract class for local operations, which should not be serializable.
AbstractLocalOperation() - Constructor for class com.hazelcast.spi.AbstractLocalOperation
 
AbstractLogger - Class in com.hazelcast.logging
Abstract ILogger implementation that provides implementations for convenience methods like finest, info, warning and severe.
AbstractLogger() - Constructor for class com.hazelcast.logging.AbstractLogger
 
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
 
AbstractWaitNotifyKey - Class in com.hazelcast.spi
Abstract implementation of the WaitNotifyKey.
AbstractWaitNotifyKey(String, String) - Constructor for class com.hazelcast.spi.AbstractWaitNotifyKey
 
AbstractXmlConfigHelper - Class in com.hazelcast.config
Contains Hazelcast XML Configuration helper methods and variables.
AbstractXmlConfigHelper() - Constructor for class com.hazelcast.config.AbstractXmlConfigHelper
 
accept(Visitor, Indexes) - Method in class com.hazelcast.query.SqlPredicate
 
accept(Visitor, Indexes) - Method in interface com.hazelcast.query.VisitablePredicate
Accept visitor.
accumulate(I) - Method in class com.hazelcast.aggregation.Aggregator
Accumulates the given entries.
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.
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
 
add(Object) - Method in interface com.hazelcast.cardinality.CardinalityEstimator
Add a new object in the estimation set.
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(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(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_DYNAMIC_CONFIG_OP - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
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(Addresses) - Method in class com.hazelcast.client.connection.Addresses
 
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.
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
 
addAndGetAsync(long) - Method in interface com.hazelcast.core.IAtomicLong
Atomically adds the given value to the current value.
addAsync(Object) - Method in interface com.hazelcast.cardinality.CardinalityEstimator
Add a new object in the estimation set.
addAsync(E, OverflowPolicy) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Asynchronously writes an item with a configurable OverflowPolicy.
addAtomicLongConfig(AtomicLongConfig) - Method in class com.hazelcast.config.Config
Adds the AtomicLong configuration.
addAtomicReferenceConfig(AtomicReferenceConfig) - Method in class com.hazelcast.config.Config
Adds the AtomicReference configuration.
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(CacheSimpleConfig) - Method in class com.hazelcast.config.Config
Adds the cache configuration.
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.
 
addCardinalityEstimatorConfig(CardinalityEstimatorConfig) - Method in class com.hazelcast.config.Config
Adds the cardinality estimator configuration.
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
 
addClasses(String...) - Method in class com.hazelcast.config.ClassFilter
 
addClientListener(ClientListener) - Method in interface com.hazelcast.core.ClientService
Adds a ClientListener.
addClientLoginModuleConfig(LoginModuleConfig) - Method in class com.hazelcast.config.SecurityConfig
 
addClientPermissionConfig(PermissionConfig) - Method in class com.hazelcast.config.SecurityConfig
 
addConnectionListener(ConnectionListener) - Method in interface com.hazelcast.nio.ConnectionListenable
Registers a ConnectionListener.
addCountDownLatchConfig(CountDownLatchConfig) - Method in class com.hazelcast.config.Config
Adds the CountDownLatch configuration.
addDataSerializableFactory(int, DataSerializableFactory) - Method in class com.hazelcast.config.SerializationConfig
 
addDataSerializableFactoryClass(int, String) - Method in class com.hazelcast.config.SerializationConfig
 
addDataSerializableFactoryClass(int, Class<? extends DataSerializableFactory>) - Method in class com.hazelcast.config.SerializationConfig
 
addDiscoveryStrategyConfig(DiscoveryStrategyConfig) - Method in class com.hazelcast.config.DiscoveryConfig
Adds an enabled DiscoveryStrategy configuration.
addDiscoveryStrategyConfig(DiscoveryStrategyConfig) - Method in class com.hazelcast.config.DiscoveryConfigReadOnly
Deprecated.
 
addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.client.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.
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.config.Config
Adds the durable executor configuration.
addEndpoint(String) - Method in class com.hazelcast.config.PermissionConfig
 
addEntryListener(MapListener, boolean) - Method in interface com.hazelcast.core.IMap
Adds a MapListener for this map.
addEntryListener(EntryListener, boolean) - Method in interface com.hazelcast.core.IMap
Deprecated.
addEntryListener(MapListener, K, boolean) - Method in interface com.hazelcast.core.IMap
Adds a MapListener for this map.
addEntryListener(EntryListener, K, boolean) - Method in interface com.hazelcast.core.IMap
addEntryListener(MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
Adds a MapListener for this map.
addEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
addEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
Adds a MapListener for this map.
addEntryListener(EntryListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
addEntryListener(EntryListener<K, V>, boolean) - Method in interface com.hazelcast.core.MultiMap
Adds an entry listener for this multimap.
addEntryListener(EntryListener<K, V>, K, boolean) - Method in interface com.hazelcast.core.MultiMap
Adds the specified entry listener for the specified key.
addEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.core.ReplicatedMap
Adds an entry listener for this map.
addEntryListener(EntryListener<K, V>, K) - Method in interface com.hazelcast.core.ReplicatedMap
Adds the specified entry listener for the specified key.
addEntryListener(EntryListener<K, V>, Predicate<K, V>) - Method in interface com.hazelcast.core.ReplicatedMap
Adds an continuous entry listener for this map.
addEntryListener(EntryListener<K, V>, Predicate<K, V>, K) - Method in interface com.hazelcast.core.ReplicatedMap
Adds an continuous entry listener for this map.
addEntryListener(MapListener, boolean) - Method in 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
 
addEntryListenerConfig(CacheSimpleEntryListenerConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
addEntryListenerConfig(CacheSimpleEntryListenerConfig) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MapConfig
 
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MultiMapConfig
Adds an entry listener to this MultiMap (listens for when entries are added or removed).
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.QueryCacheConfig
Adds EntryListenerConfig to this QueryCacheConfig.
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.ReplicatedMapConfig
 
addEventJournalConfig(EventJournalConfig) - Method in class com.hazelcast.config.Config
Adds the event journal configuration.
addExecutorConfig(ExecutorConfig) - Method in class com.hazelcast.config.Config
Adds the executor configuration.
addField(FieldDefinitionImpl) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addFilter(String) - Method in class com.hazelcast.config.WanReplicationRef
Adds the class name implementing the CacheWanEventFilter or MapWanEventFilter for filtering outbound WAN replication events.
addFilter(String) - Method in class com.hazelcast.config.WanReplicationRefReadOnly
Deprecated.
 
addFlakeIdGeneratorConfig(ClientFlakeIdGeneratorConfig) - Method in class com.hazelcast.client.config.ClientConfig
Adds a flake ID generator configuration.
addFlakeIdGeneratorConfig(FlakeIdGeneratorConfig) - Method in class com.hazelcast.config.Config
Adds a flake ID generator configuration.
addFloatArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addFloatField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addIndex(String, boolean) - Method in interface com.hazelcast.core.IMap
Adds an index to this map for the specified entries so that queries can run faster.
addIndex(String, boolean) - Method in interface com.hazelcast.map.QueryCache
 
addIndexConfig(MapIndexConfig) - Method in class com.hazelcast.config.QueryCacheConfig
 
addIntArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addInterceptor(MapInterceptor) - Method in interface com.hazelcast.core.IMap
Adds an interceptor for this map.
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
 
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.config.Config
Adds the JobTracker configuration.
addLifecycleListener(LifecycleListener) - Method in interface com.hazelcast.core.LifecycleService
Add a listener object to listen for lifecycle events.
addListConfig(ListConfig) - Method in class com.hazelcast.config.Config
Adds the list configuration.
addListenerConfig(ListenerConfig) - Method in class com.hazelcast.client.config.ClientConfig
Helper method to add a new ListenerConfig
addListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.Config
Adds a configuration for an EventListener.
addListenerConfig(QuorumListenerConfig) - Method in class com.hazelcast.config.QuorumConfig
 
addLocalEntryListener(MapListener) - Method in interface com.hazelcast.core.IMap
Adds a MapListener for this map.
addLocalEntryListener(EntryListener) - Method in interface com.hazelcast.core.IMap
Deprecated.
addLocalEntryListener(MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
Adds a MapListener for this map.
addLocalEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
addLocalEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
Adds a local entry listener for this map.
addLocalEntryListener(EntryListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
addLocalEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.core.MultiMap
Adds a local entry listener for this multimap.
addLocalPartitionLostListener(PartitionLostListener) - Method in interface com.hazelcast.spi.partition.IPartitionService
 
addLockConfig(LockConfig) - Method in class com.hazelcast.config.Config
Adds the lock configuration.
addLogListener(Level, LogListener) - Method in interface com.hazelcast.logging.LoggingService
 
addLogListener(Level, LogListener) - Method in class com.hazelcast.logging.LoggingServiceImpl
 
addLongArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addLongField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addMapAttributeConfig(MapAttributeConfig) - Method in class com.hazelcast.config.MapConfig
 
addMapConfig(MapConfig) - Method in class com.hazelcast.config.Config
Adds the map configuration.
addMapIndexConfig(MapIndexConfig) - Method in class com.hazelcast.config.MapConfig
 
addMapIndexConfig(MapIndexConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
addMapPartitionLostListenerConfig(MapPartitionLostListenerConfig) - Method in class com.hazelcast.config.MapConfig
 
addMember(String) - Method in class com.hazelcast.config.TcpIpConfig
Adds a 'well known' member.
addMember(Member) - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
addMember(Member) - Method in interface com.hazelcast.partition.membergroup.MemberGroup
 
addMember(Member) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
addMemberGroupConfig(MemberGroupConfig) - Method in class com.hazelcast.config.PartitionGroupConfig
addMemberLoginModuleConfig(LoginModuleConfig) - Method in class com.hazelcast.config.SecurityConfig
 
addMembers(Collection<Member>) - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
addMembers(Collection<Member>) - Method in interface com.hazelcast.partition.membergroup.MemberGroup
 
addMembers(Collection<Member>) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
addMembershipListener(MembershipListener) - Method in interface com.hazelcast.client.spi.ClientClusterService
 
addMembershipListener(MembershipListener) - Method in interface com.hazelcast.core.Cluster
Adds MembershipListener to listen for membership updates.
addMerkleTreeConfig(MerkleTreeConfig) - Method in class com.hazelcast.config.Config
Adds the merkle tree configuration.
addMessageListener(MessageListener<E>) - Method in interface com.hazelcast.core.ITopic
Subscribes to this topic.
addMessageListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.ReliableTopicConfig
Adds a message listener (listens for when messages are added or removed) to this reliable topic.
addMessageListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.TopicConfig
Adds a message listener to this topic (listens for when messages are added or removed).
addMessageListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.TopicConfigReadOnly
Deprecated.
 
addMigrationListener(MigrationListener) - Method in interface com.hazelcast.core.PartitionService
Adds a MigrationListener.
addMigrationListener(MigrationListener) - Method in interface com.hazelcast.spi.partition.IPartitionService
 
addMultiMapConfig(MultiMapConfig) - Method in class com.hazelcast.config.Config
Adds the multimap configuration.
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
addObject(T) - Method in class com.hazelcast.query.extractor.ValueCollector
Collects a value passed as an argument
addOpToCancel(Address, long) - Method in class com.hazelcast.spi.CallsPerMember
 
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
 
addPackages(String...) - Method in class com.hazelcast.config.ClassFilter
 
addPartitionLostListener(CachePartitionLostListener) - Method in interface com.hazelcast.cache.ICache
Adds a CachePartitionLostListener.
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 interface com.hazelcast.spi.partition.IPartitionService
 
addPNCounterConfig(PNCounterConfig) - Method in class com.hazelcast.config.Config
Adds the PN counter configuration.
addPortableArrayField(String, ClassDefinition) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addPortableFactory(int, PortableFactory) - Method in class com.hazelcast.config.SerializationConfig
 
addPortableFactoryClass(int, Class<? extends PortableFactory>) - Method in class com.hazelcast.config.SerializationConfig
 
addPortableFactoryClass(int, String) - Method in class com.hazelcast.config.SerializationConfig
 
addPortableField(String, ClassDefinition) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addPrefixes(String...) - Method in class com.hazelcast.config.ClassFilter
 
addProperty(String, Comparable) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
addProperty(String, String) - Method in class com.hazelcast.config.ServiceConfig
 
addProxyFactoryConfig(ProxyFactoryConfig) - Method in class com.hazelcast.client.config.ClientConfig
Helper method to add a new ProxyFactoryConfig
addProxyListener(DistributedObjectListener) - Method in interface com.hazelcast.spi.ProxyService
 
addQueryCacheConfig(String, QueryCacheConfig) - Method in class com.hazelcast.client.config.ClientConfig
 
addQueryCacheConfig(QueryCacheConfig) - Method in class com.hazelcast.config.MapConfig
Adds a new QueryCacheConfig to this MapConfig.
addQueueConfig(QueueConfig) - Method in class com.hazelcast.config.Config
Adds the queue configuration.
addQuorumConfig(QuorumConfig) - Method in class com.hazelcast.config.Config
Adds the split-brain protection configuration.
addReliableTopicConfig(ClientReliableTopicConfig) - Method in class com.hazelcast.client.config.ClientConfig
Adds a ClientReliableTopicConfig.
addReliableTopicConfig(ReliableTopicConfig) - Method in class com.hazelcast.config.Config
Adds the reliable topic configuration.
addReplicatedMapConfig(ReplicatedMapConfig) - Method in class com.hazelcast.config.Config
Adds the replicated map configuration.
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
 
Addresses - Class in com.hazelcast.client.connection
A collection of addresses.
Addresses() - Constructor for class com.hazelcast.client.connection.Addresses
 
Addresses(Collection<Address>) - Constructor for class com.hazelcast.client.connection.Addresses
 
addresses() - Method in class com.hazelcast.spi.CallsPerMember
 
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.
addRingBufferConfig(RingbufferConfig) - Method in class com.hazelcast.config.Config
Adds the ringbuffer configuration.
addScheduledExecutorConfig(ScheduledExecutorConfig) - Method in class com.hazelcast.config.Config
Adds the scheduled executor configuration.
addSecurityInterceptorConfig(SecurityInterceptorConfig) - Method in class com.hazelcast.config.SecurityConfig
 
addSemaphoreConfig(SemaphoreConfig) - Method in class com.hazelcast.config.Config
Adds the ISemaphore configuration.
addSerializerConfig(SerializerConfig) - Method in class com.hazelcast.config.SerializationConfig
 
addServiceConfig(ServiceConfig) - Method in class com.hazelcast.config.ServicesConfig
 
addSetConfig(SetConfig) - Method in class com.hazelcast.config.Config
Adds the set configuration.
addShortArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addShortField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addTopicConfig(TopicConfig) - Method in class com.hazelcast.config.Config
Adds the topic configuration.
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
 
addWanPublisherConfig(WanPublisherConfig) - Method in class com.hazelcast.config.WanReplicationConfig
Adds a WAN publisher configuration to this WAN replication.
addWanReplicationConfig(WanReplicationConfig) - Method in class com.hazelcast.config.Config
Adds the WAN replication config under the name defined by WanReplicationConfig.getName().
addWanReplicationConfig(WanReplicationConfig) - Method in interface com.hazelcast.wan.WanReplicationService
Adds a new WanReplicationConfig to this member and creates the WanReplicationPublishers specified in the config.
after(Credentials, String, String, String, Parameters) - Method in interface com.hazelcast.security.SecurityInterceptor
 
afterGet(Object) - Method in interface com.hazelcast.map.MapInterceptor
Called after the get(...) operation is completed.
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.
afterRun() - Method in class com.hazelcast.crdt.AbstractCRDTReplicationOperation
 
afterRun() - Method in class com.hazelcast.spi.Operation
Is executed called after Operation.run() or Operation.call() method completes normally and the operation is not blocked, see CallStatus.WAIT.
afterStart(HazelcastClientInstanceImpl) - Method in interface com.hazelcast.client.ClientExtension
Called after node is started
aggregate() - Method in class com.hazelcast.aggregation.Aggregator
Returns the result of the aggregation.
aggregate(Aggregator<Map.Entry<K, V>, R>) - Method in interface com.hazelcast.core.IMap
Applies the aggregation logic on all map entries and returns the result
aggregate(Aggregator<Map.Entry<K, V>, R>, Predicate<K, V>) - Method in interface com.hazelcast.core.IMap
Applies the aggregation logic on map entries filtered with the Predicated and returns the result
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in interface com.hazelcast.core.IMap
Deprecated.
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in interface com.hazelcast.core.IMap
Deprecated.
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in interface com.hazelcast.core.MultiMap
Deprecated.
The old Aggregations API is superseded by Fast Aggregations (com.hazelcast.aggregation) which does not yet support MultiMap. Hazelcast Jet can be used in the future to replace this functionality.
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in interface com.hazelcast.core.MultiMap
Deprecated.
The old Aggregations API is superseded by Fast Aggregations (com.hazelcast.aggregation) which does not yet support MultiMap. Hazelcast Jet can be used in the future to replace this functionality.
Aggregation<Key,Supplied,Result> - Interface in com.hazelcast.mapreduce.aggregation
Deprecated.
AGGREGATION_ACCUMULATION_PARALLEL_EVALUATION - Static variable in class com.hazelcast.spi.properties.GroupProperty
Run aggregation accumulation for multiple entries in parallel.
Aggregations - Class in com.hazelcast.mapreduce.aggregation
Deprecated.
Use fast-aggregations Aggregators
Aggregator<I,R> - Class in com.hazelcast.aggregation
Base class for all aggregators.
Aggregator() - Constructor for class com.hazelcast.aggregation.Aggregator
 
Aggregators - Class in com.hazelcast.aggregation
A utility class to create basic Aggregator instances.
AliasedDiscoveryConfig<T extends AliasedDiscoveryConfig<T>> - Class in com.hazelcast.config
Configuration for discovery strategy aliases, e.g.
AliasedDiscoveryConfig(String) - Constructor for class com.hazelcast.config.AliasedDiscoveryConfig
 
aliasedDiscoveryConfigsFrom(ClientConfig) - Static method in class com.hazelcast.client.config.ClientAliasedDiscoveryConfigUtils
Gets a list of all aliased discovery configs from config.
aliasedDiscoveryConfigsFrom(JoinConfig) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Gets a list of all aliased discovery configs from config.
aliasedDiscoveryConfigsFrom(WanPublisherConfig) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Gets a list of all aliased discovery configs from config.
AliasedDiscoveryConfigUtils - Class in com.hazelcast.config
Utility class for Aliased Discovery Configs.
all() - Static method in class com.hazelcast.mapreduce.aggregation.Supplier
Deprecated.
The predefined Supplier selects all values and does not perform any kind of data transformation.
all(PropertyExtractor<ValueIn, ValueOut>) - Static method in class com.hazelcast.mapreduce.aggregation.Supplier
Deprecated.
The predefined Supplier selects all values and performs the given PropertyExtractors transformation to the input data.
ALLOW_INVOCATIONS_WHEN_DISCONNECTED - Static variable in class com.hazelcast.client.spi.properties.ClientProperty
Client disallows doing invocations on client disconnected state.
AllPermissions - Class in com.hazelcast.security.permission
 
AllPermissions() - Constructor for class com.hazelcast.security.permission.AllPermissions
 
AllPermissions.AllPermissionsCollection - Class in com.hazelcast.security.permission
 
AllPermissionsCollection() - Constructor for class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
AllPermissionsCollection(boolean) - Constructor for class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
allUsePublicAddress(List<AliasedDiscoveryConfig<?>>) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Checks whether all aliased discovery configs have the tag <use-public-ip>trye</use-public-ip.
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.
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 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.
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.
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.
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.
andThen(ExecutionCallback<V>) - Method in interface com.hazelcast.core.ICompletableFuture
Registers a callback that will run after this 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 this future is completed.
appendProperties(Properties) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
appendProperties(Map<String, Comparable>) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
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 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(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) - 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 interface com.hazelcast.quorum.QuorumFunction
Determines if quorum is present based on the current list of members in the cluster.
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.
ArgumentParser<I,O> - Class in com.hazelcast.query.extractor
Common superclass for all argument parsers.
ArgumentParser() - Constructor for class com.hazelcast.query.extractor.ArgumentParser
 
ArrayMerkleTree - Class in com.hazelcast.wan.merkletree
A not thread-safe, array based MerkleTree implementation, which represents each node of the tree as a single int containing the node's hash.
ArrayMerkleTree(int) - Constructor for class com.hazelcast.wan.merkletree.ArrayMerkleTree
 
asCompletableFuture(Future<V>) - Method in interface com.hazelcast.spi.ExecutionService
 
asElementIterable(NodeList) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
 
asReadOnly() - Method in class com.hazelcast.config.MemberAttributeConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
asVersion() - Method in class com.hazelcast.version.MemberVersion
 
ASYNC_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
Name of the async executor.
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 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 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 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 interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Clears the current stored reference.
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.
asyncContains(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Checks if the reference contains the value.
asyncDecrementAndGet() - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Atomically decrements the current value by one.
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 interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Atomically adds the given value to the current value.
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 interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Atomically increments the current value by one.
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 interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Atomically increments the current value by one.
asyncIsNull() - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Checks if the stored reference is null.
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 interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
will be removed from Hazelcast 3.4 since it doesn't really serve a purpose.
ATOMIC_LONG_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
ATOMIC_REFERENCE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
AtomicLongConfig - Class in com.hazelcast.config
Contains the configuration for an AtomicLong.
AtomicLongConfig(String) - Constructor for class com.hazelcast.config.AtomicLongConfig
 
AtomicLongConfig(AtomicLongConfig) - Constructor for class com.hazelcast.config.AtomicLongConfig
 
AtomicLongPermission - Class in com.hazelcast.security.permission
 
AtomicLongPermission(String, String...) - Constructor for class com.hazelcast.security.permission.AtomicLongPermission
 
AtomicReferenceConfig - Class in com.hazelcast.config
Contains the configuration for an AtomicReference.
AtomicReferenceConfig(String) - Constructor for class com.hazelcast.config.AtomicReferenceConfig
 
AtomicReferenceConfig(AtomicReferenceConfig) - Constructor for class com.hazelcast.config.AtomicReferenceConfig
 
AtomicReferencePermission - Class in com.hazelcast.security.permission
 
AtomicReferencePermission(String, String...) - Constructor for class com.hazelcast.security.permission.AtomicReferencePermission
 
AuthenticationException - Exception in com.hazelcast.client
A HazelcastException that is thrown when there is an Authentication failure: e.g.
AuthenticationException() - Constructor for exception com.hazelcast.client.AuthenticationException
Creates a AuthenticationException with a default message.
AuthenticationException(String) - Constructor for exception com.hazelcast.client.AuthenticationException
Creates a AuthenticationException with the given message.
availablePermits() - Method in interface com.hazelcast.core.ISemaphore
Returns the current number of permits currently available in this semaphore.
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.
AwsConfig - Class in com.hazelcast.config
The AWSConfig contains the configuration for AWS join mechanism.
AwsConfig() - Constructor for class com.hazelcast.config.AwsConfig
 
AzureConfig - Class in com.hazelcast.config
Configuration for the Azure Discovery Strategy.
AzureConfig() - Constructor for class com.hazelcast.config.AzureConfig
 

B

BACKPRESSURE_BACKOFF_TIMEOUT_MILLIS - Static variable in class com.hazelcast.client.spi.properties.ClientProperty
Control the maximum timeout in millis to wait for an invocation space to be available.
BACKPRESSURE_BACKOFF_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Control the maximum timeout in millis to wait for an invocation space to be available.
BACKPRESSURE_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Using back pressure, you can prevent an overload of pending asynchronous backups.
BACKPRESSURE_MAX_CONCURRENT_INVOCATIONS_PER_PARTITION - Static variable in class com.hazelcast.spi.properties.GroupProperty
The maximum number of concurrent invocations per partition.
BACKPRESSURE_SYNCWINDOW - Static variable in class com.hazelcast.spi.properties.GroupProperty
Controls the frequency of a BackupAwareOperation getting its async backups converted to a sync backups.
backup() - Method in interface com.hazelcast.hotrestart.HotRestartService
Attempts to perform a cluster hot restart data backup.
backup(long) - Method in interface com.hazelcast.hotrestart.HotRestartService
Attempts to perform a cluster hot restart data backup.
backup() - Method in class com.hazelcast.hotrestart.NoOpHotRestartService
 
backup(long) - Method in class com.hazelcast.hotrestart.NoOpHotRestartService
 
BACKUP_DIR_PREFIX - Static variable in interface com.hazelcast.hotrestart.HotRestartService
The prefix for each hot restart backup directory.
BackupAwareEntryProcessor<K,V,T> - Interface in com.hazelcast.cache
An invocable function that allows applications to perform compound operations on a Cache.Entry atomically, according to the defined consistency of a Cache.
BackupAwareOperation - Interface in com.hazelcast.spi
A BackupAwareOperation is an Operation to indicate then when a change is made, a BackupOperation is created to replicate the backup.
BackupOperation - Interface in com.hazelcast.spi
When an BackupAwareOperation makes a change, the backups need to be replicated to other members (depending on the configuration and if change really happened).
BackupTaskState - Enum in com.hazelcast.hotrestart
The state of the hot restart backup task
BackupTaskStatus - Class in com.hazelcast.hotrestart
The status of the hot restart backup task, including progress and state.
BackupTaskStatus(BackupTaskState, int, int) - Constructor for class com.hazelcast.hotrestart.BackupTaskStatus
 
BaseMap<K,V> - Interface in com.hazelcast.core
Base interface for Hazelcast distributed maps.
BaseMultiMap<K,V> - Interface in com.hazelcast.core
Base interface for Hazelcast distributed multi-maps.
BaseQueue<E> - Interface in com.hazelcast.core
Base interface for Hazelcast distributed queues.
before(Credentials, String, String, String, Parameters) - Method in interface com.hazelcast.security.SecurityInterceptor
 
beforeConnectToCluster(Address) - Method in class com.hazelcast.client.connection.ClientConnectionStrategy
If a cluster connection is established, this method will be called.
beforeGetConnection(Address) - Method in class com.hazelcast.client.connection.ClientConnectionStrategy
The purpose of this method is to validate a connection request by target, and exit the blocking invocation.
beforeListenerRegister() - Method in interface com.hazelcast.client.spi.EventHandler
This method is called before registration request is sent to node.
beforeMigration(PartitionMigrationEvent) - Method in interface com.hazelcast.spi.MigrationAwareService
Called before migration process starts, on both source and destination members.
beforeOpenConnection(Address) - Method in class com.hazelcast.client.connection.ClientConnectionStrategy
If a new connection is required to open by ClientConnectionManager, this method will be called.
beforeRun() - Method in class com.hazelcast.spi.Operation
The beforeRun is called before either the Operation.run() or the Operation.call() method is called.
beforeStart(HazelcastClientInstanceImpl) - Method in interface com.hazelcast.client.ClientExtension
Called before client is started
beginCombine() - Method in class com.hazelcast.mapreduce.Combiner
Deprecated.
This method is called before the first value is submitted to this Combiner instance.
beginReduce() - Method in class com.hazelcast.mapreduce.Reducer
Deprecated.
This method is called before the first value is submitted to this Reducer instance.
beginTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
Begins a transaction.
Beta - Annotation Type in com.hazelcast.spi.annotation
An element annotated with this annotation is considered beta status.
between(Comparable, Comparable) - Method in class com.hazelcast.query.EntryObject
 
between(String, Comparable, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates a between predicate that will pass items if the value stored under the given item attribute is contained inside the given range.
bigDecimalAvg() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalAvg() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to calculate the BigDecimal average of all supplied values.
This aggregation is similar to:
bigDecimalMax() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalMax() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to find the BigDecimal maximum of all supplied values.
This aggregation is similar to:
bigDecimalMin() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalMin() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to find the BigDecimal minimum of all supplied values.
This aggregation is similar to:
bigDecimalSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalSum() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to calculate the BigDecimal sum of all supplied values.
This aggregation is similar to:
bigIntegerAvg() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerAvg() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to calculate the BigInteger average of all supplied values.
This aggregation is similar to:
bigIntegerMax() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerMax() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to find the BigInteger maximum of all supplied values.
This aggregation is similar to:
bigIntegerMin() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerMin() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to find the BigInteger minimum of all supplied values.
This aggregation is similar to:
bigIntegerSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerSum() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to calculate the BigInteger sum of all supplied values.
This aggregation is similar to:
BinaryInterface - Annotation Type in com.hazelcast.nio.serialization
Indicates that the binary serialized form of the annotated class is used in client-member communication over Hazelcast Open Binary Client Protocol or in other ways which may break Hazelcast or other systems.
BIND_SPOOFING_CHECKS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Controls whether we apply more strict checks upon BIND requests towards a cluster member.
Bits - Class in com.hazelcast.nio
Access and manipulate bits, bytes, primitives...
blacklist(Address, boolean) - Method in interface com.hazelcast.cluster.Joiner
Deprecated.
Adds an address to the blacklist.
BlockingOperation - Interface in com.hazelcast.spi
An interface that can be implemented by an operation that can block.
BOOLEAN_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
BOOLEAN_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
BOOLEAN_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
Boolean size in bytes
BufferObjectDataInput - Interface in com.hazelcast.nio
 
BufferObjectDataOutput - Interface in com.hazelcast.nio
 
build() - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
 
build(ClassLoader) - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
 
build() - Method in interface com.hazelcast.config.ConfigBuilder
Builds Config object.
build() - Method in class com.hazelcast.config.ProbabilisticQuorumConfigBuilder
 
build() - Method in class com.hazelcast.config.QuorumConfigBuilder
 
build() - Method in class com.hazelcast.config.RecentlyActiveQuorumConfigBuilder
 
build() - Method in class com.hazelcast.config.XmlConfigBuilder
 
build() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
BuiltInCacheMergePolicies - Enum in com.hazelcast.cache
Enum that represents all built-in CacheMergePolicy implementations.
byOrdinal(int) - Static method in enum com.hazelcast.mapreduce.JobPartitionState.State
Deprecated.
Returns an processing state by its given ordinal
BYTE_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
BYTE_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
BYTE_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
Byte size in bytes
ByteArraySerializer<T> - Interface in com.hazelcast.nio.serialization
For sample usage custom serialization and other way of custom serialization see StreamSerializer.
bytes() - Method in class com.hazelcast.memory.MemorySize
Returns value of memory size in bytes.

C

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_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_MANAGER_PREFIX - Static variable in interface com.hazelcast.cache.HazelcastCacheManager
Hazelcast's CacheManager prefix to be appended to the head of the cache name.
CACHE_PARTITION_LOST_LISTENER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
CACHE_PROP - Static variable in class com.hazelcast.spring.cache.HazelcastCacheManager
Property name for hazelcast spring-cache related properties.
CacheConfig<K,V> - Class in com.hazelcast.config
Contains all the configuration for the ICache.
CacheConfig() - Constructor for class com.hazelcast.config.CacheConfig
 
CacheConfig(String) - Constructor for class com.hazelcast.config.CacheConfig
 
CacheConfig(CompleteConfiguration<K, V>) - Constructor for class com.hazelcast.config.CacheConfig
 
CacheConfig(CacheSimpleConfig) - Constructor for class com.hazelcast.config.CacheConfig
 
CacheConfigReadOnly<K,V> - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
CacheConfiguration<K,V> - Interface in com.hazelcast.config
Mutable extension to CompleteConfiguration
CacheDeserializedValues - Enum in com.hazelcast.config
Control caching of de-serialized values.
CacheEntryView<K,V> - Interface in com.hazelcast.cache
Entry info for cache record.
CacheEventType - Enum in com.hazelcast.cache
Hazelcast JCache implementation's internal event types.
CacheEvictionConfig - Class in com.hazelcast.config
Deprecated.
Use EvictionConfig instead of this
CacheEvictionConfig() - Constructor for class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
CacheEvictionConfig(int, EvictionConfig.MaxSizePolicy, EvictionPolicy) - Constructor for class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
CacheEvictionConfig(int, CacheEvictionConfig.CacheMaxSizePolicy, EvictionPolicy) - Constructor for class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
CacheEvictionConfig(int, EvictionConfig.MaxSizePolicy, String) - Constructor for class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
CacheEvictionConfig(int, CacheEvictionConfig.CacheMaxSizePolicy, String) - Constructor for class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
CacheEvictionConfig(int, EvictionConfig.MaxSizePolicy, EvictionPolicyComparator) - Constructor for class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
CacheEvictionConfig(int, CacheEvictionConfig.CacheMaxSizePolicy, EvictionPolicyComparator) - Constructor for class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
CacheEvictionConfig(EvictionConfig) - Constructor for class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
CacheEvictionConfig.CacheMaxSizePolicy - Enum in com.hazelcast.config
Deprecated.
Cache Maximum Size Policy
CacheEvictionConfigReadOnly - Class in com.hazelcast.config
Deprecated.
Use EvictionConfigReadOnly instead of this
CacheEvictionConfigReadOnly(EvictionConfig) - Constructor for class com.hazelcast.config.CacheEvictionConfigReadOnly
Deprecated.
 
CacheEvictionPolicyComparator<K,V> - Class in com.hazelcast.cache
Cache specific EvictionPolicyComparator for comparing CacheEntryViews to be evicted.
CacheEvictionPolicyComparator() - Constructor for class com.hazelcast.cache.CacheEvictionPolicyComparator
 
cacheLoaderFactory - Variable in class com.hazelcast.config.AbstractCacheConfig
The Factory for the CacheLoader.
CacheManagerBeanDefinitionParser - Class in com.hazelcast.spring
Bean definition parser for JCache CacheManager.
CacheManagerBeanDefinitionParser() - Constructor for class com.hazelcast.spring.CacheManagerBeanDefinitionParser
 
CacheMergePolicy - Interface in com.hazelcast.cache
Policy for merging cache entries after a split-brain has been healed.
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
 
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
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
CachePartitionLostListenerConfigReadOnly(CachePartitionLostListenerConfig) - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfigReadOnly
Deprecated.
 
CachePermission - Class in com.hazelcast.security.permission
 
CachePermission(String, String...) - Constructor for class com.hazelcast.security.permission.CachePermission
 
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
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
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
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
CacheSimpleEntryListenerConfigReadOnly(CacheSimpleEntryListenerConfig) - Constructor for class com.hazelcast.config.CacheSimpleEntryListenerConfigReadOnly
Deprecated.
 
CacheStatistics - Interface in com.hazelcast.cache
Cache statistics
CacheUtil - Class in com.hazelcast.cache
Utility class for various cache related operations to be used by our internal structure and end user.
cacheWriterFactory - Variable in class com.hazelcast.config.AbstractCacheConfig
The Factory for the CacheWriter.
call() - Method in class com.hazelcast.console.Echo
 
call() - Method in class com.hazelcast.console.SimulateLoadTask
 
call() - Method in class com.hazelcast.spi.Operation
Call the operation and returns the CallStatus.
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
 
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 - Class in com.hazelcast.spi
The result of an Operation.call().
CallStatus(int) - Constructor for class com.hazelcast.spi.CallStatus
 
callTimeout - Variable in class com.hazelcast.spi.InvocationBuilder
 
CanCancelOperations - Interface in com.hazelcast.spi
Implemented by a service that can cancel its operations.
cancel(boolean) - Method in interface com.hazelcast.scheduledexecutor.IScheduledFuture
Attempts to cancel further scheduling of this task.
cancelOperation(Address, long) - Method in interface com.hazelcast.spi.CanCancelOperations
Notifies this service that an operation was requested to be cancelled.
capacity() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Returns the capacity of this Ringbuffer.
CARDINALITY_ESTIMATOR_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
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.
CardinalityEstimatorConfig - Class in com.hazelcast.config
Configuration options for the CardinalityEstimator
CardinalityEstimatorConfig() - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
 
CardinalityEstimatorConfig(String) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
 
CardinalityEstimatorConfig(String, int, int) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
 
CardinalityEstimatorConfig(String, int, int, MergePolicyConfig) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
 
CardinalityEstimatorConfig(String, int, int, String, MergePolicyConfig) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
 
CardinalityEstimatorConfig(CardinalityEstimatorConfig) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
 
CardinalityEstimatorPermission - Class in com.hazelcast.security.permission
 
CardinalityEstimatorPermission(String, String...) - Constructor for class com.hazelcast.security.permission.CardinalityEstimatorPermission
 
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.
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.
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_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
Char size in bytes
checkPermission(Subject, Permission) - Method in interface com.hazelcast.security.SecurityContext
Checks whether current Subject has been granted specified permission or not.
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(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.
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
ClassFilter - Class in com.hazelcast.config
Holds blacklist and whitelist configuration in java deserialization configuration.
ClassFilter() - Constructor for class com.hazelcast.config.ClassFilter
 
classLoader - Variable in class com.hazelcast.config.AbstractCacheConfig
The ClassLoader to be used to resolve key & value types, if set
ClassLoaderUtil - Class in com.hazelcast.nio
Utility class to deal with class loaders.
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 - Interface in com.hazelcast.nio
Allows to intercept class resolution during deserialization based on classname.
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.
cleanNodeName(Node) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
 
clear() - Method in class com.hazelcast.config.InterfacesConfig
clears all interfaces.
clear() - Method in class com.hazelcast.config.MemberGroupConfig
Removes all interfaces from the member group.
clear() - Method in class com.hazelcast.config.PartitionGroupConfig
Removes all the PartitionGroupConfig.MemberGroupType instances.
clear() - Method in class com.hazelcast.config.ServicesConfig
 
clear() - Method in class com.hazelcast.config.TcpIpConfig
Removes all members.
clear() - Method in interface com.hazelcast.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.nio.BufferObjectDataInput
 
clear() - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
clear() - Method in class com.hazelcast.spi.CallsPerMember
 
clear() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Clears the data in the ringbuffer.
clear() - Method in class com.hazelcast.spring.cache.HazelcastCache
 
clear() - Method in class com.hazelcast.wan.merkletree.ArrayMerkleTree
 
clear() - Method in interface com.hazelcast.wan.merkletree.MerkleTree
Clears the Merkle tree
clearAsync() - Method in interface com.hazelcast.core.IAtomicReference
Clears the current stored reference.
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
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
 
clearLoadedLoggers() - Method in class com.hazelcast.logging.LoggerFactorySupport
 
clearQueues(String, String) - Method in interface com.hazelcast.wan.WanReplicationService
Clears WAN replication queues of the given wanReplicationName for the given target.
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_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_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_QUERY_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
Name of the client executor.
ClientAliasedDiscoveryConfigUtils - Class in com.hazelcast.client.config
Utility class for Aliased Discovery Configs in Hazelcast Client.
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
Deprecated.
Use AwsConfig instead.
ClientAwsConfig() - Constructor for class com.hazelcast.client.config.ClientAwsConfig
Deprecated.
 
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.
ClientCloudConfig - Class in com.hazelcast.client.config
hazelcast.cloud configuration to let the client connect the cluster via hazelcast.cloud
ClientCloudConfig() - Constructor for class com.hazelcast.client.config.ClientCloudConfig
 
ClientClusterService - Interface in com.hazelcast.client.spi
Cluster service for Hazelcast clients.
ClientConfig - Class in com.hazelcast.client.config
Main configuration to setup a Hazelcast Client
ClientConfig() - Constructor for class com.hazelcast.client.config.ClientConfig
 
ClientConfigXmlGenerator - Class in com.hazelcast.client.config
The ClientConfigXmlGenerator is responsible for transforming a ClientConfig to a Hazelcast Client XML string.
clientConnected(Client) - Method in interface com.hazelcast.core.ClientListener
Invoked when a client is connected.
ClientConnectionManager - Interface in com.hazelcast.client.connection
Responsible for managing ClientConnection objects.
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.
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
 
clientDisconnected(Client) - Method in interface com.hazelcast.core.ClientListener
Invoked when a client is disconnected.
clientDisconnected(String) - Method in interface com.hazelcast.spi.ClientAwareService
Invoked when a client disconnects from a member.
ClientExecutionService - Interface in com.hazelcast.client.spi
Executor service for Hazelcast clients.
ClientExtension - Interface in com.hazelcast.client
ClientExtension is a client extension mechanism to be able to plug different implementations of some modules, like; InternalSerializationService etc.
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
ClientIcmpPingConfig - Class in com.hazelcast.client.config
Configuration for icmp ping failure detector of clients.
ClientIcmpPingConfig() - Constructor for class com.hazelcast.client.config.ClientIcmpPingConfig
 
ClientInvocationService - Interface in com.hazelcast.client.spi
Invocation service for Hazelcast clients.
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.
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
 
ClientPartitionService - Interface in com.hazelcast.client.spi
Partition service for Hazelcast clients.
ClientProperty - Class in com.hazelcast.client.spi.properties
Defines the name and default value for Hazelcast Client properties.
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.
ClientReliableTopicConfig - Class in com.hazelcast.client.config
Contains the ReliableTopic configuration for a client.
ClientReliableTopicConfig() - Constructor for class com.hazelcast.client.config.ClientReliableTopicConfig
 
ClientReliableTopicConfig(String) - Constructor for class com.hazelcast.client.config.ClientReliableTopicConfig
Creates a new ReliableTopicConfig with default settings.
ClientReliableTopicConfig(ClientReliableTopicConfig) - Constructor for class com.hazelcast.client.config.ClientReliableTopicConfig
Create a clone of given reliable topic
ClientSecurityConfig - Class in com.hazelcast.client.config
Contains the security configuration for the client.
ClientSecurityConfig() - Constructor for class com.hazelcast.client.config.ClientSecurityConfig
 
ClientService - Interface in com.hazelcast.core
ClientService allows you to query connected Clients and attach/detach ClientListeners to listen to connection events.
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
Manages the execution of client transactions and provides TransactionContexts.
ClientType - Enum in com.hazelcast.core
Type of a Hazelcast client.
ClientUserCodeDeploymentConfig - Class in com.hazelcast.client.config
Configuration of User Code Deployment.
ClientUserCodeDeploymentConfig() - Constructor for class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
close() - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
close(ClassLoader) - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
close(URI, ClassLoader) - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
close() - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
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.
closeResource(Closeable) - Static method in class com.hazelcast.nio.IOUtil
Quietly attempts to close a Closeable resource, swallowing any exception.
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
 
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
 
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.
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
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
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
 
com.hazelcast - package com.hazelcast
This package contains PlaceHolder
com.hazelcast.aggregation - package com.hazelcast.aggregation
Contains classes related to aggregations.
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.journal - package com.hazelcast.cache.journal
Contains EventJournal event interface for ICache.
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.client - package com.hazelcast.client
Contains classes/interfaces related to Client
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.spi - package com.hazelcast.client.spi
Contains classes/interfaces related to the Hazelcast client Service Provider Interface.
com.hazelcast.client.spi.properties - package com.hazelcast.client.spi.properties
Contains the Hazelcast client properties implementation.
com.hazelcast.cluster - package com.hazelcast.cluster
This package contains the cluster functionality.
com.hazelcast.cluster.memberselector - package com.hazelcast.cluster.memberselector
This package contains several MemberSelector implementations.
com.hazelcast.config - package com.hazelcast.config
Provides classes for configuring HazelcastInstance.
com.hazelcast.config.matcher - package com.hazelcast.config.matcher
Provides implementations for ConfigPatternMatcher.
com.hazelcast.config.properties - package com.hazelcast.config.properties
This package contains the public API for properties defined in the XML configuration.
com.hazelcast.config.replacer - package com.hazelcast.config.replacer
This package contains the public API and default implementation of variable replacers for configuration files.
com.hazelcast.config.replacer.spi - package com.hazelcast.config.replacer.spi
This package contains the SPI for configuration files variable replacers.
com.hazelcast.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.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.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.flakeidgen - package com.hazelcast.flakeidgen
This package contains Flake ID Generator functionality for Hazelcast.
com.hazelcast.hotrestart - package com.hazelcast.hotrestart
This package contains Hot Restart classes needed for open source Hazelcast code
com.hazelcast.logging - package com.hazelcast.logging
This package contains logging functionality for Hazelcast.
Since Hazelcast has a zero dependency policy, Hazelcast provides a logging abstraction like commons logging, so that different logging frameworks like log4j, can be hooked in.
com.hazelcast.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.journal - package com.hazelcast.map.journal
Contains EventJournal event interface for IMap.
com.hazelcast.map.listener - package com.hazelcast.map.listener
Contains various MapListener interfaces.
com.hazelcast.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.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.nio - package com.hazelcast.nio
This package contains classes related to New IO
com.hazelcast.nio.serialization - package com.hazelcast.nio.serialization
Contains interfaces/classes related to serialization; such as serializer interfaces, input/output streams.
com.hazelcast.osgi - package com.hazelcast.osgi
This package contains the OSGI functionality contract points 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.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.quorum - package com.hazelcast.quorum
Contains classes related to cluster quorum.
com.hazelcast.replicatedmap - package com.hazelcast.replicatedmap
Classes for replicated map.
com.hazelcast.replicatedmap.merge - package com.hazelcast.replicatedmap.merge
Contains out-of-the-box merge policies for ReplicatedMap.
com.hazelcast.ringbuffer - package com.hazelcast.ringbuffer
Contains the API for the Ringbuffer.
com.hazelcast.scheduledexecutor - package com.hazelcast.scheduledexecutor
This package contains ScheduledExecutorService functionality for Hazelcast.
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.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.exception - package com.hazelcast.spi.exception
Contains exceptions for Hazelcast SPI.
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.transaction - package com.hazelcast.transaction
Provides interfaces/classes for Hazelcast transaction support.
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.merkletree - package com.hazelcast.wan.merkletree
This package contains Merkle tree based anti-entropy implementation
combine(Aggregator) - Method in class com.hazelcast.aggregation.Aggregator
Incorporates the intermediary result of the given aggregator to this instance of the aggregator.
combine(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
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
Combiner() - Constructor for class com.hazelcast.mapreduce.Combiner
Deprecated.
 
combiner(CombinerFactory<? super KeyIn, ? super ValueIn, ? extends ValueOut>) - Method in interface com.hazelcast.mapreduce.MappingJob
Deprecated.
Defines the CombinerFactory for this task.
CombinerFactory<KeyIn,ValueIn,ValueOut> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
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.
commitMigration(PartitionMigrationEvent) - Method in interface com.hazelcast.spi.MigrationAwareService
Commits the migration process for this service, on both source and destination members.
commitTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
Commits a transaction.
compact() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
 
compactOrClear(ByteBuffer) - Static method in class com.hazelcast.nio.IOUtil
Compacts or clears the buffer depending if bytes are remaining in the byte-buffer.
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:
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:
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
Compares the given EvictableEntryView instances and returns the result.
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
 
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.
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.
compareTo(MemberVersion) - Method in class com.hazelcast.version.MemberVersion
 
compareTo(Version) - Method in class com.hazelcast.version.Version
 
compareTrees(MerkleTreeView, MerkleTreeView) - Static method in class com.hazelcast.wan.merkletree.MerkleTreeUtil
Compares the provided local and the remote Merkle trees and returns the breadth-first orders of the leaves that found to be different.
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.
complete(Object) - Method in interface com.hazelcast.spi.InternalCompletableFuture
Completes this future.
compress(byte[]) - Static method in class com.hazelcast.nio.IOUtil
 
Config - Class in com.hazelcast.config
Contains all the configuration to start a HazelcastInstance.
Config() - Constructor for class com.hazelcast.config.Config
 
Config(String) - Constructor for class com.hazelcast.config.Config
 
ConfigBuilder - Interface in com.hazelcast.config
Interface for all config builders.
configBuilder - Variable in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
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
 
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
 
ConfigReplacer - Interface in com.hazelcast.config.replacer.spi
Interface to be implemented by pluggable variable replacers for the configuration files.
ConfigurableService<T> - Interface in com.hazelcast.spi
A capability for SPI services.
ConfigurationException - Exception in com.hazelcast.config
A HazelcastException that is thrown when something is wrong with the server or client configuration.
ConfigurationException(String, String, String) - Constructor for exception com.hazelcast.config.ConfigurationException
 
ConfigurationException(String) - Constructor for exception com.hazelcast.config.ConfigurationException
 
ConfigurationException(String, Throwable) - Constructor for exception com.hazelcast.config.ConfigurationException
 
configure(GroupConfig, Properties) - Method in interface com.hazelcast.security.ICredentialsFactory
configure(Config, Properties) - Method in interface com.hazelcast.security.IPermissionPolicy
Configures IPermissionPolicy.
configure(T) - Method in interface com.hazelcast.spi.ConfigurableService
 
ConfigXmlGenerator - Class in com.hazelcast.config
The ConfigXmlGenerator is responsible for transforming a Config to a Hazelcast XML string.
ConfigXmlGenerator() - Constructor for class com.hazelcast.config.ConfigXmlGenerator
Creates a ConfigXmlGenerator that will format the code.
ConfigXmlGenerator(boolean) - Constructor for class com.hazelcast.config.ConfigXmlGenerator
Creates a ConfigXmlGenerator.
ConfigXmlGenerator(boolean, boolean) - Constructor for class com.hazelcast.config.ConfigXmlGenerator
Creates a ConfigXmlGenerator.
ConfigXmlGenerator.XmlGenerator - Class in com.hazelcast.config
Utility class to build xml using a StringBuilder.
CONNECT_ALL_WAIT_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
Connection - Interface in com.hazelcast.nio
Represents a 'connection' between two machines.
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 interface com.hazelcast.nio.ConnectionListener
 
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 - Interface in com.hazelcast.nio
Responsible for managing Connection objects.
connectionRemoved(Connection) - Method in interface com.hazelcast.nio.ConnectionListener
 
ConnectionRetryConfig - Class in com.hazelcast.client.config
Connection Retry Config is controls the period among the retries and when should a client gave up retrying.
ConnectionRetryConfig() - Constructor for class com.hazelcast.client.config.ConnectionRetryConfig
 
ConnectionType - Enum in com.hazelcast.nio
An enumeration of all possible Connection types.
connectToCluster() - Method in interface com.hazelcast.client.connection.ClientConnectionManager
 
connectToClusterAsync() - Method in interface com.hazelcast.client.connection.ClientConnectionManager
 
consistencyCheck(String, String, String) - Method in interface com.hazelcast.wan.WanReplicationService
Initiate WAN consistency check for a specific map.
ConsistencyCheckResult - Class in com.hazelcast.wan.merkletree
Result of the last WAN consistency check result
ConsistencyCheckResult() - Constructor for class com.hazelcast.wan.merkletree.ConsistencyCheckResult
 
ConsistencyCheckResult(int, int, int, int, int) - Constructor for class com.hazelcast.wan.merkletree.ConsistencyCheckResult
Constructs the result of the WAN consistency check comparison
ConsistencyCheckStrategy - Enum in com.hazelcast.config
Strategy for checking the consistency of data between replicas.
ConsistencyLostException - Exception in com.hazelcast.core
Exception that indicates that the consistency guarantees provided by some service has been lost.
ConsistencyLostException(String) - Constructor for exception com.hazelcast.core.ConsistencyLostException
 
ConsoleApp - Class in com.hazelcast.console
Special thanks to Alexandre Vasseur for providing this very nice test application.
ConsoleApp(HazelcastInstance) - Constructor for class com.hazelcast.console.ConsoleApp
 
contains(E) - Method in interface com.hazelcast.core.IAtomicReference
Checks if the reference contains the value.
containsAsync(E) - Method in interface com.hazelcast.core.IAtomicReference
Checks if the reference contains the value.
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 interface com.hazelcast.core.MultiMap
Returns whether the multimap contains the given key-value pair.
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
Transactional implementation of IMap.containsKey(Object).
containsKey(Object) - Method in interface com.hazelcast.map.QueryCache
 
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 interface com.hazelcast.map.QueryCache
 
Context<K,V> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
convert(Comparable) - Method in interface com.hazelcast.core.TypeConverter
Compares a Comparable typed value to another one.
convert(long, MemoryUnit) - Method in enum com.hazelcast.memory.MemoryUnit
 
convertToEventType(CacheEventType) - Static method in enum com.hazelcast.cache.CacheEventType
Converts a CacheEventType into EventType.
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.
copyFile(File, File, long) - Static method in class com.hazelcast.nio.IOUtil
Copies source file to target and creates the target if necessary.
copyTo(byte[], int) - Method in interface com.hazelcast.nio.serialization.Data
Copies the payload contained in the Data to the destination buffer.
copyToHeapBuffer(ByteBuffer, ByteBuffer) - Static method in class com.hazelcast.nio.IOUtil
 
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 method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation for counting all supplied values.
This aggregation is similar to:
COUNT_DOWN_LATCH_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
countDown() - Method in interface com.hazelcast.core.ICountDownLatch
Decrements the count of the latch, releasing all waiting threads if the count reaches zero.
CountDownLatchConfig - Class in com.hazelcast.config
Contains the configuration for an ICountDownLatch.
CountDownLatchConfig() - Constructor for class com.hazelcast.config.CountDownLatchConfig
Creates a default configured CountDownLatchConfig.
CountDownLatchConfig(String) - Constructor for class com.hazelcast.config.CountDownLatchConfig
Creates a default configured CountDownLatchConfig setting its name to the given name.
CountDownLatchConfig(CountDownLatchConfig) - Constructor for class com.hazelcast.config.CountDownLatchConfig
Creates a CountDownLatchConfig by cloning another one.
CountDownLatchPermission - Class in com.hazelcast.security.permission
 
CountDownLatchPermission(String, String...) - Constructor for class com.hazelcast.security.permission.CountDownLatchPermission
 
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
The constant for the PNCounter CRDTTimestampedLong
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
 
create(String) - Method in interface com.hazelcast.client.spi.ClientProxyFactory
Creates a new client proxy with the given ID
create(int) - Method in interface com.hazelcast.nio.serialization.DataSerializableFactory
Creates an IdentifiedDataSerializable instance using given type ID
create(int) - Method in interface com.hazelcast.nio.serialization.PortableFactory
Creates a Portable instance using given class ID
CREATE - Static variable in class com.hazelcast.security.permission.InstancePermission
 
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
 
createBackupEntryProcessor() - Method in interface com.hazelcast.cache.BackupAwareEntryProcessor
Either creates a new, specialized EntryProcessor to be executed on the backup-partition, or returns
createBeanBuilder(Class) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
createChannelInitializer() - Method in interface com.hazelcast.client.ClientExtension
 
createClientLoginContext(Credentials) - Method in interface com.hazelcast.security.SecurityContext
Creates client LoginContext.
createClientProxyDescriptors() - Method in interface com.hazelcast.client.spi.ClientProxyDescriptorProvider
Return registered clientProxy descriptors
createConcurrentSet() - Method in class com.hazelcast.config.AbstractCacheConfig
 
createDiscoveryStrategyConfigs(ClientConfig) - Static method in class com.hazelcast.client.config.ClientAliasedDiscoveryConfigUtils
Extracts aliased discovery configs from config and creates a list of DiscoveryStrategyConfig out of them.
createDiscoveryStrategyConfigs(JoinConfig) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Extracts aliased discovery configs from config and creates a list of DiscoveryStrategyConfig out of them.
createDiscoveryStrategyConfigs(WanPublisherConfig) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Extracts aliased discovery configs from config and creates a list of DiscoveryStrategyConfig out of them.
createDistributedObject(String) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
createDistributedObject(String) - Method in interface com.hazelcast.spi.RemoteService
Creates a distributed object.
createDistributedObjectsOnCluster(Connection) - Method in class com.hazelcast.client.spi.ProxyManager
 
createFactory() - Method in class com.hazelcast.config.ConfigDataSerializerHook
 
createFactory() - Method in class com.hazelcast.crdt.CRDTDataSerializerHook
 
createHazelcastInstanceClient(C, ClientConnectionManagerFactory) - Method in interface com.hazelcast.client.HazelcastClientFactory
 
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(String, Operation, int) - Method in interface com.hazelcast.spi.OperationService
 
createInvocationBuilder(String, Operation, Address) - Method in interface com.hazelcast.spi.OperationService
 
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
 
createMemberGroups(Collection<? extends Member>) - Method in interface com.hazelcast.partition.membergroup.MemberGroupFactory
 
createMemberGroups(Collection<? extends Member>) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroupFactory
 
createMemberInboundHandlers(TcpIpConnection) - Method in interface com.hazelcast.nio.IOService
 
createMemberInboundHandlers(TcpIpConnection) - Method in class com.hazelcast.nio.NodeIOService
 
createMemberLoginContext(Credentials) - Method in interface com.hazelcast.security.SecurityContext
Creates member LoginContext.
createMemberOutboundHandlers(TcpIpConnection) - Method in interface com.hazelcast.nio.IOService
 
createMemberOutboundHandlers(TcpIpConnection) - Method in class com.hazelcast.nio.NodeIOService
 
createNearCacheManager() - Method in interface com.hazelcast.client.ClientExtension
Creates a NearCacheManager instance to be used by this client.
createOperation() - Method in interface com.hazelcast.spi.OperationFactory
Creates the operation.
createProxy(T) - Method in interface com.hazelcast.client.HazelcastClientFactory
 
createRemoteMerkleTreeView(DataInput) - Static method in class com.hazelcast.wan.merkletree.MerkleTreeUtil
Creates a RemoteMerkleTreeView by reading the hashes of the leaves of a Merkle tree from the provided DataInput
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
Creates a InternalSerializationService instance to be used by this client.
createSerializer() - Method in interface com.hazelcast.nio.serialization.SerializerHook
Creates a new serializer for the serialization type
createServiceProxyFactory(Class<T>) - Method in interface com.hazelcast.client.ClientExtension
Creates a ClientProxyFactory for the supplied service class.
createSocketInterceptor() - Method in interface com.hazelcast.client.ClientExtension
Creates a SocketInterceptor to be used by this client if available, otherwise returns null
createTransactionalObject(String, Transaction) - Method in interface com.hazelcast.spi.TransactionalService
 
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
 

D

Data - Interface in com.hazelcast.nio.serialization
Data is basic unit of serialization.
DATA_MEMBER_SELECTOR - Static variable in class com.hazelcast.cluster.memberselector.MemberSelectors
A MemberSelector instance that selects only data members that own a partition
DataSerializable - Interface in com.hazelcast.nio.serialization
DataSerializable is a serialization method alternative to standard Java serialization.
DataSerializableFactory - Interface in com.hazelcast.nio.serialization
DataSerializableFactory is used to create IdentifiedDataSerializable instances during de-serialization.
dataSize() - Method in interface com.hazelcast.nio.serialization.Data
Returns size of internal binary data in bytes
DataType - Enum in com.hazelcast.nio.serialization
Defines type of the Data: heap or native.
deactivate(Operation) - Static method in class com.hazelcast.spi.OperationAccessor
Marks the supplied operation as "not active".
decompress(byte[]) - Static method in class com.hazelcast.nio.IOUtil
 
decreaseHits(long) - Method in interface com.hazelcast.monitor.LocalRecordStoreStats
Decreases the number of hits of the locally owned entries of this partition.
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
 
decrementAndGetAsync() - Method in interface com.hazelcast.core.IAtomicLong
Atomically decrements the current value by one.
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 default number of backups
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_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_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 value for "cipherAlgorithm" property.
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
Deprecated.
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_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_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_INTERVAL_MILLISECONDS - Static variable in class com.hazelcast.client.config.ClientIcmpPingConfig
Default interval between icmp ping attempts see ClientIcmpPingConfig.intervalMilliseconds
DEFAULT_INVALIDATE_ON_CHANGE - Static variable in class com.hazelcast.config.NearCacheConfig
 
DEFAULT_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_MAX_ATTEMPT - Static variable in class com.hazelcast.client.config.ClientIcmpPingConfig
Default max number of attempts ClientIcmpPingConfig.maxAttempts
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 in bytes
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 in bytes
DEFAULT_PARALLELISM - Static variable in class com.hazelcast.config.HotRestartPersistenceConfig
Default level of parallelism in Hot Restart Persistence.
DEFAULT_PERSIST_WAN_REPLICATED_DATA - Static variable in class com.hazelcast.config.WanConsumerConfig
 
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_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_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 value for "secretKeyFactoryAlgorithm" property.
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_TIMEOUT_MILLIS - Static variable in class com.hazelcast.transaction.TransactionOptions
2 minutes as default timeout value
DEFAULT_TIMEOUT_MILLISECONDS - Static variable in class com.hazelcast.client.config.ClientIcmpPingConfig
Default timeout for icmp detection in millis see ClientIcmpPingConfig.timeoutMilliseconds
DEFAULT_TOPIC_OVERLOAD_POLICY - Static variable in class com.hazelcast.client.config.ClientReliableTopicConfig
The default slow consumer policy.
DEFAULT_TOPIC_OVERLOAD_POLICY - Static variable in class com.hazelcast.config.ReliableTopicConfig
The default slow consumer policy.
DEFAULT_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 for icmp packages ClientIcmpPingConfig.ttl.
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
DefaultGarbageCollectorStats - Class in com.hazelcast.memory
Default implementation of GarbageCollectorStats.
DefaultGarbageCollectorStats() - Constructor for class com.hazelcast.memory.DefaultGarbageCollectorStats
 
DefaultMemberGroup - Class in com.hazelcast.partition.membergroup
 
DefaultMemberGroup() - Constructor for class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
DefaultMemberGroup(Collection<Member>) - Constructor for class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
DefaultMemoryStats - Class in com.hazelcast.memory
Default implementation of MemoryStats.
DefaultMemoryStats() - Constructor for class com.hazelcast.memory.DefaultMemoryStats
 
DefaultObjectNamespace - Class in com.hazelcast.spi
Deprecated.
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.
 
DefaultPartitioningStrategy - Class in com.hazelcast.partition.strategy
A PartitioningStrategy that checks if the key implements PartitionAware.
DefaultPartitioningStrategy() - Constructor for class com.hazelcast.partition.strategy.DefaultPartitioningStrategy
 
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
Transactional implementation of IMap.delete(Object).
delete(File) - Static method in class com.hazelcast.nio.IOUtil
Ensures that the file described by the supplied parameter does not exist after the method returns.
deleteAll(Collection<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.
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.
DenyAllPermissionCollection - Class in com.hazelcast.security.permission
 
DenyAllPermissionCollection() - Constructor for class com.hazelcast.security.permission.DenyAllPermissionCollection
 
deregisterAllListeners(String, String) - Method in interface com.hazelcast.spi.EventService
Deregisters all listeners belonging to the given service and topic.
deregisterListener(String) - Method in interface com.hazelcast.client.spi.ClientListenerService
 
deregisterListener(String) - Method in class com.hazelcast.client.spi.ClientProxy
 
deregisterListener(String, String, Object) - Method in interface com.hazelcast.spi.EventService
Deregisters a listener with the given registration ID.
describeFlags(char) - Method in enum com.hazelcast.nio.Packet.Type
 
destroy() - Method in interface com.hazelcast.cache.HazelcastCacheManager
Destroys the cache manager.
destroy() - Method in interface com.hazelcast.cache.ICache
Closes the cache.
destroy() - Method in class com.hazelcast.client.spi.ClientProxy
 
destroy() - Method in class com.hazelcast.client.spi.ProxyManager
 
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.map.QueryCache
Destroys this cache.
destroy() - Method in interface com.hazelcast.nio.serialization.Serializer
Called when instance is shutting down.
destroy() - Method in interface com.hazelcast.security.ICredentialsFactory
destroy() - Method in interface com.hazelcast.security.IPermissionPolicy
DESTROY - Static variable in class com.hazelcast.security.permission.InstancePermission
 
destroy() - Method in interface com.hazelcast.security.SecurityContext
Destroys SecurityContext and all security elements.
destroy() - Method in class com.hazelcast.spi.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 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
 
destroyDistributedObject(String) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
destroyDistributedObject(String, String) - Method in interface com.hazelcast.spi.ProxyService
 
destroyDistributedObject(String) - Method in interface com.hazelcast.spi.RemoteService
Destroys a distributed object.
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.
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.
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.
DISABLE_STALE_READ_ON_PARTITION_MIGRATION - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
DiscardMergePolicy<V,T extends MergingValue<V>> - Class in com.hazelcast.spi.merge
Merges only entries from the destination data structure and discards all entries from the source data structure.
DiscardMergePolicy() - Constructor for class com.hazelcast.spi.merge.DiscardMergePolicy
 
discoverLocalMetadata() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
 
discoverLocalMetadata() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategy
Returns a map with discovered metadata provided by the runtime environment.
discoverLocalMetadata() - Method in 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 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.
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
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
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 - Interface in com.hazelcast.spi.discovery.integration
The DiscoveryService interface defines the basic entry point into the Discovery SPI implementation.
DiscoveryServiceProvider - Interface in com.hazelcast.spi.discovery.integration
The DiscoveryServiceProvider interface provides the possibility to build DiscoveryServices.
DiscoveryServiceSettings - Class in com.hazelcast.spi.discovery.integration
The DiscoveryServiceSettings class is used to pass the necessary configuration to create a DiscoveryService to the DiscoveryServiceProvider.
DiscoveryServiceSettings() - Constructor for class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
DiscoveryStrategy - Interface in com.hazelcast.spi.discovery
The DiscoveryStrategy itself is the actual implementation to discover nodes based on whatever environment is used to run the Hazelcast cloud.
DiscoveryStrategyConfig - Class in com.hazelcast.config
This configuration class describes a DiscoveryStrategy based on a parsed XML or configured manually using the config API
DiscoveryStrategyConfig(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(E, T) - Method in interface com.hazelcast.spi.EventPublishingService
Notifies the service of a published event.
Disposable - Interface in com.hazelcast.nio
A Disposable is a container of data and/or resources that can be disposed.
dispose() - Method in interface com.hazelcast.nio.Disposable
Disposes this object and releases any data and/or resources associated with it.
dispose() - Method in interface com.hazelcast.scheduledexecutor.IScheduledFuture
Used to destroy the instance of the IScheduledFuture in the scheduled executor.
disposeResult(long) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Disposes the result with the given taskId
distinct() - Static method in class com.hazelcast.aggregation.Aggregators
 
distinct(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
distinctValues() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation for selecting all distinct values.
This aggregation is similar to:
DistributedObject - Interface in com.hazelcast.core
Base interface for all distributed objects.
distributedObject - Variable in class com.hazelcast.core.DistributedObjectEvent
 
distributedObjectCreated(DistributedObjectEvent) - Method in interface com.hazelcast.core.DistributedObjectListener
Invoked when a DistributedObject is created.
distributedObjectDestroyed(DistributedObjectEvent) - Method in interface com.hazelcast.core.DistributedObjectListener
Invoked when a DistributedObject is destroyed.
DistributedObjectDestroyedException - Exception in com.hazelcast.spi.exception
A HazelcastException that indicates that a DistributedObject access was attempted, but the object is destroyed.
DistributedObjectDestroyedException(String) - Constructor for exception com.hazelcast.spi.exception.DistributedObjectDestroyedException
 
DistributedObjectEvent - Class in com.hazelcast.core
DistributedObjectEvent is fired when a DistributedObject is created or destroyed cluster-wide.
DistributedObjectEvent(DistributedObjectEvent.EventType, String, String, DistributedObject) - Constructor for class com.hazelcast.core.DistributedObjectEvent
Constructs a DistributedObject Event.
DistributedObjectEvent.EventType - Enum in com.hazelcast.core
Type of the DistributedObjectEvent.
DistributedObjectListener - Interface in com.hazelcast.core
DistributedObjectListener notifies when a DistributedObject is created or destroyed cluster-wide.
DistributedObjectNamespace - Class in com.hazelcast.spi
Default ObjectNamespace implementation for DistributedObject.
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
Utility class for DistributedObject.
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
 
doGetTransaction() - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
 
domLevel3 - Variable in class com.hazelcast.config.AbstractXmlConfigHelper
 
DONE_RESPONSE - Static variable in class com.hazelcast.spi.CallStatus
Signals that the Operation is done running and that a response is ready to be returned.
DONE_RESPONSE_ORDINAL - Static variable in class com.hazelcast.spi.CallStatus
The ordinal value for a CallStatus.DONE_RESPONSE.
DONE_VOID - Static variable in class com.hazelcast.spi.CallStatus
Signals that the Operation is done running, but no response will be returned.
DONE_VOID_ORDINAL - Static variable in class com.hazelcast.spi.CallStatus
The ordinal value for a CallStatus.DONE_VOID.
doneCallback - Variable in class com.hazelcast.spi.InvocationBuilder
 
doRollback(DefaultTransactionStatus) - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
 
doSetRollbackOnly(DefaultTransactionStatus) - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
 
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_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
Double size in bytes
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:
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:
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:
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:
drainPermits() - Method in interface com.hazelcast.core.ISemaphore
Acquires and returns all permits that are immediately available.
drainTo(InputStream, OutputStream) - Static method in class com.hazelcast.nio.IOUtil
 
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
 
DurableExecutorConfig - Class in com.hazelcast.config
Contains the configuration for an DurableExecutorService.
DurableExecutorConfig() - Constructor for class com.hazelcast.config.DurableExecutorConfig
 
DurableExecutorConfig(String) - Constructor for class com.hazelcast.config.DurableExecutorConfig
 
DurableExecutorConfig(String, int, int, int) - Constructor for class com.hazelcast.config.DurableExecutorConfig
 
DurableExecutorConfig(String, int, int, int, String) - Constructor for class com.hazelcast.config.DurableExecutorConfig
 
DurableExecutorConfig(DurableExecutorConfig) - Constructor for class com.hazelcast.config.DurableExecutorConfig
 
DurableExecutorService - Interface in com.hazelcast.durableexecutor
Durable implementation of ExecutorService.
DurableExecutorServiceFuture<V> - Interface in com.hazelcast.durableexecutor
A Future where one can obtain the task ID for tracking the response.
DurableExecutorServicePermission - Class in com.hazelcast.security.permission
 
DurableExecutorServicePermission(String, String...) - Constructor for class com.hazelcast.security.permission.DurableExecutorServicePermission
 
DurationConfig() - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
DurationConfig(long, TimeUnit) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
DYNAMIC_CONFIG_PRE_JOIN_OP - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 

E

Echo - Class in com.hazelcast.console
Echoes to screen.
Echo() - Constructor for class com.hazelcast.console.Echo
 
Echo(String) - Constructor for class com.hazelcast.console.Echo
 
element() - Method in class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
Returns the current index element Calls to this method won't change state.
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
 
emit(K, V) - Method in interface com.hazelcast.mapreduce.Context
Deprecated.
Emits a key-value pair to the intermediate working space.
ENABLE_JMX - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
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
 
encrypt(String, int) - Method in class com.hazelcast.config.replacer.AbstractPbeReplacer
Encrypts given string with key generated from AbstractPbeReplacer.getPassword() with given iteration count and return the masked value (to be used as the variable).
encrypt(String...) - Static method in class com.hazelcast.config.replacer.EncryptionReplacer
 
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
 
Endpoint - Interface in com.hazelcast.core
Endpoint represents a peer in the cluster.
ensureMember(Address) - Method in class com.hazelcast.spi.CallsPerMember
Makes sure that a list of counters is created for a member.
ensureQuorumPresent(String, QuorumType) - Method in interface com.hazelcast.quorum.QuorumService
Ensures that the quorum with the given name is present.
ENTERPRISE_LICENSE_KEY - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
ENTRY_LISTENER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
EntryAdapter<K,V> - Class in com.hazelcast.core
Adapter for MapListener.
EntryAdapter() - Constructor for class com.hazelcast.core.EntryAdapter
 
entryAdded(EntryEvent) - Method in class com.hazelcast.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 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.
EntryBackupProcessor<K,V> - Interface in com.hazelcast.map
Processes an entry on a backup partition.
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.
EntryEventType - Enum in com.hazelcast.core
Type of entry event.
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 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 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.
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
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
EntryListenerConfigReadOnly(EntryListenerConfig) - Constructor for class com.hazelcast.config.EntryListenerConfigReadOnly
Deprecated.
 
entryLoaded(EntryEvent<K, V>) - Method in interface com.hazelcast.map.listener.EntryLoadedListener
Invoked upon load of an entry.
EntryLoadedListener<K,V> - Interface in com.hazelcast.map.listener
Invoked upon load of an entry.
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
 
EntryProcessor<K,V> - Interface in com.hazelcast.map
An EntryProcessor passes you a Map.Entry.
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 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.
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 interface com.hazelcast.map.QueryCache
 
entrySet(Predicate) - Method in interface com.hazelcast.map.QueryCache
 
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 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.
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.
equals(Object) - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
 
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.spi.ClientProxy
 
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.MerkleTreeConfig
 
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.hotrestart.BackupTaskStatus
 
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.memory.MemorySize
 
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.partition.membergroup.DefaultMemberGroup
 
equals(Object) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
equals(Object) - Method in class com.hazelcast.query.PartitionPredicate
 
equals(Object) - Method in class com.hazelcast.query.SqlPredicate
 
equals(Object) - Method in class com.hazelcast.query.TruePredicate
 
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.PartitionMigrationEvent
 
equals(Object) - Method in class com.hazelcast.version.MemberVersion
 
equals(Object) - Method in class com.hazelcast.version.Version
 
estimate() - Method in interface com.hazelcast.cardinality.CardinalityEstimator
Estimates the cardinality of the aggregation so far.
estimateAsync() - Method in interface com.hazelcast.cardinality.CardinalityEstimator
Estimates the cardinality of the aggregation so far.
EurekaConfig - Class in com.hazelcast.config
Configuration for the Eureka Discovery Strategy.
EurekaConfig() - Constructor for class com.hazelcast.config.EurekaConfig
 
eval(Object) - Method in interface com.hazelcast.spi.EventFilter
Returns true if the event matches this filter.
evaluate(Key) - Method in interface com.hazelcast.mapreduce.KeyPredicate
Deprecated.
This method evaluates whether or not to select a key.
EVENT_JOURNAL_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
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
The capacity of the EventServiceImpl executor.
EVENT_QUEUE_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The timeout for offering an event to the event executor for processing.
EVENT_SYNC_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
Number of threads for the EventServiceImpl executor.
EVENT_TYPE - Static variable in class com.hazelcast.map.EventLostEvent
Event type ID.
EventFilter - Interface in com.hazelcast.spi
A predicate that can filter out events.
EventHandler<E> - Interface in com.hazelcast.client.spi
Base interface for all client EventHandlers.
EventJournalCacheEvent<K,V> - Interface in com.hazelcast.cache.journal
The event for the cache event journal.
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
EventJournalMapEvent<K,V> - Interface in com.hazelcast.map.journal
The event for the map event journal.
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.
EventPublishingService<E,T> - Interface in com.hazelcast.spi
A service for publishing events.
EventRegistration - Interface in com.hazelcast.spi
The result of a Event Registration.
EventService - Interface in com.hazelcast.spi
Component responsible for handling events like topic events or map.listener events.
evict(K) - Method in interface com.hazelcast.core.IMap
Evicts the specified key from this map.
evict(Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
 
evictAll() - Method in interface com.hazelcast.core.IMap
Evicts all keys from this map except the locked ones.
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
EvictionConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
EvictionConfigReadOnly(EvictionConfig) - Constructor for class com.hazelcast.config.EvictionConfigReadOnly
Deprecated.
 
evictionPolicy - Variable in class com.hazelcast.config.EvictionConfig
 
EvictionPolicy - Enum in com.hazelcast.config
Eviction Policy enum.
ExceptionAction - Enum in com.hazelcast.spi
The possible actions that can be taken when a certain exception is thrown.
execute(Runnable, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
Executes a task on a randomly selected member.
execute(String, Runnable) - Method in interface com.hazelcast.spi.ExecutionService
 
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.
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.
executeEventCallback(Runnable) - Method in interface com.hazelcast.spi.EventService
Executes an event callback on a random event thread.
executeOnAllMembers(Runnable) - Method in interface com.hazelcast.core.IExecutorService
Executes a task on all of the known cluster members.
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.
executeOnKey(K, EntryProcessor) - Method in interface com.hazelcast.core.IMap
Applies the user defined EntryProcessor to the entry mapped by the key.
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.
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.
executeOnMember(Runnable, Member) - Method in interface com.hazelcast.core.IExecutorService
Executes a task on the specified member.
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.
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 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(TransactionOptions, TransactionalTask<T>) - Method in interface com.hazelcast.transaction.TransactionManagerService
 
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
 
ExecutionService - Interface in com.hazelcast.spi
A Service responsible for providing access to 'system' executors and customer executors.
executionService - Variable in class com.hazelcast.spi.Offload
 
EXECUTOR_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
ExecutorConfig - Class in com.hazelcast.config
Contains the configuration for an IExecutorService.
ExecutorConfig() - Constructor for class com.hazelcast.config.ExecutorConfig
 
ExecutorConfig(String) - Constructor for class com.hazelcast.config.ExecutorConfig
 
ExecutorConfig(String, int) - Constructor for class com.hazelcast.config.ExecutorConfig
 
ExecutorConfig(ExecutorConfig) - Constructor for class com.hazelcast.config.ExecutorConfig
 
ExecutorConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
ExecutorConfigReadOnly(ExecutorConfig) - Constructor for class com.hazelcast.config.ExecutorConfigReadOnly
Deprecated.
 
ExecutorServicePermission - Class in com.hazelcast.security.permission
 
ExecutorServicePermission(String, String...) - Constructor for class com.hazelcast.security.permission.ExecutorServicePermission
 
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
 
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
 
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.
extractInt(long, boolean) - Static method in class com.hazelcast.nio.Bits
 
extractShort(int, boolean) - Static method in class com.hazelcast.nio.Bits
 

F

F_ID - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.crdt.CRDTDataSerializerHook
The CRDT (de)serializer factory ID
FAIL_ON_INDETERMINATE_OPERATION_STATE - Static variable in class com.hazelcast.spi.properties.GroupProperty
When this configuration is enabled, if an operation has sync backups and acks are not received from backup replicas in time, or the member which owns primary replica of the target partition leaves the cluster, then the invocation fails with IndeterminateOperationStateException.
failOnIndeterminateOperationState - Variable in class com.hazelcast.spi.InvocationBuilder
 
FieldDefinition - Interface in com.hazelcast.nio.serialization
FieldDefinition defines name, type, index of a field
fieldsToString() - Method in class com.hazelcast.config.CollectionConfig
Returns field names with values as concatenated String so it can be used in child classes' toString() methods.
FieldType - Enum in com.hazelcast.nio.serialization
 
FileSystemXmlConfig - Class in com.hazelcast.config
A Config which includes functionality for loading itself from a XML configuration file.
FileSystemXmlConfig(String) - Constructor for class com.hazelcast.config.FileSystemXmlConfig
Creates a Config based on a Hazelcast xml file and uses the System.properties to resolve variables in the XML.
FileSystemXmlConfig(String, Properties) - Constructor for class com.hazelcast.config.FileSystemXmlConfig
Creates a Config based on a Hazelcast XML file.
FileSystemXmlConfig(File) - Constructor for class com.hazelcast.config.FileSystemXmlConfig
Creates a Config based on a Hazelcast xml file and uses the System.properties to resolve variables in the XML.
FileSystemXmlConfig(File, Properties) - Constructor for class com.hazelcast.config.FileSystemXmlConfig
Creates a Config based on a Hazelcast XML file.
fillAttributesForAliasedDiscoveryStrategy(AliasedDiscoveryConfig, Node, BeanDefinitionBuilder, String) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
fillAttributeValues(Node, BeanDefinitionBuilder, String...) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
fillAttributeValues(Node, BeanDefinitionBuilder, Collection<String>) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
fillDataSerializableFactories(Node, SerializationConfig) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
fillJavaSerializationFilter(Node, SerializationConfig) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
fillNativeMemoryConfig(Node, NativeMemoryConfig) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
fillPortableFactories(Node, SerializationConfig) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
fillProperties(Node, Properties) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
fillProperties(Node, Map<String, Comparable>) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
fillSerializers(Node, SerializationConfig) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
fillValues(Node, BeanDefinitionBuilder, String...) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
filter(String) - Method in interface com.hazelcast.nio.ClassNameFilter
filter(String) - Method in class com.hazelcast.nio.SerializationClassNameFilter
Throws SecurityException if the given class name appears on the blacklist or does not appear a whitelist.
filter(QueryContext) - Method in interface com.hazelcast.query.IndexAwarePredicate
Produces a filtered entry set by utilizing the indexes available while executing the query in the given query context.
filter(QueryContext) - Method in class com.hazelcast.query.PagingPredicate
Used if inner predicate is instanceof IndexAwarePredicate for filtering.
filter(QueryContext) - Method in class com.hazelcast.query.PredicateBuilder
 
filter(QueryContext) - Method in class com.hazelcast.query.SqlPredicate
 
finalizeChunk() - Method in class com.hazelcast.mapreduce.Combiner
Deprecated.
Creates a chunk of ValueOut to be sent to the Reducer for the according key.
finalizeCombine() - Method in class com.hazelcast.mapreduce.Combiner
Deprecated.
This method is called after the mapping phase on the local node is over.
finalized(Context<KeyOut, ValueOut>) - Method in interface com.hazelcast.mapreduce.LifecycleMapper
Deprecated.
This method is called after the Mapper.map(Object, Object, Context) method is executed for every value and can be used to finalize the internal state of the mapper or to emit a special value.
finalized(Context<KeyOut, ValueOut>) - Method in class com.hazelcast.mapreduce.LifecycleMapperAdapter
Deprecated.
This method is called after the Mapper.map(Object, Object, Context) method is executed for every value and can be used to finalize the internal state of the mapper or to emit a special value.
finalizeReduce() - Method in class com.hazelcast.mapreduce.Reducer
Deprecated.
finalizeReduce is called as last step for a reducing phase per key.
findAtomicLongConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only AtomicLong configuration for the given name.
findAtomicReferenceConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only AtomicReference configuration for the given name.
findCacheConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only CacheSimpleConfig configuration for the given name.
findCacheConfigOrNull(String) - Method in class com.hazelcast.config.Config
Returns the cache config with the given name or null if there is none.
findCacheEventJournalConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only cache EventJournal configuration for the given name.
findCardinalityEstimatorConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only CardinalityEstimator configuration for the given name.
findCountDownLatchConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only CountDownLatch configuration for the given name.
findDurableExecutorConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only durable executor configuration for the given name.
findExecutorConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only executor configuration for the given name.
findFlakeIdGeneratorConfig(String) - Method in class com.hazelcast.client.config.ClientConfig
Returns a ClientFlakeIdGeneratorConfig configuration for the given flake ID generator name.
findFlakeIdGeneratorConfig(String) - Method in class com.hazelcast.config.Config
Returns a FlakeIdGeneratorConfig configuration for the given flake ID generator name.
findJobTrackerConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only JobTracker configuration for the given name.
findListConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only IList configuration for the given name.
findLockConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only ILock configuration for the given name.
findMapConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only IMap configuration for the given name.
findMapEventJournalConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only map EventJournal configuration for the given name.
findMapMerkleTreeConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only map MerkleTreeConfig for the given name.
findMultiMapConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only MultiMap configuration for the given name.
findNextAddressToSendCreateRequest() - Method in class com.hazelcast.client.spi.ProxyManager
 
findPNCounterConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only PNCounterConfig configuration for the given name.
findQueueConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only IQueue configuration for the given name.
findQuorumConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only split-brain protection configuration for the given name.
findReliableTopicConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only reliable topic configuration for the given name.
findReplicatedMapConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only ReplicatedMap configuration for the given name.
findRingbufferConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only Ringbuffer configuration for the given name.
findScheduledExecutorConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only scheduled executor configuration for the given name.
findSemaphoreConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only ISemaphore configuration for the given name.
findSetConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only ISet configuration for the given name.
findTopicConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only ITopic configuration for the given name.
fine(String) - Method in class com.hazelcast.logging.AbstractLogger
 
fine(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
fine(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
fine(String) - Method in interface com.hazelcast.logging.ILogger
Logs a message at the Level.FINE level.
fine(Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a throwable at the Level.FINE level.
fine(String, Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a message with an associated throwable at the Level.FINE level.
finest(String) - Method in class com.hazelcast.logging.AbstractLogger
 
finest(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
finest(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
finest(String) - Method in interface com.hazelcast.logging.ILogger
Logs a message at the Level.FINEST level.
finest(Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a throwable at the Level.FINEST level.
finest(String, Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a message with an associated throwable at the Level.FINEST level.
fixedPointSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
fixedPointSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
FLAG_JET_FLOW_CONTROL - Static variable in class com.hazelcast.nio.Packet
Marks a Jet packet as Flow control
FLAG_OP_CONTROL - Static variable in class com.hazelcast.nio.Packet
Marks an Operation packet as Operation control (like invocation-heartbeats)
FLAG_OP_RESPONSE - Static variable in class com.hazelcast.nio.Packet
Marks an Operation packet as Response
FLAG_URGENT - Static variable in class com.hazelcast.nio.Packet
Marks the packet as Urgent
FLAKE_ID_GENERATOR_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
FlakeIdGenerator - Interface in com.hazelcast.flakeidgen
A cluster-wide unique ID generator.
FlakeIdGeneratorConfig - Class in com.hazelcast.config
The FlakeIdGeneratorConfig contains the configuration for the member regarding Flake ID Generator.
FlakeIdGeneratorConfig(String) - Constructor for class com.hazelcast.config.FlakeIdGeneratorConfig
 
FlakeIdGeneratorConfig(FlakeIdGeneratorConfig) - Constructor for class com.hazelcast.config.FlakeIdGeneratorConfig
Copy-constructor
FlakeIdGeneratorConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
FlakeIdGeneratorPermission - Class in com.hazelcast.security.permission
 
FlakeIdGeneratorPermission(String, String...) - Constructor for class com.hazelcast.security.permission.FlakeIdGeneratorPermission
 
FLOAT_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
FLOAT_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
FLOAT_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
Float size in bytes
floatingPointSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
floatingPointSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
flush() - Method in interface com.hazelcast.core.IMap
If this map has a MapStore, this method flushes all the local dirty entries.
footprint() - Method in class com.hazelcast.wan.merkletree.ArrayMerkleTree
 
footprint() - Method in interface com.hazelcast.wan.merkletree.MerkleTree
Returns the memory footprint of Merkle Tree in bytes
forceLocalMemberToBeSafe(long, TimeUnit) - Method in interface com.hazelcast.core.PartitionService
Force the local member to be safe by checking and syncing partitions owned by the local member with at least one of the backups.
forceStartBeforeJoin() - Method in interface com.hazelcast.hotrestart.InternalHotRestartService
Executes force-start process, resets local hot restart data and member gets a new UUID.
forceStartBeforeJoin() - Method in class com.hazelcast.hotrestart.NoopInternalHotRestartService
 
forceUnlock() - Method in interface com.hazelcast.core.ILock
Releases the lock regardless of the lock owner.
forceUnlock(K) - Method in interface com.hazelcast.core.IMap
Releases the lock for the specified key regardless of the lock owner.
forceUnlock(K) - Method in interface com.hazelcast.core.MultiMap
Releases the lock for the specified key regardless of the lock owner.
forEachKeyOfNode(int, Consumer<Object>) - Method in class com.hazelcast.wan.merkletree.ArrayMerkleTree
 
forEachKeyOfNode(int, Consumer<Object>) - Method in interface com.hazelcast.wan.merkletree.MerkleTree
Performs the given action for each key of the specified node until all elements have been processed or the action throws an exception.
FragmentedMigrationAwareService - Interface in com.hazelcast.spi
FragmentedMigrationAwareService is an extension to the MigrationAwareService which allows migration/replication of partition replicas in smaller fragments.
freePhysicalMemory() - Static method in class com.hazelcast.memory.MemoryStatsSupport
Returns the amount of physical memory that is available on the system in bytes or -1 if not available.
freeSwapSpace() - Static method in class com.hazelcast.memory.MemoryStatsSupport
Returns the amount of free swap space in bytes or -1 if not available.
fromFlags(int) - Static method in enum com.hazelcast.nio.Packet.Type
 
fromKeyPredicate(KeyPredicate<KeyIn>) - Static method in class com.hazelcast.mapreduce.aggregation.Supplier
Deprecated.
The predefined Supplier selects values using the given KeyPredicate and does not perform any kind of data transformation.
fromKeyPredicate(KeyPredicate<KeyIn>, Supplier<KeyIn, ValueIn, ValueOut>) - Static method in class com.hazelcast.mapreduce.aggregation.Supplier
Deprecated.
The predefined Supplier selects values using the given KeyPredicate and chains the filtered value to the given Supplier which might perform data transformation.
fromList(IList<? extends V>) - Static method in class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
A helper method to build a KeyValueSource implementation based on the specified IList.
The key returned by this KeyValueSource implementation is ALWAYS the name of the list itself, whereas the value are the entries of the list, one by one.
fromMap(IMap<? super K, ? extends V>) - Static method in class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
A helper method to build a KeyValueSource implementation based on the specified IMap
fromMaxSizePolicy(EvictionConfig.MaxSizePolicy) - Static method in enum com.hazelcast.config.CacheEvictionConfig.CacheMaxSizePolicy
Deprecated.
 
fromMultiMap(MultiMap<? super K, ? extends V>) - Static method in class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
A helper method to build a KeyValueSource implementation based on the specified MultiMap
fromPredicate(Predicate<KeyIn, ValueIn>) - Static method in class com.hazelcast.mapreduce.aggregation.Supplier
Deprecated.
The predefined Supplier selects values using the given Predicate and does not perform any kind of data transformation.
fromPredicate(Predicate<KeyIn, ValueIn>, Supplier<KeyIn, ValueIn, ValueOut>) - Static method in class com.hazelcast.mapreduce.aggregation.Supplier
Deprecated.
The predefined Supplier selects values using the given Predicate and chains the filtered value to the given Supplier which might perform data transformation.
fromSet(ISet<? extends V>) - Static method in class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
A helper method to build a KeyValueSource implementation based on the specified ISet.
The key returned by this KeyValueSource implementation is ALWAYS the name of the set itself, whereas the value are the entries of the set, one by one.
fromStoreValue(Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
 

G

GarbageCollectorStats - Interface in com.hazelcast.memory
Garbage collector statistics for the JVM which current HazelcastInstance belongs to.
GcpConfig - Class in com.hazelcast.config
Configuration for the GCP Discovery Strategy.
GcpConfig() - Constructor for class com.hazelcast.config.GcpConfig
 
GCStatsSupport - Class in com.hazelcast.memory
Used to gather garbage collection statistics.
generate(ClientConfig) - Static method in class com.hazelcast.client.config.ClientConfigXmlGenerator
Convenience for ClientConfigXmlGenerator.generate(ClientConfig, int), which generates the xml without any formatting.
generate(ClientConfig, int) - Static method in class com.hazelcast.client.config.ClientConfigXmlGenerator
Transforms the given ClientConfig to xml string formatting the output with given indent, -1 means no formatting.
generate(Config) - Method in class com.hazelcast.config.ConfigXmlGenerator
Generates the XML string based on some Config.
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.
get(K, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Retrieves the mapped value of the given key using a custom ExpiryPolicy.
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
Transactional implementation of IMap.get(Object).
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(Object) - Method in interface com.hazelcast.map.QueryCache
 
get(byte) - Static method in enum com.hazelcast.nio.serialization.FieldType
 
get(String) - Method in class com.hazelcast.query.EntryObject
 
get(int) - Method in interface com.hazelcast.ringbuffer.ReadResultSet
Gets the item at the given index.
get(int) - Method in interface com.hazelcast.security.Parameters
 
get(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
 
getAccessHit() - Method in interface com.hazelcast.cache.CacheEntryView
Gets the count of how many time this cache entry has been accessed.
getAccessKey() - Method in class com.hazelcast.config.AwsConfig
getAcknowledgeType() - Method in class com.hazelcast.wan.WanReplicationEvent
 
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
 
getActiveConnectionCount() - Method in interface com.hazelcast.nio.ConnectionManager
Gets the number of active connections.
getActiveConnections() - Method in interface com.hazelcast.client.connection.ClientConnectionManager
 
getActivePublisherName() - Method in interface com.hazelcast.monitor.WanSyncState
 
getActiveWanConfigName() - Method in interface com.hazelcast.monitor.WanSyncState
 
getAddress() - Method in interface com.hazelcast.core.Member
Returns the Address of this Member.
getAddress() - Method in interface com.hazelcast.monitor.MemberState
 
getAddress() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
Returns the address of the member the task is associated with.
getAddresses() - Method in class com.hazelcast.client.config.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
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<K>) - Method in interface com.hazelcast.core.IMap
Returns the entries for the given keys.
getAll(Set<K>) - Method in interface com.hazelcast.map.QueryCache
 
getAllDiscoveryConfigs() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
getAllDistributedObjects() - Method in interface com.hazelcast.spi.ProxyService
 
getAllHazelcastClients() - Static method in class com.hazelcast.client.HazelcastClient
Gets an immutable collection of all client HazelcastInstances created in this JVM.
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() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Gets all active/running HazelcastOSGiInstances on the owner bundle.
getAllInterfaces(Class<?>) - Static method in class com.hazelcast.nio.ClassLoaderUtil
 
getAllKeys() - Method in class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
If KeyValueSource.isAllKeysSupported() returns true, a call to this method returns all clusterwide available keys.
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().
getAllocatorType() - Method in class com.hazelcast.config.NativeMemoryConfig
Returns the NativeMemoryConfig.MemoryAllocatorType to be used while allocating native memory.
getAllScheduledFutures() - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Fetches and returns all scheduled (not disposed yet) futures from all members in the cluster.
getAllServiceNamespaces(PartitionReplicationEvent) - Method in interface com.hazelcast.spi.FragmentedMigrationAwareService
Returns all known namespaces for given replication event.
getAllTextConnections() - Method in interface com.hazelcast.nio.ConnectionManager
Gets the number of text connections (rest/memcache)
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 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
 
getAndAddAsync(long) - Method in interface com.hazelcast.core.IAtomicLong
Atomically adds the given value to the current value.
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 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.
getAndDecrement() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Decrements by one the current value.
getAndDecrement() - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
 
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
 
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.
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.
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.
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 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.
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.
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
 
getAsReadOnly() - Method in class com.hazelcast.config.AtomicLongConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.AtomicReferenceConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.CacheConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.CacheEvictionConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.CacheSimpleConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.CollectionConfig
 
getAsReadOnly() - Method in class com.hazelcast.config.CountDownLatchConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.DiscoveryConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.EntryListenerConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.EvictionConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.ExecutorConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.ItemListenerConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.JobTrackerConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.ListConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.ListenerConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.LockConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.MapAttributeConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.MapConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.MapIndexConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.MapStoreConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.MaxSizeConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.MergePolicyConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.MultiMapConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.NearCacheConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.PartitioningStrategyConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.PredicateConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.QueryCacheConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.QueueConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.QueueStoreConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.ReliableTopicConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.ReplicatedMapConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.RingbufferConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.RingbufferStoreConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.SemaphoreConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.SetConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.TopicConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.WanReplicationRef
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
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 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.
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 interface com.hazelcast.spi.BackupAwareOperation
The asynchronous backup count.
getAtomicLong(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns a cluster-wide atomic long.
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.
getAtomicLongConfigs() - Method in class com.hazelcast.config.Config
Returns the map of AtomicLong configurations, mapped by config name.
getAtomicNumber() - Method in class com.hazelcast.console.ConsoleApp
 
getAtomicReference(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns a cluster-wide atomic reference.
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.
getAtomicReferenceConfigs() - Method in class com.hazelcast.config.Config
Returns the map of AtomicReference configurations, mapped by config name.
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() - Method in class com.hazelcast.query.PredicateBuilder
 
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.
getAverageGetTime() - Method in interface com.hazelcast.cache.CacheStatistics
The mean time to execute gets.
getAverageGetTime() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the mean time to execute gets on the cache.
getAverageHitLatency() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the average hit latency (in nanoseconds) for the index.
getAverageHitSelectivity() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the average selectivity of the hits served by the index.
getAveragePutTime() - Method in interface com.hazelcast.cache.CacheStatistics
The mean time to execute puts.
getAveragePutTime() - Method in 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 interface com.hazelcast.monitor.LocalCacheStats
Returns the mean time to execute removes on the cache.
getAvgAge() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns the average age of the items in this member.
getAwsConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Returns the current ClientAwsConfig.
getAwsConfig() - Method in class com.hazelcast.config.JoinConfig
 
getAwsConfig() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the AwsConfig used by the discovery mechanism for this WAN publisher.
getAzureConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Returns the current AzureConfig.
getAzureConfig() - Method in class com.hazelcast.config.JoinConfig
 
getAzureConfig() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the AzureConfig used by the discovery mechanism for this WAN publisher.
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 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.
getBackupDirectory() - Method in interface com.hazelcast.hotrestart.HotRestartService
Returns the hot restart backup directory.
getBackupDirectory() - Method in class com.hazelcast.hotrestart.NoOpHotRestartService
 
getBackupDirectory() - Method in interface com.hazelcast.monitor.HotRestartState
 
getBackupEntryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the number of backup entries hold by this member.
getBackupEntryMemoryCost() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns memory cost (number of bytes) of backup entries in this member.
getBackupItemCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns the number of backup items in this member.
getBackupOperation() - Method in interface com.hazelcast.spi.BackupAwareOperation
Creates the BackupOperation responsible for making the backup.
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).
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
 
getBatchCount() - Method in interface com.hazelcast.monitor.LocalFlakeIdGeneratorStats
The average batch size can be calculated by dividing LocalFlakeIdGeneratorStats.getIdCount() by getBatchCount().
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.
getBindAddress() - Method in interface com.hazelcast.spi.MemberAddressProvider
What address should Hazelcast bind to.
getBlacklist() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
getBlacklistedPrefixes() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Return currently configured blacklist prefixes.
getBoolean(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured boolean value of a HazelcastProperty.
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.
getBooleanValue(String) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
 
getBufferSize() - Method in class com.hazelcast.client.config.SocketOptions
Gets the SO_SNDBUF and SO_RCVBUF options to the specified value in KB
getBufferSize() - Method in class com.hazelcast.config.QueryCacheConfig
Returns the maximum number of events which can be stored in a buffer of partition.
getById(byte) - Static method in enum com.hazelcast.config.ConsistencyCheckStrategy
Returns the ConsistencyCheckStrategy for the given ID.
getById(int) - Static method in enum com.hazelcast.config.WanAcknowledgeType
Returns the WanAcknowledgeType for the given ID.
getById(int) - Static method in enum com.hazelcast.ringbuffer.OverflowPolicy
Returns the OverflowPolicy for the given ID.
getByStatus(int) - Static method in enum com.hazelcast.wan.WanSyncStatus
 
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.
getByteOrder() - Method in class com.hazelcast.config.SerializationConfig
Note that result of useNativeByteOrder is not reflected to return value of this method.
getByteOrder() - Method in interface com.hazelcast.nio.ObjectDataInput
 
getByteOrder() - Method in interface com.hazelcast.nio.ObjectDataOutput
 
getByType(int) - Static method in enum com.hazelcast.cache.CacheEventType
 
getByType(byte) - Static method in enum com.hazelcast.config.WanPublisherState
Returns the WanPublisherState as an enum.
getByType(int) - Static method in enum com.hazelcast.config.WANQueueFullBehavior
Returns the WANQueueFullBehavior as an enum.
getByType(int) - Static method in enum com.hazelcast.core.EntryEventType
 
getByType(int) - Static method in enum com.hazelcast.core.ItemEventType
 
getByValue(int) - Static method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
 
getCache(String) - Method in interface com.hazelcast.core.ICacheManager
Returns the cache instance with the specified prefixed cache name.
getCache(String) - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
 
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.
getCacheConfigs() - Method in class com.hazelcast.config.Config
Returns the map of cache configurations, mapped by config name.
getCacheDeserializedValues() - Method in class com.hazelcast.config.MapConfig
Get current value cache settings
getCacheEntryEventFilterFactory() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
getCacheEntryListenerConfigurations() - Method in class com.hazelcast.config.AbstractCacheConfig
 
getCacheEntryListenerConfigurations() - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
getCacheEntryListenerFactory() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
getCacheEntryListeners() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets a list of CacheSimpleEntryListenerConfig from this ICache.
getCacheEntryListeners() - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
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.
getCacheEventJournalConfigs() - Method in class com.hazelcast.config.Config
Returns the map of cache event journal configurations, mapped by config name.
getCacheEvictions() - Method in interface com.hazelcast.cache.CacheStatistics
The total number of evictions from the cache.
getCacheEvictions() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the number of evictions on the cache.
getCacheGets() - Method in interface com.hazelcast.cache.CacheStatistics
The total number of requests to the cache.
getCacheGets() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the number of gets on the cache.
getCacheHitPercentage() - Method in interface com.hazelcast.cache.CacheStatistics
This is a measure of cache efficiency.
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 interface com.hazelcast.monitor.LocalCacheStats
Returns the number of hits (successful get operations) on the cache.
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() - Method in interface com.hazelcast.core.HazelcastInstance
Obtain the ICacheManager that provides access to JSR-107 (JCache) caches configured on a Hazelcast cluster.
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 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 interface com.hazelcast.monitor.LocalCacheStats
Returns the percentage of missed cache accesses on the cache.
getCacheName() - Method in class com.hazelcast.config.EventJournalConfig
Returns the cache name to which this config applies.
getCacheNames() - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
 
getCacheNameWithPrefix(String) - Method in interface com.hazelcast.cache.HazelcastCacheManager
Gets the cache name by adding the manager prefix.
getCachePuts() - Method in interface com.hazelcast.cache.CacheStatistics
The total number of puts to the cache.
getCachePuts() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the number of puts to the queue.
getCacheRemovals() - Method in interface com.hazelcast.cache.CacheStatistics
The total number of removals from the cache.
getCacheRemovals() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the number of removals from the queue.
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.
getCallerAddress() - Method in class com.hazelcast.spi.Operation
 
getCallerUuid() - Method in class com.hazelcast.spi.Operation
 
getCallId() - Method in class com.hazelcast.spi.Operation
Gets the call ID of this operation.
getCallTimeout() - Method in class com.hazelcast.spi.InvocationBuilder
 
getCallTimeout() - Method in class com.hazelcast.spi.Operation
Gets the call timeout in milliseconds.
getCancelledTaskCount() - Method in 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.spi.merge.RingbufferMergeData
Returns the capacity of this ringbuffer.
getCardinalityEstimator(String) - Method in interface com.hazelcast.core.HazelcastInstance
Obtain a CardinalityEstimator with the given name.
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.
getCardinalityEstimatorConfigs() - Method in class com.hazelcast.config.Config
Returns the map of cardinality estimator configurations, mapped by config name.
getChunkSize() - Method in class com.hazelcast.config.JobTrackerConfig
Gets the number of emitted values before a chunk is send to the reducers.
getClassCacheMode() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Return the current ClassCacheMode
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 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.security.UsernamePasswordCredentials
 
getClassLoader() - Method in class com.hazelcast.client.config.ClientConfig
Gets the classLoader
getClassLoader() - Method in class com.hazelcast.config.Config
Returns the class-loader that will be used in serialization.
getClassLoader() - Method in interface com.hazelcast.nio.ObjectDataInput
Returns class loader that internally used for objects.
getClassName() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
 
getClassName() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
getClassName() - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
getClassName() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
getClassName() - Method in class com.hazelcast.config.GlobalSerializerConfig
 
getClassName() - Method in class com.hazelcast.config.ListenerConfig
Returns the name of the class of the EventListener.
getClassName() - Method in class com.hazelcast.config.LoginModuleConfig
 
getClassName() - Method in class com.hazelcast.config.MapStoreConfig
Returns the name of the MapStore implementation class
getClassName() - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
getClassName() - Method in class com.hazelcast.config.PermissionPolicyConfig
 
getClassName() - Method in class com.hazelcast.config.PredicateConfig
Returns the name of the class of the Predicate.
getClassName() - Method in class com.hazelcast.config.QueueStoreConfig
 
getClassName() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
getClassName() - Method in class com.hazelcast.config.SecurityInterceptorConfig
 
getClassName() - Method in class com.hazelcast.config.SerializerConfig
Returns the class name of the serializer implementation.
getClassName() - Method in class com.hazelcast.config.ServiceConfig
 
getClassName() - Method in class com.hazelcast.config.SocketInterceptorConfig
Returns the name of the SocketInterceptor implementation class.
getClassName() - Method in class com.hazelcast.config.WanConsumerConfig
Returns the fully qualified class name of the class implementing WanReplicationConsumer.
getClassName() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the name of the class implementing the WanReplicationEndpoint.
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() - Method in interface com.hazelcast.nio.serialization.VersionedPortable
Returns version for this Portable class
getClient() - Method in class com.hazelcast.client.spi.ClientProxy
 
getClient() - Method in interface com.hazelcast.client.spi.ClientTransactionContext
 
getClientBlockUnmappedActions() - Method in class com.hazelcast.config.SecurityConfig
 
getClientConfig() - Method in class com.hazelcast.client.spi.ClientContext
 
getClientEngine() - Method in interface com.hazelcast.nio.IOService
 
getClientEngine() - Method in class com.hazelcast.nio.NodeIOService
 
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
 
getClientPermissionConfigs() - Method in class com.hazelcast.config.SecurityConfig
 
getClientPermissionConfigs() - Method in interface com.hazelcast.security.SecurityService
Returns latest client permission configuration.
getClientPolicyConfig() - Method in class com.hazelcast.config.SecurityConfig
 
getClientProxyClass() - Method in interface com.hazelcast.client.spi.ClientProxyDescriptor
 
getClientProxyFactory(String) - Method in class com.hazelcast.client.spi.ProxyManager
 
getClients() - Method in interface com.hazelcast.monitor.MemberState
 
getClientService() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the client service of this Hazelcast instance.
getClientType() - Method in interface com.hazelcast.core.Client
Returns the type of this client.
getCloseCause() - Method in interface com.hazelcast.nio.Connection
Gets the cause this Connection was closed.
getCloseReason() - Method in interface com.hazelcast.nio.Connection
Gets the reason this Connection was closed.
getCloudConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
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.
getClusterDataRecoveryPolicy() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Returns the policy to be used when the cluster is started
getClusterHotRestartStatus() - Method in interface com.hazelcast.monitor.MemberState
 
getClusterService() - Method in class com.hazelcast.client.spi.ClientContext
 
getClusterService() - Method in interface com.hazelcast.spi.NodeEngine
Gets the ClusterService.
getClusterState() - Method in interface com.hazelcast.core.Cluster
Returns the state of the cluster.
getClusterState() - Method in interface com.hazelcast.monitor.NodeState
 
getClusterTime() - Method in interface com.hazelcast.client.spi.ClientClusterService
Returns the cluster-time.
getClusterTime() - Method in interface com.hazelcast.core.Cluster
Returns the cluster-wide time in milliseconds.
getClusterVersion() - Method in interface com.hazelcast.core.Cluster
The cluster version indicates the operating version of the cluster.
getClusterVersion() - Method in interface com.hazelcast.monitor.NodeState
 
getCollator() - Method in interface com.hazelcast.mapreduce.aggregation.Aggregation
Deprecated.
Returns the Collator implementation used in this aggregation.
getCombinerFactory() - Method in interface com.hazelcast.mapreduce.aggregation.Aggregation
Deprecated.
Returns the CombinerFactory for this aggregation to pre-reduce values on mapping nodes.
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.
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.
getComparator() - Method in class com.hazelcast.config.EvictionConfig
Returns the instance of the configured EvictionPolicyComparator implementation.
getComparator() - Method in class com.hazelcast.query.PagingPredicate
 
getComparatorClassName() - Method in class com.hazelcast.config.EvictionConfig
Returns the class name of the configured EvictionPolicyComparator implementation.
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
 
getCompletedTaskCount() - Method in interface com.hazelcast.monitor.LocalExecutorStats
Returns the number of completed operations on the executor service.
getConcurrencyLevel() - Method in class com.hazelcast.config.ReplicatedMapConfig
Deprecated.
new implementation doesn't use mutexes
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 interface com.hazelcast.spi.NodeEngine
Returns the Config that was used to create the HazelcastInstance.
getConfigAndReset() - Method in class com.hazelcast.config.LegacyCacheConfig
 
getConfigByTag(ClientNetworkConfig, String) - Static method in class com.hazelcast.client.config.ClientAliasedDiscoveryConfigUtils
Gets the AliasedDiscoveryConfig from config by tag.
getConfigByTag(JoinConfig, String) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Gets the AliasedDiscoveryConfig from config by tag.
getConfigByTag(WanPublisherConfig, String) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Gets the AliasedDiscoveryConfig from config by tag.
getConfigClassLoader() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
getConfigClassLoader() - Method in interface com.hazelcast.spi.NodeEngine
Returns the Config ClassLoader.
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.config.Config
Returns the pattern matcher which is used to match item names to configuration objects.
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
 
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
 
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
 
getConn() - Method in class com.hazelcast.nio.Packet
Gets the Connection this Packet was send with.
getConnectedClients() - Method in interface com.hazelcast.core.ClientService
Returns all connected clients to this member.
getConnectedServerVersion() - Method in class com.hazelcast.client.spi.ClientProxy
 
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() - 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 interface com.hazelcast.nio.ConnectionManager
Gets the total number of connections.
getConnectionManager() - Method in class com.hazelcast.client.spi.ClientContext
 
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
 
getConnectionRetryConfig() - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
Connection Retry Config is controls the period among the retries and when should a client gave up retrying.
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
getConnectionTimeoutSeconds() - Method in class com.hazelcast.config.TcpIpConfig
Returns the connection timeout.
getConsistencyCheckStrategy() - Method in class com.hazelcast.config.WanSyncConfig
Returns the strategy for checking consistency of data between source and target cluster.
getContext() - Method in class com.hazelcast.client.spi.ClientProxy
 
getContext() - Method in class com.hazelcast.client.spi.ProxyManager
 
getCost() - Method in interface com.hazelcast.core.EntryView
Returns the cost (in bytes) of the entry.
getCost() - Method in interface com.hazelcast.spi.merge.MergingCosts
Returns the memory cost of the merge data.
getCount() - Method in interface com.hazelcast.core.ICountDownLatch
Returns the current count.
getCountDownLatch(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns a cluster-wide CountDownLatch.
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.
getCountDownLatchConfigs() - Method in class com.hazelcast.config.Config
Returns the map of CountDownLatch configurations, mapped by config name.
getCounter(String) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
Returns the counter with the given name.
getCRDTReplicationConfig() - Method in class com.hazelcast.config.Config
 
getCreationTime() - Method in interface com.hazelcast.cache.CacheStatistics
Gets the cache creation time.
getCreationTime() - Method in interface com.hazelcast.core.EntryView
Returns the creation time of the entry.
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 interface com.hazelcast.spi.merge.MergingCreationTime
Returns the creation time of the merge data.
getCredentials() - Method in class com.hazelcast.client.config.ClientConfig
getCredentials() - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
getCredentialsClassname() - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
getCredentialsFactory() - Method in interface com.hazelcast.security.SecurityContext
Returns current ICredentialsFactory.
getCredentialsFactoryConfig() - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
getCurrentClientConnections() - Method in interface com.hazelcast.nio.ConnectionManager
Gets the number of client connections.
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
 
getCurrentMembers() - Method in class com.hazelcast.quorum.QuorumEvent
Returns the snapshot of member list at the time quorum happened
getCurrentReplicaIndex() - Method in class com.hazelcast.spi.PartitionMigrationEvent
Gets the index of the partition replica that current member owns currently, before migration starts.
getCurrentTargetReplicaAddress() - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
Returns the current target replica address to which this proxy is sending invocations.
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
 
getDataLoadTimeoutSeconds() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Returns configured data load timeout for hot-restart process.
getDataSerializableFactories() - Method in class com.hazelcast.config.SerializationConfig
 
getDataSerializableFactoryClasses() - Method in class com.hazelcast.config.SerializationConfig
 
getDefault() - Static method in enum com.hazelcast.cache.BuiltInCacheMergePolicies
Gets the definition of the default CacheMergePolicy.
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
 
getDefaultHazelcastInstance() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Gets the default HazelcastOSGiInstance.
getDefaultProperties() - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
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
 
getDefaultValue() - Method in class com.hazelcast.spi.properties.HazelcastProperty
Returns the default value of the property.
getDelaySeconds() - Method in class com.hazelcast.config.QueryCacheConfig
Returns the minimum number of delay seconds which an event waits in the buffer of node before sending to a QueryCache
getDelegatedInstance() - Method in interface com.hazelcast.osgi.HazelcastOSGiInstance
Gets the delegated (underlying) HazelcastInstance.
getDeprecatedName() - Method in class com.hazelcast.spi.properties.HazelcastProperty
 
getDepth() - Method in class com.hazelcast.config.MerkleTreeConfig
Returns the depth of the merkle tree.
getDeserializedKey() - Method in interface com.hazelcast.spi.merge.MergingEntry
Returns the deserialized merging key.
getDeserializedValue() - Method in interface com.hazelcast.spi.merge.MergingValue
Returns the deserialized merging value.
getDiffPercentage() - Method in class com.hazelcast.wan.merkletree.ConsistencyCheckResult
 
getDirectory() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
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
Returns the currently defined DiscoveryConfig
getDiscoveryConfig() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the currently defined DiscoveryConfig used by the discovery mechanism for this WAN publisher.
getDiscoveryConfig() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
getDiscoveryMode() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
getDiscoveryNode() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
getDiscoveryServiceProvider() - Method in class com.hazelcast.config.DiscoveryConfig
 
getDiscoveryStrategyConfigs() - Method in class com.hazelcast.config.DiscoveryConfig
Returns the defined DiscoveryStrategy configurations.
getDiscoveryStrategyFactory() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
getDiscoveryStrategyType() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategyFactory
Returns the type of the DiscoveryStrategy itself.
getDiscoveryStrategyType() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategyFactory
 
getDiscoveryToken() - Method in class com.hazelcast.client.config.ClientCloudConfig
hazelcast.cloud discoveryToken of your cluster
getDistributedObject() - 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 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 class com.hazelcast.client.spi.ClientProxy
 
getDistributedObjectName() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
getDistributedObjectNames(String) - Method in interface com.hazelcast.spi.ProxyService
 
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(String) - Method in interface com.hazelcast.spi.ProxyService
 
getDouble(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured double value of a HazelcastProperty.
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.
getDoubleValue(String, String) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
 
getDoubleValue(String, String, double) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
 
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.transaction.TransactionOptions
Gets the transaction durability.
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.
getDurableExecutorConfigs() - Method in class com.hazelcast.config.Config
Returns the map of durable executor configurations, mapped by config name.
getDurableExecutorService(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the durable executor service for the given name.
getDurationAmount() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
getDurationConfig() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
getDurationSecs() - Method in interface com.hazelcast.wan.WanSyncStats
Returns the duration of the synchronization in seconds
getEmptyPollOperationCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns number of null returning poll operations.
getEmptyQueueTtl() - Method in class com.hazelcast.config.QueueConfig
Returns the TTL (time to live) for emptying the Queue.
getEndPoint() - Method in interface com.hazelcast.nio.Connection
Gets the Address of the other side of this Connection.
getEndpoint() - Method in class com.hazelcast.security.AbstractCredentials
 
getEndpoint() - Method in interface com.hazelcast.security.Credentials
Returns IP address of endpoint.
getEndpoints() - Method in class com.hazelcast.config.PermissionConfig
 
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
 
getEntryView(K) - Method in interface com.hazelcast.core.IMap
Returns the EntryView for the specified key.
getEnum(HazelcastProperty, Class<E>) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured enum value of a GroupProperty.
getEurekaConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Returns the current EurekaConfig.
getEurekaConfig() - Method in class com.hazelcast.config.JoinConfig
 
getEurekaConfig() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the EurekaConfig used by the discovery mechanism for this WAN publisher.
getEventObject() - Method in class com.hazelcast.wan.WanReplicationEvent
Gets the event object.
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
getEventQueueCapacity() - Method in interface com.hazelcast.spi.EventService
Returns the queue capacity per event thread.
getEventQueueSize() - Method in interface com.hazelcast.spi.EventService
Returns the current total event queue size.
getEventService() - Method in interface com.hazelcast.nio.IOService
 
getEventService() - Method in class com.hazelcast.nio.NodeIOService
 
getEventService() - Method in interface com.hazelcast.spi.NodeEngine
Gets the EventService.
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 interface com.hazelcast.spi.EventService
Returns the event thread count.
getEventType() - Method in class com.hazelcast.core.AbstractIMapEvent
Returns the event type EntryEventType.
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.map.EventLostEvent
Intentionally returns null.
getEvictionConfig() - Method in class com.hazelcast.config.CacheConfig
Gets the EvictionConfig instance of the eviction configuration for this ICache.
getEvictionConfig() - Method in class com.hazelcast.config.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
Returns EvictionConfig instance for this QueryCache
getEvictionConfig(Node) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
getEvictionPercentage() - Method in class com.hazelcast.config.MapConfig
Deprecated.
As of version 3.7, eviction mechanism changed. It uses a probabilistic algorithm based on sampling. Please see documentation for further details.
getEvictionPolicy() - Method in class com.hazelcast.config.EvictionConfig
Returns the EvictionPolicy of this eviction configuration.
getEvictionPolicy() - Method in class com.hazelcast.config.MapConfig
Returns the EvictionPolicy.
getEvictionPolicy() - Method in class com.hazelcast.config.NearCacheConfig
getEvictionPolicyType() - Method in class com.hazelcast.config.EvictionConfig
Deprecated.
getEvictions() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the number of evictions of Near Cache entries owned by this member.
getEvictionStrategyType() - Method in class com.hazelcast.config.EvictionConfig
Returns the EvictionStrategyType of this eviction configuration.
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
 
getExecutionCallback() - Method in class com.hazelcast.spi.InvocationBuilder
Gets the ExecutionCallback.
getExecutionService() - Method in class com.hazelcast.client.spi.ClientContext
 
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
 
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.
getExecutorConfigs() - Method in class com.hazelcast.config.Config
Returns the map of executor configurations, mapped by config name.
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 interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed executor service for the given name.
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 interface com.hazelcast.core.EntryView
Returns the expiration time of the entry.
getExpirationTime() - Method in interface com.hazelcast.spi.merge.MergingExpirationTime
Returns the expiration time of the merge data.
getExpiryForAccess() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
 
getExpiryForCreation() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
 
getExpiryForUpdate() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
 
getExpiryPolicy() - Method in interface com.hazelcast.cache.CacheEntryView
Gets the expiry policy associated with this entry if there is one.
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
 
getExtractor() - Method in class com.hazelcast.config.MapAttributeConfig
Gets the full class name of the extractor in a String format, e.g.
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.cache.HazelcastExpiryPolicy
 
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.MerkleTreeConfig
 
getFactoryId() - Method in class com.hazelcast.config.MultiMapConfig
 
getFactoryId() - Method in class com.hazelcast.config.NearCacheConfig
 
getFactoryId() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
getFactoryId() - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
getFactoryId() - Method in class com.hazelcast.config.PNCounterConfig
 
getFactoryId() - Method in class com.hazelcast.config.PredicateConfig
 
getFactoryId() - Method in class com.hazelcast.config.QueryCacheConfig
 
getFactoryId() - Method in class com.hazelcast.config.QueueConfig
 
getFactoryId() - Method in class com.hazelcast.config.QueueStoreConfig
 
getFactoryId() - Method in class com.hazelcast.config.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.config.WanSyncConfig
 
getFactoryId() - Method in class com.hazelcast.crdt.AbstractCRDTReplicationOperation
 
getFactoryId() - Method in class com.hazelcast.crdt.CRDTDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
 
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.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.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.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.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.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.OperationControl
 
getFactoryId() - Method in class com.hazelcast.version.MemberVersion
 
getFactoryId() - Method in class com.hazelcast.version.Version
 
getFactoryId() - Method in class com.hazelcast.wan.WanReplicationEvent
 
getFactoryImpl() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
 
getFactoryImplementation() - Method in class com.hazelcast.config.MapStoreConfig
Returns the map store factory implementation object.
getFactoryImplementation() - Method in class com.hazelcast.config.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 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 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 interface com.hazelcast.nio.serialization.ClassDefinition
Returns the field count.
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 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 interface com.hazelcast.spi.EventRegistration
Returns the EventFilter attached to this registration.
getFilters() - Method in class com.hazelcast.config.WanReplicationRef
Returns the list of class names implementing the CacheWanEventFilter or MapWanEventFilter for filtering outbound WAN replication events.
getFlags() - Method in class com.hazelcast.nio.Packet
 
getFlakeIdGenerator(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns a cluster-wide unique ID generator.
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.config.Config
Returns the FlakeIdGeneratorConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getFlakeIdGeneratorConfigMap() - Method in class com.hazelcast.client.config.ClientConfig
Returns the map of FlakeIdGenerator configurations, mapped by config name.
getFlakeIdGeneratorConfigs() - Method in class com.hazelcast.config.Config
Returns the map of FlakeIdGenerator configurations, mapped by config name.
getFloat(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured float value of a HazelcastProperty.
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.
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.
getFrameLength() - Method in class com.hazelcast.nio.Packet
 
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.
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.
getFreePhysical() - Method in class com.hazelcast.memory.DefaultMemoryStats
 
getFreePhysical() - Method in interface com.hazelcast.memory.MemoryStats
Returns free physical memory available in OS.
getGcpConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Returns the current GcpConfig.
getGcpConfig() - Method in class com.hazelcast.config.JoinConfig
 
getGcpConfig() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the GcpConfig used by the discovery mechanism for this WAN publisher.
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 interface com.hazelcast.monitor.LocalMemoryStats
 
getGetOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the number of get operations
getGlobalSerializerConfig() - Method in class com.hazelcast.config.SerializationConfig
 
getGlobalTaskScheduler() - Method in interface com.hazelcast.spi.ExecutionService
 
getGroupConfig() - Method in class com.hazelcast.client.config.ClientConfig
getGroupConfig() - Method in class com.hazelcast.config.Config
Returns the configuration for hazelcast groups.
getGroupName() - Method in interface com.hazelcast.client.spi.ClientTransactionManagerService
 
getGroupName() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the group name used as an endpoint group name for authentication on the target endpoint.
getGroupType() - Method in class com.hazelcast.config.PartitionGroupConfig
Returns the MemberGroupType configured.
getHandler() - Method in interface com.hazelcast.scheduledexecutor.IScheduledFuture
Returns the scheduled future resource handler.
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
Gets the underlying HazelcastInstance implementation.
getHazelcastInstance() - Method in class com.hazelcast.client.spi.ClientContext
 
getHazelcastInstance() - Method in class com.hazelcast.client.spi.ProxyManager
 
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
Gets an existing HazelcastOSGiInstance with its instanceName.
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 class com.hazelcast.spi.merge.RingbufferMergeData
Returns the sequence of the head.
getHeapCost() - Method in interface com.hazelcast.monitor.LocalMapStats
Cost of map & Near Cache & backup & Merkle trees in bytes
getHeapCost() - Method in interface com.hazelcast.nio.serialization.Data
Returns approximate heap cost of this Data object in bytes.
getHitCount() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the total number of hits into the index.
getHits() - Method in interface com.hazelcast.core.EntryView
Returns number of hits of the entry.
getHits() - Method in 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 interface com.hazelcast.spi.merge.MergingHits
Returns the access hits of the merge data.
getHost() - Method in class com.hazelcast.nio.Address
 
getHostHeader() - Method in class com.hazelcast.config.AwsConfig
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.config.Config
Returns the Hot Restart configuration for this hazelcast instance
getHotRestartService() - Method in interface com.hazelcast.core.Cluster
Returns the Hot Restart service for interacting with Hot Restart.
getHotRestartState() - Method in interface com.hazelcast.monitor.MemberState
 
getHzPort() - Method in class com.hazelcast.config.AwsConfig
getIamRole() - Method in class com.hazelcast.config.AwsConfig
getIcmpFailureDetectorConfig() - Method in class com.hazelcast.config.NetworkConfig
Returns the current IcmpFailureDetectorConfig.
getId() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
 
getId() - Method in class com.hazelcast.client.spi.ClientProxy
Deprecated.
getId() - Method in enum com.hazelcast.cluster.MemberAttributeOperationType
Gets the ID of the MemberAttributeOperationType.
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 enum com.hazelcast.config.ConsistencyCheckStrategy
Gets the ID for this ConsistencyCheckStrategy.
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.MerkleTreeConfig
 
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
Gets the ID for the given WanAcknowledgeType.
getId() - Method in class com.hazelcast.config.WanConsumerConfig
 
getId() - Method in class com.hazelcast.config.WanPublisherConfig
 
getId() - Method in enum com.hazelcast.config.WanPublisherState
Returns the ID of the WAN publisher state.
getId() - Method in enum com.hazelcast.config.WANQueueFullBehavior
Gets the ID for the given WANQueueFullBehavior.
getId() - Method in class com.hazelcast.config.WanReplicationConfig
 
getId() - Method in class com.hazelcast.config.WanSyncConfig
 
getId() - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
 
getId() - Method in class com.hazelcast.crdt.pncounter.PNCounterReplicationOperation
 
getId() - Method in class com.hazelcast.map.eviction.LFUEvictionPolicy
 
getId() - Method in class com.hazelcast.map.eviction.LRUEvictionPolicy
 
getId() - Method in class com.hazelcast.map.eviction.RandomEvictionPolicy
 
getId() - Method in class com.hazelcast.map.merge.HigherHitsMapMergePolicy
 
getId() - Method in class com.hazelcast.map.merge.IgnoreMergingEntryMapMergePolicy
 
getId() - Method in class com.hazelcast.map.merge.LatestUpdateMapMergePolicy
 
getId() - Method in class com.hazelcast.map.merge.PassThroughMergePolicy
 
getId() - Method in class com.hazelcast.map.merge.PutIfAbsentMapMergePolicy
 
getId() - Method in class com.hazelcast.nio.Address
 
getId() - Method in enum com.hazelcast.nio.serialization.FieldType
 
getId() - Method in interface com.hazelcast.nio.serialization.IdentifiedDataSerializable
Returns type identifier for this class.
getId() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Gets the ID of service.
getId() - Method in class com.hazelcast.query.PagingPredicate
 
getId() - Method in class com.hazelcast.query.PartitionPredicate
 
getId() - Method in class com.hazelcast.query.SqlPredicate
 
getId() - Method in class com.hazelcast.query.TruePredicate
 
getId() - Method in class com.hazelcast.replicatedmap.merge.HigherHitsMapMergePolicy
 
getId() - Method in class com.hazelcast.replicatedmap.merge.LatestUpdateMapMergePolicy
 
getId() - Method in class com.hazelcast.replicatedmap.merge.PassThroughMergePolicy
 
getId() - Method in class com.hazelcast.replicatedmap.merge.PutIfAbsentMapMergePolicy
 
getId() - Method in enum com.hazelcast.ringbuffer.OverflowPolicy
Gets the ID for the given OverflowPolicy.
getId() - Method in class com.hazelcast.spi.AbstractLocalOperation
 
getId() - Method in class com.hazelcast.spi.DistributedObjectNamespace
 
getId() - Method in interface com.hazelcast.spi.EventRegistration
Returns the event registration ID.
getId() - Method in class com.hazelcast.spi.merge.DiscardMergePolicy
 
getId() - Method in class com.hazelcast.spi.merge.ExpirationTimeMergePolicy
 
getId() - Method in class com.hazelcast.spi.merge.HigherHitsMergePolicy
 
getId() - Method in class com.hazelcast.spi.merge.HyperLogLogMergePolicy
 
getId() - Method in class com.hazelcast.spi.merge.LatestAccessMergePolicy
 
getId() - Method in class com.hazelcast.spi.merge.LatestUpdateMergePolicy
 
getId() - Method in class com.hazelcast.spi.merge.PassThroughMergePolicy
 
getId() - Method in class com.hazelcast.spi.merge.PutIfAbsentMergePolicy
 
getId() - Method in class com.hazelcast.spi.OperationControl
 
getId() - Method in class com.hazelcast.version.MemberVersion
 
getId() - Method in class com.hazelcast.version.Version
 
getId() - Method in class com.hazelcast.wan.WanReplicationEvent
 
getIdCount() - Method in interface com.hazelcast.monitor.LocalFlakeIdGeneratorStats
Note that the ID count returned is the number of generated IDs not the number of consumed IDs.
getIdGenerator(String) - Method in interface com.hazelcast.core.HazelcastInstance
Deprecated.
The implementation can produce duplicate IDs in case of network split, even with split-brain protection enabled (during short window while split-brain is detected). Use HazelcastInstance.getFlakeIdGenerator(String) for an alternative implementation which does not suffer from this problem.
getIdOffset() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
getImplementation() - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
 
getImplementation() - Method in class com.hazelcast.config.CachePartitionLostListenerConfigReadOnly
Deprecated.
 
getImplementation() - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
getImplementation() - Method in class com.hazelcast.config.EntryListenerConfig
 
getImplementation() - Method in class com.hazelcast.config.GlobalSerializerConfig
 
getImplementation() - Method in class com.hazelcast.config.ItemListenerConfig
 
getImplementation() - Method in class com.hazelcast.config.ListenerConfig
Returns the EventListener implementation.
getImplementation() - Method in class com.hazelcast.config.LoginModuleConfig
Deprecated.
getImplementation() - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
 
getImplementation() - Method in class com.hazelcast.config.MapPartitionLostListenerConfigReadOnly
Deprecated.
 
getImplementation() - Method in class com.hazelcast.config.MapStoreConfig
Returns the map store implementation object.
getImplementation() - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
getImplementation() - Method in class com.hazelcast.config.PermissionPolicyConfig
 
getImplementation() - Method in class com.hazelcast.config.PredicateConfig
Returns the Predicate implementation.
getImplementation() - Method in class com.hazelcast.config.QuorumListenerConfig
 
getImplementation() - Method in class com.hazelcast.config.SecurityInterceptorConfig
 
getImplementation() - Method in class com.hazelcast.config.SerializerConfig
Returns the implementation of the serializer class.
getImplementation() - Method in class com.hazelcast.config.ServiceConfig
 
getImplementation() - Method in class com.hazelcast.config.SocketInterceptorConfig
Returns the SocketInterceptor implementation object.
getImplementation() - Method in class com.hazelcast.config.WanConsumerConfig
Returns the implementation implementing WanReplicationConsumer.
getImplementation() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the implementation of the WanReplicationEndpoint.
getImplementationClass() - Method in enum com.hazelcast.cache.BuiltInCacheMergePolicies
 
getImplementationClassName() - Method in enum com.hazelcast.cache.BuiltInCacheMergePolicies
Gets the name of the implementation class of CacheMergePolicy.
getIn() - Method in class com.hazelcast.client.config.XmlClientConfigLocator
 
getIn() - Method in class com.hazelcast.config.XmlConfigLocator
 
getIndex() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
 
getIndexConfigs() - Method in class com.hazelcast.config.QueryCacheConfig
 
getIndexedQueryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the total number of indexed queries performed on the map.
getIndexStats() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the per-index statistics map keyed by the index name.
getInetAddress() - Method in class com.hazelcast.nio.Address
 
getInetAddress() - Method in interface com.hazelcast.nio.Connection
Returns remote address of this Connection.
getInetSocketAddress() - Method in interface com.hazelcast.core.Member
Deprecated.
getInetSocketAddress() - Method in class com.hazelcast.nio.Address
 
getInitialBackoffMillis() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
how long to wait after the first failure before retrying
getInitialLoadMode() - Method in class com.hazelcast.config.MapStoreConfig
Returns the initial load mode.
getInitialPermits() - Method in class com.hazelcast.config.SemaphoreConfig
Gets the initial number of permits.
getInitialPublisherState() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the initial WAN publisher state.
getInMemoryFormat() - Method in class com.hazelcast.config.CacheConfig
Gets the data type that will be used to store records.
getInMemoryFormat() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the InMemory Format for this ICache.
getInMemoryFormat() - Method in class com.hazelcast.config.MapConfig
Returns the data type that will be used for storing records.
getInMemoryFormat() - Method in class com.hazelcast.config.NearCacheConfig
Returns the data type used to store entries.
getInMemoryFormat() - Method in class com.hazelcast.config.QueryCacheConfig
Returns memory format of values of entries in QueryCache.
getInMemoryFormat() - Method in class com.hazelcast.config.ReplicatedMapConfig
Data type used to store entries.
getInMemoryFormat() - Method in class com.hazelcast.config.RingbufferConfig
Gets the InMemoryFormat.
getInsertCount() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the number of insert operations performed on the index.
getInstanceName() - Method in class com.hazelcast.client.config.ClientConfig
 
getInstanceName() - Method in class com.hazelcast.config.Config
Returns the instance name uniquely identifying the hazelcast instance created by this configuration.
getIntAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
 
getIntAttribute(String) - Method in interface com.hazelcast.core.Member
Returns the value of the specified key for this member or null if value is undefined.
getInteger(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured int value of a HazelcastProperty.
getIntegerValue(String, String) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
 
getIntegerValue(String, String, int) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
 
getInterfaces() - Method in class com.hazelcast.config.InterfacesConfig
 
getInterfaces() - Method in class com.hazelcast.config.MemberGroupConfig
Gets an unmodifiable collection containing all interfaces.
getInterfaces() - Method in class com.hazelcast.config.NetworkConfig
 
getIntervalMilliseconds() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
getIntervalMilliseconds() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
getInvalidations() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the number of invalidations of Near Cache entries owned by this member.
getInvocationService() - Method in class com.hazelcast.client.spi.ClientContext
 
getInvocationTime() - Method in class com.hazelcast.spi.Operation
Gets the time in milliseconds when this invocation started.
getItem() - Method in class com.hazelcast.core.ItemEvent
Returns the item related to the event.
getItemListenerConfigs() - Method in class com.hazelcast.config.CollectionConfig
Gets the list of ItemListenerConfigs.
getItemListenerConfigs() - Method in class com.hazelcast.config.ListConfigReadOnly
Deprecated.
 
getItemListenerConfigs() - Method in class com.hazelcast.config.QueueConfig
Get the list of item listener configurations for this queue.
getItemListenerConfigs() - Method in class com.hazelcast.config.QueueConfigReadOnly
Deprecated.
 
getItemListenerConfigs() - Method in class com.hazelcast.config.SetConfigReadOnly
Deprecated.
 
getItems() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Returns the array representing this ringbuffer.
getIterationCount() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
getIterationType() - Method in class com.hazelcast.query.PagingPredicate
 
getJarPaths() - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
getJavaSerializationFilterConfig() - Method in class com.hazelcast.config.SerializationConfig
 
getJitter() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
by how much to randomize backoffs.
getJobId() - Method in interface com.hazelcast.mapreduce.JobCompletableFuture
Deprecated.
Returns the unique identifier for this mapreduce job.
getJobId() - Method in interface com.hazelcast.mapreduce.TrackableJob
Deprecated.
Returns the unique job ID of the tracked job
getJobProcessInformation() - Method in interface com.hazelcast.mapreduce.TrackableJob
Deprecated.
Returns an instance of JobProcessInformation to find out the state and statistics of a running task, or returns null if the underlying job ID is not available because the job is already finished or has not yet been submitted.
It returns null if not requested on the job issuing cluster member or client, since those values are not distributed to all clusters for traffic reasons.
getJobTracker(String) - Method in interface com.hazelcast.core.HazelcastInstance
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
getJobTracker() - Method in interface com.hazelcast.mapreduce.TrackableJob
Deprecated.
Returns the assigned JobTracker
getJobTrackerConfig(String) - Method in class com.hazelcast.config.Config
Returns the JobTrackerConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getJobTrackerConfigs() - Method in class com.hazelcast.config.Config
Returns the map of JobTracker configurations, mapped by config name.
getJoin() - Method in class com.hazelcast.config.NetworkConfig
Returns the JoinConfig.
getKey() - Method in interface com.hazelcast.cache.CacheEntryView
Gets the key of the cache entry.
getKey() - Method in interface com.hazelcast.cache.journal.EventJournalCacheEvent
Returns the key for the event entry.
getKey() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
getKey() - Method in class com.hazelcast.core.EntryEvent
Returns the key of the entry event.
getKey() - Method in interface com.hazelcast.core.EntryView
Returns the key of the entry.
getKey() - Method in interface com.hazelcast.core.ILock
Deprecated.
getKey() - Method in class com.hazelcast.core.MemberAttributeEvent
Returns the key for this MemberAttributeEvent.
getKey() - Method in class com.hazelcast.core.PartitionAwareKey
Gets the key (not the partitionKey).
getKey() - Method in interface com.hazelcast.map.journal.EventJournalMapEvent
Returns the key for the event entry.
getKey() - Method in interface com.hazelcast.spi.merge.MergingEntry
Returns the merging key in the in-memory format of the backing data structure.
getKey() - Method in interface com.hazelcast.wan.ReplicationEventObject
Returns the key for the entry on which the event occurred.
getKeyClassName() - Method in class com.hazelcast.config.AbstractCacheConfig
 
getKeyType() - Method in class com.hazelcast.config.AbstractCacheConfig
 
getKeyType() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the key type for this ICache.
getKubernetesConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Returns the current KubernetesConfig.
getKubernetesConfig() - Method in class com.hazelcast.config.JoinConfig
 
getKubernetesConfig() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the KubernetesConfig used by the discovery mechanism for this WAN publisher.
getLargestSequence() - Method in interface com.hazelcast.core.RingbufferStore
Return the largest sequence seen by the data store.
getLastAccessTime() - Method in interface com.hazelcast.cache.CacheEntryView
Gets the last access time in milliseconds of the cache entry.
getLastAccessTime() - Method in interface com.hazelcast.cache.CacheStatistics
Gets the last access time to cache.
getLastAccessTime() - Method in interface com.hazelcast.core.EntryView
Returns the last access time for the entry.
getLastAccessTime() - Method in interface com.hazelcast.monitor.LocalCacheStats
Gets the last access time to cache.
getLastAccessTime() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the last access (read) time of the locally owned entries.
getLastAccessTime() - Method in interface com.hazelcast.monitor.LocalRecordStoreStats
Returns the last access (read) time of the locally owned entries of this partition.
getLastAccessTime() - Method in interface com.hazelcast.spi.merge.MergingLastAccessTime
Returns the last access time of the merge data.
getLastCheckedLeafCount() - Method in class com.hazelcast.wan.merkletree.ConsistencyCheckResult
 
getLastCheckedPartitionCount() - Method in class com.hazelcast.wan.merkletree.ConsistencyCheckResult
 
getLastConsistencyCheckResults() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns the last results of the consistency checks, mapped by map name.
getLastDiffLeafCount() - Method in class com.hazelcast.wan.merkletree.ConsistencyCheckResult
 
getLastDiffPartitionCount() - Method in class com.hazelcast.wan.merkletree.ConsistencyCheckResult
 
getLastEntriesToSync() - Method in class com.hazelcast.wan.merkletree.ConsistencyCheckResult
 
getLastIdleTime(TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.ScheduledTaskStatistics
Returns the last period of time the task was idle, waiting to get scheduled
getLastPersistenceDuration() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the duration in milliseconds of the last Near Cache key persistence (when the pre-load feature is enabled).
getLastPersistenceFailure() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the failure reason of the last Near Cache persistence (when the pre-load feature is enabled).
getLastPersistenceKeyCount() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the number of persisted keys of the last Near Cache key persistence (when the pre-load feature is enabled).
getLastPersistenceTime() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the timestamp of the last Near Cache key persistence (when the pre-load feature is enabled).
getLastPersistenceWrittenBytes() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the written bytes of the last Near Cache key persistence (when the pre-load feature is enabled).
getLastRunDuration(TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.ScheduledTaskStatistics
Returns the duration of the task's last execution.
getLastStoredTime() - Method in interface com.hazelcast.core.EntryView
Returns the last time the value was flushed to its store (e.g.
getLastStoredTime() - Method in interface com.hazelcast.spi.merge.MergingLastStoredTime
Returns the last stored time of the merge data.
getLastSyncStats() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns the last synchronization statistics, mapped by map name.
getLastUpdateTime() - Method in interface com.hazelcast.cache.CacheStatistics
Gets the last update time to cache.
getLastUpdateTime() - Method in interface com.hazelcast.core.EntryView
Returns the last time the value was updated.
getLastUpdateTime() - Method in interface com.hazelcast.monitor.LocalCacheStats
Gets the last update time to cache.
getLastUpdateTime() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the last update time of the locally owned entries.
getLastUpdateTime() - Method in interface com.hazelcast.monitor.LocalRecordStoreStats
Returns the last update time of the locally owned entries of this partition.
getLastUpdateTime() - Method in interface com.hazelcast.spi.merge.MergingLastUpdateTime
Returns the last update time of the merge data.
getLeftChildOrder(int) - Static method in class com.hazelcast.wan.merkletree.MerkleTreeUtil
Returns the breadth-first order of the left child node of the node with nodeOrder
getLevel() - Method in interface com.hazelcast.logging.ILogger
Gets the logging level.
getLevel() - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
 
getLevelOfNode(int) - Static method in class com.hazelcast.wan.merkletree.MerkleTreeUtil
Returns the level a node with the given order is on in the tree
getLicenseKey() - Method in class com.hazelcast.client.config.ClientConfig
 
getLicenseKey() - Method in class com.hazelcast.config.Config
Returns the license key for this hazelcast instance.
getLifecycleService() - Method in class com.hazelcast.client.spi.ClientContext
 
getLifecycleService() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the lifecycle service for this instance.
getLingerSeconds() - Method in class com.hazelcast.client.config.SocketOptions
Gets SO_LINGER with the specified linger time in seconds
getList() - Method in class com.hazelcast.console.ConsoleApp
 
getList(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed list instance with the specified name.
getList(String) - Method in class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
 
getList(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
Returns the transactional list instance with the specified name.
getListConfig(String) - Method in class com.hazelcast.config.Config
Returns the ListConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getListConfigs() - Method in class com.hazelcast.config.Config
Returns the map of IList configurations, mapped by config name.
getListener() - Method in interface com.hazelcast.spi.ListenerWrapperEventFilter
Gets the wrapped listener.
getListenerConfigs() - Method in class com.hazelcast.client.config.ClientConfig
Gets list of all configured ListenerConfig's
getListenerConfigs() - Method in class com.hazelcast.config.Config
Returns the list of EventListener configurations.
getListenerConfigs() - Method in class com.hazelcast.config.QuorumConfig
 
getListenerConfigs() - Method in class com.hazelcast.config.ReplicatedMapConfig
 
getListenerConfigurations() - Method in class com.hazelcast.config.AbstractCacheConfig
 
getListenerService() - Method in class com.hazelcast.client.spi.ClientContext
 
getLoadBalancer() - Method in class com.hazelcast.client.config.ClientConfig
Gets LoadBalancer
getLocalCacheStatistics() - Method in interface com.hazelcast.cache.ICache
Directly access local Cache Statistics.
getLocalCacheStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getLocalClient() - Method in interface com.hazelcast.client.spi.ClientClusterService
 
getLocalEndpoint() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the local Endpoint which this HazelcastInstance belongs to.
getLocalExecutorStats() - Method in interface com.hazelcast.core.IExecutorService
Returns local statistics related to this executor service.
getLocalExecutorStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getLocalFlakeIdGeneratorStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getLocalMapStats() - Method in interface com.hazelcast.core.IMap
Returns LocalMapStats for this map.
getLocalMapStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getLocalMember() - Method in interface com.hazelcast.core.Cluster
Returns this Hazelcast instance member.
getLocalMember() - Method in interface com.hazelcast.spi.NodeEngine
Returns the local member.
getLocalMemoryStats() - Method in interface com.hazelcast.monitor.MemberState
 
getLocalMultiMapStats() - Method in interface com.hazelcast.core.MultiMap
Returns LocalMultiMapStats for this map.
getLocalMultiMapStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getLocalPNCounterStats(String) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
Returns the PN counter statistics for the counter with the given name
getLocalPNCounterStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getLocalQueueStats() - Method in interface com.hazelcast.core.IQueue
Returns LocalQueueStats for this queue.
getLocalQueueStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getLocalReplicatedMapStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getLocalTopicStats() - Method in interface com.hazelcast.core.ITopic
Returns statistics about this topic, like total number of publishes/receives.
getLocalTopicStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getLocalUpdatePolicy() - Method in class com.hazelcast.config.NearCacheConfig
Returns the NearCacheConfig.LocalUpdatePolicy of this Near Cache.
getLocalWanPublisherStats() - Method in interface com.hazelcast.monitor.LocalWanStats
Returns the statistics of different publisher clusters belongs the scheme on this member
getLocalWanStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getLock(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed lock instance for the specified key object.
getLockConfig(String) - Method in class com.hazelcast.config.Config
Returns the LockConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getLockConfigs() - Method in class com.hazelcast.config.Config
Returns the map of ILock configurations, mapped by config name.
getLockCount() - Method in interface com.hazelcast.core.ILock
Returns re-entrant lock hold count, regardless of lock ownership.
getLockedEntryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the number of currently locked locally owned keys.
getLogger(Class) - Static method in class com.hazelcast.logging.Logger
Obtains a logger for the given clazz.
getLogger(String) - Static method in class com.hazelcast.logging.Logger
Obtains a logger of the given name.
getLogger(String) - Method in interface com.hazelcast.logging.LoggerFactory
 
getLogger(String) - Method in class com.hazelcast.logging.LoggerFactorySupport
 
getLogger(String) - Method in interface com.hazelcast.logging.LoggingService
 
getLogger(Class) - Method in interface com.hazelcast.logging.LoggingService
 
getLogger(String) - Method in class com.hazelcast.logging.LoggingServiceImpl
 
getLogger(Class) - Method in class com.hazelcast.logging.LoggingServiceImpl
 
getLogger(String) - Method in class com.hazelcast.logging.NoLogFactory
 
getLogger() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
Returns a ILogger instance bound to the current class.
getLogger() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
getLogger(String) - Method in interface com.hazelcast.spi.NodeEngine
Gets the logger for a given name.
getLogger(Class) - Method in interface com.hazelcast.spi.NodeEngine
Gets the logger for a given class.
getLogger() - Method in class com.hazelcast.spi.Operation
 
getLoggingService() - Method in class com.hazelcast.client.spi.ClientContext
 
getLoggingService() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the logging service of this Hazelcast instance.
getLoggingService() - Method in interface com.hazelcast.nio.IOService
 
getLoggingService() - Method in class com.hazelcast.nio.NodeIOService
 
getLogRecord() - Method in class com.hazelcast.logging.LogEvent
 
getLong(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured long value of a HazelcastProperty.
getLongAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
 
getLongAttribute(String) - Method in interface com.hazelcast.core.Member
Returns the value of the specified key for this member or null if value is undefined.
getLongValue(String, String) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
 
getLongValue(String, String, long) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
 
getLostBackupCount() - Method in class com.hazelcast.partition.PartitionLostEvent
Returns the number of lost backups for the partition.
getLostReplicaIndex() - Method in class com.hazelcast.spi.partition.IPartitionLostEvent
0-based replica index that is lost for the partition.
getMajor() - Method in class com.hazelcast.version.MemberVersion
 
getMajor() - Method in class com.hazelcast.version.Version
 
getMajorCollectionCount() - Method in class com.hazelcast.memory.DefaultGarbageCollectorStats
 
getMajorCollectionCount() - Method in interface com.hazelcast.memory.GarbageCollectorStats
Returns major collection count.
getMajorCollectionTime() - Method in class com.hazelcast.memory.DefaultGarbageCollectorStats
 
getMajorCollectionTime() - Method in interface com.hazelcast.memory.GarbageCollectorStats
Returns total major collection time in ms.
getManagedContext() - Method in class com.hazelcast.client.config.ClientConfig
getManagedContext() - Method in class com.hazelcast.config.Config
Returns the external managed context.
getManagedContext() - Method in interface com.hazelcast.spi.serialization.SerializationService
getManagementCenterConfig() - Method in class com.hazelcast.config.Config
Returns the management center configuration for this hazelcast instance.
getManagerPrefix() - Method in class com.hazelcast.config.CacheConfig
Gets the manager prefix of the ICache, such as "hz://".
getMap() - Method in class com.hazelcast.console.ConsoleApp
 
getMap(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed map instance with the specified name.
getMap(String) - Method in class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
 
getMap(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
Returns the transactional distributed map instance with the specified name.
getMapAttributeConfigs() - Method in class com.hazelcast.config.MapConfig
 
getMapConfig(String) - Method in class com.hazelcast.config.Config
Returns the MapConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getMapConfigOrNull(String) - Method in class com.hazelcast.config.Config
Returns the map config with the given name or null if there is none.
getMapConfigs() - Method in class com.hazelcast.config.Config
Returns the map of IMap configurations, mapped by config name.
getMapEventJournalConfig(String) - Method in class com.hazelcast.config.Config
Returns the map event journal config for the given name, creating one if necessary and adding it to the collection of known configurations.
getMapEventJournalConfigs() - Method in class com.hazelcast.config.Config
Returns the map of map event journal configurations, mapped by config name.
getMapEvictionPolicy() - Method in class com.hazelcast.config.MapConfig
Returns custom eviction policy if it is set otherwise returns null.
getMapIndexConfigs() - Method in class com.hazelcast.config.MapConfig
 
getMapIndexConfigs() - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
getMapListener() - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
getMapMerkleTreeConfig(String) - Method in class com.hazelcast.config.Config
Returns the map merkle tree config for the given name, creating one if necessary and adding it to the collection of known configurations.
getMapMerkleTreeConfigs() - Method in class com.hazelcast.config.Config
Returns the map of map merkle tree configurations, mapped by config name.
getMapName() - Method in class com.hazelcast.config.EventJournalConfig
Returns the map name to which this config applies.
getMapName() - Method in class com.hazelcast.config.MerkleTreeConfig
Returns the map name to which this config applies.
getMapper(Supplier<Key, ?, Supplied>) - Method in interface com.hazelcast.mapreduce.aggregation.Aggregation
Deprecated.
Returns the Mapper for this aggregation.
getMapStoreConfig() - Method in class com.hazelcast.config.MapConfig
Returns the map store configuration
getMapStoreConfig() - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
getMasterAddress() - Method in interface com.hazelcast.client.spi.ClientClusterService
Returns the address of the master member.
getMasterAddress() - Method in interface com.hazelcast.spi.NodeEngine
Gets the address of the master member.
getMaxAge() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns the maximum age of the items in this member.
getMaxAllowedBackupCount() - Method in interface com.hazelcast.spi.partition.IPartitionService
Returns maximum allowed backup count according to current cluster formation and partition group configuration.
getMaxAttempts() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
getMaxAttempts() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
getMaxBackoffMillis() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
When backoff reaches this upper bound, it does not increase any more.
getMaxConcurrentReplicationTargets() - Method in class com.hazelcast.config.CRDTReplicationConfig
Returns the maximum number of target members that we replicate the CRDT states to in one period.
getMaxGetLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the maximum latency of get operations.
getMaxHeap() - Method in class com.hazelcast.memory.DefaultMemoryStats
 
getMaxHeap() - Method in interface com.hazelcast.memory.MemoryStats
Returns the maximum amount of memory that the JVM will attempt to use in bytes.
getMaxIdle() - Method in interface com.hazelcast.core.EntryView
Returns the last set max idle time in milliseconds.
getMaxIdle() - Method in interface com.hazelcast.spi.merge.MergingMaxIdle
Returns the MaxIdle of the merge data.
getMaxIdleSeconds() - Method in class com.hazelcast.config.MapConfig
Returns the maximum number of seconds for each entry to stay idle in the map.
getMaxIdleSeconds() - Method in class com.hazelcast.config.NearCacheConfig
Returns the maximum number of seconds each entry can stay in the Near Cache as untouched (not-read).
getMaximumSizePolicy() - Method in class com.hazelcast.config.EvictionConfig
Returns the EvictionConfig.MaxSizePolicy of this eviction configuration.
getMaxMetadata() - Method in class com.hazelcast.memory.DefaultMemoryStats
 
getMaxMetadata() - Method in interface com.hazelcast.memory.MemoryStats
Returns the amount of native memory reserved for metadata.
getMaxNative() - Method in class com.hazelcast.memory.DefaultMemoryStats
 
getMaxNative() - Method in interface com.hazelcast.memory.MemoryStats
Returns the maximum amount of native memory that current HazelcastInstance will attempt to use in bytes.
getMaxPutLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the maximum latency of put operations.
getMaxRemoveLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the maximum latency of remove operations.
getMaxSize() - Method in class com.hazelcast.config.CollectionConfig
Gets the maximum size for the Configuration.
getMaxSize() - Method in class com.hazelcast.config.NearCacheConfig
Deprecated.
getMaxSize() - Method in class com.hazelcast.config.QueueConfig
Returns the maximum size of the Queue.
getMaxSizeConfig() - Method in class com.hazelcast.config.MapConfig
 
getMaxSizeConfig() - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
getMaxSizePolicy() - Method in class com.hazelcast.config.CacheEvictionConfig
Deprecated.
getMaxSizePolicy() - Method in class com.hazelcast.config.MaxSizeConfig
Returns the maximum size policy of the map.
getMaxThreadSize() - Method in class com.hazelcast.config.JobTrackerConfig
Gets the maximum thread pool size of this JobTracker.
getMember(Address) - Method in interface com.hazelcast.client.spi.ClientClusterService
Gets the member for the given address.
getMember(String) - Method in interface com.hazelcast.client.spi.ClientClusterService
Gets the member with the given UUID.
getMember() - Method in class com.hazelcast.core.AbstractIMapEvent
Returns the member that fired this event.
getMember() - Method in interface com.hazelcast.core.IMapEvent
Returns the member that fired this event.
getMember() - Method in class com.hazelcast.core.ItemEvent
Returns the member that fired this event.
getMember() - Method in class com.hazelcast.core.MemberAttributeEvent
 
getMember() - Method in exception com.hazelcast.core.MemberLeftException
Returns the member that left the cluster
getMember() - Method in class com.hazelcast.core.MembershipEvent
Returns the removed or added member.
getMember() - Method in class com.hazelcast.logging.LogEvent
 
getMember() - Method in class com.hazelcast.map.EventLostEvent
 
getMember() - Method in class com.hazelcast.spi.MembershipServiceEvent
Returns the removed or added member.
getMemberAddressProviderConfig() - Method in class com.hazelcast.config.NetworkConfig
 
getMemberAttributeConfig() - Method in class com.hazelcast.config.Config
Returns the member attribute configuration.
getMemberCredentialsConfig() - Method in class com.hazelcast.config.SecurityConfig
 
getMemberGroupConfigs() - Method in class com.hazelcast.config.PartitionGroupConfig
Returns an unmodifiable collection containing all MemberGroupConfig elements.
getMemberGroups() - Method in interface com.hazelcast.spi.partitiongroup.PartitionGroupStrategy
 
getMemberList() - Method in interface com.hazelcast.client.spi.ClientClusterService
Gets the collection of members.
getMemberLoginModuleConfigs() - Method in class com.hazelcast.config.SecurityConfig
 
getMemberPartitions(Address) - Method in interface com.hazelcast.spi.partition.IPartitionService
Returns partition ID list assigned to given target.
getMemberPartitionsMap() - Method in interface com.hazelcast.spi.partition.IPartitionService
Gets member partition IDs.
getMemberPartitionState() - Method in interface com.hazelcast.monitor.MemberState
 
getMembers(MemberSelector) - Method in interface com.hazelcast.client.spi.ClientClusterService
Returns a collection of the members that satisfy the given MemberSelector.
getMembers() - Method in class com.hazelcast.config.TcpIpConfig
Gets a list of all the well known members.
getMembers() - Method in interface com.hazelcast.core.Cluster
Set of the current members in the cluster.
getMembers() - Method in class com.hazelcast.core.InitialMembershipEvent
Returns an immutable set of ordered members at the moment this InitialMembershipListener is registered.
getMembers() - Method in class com.hazelcast.core.MembershipEvent
Returns a consistent view of the the members immediately after this MembershipEvent has been processed.
getMembers() - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
getMemberSocketInterceptor() - Method in interface com.hazelcast.nio.IOService
 
getMemberSocketInterceptor() - Method in class com.hazelcast.nio.NodeIOService
 
getMemberVersion() - Method in interface com.hazelcast.monitor.NodeState
 
getMemoryCost() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the memory cost of the index in bytes.
getMemoryStats() - Method in interface com.hazelcast.client.ClientExtension
Returns MemoryStats of for the JVM and current HazelcastInstance.
getMergePolicy() - Method in class com.hazelcast.config.CacheConfig
Gets the class name of CacheMergePolicy implementation of this cache config.
getMergePolicy() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the class name of CacheMergePolicy implementation of this cache config.
getMergePolicy() - Method in class com.hazelcast.config.MapConfig
Deprecated.
getMergePolicy() - Method in class com.hazelcast.config.ReplicatedMapConfig
getMergePolicy() - Method in class com.hazelcast.config.WanReplicationRef
Returns the merge policy sent to the WAN replication target to merge replicated entries with existing target entries.
getMergePolicy(String) - Method in class com.hazelcast.map.merge.MergePolicyProvider
Returns an instance of a merge policy by its classname.
getMergePolicy(String) - Method in class com.hazelcast.replicatedmap.merge.MergePolicyProvider
Returns an instance of a merge policy by its classname.
getMergePolicy(String) - Method in class com.hazelcast.spi.merge.SplitBrainMergePolicyProvider
Resolves the SplitBrainMergePolicy class by its classname.
getMergePolicyConfig() - Method in class com.hazelcast.config.AbstractBasicConfig
Gets the MergePolicyConfig of this data structure.
getMergePolicyConfig() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Gets the MergePolicyConfig for the cardinality estimator.
getMergePolicyConfig() - Method in class com.hazelcast.config.CollectionConfig
Gets the MergePolicyConfig for the collection.
getMergePolicyConfig() - Method in class com.hazelcast.config.MapConfig
Gets the MergePolicyConfig for this map.
getMergePolicyConfig() - Method in class com.hazelcast.config.MultiMapConfig
Gets the MergePolicyConfig for this MultiMap.
getMergePolicyConfig() - Method in class com.hazelcast.config.QueueConfig
Gets the MergePolicyConfig for this queue.
getMergePolicyConfig() - Method in class com.hazelcast.config.ReplicatedMapConfig
Gets the MergePolicyConfig for this replicated map.
getMergePolicyConfig() - Method in class com.hazelcast.config.RingbufferConfig
Gets the MergePolicyConfig for this ringbuffer.
getMergePolicyConfig() - Method in class com.hazelcast.config.ScheduledExecutorConfig
Gets the MergePolicyConfig for the scheduler.
getMergingValue() - Method in class com.hazelcast.core.EntryEvent
Returns the incoming merging value of the entry event.
getMerkleTreesCost() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the heap cost of the Merkle trees
getMessageListenerConfigs() - Method in class com.hazelcast.config.ReliableTopicConfig
Gets the list of message listeners (listens for when messages are added or removed) for this reliable topic.
getMessageListenerConfigs() - Method in class com.hazelcast.config.TopicConfig
Gets the list of message listeners (listens for when messages are added or removed) for this topic.
getMessageListenerConfigs() - Method in class com.hazelcast.config.TopicConfigReadOnly
Deprecated.
 
getMessageObject() - Method in class com.hazelcast.core.Message
Returns the published message
getMetadataSpacePercentage() - Method in class com.hazelcast.config.NativeMemoryConfig
Returns the percentage of native memory space to be used to store metadata and internal memory structures by the native memory manager.
getMigrationEndpoint() - Method in class com.hazelcast.spi.PartitionMigrationEvent
Gets the partition migration endpoint.
getMigrationQueueSize() - Method in interface com.hazelcast.monitor.MemberPartitionState
Returns the migration queue size (this statistic is valid only for master).
getMigrationQueueSize() - Method in interface com.hazelcast.spi.partition.IPartitionService
 
getMillis(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured value of a HazelcastProperty converted to milliseconds.
getMinAge() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns the minimum age of the items in this member.
getMinBlockSize() - Method in class com.hazelcast.config.NativeMemoryConfig
Returns the minimum memory block size, in bytes, to be served by native memory manager.
getMinEvictionCheckMillis() - Method in class com.hazelcast.config.MapConfig
Deprecated.
As of version 3.7, eviction mechanism changed. It uses a probabilistic algorithm based on sampling. Please see documentation for further details.
getMinor() - Method in class com.hazelcast.version.MemberVersion
 
getMinor() - Method in class com.hazelcast.version.Version
 
getMinorCollectionCount() - Method in class com.hazelcast.memory.DefaultGarbageCollectorStats
 
getMinorCollectionCount() - Method in interface com.hazelcast.memory.GarbageCollectorStats
Returns minor collection count.
getMinorCollectionTime() - Method in class com.hazelcast.memory.DefaultGarbageCollectorStats
 
getMinorCollectionTime() - Method in interface com.hazelcast.memory.GarbageCollectorStats
Returns total minor collection time in ms.
getMisses() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the number of misses of Near Cache entries owned by this member.
getMulticastConfig() - Method in class com.hazelcast.config.JoinConfig
 
getMulticastGroup() - Method in class com.hazelcast.config.MulticastConfig
Gets the multicast group.
getMulticastPort() - Method in class com.hazelcast.config.MulticastConfig
Gets the multicast port.
getMulticastTimeoutSeconds() - Method in class com.hazelcast.config.MulticastConfig
Gets the multicast timeout in seconds.
getMulticastTimeToLive() - Method in class com.hazelcast.config.MulticastConfig
Gets the time to live for the multicast package.
getMultiMap() - Method in class com.hazelcast.console.ConsoleApp
 
getMultiMap(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed multimap instance with the specified name.
getMultiMap(String) - Method in class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
 
getMultiMap(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
Returns the transactional multimap instance with the specified name.
getMultiMapConfig(String) - Method in class com.hazelcast.config.Config
Returns the MultiMapConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getMultiMapConfigs() - Method in class com.hazelcast.config.Config
Returns the map of MultiMap configurations, mapped by config name.
getMultiplier() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
factor with which to multiply backoff after a failed retry
getMutualAuthConfig() - Method in class com.hazelcast.config.ManagementCenterConfig
Gets a property.
getMXBeans() - Method in interface com.hazelcast.monitor.MemberState
 
getName() - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
Returns the configuration name.
getName() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
Gets the name of the reliable topic.
getName() - Method in class com.hazelcast.client.spi.ClientContext
 
getName() - Method in class com.hazelcast.client.spi.ClientProxy
 
getName() - Method in class com.hazelcast.config.AbstractBasicConfig
Gets the name of this data structure.
getName() - Method in class com.hazelcast.config.CacheConfig
Gets the name of this ICache.
getName() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the name of this ICache.
getName() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Gets the name of the cardinality estimator.
getName() - Method in class com.hazelcast.config.CollectionConfig
Gets the name of this collection.
getName() - Method in class com.hazelcast.config.CountDownLatchConfig
Gets the name of the CountDownLatch.
getName() - Method in class com.hazelcast.config.DurableExecutorConfig
Gets the name of the executor task.
getName() - Method in class com.hazelcast.config.ExecutorConfig
Gets the name of the executor task.
getName() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Returns the configuration name.
getName() - Method in class com.hazelcast.config.GroupConfig
Gets the group name of the group.
getName() - Method in class com.hazelcast.config.JobTrackerConfig
Gets the name of this JobTracker.
getName() - Method in class com.hazelcast.config.LockConfig
Returns the name of the lock.
getName() - Method in class com.hazelcast.config.MapAttributeConfig
Gets the name of the attribute extracted by the extractor.
getName() - Method in class com.hazelcast.config.MapConfig
Returns the name of this IMap
getName() - Method in class com.hazelcast.config.MultiMapConfig
Gets the name of this MultiMap.
getName() - Method in interface com.hazelcast.config.NamedConfig
 
getName() - Method in class com.hazelcast.config.NearCacheConfig
Returns the name of the Near Cache.
getName() - Method in class com.hazelcast.config.PermissionConfig
 
getName() - Method in class com.hazelcast.config.PNCounterConfig
Gets the name of the PN counter.
getName() - Method in class com.hazelcast.config.QueryCacheConfig
Returns the name of QueryCache.
getName() - Method in class com.hazelcast.config.QueueConfig
 
getName() - Method in class com.hazelcast.config.QuorumConfig
 
getName() - Method in class com.hazelcast.config.ReliableTopicConfig
Gets the name of the reliable topic.
getName() - Method in class com.hazelcast.config.ReplicatedMapConfig
Returns the name of this ReplicatedMap.
getName() - Method in class com.hazelcast.config.RingbufferConfig
Returns the name of the ringbuffer.
getName() - Method in class com.hazelcast.config.ScheduledExecutorConfig
Gets the name of the executor task.
getName() - Method in class com.hazelcast.config.SemaphoreConfig
Gets the name of the semaphore.
getName() - Method in class com.hazelcast.config.ServiceConfig
 
getName() - Method in class com.hazelcast.config.TopicConfig
Gets the name of the topic, null if nothing is set.
getName() - Method in class com.hazelcast.config.WanReplicationConfig
 
getName() - Method in class com.hazelcast.config.WanReplicationRef
Returns the WAN replication reference name.
getName() - Method in class com.hazelcast.core.AbstractIMapEvent
Returns the name of the map for this event.
getName() - Method in interface com.hazelcast.core.DistributedObject
Returns the unique name for this DistributedObject.
getName(DistributedObject) - Static method in class com.hazelcast.core.DistributedObjectUtil
Gets the name of the given distributed object.
getName() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the name of this Hazelcast instance.
getName() - Method in interface com.hazelcast.core.IAtomicLong
Returns the name of this IAtomicLong instance.
getName() - Method in interface com.hazelcast.core.ICollection
Returns the name of this collection.
getName() - Method in interface com.hazelcast.core.IMapEvent
Returns the name of the map for this event.
getName() - Method in interface com.hazelcast.core.ISemaphore
Returns the name of this ISemaphore instance.
getName() - Method in interface com.hazelcast.core.ITopic
Returns the name of this ITopic instance.
getName() - Method in interface com.hazelcast.crdt.CRDTReplicationAwareService
Returns the name of the service
getName() - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
 
getName() - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
getName() - Method in class com.hazelcast.map.EventLostEvent
 
getName() - Method in interface com.hazelcast.map.QueryCache
Returns the name of this QueryCache.
getName() - Method in interface com.hazelcast.mapreduce.TrackableJob
Deprecated.
Returns the name of the underlying JobTracker
getName() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
 
getName() - Method in interface com.hazelcast.scheduledexecutor.NamedTask
Returns the name of the task.
getName() - Method in interface com.hazelcast.spi.NamedOperation
Returns the name of the distributed data structure.
getName() - Method in class com.hazelcast.spi.properties.HazelcastProperty
Returns the property name.
getName() - Method in class com.hazelcast.spring.cache.HazelcastCache
 
getNameAsPartitionAwareData() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
getNamespaceType() - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
getNameWithPrefix() - Method in class com.hazelcast.config.CacheConfig
Gets the full name of the ICache, including the manager scope prefix.
getNanos(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured value of a HazelcastProperty converted to nanoseconds.
getNativeCache() - Method in class com.hazelcast.spring.cache.HazelcastCache
 
getNativeMemoryConfig() - Method in class com.hazelcast.client.config.ClientConfig
 
getNativeMemoryConfig() - Method in class com.hazelcast.config.Config
Returns the native memory configuration for this hazelcast instance.
getNearCacheConfig(String) - Method in class com.hazelcast.client.config.ClientConfig
Gets the NearCacheConfig configured for the map / cache with name
getNearCacheConfig() - Method in class com.hazelcast.config.MapConfig
Returns the Near Cache configuration
getNearCacheConfig() - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
getNearCacheConfigMap() - Method in class com.hazelcast.client.config.ClientConfig
Map of all configured NearCacheConfig's with the name key and configuration as the value
getNearCacheManager() - Method in class com.hazelcast.client.spi.ClientContext
 
getNearCacheStatistics() - Method in interface com.hazelcast.cache.CacheStatistics
Gets the Near Cache statistics.
getNearCacheStats() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns statistics related to the Near Cache.
getNearestAnchorEntry(PagingPredicate) - Static method in class com.hazelcast.query.PagingPredicateAccessor
 
getNetworkConfig() - Method in class com.hazelcast.client.config.ClientConfig
getNetworkConfig() - Method in class com.hazelcast.config.Config
Returns the network configuration for this hazelcast instance.
getNewOwner() - Method in class com.hazelcast.core.MigrationEvent
Returns the new owner of the migrating partition
getNewReplicaIndex() - Method in class com.hazelcast.spi.PartitionMigrationEvent
Gets the index of the partition replica that current member will own after migration is committed.
getNewValue() - Method in interface com.hazelcast.cache.journal.EventJournalCacheEvent
Returns the new value for the event entry.
getNewValue() - Method in interface com.hazelcast.map.journal.EventJournalMapEvent
Returns the new value for the event entry.
getNextSequenceToReadFrom() - Method in interface com.hazelcast.ringbuffer.ReadResultSet
Returns the sequence of the item following the last read item.
getNodeEngine() - Method in class com.hazelcast.spi.AbstractDistributedObject
Gets the node engine.
getNodeEngine() - Method in class com.hazelcast.spi.Operation
 
getNodeFilter() - Method in class com.hazelcast.config.DiscoveryConfig
 
getNodeFilterClass() - Method in class com.hazelcast.config.DiscoveryConfig
 
getNodeHash(int) - Method in class com.hazelcast.wan.merkletree.ArrayMerkleTree
 
getNodeHash(int) - Method in class com.hazelcast.wan.merkletree.RemoteMerkleTreeView
 
getNodeIdOffset() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
getNodeKeyCount(int) - Method in class com.hazelcast.wan.merkletree.ArrayMerkleTree
 
getNodeKeyCount(int) - Method in interface com.hazelcast.wan.merkletree.MerkleTree
Returns the number of the keys under the specified node.
getNodeName() - Method in enum com.hazelcast.config.PermissionConfig.PermissionType
 
getNodesOnLevel(int) - Static method in class com.hazelcast.wan.merkletree.MerkleTreeUtil
Returns the number of nodes on the provided level
getNodeState() - Method in interface com.hazelcast.monitor.MemberState
 
getNodeState() - Method in interface com.hazelcast.monitor.NodeState
 
getNotifiedKey() - Method in interface com.hazelcast.spi.Notifier
 
getNumberOfEntriesAffected() - Method in class com.hazelcast.core.MapEvent
Returns the number of entries affected by this event.
getObjectId() - Method in class com.hazelcast.core.DistributedObjectEvent
Deprecated.
since 3.5. Please use DistributedObjectEvent.getObjectName() instead.
getObjectName() - Method in class com.hazelcast.core.DistributedObjectEvent
Returns the name of related DistributedObject.
getObjectName() - Method in class com.hazelcast.spi.AbstractWaitNotifyKey
 
getObjectName() - Method in class com.hazelcast.spi.DefaultObjectNamespace
Deprecated.
 
getObjectName() - Method in interface com.hazelcast.spi.ObjectNamespace
Gets the object name within the service.
getObjectName() - Method in interface com.hazelcast.spi.WaitNotifyKey
Returns the object name of the wait notify object for this key.
getOfferOperationCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns the number of offer/put/add operations.
getOldOwner() - Method in class com.hazelcast.core.MigrationEvent
Returns the old owner of the migrating partition
getOldValue() - Method in interface com.hazelcast.cache.journal.EventJournalCacheEvent
Returns the old value for the event entry.
getOldValue() - Method in class com.hazelcast.core.EntryEvent
Returns the old value of the entry event.
getOldValue() - Method in interface com.hazelcast.map.journal.EventJournalMapEvent
Returns the old value for the event entry.
getOp() - Method in class com.hazelcast.spi.InvocationBuilder
Gets the operation to execute.
getOperation() - Method in class com.hazelcast.crdt.CRDTReplicationContainer
Returns the CRDT replication operation.
getOperationResponseHandler() - Method in class com.hazelcast.spi.Operation
Gets the OperationResponseHandler tied to this Operation.
getOperationService() - Method in class com.hazelcast.spi.AbstractDistributedObject
Gets the OperationService.
getOperationService() - Method in interface com.hazelcast.spi.NodeEngine
Gets the OperationService.
getOperationStats() - Method in interface com.hazelcast.monitor.MemberState
Returns the local operation statistics.
getOperationType() - Method in class com.hazelcast.core.MemberAttributeEvent
Returns the type of member attribute change for this MemberAttributeEvent.
getOrConnect(Address) - Method in interface com.hazelcast.client.connection.ClientConnectionManager
 
getOrConnect(Address) - Method in interface com.hazelcast.nio.ConnectionManager
Gets the existing connection for a given address or connects.
getOrConnect(Address, boolean) - Method in interface com.hazelcast.nio.ConnectionManager
Gets the existing connection for a given address.
getOrCreate(T, ClassLoader, String) - Static method in class com.hazelcast.nio.ClassLoaderUtil
Returns the instance, if not null, or constructs a new instance of the class using ClassLoaderUtil.newInstance(ClassLoader, String).
getOrCreateCallIdsForMember(Address) - Method in class com.hazelcast.spi.CallsPerMember
 
getOrCreateHazelcastInstance() - Static method in class com.hazelcast.core.Hazelcast
Gets or creates a HazelcastInstance with the default XML configuration looked up in: System property: Hazelcast will first check if "hazelcast.config" system property is set to a file or a classpath:... path.
getOrCreateHazelcastInstance(Config) - Static method in class com.hazelcast.core.Hazelcast
Gets or creates the HazelcastInstance with a certain name.
getOrCreateProxy(String, String) - Method in class com.hazelcast.client.spi.ProxyManager
 
getOrCreateQueryCacheConfig(String, String) - Method in class com.hazelcast.client.config.ClientConfig
 
getOrDefault(PropertyDefinition, T) - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
Returns the value of the requested PropertyDefinition if available in the declarative or programmatic configuration (XML or Config API), otherwise it will return the given defaultValue.
getOrDefault(String, PropertyDefinition, T) - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
Returns the value of the requested PropertyDefinition if available in the declarative or programmatic configuration (XML or Config API), can be found in the system's environment, or passed as a JVM property.
getOriginClassName() - Method in exception com.hazelcast.client.UndefinedErrorCodeException
 
getOrNull(PropertyDefinition) - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
Returns the value of the requested PropertyDefinition if available in the declarative or programmatic configuration (XML or Config API), otherwise it will return null.
getOrNull(String, PropertyDefinition) - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
Returns the value of the requested PropertyDefinition if available in the declarative or programmatic configuration (XML or Config API), can be found in the system's environment, or passed as a JVM property.
getOrNullQueryCacheConfig(String, String) - Method in class com.hazelcast.client.config.ClientConfig
 
getOrTriggerConnect(Address, boolean) - Method in interface com.hazelcast.client.connection.ClientConnectionManager
 
getOtherOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the total number of Other Operations
getOtherOperationsCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns number of other operations
getOutboundPortDefinitions() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Returns the outbound port definitions.
getOutboundPortDefinitions() - Method in class com.hazelcast.config.NetworkConfig
 
getOutboundPorts() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Returns the outbound ports.
getOutboundPorts() - Method in class com.hazelcast.config.NetworkConfig
 
getOutboundPorts() - Method in interface com.hazelcast.nio.IOService
 
getOutboundPorts() - Method in class com.hazelcast.nio.NodeIOService
 
getOutboundQueueSize() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns the outbound queue size on this member
getOwnedEntryCount() - Method in interface com.hazelcast.cache.CacheStatistics
Returns the owned entry count in the cache.
getOwnedEntryCount() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the owned entry count in the cache.
getOwnedEntryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the number of entries owned by this member.
getOwnedEntryCount() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the number of Near Cache entries owned by this member.
getOwnedEntryMemoryCost() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns memory cost (number of bytes) of owned entries in this member.
getOwnedEntryMemoryCost() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns memory cost (number of bytes) of Near Cache entries owned by this member.
getOwnedItemCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns the number of owned items in this member.
getOwner() - Method in interface com.hazelcast.core.Partition
Returns the current member that owns this partition.
getOwner() - Method in interface com.hazelcast.mapreduce.JobPartitionState
Deprecated.
Returns the owner of this partition
getOwnerBundle() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Gets the owner Bundle of this instance.
getOwnerConnection() - Method in interface com.hazelcast.client.connection.ClientConnectionManager
 
getOwnerConnectionAddress() - Method in interface com.hazelcast.client.connection.ClientConnectionManager
 
getOwnerOrNull() - Method in interface com.hazelcast.spi.partition.IPartition
Returns the address of the owner of this partition.
getOwnerService() - Method in interface com.hazelcast.osgi.HazelcastOSGiInstance
Gets the owner HazelcastOSGiService of this instance.
getPackages() - Method in class com.hazelcast.config.ClassFilter
Returns unmodifiable set of package names.
getPacketType() - Method in class com.hazelcast.nio.Packet
 
getPage() - Method in class com.hazelcast.query.PagingPredicate
 
getPageSize() - Method in class com.hazelcast.config.NativeMemoryConfig
Returns the page size, in bytes, to be allocated by native memory manager as a single block.
getPageSize() - Method in class com.hazelcast.query.PagingPredicate
 
getParallelism() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Gets the configured number of Hot Restart store instance to create for one Hazelcast instance.
getParent() - Method in class com.hazelcast.spi.properties.HazelcastProperty
Returns the parent GroupProperty of the property.
getParentOrder(int) - Static method in class com.hazelcast.wan.merkletree.MerkleTreeUtil
Returns the breadth-first order of the parent node of the node with nodeOrder
getPartition(int) - Method in interface com.hazelcast.client.spi.ClientPartitionService
 
getPartition(Object) - Method in interface com.hazelcast.core.PartitionService
Returns the partition that the given key belongs to.
getPartition(int) - Method in interface com.hazelcast.spi.partition.IPartitionService
Returns the IPartition for a given partition ID.
getPartition(int, boolean) - Method in interface com.hazelcast.spi.partition.IPartitionService
Returns the IPartition for a given partition ID.
getPartitionCount() - Method in interface com.hazelcast.client.spi.ClientPartitionService
 
getPartitionCount() - Method in interface com.hazelcast.spi.partition.IPartitionService
Returns the number of partitions.
getPartitionGroupConfig() - Method in class com.hazelcast.config.Config
Returns the partition group configuration for this hazelcast instance.
getPartitionGroupStrategy() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
 
getPartitionGroupStrategy() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategy
Returns a custom implementation of a PartitionGroupStrategy to override default behavior of zone aware backup strategies PartitionGroupMetaData or to provide a specific behavior in case the discovery environment does not provide information about the infrastructure to be used for automatic configuration.
getPartitionGroupStrategy() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategy
 
getPartitionHash() - Method in interface com.hazelcast.nio.serialization.Data
Returns partition hash calculated for serialized object.
getPartitionId(Data) - Method in interface com.hazelcast.client.spi.ClientPartitionService
 
getPartitionId(Object) - Method in interface com.hazelcast.client.spi.ClientPartitionService
 
getPartitionId() - Method in class com.hazelcast.core.MigrationEvent
Returns the ID of the partition which is (or is being) migrated
getPartitionId() - Method in interface com.hazelcast.core.Partition
Returns the ID of the partition.
getPartitionId() - Method in class com.hazelcast.map.EventLostEvent
 
getPartitionId() - Method in class com.hazelcast.map.MapPartitionLostEvent
Returns the partition ID that has been lost for the given map
getPartitionId() - Method in class com.hazelcast.nio.Packet
Returns the partition ID of this packet.
getPartitionId() - Method in interface com.hazelcast.partition.PartitionEvent
Returns the partition ID that the event is dispatched for.
getPartitionId() - Method in class com.hazelcast.partition.PartitionLostEvent
Returns the lost partition ID.
getPartitionId() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
Returns the partition ID the task is associated with.
getPartitionId(Data) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
getPartitionId() - Method in class com.hazelcast.spi.InvocationBuilder
Returns the partition ID.
getPartitionId() - Method in class com.hazelcast.spi.Operation
Returns the ID of the partition that this Operation will be executed on.
getPartitionId() - Method in interface com.hazelcast.spi.partition.IPartition
Returns the partition ID.
getPartitionId() - Method in class com.hazelcast.spi.partition.IPartitionLostEvent
The partition ID that is lost.
getPartitionId(Data) - Method in interface com.hazelcast.spi.partition.IPartitionService
Returns the partition ID for a Data key.
getPartitionId(Object) - Method in interface com.hazelcast.spi.partition.IPartitionService
Returns the partition ID for a given object.
getPartitionId() - Method in interface com.hazelcast.spi.PartitionAwareOperation
Gets the partition ID.
getPartitionId() - Method in class com.hazelcast.spi.PartitionMigrationEvent
Gets the partition ID.
getPartitionId() - Method in class com.hazelcast.spi.PartitionReplicationEvent
Gets the ID of the partition.
getPartitioningStrategy() - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
getPartitioningStrategyClass() - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
getPartitioningStrategyConfig() - Method in class com.hazelcast.config.MapConfig
 
getPartitioningStrategyConfig() - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
getPartitionKey() - Method in class com.hazelcast.client.spi.ClientProxy
 
getPartitionKey() - Method in interface com.hazelcast.core.DistributedObject
Returns the key of the partition that this DistributedObject is assigned to.
getPartitionKey() - Method in interface com.hazelcast.core.PartitionAware
The key that will be used by Hazelcast to specify the partition.
getPartitionKey() - Method in class com.hazelcast.core.PartitionAwareKey
 
getPartitionKey(K) - Method in interface com.hazelcast.core.PartitioningStrategy
Returns the key object that will be used by Hazelcast to specify the partition.
getPartitionKey(Object) - Method in class com.hazelcast.partition.strategy.DefaultPartitioningStrategy
 
getPartitionKey(Object) - Method in class com.hazelcast.partition.strategy.StringAndPartitionAwarePartitioningStrategy
 
getPartitionKey(Object) - Method in class com.hazelcast.partition.strategy.StringPartitioningStrategy
 
getPartitionKey(String) - Static method in class com.hazelcast.partition.strategy.StringPartitioningStrategy
 
getPartitionKey() - Method in class com.hazelcast.query.PartitionPredicate
Returns the partition key that determines the partition the target Predicate is going to execute on.
getPartitionKey() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
getPartitionLostListenerConfigs() - Method in class com.hazelcast.config.CacheConfig
Gets the partition lost listener references added to cache configuration.
getPartitionLostListenerConfigs() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the partition lost listener references added to cache configuration.
getPartitionLostListenerConfigs() - Method in class com.hazelcast.config.MapConfig
 
getPartitionLostListenerConfigs() - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
getPartitionOwner(int) - Method in interface com.hazelcast.client.spi.ClientPartitionService
 
getPartitionOwner(int) - Method in interface com.hazelcast.spi.partition.IPartitionService
Gets the owner of the partition if it's set.
getPartitionOwnerOrWait(int) - Method in interface com.hazelcast.spi.partition.IPartitionService
Gets the owner of the partition.
getPartitions() - Method in interface com.hazelcast.core.PartitionService
Returns a set containing all the Partitions in the cluster.
getPartitions() - Method in interface com.hazelcast.monitor.MemberPartitionState
Returns a list of owned partitions of the member.
getPartitions() - Method in interface com.hazelcast.spi.partition.IPartitionService
Returns an array of IPartition instances.
getPartitionService() - Method in class com.hazelcast.client.spi.ClientContext
 
getPartitionService() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the partition service of this Hazelcast instance.
getPartitionService() - Method in interface com.hazelcast.spi.NodeEngine
Gets the IPartitionService.
getPartitionsSynced() - Method in interface com.hazelcast.wan.WanSyncStats
Returns the number of the partitions synchronized
getPartitionStates() - Method in interface com.hazelcast.mapreduce.JobProcessInformation
Deprecated.
Returns an array of JobPartitionStates holding information about the processing state (JobPartitionState.State) and the processing owner of this partition.
The index of the JobPartitionState inside of the array is the number of the processed partition if the KeyValueSource is PartitionIdAware or a randomly assigned ID for the different members of the cluster.
getPartitionStateVersion() - Method in interface com.hazelcast.spi.partition.IPartitionService
 
getPassword() - Method in class com.hazelcast.config.GroupConfig
Deprecated.
since 3.11, password check is removed. use SecurityConfig() , ClientSecurityConfig() for authentication
getPassword() - Method in class com.hazelcast.config.replacer.AbstractPbeReplacer
Provides password for a chosen SecretKeyFactory.
getPassword() - Method in class com.hazelcast.config.replacer.EncryptionReplacer
 
getPassword() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
getPassword() - Method in class com.hazelcast.security.UsernamePasswordCredentials
Gets the password.
getPatch() - Method in class com.hazelcast.version.MemberVersion
 
getPath(String...) - Static method in class com.hazelcast.nio.IOUtil
Concatenates path parts to a single path using the File.separator where it applies.
getPendingTaskCount() - Method in interface com.hazelcast.monitor.LocalExecutorStats
Returns the number of pending operations on the executor service.
getPermission(String, String, String...) - Static method in class com.hazelcast.security.permission.ActionConstants
Creates a permission
getPermissions(Subject, Class<? extends Permission>) - Method in interface com.hazelcast.security.IPermissionPolicy
Determines permissions of subject.
getPermissions() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
 
getPersistenceCount() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the number of Near Cache key persistences (when the pre-load feature is enabled).
getPNCounter(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns a PNCounter with the given name.
getPNCounterConfig(String) - Method in class com.hazelcast.config.Config
Returns the PNCounterConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getPNCounterConfigs() - Method in class com.hazelcast.config.Config
Returns the map of PN counter configurations, mapped by config name.
getPolicy() - Method in class com.hazelcast.config.MergePolicyConfig
Returns the classname of the SplitBrainMergePolicy.
getPollOperationCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns the number of poll/take/remove operations.
getPoolSize() - Method in class com.hazelcast.config.DurableExecutorConfig
Gets the number of executor threads per member for the executor.
getPoolSize() - Method in class com.hazelcast.config.ExecutorConfig
Gets the number of executor threads per member for the executor.
getPoolSize() - Method in class com.hazelcast.config.ScheduledExecutorConfig
Gets the number of executor threads per member for the executor.
getPort() - Method in class com.hazelcast.config.NetworkConfig
Returns the port the Hazelcast member will try to bind on.
getPort() - Method in class com.hazelcast.nio.Address
 
getPort() - Method in interface com.hazelcast.nio.Connection
The remote port.
getPortableFactories() - Method in class com.hazelcast.config.SerializationConfig
 
getPortableFactoryClasses() - Method in class com.hazelcast.config.SerializationConfig
 
getPortableVersion() - Method in class com.hazelcast.config.SerializationConfig
Portable version will be used to differentiate two versions of the same class that have changes on the class, like adding/removing a field or changing a type of a field.
getPortCount() - Method in class com.hazelcast.config.NetworkConfig
Returns the maximum number of ports allowed to try to bind on.
getPositiveMillisOrDefault(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured value of a HazelcastProperty converted to milliseconds if it is positive, otherwise returns its default value.
getPositiveMillisOrDefault(HazelcastProperty, long) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured value of a HazelcastProperty converted to milliseconds if it is positive, otherwise returns the passed default value.
getPostJoinOperation() - Method in interface com.hazelcast.spi.PostJoinAwareService
Post join operations must be lock free, meaning no locks at all: no partition locks, no key-based locks, no service level locks, no database interaction! The Operation.getPartitionId() method should return a negative value.
getPredicate() - Method in class com.hazelcast.query.PagingPredicate
 
getPredicate() - Method in class com.hazelcast.query.SqlPredicate
 
getPredicateConfig() - Method in class com.hazelcast.config.QueryCacheConfig
Returns the predicate of QueryCache.
getPrefetchCount() - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
 
getPrefetchCount() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
getPrefetchValidityMillis() - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
 
getPrefetchValidityMillis() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
getPrefix(URI, ClassLoader) - Static method in class com.hazelcast.cache.CacheUtil
Gets the prefix of cache name without Hazelcast's CacheManager specific prefix HazelcastCacheManager.CACHE_MANAGER_PREFIX.
getPrefix() - Method in class com.hazelcast.config.replacer.EncryptionReplacer
 
getPrefix() - Method in class com.hazelcast.config.replacer.PropertyReplacer
 
getPrefix() - Method in interface com.hazelcast.config.replacer.spi.ConfigReplacer
Variable replacer prefix string.
getPrefixedCacheName(String, URI, ClassLoader) - Static method in class com.hazelcast.cache.CacheUtil
Gets the cache name with prefix but without Hazelcast's CacheManager specific prefix HazelcastCacheManager.CACHE_MANAGER_PREFIX.
getPrefixedName() - Method in interface com.hazelcast.core.PrefixedDistributedObject
Returns the unique prefixed name for this DistributedObject.
getPrefixes() - Method in class com.hazelcast.config.ClassFilter
Returns unmodifiable set of class name prefixes.
getPreJoinOperation() - Method in interface com.hazelcast.spi.PreJoinAwareService
An operation to be executed on the joining member before it is set as joined.
getPreloaderConfig() - Method in class com.hazelcast.config.NearCacheConfig
Returns the NearCachePreloaderConfig of this Near Cache.
getPreloaderConfig() - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
getPreloaderConfig(Node) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
getPrincipal() - Method in interface com.hazelcast.client.connection.ClientConnectionManager
 
getPrincipal() - Method in class com.hazelcast.config.PermissionConfig
 
getPrincipal() - Method in class com.hazelcast.security.AbstractCredentials
 
getPrincipal() - Method in interface com.hazelcast.security.Credentials
Returns principal of endpoint.
getPrivateAddress() - Method in class com.hazelcast.spi.discovery.DiscoveryNode
Returns the private address of the discovered node.
getPrivateAddress() - Method in class com.hazelcast.spi.discovery.SimpleDiscoveryNode
 
getProcessedRecords() - Method in interface com.hazelcast.mapreduce.JobProcessInformation
Deprecated.
Returns the number of processed records.
The number of processed records is not a real time value, it is updated on a regular basis (after 1000 processed elements per node).
getProgress() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
getProperties() - Method in class com.hazelcast.client.config.ClientConfig
Gets Properties object
getProperties() - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
 
getProperties() - Method in class com.hazelcast.config.AbstractConfigBuilder
 
getProperties() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
Returns all properties.
getProperties() - Method in class com.hazelcast.config.Config
Returns the properties set on this config instance.
getProperties() - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
getProperties() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
getProperties() - Method in class com.hazelcast.config.LoginModuleConfig
 
getProperties() - Method in class com.hazelcast.config.MapStoreConfig
Returns all the properties
getProperties() - Method in class com.hazelcast.config.MCMutualAuthConfig
Gets all properties.
getProperties() - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
getProperties() - Method in class com.hazelcast.config.PermissionPolicyConfig
 
getProperties() - Method in class com.hazelcast.config.QueueStoreConfig
 
getProperties() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
getProperties() - Method in class com.hazelcast.config.ServiceConfig
 
getProperties() - Method in class com.hazelcast.config.SocketInterceptorConfig
Gets all properties.
getProperties() - Method in class com.hazelcast.config.SSLConfig
Gets all properties.
getProperties() - Method in class com.hazelcast.config.WanConsumerConfig
Returns the properties for the custom WAN consumer.
getProperties() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the WAN publisher properties.
getProperties() - Method in class com.hazelcast.config.XmlConfigBuilder
Gets the current used properties.
getProperties() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
Returns an immutable copy of the configuration properties.
getProperties() - Method in class com.hazelcast.spi.discovery.DiscoveryNode
Returns a set of unmodifiable properties that are assigned to the discovered node.
getProperties() - Method in class com.hazelcast.spi.discovery.SimpleDiscoveryNode
 
getProperties() - Method in interface com.hazelcast.spi.NodeEngine
Returns the HazelcastProperties.
getProperty(String) - Method in class com.hazelcast.client.config.ClientConfig
Gets a named property already set or from system properties if not exists.
getProperty(String) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
Returns property value by the property name.
getProperty(String) - Method in class com.hazelcast.config.Config
Returns the value for a named property.
getProperty(String) - Method in class com.hazelcast.config.MapStoreConfig
Returns the given property
getProperty(String) - Method in class com.hazelcast.config.MCMutualAuthConfig
Gets a property.
getProperty(String) - Method in class com.hazelcast.config.QueueStoreConfig
 
getProperty(String) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
getProperty(String) - Method in class com.hazelcast.config.SocketInterceptorConfig
Gets a property.
getProperty(String) - Method in class com.hazelcast.config.SSLConfig
Gets a property.
getProvidedMergeTypes() - Method in class com.hazelcast.config.AtomicLongConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.AtomicReferenceConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.CacheConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.CacheSimpleConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.CollectionConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.MapConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.MultiMapConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.QueueConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.ReplicatedMapConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.RingbufferConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
getProvidedMergeTypes() - Method in interface com.hazelcast.spi.merge.SplitBrainMergeTypeProvider
 
getProviderFilter() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Get current filter or null when no filter is defined.
getProviderMode() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Return the current ProviderMode
getProxyCount() - Method in interface com.hazelcast.spi.ProxyService
 
getProxyFactoryConfigs() - Method in class com.hazelcast.client.config.ClientConfig
Gets list of ProxyFactoryConfig
getProxyManager() - Method in class com.hazelcast.client.spi.ClientContext
 
getProxyService() - Method in interface com.hazelcast.spi.NodeEngine
Gets the ProxyService.
getPublicAddress() - Method in class com.hazelcast.config.NetworkConfig
 
getPublicAddress() - Method in class com.hazelcast.spi.discovery.DiscoveryNode
Returns the public address of the discovered node if available.
getPublicAddress() - Method in class com.hazelcast.spi.discovery.SimpleDiscoveryNode
 
getPublicAddress() - Method in interface com.hazelcast.spi.MemberAddressProvider
What address should Hazelcast advertise to other members and clients.
getPublisherId() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the publisher ID used for identifying the publisher in a WanReplicationConfig.
getPublisherState() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns the current WanPublisherState of this publisher.
getPublishingMember() - Method in class com.hazelcast.core.Message
Returns the member that published the message.
getPublishOperationCount() - Method in interface com.hazelcast.monitor.LocalTopicStats
Returns the total number of published messages of this topic on this member
getPublishTime() - Method in class com.hazelcast.core.Message
Return the time when the message is published
getPutOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the number of put operations
getQueryCache(String) - Method in interface com.hazelcast.core.IMap
Returns corresponding QueryCache instance for the supplied name or null.
getQueryCache(String, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
Creates an always up to date snapshot of this IMap according to the supplied parameters.
getQueryCache(String, MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
Creates an always up to date snapshot of this IMap according to the supplied parameters.
getQueryCacheConfigs() - Method in class com.hazelcast.client.config.ClientConfig
 
getQueryCacheConfigs() - Method in class com.hazelcast.config.MapConfig
Returns all QueryCacheConfig instances defined on this MapConfig.
getQueryCacheConfigs() - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
getQueryCacheContext() - Method in class com.hazelcast.client.spi.ClientContext
 
getQueryCount() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the total number of queries served by the index.
getQueryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the total number of queries performed on the map.
getQueue() - Method in class com.hazelcast.console.ConsoleApp
 
getQueue(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed queue instance with the specified name.
getQueue(String) - Method in class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
 
getQueue(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
Returns the transactional queue instance with the specified name.
getQueueCapacity() - Method in class com.hazelcast.config.ExecutorConfig
Gets the queue capacity of the executor task.
getQueueCapacity() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the capacity of the primary and backup queue for WAN replication events.
getQueueConfig(String) - Method in class com.hazelcast.config.Config
Returns the QueueConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getQueueConfigs() - Method in class com.hazelcast.config.Config
Returns the map of IQueue configurations, mapped by config name.
getQueueFullBehavior() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the configured behaviour of this WAN publisher when the WAN queue is full.
getQueueSize() - Method in class com.hazelcast.config.JobTrackerConfig
Gets the maximum size of the queue; the maximum number of tasks that can wait to be processed.
getQueueStoreConfig() - Method in class com.hazelcast.config.QueueConfig
Get the QueueStore (load and store queue items from/to a database) configuration.
getQueueStoreConfig() - Method in class com.hazelcast.config.QueueConfigReadOnly
Deprecated.
 
getQuorum(String) - Method in interface com.hazelcast.quorum.QuorumService
Returns the Quorum instance for a given quorum name.
getQuorumConfig(String) - Method in class com.hazelcast.config.Config
Returns the QuorumConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getQuorumConfigs() - Method in class com.hazelcast.config.Config
Returns the map of split brain protection configurations, mapped by config name.
getQuorumFunctionClassName() - Method in class com.hazelcast.config.QuorumConfig
 
getQuorumFunctionImplementation() - Method in class com.hazelcast.config.QuorumConfig
 
getQuorumName() - Method in class com.hazelcast.config.AbstractBasicConfig
Returns the quorum name for operations.
getQuorumName() - Method in class com.hazelcast.config.CacheConfig
Gets the name of the associated quorum if any.
getQuorumName() - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
getQuorumName() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the name of the associated quorum if any.
getQuorumName() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Returns the quorum name for operations.
getQuorumName() - Method in class com.hazelcast.config.CollectionConfig
Returns the quorum name for operations.
getQuorumName() - Method in class com.hazelcast.config.CountDownLatchConfig
 
getQuorumName() - Method in class com.hazelcast.config.DurableExecutorConfig
Returns the quorum name for operations.
getQuorumName() - Method in class com.hazelcast.config.ExecutorConfig
Returns the quorum name for operations.
getQuorumName() - Method in class com.hazelcast.config.LockConfig
Returns the quorum name for lock operations.
getQuorumName() - Method in class com.hazelcast.config.MapConfig
 
getQuorumName() - Method in class com.hazelcast.config.MultiMapConfig
Returns the quorum name for operations.
getQuorumName() - Method in class com.hazelcast.config.PNCounterConfig
Returns the quorum name for operations.
getQuorumName() - Method in class com.hazelcast.config.QueueConfig
Returns the quorum name for queue operations.
getQuorumName() - Method in class com.hazelcast.config.ReplicatedMapConfig
Returns the quorum name for operations.
getQuorumName() - Method in class com.hazelcast.config.RingbufferConfig
Returns the quorum name for operations.
getQuorumName() - Method in class com.hazelcast.config.ScheduledExecutorConfig
Returns the quorum name for operations.
getQuorumName() - Method in class com.hazelcast.config.SemaphoreConfig
 
getQuorumName(String) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
getQuorumName(String) - Method in interface com.hazelcast.spi.QuorumAwareService
Gets the name of the quorum associated with specified operation name.
getQuorumService() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the quorum service of this Hazelcast instance.
getQuorumService() - Method in interface com.hazelcast.spi.NodeEngine
Gets the QuorumService.
getRatio() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the hit/miss ratio of Near Cache entries owned by this member.
getRawDataInput() - Method in interface com.hazelcast.nio.serialization.PortableReader
getRawDataOutput() - Method in interface com.hazelcast.nio.serialization.PortableWriter
After writing portable fields, one can write remaining fields in old fashioned way consecutively at the end of stream.
getReadBatchSize() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
Gets the maximum number of items to read in a batch.
getReadBatchSize() - Method in class com.hazelcast.config.ReliableTopicConfig
Gets the maximum number of items to read in a batch.
getReadTimeout() - Method in class com.hazelcast.spring.cache.HazelcastCache
Return cache retrieval timeout in milliseconds
getReadTimeoutMap() - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
Return cache-specific value retrieval timeouts.
getReceivedEventCounters(String) - Method in interface com.hazelcast.wan.WanReplicationService
Returns a counter of received and processed WAN replication events.
getReceiveOperationCount() - Method in interface com.hazelcast.monitor.LocalTopicStats
Returns the total number of received messages of this topic on this member
getReconnectMode() - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
 
getRecordsSynced() - Method in interface com.hazelcast.wan.WanSyncStats
Returns the number of the records synchronized
getReducerFactory() - Method in interface com.hazelcast.mapreduce.aggregation.Aggregation
Deprecated.
Returns the ReducerFactory for this aggregation.
getRegion() - Method in class com.hazelcast.config.AwsConfig
getRegistrations(String, String) - Method in interface com.hazelcast.spi.EventService
Returns all registrations belonging to the given service and topic.
getRegistrationsAsArray(String, String) - Method in interface com.hazelcast.spi.EventService
Returns all registrations belonging to the given service and topic as an array.
getRejectedOfferOperationCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns the number of rejected offers.
getReleaseVersion() - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
getReliableLocalTopicStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getReliableTopic(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the reliable ReliableTopic instance with the specified name.
getReliableTopicConfig(String) - Method in class com.hazelcast.client.config.ClientConfig
Gets the ClientReliableTopicConfig for a given reliable topic name.
getReliableTopicConfig(String) - Method in class com.hazelcast.config.Config
Returns the ReliableTopicConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getReliableTopicConfigMap() - Method in class com.hazelcast.client.config.ClientConfig
Returns the map of reliable topic configurations, mapped by config name.
getReliableTopicConfigs() - Method in class com.hazelcast.config.Config
Returns the map of reliable topic configurations, mapped by config name.
getRemainingLeaseTime() - Method in interface com.hazelcast.core.ILock
Returns remaining lease time in milliseconds.
getRemoteSocketAddress() - Method in interface com.hazelcast.nio.Connection
Returns the address of the endpoint this Connection is connected to, or null if it is unconnected.
getRemoveCount() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the number of remove operations performed on the index.
getRemoveOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the number of Remove operations
getRepairingTask(String) - Method in class com.hazelcast.client.spi.ClientContext
 
getReplacement(String) - Method in class com.hazelcast.config.replacer.AbstractPbeReplacer
 
getReplacement(String) - Method in class com.hazelcast.config.replacer.PropertyReplacer
 
getReplacement(String) - Method in interface com.hazelcast.config.replacer.spi.ConfigReplacer
Provides String which should be used as a variable replacement for given masked value.
getReplicaAddress(int) - Method in interface com.hazelcast.spi.partition.IPartition
Returns the address of the replica.
getReplicaCount() - Method in class com.hazelcast.config.PNCounterConfig
Returns the number of replicas on which state for this PN counter will be kept.
getReplicaIndex() - Method in class com.hazelcast.spi.InvocationBuilder
Gets the replicaIndex.
getReplicaIndex() - Method in class com.hazelcast.spi.Operation
 
getReplicaIndex() - Method in class com.hazelcast.spi.PartitionReplicationEvent
Gets the replica index.
getReplicatedMap(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the replicated map instance with the specified name.
getReplicatedMapConfig(String) - Method in class com.hazelcast.config.Config
Returns the ReplicatedMapConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getReplicatedMapConfigs() - Method in class com.hazelcast.config.Config
Returns the map of ReplicatedMap configurations, mapped by config name.
getReplicatedMapStats() - Method in interface com.hazelcast.core.ReplicatedMap
Returns LocalReplicatedMapStats for this replicated map.
getReplicationDelayMillis() - Method in class com.hazelcast.config.ReplicatedMapConfig
Deprecated.
since new implementation will route puts to the partition owner nodes, caching won't help replication speed because most of the time subsequent puts will end up in different nodes
getReplicationEventCount() - Method in interface com.hazelcast.monitor.LocalReplicatedMapStats
Deprecated.
replication is no more handled by event system.
getReplicationPeriodMillis() - Method in class com.hazelcast.config.CRDTReplicationConfig
Returns the period between two replications of CRDT states in milliseconds.
getReplicatorExecutorService() - Method in class com.hazelcast.config.ReplicatedMapConfig
Deprecated.
new implementation doesn't use executor service for replication
getRequiredMember() - Method in class com.hazelcast.config.TcpIpConfig
Gets the required member.
getResourceFactory() - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
 
getResponse() - Method in class com.hazelcast.spi.Operation
Called if and only if Operation.returnsResponse() returned true, shortly after Operation.run() returns.
getResponseHandler() - Method in interface com.hazelcast.client.spi.ClientInvocationService
 
getRetryCount() - Method in class com.hazelcast.config.JobTrackerConfig
retry count is currently not used but reserved for later use where the framework will automatically try to restart / retry operations from a available savepoint.
getRightChildOrder(int) - Static method in class com.hazelcast.wan.merkletree.MerkleTreeUtil
Returns the breadth-first order of the right child node of the node with nodeOrder
getRingbuffer(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed Ringbuffer instance with the specified name.
getRingbufferConfig(String) - Method in class com.hazelcast.config.Config
Returns the RingbufferConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getRingbufferConfigs() - Method in class com.hazelcast.config.Config
Returns the map of Ringbuffer configurations, mapped by config name.
getRingbufferStoreConfig() - Method in class com.hazelcast.config.RingbufferConfig
Get the RingbufferStore (load and store ringbuffer items from/to a database) configuration.
getRuntimeProps() - Method in interface com.hazelcast.monitor.MemberState
 
getSalt() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
getScheduledExecutorConfig(String) - Method in class com.hazelcast.config.Config
Returns the ScheduledExecutorConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getScheduledExecutorConfigs() - Method in class com.hazelcast.config.Config
Returns the map of scheduled executor configurations, mapped by config name.
getScheduledExecutorService(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the IScheduledExecutorService scheduled executor service for the given name.
getScheduledFuture(ScheduledTaskHandler) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates a new IScheduledFuture from the given handler.
getSchedulerName() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
Return the name of the ScheduledExecutor this tasks is running on.
getScopedHost() - Method in class com.hazelcast.nio.Address
 
getScopeId() - Method in class com.hazelcast.nio.Address
 
getSeconds(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured value of a HazelcastProperty converted to seconds.
getSecretKey() - Method in class com.hazelcast.config.AwsConfig
getSecurityConfig() - Method in class com.hazelcast.client.config.ClientConfig
getSecurityConfig() - Method in class com.hazelcast.config.Config
Returns the security configuration for this hazelcast instance.
getSecurityGroupName() - Method in class com.hazelcast.config.AwsConfig
getSecurityInterceptorConfigs() - Method in class com.hazelcast.config.SecurityConfig
 
getSemaphore(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns a cluster-wide semaphore.
getSemaphoreConfig(String) - Method in class com.hazelcast.config.Config
Returns the SemaphoreConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getSemaphoreConfigs() - Method in class com.hazelcast.config.Config
Returns the collection of ISemaphore configs added to this config object.
getSemaphoreConfigsAsMap() - Method in class com.hazelcast.config.Config
Returns the map of ISemaphore configurations, mapped by config name.
getSentCacheEventCounter() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns the counter for the successfully transfered cache WAN events.
getSentEventCounters(String, String, String) - Method in interface com.hazelcast.wan.WanReplicationService
Returns a counter of sent and processed WAN replication events.
getSentMapEventCounter() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns the counter for the successfully transfered map WAN events.
getSequence(int) - Method in interface com.hazelcast.ringbuffer.ReadResultSet
Return the sequence number for the item at the given index.
getSerializationConfig() - Method in class com.hazelcast.client.config.ClientConfig
getSerializationConfig() - Method in class com.hazelcast.config.Config
Returns the serialization configuration for this hazelcast instance.
getSerializationService() - Method in class com.hazelcast.client.spi.ClientContext
 
getSerializationService() - Method in class com.hazelcast.client.spi.ClientProxy
 
getSerializationService() - Method in interface com.hazelcast.nio.IOService
 
getSerializationService() - Method in class com.hazelcast.nio.NodeIOService
 
getSerializationService() - Method in interface com.hazelcast.nio.ObjectDataInput
 
getSerializationService() - Method in interface com.hazelcast.nio.ObjectDataOutput
 
getSerializationService() - Method in interface com.hazelcast.spi.NodeEngine
Gets the SerializationService.
getSerializationType() - Method in interface com.hazelcast.nio.serialization.SerializerHook
Returns the actual class type of the serialized object
getSerializerConfigs() - Method in class com.hazelcast.config.SerializationConfig
 
getService() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
 
getService() - Method in class com.hazelcast.spi.AbstractDistributedObject
Gets the Service of this AbstractDistributedObject.
getService(String) - Method in interface com.hazelcast.spi.NodeEngine
Gets the service with the given name.
getService() - Method in class com.hazelcast.spi.Operation
 
getServiceConfig(String) - Method in class com.hazelcast.config.ServicesConfig
 
getServiceConfigs() - Method in class com.hazelcast.config.ServicesConfig
 
getServiceImpl() - Method in class com.hazelcast.config.ServiceConfig
Deprecated.
getServiceName() - Method in class com.hazelcast.client.spi.ClientProxy
 
getServiceName() - Method in interface com.hazelcast.client.spi.ClientProxyDescriptor
 
getServiceName() - Method in interface com.hazelcast.core.DistributedObject
Returns the service name for this object.
getServiceName() - Method in class com.hazelcast.core.DistributedObjectEvent
Returns the service name of related DistributedObject.
getServiceName() - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
 
getServiceName() - Method in class com.hazelcast.crdt.pncounter.PNCounterReplicationOperation
 
getServiceName() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
getServiceName() - Method in class com.hazelcast.spi.AbstractWaitNotifyKey
 
getServiceName() - Method in class com.hazelcast.spi.DefaultObjectNamespace
Deprecated.
 
getServiceName() - Method in class com.hazelcast.spi.InvocationBuilder
Gets the name of the service.
getServiceName() - Method in class com.hazelcast.spi.Operation
 
getServiceName() - Method in interface com.hazelcast.spi.ServiceNamespace
Name of the service
getServiceName() - Method in interface com.hazelcast.spi.WaitNotifyKey
Returns the service name of the wait notify object for this key.
getServiceName() - Method in class com.hazelcast.wan.WanReplicationEvent
Returns the service name for this event object.
getServiceNamespace() - Method in interface com.hazelcast.spi.ServiceNamespaceAware
Returns the ServiceNamespace which this object belongs to.
getServices(Class<S>) - Method in interface com.hazelcast.spi.NodeEngine
Returns a list of services matching provides service class/interface.
getServicesConfig() - Method in class com.hazelcast.config.Config
Returns the configuration for the user services managed by this hazelcast instance.
getSet() - Method in class com.hazelcast.console.ConsoleApp
 
getSet(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed set instance with the specified name.
getSet(String) - Method in class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
 
getSet(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
Returns the transactional set instance with the specified name.
getSetConfig(String) - Method in class com.hazelcast.config.Config
Returns the SetConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getSetConfigs() - Method in class com.hazelcast.config.Config
Returns the map of ISet configurations, mapped by config name.
getSharedService(String) - Method in interface com.hazelcast.spi.NodeEngine
Deprecated.
since 3.7, please use NodeEngine.getService(String) instead
getShortAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
 
getShortAttribute(String) - Method in interface com.hazelcast.core.Member
Returns the value of the specified key for this member or null if value is undefined.
getSingleType() - Method in enum com.hazelcast.nio.serialization.FieldType
 
getSize() - Method in interface com.hazelcast.client.spi.ClientClusterService
Gets the current number of members.
getSize(MemberSelector) - Method in interface com.hazelcast.client.spi.ClientClusterService
Gets the number of members that satisfy the given MemberSelector instance.
getSize() - Method in class com.hazelcast.config.EvictionConfig
Returns the size which is used by the EvictionConfig.MaxSizePolicy.
getSize() - Method in class com.hazelcast.config.MaxSizeConfig
Returns the size of the map.
getSize() - Method in class com.hazelcast.config.NativeMemoryConfig
Returns size of the native memory region.
getSize() - Method in class com.hazelcast.config.QuorumConfig
 
getSocketAddress() - Method in interface com.hazelcast.core.Client
Returns the socket address of this client.
getSocketAddress() - Method in interface com.hazelcast.core.Endpoint
Returns the socket address for this endpoint.
getSocketAddress() - Method in interface com.hazelcast.core.Member
Returns the socket address of this member.
getSocketConnectTimeoutSeconds() - Method in interface com.hazelcast.nio.IOService
 
getSocketConnectTimeoutSeconds() - Method in class com.hazelcast.nio.NodeIOService
 
getSocketInterceptorConfig() - Method in class com.hazelcast.client.config.ClientConfig
Deprecated.
getSocketInterceptorConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
getSocketInterceptorConfig() - Method in class com.hazelcast.config.NetworkConfig
getSocketInterceptorConfig() - Method in class com.hazelcast.nio.NodeIOService
 
getSocketOptions() - Method in class com.hazelcast.client.config.ClientConfig
Deprecated.
getSocketOptions() - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
getSource() - Method in class com.hazelcast.core.AbstractIMapEvent
Returns the object on which the event initially occurred.
getSplitBrainMergePolicyProvider() - Method in interface com.hazelcast.spi.NodeEngine
Returns the SplitBrainMergePolicyProvider for this instance.
getSql() - Method in class com.hazelcast.config.PredicateConfig
Returns sql string for this config.
getSSLConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Returns the current SSLConfig.
getSSLConfig() - Method in class com.hazelcast.config.NetworkConfig
Returns the current SSLConfig.
getSSLConfig() - Method in interface com.hazelcast.nio.IOService
 
getSSLConfig() - Method in class com.hazelcast.nio.NodeIOService
 
getStartedTaskCount() - Method in interface com.hazelcast.monitor.LocalExecutorStats
Returns the number of started operations on the executor service.
getStartTime() - Method in interface com.hazelcast.cluster.Joiner
Deprecated.
 
getState() - Method in class com.hazelcast.core.LifecycleEvent
 
getState() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
getState() - Method in interface com.hazelcast.mapreduce.JobPartitionState
Deprecated.
Returns the current processing state of this partition
getStats() - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
getStats() - Method in interface com.hazelcast.scheduledexecutor.IScheduledFuture
Returns the statistics and time measurement info of the execution of this scheduled future in the IScheduledExecutorService it was scheduled.
getStats() - Method in interface com.hazelcast.spi.StatisticsAwareService
Return the service statistics for the local instance.
getStatus() - Method in class com.hazelcast.core.MigrationEvent
Returns the status of the migration: started, completed or failed
getStatus() - Method in interface com.hazelcast.monitor.WanSyncState
 
getStatus() - Method in enum com.hazelcast.wan.WanSyncStatus
 
getStoreImplementation() - Method in class com.hazelcast.config.QueueStoreConfig
 
getStoreImplementation() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
getStoreInitialDelaySeconds() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
getStoreIntervalSeconds() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
getString(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured value of a HazelcastProperty as String.
getStringAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
 
getStringAttribute(String) - Method in interface com.hazelcast.core.Member
Returns the value of the specified key for this member or null if value is undefined.
getSubscriber() - Method in interface com.hazelcast.spi.EventRegistration
Returns the subscriber of this registration.
getSymmetricEncryptionConfig() - Method in class com.hazelcast.config.NetworkConfig
getSymmetricEncryptionConfig() - Method in interface com.hazelcast.nio.IOService
 
getSymmetricEncryptionConfig() - Method in class com.hazelcast.nio.NodeIOService
 
getSyncBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
Deprecated.
getSyncBackupCount() - Method in interface com.hazelcast.spi.BackupAwareOperation
The synchronous backup count.
getSyncedPartitionCount() - Method in interface com.hazelcast.monitor.WanSyncState
 
getSystemProperty() - Method in class com.hazelcast.spi.properties.HazelcastProperty
Gets the system property value of the property.
getTagKey() - Method in class com.hazelcast.config.AwsConfig
getTagValue() - Method in class com.hazelcast.config.AwsConfig
getTailSequence() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Returns the sequence of the tail.
getTarget() - Method in class com.hazelcast.query.PartitionPredicate
Returns the target Predicate.
getTarget() - Method in exception com.hazelcast.spi.exception.WrongTargetException
 
getTarget() - Method in class com.hazelcast.spi.InvocationBuilder
Returns the target machine.
getTargetExecutionCallback() - Method in class com.hazelcast.spi.InvocationBuilder
 
getTaskId() - Method in interface com.hazelcast.durableexecutor.DurableExecutorServiceFuture
A unique ID for the executing task
getTaskName() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
Returns the name of the task.
getTaskScheduler(String) - Method in interface com.hazelcast.spi.ExecutionService
 
getTcpIpConfig() - Method in class com.hazelcast.config.JoinConfig
 
getTextCommandService() - Method in interface com.hazelcast.nio.IOService
 
getTextCommandService() - Method in class com.hazelcast.nio.NodeIOService
 
getTextContent(Node) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
getThisAddress() - Method in interface com.hazelcast.nio.IOService
 
getThisAddress() - Method in class com.hazelcast.nio.NodeIOService
 
getThisAddress() - Method in interface com.hazelcast.spi.NodeEngine
Get the address of this member.
getThreshold() - Method in class com.hazelcast.quorum.QuorumEvent
Returns the predefined quorum threshold
getTimedExpiryPolicyFactoryConfig() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
getTimeoutMillis() - Method in class com.hazelcast.transaction.TransactionOptions
Gets the timeout in milliseconds.
getTimeoutMilliseconds() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
getTimeoutMilliseconds() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
getTimeToLiveSeconds() - Method in class com.hazelcast.config.EventJournalConfig
Gets the time to live in seconds.
getTimeToLiveSeconds() - Method in class com.hazelcast.config.MapConfig
Returns the maximum number of seconds for each entry to stay in the map.
getTimeToLiveSeconds() - Method in class com.hazelcast.config.NearCacheConfig
Returns the maximum number of seconds for each entry to stay in the Near Cache (time to live).
getTimeToLiveSeconds() - Method in class com.hazelcast.config.RingbufferConfig
Gets the time to live in seconds.
getTimeUnit() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
getTimeUnit() - Method in class com.hazelcast.spi.properties.HazelcastProperty
Returns the TimeUnit of the property.
getTopic() - Method in class com.hazelcast.console.ConsoleApp
 
getTopic(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed topic instance with the specified name.
getTopicConfig(String) - Method in class com.hazelcast.config.Config
Returns the TopicConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getTopicConfigs() - Method in class com.hazelcast.config.Config
Returns the map of reliable topic configurations, mapped by config name.
getTopicOverloadPolicy() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
Gets the TopicOverloadPolicy for this reliable topic.
getTopicOverloadPolicy() - Method in class com.hazelcast.config.ReliableTopicConfig
Gets the TopicOverloadPolicy for this reliable topic.
getTopologyChangedStrategy() - Method in class com.hazelcast.config.JobTrackerConfig
Gets how the map reduce framework will react on topology changes while executing a job.
getTotal() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
getTotalBackupCount() - Method in class com.hazelcast.config.CacheConfig
Gets the total backup count (backupCount + asyncBackupCount) of the cache.
getTotalBackupCount() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Returns the total number of backups: backupCount plus asyncBackupCount.
getTotalBackupCount() - Method in class com.hazelcast.config.CollectionConfig
Gets the total number of synchronous and asynchronous backups for this collection.
getTotalBackupCount() - Method in class com.hazelcast.config.MapConfig
Returns the total number of backups: backupCount plus asyncBackupCount.
getTotalBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
Gets the total number of backups (synchronous + asynchronous) for this MultiMap.
getTotalBackupCount() - Method in class com.hazelcast.config.QueueConfig
Get the total number of backups: the backup count plus the asynchronous backup count.
getTotalBackupCount() - Method in class com.hazelcast.config.RingbufferConfig
Returns the total number of backups: backupCount plus asyncBackupCount.
getTotalBackupCount() - Method in class com.hazelcast.config.SemaphoreConfig
Returns the total number of backups (synchronous plus asynchronous); the returned value will always equal or bigger than 0.
getTotalDecrementOperationCount() - Method in interface com.hazelcast.monitor.LocalPNCounterStats
Returns the total number of subtract (including decrement) operations on this PN counter on this member.
getTotalExecutionLatency() - Method in interface com.hazelcast.monitor.LocalExecutorStats
Returns the total execution time of operations finished.
getTotalGetLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the total latency of get operations.
getTotalIdleTime(TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.ScheduledTaskStatistics
Returns the total amount of time the task was idle, waiting to get scheduled in.
getTotalIncrementOperationCount() - Method in interface com.hazelcast.monitor.LocalPNCounterStats
Returns the total number of add (including increment) operations on this PN counter on this member.
getTotalInsertLatency() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the total latency (in nanoseconds) of insert operations performed on the index.
getTotalPhysical() - Method in class com.hazelcast.memory.DefaultMemoryStats
 
getTotalPhysical() - Method in interface com.hazelcast.memory.MemoryStats
Returns total physical memory available in OS.
getTotalPublishedEventCount() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns the total number of published events from this member
getTotalPublishLatency() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns the total latency of published wan events from this member by millisecond.
getTotalPutLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the total latency of put operations.
getTotalRemoveLatency() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the total latency (in nanoseconds) of remove operations performed on the index.
getTotalRemoveLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the total latency of remove operations.
getTotalRuns() - Method in interface com.hazelcast.scheduledexecutor.ScheduledTaskStatistics
Returns how many times the task was ran/called.
getTotalRunTime(TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.ScheduledTaskStatistics
Returns the total amount of time the task spent while scheduled in.
getTotalStartLatency() - Method in interface com.hazelcast.monitor.LocalExecutorStats
Returns the total start latency of operations started.
getTotalUpdateLatency() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the total latency (in nanoseconds) of update operations performed on the index.
getTrackableJob(String) - Method in interface com.hazelcast.mapreduce.JobTracker
Deprecated.
Returns an implementation of TrackableJob, or null if the job ID is not available or the job is already finished.
getTransactionalObject(String, String) - Method in class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
 
getTransactionalObject(String, String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
Returns the transactional object instance with the specified name and service name.
getTransactionContext(HazelcastInstance) - Static method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
Returns the transaction context for the given Hazelcast instance bounded to the current thread.
getTransactionContext() - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
Returns the transaction context
getTransactionContext() - Method in interface com.hazelcast.transaction.HazelcastXAResource
Returns the TransactionContext associated with the current thread.
getTransactionManager() - Method in class com.hazelcast.client.spi.ClientContext
 
getTransactionManagerService() - Method in interface com.hazelcast.spi.NodeEngine
Gets the TransactionManagerService.
getTransactionType() - Method in class com.hazelcast.transaction.TransactionOptions
getTrustedInterfaces() - Method in class com.hazelcast.config.MulticastConfig
Gets the trusted interfaces.
getTryCount() - Method in class com.hazelcast.spi.InvocationBuilder
Gets the try count; the number of times this operation can be retried.
getTryPauseMillis() - Method in class com.hazelcast.spi.InvocationBuilder
Gets the pause time in milliseconds.
getTtl() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
getTtl() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
getTtl() - Method in interface com.hazelcast.core.EntryView
Returns the last set time to live in milliseconds.
getTtl() - Method in interface com.hazelcast.spi.merge.MergingTTL
Returns the TTL of the merge data.
getTxnId() - Method in interface com.hazelcast.transaction.TransactionContext
Gets the ID that uniquely identifies the transaction.
getType() - Method in enum com.hazelcast.cache.CacheEventType
 
getType() - Method in interface com.hazelcast.cache.journal.EventJournalCacheEvent
Returns the event type.
getType() - Method in interface com.hazelcast.cluster.Joiner
Deprecated.
 
getType() - Method in class com.hazelcast.config.PermissionConfig
 
getType(String) - Static method in enum com.hazelcast.config.PermissionConfig.PermissionType
 
getType() - Method in class com.hazelcast.config.QuorumConfig
 
getType() - Method in enum com.hazelcast.core.EntryEventType
 
getType() - Method in enum com.hazelcast.core.ItemEventType
 
getType() - Method in interface com.hazelcast.map.journal.EventJournalMapEvent
Returns the event type.
getType() - Method in interface com.hazelcast.nio.Connection
Returns the ConnectionType of this Connection.
getType() - Method in interface com.hazelcast.nio.serialization.Data
Returns serialization type of binary form.
getType() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
 
getTypeClass() - Method in class com.hazelcast.config.SerializerConfig
Gets the type of the class that will be serialized via this implementation.
getTypeClassName() - Method in class com.hazelcast.config.SerializerConfig
Gets the name of the class that will be serialized via this implementation.
getTypeId() - Method in interface com.hazelcast.nio.serialization.Serializer
 
getTypeSize() - Method in enum com.hazelcast.nio.serialization.FieldType
 
getUnit() - Method in class com.hazelcast.memory.MemorySize
Returns unit of memory size
getUnknownCollectionCount() - Method in class com.hazelcast.memory.DefaultGarbageCollectorStats
 
getUnknownCollectionCount() - Method in interface com.hazelcast.memory.GarbageCollectorStats
Returns collection count which cannot be identified as major or minor.
getUnknownCollectionTime() - Method in class com.hazelcast.memory.DefaultGarbageCollectorStats
 
getUnknownCollectionTime() - Method in interface com.hazelcast.memory.GarbageCollectorStats
Returns total collection time which cannot be identified as major or minor.
getUpdateCount() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the number of update operations performed on the index.
getUpdateInterval() - Method in class com.hazelcast.config.ManagementCenterConfig
Gets the time frequency (in seconds) for which Management Center will take information from the Hazelcast cluster.
getUriString() - Method in class com.hazelcast.config.CacheConfig
Gets the URI string which is the global identifier for this ICache.
getUrl() - Method in class com.hazelcast.config.ManagementCenterConfig
Gets the URL where management center will work.
getUsage() - Method in class com.hazelcast.config.LoginModuleConfig
 
getUsedHeap() - Method in class com.hazelcast.memory.DefaultMemoryStats
 
getUsedHeap() - Method in interface com.hazelcast.memory.MemoryStats
Returns the amount of used memory in the JVM in bytes.
getUsedMetadata() - Method in class com.hazelcast.memory.DefaultMemoryStats
 
getUsedMetadata() - Method in interface com.hazelcast.memory.MemoryStats
 
getUsedNative() - Method in class com.hazelcast.memory.DefaultMemoryStats
 
getUsedNative() - Method in interface com.hazelcast.memory.MemoryStats
Returns the amount of used native memory in current HazelcastInstance in bytes.
getUserCodeDeploymentConfig() - Method in class com.hazelcast.client.config.ClientConfig
Get current configuration of User Code Deployment.
getUserCodeDeploymentConfig() - Method in class com.hazelcast.config.Config
Get current configuration of User Code Deployment.
getUserContext() - Method in class com.hazelcast.client.config.ClientConfig
 
getUserContext() - Method in class com.hazelcast.config.Config
Returns the user supplied context.
getUserContext() - Method in interface com.hazelcast.core.HazelcastInstance
Returns a ConcurrentMap that can be used to add user-context to the HazelcastInstance.
getUserExecutor() - Method in interface com.hazelcast.client.spi.ClientExecutionService
 
getUsername() - Method in class com.hazelcast.security.UsernamePasswordCredentials
Gets the user name.
getUuid() - Method in interface com.hazelcast.core.Client
Returns a unique UUID for this client.
getUuid() - Method in interface com.hazelcast.core.Endpoint
Returns the unique UUID for this endpoint.
getUuid() - Method in interface com.hazelcast.core.Member
Returns the UUID of this member.
getValidationTimeoutSeconds() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Returns configured validation timeout for hot-restart process.
getValue() - Method in interface com.hazelcast.cache.CacheEntryView
Gets the value of the cache entry.
getValue(int) - Static method in enum com.hazelcast.cluster.MemberAttributeOperationType
Gets the MemberAttributeOperationType by ID.
getValue() - Method in class com.hazelcast.core.EntryEvent
Returns the value of the entry event.
getValue() - Method in interface com.hazelcast.core.EntryView
Returns the value of the entry.
getValue() - Method in class com.hazelcast.core.MemberAttributeEvent
Returns the value for this MemberAttributeEvent.
getValue() - Method in class com.hazelcast.memory.MemorySize
Returns value of memory size in its original unit.
getValue() - Method in interface com.hazelcast.monitor.LocalPNCounterStats
Returns the current value of this PN counter
getValue() - Method in interface com.hazelcast.spi.merge.MergingValue
Returns the merging value in the in-memory format of the backing data structure.
getValueClassName() - Method in class com.hazelcast.config.AbstractCacheConfig
 
getValueCollectionType() - Method in class com.hazelcast.config.MultiMapConfig
Gets the collection type for the values of this MultiMap.
getValueType() - Method in class com.hazelcast.config.AbstractCacheConfig
 
getValueType() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the value type for this ICache.
getVectorClocks() - Method in class com.hazelcast.crdt.CRDTReplicationContainer
Returns the vector clocks for the CRDTs replicated by the replication operation.
getVersion() - Method in interface com.hazelcast.core.EntryView
Returns the version of the entry.
getVersion() - Method in interface com.hazelcast.core.Member
Returns the Hazelcast codebase version of this member; this may or may not be different from the version reported by Cluster.getClusterVersion(), for example when a node with a different codebase version is added to an existing cluster.
getVersion() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
Returns the version.
getVersion() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
getVersion() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
 
getVersion() - Method in interface com.hazelcast.nio.serialization.PortableReader
 
getVersion() - Method in interface com.hazelcast.nio.VersionAware
 
getVersion() - Method in interface com.hazelcast.spi.merge.MergingVersion
Returns the version of the merge data.
getVersion() - Method in interface com.hazelcast.spi.NodeEngine
Returns the codebase version of the node.
getWaitKey() - Method in interface com.hazelcast.spi.BlockingOperation
 
getWaitTimeout() - Method in interface com.hazelcast.spi.BlockingOperation
 
getWaitTimeout() - Method in class com.hazelcast.spi.Operation
Returns the wait timeout in millis.
getWanConsumerConfig() - Method in class com.hazelcast.config.WanReplicationConfig
Returns the WAN consumer configuration for this WAN replication.
getWanPublisherConfigs() - Method in class com.hazelcast.config.WanReplicationConfig
Returns the list of configured WAN publisher targets for this WAN replication.
getWanReplicationConfig(String) - Method in class com.hazelcast.config.Config
Returns the WAN replication configuration with the given name.
getWanReplicationConfigs() - Method in class com.hazelcast.config.Config
Returns the map of WAN replication configurations, mapped by config name.
getWanReplicationPublisher(String) - Method in interface com.hazelcast.wan.WanReplicationService
Creates a new WanReplicationPublisher by the given name.
getWanReplicationRef() - Method in class com.hazelcast.config.CacheConfig
 
getWanReplicationRef() - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
getWanReplicationRef() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the WAN target replication reference.
getWanReplicationRef() - Method in class com.hazelcast.config.MapConfig
Gets the WAN target replication reference.
getWanReplicationRef() - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
getWanReplicationService() - Method in interface com.hazelcast.spi.NodeEngine
Gets the WanReplicationService.
getWanSyncConfig() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the config for the WAN sync mechanism.
getWanSyncState() - Method in interface com.hazelcast.monitor.MemberState
 
getWanSyncState() - Method in interface com.hazelcast.wan.WanReplicationService
Returns current status of WAN sync operation
getWhitelist() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
getWhitelistedPrefixes() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Return currently configured whitelist prefixes
getWriteBatchSize() - Method in class com.hazelcast.config.MapStoreConfig
Returns the number of operations to be included in each batch processing round.
getWriteDelaySeconds() - Method in class com.hazelcast.config.MapStoreConfig
Returns the number of seconds to delay the store writes.
getXAResource() - Method in interface com.hazelcast.core.HazelcastInstance
Gets xaResource which will participate in XATransaction.
getXaResource() - Method in interface com.hazelcast.transaction.TransactionContext
Deprecated.
since 3.5 please use HazelcastInstance.getXAResource()
getXmlType() - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
 
getXmlType() - Method in class com.hazelcast.config.AbstractConfigBuilder
 
getXmlType() - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
getXmlType() - Method in class com.hazelcast.config.XmlConfigBuilder
 
gigaBytes() - Method in class com.hazelcast.memory.MemorySize
Returns value of memory size in giga-bytes.
GlobalSerializerConfig - Class in com.hazelcast.config
Contains the configuration for global serializer.
GlobalSerializerConfig() - Constructor for class com.hazelcast.config.GlobalSerializerConfig
 
GRACEFUL_SHUTDOWN_MAX_WAIT - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
GracefulShutdownAwareService - Interface in com.hazelcast.spi
An interface that can be implemented by SPI services to participate in graceful shutdown process, such as moving their internal data to another node or releasing their allocated resources gracefully.
greaterEqual(Comparable) - Method in class com.hazelcast.query.EntryObject
 
greaterEqual(String, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates a greater than or equal to predicate that will pass items if the value stored under the given item attribute is greater than or equal to the given value.
greaterThan(Comparable) - Method in class com.hazelcast.query.EntryObject
 
greaterThan(String, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates a greater than predicate that will pass items if the value stored under the given item attribute is greater than the given value.
GROUP - Static variable in class com.hazelcast.spi.discovery.multicast.MulticastProperties
Property used to define zones for node filtering.
GroupConfig - Class in com.hazelcast.config
Contains the configuration for Hazelcast groups.
GroupConfig() - Constructor for class com.hazelcast.config.GroupConfig
Creates a GroupConfig with default group-name and group-password.
GroupConfig(String) - Constructor for class com.hazelcast.config.GroupConfig
Creates a GroupConfig with the given group-name and default group-password
GroupConfig(String, String) - Constructor for class com.hazelcast.config.GroupConfig
Creates a GroupConfig with the given group-name and group-password
GroupProperty - Class in com.hazelcast.spi.properties
Defines the name and default value for Hazelcast properties.

H

handle(E) - Method in interface com.hazelcast.client.spi.EventHandler
 
handleAddListener(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleClear(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleClient(Element) - Method in class com.hazelcast.spring.HazelcastClientBeanDefinitionParser.SpringXmlBuilder
 
handleCommand(String) - Method in class com.hazelcast.console.ConsoleApp
Handles a command.
handleCommonBeanAttributes(Node, BeanDefinitionBuilder, ParserContext) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleContains(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleDataSerializableFactories(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleDestroy(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleDiscoveryStrategies(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleExcludedMemberUuids(Address, Set<String>) - Method in interface com.hazelcast.hotrestart.InternalHotRestartService
Handles the UUID set of excluded members only if this member is also excluded, and triggers the member force start process.
handleExcludedMemberUuids(Address, Set<String>) - Method in class com.hazelcast.hotrestart.NoopInternalHotRestartService
 
handleExit() - Method in class com.hazelcast.console.ConsoleApp
 
handleInstances(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleIterator(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleJavaSerializationFilter(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleListAdd(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleListAddMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleListContains(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleListRemove(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleListSet(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapDelete(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapEntries() - Method in class com.hazelcast.console.ConsoleApp
 
handleMapEvict(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapGet(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapGetAsync(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapGetMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapGetMapEntry(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapKeys() - Method in class com.hazelcast.console.ConsoleApp
 
handleMapLocalKeys() - Method in class com.hazelcast.console.ConsoleApp
 
handleMapLocalSize() - Method in class com.hazelcast.console.ConsoleApp
 
handleMapLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapPut(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapPutAsync(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapPutIfAbsent(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapPutMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapRemove(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapRemoveMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapReplace(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapTryLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapUnlock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapValues() - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapEntries() - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapGet(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapKeys() - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapPut(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapRemove(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapTryLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapUnlock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapValues() - Method in class com.hazelcast.console.ConsoleApp
 
handlePartitions(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handlePortableFactories(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleProperties(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleQCapacity(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQOffer(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQOfferMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQPeek(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQPoll(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQPollMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQTake(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleRemoveListener(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleSerialization(Node) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleSerializers(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleSetAdd(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleSetAddMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleSetRemove(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleSetRemoveMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleShutdown() - Method in class com.hazelcast.console.ConsoleApp
 
handleSize(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleSocketInterceptorConfig(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleSpringAware() - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleTopicPublish(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
hasActiveInvocation(Operation) - Static method in class com.hazelcast.spi.OperationAccessor
 
hasDefiniteSize() - Method in enum com.hazelcast.nio.serialization.FieldType
 
hasEventRegistration(String, String) - Method in interface com.hazelcast.spi.EventService
Returns true if a listener is registered with the specified service name and topic.
hasField(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
Checks if there exists a FieldDefinition with the given fieldName.
hasField(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
hash64() - Method in interface com.hazelcast.nio.serialization.Data
Returns 64-bit hash code for this Data object.
hashCode() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
 
hashCode() - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
 
hashCode() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
 
hashCode() - Method in class com.hazelcast.client.spi.ClientProxy
 
hashCode() - Method in class com.hazelcast.config.AbstractCacheConfig
 
hashCode() - Method in class com.hazelcast.config.AtomicLongConfig
 
hashCode() - Method in class com.hazelcast.config.AtomicReferenceConfig
 
hashCode() - Method in class com.hazelcast.config.CacheConfig
 
hashCode() - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
 
hashCode() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
hashCode() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
hashCode() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
hashCode() - Method in class com.hazelcast.config.CacheSimpleConfig
 
hashCode() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
hashCode() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
hashCode() - Method in class com.hazelcast.config.ClassFilter
 
hashCode() - Method in class com.hazelcast.config.CollectionConfig
 
hashCode() - Method in class com.hazelcast.config.CountDownLatchConfig
 
hashCode() - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
hashCode() - Method in class com.hazelcast.config.DurableExecutorConfig
 
hashCode() - Method in class com.hazelcast.config.EntryListenerConfig
 
hashCode() - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
hashCode() - Method in class com.hazelcast.config.EventJournalConfig
 
hashCode() - Method in class com.hazelcast.config.EvictionConfig
 
hashCode() - Method in class com.hazelcast.config.ExecutorConfig
 
hashCode() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
hashCode() - Method in class com.hazelcast.config.GlobalSerializerConfig
 
hashCode() - Method in class com.hazelcast.config.GroupConfig
 
hashCode() - Method in class com.hazelcast.config.HotRestartConfig
 
hashCode() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
 
hashCode() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
hashCode() - Method in class com.hazelcast.config.InterfacesConfig
 
hashCode() - Method in class com.hazelcast.config.ItemListenerConfig
 
hashCode() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
hashCode() - Method in class com.hazelcast.config.ListenerConfig
 
hashCode() - Method in class com.hazelcast.config.LockConfig
 
hashCode() - Method in class com.hazelcast.config.LoginModuleConfig
 
hashCode() - Method in class com.hazelcast.config.MapAttributeConfig
 
hashCode() - Method in class com.hazelcast.config.MapConfig
 
hashCode() - Method in class com.hazelcast.config.MapIndexConfig
 
hashCode() - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
 
hashCode() - Method in class com.hazelcast.config.MapStoreConfig
 
hashCode() - Method in class com.hazelcast.config.MaxSizeConfig
 
hashCode() - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
hashCode() - Method in class com.hazelcast.config.MemberGroupConfig
 
hashCode() - Method in class com.hazelcast.config.MergePolicyConfig
 
hashCode() - Method in class com.hazelcast.config.MerkleTreeConfig
 
hashCode() - Method in class com.hazelcast.config.MulticastConfig
 
hashCode() - Method in class com.hazelcast.config.MultiMapConfig
 
hashCode() - Method in class com.hazelcast.config.NativeMemoryConfig
 
hashCode() - Method in class com.hazelcast.config.NearCacheConfig
 
hashCode() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
hashCode() - Method in class com.hazelcast.config.PartitionGroupConfig
 
hashCode() - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
hashCode() - Method in class com.hazelcast.config.PermissionConfig
 
hashCode() - Method in class com.hazelcast.config.PermissionPolicyConfig
 
hashCode() - Method in class com.hazelcast.config.PNCounterConfig
 
hashCode() - Method in class com.hazelcast.config.PredicateConfig
 
hashCode() - Method in class com.hazelcast.config.QueryCacheConfig
 
hashCode() - Method in class com.hazelcast.config.QueueConfig
 
hashCode() - Method in class com.hazelcast.config.QueueStoreConfig
 
hashCode() - Method in class com.hazelcast.config.ReliableTopicConfig
 
hashCode() - Method in class com.hazelcast.config.ReplicatedMapConfig
 
hashCode() - Method in class com.hazelcast.config.RingbufferConfig
 
hashCode() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
hashCode() - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
hashCode() - Method in class com.hazelcast.config.SecurityConfig
 
hashCode() - Method in class com.hazelcast.config.SemaphoreConfig
 
hashCode() - Method in class com.hazelcast.config.SerializerConfig
 
hashCode() - Method in class com.hazelcast.config.ServiceConfig
 
hashCode() - Method in class com.hazelcast.config.ServicesConfig
 
hashCode() - Method in class com.hazelcast.config.SocketInterceptorConfig
 
hashCode() - Method in class com.hazelcast.config.TcpIpConfig
 
hashCode() - Method in class com.hazelcast.config.TopicConfig
 
hashCode() - Method in class com.hazelcast.config.WanReplicationRef
 
hashCode() - Method in class com.hazelcast.core.LifecycleEvent
 
hashCode() - Method in class com.hazelcast.core.PartitionAwareKey
 
hashCode() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
hashCode() - Method in class com.hazelcast.map.eviction.LFUEvictionPolicy
 
hashCode() - Method in class com.hazelcast.map.eviction.LRUEvictionPolicy
 
hashCode() - Method in class com.hazelcast.map.eviction.RandomEvictionPolicy
 
hashCode() - Method in class com.hazelcast.memory.MemorySize
 
hashCode() - Method in class com.hazelcast.nio.Address
 
hashCode() - Method in class com.hazelcast.nio.Packet
 
hashCode() - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
hashCode() - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
hashCode() - Method in class com.hazelcast.query.PartitionPredicate
 
hashCode() - Method in class com.hazelcast.query.SqlPredicate
 
hashCode() - Method in class com.hazelcast.query.TruePredicate
 
hashCode() - Method in class com.hazelcast.security.AbstractCredentials
 
hashCode() - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
hashCode() - Method in class com.hazelcast.security.permission.AllPermissions
 
hashCode() - Method in class com.hazelcast.security.permission.ClusterPermission
 
hashCode() - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
 
hashCode() - Method in class com.hazelcast.security.permission.InstancePermission
 
hashCode() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
hashCode() - Method in class com.hazelcast.spi.AbstractWaitNotifyKey
 
hashCode() - Method in class com.hazelcast.spi.DefaultObjectNamespace
Deprecated.
 
hashCode() - Method in class com.hazelcast.spi.PartitionMigrationEvent
 
hashCode() - Method in class com.hazelcast.version.MemberVersion
 
hashCode() - Method in class com.hazelcast.version.Version
 
hasListenerConfiguration() - Method in class com.hazelcast.config.AbstractCacheConfig
 
hasMember(Member) - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
hasMember(Member) - Method in interface com.hazelcast.partition.membergroup.MemberGroup
 
hasMember(Member) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
hasNext() - Method in class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
Called to request if at least one more key-value pair is available from this data source.
hasNext() - Method in class com.hazelcast.spi.merge.RingbufferMergeDataReadOnlyIterator
 
hasOnGoingMigration() - Method in interface com.hazelcast.spi.partition.IPartitionService
Checks if there are any cluster-wide migrations.
hasOnGoingMigrationLocal() - Method in interface com.hazelcast.spi.partition.IPartitionService
Checks if there are any local migrations.
hasPartitionHash() - Method in interface com.hazelcast.nio.serialization.Data
Returns true if Data has partition hash, false otherwise.
hasTextContent(Node) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
Hazelcast - Class in com.hazelcast.core
Factory for HazelcastInstance's, a node in a cluster.
HAZELCAST_ARRAY - Static variable in class com.hazelcast.nio.ClassLoaderUtil
 
HAZELCAST_BASE_PACKAGE - Static variable in class com.hazelcast.nio.ClassLoaderUtil
 
HAZELCAST_CLOUD_DISCOVERY_TOKEN - Static variable in class com.hazelcast.client.spi.properties.ClientProperty
Token to use when discovering cluster via hazelcast.cloud
HAZELCAST_CONFIG_LOCATION - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
Hazelcast config location property
HAZELCAST_INSTANCE_ITSELF - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
Hazelcast instance itself property
HAZELCAST_INSTANCE_NAME - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
Hazelcast instance name property
HAZELCAST_OSGI_GROUPING_DISABLED - Static variable in interface com.hazelcast.osgi.HazelcastOSGiService
System property for disabling the behaviour that gives different group name to each Hazelcast bundle.
HAZELCAST_OSGI_JSR223_DISABLED - Static variable in interface com.hazelcast.osgi.HazelcastOSGiService
System property for disabling the JSR-223 script engine scan by the Hazelcast OSGI service.
HAZELCAST_OSGI_REGISTER_DISABLED - Static variable in interface com.hazelcast.osgi.HazelcastOSGiService
System property for disabling the behaviour that registers created Hazelcast instances as OSGI service.
HAZELCAST_OSGI_START - Static variable in interface com.hazelcast.osgi.HazelcastOSGiService
System property for starting a default Hazelcast instance per Hazelcast OSGI bundle.
HazelcastCache - Class in com.hazelcast.spring.cache
Sprint related Cache implementation for Hazelcast.
HazelcastCache(IMap<Object, Object>) - Constructor for class com.hazelcast.spring.cache.HazelcastCache
 
HazelcastCacheManager - Interface in com.hazelcast.cache
Contract point of Hazelcast cache manager implementations (client + server) based on CacheManager.
HazelcastCacheManager - Class in com.hazelcast.spring.cache
Sprint related HazelcastCacheManager implementation for Hazelcast.
HazelcastCacheManager() - Constructor for class com.hazelcast.spring.cache.HazelcastCacheManager
 
HazelcastCacheManager(HazelcastInstance) - Constructor for class com.hazelcast.spring.cache.HazelcastCacheManager
 
HazelcastCachingProvider - Class in com.hazelcast.cache
Hazelcast implementation of JCache CachingProvider.
HazelcastCachingProvider() - Constructor for class com.hazelcast.cache.HazelcastCachingProvider
 
HazelcastClient - Class in com.hazelcast.client
The HazelcastClient is comparable to the Hazelcast class and provides the ability the create and manage Hazelcast clients.
HazelcastClientBeanDefinitionParser - Class in com.hazelcast.spring
BeanDefinitionParser for Hazelcast Client Configuration.
HazelcastClientBeanDefinitionParser() - Constructor for class com.hazelcast.spring.HazelcastClientBeanDefinitionParser
 
HazelcastClientBeanDefinitionParser.SpringXmlBuilder - Class in com.hazelcast.spring
Client bean definition builder
HazelcastClientFactory<T extends com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl,V extends com.hazelcast.client.impl.clientside.HazelcastClientProxy,C extends ClientConfig> - Interface in com.hazelcast.client
Provides the capability for the customization of Hazelcast client factories.
HazelcastClientManager - Class in com.hazelcast.client
Central manager for all Hazelcast clients of the JVM.
HazelcastClientNotActiveException - Exception in com.hazelcast.client
Thrown when Hazelcast client is not active during an invocation.
HazelcastClientNotActiveException(String) - Constructor for exception com.hazelcast.client.HazelcastClientNotActiveException
 
HazelcastClientNotActiveException(String, Throwable) - Constructor for exception com.hazelcast.client.HazelcastClientNotActiveException
 
HazelcastClientOfflineException - Exception in com.hazelcast.client
Thrown when Hazelcast client is offline during an invocation.
HazelcastClientOfflineException(String) - Constructor for exception com.hazelcast.client.HazelcastClientOfflineException
 
HazelcastConfigBeanDefinitionParser - Class in com.hazelcast.spring
BeanDefinitionParser for Hazelcast Config Configuration.
HazelcastConfigBeanDefinitionParser() - Constructor for class com.hazelcast.spring.HazelcastConfigBeanDefinitionParser
 
HazelcastException - Exception in com.hazelcast.core
Base Hazelcast exception.
HazelcastException() - Constructor for exception com.hazelcast.core.HazelcastException
 
HazelcastException(String) - Constructor for exception com.hazelcast.core.HazelcastException
 
HazelcastException(String, Throwable) - Constructor for exception com.hazelcast.core.HazelcastException
 
HazelcastException(Throwable) - Constructor for exception com.hazelcast.core.HazelcastException
 
HazelcastExpiryPolicy - Class in com.hazelcast.cache
Hazelcast provides overloads of the typical cache operations with a custom ExpiryPolicy parameter.
This class provides a custom implementation of an ExpiryPolicy to react on all three types of policies: Create Access Update
HazelcastExpiryPolicy() - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
Default constructor to serialize/deserialize
HazelcastExpiryPolicy(long, long, long) - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
Constructs an expiry policy with provided values for creation, access and update in milliseconds.
HazelcastExpiryPolicy(long, long, long, TimeUnit) - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
Constructs an expiry policy with provided values for creation, access and update as well as a TimeUnit to convert those values to internally used time unites.
HazelcastExpiryPolicy(ExpiryPolicy) - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
Copy Constructor for an already existing ExpiryPolicy.
HazelcastExpiryPolicy(Duration, Duration, Duration) - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
Constructs an expiry policy with provided values for creation, access and update by providing instances of the Duration class.
HazelcastInstance - Interface in com.hazelcast.core
Hazelcast instance.
HazelcastInstanceAware - Interface in com.hazelcast.core
Used to get HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService.
HazelcastInstanceDefinitionParser - Class in com.hazelcast.spring
BeanDefinitionParser for Hazelcast Instance Configuration.
HazelcastInstanceDefinitionParser() - Constructor for class com.hazelcast.spring.HazelcastInstanceDefinitionParser
 
HazelcastInstanceNotActiveException - Exception in com.hazelcast.core
Thrown when HazelcastInstance is not active during an invocation.
HazelcastInstanceNotActiveException() - Constructor for exception com.hazelcast.core.HazelcastInstanceNotActiveException
 
HazelcastInstanceNotActiveException(String) - Constructor for exception com.hazelcast.core.HazelcastInstanceNotActiveException
 
HazelcastNamespaceHandler - Class in com.hazelcast.spring
Hazelcast Custom Namespace Definitions.
HazelcastNamespaceHandler() - Constructor for class com.hazelcast.spring.HazelcastNamespaceHandler
 
HazelcastOSGiInstance - Interface in com.hazelcast.osgi
Contract point for HazelcastInstance implementations based on OSGi service.
HazelcastOSGiService - Interface in com.hazelcast.osgi
Contract point for Hazelcast services on top of OSGI.
HazelcastOverloadException - Exception in com.hazelcast.core
A HazelcastException that is thrown when the system won't handle more load due to an overload.
HazelcastOverloadException(String) - Constructor for exception com.hazelcast.core.HazelcastOverloadException
 
HazelcastOverloadException(String, Throwable) - Constructor for exception com.hazelcast.core.HazelcastOverloadException
 
HazelcastProperties - Class in com.hazelcast.spi.properties
Container for configured Hazelcast properties (HazelcastProperty).
HazelcastProperties(Config) - Constructor for class com.hazelcast.spi.properties.HazelcastProperties
Creates a container with configured Hazelcast properties.
HazelcastProperties(Properties) - Constructor for class com.hazelcast.spi.properties.HazelcastProperties
Creates a container with configured Hazelcast properties.
HazelcastProperty - Class in com.hazelcast.spi.properties
Interface for Hazelcast Member and Client properties.
HazelcastProperty(String) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, boolean) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, Integer) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, Byte) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, Integer, TimeUnit) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, Long, TimeUnit) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, HazelcastProperty) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, String) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, String, TimeUnit) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, String, TimeUnit, HazelcastProperty) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastSerializationException - Exception in com.hazelcast.nio.serialization
This is an exception thrown when an exception occurs while serializing/deserializing objects.
HazelcastSerializationException(String) - Constructor for exception com.hazelcast.nio.serialization.HazelcastSerializationException
 
HazelcastSerializationException(String, Throwable) - Constructor for exception com.hazelcast.nio.serialization.HazelcastSerializationException
 
HazelcastSerializationException(Throwable) - Constructor for exception com.hazelcast.nio.serialization.HazelcastSerializationException
 
HazelcastTransactionManager - Class in com.hazelcast.spring.transaction
PlatformTransactionManager implementation for a single HazelcastInstance.
HazelcastTransactionManager(HazelcastInstance) - Constructor for class com.hazelcast.spring.transaction.HazelcastTransactionManager
 
HazelcastTypeBeanDefinitionParser - Class in com.hazelcast.spring
BeanDefinitionParser for Type Configuration of Hazelcast Types like map, queue, topic etc.
HazelcastTypeBeanDefinitionParser(String) - Constructor for class com.hazelcast.spring.HazelcastTypeBeanDefinitionParser
 
HazelcastXAResource - Interface in com.hazelcast.transaction
Interface for providing Hazelcast as an XAResource
headSequence() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Returns the sequence of the head.
HEALTH_MONITORING_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
HEALTH_MONITORING_LEVEL - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
HEALTH_MONITORING_THRESHOLD_CPU_PERCENTAGE - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
HEALTH_MONITORING_THRESHOLD_MEMORY_PERCENTAGE - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
HEARTBEAT_FAILURE_DETECTOR_TYPE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Heartbeat failure detector type.
HEARTBEAT_INTERVAL - Static variable in class com.hazelcast.client.spi.properties.ClientProperty
Time interval between the heartbeats sent by the client to the nodes.
HEARTBEAT_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The interval at which member heartbeat messages are sent
HEARTBEAT_TIMEOUT - Static variable in class com.hazelcast.client.spi.properties.ClientProperty
Client sends heartbeat messages to the members and this is the timeout for this sending operations.
HeartbeatAware - Interface in com.hazelcast.quorum
QuorumFunctions which implement this interface will be notified of member heartbeats.
HigherHitsCacheMergePolicy - Class in com.hazelcast.cache.merge
Merges cache entries from source to destination cache if the source entry has more hits than the destination one.
HigherHitsCacheMergePolicy() - Constructor for class com.hazelcast.cache.merge.HigherHitsCacheMergePolicy
 
HigherHitsMapMergePolicy - Class in com.hazelcast.map.merge
Merges map entries from source to destination map if the source entry has more hits than the destination one.
HigherHitsMapMergePolicy() - Constructor for class com.hazelcast.map.merge.HigherHitsMapMergePolicy
 
HigherHitsMapMergePolicy - Class in com.hazelcast.replicatedmap.merge
Merges replicated map entries from source to destination map if the source entry has more hits than the destination one.
HigherHitsMergePolicy<V,T extends MergingHits<V>> - Class in com.hazelcast.spi.merge
Merges data structure entries from source to destination data structure if the source entry has more hits than the destination one.
HigherHitsMergePolicy() - Constructor for class com.hazelcast.spi.merge.HigherHitsMergePolicy
 
HostAwareMemberGroupFactory - Class in com.hazelcast.partition.membergroup
 
HostAwareMemberGroupFactory() - Constructor for class com.hazelcast.partition.membergroup.HostAwareMemberGroupFactory
 
HOT_RESTART_BASE_DIR_DEFAULT - Static variable in class com.hazelcast.config.HotRestartPersistenceConfig
Default directory name for the Hot Restart store's home
HOT_RESTART_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
HotRestartClusterDataRecoveryPolicy - Enum in com.hazelcast.config
Specifies the policy that will be respected during hot restart cluster start
hotRestartConfig - Variable in class com.hazelcast.config.AbstractCacheConfig
 
HotRestartConfig - Class in com.hazelcast.config
Configures the Hot Restart Persistence per Hazelcast data structure.
HotRestartConfig() - Constructor for class com.hazelcast.config.HotRestartConfig
 
HotRestartConfig(HotRestartConfig) - Constructor for class com.hazelcast.config.HotRestartConfig
 
HotRestartPersistenceConfig - Class in com.hazelcast.config
Configures the Hot Restart stores.
HotRestartPersistenceConfig() - Constructor for class com.hazelcast.config.HotRestartPersistenceConfig
 
HotRestartService - Interface in com.hazelcast.hotrestart
Service for interacting with Hot Restart.
HotRestartState - Interface in com.hazelcast.monitor
Hot Restart statistics to be used by MemberState implementations.
HTTP_HEALTHCHECK_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
HyperLogLogMergePolicy - Class in com.hazelcast.spi.merge
Only available for HyperLogLog backed CardinalityEstimator.
HyperLogLogMergePolicy() - Constructor for class com.hazelcast.spi.merge.HyperLogLogMergePolicy
 

I

IAtomicLong - Interface in com.hazelcast.core
IAtomicLong is a redundant and highly available distributed alternative to the AtomicLong.
IAtomicReference<E> - Interface in com.hazelcast.core
IAtomicReference is a redundant and highly available distributed alternative to the AtomicReference.
IBiFunction<T,U,R> - Interface in com.hazelcast.core
Represents a function that accepts two arguments and produces a result.
ICache<K,V> - Interface in com.hazelcast.cache
This ICache interface is the Cache extension offered by Hazelcast JCache.
In addition to the standard set of JCache methods defined in the JSR 107 specification, Hazelcast provides additional operations to support a broader range of programing styles.
ICacheManager - Interface in com.hazelcast.core
ICacheManager is the entry point to access JSR-107 (JCache) caches via HazelcastInstance interface.
ICMP_ECHO_FAIL_FAST - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
as of 3.10 this can be configured through IcmpFailureDetectorConfig This will be removed in future versions. Until this is done, if the IcmpFailureDetectorConfig is null we will still fall back to this
ICMP_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
as of 3.10 this can be configured through IcmpFailureDetectorConfig This will be removed in future versions. Until this is done, if the IcmpFailureDetectorConfig is null we will still fall back to this
ICMP_INTERVAL - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
as of 3.10 this can be configured through IcmpFailureDetectorConfig This will be removed in future versions. Until this is done, if the IcmpFailureDetectorConfig is null we will still fall back to this
ICMP_MAX_ATTEMPTS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
as of 3.10 this can be configured through IcmpFailureDetectorConfig This will be removed in future versions. Until this is done, if the IcmpFailureDetectorConfig is null we will still fall back to this
ICMP_PARALLEL_MODE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
as of 3.10 this can be configured through IcmpFailureDetectorConfig This will be removed in future versions. Until this is done, if the IcmpFailureDetectorConfig is null we will still fall back to this
ICMP_TIMEOUT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
as of 3.10 this can be configured through IcmpFailureDetectorConfig This will be removed in future versions. Until this is done, if the IcmpFailureDetectorConfig is null we will still fall back to this
ICMP_TTL - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
as of 3.10 this can be configured through IcmpFailureDetectorConfig This will be removed in future versions. Until this is done, if the IcmpFailureDetectorConfig is null we will still fall back to this
IcmpFailureDetectorConfig - Class in com.hazelcast.config
This Failure Detector may be configured in addition to one of Deadline and Phi Accual Failure Detectors.
It operates at Layer 3 of the OSI protocol, and provides much quicker and more deterministic detection of hardware
and other lower level events.
IcmpFailureDetectorConfig() - Constructor for class com.hazelcast.config.IcmpFailureDetectorConfig
 
ICollection<E> - Interface in com.hazelcast.core
Concurrent, distributed, partitioned, listenable collection.
ICompletableFuture<V> - Interface in com.hazelcast.core
A Future where one can asynchronously listen on completion.
ICondition - Interface in com.hazelcast.core
Distributed implementation of Condition.
ICountDownLatch - Interface in com.hazelcast.core
ICountDownLatch is a backed-up distributed alternative to the java.util.concurrent.CountDownLatch.
ICredentialsFactory - Interface in com.hazelcast.security
ICredentialsFactory is used to create Credentials objects to be used during node authentication before connection is accepted by the master node.
id() - Method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
 
IdentifiedDataSerializable - Interface in com.hazelcast.nio.serialization
IdentifiedDataSerializable is an extension to DataSerializable to avoid reflection during de-serialization.
identity() - Static method in class com.hazelcast.projection.Projections
Returns a projection that does no transformation.
IdGenerator - Interface in com.hazelcast.core
Deprecated.
The implementation can produce duplicate IDs in case of network split, even with split-brain protection enabled (during short window while split-brain is detected). Use HazelcastInstance.getFlakeIdGenerator(String) for an alternative implementation which does not suffer from this problem.
IExecutorService - Interface in com.hazelcast.core
Distributed implementation of ExecutorService.
IFunction<T,R> - Interface in com.hazelcast.core
Represents a function that accepts one argument and produces a result.
IgnoreMergingEntryMapMergePolicy - Class in com.hazelcast.map.merge
Ignores the merging entry while collecting merge-needed entries on merging side.
IgnoreMergingEntryMapMergePolicy() - Constructor for class com.hazelcast.map.merge.IgnoreMergingEntryMapMergePolicy
 
ilike(String, String) - Static method in class com.hazelcast.query.Predicates
Creates a case-insensitive like predicate that will pass items if the given pattern matches the value stored under the given item attribute in a case-insensitive manner.
IList<E> - Interface in com.hazelcast.core
Concurrent, distributed implementation of List.
ILock - Interface in com.hazelcast.core
Distributed implementation of Lock.
ILogger - Interface in com.hazelcast.logging
The Hazelcast logging interface.
IMap<K,V> - Interface in com.hazelcast.core
Concurrent, distributed, observable and queryable map.
IMapEvent - Interface in com.hazelcast.core
Map events common contract.
implementation - Variable in class com.hazelcast.config.ListenerConfig
 
implementation - Variable in class com.hazelcast.config.PredicateConfig
 
implementation - Variable in class com.hazelcast.config.SecurityInterceptorConfig
 
implementsInterfaceWithSameName(Class<?>, Class<?>) - Static method in class com.hazelcast.nio.ClassLoaderUtil
Check whether given class implements an interface with the same name.
implies(Permission) - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
implies(Permission) - Method in class com.hazelcast.security.permission.AllPermissions
 
implies(Permission) - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
 
implies(Permission) - Method in class com.hazelcast.security.permission.ConfigPermission
 
implies(Permission) - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
 
implies(Permission) - Method in class com.hazelcast.security.permission.InstancePermission
 
implies(Permission) - Method in class com.hazelcast.security.permission.TransactionPermission
 
in(Comparable...) - Method in class com.hazelcast.query.EntryObject
 
in(String, Comparable...) - Static method in class com.hazelcast.query.Predicates
Creates a in predicate that will pass items if the value stored under the given item attribute is a member of the given values set.
increaseHits() - Method in interface com.hazelcast.monitor.LocalRecordStoreStats
Increases the number of hits of the locally owned entries of this partition.
increaseHits(long) - Method in interface com.hazelcast.monitor.LocalRecordStoreStats
Increases the number of hits of the locally owned entries of this partition.
increasePermits(int) - Method in interface com.hazelcast.core.ISemaphore
Increases the number of available permits by the indicated amount.
incrementAndGet() - Method in interface com.hazelcast.core.IAtomicLong
Atomically increments the current value by one.
incrementAndGet() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Increments by one the current value.
incrementAndGet() - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
 
incrementAndGetAsync() - Method in interface com.hazelcast.core.IAtomicLong
Atomically increments the current value by one.
incrementEventCount(DistributedServiceWanEventCounters) - Method in interface com.hazelcast.wan.ReplicationEventObject
Increments the count for the related event in the counters
IndeterminateOperationStateException - Exception in com.hazelcast.core
IndeterminateOperationStateException is thrown when an invocation doesn't receive enough ACKs from the backup replicas in time.
IndeterminateOperationStateException() - Constructor for exception com.hazelcast.core.IndeterminateOperationStateException
 
IndeterminateOperationStateException(String) - Constructor for exception com.hazelcast.core.IndeterminateOperationStateException
 
IndeterminateOperationStateException(String, Throwable) - Constructor for exception com.hazelcast.core.IndeterminateOperationStateException
 
INDEX_COPY_BEHAVIOR - Static variable in class com.hazelcast.spi.properties.GroupProperty
Type of Query Index result copying behavior.
IndexAwarePredicate<K,V> - Interface in com.hazelcast.query
Extends the Predicate interface with the ability to support indexes.
info(String) - Method in class com.hazelcast.logging.AbstractLogger
 
info(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
info(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
info(String) - Method in interface com.hazelcast.logging.ILogger
Logs a message at the Level.INFO level.
info(Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a throwable at the Level.INFO level.
info(String, Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a message with an associated throwable at the Level.INFO level.
init(ClientContext) - Method in class com.hazelcast.client.connection.ClientConnectionStrategy
Initialize this strategy with client context and config
init(Cluster, ClientConfig) - Method in interface com.hazelcast.client.LoadBalancer
Initializes the LoadBalancer.
init(ClientConfig, ClientContext) - Method in class com.hazelcast.client.spi.ProxyManager
 
init(Properties) - Method in class com.hazelcast.config.replacer.AbstractPbeReplacer
 
init(Properties) - Method in class com.hazelcast.config.replacer.EncryptionReplacer
 
init(Properties) - Method in class com.hazelcast.config.replacer.PropertyReplacer
 
init(Properties) - Method in interface com.hazelcast.config.replacer.spi.ConfigReplacer
Initialization method called before first usage of the config replacer.
init(long) - Method in interface com.hazelcast.core.IdGenerator
Deprecated.
Tries to initialize this IdGenerator instance with the given ID.
init(InitialMembershipEvent) - Method in interface com.hazelcast.core.InitialMembershipListener
Called when this listener is registered.
init(int) - Method in interface com.hazelcast.core.ISemaphore
Try to initialize this ISemaphore instance with the given permit count
init(HazelcastInstance, Properties, String) - Method in interface com.hazelcast.core.MapLoaderLifecycleSupport
Initializes this MapLoader implementation.
init(NodeEngine, Properties) - Method in class com.hazelcast.crdt.CRDTReplicationMigrationService
 
init(NodeEngine, Properties) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
init(long) - Method in interface com.hazelcast.flakeidgen.FlakeIdGenerator
Deprecated.
init(byte[], int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
init(Properties) - Method in interface com.hazelcast.nio.SocketInterceptor
Initializes socket interceptor with properties which is set by Config.setProperty(String, String)
init(NodeEngine, Properties) - Method in interface com.hazelcast.spi.ManagedService
Initializes this service.
init(NodeEngineImpl, Set<Operation>) - Method in class com.hazelcast.spi.Offload
Initializes the Offload.
init() - Method in class com.hazelcast.spring.HazelcastNamespaceHandler
 
init(Node, WanReplicationConfig, WanPublisherConfig) - Method in interface com.hazelcast.wan.WanReplicationEndpoint
Initializes the endpoint using the given arguments.
INIT_CLUSTER_VERSION - Static variable in class com.hazelcast.spi.properties.GroupProperty
Override cluster version to use while node is not yet member of a cluster.
initDefaultMaxSizeForOnHeapMaps(NearCacheConfig) - Static method in class com.hazelcast.config.NearCacheConfigAccessor
 
INITIAL_MEMORY_SIZE - Static variable in class com.hazelcast.config.NativeMemoryConfig
Initial memory size in megabytes
INITIAL_MIN_CLUSTER_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
INITIAL_WAIT_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
initialize(Object) - Method in interface com.hazelcast.core.ManagedContext
Initialize the given object instance.
initialize(Context<KeyOut, ValueOut>) - Method in interface com.hazelcast.mapreduce.LifecycleMapper
Deprecated.
This method is called before the Mapper.map(Object, Object, Context) method is executed for every value and can be used to initialize the internal state of the mapper or to emit a special value.
initialize(Context<KeyOut, ValueOut>) - Method in class com.hazelcast.mapreduce.LifecycleMapperAdapter
Deprecated.
This method is called before the Mapper.map(Object, Object, Context) method is executed for every value and can be used to initialize the internal state of the mapper or to emit a special value.
initialize() - Method in interface com.hazelcast.spi.InitializingObject
 
initialize(Object) - Method in class com.hazelcast.spring.context.SpringManagedContext
 
initializeDistributedObject(String, String) - Method in interface com.hazelcast.spi.ProxyService
 
InitializingObject - Interface in com.hazelcast.spi
Can be implemented by DistributedObject (proxies) to indicate that they want to be initialized.
InitialMembershipEvent - Class in com.hazelcast.core
An event that is sent when a InitialMembershipListener registers itself on a Cluster.
InitialMembershipEvent(Cluster, Set<Member>) - Constructor for class com.hazelcast.core.InitialMembershipEvent
 
InitialMembershipListener - Interface in com.hazelcast.core
The InitializingMembershipListener is a MembershipListener that first receives a InitialMembershipEvent when it is registered so it immediately knows which members are available.
initMask(String[]) - Method in class com.hazelcast.security.permission.AtomicLongPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.AtomicReferencePermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.CachePermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.CardinalityEstimatorPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.CountDownLatchPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.DurableExecutorServicePermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.ExecutorServicePermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.FlakeIdGeneratorPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.InstancePermission
init mask
initMask(String[]) - Method in class com.hazelcast.security.permission.ListPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.LockPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.MapPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.MapReducePermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.PNCounterPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.QueuePermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.ReplicatedMapPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.RingBufferPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.ScheduledExecutorPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.SemaphorePermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.TopicPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.UserCodeDeploymentPermission
 
InMemoryFormat - Enum in com.hazelcast.config
Storage format type of values stored in cluster
InMemoryXmlConfig - Class in com.hazelcast.config
Creates a Config loaded from an in-memory Hazelcast XML String.
InMemoryXmlConfig(String) - Constructor for class com.hazelcast.config.InMemoryXmlConfig
Creates a Config from the provided XML string and uses the System.properties to resolve variables in the XML.
InMemoryXmlConfig(String, Properties) - Constructor for class com.hazelcast.config.InMemoryXmlConfig
Creates a Config from the provided XML string and properties to resolve the variables in the XML.
inProgress() - Method in enum com.hazelcast.hotrestart.BackupTaskState
Returns if the backup task is in progress.
INSTANCE - Static variable in class com.hazelcast.client.HazelcastClientManager
Global instance of HazelcastClientManager
INSTANCE - Static variable in class com.hazelcast.map.eviction.LFUEvictionPolicy
LFU eviction policy instance.
INSTANCE - Static variable in class com.hazelcast.map.eviction.LRUEvictionPolicy
LRU eviction policy instance.
INSTANCE - Static variable in class com.hazelcast.map.eviction.RandomEvictionPolicy
Random eviction policy instance.
INSTANCE - Static variable in class com.hazelcast.partition.strategy.StringAndPartitionAwarePartitioningStrategy
 
INSTANCE - Static variable in class com.hazelcast.partition.strategy.StringPartitioningStrategy
 
INSTANCE - Static variable in class com.hazelcast.query.TruePredicate
An instance of the TruePredicate.
INSTANCE - Static variable in class com.hazelcast.replicatedmap.merge.HigherHitsMapMergePolicy
Single instance of this class.
INSTANCE - Static variable in class com.hazelcast.replicatedmap.merge.LatestUpdateMapMergePolicy
Single instance of this class.
INSTANCE - Static variable in class com.hazelcast.replicatedmap.merge.PassThroughMergePolicy
Single instance of this class.
INSTANCE - Static variable in class com.hazelcast.replicatedmap.merge.PutIfAbsentMapMergePolicy
Single instance of this class.
instanceOf(Class) - Static method in class com.hazelcast.query.Predicates
Creates an instance of predicate that will pass entries for which the value class is an instanceof the given klass.
InstancePermission - Class in com.hazelcast.security.permission
TODO: Object Permission
InstancePermission(String, String...) - Constructor for class com.hazelcast.security.permission.InstancePermission
 
INT_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
INT_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
INT_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
Integer size in bytes
integerAvg() - Static method in class com.hazelcast.aggregation.Aggregators
 
integerAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
integerAvg() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to calculate the integer average of all supplied values.
This aggregation is similar to:
integerMax() - Static method in class com.hazelcast.aggregation.Aggregators
 
integerMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
integerMax() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to find the integer maximum of all supplied values.
This aggregation is similar to:
integerMin() - Static method in class com.hazelcast.aggregation.Aggregators
 
integerMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
integerMin() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to find the integer minimum of all supplied values.
This aggregation is similar to:
integerSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
integerSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
integerSum() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to calculate the integer sum of all supplied values.
This aggregation is similar to:
interceptAfter(Credentials, String, String, String) - Method in interface com.hazelcast.security.SecurityContext
intercepts a request after process if any SecurityInterceptor configured Any exception thrown during interception will be ignored
interceptBefore(Credentials, String, String, String, Object[]) - Method in interface com.hazelcast.security.SecurityContext
intercepts a request before process if any SecurityInterceptor configured
interceptGet(Object) - Method in interface com.hazelcast.map.MapInterceptor
Intercepts the get operation before returning value.
interceptPut(Object, Object) - Method in interface com.hazelcast.map.MapInterceptor
Intercepts the put operation before modifying the map data.
interceptRemove(Object) - Method in interface com.hazelcast.map.MapInterceptor
Intercepts the remove operation before removing the data.
interceptSocket(Socket, boolean) - Method in interface com.hazelcast.nio.IOService
 
interceptSocket(Socket, boolean) - Method in class com.hazelcast.nio.NodeIOService
 
InterfacesConfig - Class in com.hazelcast.config
Contains the configuration for Interfaces.
InterfacesConfig() - Constructor for class com.hazelcast.config.InterfacesConfig
 
InternalCompletableFuture<E> - Interface in com.hazelcast.spi
A ICompletableFuture with more functionality like getting the result without needing to deal with checked exceptions.
InternalHotRestartService - Interface in com.hazelcast.hotrestart
Internal service for interacting with hot restart related functionalities (e.g.
interruptBackupTask() - Method in interface com.hazelcast.hotrestart.HotRestartService
Interrupts the backup tasks on each cluster member if one is currently running.
interruptBackupTask() - Method in class com.hazelcast.hotrestart.NoOpHotRestartService
 
interruptLocalBackupTask() - Method in interface com.hazelcast.hotrestart.HotRestartService
Interrupts the local backup task if one is currently running.
interruptLocalBackupTask() - Method in class com.hazelcast.hotrestart.NoOpHotRestartService
 
invalidate() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
InvalidConfigurationException - Exception in com.hazelcast.config
A InvalidConfigurationException is thrown when there is an Invalid Configuration.
InvalidConfigurationException(String) - Constructor for exception com.hazelcast.config.InvalidConfigurationException
Creates a InvalidConfigurationException with the given message.
InvalidConfigurationException(String, Throwable) - Constructor for exception com.hazelcast.config.InvalidConfigurationException
Constructs a new runtime exception with the specified detail message and cause.
invertBit(byte, int) - Static method in class com.hazelcast.nio.Bits
Inverts n-th bit of the byte value
invertBit(int, int) - Static method in class com.hazelcast.nio.Bits
Inverts n-th bit of the integer value
INVOCATION_MAX_RETRY_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Maximum number of retries for an invocation.
INVOCATION_RETRY_PAUSE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Pause time between each retry cycle of an invocation in milliseconds.
INVOCATION_RETRY_PAUSE_MILLIS - Static variable in class com.hazelcast.client.spi.properties.ClientProperty
Pause time between each retry cycle of an invocation in milliseconds.
INVOCATION_TIMEOUT_SECONDS - Static variable in class com.hazelcast.client.spi.properties.ClientProperty
When an invocation gets an exception because : - Member throws an exception.
InvocationBuilder - Class in com.hazelcast.spi
The InvocationBuilder is responsible for building an invocation of an operation and invoking it.
InvocationBuilder(String, Operation, int, Address) - Constructor for class com.hazelcast.spi.InvocationBuilder
Creates an InvocationBuilder
invoke(ClientMessage, Object) - Method in class com.hazelcast.client.spi.ClientProxy
 
invoke(ClientMessage) - Method in class com.hazelcast.client.spi.ClientProxy
 
invoke() - Method in class com.hazelcast.spi.InvocationBuilder
 
invokeOnAddress(ClientMessage, Address) - Method in class com.hazelcast.client.spi.ClientProxy
 
invokeOnAllPartitions(String, OperationFactory) - Method in interface com.hazelcast.spi.OperationService
Invokes a set of operations on each partition.
invokeOnAllPartitionsAsync(String, OperationFactory, ExecutionCallback<Map<Integer, T>>) - Method in interface com.hazelcast.spi.OperationService
Invokes a set of operations on selected set of all partitions in an async way.
invokeOnConnection(ClientInvocation, ClientConnection) - Method in interface com.hazelcast.client.spi.ClientInvocationService
 
invokeOnPartition(ClientMessage, int) - Method in class com.hazelcast.client.spi.ClientProxy
 
invokeOnPartition(Operation) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
invokeOnPartition(String, Operation, int) - Method in interface com.hazelcast.spi.OperationService
 
invokeOnPartition(Operation) - Method in interface com.hazelcast.spi.OperationService
Executes an operation on a partition.
invokeOnPartitionInterruptibly(ClientMessage, int) - Method in class com.hazelcast.client.spi.ClientProxy
 
invokeOnPartitionOwner(ClientInvocation, int) - Method in interface com.hazelcast.client.spi.ClientInvocationService
 
invokeOnPartitions(String, OperationFactory, Collection<Integer>) - Method in interface com.hazelcast.spi.OperationService
Invokes a set of operations on selected set of partitions.
invokeOnPartitions(String, OperationFactory, int[]) - Method in interface com.hazelcast.spi.OperationService
Invokes a set of operations on selected set of partitions.
invokeOnPartitionsAsync(String, OperationFactory, Collection<Integer>, ExecutionCallback<Map<Integer, T>>) - Method in interface com.hazelcast.spi.OperationService
Invokes a set of operations on selected set of partitions in an async way.
invokeOnRandomTarget(ClientInvocation) - Method in interface com.hazelcast.client.spi.ClientInvocationService
 
invokeOnTarget(ClientInvocation, Address) - Method in interface com.hazelcast.client.spi.ClientInvocationService
 
invokeOnTarget(String, Operation, Address) - Method in interface com.hazelcast.spi.OperationService
 
IO_BALANCER_INTERVAL_SECONDS - Static variable in class com.hazelcast.client.spi.properties.ClientProperty
The interval in seconds between IOBalancer executions.
IO_BALANCER_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The interval in seconds between IOBalancer executions.
IO_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
Name of the io executor.
IO_INPUT_THREAD_COUNT - Static variable in class com.hazelcast.client.spi.properties.ClientProperty
Controls the number of socket input threads.
IO_INPUT_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Controls the number of socket input threads.
IO_OUTPUT_THREAD_COUNT - Static variable in class com.hazelcast.client.spi.properties.ClientProperty
Controls the number of socket output threads.
IO_OUTPUT_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Controls the number of socket output threads.
IO_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
The number of threads doing socket input and the number of threads doing socket output.
IOService - Interface in com.hazelcast.nio
 
IOUtil - Class in com.hazelcast.nio
 
IPartition - Interface in com.hazelcast.spi.partition
Represents a Partition.
IPartitionLostEvent - Class in com.hazelcast.spi.partition
IPartitionLostEvent() - Constructor for class com.hazelcast.spi.partition.IPartitionLostEvent
 
IPartitionLostEvent(int, int, Address) - Constructor for class com.hazelcast.spi.partition.IPartitionLostEvent
 
IPartitionService - Interface in com.hazelcast.spi.partition
An SPI service for accessing partition related information.
IPermissionPolicy - Interface in com.hazelcast.security
IPermissionPolicy is used to determine any Subject's permissions to perform a security sensitive Hazelcast operation.
IQueue<E> - Interface in com.hazelcast.core
Concurrent, blocking, distributed, observable queue.
is(String) - Method in class com.hazelcast.query.EntryObject
 
isActive() - Method in class com.hazelcast.client.spi.ClientContext
 
isActive() - Method in interface com.hazelcast.nio.IOService
 
isActive() - Method in class com.hazelcast.nio.NodeIOService
 
isActive() - Method in interface com.hazelcast.spi.NodeEngine
Deprecated.
isAlive() - Method in interface com.hazelcast.client.connection.ClientConnectionManager
Check if client connection manager is alive.
isAlive() - Method in interface com.hazelcast.nio.Connection
Checks if the Connection is alive.
isAllKeysSupported() - Method in class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
If it is possible to collect all clusterwide available keys for this KeyValueSource implementation then this method returns true.
If true is returned, a call to KeyValueSource.getAllKeys() must return all available keys to execute a preselection of interesting partitions / nodes based on returns keys.
isAllowUnsafe() - Method in class com.hazelcast.config.SerializationConfig
Unsafe, it is not public api of java.
isArrayType() - Method in enum com.hazelcast.nio.serialization.FieldType
 
isAssignedToMember() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
 
isAssignedToPartition() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
 
isAsyncFillup() - Method in class com.hazelcast.config.ReplicatedMapConfig
True if the replicated map is available for reads before the initial replication is completed, false otherwise.
isAsyncStart() - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
Client instance creation won't block on HazelcastClient.newHazelcastClient() if this value is true
isBetween(Version, Version) - Method in class com.hazelcast.version.Version
Checks if the version is between specified version (both ends inclusive)
isBinary() - Method in class com.hazelcast.config.MultiMapConfig
Checks if the MultiMap is in binary (serialized) form.
isBinary() - Method in enum com.hazelcast.nio.ConnectionType
 
isBitSet(int, int) - Static method in class com.hazelcast.nio.Bits
Returns true if n-th bit of the value is set, false otherwise
isBlacklisted(Address) - Method in interface com.hazelcast.cluster.Joiner
Deprecated.
Checks if an address is blacklisted.
isCacheLocalEntries() - Method in class com.hazelcast.config.NearCacheConfig
Checks if local entries are also cached in the Near Cache.
isCheckClassDefErrors() - Method in class com.hazelcast.config.SerializationConfig
Default value is true (enabled).
IScheduledExecutorService - Interface in com.hazelcast.scheduledexecutor
Distributed & durable implementation similar to, but not directly inherited ScheduledExecutorService.
IScheduledFuture<V> - Interface in com.hazelcast.scheduledexecutor
A delayed result-bearing action that can be cancelled.
isClassAvailable(ClassLoader, String) - Static method in class com.hazelcast.nio.ClassLoaderUtil
 
isClassDefined(String) - Static method in class com.hazelcast.nio.ClassLoaderUtil
Indicates whether or not the given class exists
isClient() - Method in interface com.hazelcast.nio.Connection
Checks if it is a client connection.
isClient() - Method in enum com.hazelcast.nio.ConnectionType
 
isClusterSafe() - Method in interface com.hazelcast.core.PartitionService
Checks whether the cluster is in a safe state.
isClusterVersionEqualTo(Version) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
isClusterVersionGreaterOrEqual(Version) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
isClusterVersionGreaterThan(Version) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
isClusterVersionLessOrEqual(Version) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
isClusterVersionLessThan(Version) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
isClusterVersionUnknown() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
isClusterVersionUnknownOrGreaterOrEqual(Version) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
isClusterVersionUnknownOrGreaterThan(Version) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
isClusterVersionUnknownOrLessOrEqual(Version) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
isClusterVersionUnknownOrLessThan(Version) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
isCoalesce() - Method in class com.hazelcast.config.QueryCacheConfig
Returns true if coalescing is is enabled, otherwise returns false.
isCommunicateStats() - Method in class com.hazelcast.config.JobTrackerConfig
True if statistics (for example, about processed entries) are transmitted to the job emitter, false otherwise.
isConnected() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns if this member is connected to the Wan publisher
isDefaultsDisabled() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
isDestroyed() - Method in interface com.hazelcast.cache.ICache
Determines whether this Cache instance has been destroyed.
isDisablePerEntryInvalidationEvents() - Method in class com.hazelcast.config.CacheConfig
Returns invalidation events disabled status for per entry.
isDisablePerEntryInvalidationEvents() - Method in class com.hazelcast.config.CacheSimpleConfig
Returns invalidation events disabled status for per entry.
isDone() - Method in enum com.hazelcast.hotrestart.BackupTaskState
Returns true if the backup task completed (successfully or with failure)
isDone() - Method in class com.hazelcast.wan.merkletree.ConsistencyCheckResult
 
isEchoFailFastOnStartup() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
ISemaphore - Interface in com.hazelcast.core
ISemaphore is a backed-up distributed alternative to the Semaphore.
isEmpty() - Method in class com.hazelcast.config.ClassFilter
 
isEmpty() - Method in interface com.hazelcast.core.BaseMap
Returns true if this map contains no entries.
isEmpty() - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of Map.isEmpty().
isEmpty() - Method in interface com.hazelcast.map.QueryCache
 
isEnableCompression() - Method in class com.hazelcast.config.SerializationConfig
Enables compression when default java serialization is used.
isEnabled() - Method in class com.hazelcast.client.config.ClientCloudConfig
 
isEnabled() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
isEnabled() - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
isEnabled() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
enables connection retry logic.
isEnabled() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
Checks whether the given join mechanism is enabled.
isEnabled() - Method in class com.hazelcast.config.DiscoveryConfig
 
isEnabled() - Method in class com.hazelcast.config.EventJournalConfig
Returns if the event journal is enabled.
isEnabled() - Method in class com.hazelcast.config.HotRestartConfig
Returns whether hot restart enabled on related data structure.
isEnabled() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Returns whether hot restart enabled on this member.
isEnabled() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
isEnabled() - Method in class com.hazelcast.config.InterfacesConfig
 
isEnabled() - Method in class com.hazelcast.config.ManagementCenterConfig
true if management center is enabled, false if disabled.
isEnabled() - Method in class com.hazelcast.config.MapStoreConfig
Returns if this configuration is enabled
isEnabled() - Method in class com.hazelcast.config.MCMutualAuthConfig
Returns if this configuration is enabled.
isEnabled() - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
isEnabled() - Method in class com.hazelcast.config.MerkleTreeConfig
Returns if the merkle tree is enabled.
isEnabled() - Method in class com.hazelcast.config.MulticastConfig
Check if the multicast discovery mechanism has been enabled.
isEnabled() - Method in class com.hazelcast.config.NativeMemoryConfig
Returns true if native memory allocation is enabled, false otherwise.
isEnabled() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
isEnabled() - Method in class com.hazelcast.config.PartitionGroupConfig
Checks if this PartitionGroupConfig is enabled.
isEnabled() - Method in class com.hazelcast.config.QueueStoreConfig
 
isEnabled() - Method in class com.hazelcast.config.QuorumConfig
 
isEnabled() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
isEnabled() - Method in class com.hazelcast.config.SecurityConfig
 
isEnabled() - Method in class com.hazelcast.config.ServiceConfig
 
isEnabled() - Method in class com.hazelcast.config.SocketInterceptorConfig
Returns if this configuration is enabled.
isEnabled() - Method in class com.hazelcast.config.SSLConfig
Returns if this configuration is enabled.
isEnabled() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
isEnabled() - Method in class com.hazelcast.config.TcpIpConfig
Checks if the Tcp/Ip join mechanism is enabled.
isEnabled() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Returns true when User Code Deployment is enabled
isEnableDefaults() - Method in class com.hazelcast.config.ServicesConfig
 
isEnableSharedObject() - Method in class com.hazelcast.config.SerializationConfig
Enables shared object when default java serialization is used.
isEnqueueNewEvents() - Method in enum com.hazelcast.config.WanPublisherState
Returns true if this state allows enqueueing new events, false otherwise.
isEqualTo(Version) - Method in class com.hazelcast.version.Version
 
ISet<E> - Interface in com.hazelcast.core
Concurrent, distributed implementation of Set
isExistingTransaction(Object) - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
 
isFailFastOnStartup() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
isFailOnMaxBackoff() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
whether to fail when the max-backoff has reached or continue waiting max-backoff-millis at each iteration When on fail, client shuts down.
isFineEnabled() - Method in class com.hazelcast.logging.AbstractLogger
 
isFineEnabled() - Method in interface com.hazelcast.logging.ILogger
Checks if the Level.FINE level is enabled.
isFinestEnabled() - Method in class com.hazelcast.logging.AbstractLogger
 
isFinestEnabled() - Method in interface com.hazelcast.logging.ILogger
Checks if the Level.FINEST level is enabled.
isFlagRaised(int) - Method in class com.hazelcast.nio.Packet
Returns true if any of the flags supplied in the argument are set.
isFsync() - Method in class com.hazelcast.config.HotRestartConfig
Returns whether disk write should be followed by an fsync() system call.
isGlobalOrderingEnabled() - Method in class com.hazelcast.config.TopicConfig
Checks if global ordering is enabled (all nodes listening to the same topic get their messages in the same order), or disabled (nodes get the messages in the order that the messages are published).
isGreaterOrEqual(Version) - Method in class com.hazelcast.version.Version
 
isGreaterThan(Version) - Method in class com.hazelcast.version.Version
 
isHotBackupEnabled() - Method in interface com.hazelcast.hotrestart.HotRestartService
Returns if hot backup is enabled.
isHotBackupEnabled() - Method in class com.hazelcast.hotrestart.NoOpHotRestartService
 
isHotBackupEnabled() - Method in interface com.hazelcast.monitor.HotRestartState
 
isIncludeValue() - Method in class com.hazelcast.config.EntryListenerConfig
 
isIncludeValue() - Method in class com.hazelcast.config.ItemListenerConfig
 
isIncludeValue() - Method in class com.hazelcast.config.ListenerConfig
 
isIncludeValue() - Method in class com.hazelcast.config.QueryCacheConfig
Returns true if value caching enabled, otherwise returns false.
isIncludeValue() - Method in class com.hazelcast.config.QuorumListenerConfig
 
isIndexed(QueryContext) - Method in interface com.hazelcast.query.IndexAwarePredicate
Signals to the query engine that this predicate is able to utilize the indexes available while executing the query in the given query context.
isIndexed(QueryContext) - Method in class com.hazelcast.query.PagingPredicate
Used if inner predicate is instanceof IndexAwarePredicate for checking if indexed.
isIndexed(QueryContext) - Method in class com.hazelcast.query.PredicateBuilder
 
isIndexed(QueryContext) - Method in class com.hazelcast.query.SqlPredicate
 
isInfoEnabled() - Method in class com.hazelcast.logging.AbstractLogger
 
isInfoEnabled() - Method in interface com.hazelcast.logging.ILogger
Checks if the Level.INFO level is enabled.
isInsideAws() - Method in class com.hazelcast.client.config.ClientAwsConfig
Deprecated.
isInternalType(Class) - Static method in class com.hazelcast.nio.ClassLoaderUtil
 
isInvalidateOnChange() - Method in class com.hazelcast.config.NearCacheConfig
Checks if Near Cache entries are invalidated when the entries in the backing data structure are changed (updated or removed).
isIPv4() - Method in class com.hazelcast.nio.Address
 
isIPv6() - Method in class com.hazelcast.nio.Address
 
isJoinAllowed() - Method in enum com.hazelcast.cluster.ClusterState
Shows whether new member join is allowed.
isKeepAlive() - Method in class com.hazelcast.client.config.SocketOptions
SO_KEEPALIVE socket option
isKnownServiceNamespace(ServiceNamespace) - Method in interface com.hazelcast.spi.FragmentedMigrationAwareService
Returns true if namespace is known by this service, false otherwise
isLessOrEqual(Version) - Method in class com.hazelcast.version.Version
 
isLessThan(Version) - Method in class com.hazelcast.version.Version
 
isListed(String) - Method in class com.hazelcast.config.ClassFilter
 
isLiteMember() - Method in class com.hazelcast.config.Config
Returns true if this member is a lite member.
isLiteMember() - Method in interface com.hazelcast.core.Member
Returns true if this member is a lite member.
isLocal() - Method in class com.hazelcast.config.EntryListenerConfig
 
isLocal() - Method in class com.hazelcast.config.ListenerConfig
 
isLocal() - Method in class com.hazelcast.config.QuorumListenerConfig
 
isLocal() - Method in interface com.hazelcast.spi.partition.IPartition
Checks if the partition is local.
isLocalMemberSafe() - Method in interface com.hazelcast.core.PartitionService
Checks whether local member is in safe state.
isLocalOnly() - Method in interface com.hazelcast.spi.EventRegistration
Returns true if this registration is for locally fired events only.
isLocked() - Method in interface com.hazelcast.core.ILock
Returns whether this lock is locked or not.
isLocked(K) - Method in interface com.hazelcast.core.IMap
Checks the lock for the specified key.
isLocked(K) - Method in interface com.hazelcast.core.MultiMap
Checks the lock for the specified key.
isLocked() - Method in interface com.hazelcast.map.LockAware
 
isLockedByCurrentThread() - Method in interface com.hazelcast.core.ILock
Returns whether this lock is locked by current thread or not.
isLoggable(Level) - Method in interface com.hazelcast.logging.ILogger
Checks if a message at the given level is going to be logged by this logger.
isLoggable(Level) - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
 
isLoopbackModeEnabled() - Method in class com.hazelcast.config.MulticastConfig
Check if the loopback mode is enabled in the multicast discovery mechanism.
isLossTolerant() - Method in interface com.hazelcast.topic.ReliableMessageListener
Checks if this ReliableMessageListener is able to deal with message loss.
isManagementEnabled - Variable in class com.hazelcast.config.AbstractCacheConfig
Whether management is enabled
isManagementEnabled() - Method in class com.hazelcast.config.AbstractCacheConfig
 
isManagementEnabled() - Method in class com.hazelcast.config.CacheSimpleConfig
Checks if management is enabled for this ICache.
isMemberExcluded(Address, String) - Method in interface com.hazelcast.hotrestart.InternalHotRestartService
Checks if the given member has been excluded during the cluster start or not.
isMemberExcluded(Address, String) - Method in class com.hazelcast.hotrestart.NoopInternalHotRestartService
 
isMemberSafe(Member) - Method in interface com.hazelcast.core.PartitionService
Checks whether the given member is in safe state.
isMemberStateSafe() - Method in interface com.hazelcast.monitor.MemberPartitionState
Returns whether member is safe for shutdown.
isMemberStateSafe() - Method in interface com.hazelcast.spi.partition.IPartitionService
Queries and returns if this member in a safe state or not.
isMigrating() - Method in interface com.hazelcast.spi.partition.IPartition
Checks if there currently is a migration going on in this partition.
isMigrationAllowed() - Method in enum com.hazelcast.cluster.ClusterState
Shows whether migrations and replications are allowed.
isMultiThreadingEnabled() - Method in class com.hazelcast.config.TopicConfig
Checks if multi-threaded processing of incoming messages is enabled or not.
isNearCacheEnabled() - Method in class com.hazelcast.config.MapConfig
Checks if Near Cache is enabled.
isNot(String) - Method in class com.hazelcast.query.EntryObject
 
isNotNull() - Method in class com.hazelcast.query.EntryObject
 
isNull() - Method in interface com.hazelcast.core.IAtomicReference
Checks if the stored reference is null.
isNull() - Method in class com.hazelcast.query.EntryObject
 
isNullAsync() - Method in interface com.hazelcast.core.IAtomicReference
Checks if the stored reference is null.
ISO_8859_1 - Static variable in class com.hazelcast.nio.Bits
A reusable instance of the ISO Latin-1 charset
isOldValueRequired() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
If old value is required, previously assigned values for the affected keys will be sent to this cache entry listener implementation.
isOptimizeQueries() - Method in class com.hazelcast.config.MapConfig
Deprecated.
isOrdered() - Method in class com.hazelcast.config.MapIndexConfig
Checks if the index should be ordered.
isOverrideJavaSerialization() - Method in class com.hazelcast.config.GlobalSerializerConfig
 
isOverwritable() - Method in interface com.hazelcast.nio.serialization.SerializerHook
Defines if this serializer can be overridden by defining a custom serializer in the configurations (codebase or configuration file)
isOwnerOrBackup(Address) - Method in interface com.hazelcast.spi.partition.IPartition
Checks if given address is owner of primary or backup of this partition.
isParallelMode() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
isPartitionOwner(int) - Method in interface com.hazelcast.spi.partition.IPartitionService
Check if this node is the owner of a partition.
isPersistWanReplicatedData() - Method in class com.hazelcast.config.WanConsumerConfig
 
isPopulate() - Method in class com.hazelcast.config.QueryCacheConfig
Returns true if initial population of QueryCache is enabled, otherwise returns false.
isPortable() - Method in interface com.hazelcast.nio.serialization.Data
Returns true if this Data is created from a Portable object, false otherwise.
isPortAutoIncrement() - Method in class com.hazelcast.config.NetworkConfig
Checks if a Hazelcast member is allowed find a free port by incrementing the port number when it encounters an occupied port.
isPresent() - Method in interface com.hazelcast.quorum.Quorum
Returns true if quorum is present, false if absent.
isPresent() - Method in class com.hazelcast.quorum.QuorumEvent
Returns the presence of the quorum
isReadBackupData() - Method in class com.hazelcast.config.MapConfig
Checks if read-backup-data (reading local backup entries) is enabled for this map.
isReadThrough - Variable in class com.hazelcast.config.AbstractCacheConfig
A flag indicating if "read-through" mode is required.
isReadThrough() - Method in class com.hazelcast.config.AbstractCacheConfig
 
isReadThrough() - Method in class com.hazelcast.config.CacheSimpleConfig
Checks if this ICache is read-through: a read loads the entry from the data store if it is not already in the cache.
isRedoOperation() - Method in class com.hazelcast.client.config.ClientConfig
Deprecated.
isRedoOperation() - Method in class com.hazelcast.client.config.ClientNetworkConfig
isRedoOperation() - Method in interface com.hazelcast.client.spi.ClientInvocationService
 
isReplicateEnqueuedEvents() - Method in enum com.hazelcast.config.WanPublisherState
Returns true if this state allows dequeueing and replicating events, false otherwise.
isRepublishingEnabled() - Method in class com.hazelcast.config.WanReplicationRef
Returns true if incoming WAN events to this member should be republished (forwarded) to this WAN replication reference.
isResultDeserialized() - Method in class com.hazelcast.spi.InvocationBuilder
Checks if the Future should automatically deserialize the result.
isReuseAddress() - Method in class com.hazelcast.client.config.SocketOptions
SO_REUSEADDR socket option.
isReuseAddress() - Method in class com.hazelcast.config.NetworkConfig
 
isRunning() - Method in interface com.hazelcast.core.LifecycleService
Checks whether or not the instance is running.
isRunning() - Method in interface com.hazelcast.spi.NodeEngine
Indicates that node is not shutting down or it has not already shut down
isRunning() - Method in class com.hazelcast.wan.merkletree.ConsistencyCheckResult
 
isSerializeKeys() - Method in class com.hazelcast.config.NearCacheConfig
Checks if the Near Cache key is stored in serialized format or by-reference.
isSevereEnabled() - Method in class com.hazelcast.logging.AbstractLogger
 
isSevereEnabled() - Method in interface com.hazelcast.logging.ILogger
Checks if the Level.SEVERE is enabled.
isSmartRouting() - Method in class com.hazelcast.client.config.ClientConfig
Deprecated.
isSmartRouting() - Method in class com.hazelcast.client.config.ClientNetworkConfig
isSocketBind() - Method in interface com.hazelcast.nio.IOService
 
isSocketBind() - Method in class com.hazelcast.nio.NodeIOService
 
isSocketBindAny() - Method in interface com.hazelcast.nio.IOService
 
isSocketBindAny() - Method in class com.hazelcast.nio.NodeIOService
 
isSocketInterceptorEnabled() - Method in interface com.hazelcast.nio.IOService
 
isSocketInterceptorEnabled() - Method in class com.hazelcast.nio.NodeIOService
 
isStatisticsEnabled - Variable in class com.hazelcast.config.AbstractCacheConfig
A flag indicating if statistics gathering is enabled.
isStatisticsEnabled() - Method in class com.hazelcast.config.AbstractCacheConfig
 
isStatisticsEnabled() - Method in class com.hazelcast.config.CacheSimpleConfig
Checks if statistics are enabled for this ICache.
isStatisticsEnabled() - Method in class com.hazelcast.config.CollectionConfig
Checks if collection statistics are enabled.
isStatisticsEnabled() - Method in class com.hazelcast.config.ExecutorConfig
Gets if statistics gathering is enabled or disabled on the executor task.
isStatisticsEnabled() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
isStatisticsEnabled() - Method in class com.hazelcast.config.MapConfig
Checks if statistics are enabled for this map.
isStatisticsEnabled() - Method in class com.hazelcast.config.MultiMapConfig
Checks to see if statistics are enabled for this MultiMap.
isStatisticsEnabled() - Method in class com.hazelcast.config.PNCounterConfig
Checks if statistics are enabled for this PN counter
isStatisticsEnabled() - Method in class com.hazelcast.config.QueueConfig
Check if statistics are enabled for this queue.
isStatisticsEnabled() - Method in class com.hazelcast.config.ReliableTopicConfig
Checks if statistics are enabled for this reliable topic.
isStatisticsEnabled() - Method in class com.hazelcast.config.ReplicatedMapConfig
Checks if statistics are enabled for this replicated map.
isStatisticsEnabled() - Method in class com.hazelcast.config.TopicConfig
Checks if statistics are enabled for this topic.
isStoreByValue - Variable in class com.hazelcast.config.AbstractCacheConfig
A flag indicating if the cache will be store-by-value or store-by-reference.
isStoreByValue() - Method in class com.hazelcast.config.AbstractCacheConfig
 
isSupported(OptionalFeature) - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
isSynchronous() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
If true, this cache entry listener implementation will be called in a synchronous manner.
isTcpNoDelay() - Method in class com.hazelcast.client.config.SocketOptions
TCP_NODELAY socket option
isTerminal(Throwable) - Method in interface com.hazelcast.topic.ReliableMessageListener
Checks if the ReliableMessageListener should be terminated based on an exception thrown while calling MessageListener.onMessage(com.hazelcast.core.Message).
isUnknown() - Method in class com.hazelcast.version.MemberVersion
 
isUnknown() - Method in class com.hazelcast.version.Version
 
isUnknownOrGreaterOrEqual(Version) - Method in class com.hazelcast.version.Version
 
isUnknownOrGreaterThan(Version) - Method in class com.hazelcast.version.Version
 
isUnknownOrLessOrEqual(Version) - Method in class com.hazelcast.version.Version
 
isUnknownOrLessThan(Version) - Method in class com.hazelcast.version.Version
 
isUrgent() - Method in class com.hazelcast.nio.Packet
 
isUrgent() - Method in class com.hazelcast.spi.Operation
 
isUseNativeByteOrder() - Method in class com.hazelcast.config.SerializationConfig
 
isUsePublicIp() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
Checks whether the public or private IP should be used to connect to Hazelcast members.
isWarningEnabled() - Method in class com.hazelcast.logging.AbstractLogger
 
isWarningEnabled() - Method in interface com.hazelcast.logging.ILogger
Checks if the Level.WARNING is enabled.
isWriteCoalescing() - Method in class com.hazelcast.config.MapStoreConfig
Returns true if write-coalescing is enabled.
isWriteThrough - Variable in class com.hazelcast.config.AbstractCacheConfig
A flag indicating if "write-through" mode is required.
isWriteThrough() - Method in class com.hazelcast.config.AbstractCacheConfig
 
isWriteThrough() - Method in class com.hazelcast.config.CacheSimpleConfig
Checks if the ICache is write-through: a write to the queue also loads the entry into the data store.
item - Variable in class com.hazelcast.core.ItemEvent
 
ITEM_LISTENER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
itemAdded(ItemEvent) - Method in class com.hazelcast.console.ConsoleApp
 
itemAdded(ItemEvent<E>) - Method in interface com.hazelcast.core.ItemListener
Invoked when an item is added.
ItemEvent<E> - Class in com.hazelcast.core
Event for a collection item.
ItemEvent(String, ItemEventType, E, Member) - Constructor for class com.hazelcast.core.ItemEvent
 
ItemEventType - Enum in com.hazelcast.core
Type of item events.
ItemListener<E> - Interface in com.hazelcast.core
Item listener for IQueue, ISet and IList
ItemListenerConfig - Class in com.hazelcast.config
Contains the configuration for an Item Listener.
ItemListenerConfig() - Constructor for class com.hazelcast.config.ItemListenerConfig
 
ItemListenerConfig(String, boolean) - Constructor for class com.hazelcast.config.ItemListenerConfig
 
ItemListenerConfig(ItemListener, boolean) - Constructor for class com.hazelcast.config.ItemListenerConfig
 
ItemListenerConfig(ItemListenerConfig) - Constructor for class com.hazelcast.config.ItemListenerConfig
 
ItemListenerConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
ItemListenerConfigReadOnly(ItemListenerConfig) - Constructor for class com.hazelcast.config.ItemListenerConfigReadOnly
Deprecated.
 
itemRemoved(ItemEvent) - Method in class com.hazelcast.console.ConsoleApp
 
itemRemoved(ItemEvent<E>) - Method in interface com.hazelcast.core.ItemListener
Invoked when an item is removed.
iterator(int) - Method in interface com.hazelcast.cache.ICache
Creates and returns a cluster wide iterator to iterate on all entries owned by this cache.
iterator() - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
iterator() - Method in interface com.hazelcast.partition.membergroup.MemberGroup
 
iterator() - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
iterator() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Returns a read-only iterator.
ITopic<E> - Interface in com.hazelcast.core
Hazelcast provides distribution mechanism for publishing messages that are delivered to multiple subscribers, which is also known as a publish/subscribe (pub/sub) messaging model.

J

JavaSerializationFilterConfig - Class in com.hazelcast.config
Configuration for Serialization Filter.
JavaSerializationFilterConfig() - Constructor for class com.hazelcast.config.JavaSerializationFilterConfig
 
JCACHE_PROVIDER_TYPE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Forces the JCache provider, which can have values client or server, to force the provider type.
JMX_UPDATE_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
Job<KeyIn,ValueIn> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
JobCompletableFuture<V> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
JobPartitionState - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
JobPartitionState.State - Enum in com.hazelcast.mapreduce
Deprecated.
Definition of the processing states
JobProcessInformation - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
JobTracker - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
JobTrackerConfig - Class in com.hazelcast.config
Contains the configuration for an JobTracker.
JobTrackerConfig() - Constructor for class com.hazelcast.config.JobTrackerConfig
 
JobTrackerConfig(JobTrackerConfig) - Constructor for class com.hazelcast.config.JobTrackerConfig
 
JobTrackerConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
join() - Method in interface com.hazelcast.cluster.Joiner
Deprecated.
 
join() - Method in interface com.hazelcast.spi.InternalCompletableFuture
Waits for this future to complete.
JoinConfig - Class in com.hazelcast.config
Contains the 3 different join configurations; TCP-IP/multicast/AWS.
JoinConfig() - Constructor for class com.hazelcast.config.JoinConfig
 
Joiner - Interface in com.hazelcast.cluster
Deprecated.

K

key() - Method in interface com.hazelcast.config.properties.PropertyDefinition
Returns the key (the name) of this property inside the configuration.
key() - Method in class com.hazelcast.config.properties.SimplePropertyDefinition
 
key - Variable in class com.hazelcast.core.EntryEvent
 
key() - Method in class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
Returns the current index key for KeyPredicate analysis.
key() - Method in class com.hazelcast.query.EntryObject
 
keyPredicate(KeyPredicate<? super KeyIn>) - Method in interface com.hazelcast.mapreduce.Job
Deprecated.
Defines the KeyPredicate implementation to preselect keys the MapReduce task will be executed on.
KeyPredicate<Key> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
keyPredicate(KeyPredicate<? super EntryKey>) - Method in interface com.hazelcast.mapreduce.MappingJob
Deprecated.
Defines the KeyPredicate implementation to preselect keys that the MapReduce task will be executed on.
keyPredicate(KeyPredicate<EntryKey>) - Method in interface com.hazelcast.mapreduce.ReducingJob
Deprecated.
Defines the KeyPredicate implementation to preselect keys the MapReduce task will be executed on.
keyPredicate(KeyPredicate<EntryKey>) - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
Deprecated.
Defines the KeyPredicate implementation to preselect keys the MapReduce task will be executed on.
keySet() - Method in interface com.hazelcast.core.BaseMap
Returns a set clone of the keys contained in this map.
keySet(Predicate) - Method in interface com.hazelcast.core.BaseMap
Queries the map based on the specified predicate and returns the keys of matching entries.
keySet() - Method in interface com.hazelcast.core.IMap
Returns a set clone of the keys contained in this map.
keySet(Predicate) - Method in interface com.hazelcast.core.IMap
Queries the map based on the specified predicate and returns the keys of matching entries.
keySet() - Method in interface com.hazelcast.core.MultiMap
Returns the set of keys in the multimap.
keySet() - Method in interface com.hazelcast.core.ReplicatedMap
Returns a lazy Set view of the key contained in this map.
A LazySet is optimized for querying speed (preventing eager deserialization and hashing on HashSet insertion) and does NOT provide all operations.
keySet() - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.keySet().
keySet(Predicate) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.keySet(com.hazelcast.query.Predicate).
keySet() - Method in interface com.hazelcast.map.QueryCache
 
keySet(Predicate) - Method in interface com.hazelcast.map.QueryCache
 
keySet() - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns an immutable set of all keys in this HazelcastProperties.
KeyValueSource<K,V> - Class in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
KeyValueSource() - Constructor for class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
 
keyValueTypesEqual(AbstractCacheConfig) - Method in class com.hazelcast.config.AbstractCacheConfig
 
KILO_BYTE - Static variable in class com.hazelcast.client.config.SocketOptions
constant for kilobyte
KILO_BYTE - Static variable in interface com.hazelcast.nio.IOService
 
kiloBytes() - Method in class com.hazelcast.memory.MemorySize
Returns value of memory size in kilo-bytes.
KubernetesConfig - Class in com.hazelcast.config
Configuration for the Kubernetes Discovery Strategy.
KubernetesConfig() - Constructor for class com.hazelcast.config.KubernetesConfig
 

L

lastReadTimeMillis() - Method in interface com.hazelcast.nio.Connection
Returns the clock time in milliseconds of the most recent read using this connection.
lastWriteTimeMillis() - Method in interface com.hazelcast.nio.Connection
Returns the clock time in milliseconds of the most recent write using this connection.
LatestAccessCacheMergePolicy - Class in com.hazelcast.cache.merge
Merges cache entries from source to destination cache if the source entry has been accessed more recently than the destination entry.
LatestAccessCacheMergePolicy() - Constructor for class com.hazelcast.cache.merge.LatestAccessCacheMergePolicy
 
LatestAccessMergePolicy<V,T extends MergingLastAccessTime<V>> - Class in com.hazelcast.spi.merge
Merges data structure entries from source to destination data structure if the source entry has been accessed more recently than the destination entry.
LatestAccessMergePolicy() - Constructor for class com.hazelcast.spi.merge.LatestAccessMergePolicy
 
LatestUpdateMapMergePolicy - Class in com.hazelcast.map.merge
Merges map entries from source to destination map if the source entry was updated more recently than the destination entry.
LatestUpdateMapMergePolicy() - Constructor for class com.hazelcast.map.merge.LatestUpdateMapMergePolicy
 
LatestUpdateMapMergePolicy - Class in com.hazelcast.replicatedmap.merge
Merges replicated map entries from source to destination map if the source entry was updated more recently than the destination entry.
LatestUpdateMergePolicy<V,T extends MergingLastUpdateTime<V>> - Class in com.hazelcast.spi.merge
Merges data structure entries from source to destination data structure if the source entry was updated more frequently than the destination entry.
LatestUpdateMergePolicy() - Constructor for class com.hazelcast.spi.merge.LatestUpdateMergePolicy
 
LegacyCacheConfig<K,V> - Class in com.hazelcast.config
Contains all the configuration for the ICache (used for backward compatibility).
LegacyCacheConfig() - Constructor for class com.hazelcast.config.LegacyCacheConfig
 
LegacyCacheConfig(CacheConfig<K, V>) - Constructor for class com.hazelcast.config.LegacyCacheConfig
 
LegacyCacheEvictionConfig - Class in com.hazelcast.config
Configuration for cache eviction (used for backward compatibility).
LegacyCacheEvictionConfig() - Constructor for class com.hazelcast.config.LegacyCacheEvictionConfig
 
LegacyCacheEvictionConfig(CacheEvictionConfig) - Constructor for class com.hazelcast.config.LegacyCacheEvictionConfig
 
LegacyMatchingPointConfigPatternMatcher - Class in com.hazelcast.config.matcher
Deprecated.
LegacyMatchingPointConfigPatternMatcher() - Constructor for class com.hazelcast.config.matcher.LegacyMatchingPointConfigPatternMatcher
Deprecated.
 
LegacyWildcardConfigPatternMatcher - Class in com.hazelcast.config.matcher
Deprecated.
LegacyWildcardConfigPatternMatcher() - Constructor for class com.hazelcast.config.matcher.LegacyWildcardConfigPatternMatcher
Deprecated.
 
length() - Method in interface com.hazelcast.security.Parameters
 
lessEqual(Comparable) - Method in class com.hazelcast.query.EntryObject
 
lessEqual(String, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates a less than or equal to predicate that will pass items if the value stored under the given item attribute is less than or equal to the given value.
lessThan(Comparable) - Method in class com.hazelcast.query.EntryObject
 
lessThan(String, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates a less than predicate that will pass items if the value stored under the given item attribute is less than the given value.
LFU_EVICTION_POLICY - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
LFUEvictionPolicy - Class in com.hazelcast.map.eviction
LFU eviction policy for an IMap
LFUEvictionPolicy() - Constructor for class com.hazelcast.map.eviction.LFUEvictionPolicy
 
LifecycleEvent - Class in com.hazelcast.core
Lifecycle events are fired when the HazelcastInstance state changes.
LifecycleEvent(LifecycleEvent.LifecycleState) - Constructor for class com.hazelcast.core.LifecycleEvent
 
LifecycleEvent.LifecycleState - Enum in com.hazelcast.core
Lifecycle states
LifecycleListener - Interface in com.hazelcast.core
Listener object for listening to lifecycle events of the Hazelcast instance
LifecycleMapper<KeyIn,ValueIn,KeyOut,ValueOut> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
LifecycleMapperAdapter<KeyIn,ValueIn,KeyOut,ValueOut> - Class in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
LifecycleMapperAdapter() - Constructor for class com.hazelcast.mapreduce.LifecycleMapperAdapter
Deprecated.
 
LifecycleService - Interface in com.hazelcast.core
LifecycleService allows you to shutdown, terminate, and listen to LifecycleEvents on HazelcastInstance.
like(String, String) - Static method in class com.hazelcast.query.Predicates
Creates a like predicate that will pass items if the given pattern matches the value stored under the given item attribute.
LineReader - Interface in com.hazelcast.console
Reads a line of input.
LIST_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
ListConfig - Class in com.hazelcast.config
Contains the configuration for an IList.
ListConfig() - Constructor for class com.hazelcast.config.ListConfig
 
ListConfig(String) - Constructor for class com.hazelcast.config.ListConfig
 
ListConfig(ListConfig) - Constructor for class com.hazelcast.config.ListConfig
 
ListConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
ListConfigReadOnly(ListConfig) - Constructor for class com.hazelcast.config.ListConfigReadOnly
Deprecated.
 
LISTENER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
LISTENER_INSTANCE - Static variable in class com.hazelcast.security.permission.ActionConstants
 
LISTENER_MEMBER - Static variable in class com.hazelcast.security.permission.ActionConstants
 
LISTENER_MIGRATION - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ListenerConfig - Class in com.hazelcast.config
Contains the configuration for an EventListener.
ListenerConfig() - Constructor for class com.hazelcast.config.ListenerConfig
Creates a ListenerConfig without className/implementation.
ListenerConfig(String) - Constructor for class com.hazelcast.config.ListenerConfig
Creates a ListenerConfig with the given className.
ListenerConfig(ListenerConfig) - Constructor for class com.hazelcast.config.ListenerConfig
 
ListenerConfig(EventListener) - Constructor for class com.hazelcast.config.ListenerConfig
Creates a ListenerConfig with the given implementation.
ListenerConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
ListenerConfigReadOnly(ListenerConfig) - Constructor for class com.hazelcast.config.ListenerConfigReadOnly
Deprecated.
 
listenerConfigurations - Variable in class com.hazelcast.config.AbstractCacheConfig
The CacheEntryListenerConfigurations for the Configuration.
ListenerWrapperEventFilter - Interface in com.hazelcast.spi
Contract point for EventFilter instances these wrap listeners.
ListPermission - Class in com.hazelcast.security.permission
 
ListPermission(String, String...) - Constructor for class com.hazelcast.security.permission.ListPermission
 
LITE_MEMBER_SELECTOR - Static variable in class com.hazelcast.cluster.memberselector.MemberSelectors
A MemberSelector instance that selects only lite members that own no partition
LiveOperations - Interface in com.hazelcast.spi
InvocationMonitor passes instances of this type to each LiveOperationsTracker so it can contribute the call IDs of invocations it is responsible for.
LiveOperationsTracker - Interface in com.hazelcast.spi
Can be implemented by a Service to track live operations.
load(String) - Static method in class com.hazelcast.config.ConfigLoader
 
load(K) - Method in interface com.hazelcast.core.MapLoader
Loads the value of a given key.
load(K) - Method in class com.hazelcast.core.MapStoreAdapter
Loads the value of a given key.
load(Long) - Method in interface com.hazelcast.core.QueueStore
Loads the value of a given key.
load(long) - Method in interface com.hazelcast.core.RingbufferStore
Loads the value of a given sequence.
load(Map<K, V>) - Method in interface com.hazelcast.scheduledexecutor.StatefulTask
Task callback to initialize its inner state, after a replica promotion, from the given map.
loadAddresses() - Method in interface com.hazelcast.client.connection.AddressProvider
 
loadAll(boolean) - Method in interface com.hazelcast.core.IMap
Loads all keys into the store.
loadAll(Set<K>, boolean) - Method in interface com.hazelcast.core.IMap
Loads the given keys.
loadAll(Collection<K>) - Method in interface com.hazelcast.core.MapLoader
Loads given keys.
loadAll(Collection<K>) - Method in class com.hazelcast.core.MapStoreAdapter
Loads given keys.
loadAll(Collection<Long>) - Method in interface com.hazelcast.core.QueueStore
Loads the given keys.
loadAllKeys() - Method in interface com.hazelcast.core.MapLoader
Loads all of the keys from the store.
loadAllKeys() - Method in class com.hazelcast.core.MapStoreAdapter
Loads all of the keys from the store.
loadAllKeys() - Method in interface com.hazelcast.core.QueueStore
Loads all of the keys from the store.
LoadBalancer - Interface in com.hazelcast.client
LoadBalancer allows you to send operations to one of a number of endpoints(Members).
loadClass(ClassLoader, String) - Static method in class com.hazelcast.nio.ClassLoaderUtil
 
loadSchemaFile(String) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
LOCAL_MEMBER_SELECTOR - Static variable in class com.hazelcast.cluster.memberselector.MemberSelectors
A MemberSelector instance that selects only local members
LocalCacheStats - Interface in com.hazelcast.monitor
Local cache statistics to be used by MemberState implementations.
LocalExecutorStats - Interface in com.hazelcast.monitor
Local executor service statistics to be used by MemberState implementations.
LocalFlakeIdGeneratorStats - Interface in com.hazelcast.monitor
local flake ID statistics to be used by MemberState implementations.
LocalGCStats - Interface in com.hazelcast.monitor
Local GC statistics to be used by MemberState implementations.
LocalIndexStats - Interface in com.hazelcast.monitor
Provides local statistics for an index to be used by MemberState implementations.
LocalInstanceStats - Interface in com.hazelcast.monitor
Base interface for local instance statistics.
localKeySet() - Method in interface com.hazelcast.core.IMap
Returns the locally owned set of keys.
localKeySet(Predicate) - Method in interface com.hazelcast.core.IMap
Returns the keys of matching locally owned entries.
localKeySet() - Method in interface com.hazelcast.core.MultiMap
Returns the locally owned set of keys.
LocalMapStats - Interface in com.hazelcast.monitor
Local map statistics to be used by MemberState implementations.
localMember() - Method in interface com.hazelcast.core.Member
Returns true if this member is the local member.
LocalMemberResetException - Exception in com.hazelcast.core
An exception provided to MemberLeftException as a cause when the local member is resetting itself
LocalMemberResetException(String) - Constructor for exception com.hazelcast.core.LocalMemberResetException
 
LocalMemoryStats - Interface in com.hazelcast.monitor
Local memory statistics to be used by MemberState implementations.
LocalMultiMapStats - Interface in com.hazelcast.monitor
Local multi map statistics to be used by MemberState implementations.
LocalOperationStats - Interface in com.hazelcast.monitor
Local operation statistics to be used by MemberState implementations.
LocalPNCounterStats - Interface in com.hazelcast.monitor
Local statistics of a single PN counter to be used by MemberState implementations.
LocalQueueStats - Interface in com.hazelcast.monitor
Local queue statistics to be used by MemberState implementations.
LocalRecordStoreStats - Interface in com.hazelcast.monitor
Local record store statistics to be used by MemberState implementations.
LocalReplicatedMapStats - Interface in com.hazelcast.monitor
Local replicated map statistics to be used by MemberState implementations.
LocalTopicStats - Interface in com.hazelcast.monitor
Local topic statistics to be used by MemberState implementations.
LocalWanPublisherStats - Interface in com.hazelcast.monitor
Local WAN publisher statistics to be used by MemberState implementations.
LocalWanStats - Interface in com.hazelcast.monitor
Local WAN statistics to be used by MemberState implementations.
locateConfig(String) - Static method in class com.hazelcast.config.ConfigLoader
 
lock() - Method in interface com.hazelcast.core.ILock
lock(long, TimeUnit) - Method in interface com.hazelcast.core.ILock
Acquires the lock for the specified lease time.
lock(K) - Method in interface com.hazelcast.core.IMap
Acquires the lock for the specified key.
lock(K, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Acquires the lock for the specified key for the specified lease time.
lock(K) - Method in interface com.hazelcast.core.MultiMap
Acquires a lock for the specified key.
lock(K, long, TimeUnit) - Method in interface com.hazelcast.core.MultiMap
Acquires the lock for the specified key for the specified lease time.
LOCK_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
LOCK_MAX_LEASE_TIME_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
LockAware - Interface in com.hazelcast.map
Determines if the object implementing this interface is locked or not.
LockConfig - Class in com.hazelcast.config
Contains the configuration for the ILock.
LockConfig() - Constructor for class com.hazelcast.config.LockConfig
 
LockConfig(String) - Constructor for class com.hazelcast.config.LockConfig
Creates a LockConfig with the provided name.
LockConfig(LockConfig) - Constructor for class com.hazelcast.config.LockConfig
Clones a LockConfig
LockConfig(String, LockConfig) - Constructor for class com.hazelcast.config.LockConfig
Creates a new LockConfig by cloning an existing config and overriding the name.
LockPermission - Class in com.hazelcast.security.permission
 
LockPermission(String, String...) - Constructor for class com.hazelcast.security.permission.LockPermission
 
log(Level, String) - Method in interface com.hazelcast.logging.ILogger
Logs a message at the given level.
log(Level, String, Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a message with an associated throwable at the given level.
log(LogEvent) - Method in interface com.hazelcast.logging.ILogger
Logs a LogEvent.
log(LogEvent) - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
 
log(Level, String) - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
 
log(Level, String, Throwable) - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
 
log(LogEvent) - Method in interface com.hazelcast.logging.LogListener
 
Log4j2Factory - Class in com.hazelcast.logging
Logging to Log4j 2.x.
Log4j2Factory() - Constructor for class com.hazelcast.logging.Log4j2Factory
 
Log4j2Factory.Log4j2Logger - Class in com.hazelcast.logging
 
Log4j2Logger(ExtendedLogger) - Constructor for class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
 
Log4jFactory - Class in com.hazelcast.logging
 
Log4jFactory() - Constructor for class com.hazelcast.logging.Log4jFactory
 
logError(Throwable) - Method in class com.hazelcast.spi.Operation
Logs Exception/Error thrown during operation execution.
LogEvent - Class in com.hazelcast.logging
 
LogEvent(LogRecord, Member) - Constructor for class com.hazelcast.logging.LogEvent
 
logger - Variable in class com.hazelcast.client.connection.ClientConnectionStrategy
 
Logger - Class in com.hazelcast.logging
Provides static utilities to access the global shared logging machinery.
LoggerFactory - Interface in com.hazelcast.logging
 
LoggerFactorySupport - Class in com.hazelcast.logging
 
LoggerFactorySupport() - Constructor for class com.hazelcast.logging.LoggerFactorySupport
 
LOGGING_TYPE - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
LoggingService - Interface in com.hazelcast.logging
 
LoggingServiceImpl - Class in com.hazelcast.logging
 
LoggingServiceImpl(String, String, BuildInfo) - Constructor for class com.hazelcast.logging.LoggingServiceImpl
 
LoginModuleConfig - Class in com.hazelcast.config
Configuration for Login Module
LoginModuleConfig() - Constructor for class com.hazelcast.config.LoginModuleConfig
 
LoginModuleConfig(String, LoginModuleConfig.LoginModuleUsage) - Constructor for class com.hazelcast.config.LoginModuleConfig
 
LoginModuleConfig.LoginModuleUsage - Enum in com.hazelcast.config
Usage of Login Module
LogListener - Interface in com.hazelcast.logging
 
LONG_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
LONG_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
LONG_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
Long size in bytes
longAvg() - Static method in class com.hazelcast.aggregation.Aggregators
 
longAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
longAvg() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to calculate the long average of all supplied values.
This aggregation is similar to:
longMax() - Static method in class com.hazelcast.aggregation.Aggregators
 
longMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
longMax() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to find the long maximum of all supplied values.
This aggregation is similar to:
longMin() - Static method in class com.hazelcast.aggregation.Aggregators
 
longMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
longMin() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to find the long minimum of all supplied values.
This aggregation is similar to:
longSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
longSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
longSum() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to calculate the long sum of all supplied values.
This aggregation is similar to:
LRU_EVICTION_POLICY - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
LRUEvictionPolicy - Class in com.hazelcast.map.eviction
LRU eviction policy for an IMap
LRUEvictionPolicy() - Constructor for class com.hazelcast.map.eviction.LRUEvictionPolicy
 

M

main(String...) - Static method in class com.hazelcast.config.replacer.EncryptionReplacer
 
main(String[]) - Static method in class com.hazelcast.console.ConsoleApp
Starts the test application.
MAJOR_MINOR_VERSION_COMPARATOR - Static variable in class com.hazelcast.version.MemberVersion
Version comparator that takes into account only major & minor version, disregarding patch version number.
ManagedContext - Interface in com.hazelcast.core
Container managed context, such as Spring, Guice and etc.
ManagedService - Interface in com.hazelcast.spi
An interface that can be implemented by an SPI Service to receive lifecycle calls: initialization shutdown reset
ManagedTransactionalTaskContext - Class in com.hazelcast.spring.transaction
TransactionalTaskContext proxying implementation to make the one created by HazelcastTransactionManager available to actual business logic.
ManagedTransactionalTaskContext(HazelcastTransactionManager) - Constructor for class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
 
ManagementCenterConfig - Class in com.hazelcast.config
Contains the configuration for a Management Center.
ManagementCenterConfig() - Constructor for class com.hazelcast.config.ManagementCenterConfig
 
ManagementCenterConfig(String, int) - Constructor for class com.hazelcast.config.ManagementCenterConfig
 
map(List<AliasedDiscoveryConfig<?>>) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Maps aliased discovery strategy configs into discovery strategy configs.
map(KeyIn, ValueIn, Context<KeyOut, ValueOut>) - Method in class com.hazelcast.mapreduce.LifecycleMapperAdapter
Deprecated.
The map method is called for every single key-value pair in the bound KeyValueSource instance on this cluster node and partition.
Due to its nature of a DataGrid, Hazelcast distributes values all over the cluster and so this method is executed on multiple servers at the same time.
If you want to know more about the implementation of MapReduce algorithms read the Google Whitepaper on MapReduce.
map(KeyIn, ValueIn, Context<KeyOut, ValueOut>) - Method in interface com.hazelcast.mapreduce.Mapper
Deprecated.
The map method is called for every single key-value pair in the bound KeyValueSource instance on this cluster node and partition.
Due to its nature of a DataGrid, Hazelcast distributes values all over the cluster and so this method is executed on multiple servers at the same time.
If you want to know more about the implementation of MapReduce algorithms read the Google Whitepaper on MapReduce.
MAP_ATTRIBUTE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MAP_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MAP_EVICTION_BATCH_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Maximum number of IMap entries Hazelcast will evict during a single eviction cycle.
MAP_EXPIRY_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
You can use MAP_EXPIRY_DELAY_SECONDS to deal with some possible edge cases, such as using EntryProcessor.
MAP_INDEX_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MAP_INVALIDATION_MESSAGE_BATCH_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Defines Near Cache invalidation event batch sending is enabled or not.
MAP_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Defines the Near Cache invalidation event batch sending frequency in seconds.
MAP_INVALIDATION_MESSAGE_BATCH_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Defines the maximum number of Near Cache invalidation events to be drained and sent to the event Near Cache in a batch.
MAP_LISTENER_TO_ENTRY_LISTENER_ADAPTER - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MAP_LOAD_ALL_KEYS_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
The name of the executor that loads the entry keys and dispatches the keys to the partition owners for value loading.
MAP_LOAD_ALL_PUBLISHES_ADDED_EVENT - Static variable in class com.hazelcast.spi.properties.GroupProperty
This property is a switch between old and new event publishing behavior of map#loadAll.
MAP_LOAD_CHUNK_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
The maximum size of the key batch sent to the partition owners for value loading and the maximum size of a key batch for which values are loaded in a single partition.
MAP_LOADER_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
Name of the map-loader executor that loads the entry values for a given key set locally on the member owning the partition which contains the keys.
MAP_PARTITION_LOST_LISTENER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MAP_REPLICA_SCHEDULED_TASK_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
MAP_STORE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MAP_WRITE_BEHIND_QUEUE_CAPACITY - Static variable in class com.hazelcast.spi.properties.GroupProperty
Setting this capacity is valid if you set MapStoreConfig.writeCoalescing to false.
MapAttributeConfig - Class in com.hazelcast.config
Contains the configuration of a custom attribute that will be extracted from a Map's entry using a given ValueExtractor.
MapAttributeConfig() - Constructor for class com.hazelcast.config.MapAttributeConfig
Creates an empty MapAttributeConfig.
MapAttributeConfig(String, String) - Constructor for class com.hazelcast.config.MapAttributeConfig
Creates a MapAttributeConfig with the given attribute and ordered setting.
MapAttributeConfig(MapAttributeConfig) - Constructor for class com.hazelcast.config.MapAttributeConfig
 
MapAttributeConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
MapAttributeConfigReadOnly(MapAttributeConfig) - Constructor for class com.hazelcast.config.MapAttributeConfigReadOnly
Deprecated.
 
mapCleared(MapEvent) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
mapCleared(MapEvent) - Method in class com.hazelcast.console.ConsoleApp
 
mapCleared(MapEvent) - Method in class com.hazelcast.core.EntryAdapter
 
mapCleared(MapEvent) - Method in interface com.hazelcast.map.listener.MapClearedListener
Invoked when all entries are removed by IMap.clear().
MapClearedListener - Interface in com.hazelcast.map.listener
Invoked after all entries are removed by IMap.clear().
MapConfig - Class in com.hazelcast.config
Contains the configuration for an IMap.
MapConfig() - Constructor for class com.hazelcast.config.MapConfig
 
MapConfig(String) - Constructor for class com.hazelcast.config.MapConfig
 
MapConfig(MapConfig) - Constructor for class com.hazelcast.config.MapConfig
 
MapConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
MapEvent - Class in com.hazelcast.core
Used for map-wide events like EntryEventType.EVICT_ALL and EntryEventType.CLEAR_ALL.
MapEvent(Object, Member, int, int) - Constructor for class com.hazelcast.core.MapEvent
 
mapEvicted(MapEvent) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
mapEvicted(MapEvent) - Method in class com.hazelcast.console.ConsoleApp
 
mapEvicted(MapEvent) - Method in class com.hazelcast.core.EntryAdapter
 
mapEvicted(MapEvent) - Method in interface com.hazelcast.map.listener.MapEvictedListener
Invoked when all entries are evicted by IMap.evictAll().
MapEvictedListener - Interface in com.hazelcast.map.listener
Invoked after all entries are evicted by IMap.evictAll().
MapEvictionPolicy<K,V> - Class in com.hazelcast.map.eviction
An eviction policy takes its role after the decision that a map needs to free some memory according to one of MaxSizePolicies and it helps to find most appropriate entries to remove.
MapEvictionPolicy() - Constructor for class com.hazelcast.map.eviction.MapEvictionPolicy
 
MapIndexConfig - Class in com.hazelcast.config
Contains the configuration for an index in a map.
MapIndexConfig() - Constructor for class com.hazelcast.config.MapIndexConfig
Creates a MapIndexConfig without an attribute and with ordered set to false.
MapIndexConfig(String, boolean) - Constructor for class com.hazelcast.config.MapIndexConfig
Creates a MapIndexConfig with the given attribute and ordered setting.
MapIndexConfig(MapIndexConfig) - Constructor for class com.hazelcast.config.MapIndexConfig
 
MapIndexConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
MapIndexConfigReadOnly(MapIndexConfig) - Constructor for class com.hazelcast.config.MapIndexConfigReadOnly
Deprecated.
 
MapInterceptor - Interface in com.hazelcast.map
MapInterceptor is used to intercept changes to the map, allowing access to the values before and after adding them to the map.
MapListener - Interface in com.hazelcast.map.listener
A marker interface which is used to get notified upon a map or an entry event.
MapListenerToEntryListenerAdapter() - Constructor for class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
MapListenerToEntryListenerAdapter(MapListener) - Constructor for class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
MapLoader<K,V> - Interface in com.hazelcast.core
Hazelcast distributed map implementation is an in-memory data store but it can be backed by any type of data store such as RDBMS, OODBMS, or simply a file based data store.
MapLoaderLifecycleSupport - Interface in com.hazelcast.core
Provides Lifecycle support for the implementing MapLoader class.
MapMergePolicy - Interface in com.hazelcast.map.merge
Policy for merging map entries after a split-brain has been healed.
MapPartitionLostEvent - Class in com.hazelcast.map
Used for providing information about the lost partition for a map
MapPartitionLostEvent(Object, Member, int, int) - Constructor for class com.hazelcast.map.MapPartitionLostEvent
 
MapPartitionLostListener - Interface in com.hazelcast.map.listener
Invoked when owner and all backups of a partition is lost for a specific map.
MapPartitionLostListenerConfig - Class in com.hazelcast.config
Configuration for MapPartitionLostListener
MapPartitionLostListenerConfig() - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfig
 
MapPartitionLostListenerConfig(String) - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfig
 
MapPartitionLostListenerConfig(MapPartitionLostListener) - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfig
 
MapPartitionLostListenerConfig(MapPartitionLostListenerConfig) - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfig
 
MapPartitionLostListenerConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
MapPartitionLostListenerConfigReadOnly(MapPartitionLostListenerConfig) - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfigReadOnly
Deprecated.
 
mapper(Mapper<KeyIn, ValueIn, KeyOut, ValueOut>) - Method in interface com.hazelcast.mapreduce.Job
Deprecated.
Defines the mapper for this task.
Mapper<KeyIn,ValueIn,KeyOut,ValueOut> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
MapPermission - Class in com.hazelcast.security.permission
 
MapPermission(String, String...) - Constructor for class com.hazelcast.security.permission.MapPermission
 
MappingJob<EntryKey,KeyIn,ValueIn> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
MapReducePermission - Class in com.hazelcast.security.permission
To be able to map-reduce from a client in a secure environment
MapReducePermission(String, String...) - Constructor for class com.hazelcast.security.permission.MapReducePermission
 
MapStore<K,V> - Interface in com.hazelcast.core
Hazelcast distributed map implementation is an in-memory data store, but it can be backed by any type of data store such as RDBMS, OODBMS, NOSQL, or simply a file-based data store.
MapStoreAdapter<K,V> - Class in com.hazelcast.core
Adapter for MapStore.
MapStoreAdapter() - Constructor for class com.hazelcast.core.MapStoreAdapter
 
MapStoreConfig - Class in com.hazelcast.config
Contains the configuration for a Map Store.
MapStoreConfig() - Constructor for class com.hazelcast.config.MapStoreConfig
 
MapStoreConfig(MapStoreConfig) - Constructor for class com.hazelcast.config.MapStoreConfig
 
MapStoreConfig.InitialLoadMode - Enum in com.hazelcast.config
Initial load module
MapStoreConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
MapStoreConfigReadOnly(MapStoreConfig) - Constructor for class com.hazelcast.config.MapStoreConfigReadOnly
Deprecated.
 
MapStoreFactory<K,V> - Interface in com.hazelcast.core
Factory for MapLoader or MapStore instances, specifiable in MapStoreConfig.
markMigrated(VectorClock) - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
Marks this CRDT as migrated.
markMigrated() - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
Unconditionally marks this CRDT as migrated.
mask - Variable in class com.hazelcast.security.permission.InstancePermission
 
MASK_FOR_SENSITIVE_DATA - Static variable in class com.hazelcast.config.ConfigXmlGenerator
 
MASTER_CONFIRMATION_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
since 3.10
MASTERSHIP_CLAIM_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The timeout which defines when master candidate gives up waiting for response to its mastership claim.
matches(Iterable<String>, String) - Method in interface com.hazelcast.config.ConfigPatternMatcher
Returns the best match for an item name out of a list of configuration patterns.
matches(Iterable<String>, String) - Method in class com.hazelcast.config.matcher.LegacyMatchingPointConfigPatternMatcher
Deprecated.
 
matches(Iterable<String>, String) - Method in class com.hazelcast.config.matcher.LegacyWildcardConfigPatternMatcher
Deprecated.
 
matches(String, String) - Method in class com.hazelcast.config.matcher.LegacyWildcardConfigPatternMatcher
Deprecated.
This method is public to be accessible by InstancePermission.
matches(Iterable<String>, String) - Method in class com.hazelcast.config.matcher.MatchingPointConfigPatternMatcher
 
matches(Iterable<String>, String) - Method in class com.hazelcast.config.matcher.RegexConfigPatternMatcher
 
matches(Iterable<String>, String) - Method in class com.hazelcast.config.matcher.WildcardConfigPatternMatcher
 
matches(String, String) - Method in class com.hazelcast.config.matcher.WildcardConfigPatternMatcher
This method is public to be accessible by InstancePermission.
MatchingPointConfigPatternMatcher - Class in com.hazelcast.config.matcher
This ConfigPatternMatcher supports a simplified wildcard matching.
MatchingPointConfigPatternMatcher() - Constructor for class com.hazelcast.config.matcher.MatchingPointConfigPatternMatcher
 
MAX_BACKUP_COUNT - Static variable in class com.hazelcast.config.CacheSimpleConfig
The maximum number of backups.
MAX_BACKUP_COUNT - Static variable in class com.hazelcast.config.MapConfig
The maximum number of backups
MAX_BACKUP_COUNT - Static variable in interface com.hazelcast.spi.partition.IPartition
The maximum number of backups.
MAX_CONCURRENT_INVOCATIONS - Static variable in class com.hazelcast.client.spi.properties.ClientProperty
The maximum number of concurrent invocations allowed.
MAX_EVICTION_PERCENTAGE - Static variable in class com.hazelcast.config.MapConfig
The number of maximum eviction percentage
MAX_JOIN_MERGE_TARGET_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
MAX_JOIN_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
MAX_NO_HEARTBEAT_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The timeout which defines when a cluster member is removed because it has not sent any heartbeats.
MAX_NO_MASTER_CONFIRMATION_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
since 3.10
MAX_WAIT_SECONDS_BEFORE_JOIN - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
maxBy(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
MAXIMUM_PREFETCH_COUNT - Static variable in class com.hazelcast.config.FlakeIdGeneratorConfig
Maximum value for prefetch count.
MaxSizeConfig - Class in com.hazelcast.config
Configuration for map's capacity.
MaxSizeConfig() - Constructor for class com.hazelcast.config.MaxSizeConfig
 
MaxSizeConfig(int, MaxSizeConfig.MaxSizePolicy) - Constructor for class com.hazelcast.config.MaxSizeConfig
 
MaxSizeConfig(MaxSizeConfig) - Constructor for class com.hazelcast.config.MaxSizeConfig
 
MaxSizeConfig.MaxSizePolicy - Enum in com.hazelcast.config
Maximum Size Policy
MaxSizeConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
MaxSizeConfigReadOnly(MaxSizeConfig) - Constructor for class com.hazelcast.config.MaxSizeConfigReadOnly
Deprecated.
 
maxSizePolicy - Variable in class com.hazelcast.config.EvictionConfig
 
MC_MAX_VISIBLE_SLOW_OPERATION_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
MC_URL_CHANGE_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
MCMutualAuthConfig - Class in com.hazelcast.config
Management Center mutual authentication configuration.
MCMutualAuthConfig() - Constructor for class com.hazelcast.config.MCMutualAuthConfig
 
megaBytes() - Method in class com.hazelcast.memory.MemorySize
Returns value of memory size in mega-bytes.
MEM_COPY_THRESHOLD - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
Member - Interface in com.hazelcast.core
Cluster member interface.
MEMBER_ADDED - Static variable in class com.hazelcast.core.MembershipEvent
This event type is fired when a new member joins the cluster.
MEMBER_ATTRIBUTE_CHANGED - Static variable in class com.hazelcast.core.MembershipEvent
This event type is fired if a member attribute has been changed or removed.
MEMBER_LIST_PUBLISH_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The interval at which the master sends the member lists are sent to other non-master members
MEMBER_REMOVED - Static variable in class com.hazelcast.core.MembershipEvent
This event type is fired if a member left the cluster or was decided to be unresponsive by other members for a extended time.
memberAdded(MembershipEvent) - Method in class com.hazelcast.core.MembershipAdapter
 
memberAdded(MembershipEvent) - Method in interface com.hazelcast.core.MembershipListener
Invoked when a new member is added to the cluster.
memberAdded(MembershipServiceEvent) - Method in class com.hazelcast.crdt.CRDTReplicationMigrationService
 
memberAdded(MembershipServiceEvent) - Method in interface com.hazelcast.spi.MembershipAwareService
Invoked when a new member is added to the cluster.
MemberAddressProvider - Interface in com.hazelcast.spi
IMPORTANT This interface is not intended to provide addresses of other cluster members with which the hazelcast instance will form a cluster.
MemberAddressProviderConfig - Class in com.hazelcast.config
Configuration for a custom MemberAddressProvider strategy.
MemberAddressProviderConfig() - Constructor for class com.hazelcast.config.MemberAddressProviderConfig
 
memberAttributeChanged(MemberAttributeEvent) - Method in class com.hazelcast.core.MembershipAdapter
 
memberAttributeChanged(MemberAttributeEvent) - Method in interface com.hazelcast.core.MembershipListener
Invoked when an attribute of a member was changed.
memberAttributeChanged(MemberAttributeServiceEvent) - Method in class com.hazelcast.crdt.CRDTReplicationMigrationService
 
memberAttributeChanged(MemberAttributeServiceEvent) - Method in interface com.hazelcast.spi.MembershipAwareService
Invoked when a member attribute is changed.
MemberAttributeConfig - Class in com.hazelcast.config
Contains configuration for attribute of member.
MemberAttributeConfig() - Constructor for class com.hazelcast.config.MemberAttributeConfig
 
MemberAttributeConfig(MemberAttributeConfig) - Constructor for class com.hazelcast.config.MemberAttributeConfig
 
MemberAttributeConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
MemberAttributeEvent - Class in com.hazelcast.core
Event for member attribute changes.
MemberAttributeEvent() - Constructor for class com.hazelcast.core.MemberAttributeEvent
 
MemberAttributeEvent(Cluster, Member, MemberAttributeOperationType, String, Object) - Constructor for class com.hazelcast.core.MemberAttributeEvent
 
MemberAttributeOperationType - Enum in com.hazelcast.cluster
Used to identify the type of member attribute change, either PUT or REMOVED.
MemberAttributeServiceEvent - Class in com.hazelcast.spi
This service event is fired to inform services about a change in a member's attributes collection
MemberAttributeServiceEvent() - Constructor for class com.hazelcast.spi.MemberAttributeServiceEvent
 
MemberAttributeServiceEvent(Cluster, MemberImpl, MemberAttributeOperationType, String, Object) - Constructor for class com.hazelcast.spi.MemberAttributeServiceEvent
 
MemberGroup - Interface in com.hazelcast.partition.membergroup
 
MemberGroupConfig - Class in com.hazelcast.config
Contains the configuration for a single member group.
MemberGroupConfig() - Constructor for class com.hazelcast.config.MemberGroupConfig
 
MemberGroupFactory - Interface in com.hazelcast.partition.membergroup
Defines how members will be grouped (e.g.
MemberGroupFactoryFactory - Class in com.hazelcast.partition.membergroup
 
MemberLeftException - Exception in com.hazelcast.core
A ExecutionException thrown when a member left during an invocation or execution.
MemberLeftException() - Constructor for exception com.hazelcast.core.MemberLeftException
 
MemberLeftException(String) - Constructor for exception com.hazelcast.core.MemberLeftException
 
MemberLeftException(Member) - Constructor for exception com.hazelcast.core.MemberLeftException
 
MemberLeftException(Throwable) - Constructor for exception com.hazelcast.core.MemberLeftException
 
MemberPartitionState - Interface in com.hazelcast.monitor
Partition related statistics to be used by MemberState implementations.
memberRemoved(MembershipEvent) - Method in class com.hazelcast.core.MembershipAdapter
 
memberRemoved(MembershipEvent) - Method in interface com.hazelcast.core.MembershipListener
Invoked when an existing member leaves the cluster.
memberRemoved(MembershipServiceEvent) - Method in class com.hazelcast.crdt.CRDTReplicationMigrationService
 
memberRemoved(MembershipServiceEvent) - Method in interface com.hazelcast.spi.MembershipAwareService
Invoked when an existing member leaves the cluster.
MemberSelector - Interface in com.hazelcast.core
Implementations of this interface select members that are capable of executing a special kind of task.
The MemberSelector.select(Member) method is called for every available member in the cluster and it is up to the implementation to decide if the member is going to be used or not.
MemberSelectors - Class in com.hazelcast.cluster.memberselector
A utility class to get MemberSelector instances.
MembershipAdapter - Class in com.hazelcast.core
Adapter for MembershipListener.
MembershipAdapter() - Constructor for class com.hazelcast.core.MembershipAdapter
 
MembershipAwareService - Interface in com.hazelcast.spi
An interface that can be implemented by a SPI service that needs to be notified members joining and leaving the cluster.
MembershipEvent - Class in com.hazelcast.core
Membership event fired when a new member is added to the cluster and/or when a member leaves the cluster or when there is a member attribute change via Member.setBooleanAttribute(String, boolean) and similar methods.
MembershipEvent(Cluster, Member, int, Set<Member>) - Constructor for class com.hazelcast.core.MembershipEvent
 
MembershipListener - Interface in com.hazelcast.core
Cluster membership listener.
MembershipServiceEvent - Class in com.hazelcast.spi
Membership event fired when a new member is added to the cluster and/or when a member leaves the cluster.
MembershipServiceEvent(MembershipEvent) - Constructor for class com.hazelcast.spi.MembershipServiceEvent
 
MemberSocketInterceptor - Interface in com.hazelcast.nio
Member Socket Interceptor can be registered via see SocketInterceptorConfig Warning: a MemberSocketInterceptor provides access to the socket and will bypass any TLS encryption.
MemberState - Interface in com.hazelcast.monitor
Local statistics for a Hazelcast member.
MemberVersion - Class in com.hazelcast.version
Determines the Hazelcast codebase version in terms of major.minor.patch version.
MemberVersion() - Constructor for class com.hazelcast.version.MemberVersion
 
MemberVersion(int, int, int) - Constructor for class com.hazelcast.version.MemberVersion
 
MemberVersion(String) - Constructor for class com.hazelcast.version.MemberVersion
 
MEMCACHE_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
MemorySize - Class in com.hazelcast.memory
MemorySize represents a memory size with given value and MemoryUnit.
MemorySize(long) - Constructor for class com.hazelcast.memory.MemorySize
 
MemorySize(long, MemoryUnit) - Constructor for class com.hazelcast.memory.MemorySize
 
MemoryStats - Interface in com.hazelcast.memory
Memory statistics for the JVM which current HazelcastInstance belongs to.
MemoryStatsSupport - Class in com.hazelcast.memory
This class provides heap usage statistics
MemoryUnit - Enum in com.hazelcast.memory
MemoryUnit represents memory size at a given unit of granularity and provides utility methods to convert across units.
merge(String, CacheEntryView, CacheEntryView) - Method in interface com.hazelcast.cache.CacheMergePolicy
Selects one of the merging and existing cache entries to be merged.
merge(String, CacheEntryView, CacheEntryView) - Method in class com.hazelcast.cache.merge.HigherHitsCacheMergePolicy
 
merge(String, CacheEntryView, CacheEntryView) - Method in class com.hazelcast.cache.merge.LatestAccessCacheMergePolicy
 
merge(String, CacheEntryView, CacheEntryView) - Method in class com.hazelcast.cache.merge.PassThroughCacheMergePolicy
 
merge(String, CacheEntryView, CacheEntryView) - Method in class com.hazelcast.cache.merge.PutIfAbsentCacheMergePolicy
 
merge(T) - Method in interface com.hazelcast.crdt.CRDT
Merges the state of a different replica into this CRDT.
merge(String, T) - Method in interface com.hazelcast.crdt.CRDTReplicationAwareService
Performs a merge of the local name CRDT with the provided state.
merge(PNCounterImpl) - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
 
merge(String, PNCounterImpl) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
merge(String, EntryView, EntryView) - Method in class com.hazelcast.map.merge.HigherHitsMapMergePolicy
 
merge(String, EntryView, EntryView) - Method in class com.hazelcast.map.merge.IgnoreMergingEntryMapMergePolicy
 
merge(String, EntryView, EntryView) - Method in class com.hazelcast.map.merge.LatestUpdateMapMergePolicy
 
merge(String, EntryView, EntryView) - Method in interface com.hazelcast.map.merge.MapMergePolicy
Selects one of the merging and existing map entries to be merged.
merge(String, EntryView, EntryView) - Method in class com.hazelcast.map.merge.PassThroughMergePolicy
 
merge(String, EntryView, EntryView) - Method in class com.hazelcast.map.merge.PutIfAbsentMapMergePolicy
 
merge(String, ReplicatedMapEntryView, ReplicatedMapEntryView) - Method in class com.hazelcast.replicatedmap.merge.HigherHitsMapMergePolicy
 
merge(String, ReplicatedMapEntryView, ReplicatedMapEntryView) - Method in class com.hazelcast.replicatedmap.merge.LatestUpdateMapMergePolicy
 
merge(String, ReplicatedMapEntryView, ReplicatedMapEntryView) - Method in class com.hazelcast.replicatedmap.merge.PassThroughMergePolicy
 
merge(String, ReplicatedMapEntryView, ReplicatedMapEntryView) - Method in class com.hazelcast.replicatedmap.merge.PutIfAbsentMapMergePolicy
 
merge(String, ReplicatedMapEntryView, ReplicatedMapEntryView) - Method in interface com.hazelcast.replicatedmap.merge.ReplicatedMapMergePolicy
Selects one of the merging and existing map entries to be merged.
merge(T, T) - Method in class com.hazelcast.spi.merge.DiscardMergePolicy
 
merge(T, T) - Method in class com.hazelcast.spi.merge.ExpirationTimeMergePolicy
 
merge(T, T) - Method in class com.hazelcast.spi.merge.HigherHitsMergePolicy
 
merge(SplitBrainMergeTypes.CardinalityEstimatorMergeTypes, SplitBrainMergeTypes.CardinalityEstimatorMergeTypes) - Method in class com.hazelcast.spi.merge.HyperLogLogMergePolicy
 
merge(T, T) - Method in class com.hazelcast.spi.merge.LatestAccessMergePolicy
 
merge(T, T) - Method in class com.hazelcast.spi.merge.LatestUpdateMergePolicy
 
merge(T, T) - Method in class com.hazelcast.spi.merge.PassThroughMergePolicy
 
merge(T, T) - Method in class com.hazelcast.spi.merge.PutIfAbsentMergePolicy
 
merge(T, T) - Method in interface com.hazelcast.spi.merge.SplitBrainMergePolicy
Selects the value of either the merging or the existing MergingValue which should be merged.
MERGE_FIRST_RUN_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The delay until the first run of the SplitBrainHandler
MERGE_NEXT_RUN_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The interval between invocations of the SplitBrainHandler
MERGE_POLICY_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
mergePolicyConfig - Variable in class com.hazelcast.config.AbstractBasicConfig
 
MergePolicyConfig - Class in com.hazelcast.config
Configuration for SplitBrainMergePolicy.
MergePolicyConfig() - Constructor for class com.hazelcast.config.MergePolicyConfig
 
MergePolicyConfig(String, int) - Constructor for class com.hazelcast.config.MergePolicyConfig
 
MergePolicyConfig(MergePolicyConfig) - Constructor for class com.hazelcast.config.MergePolicyConfig
 
MergePolicyProvider - Class in com.hazelcast.map.merge
A provider for MapMergePolicy instances.
MergePolicyProvider(NodeEngine) - Constructor for class com.hazelcast.map.merge.MergePolicyProvider
 
MergePolicyProvider - Class in com.hazelcast.replicatedmap.merge
A provider for ReplicatedMapMergePolicy instances.
MergePolicyProvider(NodeEngine) - Constructor for class com.hazelcast.replicatedmap.merge.MergePolicyProvider
 
MergingCosts<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of memory costs for the merging process after a split-brain.
MergingCreationTime<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view a creation time for the merging process after a split-brain.
MergingEntry<K,V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a data structure key/value-pair for the merging process after a split-brain.
MergingExpirationTime<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of an expiration time for the merging process after a split-brain.
MergingHits<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view access hits for the merging process after a split-brain.
MergingLastAccessTime<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a last access time for the merging process after a split-brain.
MergingLastStoredTime<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a last stored time for the merging process after a split-brain.
MergingLastUpdateTime<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a last update time for the merging process after a split-brain.
MergingMaxIdle<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a MaxIdle for the merging process after a split-brain.
MergingTTL<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a TTL for the merging process after a split-brain.
mergingValue - Variable in class com.hazelcast.core.EntryEvent
 
MergingValue<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a data structure value for the merging process after a split-brain.
MergingVersion<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a version for the merging process after a split-brain.
MERKLE_TREE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MerkleTree - Interface in com.hazelcast.wan.merkletree
Interface defining methods for Merkle tree implementations
MerkleTreeConfig - Class in com.hazelcast.config
Configuration for a merkle tree.
MerkleTreeConfig() - Constructor for class com.hazelcast.config.MerkleTreeConfig
 
MerkleTreeConfig(MerkleTreeConfig) - Constructor for class com.hazelcast.config.MerkleTreeConfig
MerkleTreeUtil - Class in com.hazelcast.wan.merkletree
Utility methods for Merkle tree implementation
Message<E> - Class in com.hazelcast.core
Message for ITopic.
Message(String, E, long, Member) - Constructor for class com.hazelcast.core.Message
 
MessageListener<E> - Interface in com.hazelcast.core
Message listener for ITopic.
messageObject - Variable in class com.hazelcast.core.Message
 
MigrationAwareService - Interface in com.hazelcast.spi
An interface that can be implemented by SPI services to get notified of partition changes; for example, if a MapService starts moving its data around because partitions are moving to a different machine.
migrationCompleted(MigrationEvent) - Method in interface com.hazelcast.core.MigrationListener
Invoked when a partition migration is completed.
MigrationEndpoint - Enum in com.hazelcast.spi.partition
Denotes endpoint of a migration.
MigrationEvent - Class in com.hazelcast.core
An event fired when a partition migration starts, completes or fails.
MigrationEvent() - Constructor for class com.hazelcast.core.MigrationEvent
 
MigrationEvent(int, Member, Member, MigrationEvent.MigrationStatus) - Constructor for class com.hazelcast.core.MigrationEvent
 
MigrationEvent.MigrationStatus - Enum in com.hazelcast.core
Migration status: Started, completed or failed
migrationFailed(MigrationEvent) - Method in interface com.hazelcast.core.MigrationListener
Invoked when a partition migration is failed.
MigrationListener - Interface in com.hazelcast.core
MigrationListener provides the ability to listen to partition migration events.
migrationStarted(MigrationEvent) - Method in interface com.hazelcast.core.MigrationListener
Invoked when a partition migration is started.
MIN_BACKUP_COUNT - Static variable in class com.hazelcast.config.CacheSimpleConfig
The minimum number of backups.
MIN_BACKUP_COUNT - Static variable in class com.hazelcast.config.MapConfig
The minimum number of backups
MIN_EVICTION_PERCENTAGE - Static variable in class com.hazelcast.config.MapConfig
The number of minimum eviction percentage
MIN_INITIAL_MEMORY_SIZE - Static variable in class com.hazelcast.config.NativeMemoryConfig
Minimum initial memory size in megabytes
minBy(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
multiAttribute(String...) - Static method in class com.hazelcast.projection.Projections
Returns a projection that extracts the value of the given attributePaths.
MulticastConfig - Class in com.hazelcast.config
Contains the configuration for the multicast discovery mechanism.
MulticastConfig() - Constructor for class com.hazelcast.config.MulticastConfig
 
MulticastDiscoveryStrategy - Class in com.hazelcast.spi.discovery.multicast
The multicast DiscoveryStrategy.
MulticastDiscoveryStrategy(DiscoveryNode, ILogger, Map<String, Comparable>) - Constructor for class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategy
 
MulticastDiscoveryStrategyFactory - Class in com.hazelcast.spi.discovery.multicast
Factory class which returns MulticastDiscoveryStrategy to Discovery SPI
MulticastDiscoveryStrategyFactory() - Constructor for class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategyFactory
 
MulticastProperties - Class in com.hazelcast.spi.discovery.multicast
Defines the name and default value for the Multicast Discovery Strategy.
MultiExecutionCallback - Interface in com.hazelcast.core
MultiExecutionCallback provides notification for when an execution is completed on each member that a task is submitted to.
MultiMap<K,V> - Interface in com.hazelcast.core
A specialized map whose keys can be associated with multiple values.
MULTIMAP_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MultiMapConfig - Class in com.hazelcast.config
Configuration for MultiMap.
MultiMapConfig() - Constructor for class com.hazelcast.config.MultiMapConfig
 
MultiMapConfig(String) - Constructor for class com.hazelcast.config.MultiMapConfig
 
MultiMapConfig(MultiMapConfig) - Constructor for class com.hazelcast.config.MultiMapConfig
 
MultiMapConfig.ValueCollectionType - Enum in com.hazelcast.config
Type of value collection
MultiMapConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
MultiMapConfigReadOnly(MultiMapConfig) - Constructor for class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
MultiMapPermission - Class in com.hazelcast.security.permission
 
MultiMapPermission(String, String...) - Constructor for class com.hazelcast.security.permission.MultiMapPermission
 
MutationDisallowedException - Exception in com.hazelcast.crdt
Exception that indicates that the state found on this replica disallows mutation.
MutationDisallowedException(String) - Constructor for exception com.hazelcast.crdt.MutationDisallowedException
 

N

name - Variable in class com.hazelcast.client.spi.ClientProxy
 
name - Variable in class com.hazelcast.config.AbstractBasicConfig
 
name - Variable in class com.hazelcast.core.AbstractIMapEvent
 
named(String, Runnable) - Static method in class com.hazelcast.scheduledexecutor.TaskUtils
Decorate any Runnable with a NamedTask to provide naming information to scheduler.
named(String, Callable<V>) - Static method in class com.hazelcast.scheduledexecutor.TaskUtils
Decorate any Callable with a NamedTask to provide naming information to scheduler.
NamedConfig - Interface in com.hazelcast.config
Interface for hazelcast data structures with name
NamedOperation - Interface in com.hazelcast.spi
Indicates that Operation carries the distributed data structure name that is going to work on.
NamedTask - Interface in com.hazelcast.scheduledexecutor
The NamedTask interface should be implemented by any task that needs to have an identification and enhanced atomicity upon scheduling the task.
NativeMemoryConfig - Class in com.hazelcast.config
Configures native memory region.
NativeMemoryConfig() - Constructor for class com.hazelcast.config.NativeMemoryConfig
 
NativeMemoryConfig.MemoryAllocatorType - Enum in com.hazelcast.config
Type of memory allocator: STANDARD: allocate/free memory using default OS memory manager POOLED: manage memory blocks in pool
NativeOutOfMemoryError - Error in com.hazelcast.memory
Thrown when Hazelcast cannot allocate required native memory.
NativeOutOfMemoryError() - Constructor for error com.hazelcast.memory.NativeOutOfMemoryError
 
NativeOutOfMemoryError(String) - Constructor for error com.hazelcast.memory.NativeOutOfMemoryError
 
NativeOutOfMemoryError(String, Throwable) - Constructor for error com.hazelcast.memory.NativeOutOfMemoryError
 
NEAR_CACHE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
NEAR_CACHE_PRELOADER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
NearCacheConfig - Class in com.hazelcast.config
Contains the configuration for a Near Cache.
NearCacheConfig() - Constructor for class com.hazelcast.config.NearCacheConfig
 
NearCacheConfig(String) - Constructor for class com.hazelcast.config.NearCacheConfig
 
NearCacheConfig(int, int, boolean, InMemoryFormat) - Constructor for class com.hazelcast.config.NearCacheConfig
 
NearCacheConfig(int, int, boolean, InMemoryFormat, EvictionConfig) - Constructor for class com.hazelcast.config.NearCacheConfig
 
NearCacheConfig(int, int, String, int, boolean, InMemoryFormat) - Constructor for class com.hazelcast.config.NearCacheConfig
NearCacheConfig(int, int, String, int, boolean, InMemoryFormat, EvictionConfig) - Constructor for class com.hazelcast.config.NearCacheConfig
NearCacheConfig(NearCacheConfig) - Constructor for class com.hazelcast.config.NearCacheConfig
 
NearCacheConfig.LocalUpdatePolicy - Enum in com.hazelcast.config
Defines how to reflect local updates to the Near Cache.
NearCacheConfigAccessor - Class in com.hazelcast.config
Accessor for the EvictionConfig of a NearCacheConfig to initialize the old default max size, if no size was configured by the user.
NearCacheConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
NearCacheConfigReadOnly() - Constructor for class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
NearCacheConfigReadOnly(NearCacheConfig) - Constructor for class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
NearCachePreloaderConfig - Class in com.hazelcast.config
Configuration for eviction.
NearCachePreloaderConfig() - Constructor for class com.hazelcast.config.NearCachePreloaderConfig
 
NearCachePreloaderConfig(NearCachePreloaderConfig) - Constructor for class com.hazelcast.config.NearCachePreloaderConfig
 
NearCachePreloaderConfig(String) - Constructor for class com.hazelcast.config.NearCachePreloaderConfig
 
NearCachePreloaderConfig(boolean, String) - Constructor for class com.hazelcast.config.NearCachePreloaderConfig
 
NearCacheStats - Interface in com.hazelcast.monitor
Near Cache statistics to be used by MemberState implementations.
NetworkConfig - Class in com.hazelcast.config
Contains configuration for Network.
NetworkConfig() - Constructor for class com.hazelcast.config.NetworkConfig
 
newAliasedDiscoveryConfig(String) - Static method in class com.hazelcast.client.config.ClientAliasedDiscoveryConfigUtils
Creates new AliasedDiscoveryConfig by the given tag.
newByteBuffer(int, boolean) - Static method in class com.hazelcast.nio.IOUtil
 
newClientTransactionContext(TransactionOptions, String) - Method in interface com.hazelcast.transaction.TransactionManagerService
 
newCombiner(KeyIn) - Method in interface com.hazelcast.mapreduce.CombinerFactory
Deprecated.
Build a new Combiner instance specific to the supplied key.
newCondition() - Method in interface com.hazelcast.core.ILock
This method is not implemented! Use ILock.newCondition(String) instead.
newCondition(String) - Method in interface com.hazelcast.core.ILock
Returns a new ICondition instance that is bound to this ILock instance with given name.
newConfigFor(String) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Creates new AliasedDiscoveryConfig by the given tag.
newCredentials() - Method in interface com.hazelcast.security.ICredentialsFactory
Creates new Credentials object.
newDiscoveryService(DiscoveryServiceSettings) - Method in interface com.hazelcast.spi.discovery.integration.DiscoveryServiceProvider
Instantiates a new instance of the DiscoveryService.
newDiscoveryStrategy(DiscoveryNode, ILogger, Map<String, Comparable>) - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategyFactory
Instantiates a new instance of the DiscoveryStrategy with the given configuration properties.
newDiscoveryStrategy(DiscoveryNode, ILogger, Map<String, Comparable>) - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategyFactory
 
newHazelcastClient() - Static method in class com.hazelcast.client.HazelcastClient
 
newHazelcastClient(ClientConfig) - Static method in class com.hazelcast.client.HazelcastClient
 
newHazelcastClient(HazelcastClientFactory) - Static method in class com.hazelcast.client.HazelcastClientManager
 
newHazelcastClient(ClientConfig, HazelcastClientFactory) - Static method in class com.hazelcast.client.HazelcastClientManager
 
newHazelcastInstance(Config) - Static method in class com.hazelcast.core.Hazelcast
Creates a new HazelcastInstance (a new node in a cluster).
newHazelcastInstance() - Static method in class com.hazelcast.core.Hazelcast
Creates a new HazelcastInstance (a new node in a cluster).
newHazelcastInstance(Config) - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Creates a new HazelcastOSGiInstance on the owner bundle with specified configuration.
newHazelcastInstance() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Creates a new HazelcastOSGiInstance on the owner bundle with default configuration.
newId() - Method in interface com.hazelcast.core.IdGenerator
Deprecated.
Generates and returns a cluster-wide unique ID.
newId() - Method in interface com.hazelcast.flakeidgen.FlakeIdGenerator
Generates and returns a cluster-wide unique ID.
newInputStream(ByteBuffer) - Static method in class com.hazelcast.nio.IOUtil
 
newInstance() - Method in enum com.hazelcast.cache.BuiltInCacheMergePolicies
Create a new instance of CacheMergePolicy.
newInstance(ClassLoader, String) - Static method in class com.hazelcast.nio.ClassLoaderUtil
Creates a new instance of class with className, using the no-arg constructor.
newJob(KeyValueSource<K, V>) - Method in interface com.hazelcast.mapreduce.JobTracker
Deprecated.
Builds a Job instance for the given KeyValueSource instance.
newLoggerFactory(String) - Static method in class com.hazelcast.logging.Logger
Creates a logger factory instance of the given preferred type.
newMapStore(String, Properties) - Method in interface com.hazelcast.core.MapStoreFactory
Produces a MapLoader or a MapStore for the given map name and properties.
newMemberGroupFactory(PartitionGroupConfig, DiscoveryService) - Static method in class com.hazelcast.partition.membergroup.MemberGroupFactoryFactory
 
newObjectInputStream(ClassLoader, ClassNameFilter, InputStream) - Static method in class com.hazelcast.nio.IOUtil
 
newOutputStream(ByteBuffer) - Static method in class com.hazelcast.nio.IOUtil
 
newPermissionCollection() - Method in class com.hazelcast.security.permission.AllPermissions
 
newPermissionCollection() - Method in class com.hazelcast.security.permission.ClusterPermission
 
newProbabilisticQuorumConfigBuilder(String, int) - Static method in class com.hazelcast.config.QuorumConfig
Returns a builder for QuorumConfig with the given name using a probabilistic quorum function, for the given quorum size that is enabled by default.
newQueueStore(String, Properties) - Method in interface com.hazelcast.core.QueueStoreFactory
 
newRecentlyActiveQuorumConfigBuilder(String, int, int) - Static method in class com.hazelcast.config.QuorumConfig
Returns a builder for a QuorumConfig with the given name using a recently-active quorum function for the given quorum size that is enabled by default.
newReducer(KeyIn) - Method in interface com.hazelcast.mapreduce.ReducerFactory
Deprecated.
Build a new Reducer instance specific to the supplied key.
newRingbufferStore(String, Properties) - Method in interface com.hazelcast.core.RingbufferStoreFactory
 
newTransactionContext() - Method in interface com.hazelcast.client.spi.ClientTransactionManagerService
 
newTransactionContext(TransactionOptions) - Method in interface com.hazelcast.client.spi.ClientTransactionManagerService
 
newTransactionContext() - Method in interface com.hazelcast.core.HazelcastInstance
Creates a new TransactionContext associated with the current thread using default options.
newTransactionContext(TransactionOptions) - Method in interface com.hazelcast.core.HazelcastInstance
Creates a new TransactionContext associated with the current thread with given options.
newTransactionContext(TransactionOptions) - Method in interface com.hazelcast.transaction.TransactionManagerService
 
newXATransactionContext(Xid, int) - Method in interface com.hazelcast.client.spi.ClientTransactionManagerService
 
next() - Method in interface com.hazelcast.client.LoadBalancer
Returns the next member to route to.
next() - Method in class com.hazelcast.spi.merge.RingbufferMergeDataReadOnlyIterator
 
nextPage() - Method in class com.hazelcast.query.PagingPredicate
sets the page value to next page
NO_OFFLOADING - Static variable in interface com.hazelcast.core.Offloadable
Constant meaning that there will be no off-loading if returned from the Offloadable.getExecutorName() method.
NoDataMemberInClusterException - Exception in com.hazelcast.partition
Thrown when there is no data member in the cluster to assign partitions.
NoDataMemberInClusterException(String) - Constructor for exception com.hazelcast.partition.NoDataMemberInClusterException
 
node(String, Object, Object...) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
NodeAware - Interface in com.hazelcast.spi
A 'capability' that can be implemented by object to get the Node injected.
NodeEngine - Interface in com.hazelcast.spi
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a ManagedService.
nodeEngine - Variable in class com.hazelcast.spi.Offload
 
NodeFilter - Interface in com.hazelcast.spi.discovery
The NodeFilter, if supplied, will retrieve all discovered nodes and might apply additional filtering based on vendor provided metadata.
NodeIOService - Class in com.hazelcast.nio
 
NodeIOService(Node, NodeEngineImpl) - Constructor for class com.hazelcast.nio.NodeIOService
 
NodeState - Interface in com.hazelcast.monitor
Local node statistics to be used by MemberState implementations.
NoLogFactory - Class in com.hazelcast.logging
 
NoLogFactory() - Constructor for class com.hazelcast.logging.NoLogFactory
 
noLogger() - Static method in class com.hazelcast.logging.Logger
 
NON_LOCAL_MEMBER_SELECTOR - Static variable in class com.hazelcast.cluster.memberselector.MemberSelectors
A MemberSelector instance that selects only remote members
NONE - Static variable in class com.hazelcast.security.permission.InstancePermission
 
NoOpHotRestartService - Class in com.hazelcast.hotrestart
Empty implementation of HotRestartService to avoid null checks.
NoOpHotRestartService() - Constructor for class com.hazelcast.hotrestart.NoOpHotRestartService
 
NoopInternalHotRestartService - Class in com.hazelcast.hotrestart
Empty implementation of InternalHotRestartService to avoid null checks.
NoopInternalHotRestartService() - Constructor for class com.hazelcast.hotrestart.NoopInternalHotRestartService
 
not(Predicate) - Static method in class com.hazelcast.query.Predicates
Creates a not predicate that will negate the result of the given predicate.
notEqual(Comparable) - Method in class com.hazelcast.query.EntryObject
 
notEqual(String, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates a not equal predicate that will pass items if the given value and the value stored under the given item attribute are not equal.
NotifiableEventListener<S> - Interface in com.hazelcast.spi
Contract point for event listeners to be notified by EventService.
Notifier - Interface in com.hazelcast.spi
A component used in wait/notify systems like Condition.
notifyExcludedMember(Address) - Method in interface com.hazelcast.hotrestart.InternalHotRestartService
Notifies the excluded member and triggers the member force start process.
notifyExcludedMember(Address) - Method in class com.hazelcast.hotrestart.NoopInternalHotRestartService
 
NULL_ARRAY_LENGTH - Static variable in class com.hazelcast.nio.Bits
for null arrays, this value is written to the stream to represent null array size.
numberAvg() - Static method in class com.hazelcast.aggregation.Aggregators
 
numberAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
 

O

ObjectDataInput - Interface in com.hazelcast.nio
Provides serialization methods for arrays of primitive types.
ObjectDataOutput - Interface in com.hazelcast.nio
Provides serialization methods for arrays by extending DataOutput
objectName - Variable in class com.hazelcast.spi.DefaultObjectNamespace
Deprecated.
 
ObjectNamespace - Interface in com.hazelcast.spi
An ObjectNamespace that makes identification of object within a service possible.
of(String) - Static method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
Reconstructs a ScheduledTaskHandler from a URN String.
of(int, int, int) - Static method in class com.hazelcast.version.MemberVersion
 
of(String) - Static method in class com.hazelcast.version.MemberVersion
 
of(int, int) - Static method in class com.hazelcast.version.Version
 
of(String) - Static method in class com.hazelcast.version.Version
Parse the given string to a Version.
offer(E) - Method in interface com.hazelcast.core.BaseQueue
Inserts the specified element into this queue if it is possible to do so immediately without violating capacity restrictions.
offer(E, long, TimeUnit) - Method in interface com.hazelcast.core.BaseQueue
Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to become available.
offer(E) - Method in interface com.hazelcast.core.TransactionalQueue
Inserts the specified element into this queue if it is possible to do so immediately without violating capacity restrictions.
offer(E, long, TimeUnit) - Method in interface com.hazelcast.core.TransactionalQueue
Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to become available.
Offload - Class in com.hazelcast.spi
This is an internal class.
Offload(Operation) - Constructor for class com.hazelcast.spi.Offload
Creates a new Offload instance.
OFFLOAD_ORDINAL - Static variable in class com.hazelcast.spi.CallStatus
The ordinal value for an Offload.
Offloadable - Interface in com.hazelcast.core
Allows off-loading the processing unit implementing this interface to the specified or default Executor.
OFFLOADABLE_EXECUTOR - Static variable in interface com.hazelcast.core.Offloadable
Constant meaning that processing will be off-loaded to the default OFFLOADABLE_EXECUTOR executor.
OFFLOADABLE_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
Name of the offloadable executor.
offloadedOperation() - Method in class com.hazelcast.spi.Offload
Returns the Operation that created this Offload.
oldValue - Variable in class com.hazelcast.core.EntryEvent
 
ON_JOIN_PERMISSIONS_OPERATION - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
This property is only available in Hazelcast 3.11.z patch stream (starting 3.11.2). Use SecurityConfig.setOnJoinPermissionOperation(...) instead in Hazelcast 3.12 and newer.
onAccept(Socket) - Method in interface com.hazelcast.nio.MemberSocketInterceptor
This method will be called when a connection to a member node is accepted meaning security requirements and clusters are matching.
onAccumulationFinished() - Method in class com.hazelcast.aggregation.Aggregator
Called after the last call to combine on a specific instance.
onChange(QuorumEvent) - Method in interface com.hazelcast.quorum.QuorumListener
Called when quorum presence state is changed.
onCombinationFinished() - Method in class com.hazelcast.aggregation.Aggregator
Called after the last call to combine on a specific instance.
onComplete(Map<Member, Object>) - Method in interface com.hazelcast.core.MultiExecutionCallback
Called after all executions are completed.
onConnect(ClientConnection) - Method in class com.hazelcast.client.connection.ClientConnectionStrategy
If the ClientConnectionManager opens a new connection to a member, this method will be called with the connection parameter
onConnect(Socket) - Method in interface com.hazelcast.nio.SocketInterceptor
Called when a connection is established.
onConnectionClose(Connection) - Method in interface com.hazelcast.nio.ConnectionManager
Deals with cleaning up a closed connection.
onConnectToCluster() - Method in class com.hazelcast.client.connection.ClientConnectionStrategy
If a cluster connection is established, this method will be called.
onDeregister(S, String, String, EventRegistration) - Method in interface com.hazelcast.spi.NotifiableEventListener
Called when this listener deregistered from EventService.
onDestroy() - Method in class com.hazelcast.client.spi.ClientProxy
Called before proxy is destroyed.
onDisconnect(ClientConnection) - Method in class com.hazelcast.client.connection.ClientConnectionStrategy
If a connection is disconnected, this method will be called with the connection parameter
onDisconnect(Address, Throwable) - Method in interface com.hazelcast.nio.IOService
 
onDisconnect(Address, Throwable) - Method in class com.hazelcast.nio.NodeIOService
 
onDisconnectFromCluster() - Method in class com.hazelcast.client.connection.ClientConnectionStrategy
If the cluster connection is lost for any reason, this method will be called.
onEntryEvent(EntryEvent<K, V>) - Method in class com.hazelcast.core.EntryAdapter
This method is called when an one of the methods of the EntryListener is not overridden.
onEvent(T) - Method in interface com.hazelcast.partition.PartitionEventListener
 
onExecutionFailure(Throwable) - Method in class com.hazelcast.spi.Operation
Called when an Exception/Error is thrown during operation execution.
onFailedConnection(Address) - Method in interface com.hazelcast.nio.IOService
 
onFailedConnection(Address) - Method in class com.hazelcast.nio.NodeIOService
 
onFailure(Throwable) - Method in interface com.hazelcast.core.ExecutionCallback
Called when an execution is completed with an error.
onFatalError(Exception) - Method in interface com.hazelcast.nio.IOService
 
onFatalError(Exception) - Method in class com.hazelcast.nio.NodeIOService
 
onHeartbeat(Member, long) - Method in interface com.hazelcast.quorum.HeartbeatAware
Notifies of a received heartbeat.
onInitialize() - Method in class com.hazelcast.client.spi.ClientProxy
Called when proxy is created.
onInvocationException(Throwable) - Method in class com.hazelcast.spi.Operation
Called when an Exception/Error is thrown during an invocation.
OnJoinPermissionOperationName - Enum in com.hazelcast.config
Enum of operation names for handling client permissions when the member is joining into the cluster.
onKeys(Iterable<? extends KeyIn>) - Method in interface com.hazelcast.mapreduce.Job
Deprecated.
Defines keys to execute the mapper and a possibly defined reducer against.
onKeys(KeyIn...) - Method in interface com.hazelcast.mapreduce.Job
Deprecated.
Defines keys to execute the mapper and a possibly defined reducer against.
onKeys(Iterable<? extends EntryKey>) - Method in interface com.hazelcast.mapreduce.MappingJob
Deprecated.
Defines keys to execute the mapper and a possibly defined reducer against.
onKeys(EntryKey...) - Method in interface com.hazelcast.mapreduce.MappingJob
Deprecated.
Defines keys to execute the mapper and a possibly defined reducer against.
onKeys(Iterable<EntryKey>) - Method in interface com.hazelcast.mapreduce.ReducingJob
Deprecated.
Defines keys to execute the mapper and a possibly defined reducer against.
onKeys(EntryKey...) - Method in interface com.hazelcast.mapreduce.ReducingJob
Deprecated.
Defines keys to execute the mapper and a possibly defined reducer against.
onKeys(Iterable<EntryKey>) - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
Deprecated.
Defines keys to execute the mapper and a possibly defined reducer against.
onKeys(EntryKey...) - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
Deprecated.
Defines keys to execute the mapper and a possibly defined reducer against.
onListenerRegister() - Method in interface com.hazelcast.client.spi.EventHandler
This method is called when registration request response is successfully returned from node.
onMapEvent(MapEvent) - Method in class com.hazelcast.core.EntryAdapter
This method is called when an one of the methods of the EntryListener is not overridden.
onMessage(Message) - Method in class com.hazelcast.console.ConsoleApp
 
onMessage(Message<E>) - Method in interface com.hazelcast.core.MessageListener
Invoked when a message is received for the added topic.
onOutOfMemory(OutOfMemoryError, HazelcastInstance[]) - Method in class com.hazelcast.client.ClientOutOfMemoryHandler
 
onOutOfMemory(OutOfMemoryError, HazelcastInstance[]) - Method in class com.hazelcast.core.OutOfMemoryHandler
When an OutOfMemoryError is caught by Hazelcast threads, this method is called for ALL HazelcastInstances knows by current JVM (actually ClassLoader).
onPartitionLost(IPartitionLostEvent) - Method in interface com.hazelcast.spi.PartitionAwareService
Invoked when a partition lost is detected
onPingLost(Member) - Method in interface com.hazelcast.quorum.PingAware
Notifies the QuorumFunction of ping loss.
onPingRestored(Member) - Method in interface com.hazelcast.quorum.PingAware
Notifies the QuorumFunction of a successful ping after one or more pings to that member were lost.
onRegister(S, String, String, EventRegistration) - Method in interface com.hazelcast.spi.NotifiableEventListener
Called when this listener registered to EventService.
onReplicationEvent(WanReplicationEvent) - Method in interface com.hazelcast.spi.ReplicationSupportingService
Processes a WAN replication event
onResponse(V) - Method in interface com.hazelcast.core.ExecutionCallback
Called when an execution is completed successfully.
onResponse(Member, Object) - Method in interface com.hazelcast.core.MultiExecutionCallback
Called when an execution is completed on a member.
onResult(T) - Method in class com.hazelcast.query.extractor.ValueCallback
Notifies about a value passed as an argument
onSetCallId(long) - Method in class com.hazelcast.spi.Operation
Called every time a new callId is set on the operation.
onShutdown() - Method in class com.hazelcast.client.spi.ClientProxy
Called before client shutdown.
onShutdown(long, TimeUnit) - Method in class com.hazelcast.crdt.CRDTReplicationMigrationService
Attempts to replicate only the unreplicated CRDT state to any non-local member in the cluster.
onShutdown(long, TimeUnit) - Method in interface com.hazelcast.spi.GracefulShutdownAwareService
A hook method that's called during graceful shutdown to provide safety for data managed by this service.
onSuccessfulConnection(Address) - Method in interface com.hazelcast.nio.IOService
 
onSuccessfulConnection(Address) - Method in class com.hazelcast.nio.NodeIOService
 
onWaitExpire() - Method in interface com.hazelcast.spi.BlockingOperation
 
op - Variable in class com.hazelcast.spi.InvocationBuilder
 
open(String, Object...) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
open(NodeEngine) - Method in class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
This method is called before accessing the key-value pairs of this KeyValueSource.
Operation - Class in com.hazelcast.spi
An operation could be compared to a Runnable.
Operation() - Constructor for class com.hazelcast.spi.Operation
 
OPERATION_BACKUP_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.GroupProperty
If an operation has backups, this property specifies how long the invocation will wait for acks from the backup replicas.
OPERATION_CALL_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
OperationAccessor - Class in com.hazelcast.spi
Allows access to certain attributes on an Operation.
OperationControl - Class in com.hazelcast.spi
Content of an Operation Control packet: a list of operations the remote member started on this member which are still running; a list of operations this member wants to cancel on the remote member. Operations are identified by their call ID.
OperationControl() - Constructor for class com.hazelcast.spi.OperationControl
 
OperationControl(long[], long[]) - Constructor for class com.hazelcast.spi.OperationControl
 
OperationFactory - Interface in com.hazelcast.spi
A Factory for creating Operation instances.
OperationResponseHandler<O extends Operation> - Interface in com.hazelcast.spi
A handler for the OperationService when it has calculated a response.
operationService - Variable in class com.hazelcast.spi.Offload
 
OperationService - Interface in com.hazelcast.spi
The OperationService is responsible for executing operations.
operationsToCancel() - Method in class com.hazelcast.spi.OperationControl
 
OperationTimeoutException - Exception in com.hazelcast.core
An unchecked version of TimeoutException.
OperationTimeoutException() - Constructor for exception com.hazelcast.core.OperationTimeoutException
 
OperationTimeoutException(String) - Constructor for exception com.hazelcast.core.OperationTimeoutException
 
OperationTimeoutException(String, String) - Constructor for exception com.hazelcast.core.OperationTimeoutException
 
OperationTimeoutException(String, Throwable) - Constructor for exception com.hazelcast.core.OperationTimeoutException
 
optional() - Method in interface com.hazelcast.config.properties.PropertyDefinition
Defines if this property is optional or not.
optional() - Method in class com.hazelcast.config.properties.SimplePropertyDefinition
 
or(MemberSelector...) - Static method in class com.hazelcast.cluster.memberselector.MemberSelectors
Selects a member when one of the selectors succeed
or(Predicate) - Method in class com.hazelcast.query.PredicateBuilder
 
or(Predicate...) - Static method in class com.hazelcast.query.Predicates
Creates an or predicate that will perform the logical or operation on the given predicates.
ordinal() - Method in class com.hazelcast.spi.CallStatus
Returns the ordinal value (useful for doing a switch case based on the type of CallStatus).
OutOfMemoryHandler - Class in com.hazelcast.core
Handler for OutOfMemoryError.
OutOfMemoryHandler() - Constructor for class com.hazelcast.core.OutOfMemoryHandler
 
OverflowPolicy - Enum in com.hazelcast.ringbuffer
Using this policy one can control the behavior what should to be done when an item is about to be added to the ringbuffer, but there is 0 remaining capacity.

P

Packet - Class in com.hazelcast.nio
A Packet is a piece of data sent over the wire.
Packet() - Constructor for class com.hazelcast.nio.Packet
 
Packet(byte[]) - Constructor for class com.hazelcast.nio.Packet
 
Packet(byte[], int) - Constructor for class com.hazelcast.nio.Packet
 
Packet.Type - Enum in com.hazelcast.nio
 
PacketIOHelper - Class in com.hazelcast.nio
Responsible for writing or reading an Packet.
PacketIOHelper() - Constructor for class com.hazelcast.nio.PacketIOHelper
 
PagingPredicate<K,V> - Class in com.hazelcast.query
This class is a special Predicate which helps to get a page-by-page result of a query.
PagingPredicate() - Constructor for class com.hazelcast.query.PagingPredicate
Used for serialization internally
PagingPredicate(int) - Constructor for class com.hazelcast.query.PagingPredicate
Construct with a pageSize results will not be filtered results will be natural ordered throws IllegalArgumentException if pageSize is not greater than 0
PagingPredicate(Predicate, int) - Constructor for class com.hazelcast.query.PagingPredicate
Construct with an inner predicate and pageSize results will be filtered via inner predicate results will be natural ordered throws IllegalArgumentException if pageSize is not greater than 0 throws IllegalArgumentException if inner predicate is also PagingPredicate
PagingPredicate(Comparator<Map.Entry<K, V>>, int) - Constructor for class com.hazelcast.query.PagingPredicate
Construct with a comparator and pageSize results will not be filtered results will be ordered via comparator throws IllegalArgumentException if pageSize is not greater than 0
PagingPredicate(Predicate<K, V>, Comparator<Map.Entry<K, V>>, int) - Constructor for class com.hazelcast.query.PagingPredicate
Construct with an inner predicate, comparator and pageSize results will be filtered via inner predicate results will be ordered via comparator throws IllegalArgumentException if pageSize is not greater than 0 throws IllegalArgumentException if inner predicate is also PagingPredicate
PagingPredicateAccessor - Class in com.hazelcast.query
This class provides paging accessor of predicate.
Parameters - Interface in com.hazelcast.security
This interface is used to pass parameters of a method call to a SecurityInterceptor.
parse(InputStream) - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
 
parse(InputStream) - Method in class com.hazelcast.config.AbstractConfigBuilder
Reads XML from InputStream and parses.
parse(InputStream) - Method in class com.hazelcast.config.XmlConfigBuilder
 
parse(String) - Static method in class com.hazelcast.memory.MemorySize
Parses string representation of a memory size value.
parse(String, MemoryUnit) - Static method in class com.hazelcast.memory.MemorySize
Parses string representation of a memory size value.
parse(I) - Method in class com.hazelcast.query.extractor.ArgumentParser
This method takes the unparsed argument object as an input and returns the parsed output that will be used by the ValueExtractor.
parse(Element) - Method in interface com.hazelcast.spi.ServiceConfigurationParser
 
parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.CacheManagerBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.HazelcastClientBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.HazelcastConfigBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.HazelcastInstanceDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.HazelcastTypeBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.hibernate.RegionFactoryBeanDefinitionParser
 
parseListeners(Node, Class) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
parseProperties(Node) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
parseProxyFactories(Node, Class) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
parseSerialization(Node) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
parseSocketInterceptorConfig(Node) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
parseString(String) - Static method in enum com.hazelcast.config.CacheDeserializedValues
Create instance from String
Partition - Interface in com.hazelcast.core
In Hazelcast the data is split up in partitions: by default, 271 and configurable through the 'hazelcast.partition.count' GroupProperty.
PARTITION_BACKUP_SYNC_INTERVAL - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
PARTITION_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Total number of partitions in the Hazelcast cluster.
PARTITION_FRAGMENTED_MIGRATION_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
PARTITION_GROUP_HOST - Static variable in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
Metadata key definition for a low-latency link on a shared physical node, in case of virtualization being used
PARTITION_GROUP_RACK - Static variable in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
Metadata key definition for a low-latency link inside the same data center but for different racks
PARTITION_GROUP_ZONE - Static variable in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
Metadata key definition for a low-latency link between (virtual) data centers in the same area
PARTITION_MAX_PARALLEL_REPLICATIONS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
PARTITION_MIGRATION_INTERVAL - Static variable in class com.hazelcast.spi.properties.GroupProperty
Time in seconds to sleep after a migration task.
PARTITION_MIGRATION_TIMEOUT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Timeout in seconds for all migration operations.
PARTITION_OPERATION_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
The number of partition operation handler threads per member.
PARTITION_STRATEGY_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
PARTITION_TABLE_SEND_INTERVAL - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
PartitionAware<T> - Interface in com.hazelcast.core
PartitionAware means that data will be based in the same member based on the partition key and implementing tasks will be executed on the PartitionAware.getPartitionKey()'s owner member.
PartitionAwareKey<K,P> - Class in com.hazelcast.core
PartitionAwareKey(K, P) - Constructor for class com.hazelcast.core.PartitionAwareKey
Creates a new PartitionAwareKey.
PartitionAwareOperation - Interface in com.hazelcast.spi
An interface that can be implemented by an operation to indicate that it should be invoked on a particular partition.
PartitionAwareService - Interface in com.hazelcast.spi
An interface that can be implemented by SPI services to get notified of when a partition-related event occurs; for example, if a MapService notifies its map listeners when partition is lost for a map.
PartitionEvent - Interface in com.hazelcast.partition
PartitionEvent is a base interface for partition related events.
PartitionEventListener<T extends PartitionEvent> - Interface in com.hazelcast.partition
PartitionEventListener is a base interface for partition-related event listeners.
PartitionGroupConfig - Class in com.hazelcast.config
With PartitionGroupConfig, you can control how primary and backup partitions are mapped to physical Members.
PartitionGroupConfig() - Constructor for class com.hazelcast.config.PartitionGroupConfig
 
PartitionGroupConfig.MemberGroupType - Enum in com.hazelcast.config
Type of member groups.
PartitionGroupMetaData - Enum in com.hazelcast.spi.partitiongroup
This class contains the definition of known Discovery SPI metadata to support automatic generation of zone aware backup strategies based on cloud or service discovery provided information.
PartitionGroupStrategy - Interface in com.hazelcast.spi.partitiongroup
A PartitionGroupStrategy implementation defines a strategy how backup groups are designed.
partitionId - Variable in class com.hazelcast.spi.InvocationBuilder
 
PartitionIdAware - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
PARTITIONING_STRATEGY - Static variable in class com.hazelcast.spi.AbstractDistributedObject
 
PARTITIONING_STRATEGY_CLASS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
PartitioningStrategy<K> - Interface in com.hazelcast.core
PartitioningStrategy allows keys to be located on the same member.
PartitioningStrategyConfig - Class in com.hazelcast.config
Contains the configuration for partitioning strategy.
PartitioningStrategyConfig() - Constructor for class com.hazelcast.config.PartitioningStrategyConfig
 
PartitioningStrategyConfig(PartitioningStrategyConfig) - Constructor for class com.hazelcast.config.PartitioningStrategyConfig
 
PartitioningStrategyConfig(String) - Constructor for class com.hazelcast.config.PartitioningStrategyConfig
 
PartitioningStrategyConfig(PartitioningStrategy) - Constructor for class com.hazelcast.config.PartitioningStrategyConfig
 
PartitioningStrategyConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
PartitioningStrategyConfigReadOnly(PartitioningStrategyConfig) - Constructor for class com.hazelcast.config.PartitioningStrategyConfigReadOnly
Deprecated.
 
partitionLost(MapPartitionLostEvent) - Method in interface com.hazelcast.map.listener.MapPartitionLostListener
Invoked when owner and all backups of a partition is lost for a specific map.
partitionLost(PartitionLostEvent) - Method in interface com.hazelcast.partition.PartitionLostListener
Invoked when a partition loses its owner and all backups.
PartitionLostEvent - Class in com.hazelcast.partition
The event that is fired when a partition lost its owner and all backups.
PartitionLostEvent() - Constructor for class com.hazelcast.partition.PartitionLostEvent
 
PartitionLostEvent(int, int, Address) - Constructor for class com.hazelcast.partition.PartitionLostEvent
 
PartitionLostListener - Interface in com.hazelcast.partition
PartitionLostListener provides the ability to be notified upon a possible data loss when a partition loses a replica.
PartitionMigratingException - Exception in com.hazelcast.spi.exception
A RetryableHazelcastException that is thrown when an operation is executed on a partition, but that partition is currently being moved around.
PartitionMigratingException(Address, int, String, String) - Constructor for exception com.hazelcast.spi.exception.PartitionMigratingException
 
PartitionMigratingException(String) - Constructor for exception com.hazelcast.spi.exception.PartitionMigratingException
 
PartitionMigrationEvent - Class in com.hazelcast.spi
An EventObject for a partition migration.
PartitionMigrationEvent(MigrationEndpoint, int, int, int) - Constructor for class com.hazelcast.spi.PartitionMigrationEvent
 
PartitionPredicate<K,V> - Class in com.hazelcast.query
A Predicate that restricts the execution of a Predicate to a single Partition.
PartitionPredicate() - Constructor for class com.hazelcast.query.PartitionPredicate
 
PartitionPredicate(Object, Predicate<K, V>) - Constructor for class com.hazelcast.query.PartitionPredicate
Creates a new PartitionPredicate.
PartitionReplicationEvent - Class in com.hazelcast.spi
An event send to MigrationAwareService when partition changes happen.
PartitionReplicationEvent(int, int) - Constructor for class com.hazelcast.spi.PartitionReplicationEvent
Creates a PartitionReplicationEvent
PartitionService - Interface in com.hazelcast.core
PartitionService allows you to query Partitions and attach/detach MigrationListeners to listen to partition migration events.
PassThroughCacheMergePolicy - Class in com.hazelcast.cache.merge
Merges cache entries from source to destination directly unless the merging entry is null.
PassThroughCacheMergePolicy() - Constructor for class com.hazelcast.cache.merge.PassThroughCacheMergePolicy
 
PassThroughMergePolicy - Class in com.hazelcast.map.merge
Merges map entries from source to destination directly unless the merging entry is null.
PassThroughMergePolicy() - Constructor for class com.hazelcast.map.merge.PassThroughMergePolicy
 
PassThroughMergePolicy - Class in com.hazelcast.replicatedmap.merge
Merges replicated map entries from source to destination directly unless the merging entry is null.
PassThroughMergePolicy<V,T extends MergingValue<V>> - Class in com.hazelcast.spi.merge
Merges data structure entries from source to destination directly unless the merging entry is null.
PassThroughMergePolicy() - Constructor for class com.hazelcast.spi.merge.PassThroughMergePolicy
 
pause(String, String) - Method in interface com.hazelcast.wan.WanReplicationService
Pauses WAN replication for the given wanReplicationName and targetGroupName on this hazelcast instance.
peek() - Method in interface com.hazelcast.core.TransactionalQueue
peek(long, TimeUnit) - Method in interface com.hazelcast.core.TransactionalQueue
PermissionConfig - Class in com.hazelcast.config
Contains the configuration for a permission.
PermissionConfig() - Constructor for class com.hazelcast.config.PermissionConfig
 
PermissionConfig(PermissionConfig.PermissionType, String, String) - Constructor for class com.hazelcast.config.PermissionConfig
 
PermissionConfig(PermissionConfig) - Constructor for class com.hazelcast.config.PermissionConfig
 
PermissionConfig.PermissionType - Enum in com.hazelcast.config
Type of permission
PermissionPolicyConfig - Class in com.hazelcast.config
Contains the configuration for policy of permission
PermissionPolicyConfig() - Constructor for class com.hazelcast.config.PermissionPolicyConfig
 
PermissionPolicyConfig(String) - Constructor for class com.hazelcast.config.PermissionPolicyConfig
 
PHONE_HOME_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
PingAware - Interface in com.hazelcast.quorum
Quorum functions that need access to ICMP ping failure detector should implement this interface; the instance of PingFailureDetector used by this member's ClusterHeartbeatManager will be provided on initialization.
PlaceHolder - Class in com.hazelcast
 
PlaceHolder() - Constructor for class com.hazelcast.PlaceHolder
 
PN_COUNTER - Static variable in class com.hazelcast.crdt.CRDTDataSerializerHook
The (de)serialization constant for a PNCounter implementation
PN_COUNTER_ADD_OPERATION - Static variable in class com.hazelcast.crdt.CRDTDataSerializerHook
The constant for the PNCounter AddOperation
PN_COUNTER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
PN_COUNTER_GET_OPERATION - Static variable in class com.hazelcast.crdt.CRDTDataSerializerHook
The constant for the PNCounter GetOperation
PN_COUNTER_REPLICATION - Static variable in class com.hazelcast.crdt.CRDTDataSerializerHook
The (de)serialization constant for a PNCounter replication operation
PNCounter - Interface in com.hazelcast.crdt.pncounter
PN (Positive-Negative) CRDT counter.
PNCounterConfig - Class in com.hazelcast.config
Configuration for a PNCounter
PNCounterConfig() - Constructor for class com.hazelcast.config.PNCounterConfig
 
PNCounterConfig(String, int, String, boolean) - Constructor for class com.hazelcast.config.PNCounterConfig
 
PNCounterConfig(String) - Constructor for class com.hazelcast.config.PNCounterConfig
 
PNCounterConfig(PNCounterConfig) - Constructor for class com.hazelcast.config.PNCounterConfig
 
PNCounterImpl - Class in com.hazelcast.crdt.pncounter
PN (Positive-Negative) CRDT counter where each replica is identified by a String.
PNCounterImpl() - Constructor for class com.hazelcast.crdt.pncounter.PNCounterImpl
 
PNCounterPermission - Class in com.hazelcast.security.permission
 
PNCounterPermission(String, String...) - Constructor for class com.hazelcast.security.permission.PNCounterPermission
 
PNCounterProxy - Class in com.hazelcast.crdt.pncounter
Member proxy implementation for a PNCounter.
PNCounterReplicationOperation - Class in com.hazelcast.crdt.pncounter
CRDT replication operation for a PNCounter.
PNCounterReplicationOperation() - Constructor for class com.hazelcast.crdt.pncounter.PNCounterReplicationOperation
 
PNCounterService - Class in com.hazelcast.crdt.pncounter
Service responsible for PNCounter proxies and replication operation.
PNCounterService() - Constructor for class com.hazelcast.crdt.pncounter.PNCounterService
 
poll() - Method in interface com.hazelcast.core.BaseQueue
Retrieves and removes the head of this queue, or returns null if this queue is empty.
poll(long, TimeUnit) - Method in interface com.hazelcast.core.BaseQueue
Retrieves and removes the head of this queue, waiting up to the specified wait time if necessary for an element to become available.
poll() - Method in interface com.hazelcast.core.IQueue
 
poll(long, TimeUnit) - Method in interface com.hazelcast.core.IQueue
 
poll() - Method in interface com.hazelcast.core.TransactionalQueue
Retrieves and removes the head of this queue, or returns null if this queue is empty.
poll(long, TimeUnit) - Method in interface com.hazelcast.core.TransactionalQueue
Retrieves and removes the head of this queue, waiting up to the specified wait time if necessary for an element to become available.
populate(LiveOperations) - Method in interface com.hazelcast.spi.LiveOperationsTracker
Populate the LiveOperations
PORT - Static variable in class com.hazelcast.spi.discovery.multicast.MulticastProperties
Property used to define multicast port.
Portable - Interface in com.hazelcast.nio.serialization
Portable provides an alternative serialization method.
PortableFactory - Interface in com.hazelcast.nio.serialization
PortableFactory is used to create Portable instances during de-serialization.
PortableReader - Interface in com.hazelcast.nio.serialization
Provides a mean of reading portable fields from a binary in form of java primitives arrays of java primitives, nested portable fields and array of portable fields.
PortableWriter - Interface in com.hazelcast.nio.serialization
Provides a mean of writing portable fields to a binary in form of java primitives arrays of java primitives, nested portable fields and array of portable fields.
position() - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
position(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
position() - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
position(int) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
postDestroy() - Method in class com.hazelcast.client.spi.ClientProxy
Called after proxy is destroyed.
postDestroy() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
PostJoinAwareService - Interface in com.hazelcast.spi
Marker interface for services that want to return operations to be executed on the cluster members after a join has been finalized.
PostProcessingMapStore - Interface in com.hazelcast.core
Implement this interface if you modify the value in MapStore.store(K key, V value) method.
preDestroy() - Method in class com.hazelcast.client.spi.ClientProxy
Called before proxy is destroyed and determines whether destroy should be done.
preDestroy() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
Predicate<K,V> - Interface in com.hazelcast.query
Represents a map entry predicate.
PREDICATE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
PredicateBuilder - Class in com.hazelcast.query
This class provides functionality to build predicate.
PredicateBuilder() - Constructor for class com.hazelcast.query.PredicateBuilder
 
PredicateConfig - Class in com.hazelcast.config
Contains the configuration for an Predicate.
PredicateConfig() - Constructor for class com.hazelcast.config.PredicateConfig
Creates a PredicateConfig without className/implementation.
PredicateConfig(String) - Constructor for class com.hazelcast.config.PredicateConfig
Creates a PredicateConfig with the given className.
PredicateConfig(PredicateConfig) - Constructor for class com.hazelcast.config.PredicateConfig
 
PredicateConfig(Predicate) - Constructor for class com.hazelcast.config.PredicateConfig
Creates a PredicateConfig with the given implementation.
Predicates - Class in com.hazelcast.query
A utility class to create Predicate instances.
PREFER_IPv4_STACK - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
PrefixedDistributedObject - Interface in com.hazelcast.core
Contact point for special DistributedObject's which has prefixed name.
PreJoinAwareService - Interface in com.hazelcast.spi
Services which need to perform operations on a joining member just before the member is set as joined must implement this interface.
prepareMergeRunnable() - Method in interface com.hazelcast.spi.SplitBrainHandlerService
When the two separate clusters merge (resolve a split-brain), this method is called to return a Runnable, that will merge the clusters.
prepareMigrationOperation(int) - Method in interface com.hazelcast.crdt.CRDTReplicationAwareService
Returns a migration operation for all of the CRDT states not owned by this member.
prepareMigrationOperation(int) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
prepareReplicationOperation(Map<String, VectorClock>, int) - Method in interface com.hazelcast.crdt.CRDTReplicationAwareService
Returns a replication operation for the provided vector clocks.
prepareReplicationOperation(Map<String, VectorClock>, int) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
prepareReplicationOperation(PartitionReplicationEvent, Collection<ServiceNamespace>) - Method in interface com.hazelcast.spi.FragmentedMigrationAwareService
Returns an operation to replicate service data and/or state for a specific partition replica and namespaces on another cluster member.
prepareReplicationOperation(PartitionReplicationEvent) - Method in interface com.hazelcast.spi.MigrationAwareService
Returns an operation to replicate service data and/or state for a specific partition replica on another cluster member.
prepareToSafeShutdown() - Method in interface com.hazelcast.crdt.CRDTReplicationAwareService
Prepares the service for replication and shutdown.
prepareToSafeShutdown() - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
previousPage() - Method in class com.hazelcast.query.PagingPredicate
sets the page value to previous page
primary() - Method in class com.hazelcast.client.connection.Addresses
 
PRIMITIVE_TYPE_BOOLEAN - Static variable in class com.hazelcast.nio.IOUtil
 
PRIMITIVE_TYPE_BYTE - Static variable in class com.hazelcast.nio.IOUtil
 
PRIMITIVE_TYPE_DOUBLE - Static variable in class com.hazelcast.nio.IOUtil
 
PRIMITIVE_TYPE_FLOAT - Static variable in class com.hazelcast.nio.IOUtil
 
PRIMITIVE_TYPE_INTEGER - Static variable in class com.hazelcast.nio.IOUtil
 
PRIMITIVE_TYPE_LONG - Static variable in class com.hazelcast.nio.IOUtil
 
PRIMITIVE_TYPE_SHORT - Static variable in class com.hazelcast.nio.IOUtil
 
PRIMITIVE_TYPE_UTF - Static variable in class com.hazelcast.nio.IOUtil
 
print(Object) - Method in class com.hazelcast.console.ConsoleApp
 
println(Object) - Method in class com.hazelcast.console.ConsoleApp
 
PRIORITY_GENERIC_OPERATION_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
The number of priority generic operation handler threads per member.
PrivateApi - Annotation Type in com.hazelcast.spi.annotation
Marker for private api.
ProbabilisticQuorumConfigBuilder - Class in com.hazelcast.config
Builder for a QuorumConfig configured with ProbabilisticQuorumFunction that considers members present in the context of a quorum using a probabilistic, adaptive quorum function.
process(Node) - Method in class com.hazelcast.config.AbstractConfigBuilder
 
process(Map.Entry<K, V>) - Method in interface com.hazelcast.map.EntryProcessor
Process the entry without worrying about concurrency.
processBackup(Map.Entry<K, V>) - Method in interface com.hazelcast.map.EntryBackupProcessor
 
project(Projection<Map.Entry<K, V>, R>) - Method in interface com.hazelcast.core.IMap
Applies the projection logic on all map entries and returns the result
project(Projection<Map.Entry<K, V>, R>, Predicate<K, V>) - Method in interface com.hazelcast.core.IMap
Applies the projection logic on map entries filtered with the Predicated and returns the result
Projection<I,O> - Class in com.hazelcast.projection
Enables transforming object into other objects.
Projection() - Constructor for class com.hazelcast.projection.Projection
 
Projections - Class in com.hazelcast.projection
A utility class to create basic Projection instances.
promoteLocalLiteMember() - Method in interface com.hazelcast.core.Cluster
Promotes local lite member to data member.
properties() - Method in interface com.hazelcast.nio.IOService
 
properties() - Method in class com.hazelcast.nio.NodeIOService
 
propertiesByInstanceItself(HazelcastInstance) - Static method in class com.hazelcast.cache.HazelcastCachingProvider
Create the Properties with the provided instance itself.
propertiesByInstanceName(String) - Static method in class com.hazelcast.cache.HazelcastCachingProvider
Create the Properties with the provided instance name.
propertiesByLocation(String) - Static method in class com.hazelcast.cache.HazelcastCachingProvider
Create the Properties with the provided config file location.
PROPERTY_CIPHER_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Replacer property name to configure Cipher algorithm name.
PROPERTY_KEY_LENGTH_BITS - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Replacer property name to configure key length (in bits).
PROPERTY_PASSWORD_FILE - Static variable in class com.hazelcast.config.replacer.EncryptionReplacer
Replacer property name to configure path to a password file which content should be used as part of the encryption password.
PROPERTY_PASSWORD_NETWORK_INTERFACE - Static variable in class com.hazelcast.config.replacer.EncryptionReplacer
Replacer property name to configure network interface name used to retrieve MAC address used as part of the encryption password.
PROPERTY_PASSWORD_USER_PROPERTIES - Static variable in class com.hazelcast.config.replacer.EncryptionReplacer
Replacer property name to configure true/false flag contolling if users properties should be used as part of the encryption password.
PROPERTY_SALT_LENGTH_BYTES - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Replacer property name to configure salt length (in bytes).
PROPERTY_SECRET_KEY_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Replacer property name to configure SecretKeySpec algorithm name.
PROPERTY_SECRET_KEY_FACTORY_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Replacer property name to configure SecretKeyFactory algorithm name.
PROPERTY_SECURITY_PROVIDER - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Replacer property name to configure Java Security provider name used for Cipher and SecretKeyFactory selection.
PropertyDefinition - Interface in com.hazelcast.config.properties
This interface describes an extended approach of the currently available pure property based configuration inside Hazelcast and helps implementing an automatic and transparent way to verify configuration as well as converting types based on provided validators and converters.
PropertyExtractor<ValueIn,ValueOut> - Interface in com.hazelcast.mapreduce.aggregation
Deprecated.
Use fast-aggregations Aggregator
PropertyReplacer - Class in com.hazelcast.config.replacer
ConfigReplacer for replacing property names with property values for properties provided in PropertyReplacer.init(Properties) method.
PropertyReplacer() - Constructor for class com.hazelcast.config.replacer.PropertyReplacer
 
PropertyTypeConverter - Enum in com.hazelcast.config.properties
This enum class contains basic TypeConverter implementations to convert strings to all common basic Java types.
PROTOCOL_LENGTH - Static variable in class com.hazelcast.nio.Protocols
The length in bytes of the of the protocol-string
Protocols - Class in com.hazelcast.nio
First bytes to send a node that defines selected protocol
ProxyFactoryConfig - Class in com.hazelcast.client.config
This class is related to SPI.
ProxyFactoryConfig() - Constructor for class com.hazelcast.client.config.ProxyFactoryConfig
 
ProxyFactoryConfig(String, String) - Constructor for class com.hazelcast.client.config.ProxyFactoryConfig
 
ProxyFactoryConfig(String, ClientProxyFactory) - Constructor for class com.hazelcast.client.config.ProxyFactoryConfig
 
ProxyManager - Class in com.hazelcast.client.spi
The ProxyManager handles client proxy instantiation and retrieval at start and runtime by registering corresponding service manager names and their ClientProxyFactorys.
ProxyManager(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.spi.ProxyManager
 
ProxyService - Interface in com.hazelcast.spi
A CoreService responsible for managing the DistributedObject proxies.
publish(E) - Method in interface com.hazelcast.core.ITopic
Publishes the message to all subscribers of this topic.
publishEvent(String, String, Object, int) - Method in interface com.hazelcast.spi.EventService
Publishes an event for all event registrations belonging to the specified service name and topic.
publishEvent(String, EventRegistration, Object, int) - Method in interface com.hazelcast.spi.EventService
Publishes an event for a specific event registration.
publishEvent(String, Collection<EventRegistration>, Object, int) - Method in interface com.hazelcast.spi.EventService
Publishes an event for multiple event registrations.
publishRemoteEvent(String, Collection<EventRegistration>, Object, int) - Method in interface com.hazelcast.spi.EventService
Publishes an event for multiple event registrations, excluding local ones.
publishReplicationEvent(String, ReplicationEventObject) - Method in interface com.hazelcast.wan.WanReplicationPublisher
Publish the eventObject WAN replication event.
publishReplicationEvent(WanReplicationEvent) - Method in interface com.hazelcast.wan.WanReplicationPublisher
Publishes the wanReplicationEvent on this publisher.
publishReplicationEventBackup(String, ReplicationEventObject) - Method in interface com.hazelcast.wan.WanReplicationPublisher
Publish the eventObject WAN replication event backup.
put(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Associates the specified value with the specified key in the cache using a custom ExpiryPolicy.
put(K, V) - Method in interface com.hazelcast.core.BaseMap
Associates the specified value with the specified key in this map.
put(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.BaseMap
Associates the specified value with the specified key in this map with a given ttl (time to live) value.
put(K, V) - Method in interface com.hazelcast.core.BaseMultiMap
Stores a key-value pair in the multimap.
put(K, V) - Method in interface com.hazelcast.core.IMap
Associates the specified value with the specified key in this map.
put(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Puts an entry into this map with a given TTL (time to live) value.
put(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Puts an entry into this map with a given TTL (time to live) value and max idle time value.
put(K, V) - Method in interface com.hazelcast.core.MultiMap
Stores a key-value pair in the multimap.
put(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.ReplicatedMap
Associates a given value to the specified key and replicates it to the cluster.
put(K, V) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.put(Object, Object).
put(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.put(Object, Object, long, TimeUnit).
put(K, V) - Method in interface com.hazelcast.core.TransactionalMultiMap
Stores a key-value pair in the multimap.
put(Object, Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
 
putAll(Map<? extends K, ? extends V>, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Copies all of the entries from the given map to the cache using a custom ExpiryPolicy.
putAll(Map<? extends K, ? extends V>) - Method in interface com.hazelcast.core.IMap
putAsync(K, V) - Method in interface com.hazelcast.cache.ICache
Asynchronously associates the specified value with the specified key in the cache.
putAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Asynchronously associates the specified value with the specified key in the cache using a custom ExpiryPolicy.
putAsync(K, V) - Method in interface com.hazelcast.core.IMap
Asynchronously puts the given key and value.
putAsync(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Asynchronously puts the given key and value into this map with a given TTL (time to live) value.
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Asynchronously puts the given key and value into this map with a given TTL (time to live) value and max idle time value.
putIfAbsent(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Associates the specified key with the given value if and only if there is not yet a mapping defined for the specified key.
putIfAbsent(K, V) - Method in interface com.hazelcast.core.BaseMap
If the specified key is not already associated with a value, associate it with the given value.
putIfAbsent(K, V) - Method in interface com.hazelcast.core.IMap
If the specified key is not already associated with a value, associate it with the given value.
putIfAbsent(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Puts an entry into this map with a given TTL (time to live) value, if the specified key is not already associated with a value.
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Puts an entry into this map with a given TTL (time to live) value and max idle time value.
putIfAbsent(K, V) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.putIfAbsent(Object, Object).
putIfAbsent(Object, Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
 
putIfAbsentAsync(K, V) - Method in interface com.hazelcast.cache.ICache
Asynchronously associates the specified key with the given value if and only if there is not yet a mapping defined for the specified key.
putIfAbsentAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Asynchronously associates the specified key with the given value if and only if there is not yet a mapping defined for the specified key.
PutIfAbsentCacheMergePolicy - Class in com.hazelcast.cache.merge
Merges cache entries from source to destination if they don't exist in the destination cache.
PutIfAbsentCacheMergePolicy() - Constructor for class com.hazelcast.cache.merge.PutIfAbsentCacheMergePolicy
 
PutIfAbsentMapMergePolicy - Class in com.hazelcast.map.merge
Merges map entries from source to destination if they don't exist in the destination map.
PutIfAbsentMapMergePolicy() - Constructor for class com.hazelcast.map.merge.PutIfAbsentMapMergePolicy
 
PutIfAbsentMapMergePolicy - Class in com.hazelcast.replicatedmap.merge
Merges replicated map entries from source to destination if they don't exist in the destination map.
PutIfAbsentMergePolicy<V,T extends MergingValue<V>> - Class in com.hazelcast.spi.merge
Merges data structure entries from source to destination if they don't exist in the destination data structure.
PutIfAbsentMergePolicy() - Constructor for class com.hazelcast.spi.merge.PutIfAbsentMergePolicy
 
putTransient(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Same as #put(K, V, long, java.util.concurrent.TimeUnit) except that the map store, if defined, will not be called to load/store/persist the entry.
putTransient(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Same as #put(K, V, long, java.util.concurrent.TimeUnit) except that the map store, if defined, will not be called to load/store/persist the entry.

Q

QUERY_CACHE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
QUERY_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
Name of the query executor.
QUERY_MAX_LOCAL_PARTITION_LIMIT_FOR_PRE_CHECK - Static variable in class com.hazelcast.spi.properties.GroupProperty
Maximum value of local partitions to trigger local pre-check for TruePredicate query operations on maps.
QUERY_OPTIMIZER_TYPE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Type of Query Optimizer.
QUERY_PREDICATE_PARALLEL_EVALUATION - Static variable in class com.hazelcast.spi.properties.GroupProperty
Run Query Evaluations for multiple partitions in parallel.
QUERY_RESULT_SIZE_LIMIT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Result size limit for query operations on maps.
QueryCache<K,V> - Interface in com.hazelcast.map
A concurrent, queryable data structure which is used to cache results of a continuous query executed on an IMap.
QueryCacheConfig - Class in com.hazelcast.config
Contains configuration for QueryCache.
QueryCacheConfig() - Constructor for class com.hazelcast.config.QueryCacheConfig
 
QueryCacheConfig(String) - Constructor for class com.hazelcast.config.QueryCacheConfig
 
QueryCacheConfig(QueryCacheConfig) - Constructor for class com.hazelcast.config.QueryCacheConfig
 
QueryConstants - Enum in com.hazelcast.query
Contains constants for Query.
QueryException - Exception in com.hazelcast.query
Exception class for the Query.
QueryException() - Constructor for exception com.hazelcast.query.QueryException
 
QueryException(String) - Constructor for exception com.hazelcast.query.QueryException
 
QueryException(String, Throwable) - Constructor for exception com.hazelcast.query.QueryException
 
QueryException(Throwable) - Constructor for exception com.hazelcast.query.QueryException
 
QueryResultSizeExceededException - Exception in com.hazelcast.map
This exception is thrown when a query exceeds a configurable result size limit.
QueryResultSizeExceededException(String) - Constructor for exception com.hazelcast.map.QueryResultSizeExceededException
 
QueryResultSizeExceededException() - Constructor for exception com.hazelcast.map.QueryResultSizeExceededException
 
QueryResultSizeExceededException(int, String) - Constructor for exception com.hazelcast.map.QueryResultSizeExceededException
 
QUEUE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
QUEUE_STORE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
QueueConfig - Class in com.hazelcast.config
Contains the configuration for an IQueue.
QueueConfig() - Constructor for class com.hazelcast.config.QueueConfig
 
QueueConfig(String) - Constructor for class com.hazelcast.config.QueueConfig
 
QueueConfig(QueueConfig) - Constructor for class com.hazelcast.config.QueueConfig
 
QueueConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
QueuePermission - Class in com.hazelcast.security.permission
 
QueuePermission(String, String...) - Constructor for class com.hazelcast.security.permission.QueuePermission
 
QueueStore<T> - Interface in com.hazelcast.core
QueueStore makes a queue backed by a central data store; such as database, disk, etc.
QueueStoreConfig - Class in com.hazelcast.config
Configuration for the QueueStore.
QueueStoreConfig() - Constructor for class com.hazelcast.config.QueueStoreConfig
 
QueueStoreConfig(QueueStoreConfig) - Constructor for class com.hazelcast.config.QueueStoreConfig
 
QueueStoreConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
QueueStoreConfigReadOnly(QueueStoreConfig) - Constructor for class com.hazelcast.config.QueueStoreConfigReadOnly
Deprecated.
 
QueueStoreFactory<T> - Interface in com.hazelcast.core
Creates a new QueueStore.
Quorum - Interface in com.hazelcast.quorum
Quorum provides access to the current status of a quorum.
QUORUM_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
QUORUM_LISTENER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
QuorumAwareService - Interface in com.hazelcast.spi
Quorum service can ask for quorum information to the QuorumAwareService to decide whether operation participates into a quorum or not.
QuorumConfig - Class in com.hazelcast.config
Configuration for cluster quorum, a means to protect consistency of data from network partitions.
QuorumConfig() - Constructor for class com.hazelcast.config.QuorumConfig
 
QuorumConfig(String, boolean) - Constructor for class com.hazelcast.config.QuorumConfig
 
QuorumConfig(String, boolean, int) - Constructor for class com.hazelcast.config.QuorumConfig
 
QuorumConfig(QuorumConfig) - Constructor for class com.hazelcast.config.QuorumConfig
 
QuorumConfigBuilder - Class in com.hazelcast.config
Commons for quorum config builders.
QuorumConfigBuilder() - Constructor for class com.hazelcast.config.QuorumConfigBuilder
 
QuorumEvent - Class in com.hazelcast.quorum
An Event that is send when a Quorum changes.
QuorumEvent(Object, int, Collection<Member>, boolean) - Constructor for class com.hazelcast.quorum.QuorumEvent
 
QuorumException - Exception in com.hazelcast.quorum
An exception thrown when the cluster size is below the defined threshold.
QuorumException(String) - Constructor for exception com.hazelcast.quorum.QuorumException
 
QuorumFunction - Interface in com.hazelcast.quorum
A function that can be used to conclude absence/presence of quorum.
QuorumListener - Interface in com.hazelcast.quorum
Listener to get notified when a quorum state is changed IMPORTANT: The term "quorum" simply refers to the count of members in the cluster required for an operation to succeed.
QuorumListenerConfig - Class in com.hazelcast.config
Confiquration class for QuorumListener IMPORTANT: The term "quorum" simply refers to the count of members in the cluster required for an operation to succeed.
QuorumListenerConfig() - Constructor for class com.hazelcast.config.QuorumListenerConfig
 
QuorumListenerConfig(String) - Constructor for class com.hazelcast.config.QuorumListenerConfig
 
QuorumListenerConfig(QuorumListener) - Constructor for class com.hazelcast.config.QuorumListenerConfig
 
quorumName - Variable in class com.hazelcast.config.AbstractBasicConfig
 
QuorumService - Interface in com.hazelcast.quorum
Quorum service can be used to trigger cluster quorums at any time.
QuorumType - Enum in com.hazelcast.quorum
Represents a cluster quorum type

R

raiseFlags(int) - Method in class com.hazelcast.nio.Packet
Raises all the flags raised in the argument.
RANDOM_EVICTION_POLICY - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
RandomEvictionPolicy - Class in com.hazelcast.map.eviction
Random eviction policy for an IMap
RandomEvictionPolicy() - Constructor for class com.hazelcast.map.eviction.RandomEvictionPolicy
 
randomPartitionKey() - Method in interface com.hazelcast.core.PartitionService
Deprecated.
ReachedMaxSizeException - Exception in com.hazelcast.map
Exception thrown when a write-behind MapStore rejects to accept a new element.
ReachedMaxSizeException(String) - Constructor for exception com.hazelcast.map.ReachedMaxSizeException
 
read(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
read(byte[]) - Method in interface com.hazelcast.nio.serialization.ByteArraySerializer
Converts given byte array to object
read(ObjectDataInput) - Method in interface com.hazelcast.nio.serialization.StreamSerializer
Reads object from objectDataInputStream
read(byte[], Class) - Method in interface com.hazelcast.nio.serialization.TypedByteArrayDeserializer
Reads object from objectDataInputStream
read(ObjectDataInput, Class) - Method in interface com.hazelcast.nio.serialization.TypedStreamDeserializer
Reads object from objectDataInputStream
read(String, ValueCallback<T>) - Method in class com.hazelcast.query.extractor.ValueReader
Read the value of the attribute specified by the path and returns the result via the callback.
read(String, ValueCollector<T>) - Method in class com.hazelcast.query.extractor.ValueReader
Read the value of the attribute specified by the path and returns the result directly to the collector.
read(long) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Reads one item from the ringbuffer.
readAttributeValue(ObjectDataInput) - Static method in class com.hazelcast.nio.IOUtil
 
readBoolean(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readBoolean(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readBooleanArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readBooleanArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readByte(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readByte(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readByteArray(ObjectDataInput) - Static method in class com.hazelcast.nio.IOUtil
 
readByteArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readByteArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readChar(byte[], int, boolean) - Static method in class com.hazelcast.nio.Bits
 
readChar(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readChar(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readCharArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readCharArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readCharB(byte[], int) - Static method in class com.hazelcast.nio.Bits
 
readCharL(byte[], int) - Static method in class com.hazelcast.nio.Bits
 
readCount() - Method in interface com.hazelcast.ringbuffer.ReadResultSet
Returns the number of items that have been read before filtering.
readData(ObjectDataInput) - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.AtomicLongConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.AtomicReferenceConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CollectionConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CountDownLatchConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.DurableExecutorConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.EntryListenerConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.EventJournalConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.EvictionConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.ExecutorConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.HotRestartConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.ItemListenerConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.LegacyCacheConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.LegacyCacheEvictionConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.ListenerConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.LockConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.MapAttributeConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.MapConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.MapIndexConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.MapStoreConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.MaxSizeConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.MergePolicyConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.MerkleTreeConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.MultiMapConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.NearCacheConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.PNCounterConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.PredicateConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.QueryCacheConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.QueueConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.QueueStoreConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.QuorumConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.ReliableTopicConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.ReplicatedMapConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.RingbufferConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.SemaphoreConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.TopicConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.WanConsumerConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.WanPublisherConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.WanReplicationConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.WanReplicationRef
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.WanSyncConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.console.Echo
 
readData(ObjectDataInput) - Method in class com.hazelcast.core.MemberAttributeEvent
 
readData(ObjectDataInput) - Method in class com.hazelcast.core.MigrationEvent
 
readData(ObjectDataInput) - Method in class com.hazelcast.core.PartitionAwareKey
 
readData(ObjectDataInput) - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.eviction.LFUEvictionPolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.eviction.LRUEvictionPolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.eviction.RandomEvictionPolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.merge.HigherHitsMapMergePolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.merge.IgnoreMergingEntryMapMergePolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.merge.LatestUpdateMapMergePolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.merge.PassThroughMergePolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.merge.PutIfAbsentMapMergePolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.nio.Address
 
readData() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readData(ObjectDataInput) - Method in interface com.hazelcast.nio.serialization.DataSerializable
Reads fields from the input stream
readData(ObjectDataInput) - Method in class com.hazelcast.partition.PartitionLostEvent
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.PagingPredicate
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.PartitionPredicate
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.PredicateBuilder
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.SqlPredicate
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.TruePredicate
 
readData(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.merge.HigherHitsMapMergePolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.merge.LatestUpdateMapMergePolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.merge.PassThroughMergePolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.merge.PutIfAbsentMapMergePolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.DefaultObjectNamespace
Deprecated.
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.DistributedObjectNamespace
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.Operation
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.OperationControl
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.partition.IPartitionLostEvent
 
readData(ObjectDataInput) - Method in class com.hazelcast.transaction.TransactionOptions
 
readData(ObjectDataInput) - Method in class com.hazelcast.version.MemberVersion
 
readData(ObjectDataInput) - Method in class com.hazelcast.version.Version
 
readData(ObjectDataInput) - Method in class com.hazelcast.wan.WanReplicationEvent
 
readDataAsObject() - Method in interface com.hazelcast.nio.ObjectDataInput
Reads to stored Data as an object instead of a Data instance.
readDouble(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readDouble(ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readDouble(int, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readDouble(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readDoubleArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readDoubleArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readFactories(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
 
readFloat(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readFloat(ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readFloat(int, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readFloat(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readFloatArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readFloatArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readFrom(DataInput) - Static method in enum com.hazelcast.core.MigrationEvent.MigrationStatus
 
readFrom(ByteBuffer) - Method in class com.hazelcast.nio.PacketIOHelper
Reads the packet data from the supplied ByteBuffer.
readFrom(DataInput) - Static method in enum com.hazelcast.spi.partition.MigrationEndpoint
 
readFully(InputStream, byte[]) - Static method in class com.hazelcast.nio.IOUtil
Fills a buffer from an InputStream.
readFullyOrNothing(InputStream, byte[]) - Static method in class com.hazelcast.nio.IOUtil
Fills a buffer from an InputStream.
readInt(byte[], int, boolean) - Static method in class com.hazelcast.nio.Bits
 
readInt(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readInt(ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readInt(int, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readInt(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readIntArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readIntArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readIntB(byte[], int) - Static method in class com.hazelcast.nio.Bits
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.crdt.AbstractCRDTReplicationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.AbstractLocalOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.Operation
 
readIntL(byte[], int) - Static method in class com.hazelcast.nio.Bits
 
readIntL(ByteBuffer) - Static method in class com.hazelcast.nio.Bits
 
readKeyValueTypes(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
 
readLine() - Method in interface com.hazelcast.console.LineReader
 
readListenerConfigurations(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
 
readLong(byte[], int, boolean) - Static method in class com.hazelcast.nio.Bits
 
readLong(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readLong(ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readLong(int, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readLong(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readLongArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readLongArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readLongB(byte[], int) - Static method in class com.hazelcast.nio.Bits
 
readLongL(byte[], int) - Static method in class com.hazelcast.nio.Bits
 
readManyAsync(long, int, int, IFunction<E, Boolean>) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Reads a batch of items from the Ringbuffer.
readObject(ObjectDataInput) - Static method in class com.hazelcast.nio.IOUtil
 
readObject() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readObject(Class) - Method in interface com.hazelcast.nio.ObjectDataInput
 
readOne(long) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Reads one item from the Ringbuffer.
readOnly - Variable in class com.hazelcast.config.EvictionConfig
 
ReadOnly - Interface in com.hazelcast.core
Allows notifying Hazelcast that the processing unit implementing this interface will not do any modifications.
ReadonlyOperation - Interface in com.hazelcast.spi
Read-only operations are allowed to run during migration and passive state.
readPortable(PortableReader) - Method in interface com.hazelcast.nio.serialization.Portable
Read portable fields using PortableReader
readPortable(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readPortable(PortableReader) - Method in class com.hazelcast.security.AbstractCredentials
 
readPortableArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readPortableInternal(PortableReader) - Method in class com.hazelcast.security.AbstractCredentials
 
readPortableInternal(PortableReader) - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
ReadResultSet<E> - Interface in com.hazelcast.ringbuffer
readShort(byte[], int, boolean) - Static method in class com.hazelcast.nio.Bits
 
readShort(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readShort(ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readShort(int, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readShort(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readShortArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readShortArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readShortB(byte[], int) - Static method in class com.hazelcast.nio.Bits
 
readShortL(byte[], int) - Static method in class com.hazelcast.nio.Bits
 
readUTF(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readUtf8Char(byte[], int, char[], int) - Static method in class com.hazelcast.nio.Bits
 
readUtf8Char(DataInput, byte) - Static method in class com.hazelcast.nio.Bits
 
readUTFArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readUTFArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
RecentlyActiveQuorumConfigBuilder - Class in com.hazelcast.config
Builder for a QuorumConfig configured with RecentlyActiveQuorumFunction that considers members present in the context of a quorum if the last received heartbeat is within a recent window of time.
reduce(ValueIn) - Method in class com.hazelcast.mapreduce.Reducer
Deprecated.
This method is called to supply values to be reduced into a final reduced result.
The reduce method might be called multiple times so the eventually reduced value needs to be held internally in a member state of the Reducer.
reducePermits(int) - Method in interface com.hazelcast.core.ISemaphore
Shrinks the number of available permits by the indicated reduction.
reducer(ReducerFactory<? super KeyIn, ? super ValueIn, ? extends ValueOut>) - Method in interface com.hazelcast.mapreduce.MappingJob
Deprecated.
Defines the ReducerFactory for this task.
Reducer<ValueIn,ValueOut> - Class in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
Reducer() - Constructor for class com.hazelcast.mapreduce.Reducer
Deprecated.
 
reducer(ReducerFactory<KeyIn, ValueIn, ValueOut>) - Method in interface com.hazelcast.mapreduce.ReducingJob
Deprecated.
Defines the ReducerFactory for this task.
ReducerFactory<KeyIn,ValueIn,ValueOut> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
ReducingJob<EntryKey,KeyIn,ValueIn> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
ReducingSubmittableJob<EntryKey,KeyIn,ValueIn> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
refresh() - Method in interface com.hazelcast.client.connection.AddressTranslator
Refreshes the internal lookup table if necessary.
refreshClientPermissions(Set<PermissionConfig>) - Method in interface com.hazelcast.security.SecurityService
Propagates changes made to client permissions to all members and reinitiates IPermissionPolicy with new configuration.
refreshPermissions(Set<PermissionConfig>) - Method in interface com.hazelcast.security.IPermissionPolicy
Replaces existing permissions with given set of permissions.
refreshPermissions(Set<PermissionConfig>) - Method in interface com.hazelcast.security.SecurityContext
 
regex(String, String) - Static method in class com.hazelcast.query.Predicates
Creates a regex predicate that will pass items if the given pattern matches the value stored under the given item attribute.
RegexConfigPatternMatcher - Class in com.hazelcast.config.matcher
This ConfigPatternMatcher uses Java regular expressions for matching.
RegexConfigPatternMatcher() - Constructor for class com.hazelcast.config.matcher.RegexConfigPatternMatcher
 
RegexConfigPatternMatcher(int) - Constructor for class com.hazelcast.config.matcher.RegexConfigPatternMatcher
 
RegionFactoryBeanDefinitionParser - Class in com.hazelcast.spring.hibernate
Parser for RegionFactory.
RegionFactoryBeanDefinitionParser() - Constructor for class com.hazelcast.spring.hibernate.RegionFactoryBeanDefinitionParser
 
register(String, ClientProxyFactory) - Method in class com.hazelcast.client.spi.ProxyManager
 
register(String, Class<? extends ClientProxy>) - Method in class com.hazelcast.client.spi.ProxyManager
 
register(String, int, int, ExecutorType) - Method in interface com.hazelcast.spi.ExecutionService
 
registerConnection(Address, Connection) - Method in interface com.hazelcast.nio.ConnectionManager
 
registerListener(ListenerMessageCodec, EventHandler) - Method in interface com.hazelcast.client.spi.ClientListenerService
 
registerListener(ListenerMessageCodec, EventHandler) - Method in class com.hazelcast.client.spi.ClientProxy
 
registerListener(String, String, Object) - Method in interface com.hazelcast.spi.EventService
Registers a listener on all cluster nodes.
registerListener(String, String, EventFilter, Object) - Method in interface com.hazelcast.spi.EventService
Registers a listener on all cluster nodes with an event filter.
registerLocalListener(String, String, Object) - Method in interface com.hazelcast.spi.EventService
Registers a local only listener.
registerLocalListener(String, String, EventFilter, Object) - Method in interface com.hazelcast.spi.EventService
Registers a local only listener with an event filter.
release() - Method in interface com.hazelcast.core.ISemaphore
Releases a permit, increasing the number of available permits by one.
release(int) - Method in interface com.hazelcast.core.ISemaphore
Releases the given number of permits, increasing the number of available permits by that amount.
RELIABLE_TOPIC_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
ReliableMessageListener<E> - Interface in com.hazelcast.topic
A MessageListener to better integrate with the reliable topic.
ReliableTopicConfig - Class in com.hazelcast.config
Configuration for a reliable ITopic.
ReliableTopicConfig() - Constructor for class com.hazelcast.config.ReliableTopicConfig
 
ReliableTopicConfig(String) - Constructor for class com.hazelcast.config.ReliableTopicConfig
Creates a new ReliableTopicConfig with default settings.
remainingCapacity() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Returns the remaining capacity of the ringbuffer.
RemoteMapReduceException - Exception in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
RemoteMapReduceException(String, List<Exception>) - Constructor for exception com.hazelcast.mapreduce.RemoteMapReduceException
Deprecated.
 
RemoteMerkleTreeView - Class in com.hazelcast.wan.merkletree
Represents the readonly view of a remote Merkle Tree.
RemoteService - Interface in com.hazelcast.spi
An interface that can be implemented by SPI-Services to give them the ability to create proxies to distributed objects.
remove(Object) - Method in interface com.hazelcast.core.BaseMap
Removes the mapping for a key from this map if it is present.
remove(Object, Object) - Method in interface com.hazelcast.core.BaseMap
Removes the entry for a key only if currently mapped to a given value.
remove(Object, Object) - Method in interface com.hazelcast.core.BaseMultiMap
Removes the given key value pair from the multimap.
remove(Object) - Method in interface com.hazelcast.core.BaseMultiMap
Removes all the entries associated with the given key.
remove(Object) - Method in interface com.hazelcast.core.IMap
Removes the mapping for a key from this map if it is present.
remove(Object, Object) - Method in interface com.hazelcast.core.IMap
Removes the entry for a key only if currently mapped to a given value.
remove(Object, Object) - Method in interface com.hazelcast.core.MultiMap
Removes the given key value pair from the multimap.
remove(Object) - Method in interface com.hazelcast.core.MultiMap
Removes all the entries with the given key.
remove(E) - Method in interface com.hazelcast.core.TransactionalList
Removes an item from the transactional list.
remove(Object) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.remove(Object).
remove(Object, Object) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.remove(Object, Object).
remove(Object, Object) - Method in interface com.hazelcast.core.TransactionalMultiMap
Removes the given key value pair from the multimap.
remove(Object) - Method in interface com.hazelcast.core.TransactionalMultiMap
Removes all the entries associated with the given key.
remove(E) - Method in interface com.hazelcast.core.TransactionalSet
Remove item from transactional set.
remove() - Method in class com.hazelcast.spi.merge.RingbufferMergeDataReadOnlyIterator
 
removeAll(Predicate<K, V>) - Method in interface com.hazelcast.core.IMap
Removes all entries which match with the supplied predicate.
removeAsync(K) - Method in interface com.hazelcast.cache.ICache
Asynchronously removes the mapping for a key from this cache if it is present.
removeAsync(K, V) - Method in interface com.hazelcast.cache.ICache
Asynchronously removes the mapping for the given key if and only if the currently mapped value equals to the value of oldValue.
removeAsync(K) - Method in interface com.hazelcast.core.IMap
Asynchronously removes the given key, returning an ICompletableFuture on which the caller can provide an ExecutionCallback to be invoked upon remove operation completion or block waiting for the operation to complete with Future.get().
removeAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
 
removeAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
Deprecated.
 
removeAttribute(String) - Method in interface com.hazelcast.core.Member
Removes a key-value pair attribute for this member if given key was previously assigned as an attribute.
If key wasn't assigned to a value this method does nothing.
removeCache(String, boolean) - Method in interface com.hazelcast.cache.HazelcastCacheManager
Removes the associated cache with the given cache name.
removeCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.config.AbstractCacheConfig
Remove a configuration for a CacheEntryListener.
removeCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
removeCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in interface com.hazelcast.config.CacheConfiguration
Remove a configuration for a CacheEntryListener.
removeClientListener(String) - Method in interface com.hazelcast.core.ClientService
Removes a ClientListener.
removeDistributedObjectListener(String) - Method in class com.hazelcast.client.spi.ProxyManager
 
removeDistributedObjectListener(String) - Method in interface com.hazelcast.core.HazelcastInstance
Removes the specified Distributed Object listener.
removeEndpoint(Address) - Method in interface com.hazelcast.nio.IOService
 
removeEndpoint(Address) - Method in class com.hazelcast.nio.NodeIOService
 
removeEntryListener(String) - Method in interface com.hazelcast.core.IMap
Removes the specified entry listener.
removeEntryListener(String) - Method in interface com.hazelcast.core.MultiMap
Removes the specified entry listener.
removeEntryListener(String) - Method in interface com.hazelcast.core.ReplicatedMap
Removes the specified entry listener.
removeEntryListener(String) - Method in interface com.hazelcast.map.QueryCache
 
removeInterceptor(String) - Method in interface com.hazelcast.core.IMap
Removes the given interceptor for this map, so it will not intercept operations anymore.
removeItemListener(String) - Method in interface com.hazelcast.core.ICollection
Removes the specified item listener.
removeLifecycleListener(String) - Method in interface com.hazelcast.core.LifecycleService
Removes a lifecycle listener.
removeLogListener(LogListener) - Method in interface com.hazelcast.logging.LoggingService
 
removeLogListener(LogListener) - Method in class com.hazelcast.logging.LoggingServiceImpl
 
removeMember(Member) - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
removeMember(Member) - Method in interface com.hazelcast.partition.membergroup.MemberGroup
 
removeMember(Member) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
removeMembershipListener(String) - Method in interface com.hazelcast.client.spi.ClientClusterService
 
removeMembershipListener(String) - Method in interface com.hazelcast.core.Cluster
Removes the specified MembershipListener.
removeMessageListener(String) - Method in interface com.hazelcast.core.ITopic
Stops receiving messages for the given message listener.
removeMigrationListener(String) - Method in interface com.hazelcast.core.PartitionService
Removes a MigrationListener.
removeMigrationListener(String) - Method in interface com.hazelcast.spi.partition.IPartitionService
 
removePartitionLostListener(String) - Method in interface com.hazelcast.cache.ICache
Removes the specified cache partition lost listener.
removePartitionLostListener(String) - Method in interface com.hazelcast.core.IMap
Removes the specified map partition lost listener.
removePartitionLostListener(String) - Method in interface com.hazelcast.core.PartitionService
Removes a PartitionLostListener.
removePartitionLostListener(String) - Method in interface com.hazelcast.spi.partition.IPartitionService
 
removeProperty(String) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
removeProxyListener(String) - Method in interface com.hazelcast.spi.ProxyService
 
removeWanEventCounters(String, String) - Method in interface com.hazelcast.wan.WanReplicationService
Removes all WAN event counters for the given serviceName and dataStructureName.
rename(File, File) - Static method in class com.hazelcast.nio.IOUtil
Ensures that the file described by fileNow is renamed to file described by fileToBe.
replace(K, V, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Atomically replaces the currently assigned value for the given key with the specified newValue if and only if the currently assigned value equals the value of oldValue using a custom ExpiryPolicy.
replace(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Atomically replaces the assigned value of the given key by the specified value using a custom ExpiryPolicy.
replace(K, V) - Method in interface com.hazelcast.core.BaseMap
Replaces the entry for a key only if it is currently mapped to some value.
replace(K, V, V) - Method in interface com.hazelcast.core.BaseMap
Replaces the entry for a key only if currently mapped to a given value.
replace(K, V, V) - Method in interface com.hazelcast.core.IMap
Replaces the entry for a key only if currently mapped to a given value.
replace(K, V) - Method in interface com.hazelcast.core.IMap
Replaces the entry for a key only if it is currently mapped to some value.
replace(K, V) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.replace(Object, Object).
replace(K, V, V) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.replace(Object, Object, Object).
replaceAsync(K, V) - Method in interface com.hazelcast.cache.ICache
Asynchronously replaces the assigned value of the given key by the specified value.
replaceAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Asynchronously replaces the assigned value of the given key by the specified value using a custom ExpiryPolicy.
replaceAsync(K, V, V) - Method in interface com.hazelcast.cache.ICache
Asynchronously replaces the currently assigned value for the given key with the specified newValue if and only if the currently assigned value equals the value of oldValue.
replaceAsync(K, V, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Asynchronously replaces the currently assigned value for the given key with the specified newValue if and only if the currently assigned value equals the value of oldValue using a custom ExpiryPolicy.
replicaIndex - Variable in class com.hazelcast.spi.InvocationBuilder
 
REPLICATED_MAP_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
ReplicatedMap<K,V> - Interface in com.hazelcast.core
A ReplicatedMap is a map-like data structure with weak consistency and values locally stored on every node of the cluster.
ReplicatedMapCantBeCreatedOnLiteMemberException - Exception in com.hazelcast.replicatedmap
Thrown when HazelcastInstance.getReplicatedMap(String) is invoked on a lite member.
ReplicatedMapCantBeCreatedOnLiteMemberException(Address) - Constructor for exception com.hazelcast.replicatedmap.ReplicatedMapCantBeCreatedOnLiteMemberException
 
ReplicatedMapCantBeCreatedOnLiteMemberException(String) - Constructor for exception com.hazelcast.replicatedmap.ReplicatedMapCantBeCreatedOnLiteMemberException
 
ReplicatedMapConfig - Class in com.hazelcast.config
Contains the configuration for an ReplicatedMap
ReplicatedMapConfig() - Constructor for class com.hazelcast.config.ReplicatedMapConfig
 
ReplicatedMapConfig(String) - Constructor for class com.hazelcast.config.ReplicatedMapConfig
Creates a ReplicatedMapConfig with the given name.
ReplicatedMapConfig(ReplicatedMapConfig) - Constructor for class com.hazelcast.config.ReplicatedMapConfig
 
ReplicatedMapMergePolicy - Interface in com.hazelcast.replicatedmap.merge
Policy for merging replicated map entries after a split-brain has been healed.
ReplicatedMapPermission - Class in com.hazelcast.security.permission
 
ReplicatedMapPermission(String, String...) - Constructor for class com.hazelcast.security.permission.ReplicatedMapPermission
 
ReplicationEventObject - Interface in com.hazelcast.wan
Interface for all WAN replication messages
ReplicationSupportingService - Interface in com.hazelcast.spi
An interface that can be implemented by SPI services to give them the ability to listen to WAN replication events.
requiresExplicitServiceName() - Method in class com.hazelcast.spi.Operation
Returns true to force the explicit service name serialization for this operation, false otherwise.
reset() - Method in interface com.hazelcast.cluster.Joiner
Deprecated.
 
reset() - Method in class com.hazelcast.crdt.CRDTReplicationMigrationService
 
reset() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Resets the observed state by this PN counter.
reset() - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
 
reset() - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
reset() - Method in class com.hazelcast.mapreduce.Combiner
Deprecated.
This method is always called after a chunk of data is retrieved.
reset() - Method in class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
This method resets all internal state to be a new instance.
reset() - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
reset() - Method in class com.hazelcast.query.PagingPredicate
resets for reuse
reset() - Method in interface com.hazelcast.spi.ManagedService
Resets this service back to its initial state.
resetFlagsTo(int) - Method in class com.hazelcast.nio.Packet
Resets the entire flags bitfield to the supplied value.
resetService(boolean) - Method in interface com.hazelcast.hotrestart.InternalHotRestartService
Resets local service data, removes hot restart directories and recreates them.
resetService(boolean) - Method in class com.hazelcast.hotrestart.NoopInternalHotRestartService
 
RESPONSE_THREAD_COUNT - Static variable in class com.hazelcast.client.spi.properties.ClientProperty
The number of response threads.
RESPONSE_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
The number of threads that process responses.
ResponseAlreadySentException - Exception in com.hazelcast.spi.exception
A HazelcastException indicating that there is some kind of system error causing a response to be send multiple times for some operation.
ResponseAlreadySentException() - Constructor for exception com.hazelcast.spi.exception.ResponseAlreadySentException
 
ResponseAlreadySentException(String) - Constructor for exception com.hazelcast.spi.exception.ResponseAlreadySentException
 
REST_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
resultDeserialized - Variable in class com.hazelcast.spi.InvocationBuilder
 
resume(String, String) - Method in interface com.hazelcast.wan.WanReplicationService
Resumes WAN replication for the given wanReplicationName and targetGroupName on this hazelcast instance.
retrieveAndDisposeResult(long) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Retrieves and disposes the result with the given taskId
retrieveInitialSequence() - Method in interface com.hazelcast.topic.ReliableMessageListener
Retrieves the initial sequence from which this ReliableMessageListener should start.
retrieveResult(long) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Retrieves the result with the given taskId
RetryableException - Interface in com.hazelcast.spi.exception
Marker interface for exceptions to indicate that an operation can be retried.
RetryableHazelcastException - Exception in com.hazelcast.spi.exception
A 'marker' exception that indicates that an operation can be retried.
RetryableHazelcastException() - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
 
RetryableHazelcastException(String) - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
 
RetryableHazelcastException(String, Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
 
RetryableHazelcastException(Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
 
RetryableIOException - Exception in com.hazelcast.spi.exception
A IOException indicating that there was a IO failure, but it can be retried.
RetryableIOException() - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
 
RetryableIOException(String) - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
 
RetryableIOException(String, Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
 
RetryableIOException(Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
 
returnsResponse() - Method in class com.hazelcast.spi.Operation
Method is intended to be subclassed.
Ringbuffer<E> - Interface in com.hazelcast.ringbuffer
A Ringbuffer is a data structure where the content is stored in a ring-like structure.
RINGBUFFER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
RINGBUFFER_STORE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
RingbufferConfig - Class in com.hazelcast.config
Contains the configuration for the Ringbuffer.
RingbufferConfig() - Constructor for class com.hazelcast.config.RingbufferConfig
 
RingbufferConfig(String) - Constructor for class com.hazelcast.config.RingbufferConfig
Creates a RingbufferConfig with the provided name.
RingbufferConfig(RingbufferConfig) - Constructor for class com.hazelcast.config.RingbufferConfig
Clones a RingbufferConfig
RingbufferConfig(String, RingbufferConfig) - Constructor for class com.hazelcast.config.RingbufferConfig
Creates a new RingbufferConfig by cloning an existing config and overriding the name.
RingbufferMergeData - Class in com.hazelcast.spi.merge
A ringbuffer implementation holding data involved in split-brain healing.
RingbufferMergeData(int) - Constructor for class com.hazelcast.spi.merge.RingbufferMergeData
 
RingbufferMergeData(Ringbuffer<Object>) - Constructor for class com.hazelcast.spi.merge.RingbufferMergeData
 
RingbufferMergeDataReadOnlyIterator<E> - Class in com.hazelcast.spi.merge
Read-only iterator over items in a provided RingbufferMergeData.
RingBufferPermission - Class in com.hazelcast.security.permission
 
RingBufferPermission(String, String...) - Constructor for class com.hazelcast.security.permission.RingBufferPermission
 
RingbufferStore<T> - Interface in com.hazelcast.core
Ringbuffer store makes a ring buffer backed by a central data store; such as database, disk, etc.
RingbufferStoreConfig - Class in com.hazelcast.config
Configuration for the RingbufferStore.
RingbufferStoreConfig() - Constructor for class com.hazelcast.config.RingbufferStoreConfig
 
RingbufferStoreConfig(RingbufferStoreConfig) - Constructor for class com.hazelcast.config.RingbufferStoreConfig
 
RingbufferStoreFactory<T> - Interface in com.hazelcast.core
Creates a new RingbufferStore.
rollbackMigration(PartitionMigrationEvent) - Method in interface com.hazelcast.spi.MigrationAwareService
Rollback the migration process for this service, on both source and destination members.
rollbackTransaction(String) - Method in interface com.hazelcast.spi.TransactionalService
 
rollbackTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
Rollback of the current transaction.
run() - Method in class com.hazelcast.crdt.AbstractCRDTReplicationOperation
 
run() - Method in class com.hazelcast.spi.Operation
Runs the operation.
run(Operation) - Method in interface com.hazelcast.spi.OperationService
Runs an operation in the calling thread.
runningOperations() - Method in class com.hazelcast.spi.OperationControl
 
RuntimeInterruptedException - Exception in com.hazelcast.core
An unchecked version of InterruptedException.
RuntimeInterruptedException() - Constructor for exception com.hazelcast.core.RuntimeInterruptedException
 
RuntimeInterruptedException(String) - Constructor for exception com.hazelcast.core.RuntimeInterruptedException
 

S

save(Map<K, V>) - Method in interface com.hazelcast.scheduledexecutor.StatefulTask
Task callback to capture its state on the provided map.
schedule(Runnable, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay.
schedule(Callable<V>, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay.
schedule(Runnable, long, TimeUnit) - Method in interface com.hazelcast.spi.ExecutionService
 
schedule(String, Runnable, long, TimeUnit) - Method in interface com.hazelcast.spi.ExecutionService
 
schedule(Runnable, long, TimeUnit) - Method in interface com.hazelcast.spi.TaskScheduler
Creates and executes a one-shot action that becomes enabled after the given delay.
schedule(Callable<V>, long, TimeUnit) - Method in interface com.hazelcast.spi.TaskScheduler
Creates and executes a one-shot action that becomes enabled after the given delay.
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period.
SCHEDULED_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
Name of the scheduled executor.
SCHEDULED_EXECUTOR_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
ScheduledExecutorConfig - Class in com.hazelcast.config
Configuration options for the IScheduledExecutorService.
ScheduledExecutorConfig() - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
 
ScheduledExecutorConfig(String) - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
 
ScheduledExecutorConfig(String, int, int, int) - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
 
ScheduledExecutorConfig(String, int, int, int, String, MergePolicyConfig) - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
 
ScheduledExecutorConfig(ScheduledExecutorConfig) - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
 
ScheduledExecutorPermission - Class in com.hazelcast.security.permission
 
ScheduledExecutorPermission(String, String...) - Constructor for class com.hazelcast.security.permission.ScheduledExecutorPermission
 
ScheduledTaskHandler - Class in com.hazelcast.scheduledexecutor
Resource handler pointing to a IScheduledFuture.
ScheduledTaskHandler() - Constructor for class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
 
ScheduledTaskStatistics - Interface in com.hazelcast.scheduledexecutor
Statistics and timing info for a IScheduledFuture accessible through IScheduledFuture.getStats()
scheduleOnAllMembers(Runnable, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay on all cluster Members.
scheduleOnAllMembers(Callable<V>, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay on all cluster Members.
scheduleOnAllMembersAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period on all cluster Members.
scheduleOnKeyOwner(Runnable, Object, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay on the partition owner of the given key.
scheduleOnKeyOwner(Callable<V>, Object, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay on the partition owner of the given key.
scheduleOnKeyOwnerAtFixedRate(Runnable, Object, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period on the partition owner of the given key.
scheduleOnMember(Runnable, Member, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay at the given Member.
scheduleOnMember(Callable<V>, Member, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay at the given Member.
scheduleOnMemberAtFixedRate(Runnable, Member, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period at the given Member.
scheduleOnMembers(Runnable, Collection<Member>, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay on all Members given.
scheduleOnMembers(Callable<V>, Collection<Member>, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay on all Members given.
scheduleOnMembersAtFixedRate(Runnable, Collection<Member>, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period on all Members given.
scheduleWithRepetition(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.spi.ExecutionService
 
scheduleWithRepetition(String, Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.spi.ExecutionService
 
scheduleWithRepetition(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.spi.TaskScheduler
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period.
schemaValidation(Document) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
SCRIPTING_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
This property will be replaced by a field in ManagementCenterConfig in Hazelcast 3.12.
SEARCH_DYNAMIC_CONFIG_FIRST - Static variable in class com.hazelcast.spi.properties.GroupProperty
By default, search for data structures config is performed within static configuration first: Exact match in static config Wildcard match in static config Exact match in dynamic config Wildcard match in dynamic config Fallback to default But sometimes it makes sense to perform search within dynamic configs first.
searchForOtherClusters() - Method in interface com.hazelcast.cluster.Joiner
Deprecated.
 
secondary() - Method in class com.hazelcast.client.connection.Addresses
 
SecureCallable<V> - Interface in com.hazelcast.security
A secure callable that runs in a sandbox.
SecurityConfig - Class in com.hazelcast.config
Contains configuration for Security
SecurityConfig() - Constructor for class com.hazelcast.config.SecurityConfig
 
SecurityContext - Interface in com.hazelcast.security
SecurityContext is responsible for managing lifecycle of security object such as ICredentialsFactory, IPermissionPolicy etc, to creating LoginContextes for member and client authentications and checking permissions for client operations.
SecurityInterceptor - Interface in com.hazelcast.security
This interface allows to intercept requests which were produced by an API call like map.put, queue.offer...
SecurityInterceptorConfig - Class in com.hazelcast.config
This class is used to configure SecurityInterceptor
SecurityInterceptorConfig() - Constructor for class com.hazelcast.config.SecurityInterceptorConfig
 
SecurityInterceptorConfig(String) - Constructor for class com.hazelcast.config.SecurityInterceptorConfig
 
SecurityInterceptorConfig(SecurityInterceptor) - Constructor for class com.hazelcast.config.SecurityInterceptorConfig
 
SecurityService - Interface in com.hazelcast.security
Provides necessary methods to initiate security related config changes.
select(Member) - Method in interface com.hazelcast.core.MemberSelector
Decides if the given member will be part of an operation or not.
SEMAPHORE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
SemaphoreConfig - Class in com.hazelcast.config
Contains the configuration for an ISemaphore.
SemaphoreConfig() - Constructor for class com.hazelcast.config.SemaphoreConfig
Creates a default configured SemaphoreConfig.
SemaphoreConfig(SemaphoreConfig) - Constructor for class com.hazelcast.config.SemaphoreConfig
Creates a SemaphoreConfig by cloning another one.
SemaphoreConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
SemaphoreConfigReadOnly(SemaphoreConfig) - Constructor for class com.hazelcast.config.SemaphoreConfigReadOnly
Deprecated.
 
SemaphorePermission - Class in com.hazelcast.security.permission
 
SemaphorePermission(String, String...) - Constructor for class com.hazelcast.security.permission.SemaphorePermission
 
send(Operation, Address) - Method in interface com.hazelcast.spi.OperationService
Executes an operation remotely.
sendResponse(Object) - Method in class com.hazelcast.spi.Operation
 
sendResponse(O, Object) - Method in interface com.hazelcast.spi.OperationResponseHandler
Sends a response.
SEQUENCE_UNAVAILABLE - Static variable in interface com.hazelcast.ringbuffer.ReadResultSet
Value returned from methods returning a sequence number when the information is not available (e.g.
SerializableByConvention - Annotation Type in com.hazelcast.nio.serialization
Indicates that the annotated class cannot be converted to IdentifiedDataSerializable due to other conventions.
SerializableByConvention.Reason - Enum in com.hazelcast.nio.serialization
 
SERIALIZATION_VERSION - Static variable in class com.hazelcast.spi.properties.GroupProperty
Hazelcast serialization version.
SerializationClassNameFilter - Class in com.hazelcast.nio
Implementation of basic protection against untrusted deserialization.
SerializationClassNameFilter(JavaSerializationFilterConfig) - Constructor for class com.hazelcast.nio.SerializationClassNameFilter
 
SerializationConfig - Class in com.hazelcast.config
Contains the serialization configuration of HazelcastInstance.
SerializationConfig() - Constructor for class com.hazelcast.config.SerializationConfig
 
serializationService - Variable in class com.hazelcast.config.AbstractCacheConfig
 
serializationService - Variable in class com.hazelcast.spi.Offload
 
SerializationService - Interface in com.hazelcast.spi.serialization
SPI to serialize user objects to Data and back to Object Data is the internal representation of binary data in hazelcast.
SerializationServiceAware - Interface in com.hazelcast.spi.serialization
Used to get a SerializationService reference injected.
Serializer - Interface in com.hazelcast.nio.serialization
Base interface of custom serialization interfaces

see ByteArraySerializer see StreamSerializer

SerializerConfig - Class in com.hazelcast.config
Contains the serialization configuration for a particular class.
SerializerConfig() - Constructor for class com.hazelcast.config.SerializerConfig
 
SerializerHook<T> - Interface in com.hazelcast.nio.serialization
This interface is used to automatically register serializers from external Hazelcast or user modules.
Both types of Serializers are supported (StreamSerializer and ByteArraySerializer).
service - Variable in class com.hazelcast.spi.DefaultObjectNamespace
Deprecated.
 
SERVICE_NAME - Static variable in class com.hazelcast.crdt.CRDTReplicationMigrationService
The name of this service
SERVICE_NAME - Static variable in class com.hazelcast.crdt.pncounter.PNCounterService
The name under which this service is registered
SERVICE_NAME - Static variable in interface com.hazelcast.spi.partition.IPartitionService
The name of the service.
SERVICE_NAME - Static variable in interface com.hazelcast.wan.WanReplicationService
Service name.
ServiceConfig - Class in com.hazelcast.config
Configuration for a single service.
ServiceConfig() - Constructor for class com.hazelcast.config.ServiceConfig
 
ServiceConfigurationParser<T> - Interface in com.hazelcast.spi
A hook into the parsing system.
serviceName - Variable in class com.hazelcast.spi.InvocationBuilder
 
ServiceNamespace - Interface in com.hazelcast.spi
ServiceNamespace is a namespace to group objects, structures, fragments within a service.
ServiceNamespaceAware - Interface in com.hazelcast.spi
An object which is aware of ServiceNamespace which object itself belongs to.
ServiceNotFoundException - Exception in com.hazelcast.spi.exception
A HazelcastException that indicates that a requested service is not exist.
ServiceNotFoundException(String) - Constructor for exception com.hazelcast.spi.exception.ServiceNotFoundException
 
ServicesConfig - Class in com.hazelcast.config
Configuration for the Services.
ServicesConfig() - Constructor for class com.hazelcast.config.ServicesConfig
 
set(K, V) - Method in interface com.hazelcast.core.BaseMap
Associates the specified value with the specified key in this map.
set(long) - Method in interface com.hazelcast.core.IAtomicLong
Atomically sets the given value.
set(E) - Method in interface com.hazelcast.core.IAtomicReference
Atomically sets the given value.
set(K, V) - Method in interface com.hazelcast.core.IMap
Puts an entry into this map without returning the old value (which is more efficient than put()).
set(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Puts an entry into this map with a given TTL (time to live) value, without returning the old value (which is more efficient than put()).
set(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Puts an entry into this map with a given TTL (time to live) value and max idle time value.
set(K, V) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.set(Object, Object).
set(long, Object) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Sets the item at the given sequence.
SET_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
setAccessKey(String) - Method in class com.hazelcast.config.AwsConfig
setAcknowledgeType(WanAcknowledgeType) - Method in class com.hazelcast.wan.WanReplicationEvent
 
setActions(Set<String>) - Method in class com.hazelcast.config.PermissionConfig
 
setAddresses(List<String>) - Method in class com.hazelcast.client.config.ClientConfig
Deprecated.
setAddresses(List<String>) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Sets given addresses as candidate address list that client will use to establish initial connection
setAlgorithm(String) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
setAliasedDiscoveryConfigs(List<DiscoveryStrategyConfig>) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
setAllocatorType(NativeMemoryConfig.MemoryAllocatorType) - Method in class com.hazelcast.config.NativeMemoryConfig
Sets the NativeMemoryConfig.MemoryAllocatorType to be used while allocating native memory.
setAllowUnsafe(boolean) - Method in class com.hazelcast.config.SerializationConfig
Unsafe, it is not public api of java.
setAnchor(PagingPredicate, int, Map.Entry) - Static method in class com.hazelcast.query.PagingPredicateAccessor
 
setAndGet(E) - Method in interface com.hazelcast.core.IAtomicReference
Deprecated.
will be removed from Hazelcast 3.4 since it doesn't really serve a purpose
setApplicationContext(ApplicationContext) - Method in class com.hazelcast.spring.context.SpringManagedContext
 
setAsync(long) - Method in interface com.hazelcast.core.IAtomicLong
Atomically sets the given value.
setAsync(E) - Method in interface com.hazelcast.core.IAtomicReference
Atomically sets the given value.
setAsync(K, V) - Method in interface com.hazelcast.core.IMap
Asynchronously puts the given key and value.
setAsync(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Asynchronously puts an entry into this map with a given TTL (time to live) value, without returning the old value (which is more efficient than put()).
setAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Asynchronously puts an entry into this map with a given TTL (time to live) value and max idle time value.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.CacheConfig
Sets the number of asynchronous backups for this ICache.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setAsyncBackupCount(int) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the number of asynchronous backups for this ICache.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setAsyncBackupCount(int) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Sets the number of synchronous backups.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.CollectionConfig
Sets the number of asynchronous backups.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.ListConfigReadOnly
Deprecated.
 
setAsyncBackupCount(int) - Method in class com.hazelcast.config.MapConfig
Sets the number of asynchronous backups.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setAsyncBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfig
Sets the number of asynchronous backups.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
setAsyncBackupCount(int) - Method in class com.hazelcast.config.QueueConfig
Sets the number of asynchronous backups.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.QueueConfigReadOnly
Deprecated.
 
setAsyncBackupCount(int) - Method in class com.hazelcast.config.RingbufferConfig
Sets the number of asynchronous backups.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.SemaphoreConfig
Sets the number of asynchronous backups.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.SemaphoreConfigReadOnly
Deprecated.
 
setAsyncBackupCount(int) - Method in class com.hazelcast.config.SetConfigReadOnly
Deprecated.
 
setAsyncFillup(boolean) - Method in class com.hazelcast.config.ReplicatedMapConfig
True if the replicated map is available for reads before the initial replication is completed, false otherwise.
setAsyncStart(boolean) - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
Set true for non blocking HazelcastClient.newHazelcastClient().
setAtomicLongConfigs(Map<String, AtomicLongConfig>) - Method in class com.hazelcast.config.Config
Sets the map of AtomicLong configurations, mapped by config name.
setAtomicReferenceConfigs(Map<String, AtomicReferenceConfig>) - Method in class com.hazelcast.config.Config
Sets the map of AtomicReference configurations, mapped by config name.
setAttribute(String) - Method in class com.hazelcast.config.MapIndexConfig
Sets the attribute that is going to be indexed.
setAttribute(String) - Method in class com.hazelcast.config.MapIndexConfigReadOnly
Deprecated.
 
setAttribute(String) - Method in class com.hazelcast.query.PredicateBuilder
 
setAttributes(Map<String, Object>) - Method in class com.hazelcast.config.MemberAttributeConfig
 
setAttributes(Map<String, Object>) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
Deprecated.
 
setAwsConfig(ClientAwsConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Sets configuration to connect nodes in AWS environment.
setAwsConfig(AwsConfig) - Method in class com.hazelcast.config.JoinConfig
 
setAwsConfig(AwsConfig) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the AwsConfig used by the discovery mechanism for this WAN publisher.
setAzureConfig(AzureConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Sets configuration to connect nodes in Azure environment.
setAzureConfig(AzureConfig) - Method in class com.hazelcast.config.JoinConfig
 
setAzureConfig(AzureConfig) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the AzureConfig used by the discovery mechanism for this WAN publisher.
setBackupCount(int) - Method in class com.hazelcast.config.CacheConfig
Sets the number of synchronous backups.
setBackupCount(int) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setBackupCount(int) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the number of synchronous backups for this ICache.
setBackupCount(int) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setBackupCount(int) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Sets the number of synchronous backups.
setBackupCount(int) - Method in class com.hazelcast.config.CollectionConfig
Sets the number of synchronous backups for this collection.
setBackupCount(int) - Method in class com.hazelcast.config.ListConfigReadOnly
Deprecated.
 
setBackupCount(int) - Method in class com.hazelcast.config.MapConfig
Number of synchronous backups.
setBackupCount(int) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfig
Sets the number of synchronous backups.
setBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
setBackupCount(int) - Method in class com.hazelcast.config.QueueConfig
Sets the number of synchronous backups for this queue.
setBackupCount(int) - Method in class com.hazelcast.config.QueueConfigReadOnly
Deprecated.
 
setBackupCount(int) - Method in class com.hazelcast.config.RingbufferConfig
Sets the number of synchronous backups.
setBackupCount(int) - Method in class com.hazelcast.config.SemaphoreConfig
Sets the number of synchronous backups.
setBackupCount(int) - Method in class com.hazelcast.config.SemaphoreConfigReadOnly
Deprecated.
 
setBackupCount(int) - Method in class com.hazelcast.config.SetConfigReadOnly
Deprecated.
 
setBackupDir(File) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets base directory for all Hot Restart stores.
setBaseDir(File) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets base directory for all Hot Restart stores.
setBatchSize(int) - Method in class com.hazelcast.config.MergePolicyConfig
Sets the batch size, which will be used to determine the number of entries to be sent in a merge operation.
setBatchSize(int) - Method in class com.hazelcast.config.QueryCacheConfig
Sets the batch size which will be used to determine number of events to be sent in a batch to QueryCache
setBinary(boolean) - Method in class com.hazelcast.config.MultiMapConfig
Enables or disables binary (serialized) form for this MultiMap.
setBinary(boolean) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
setBit(byte, int) - Static method in class com.hazelcast.nio.Bits
Sets n-th bit of the byte value
setBit(int, int) - Static method in class com.hazelcast.nio.Bits
Sets n-th bit of the integer value
setBlacklist(ClassFilter) - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
setBlacklistedPrefixes(String) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Comma separated list of prefixes of classes which will never be loaded remotely.
setBooleanAttribute(String, boolean) - Method in class com.hazelcast.config.MemberAttributeConfig
 
setBooleanAttribute(String, boolean) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
Deprecated.
 
setBooleanAttribute(String, boolean) - Method in interface com.hazelcast.core.Member
Defines a key-value pair boolean attribute for this member that is available to other cluster members.
setBufferSize(int) - Method in class com.hazelcast.client.config.SocketOptions
Sets the SO_SNDBUF and SO_RCVBUF options to the specified value in KB
setBufferSize(int) - Method in class com.hazelcast.config.QueryCacheConfig
Sets the maximum number of events which can be stored in a buffer of partition.
setByteAttribute(String, byte) - Method in class com.hazelcast.config.MemberAttributeConfig
 
setByteAttribute(String, byte) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
Deprecated.
 
setByteAttribute(String, byte) - Method in interface com.hazelcast.core.Member
Defines a key-value pair byte attribute for this member available to other cluster members.
setByteOrder(ByteOrder) - Method in class com.hazelcast.config.SerializationConfig
Note that configuring use native byte order as enabled will override the byte order set by this method.
setCacheConfigs(Map<String, CacheSimpleConfig>) - Method in class com.hazelcast.config.Config
Sets the map of cache configurations, mapped by config name.
setCacheDeserializedValues(CacheDeserializedValues) - Method in class com.hazelcast.config.MapConfig
Configure de-serialized value caching.
setCacheDeserializedValues(CacheDeserializedValues) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setCacheEntryEventFilterFactory(String) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
setCacheEntryEventFilterFactory(String) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfigReadOnly
Deprecated.
 
setCacheEntryListenerFactory(String) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
setCacheEntryListenerFactory(String) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfigReadOnly
Deprecated.
 
setCacheEntryListeners(List<CacheSimpleEntryListenerConfig>) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets a list of CacheSimpleEntryListenerConfig for this ICache.
setCacheEntryListeners(List<CacheSimpleEntryListenerConfig>) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setCacheEventJournalConfigs(Map<String, EventJournalConfig>) - Method in class com.hazelcast.config.Config
Sets the map of cache event journal configurations, mapped by config name.
setCacheLoader(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Set classname of a class to be used as CacheLoader.
setCacheLoaderFactory(Factory<? extends CacheLoader<K, V>>) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setCacheLoaderFactory(Factory<? extends CacheLoader<K, V>>) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setCacheLoaderFactory(Factory<? extends CacheLoader<K, V>>) - Method in interface com.hazelcast.config.CacheConfiguration
Set the CacheLoader factory.
setCacheLoaderFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the factory for this CacheLoader.
setCacheLoaderFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setCacheLocalEntries(boolean) - Method in class com.hazelcast.config.NearCacheConfig
Sets if local entries are also cached in the Near Cache.
setCacheLocalEntries(boolean) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
setCacheName(String) - Method in class com.hazelcast.config.EventJournalConfig
Sets the cache name to which this config applies.
setCacheOptions(String) - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
Set the cache ead-timeout params
setCacheWriter(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Set classname of a class to be used as CacheWriter.
setCacheWriterFactory(Factory<? extends CacheWriter<? super K, ? super V>>) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setCacheWriterFactory(Factory<? extends CacheWriter<? super K, ? super V>>) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setCacheWriterFactory(Factory<? extends CacheWriter<? super K, ? super V>>) - Method in interface com.hazelcast.config.CacheConfiguration
Set the CacheWriter factory.
setCacheWriterFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the factory for this CacheWriter.
setCacheWriterFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setCallerAddress(Operation, Address) - Static method in class com.hazelcast.spi.OperationAccessor
 
setCallerUuid(String) - Method in class com.hazelcast.spi.Operation
 
setCallId(Operation, long) - Static method in class com.hazelcast.spi.OperationAccessor
Assigns the supplied call ID to the supplied operation, thereby activating it.
setCallTimeout(long) - Method in class com.hazelcast.spi.InvocationBuilder
 
setCallTimeout(Operation, long) - Static method in class com.hazelcast.spi.OperationAccessor
Sets the call timeout in milliseconds for the Operation.
setCapacity(int) - Method in class com.hazelcast.config.DurableExecutorConfig
Sets the ring buffer capacity of the executor task.
setCapacity(int) - Method in class com.hazelcast.config.EventJournalConfig
Sets the capacity of the event journal.
setCapacity(int) - Method in class com.hazelcast.config.RingbufferConfig
Sets the capacity of the ringbuffer.
setCapacity(int) - Method in class com.hazelcast.config.ScheduledExecutorConfig
Sets the capacity of the executor The capacity represents the maximum number of tasks that a scheduler can have at any given point in time per partition.
setCardinalityEstimatorConfigs(Map<String, CardinalityEstimatorConfig>) - Method in class com.hazelcast.config.Config
Sets the map of cardinality estimator configurations, mapped by config name.
setCheckClassDefErrors(boolean) - Method in class com.hazelcast.config.SerializationConfig
When enabled, serialization system will check for class definitions error at start and throw an Serialization Exception with error definition.
setChunkSize(int) - Method in class com.hazelcast.config.JobTrackerConfig
Sets the number of emitted values before a chunk is send to the reducers.
setChunkSize(int) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
Deprecated.
 
setClass(Class<? extends Serializer>) - Method in class com.hazelcast.config.SerializerConfig
Sets the class of the serializer implementation.
setClassCacheMode(UserCodeDeploymentConfig.ClassCacheMode) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Configure caching of classes loaded from remote members.
setClassDefinitions(Set<ClassDefinition>) - Method in class com.hazelcast.config.SerializationConfig
 
setClasses(Collection<String>) - Method in class com.hazelcast.config.ClassFilter
 
setClassLoader(ClassLoader) - Method in class com.hazelcast.client.config.ClientConfig
Sets the classLoader which is used by serialization and listener configuration
setClassLoader(ClassLoader) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setClassLoader(ClassLoader) - Method in class com.hazelcast.config.Config
Sets the class-loader to be used during de-serialization and as context class-loader of Hazelcast internal threads.
setClassName(String) - Method in class com.hazelcast.client.config.ProxyFactoryConfig
Sets class name of proxy factory
setClassName(String) - Method in class com.hazelcast.config.CachePartitionLostListenerConfigReadOnly
Deprecated.
 
setClassName(String) - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
setClassName(String) - Method in class com.hazelcast.config.EntryListenerConfigReadOnly
Deprecated.
 
setClassName(String) - Method in class com.hazelcast.config.GlobalSerializerConfig
 
setClassName(String) - Method in class com.hazelcast.config.ItemListenerConfigReadOnly
Deprecated.
 
setClassName(String) - Method in class com.hazelcast.config.ListenerConfig
Sets the class name of the EventListener.
setClassName(String) - Method in class com.hazelcast.config.ListenerConfigReadOnly
Deprecated.
 
setClassName(String) - Method in class com.hazelcast.config.LoginModuleConfig
 
setClassName(String) - Method in class com.hazelcast.config.MapPartitionLostListenerConfigReadOnly
Deprecated.
 
setClassName(String) - Method in class com.hazelcast.config.MapStoreConfig
Sets the name for the MapStore implementation class
setClassName(String) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
Deprecated.
 
setClassName(String) - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
setClassName(String) - Method in class com.hazelcast.config.PermissionPolicyConfig
 
setClassName(String) - Method in class com.hazelcast.config.PredicateConfig
Sets the class name of the Predicate.
setClassName(String) - Method in class com.hazelcast.config.QueueStoreConfig
 
setClassName(String) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
Deprecated.
 
setClassName(String) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
setClassName(String) - Method in class com.hazelcast.config.SecurityInterceptorConfig
 
setClassName(String) - Method in class com.hazelcast.config.SerializerConfig
Sets the class name of the serializer implementation.
setClassName(String) - Method in class com.hazelcast.config.ServiceConfig
 
setClassName(String) - Method in class com.hazelcast.config.SocketInterceptorConfig
Sets the name for the SocketInterceptor implementation class.
setClassName(String) - Method in class com.hazelcast.config.WanConsumerConfig
Sets the fully qualified class name of the class implementing WanReplicationConsumer.
setClassName(String) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the name of the class implementing the WanReplicationEndpoint.
setClassNames(List<String>) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
setClientBlockUnmappedActions(boolean) - Method in class com.hazelcast.config.SecurityConfig
Block or allow actions, submitted as tasks in an Executor from clients and have no permission mappings.
setClientIcmpPingConfig(ClientIcmpPingConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
ICMP ping is used to detect if machine that a remote hazelcast member runs on alive or not
setClientLoginModuleConfigs(List<LoginModuleConfig>) - Method in class com.hazelcast.config.SecurityConfig
 
setClientPermissionConfigs(Set<PermissionConfig>) - Method in class com.hazelcast.config.SecurityConfig
 
setClientPolicyConfig(PermissionPolicyConfig) - Method in class com.hazelcast.config.SecurityConfig
 
setCloudConfig(ClientCloudConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
setClusterDataRecoveryPolicy(HotRestartClusterDataRecoveryPolicy) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets the policy to be used when the cluster is started
setCoalesce(boolean) - Method in class com.hazelcast.config.QueryCacheConfig
Set true to enable coalescing, otherwise set false.
setCommunicateStats(boolean) - Method in class com.hazelcast.config.JobTrackerConfig
Set to true if statistics (for example, about processed entries) should be transmitted to the job emitter, false otherwise.
setCommunicateStats(boolean) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
Deprecated.
 
setComparator(EvictionPolicyComparator) - Method in class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
setComparator(EvictionPolicyComparator) - Method in class com.hazelcast.config.CacheEvictionConfigReadOnly
Deprecated.
 
setComparator(EvictionPolicyComparator) - Method in class com.hazelcast.config.EvictionConfig
Sets the instance of the configured EvictionPolicyComparator implementation.
setComparator(EvictionPolicyComparator) - Method in class com.hazelcast.config.EvictionConfigReadOnly
Deprecated.
 
setComparatorClassName(String) - Method in class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
setComparatorClassName(String) - Method in class com.hazelcast.config.CacheEvictionConfigReadOnly
Deprecated.
 
setComparatorClassName(String) - Method in class com.hazelcast.config.EvictionConfig
Sets the class name of the configured EvictionPolicyComparator implementation.
setComparatorClassName(String) - Method in class com.hazelcast.config.EvictionConfigReadOnly
Deprecated.
 
setConcurrencyLevel(int) - Method in class com.hazelcast.config.ReplicatedMapConfig
Deprecated.
new implementation doesn't use mutexes
SetConfig - Class in com.hazelcast.config
Contains the configuration for an ISet.
SetConfig() - Constructor for class com.hazelcast.config.SetConfig
 
SetConfig(String) - Constructor for class com.hazelcast.config.SetConfig
 
SetConfig(SetConfig) - Constructor for class com.hazelcast.config.SetConfig
 
setConfigClassLoader(ClassLoader) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
setConfigObject(Object) - Method in class com.hazelcast.config.ServiceConfig
 
setConfigPatternMatcher(ConfigPatternMatcher) - Method in class com.hazelcast.client.config.ClientConfig
Sets the pattern matcher which is used to match item names to configuration objects.
setConfigPatternMatcher(ConfigPatternMatcher) - Method in class com.hazelcast.config.Config
Sets the pattern matcher which is used to match item names to configuration objects.
SetConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
SetConfigReadOnly(SetConfig) - Constructor for class com.hazelcast.config.SetConfigReadOnly
Deprecated.
 
setConfigurationFile(File) - Method in class com.hazelcast.config.Config
Sets the File from which this configuration has been retrieved and created.
setConfigurationUrl(URL) - Method in class com.hazelcast.config.Config
Sets the URL from which this configuration has been retrieved and created.
setConn(Connection) - Method in class com.hazelcast.nio.Packet
Sets the Connection this Packet is send with.
setConnection(Operation, Connection) - Static method in class com.hazelcast.spi.OperationAccessor
 
setConnectionAttemptLimit(int) - Method in class com.hazelcast.client.config.ClientConfig
Deprecated.
setConnectionAttemptLimit(int) - Method in class com.hazelcast.client.config.ClientNetworkConfig
While client is trying to connect initially to one of the members in the ClientNetworkConfig.addressList, all might be not available.
setConnectionAttemptPeriod(int) - Method in class com.hazelcast.client.config.ClientConfig
Deprecated.
setConnectionAttemptPeriod(int) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Period for the next attempt to find a member to connect.
setConnectionRetryConfig(ConnectionRetryConfig) - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
Connection Retry Config is controls the period among the retries and when should a client gave up retrying.
setConnectionStrategyConfig(ClientConnectionStrategyConfig) - Method in class com.hazelcast.client.config.ClientConfig
 
setConnectionTimeout(int) - Method in class com.hazelcast.client.config.ClientConfig
Deprecated.
setConnectionTimeout(int) - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
setConnectionTimeoutSeconds(int) - Method in class com.hazelcast.config.AwsConfig
setConnectionTimeoutSeconds(int) - Method in class com.hazelcast.config.TcpIpConfig
Sets the connection timeout.
setConsistencyCheckStrategy(ConsistencyCheckStrategy) - Method in class com.hazelcast.config.WanSyncConfig
Sets the strategy for checking consistency of data between source and target cluster.
setContext(ClientContext) - Method in class com.hazelcast.client.spi.ClientProxy
 
setCountDownLatchConfigs(Map<String, CountDownLatchConfig>) - Method in class com.hazelcast.config.Config
Sets the map of CountDownLatch configurations, mapped by config name.
setCRDTReplicationConfig(CRDTReplicationConfig) - Method in class com.hazelcast.config.Config
Sets the replication configuration for CRDT implementations.
setCredentials(Credentials) - Method in class com.hazelcast.client.config.ClientConfig
setCredentials(Credentials) - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
setCredentialsClassname(String) - Method in class com.hazelcast.client.config.ClientSecurityConfig
Credentials class will be instantiated from class name when setCredentialsFactoryConfig and setCredentials are not used.
setCredentialsFactoryConfig(CredentialsFactoryConfig) - Method in class com.hazelcast.client.config.ClientSecurityConfig
Credentials Factory Config allows user to pass custom properties and use group config when instantiating a credentials object.
setDataLoadTimeoutSeconds(int) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets data load timeout for hot-restart process, all members in the cluster should complete restoring their local data before this timeout.
setDataSerializableFactories(Map<Integer, DataSerializableFactory>) - Method in class com.hazelcast.config.SerializationConfig
 
setDataSerializableFactoryClasses(Map<Integer, String>) - Method in class com.hazelcast.config.SerializationConfig
 
setDefaultReadTimeout(long) - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
Set default cache value retrieval timeout.
setDefaultsDisabled(boolean) - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
setDelaySeconds(int) - Method in class com.hazelcast.config.QueryCacheConfig
Sets the minimum number of delay seconds which an event waits in the buffer of node before sending to a QueryCache
setDeprecatedName(String) - Method in class com.hazelcast.spi.properties.HazelcastProperty
Sets the deprecated name of ths property.
setDepth(int) - Method in class com.hazelcast.config.MerkleTreeConfig
Sets the depth of the merkle tree.
setDirectory(String) - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
setDisablePerEntryInvalidationEvents(boolean) - Method in class com.hazelcast.config.CacheConfig
Sets invalidation events disabled status for per entry.
setDisablePerEntryInvalidationEvents(boolean) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setDisablePerEntryInvalidationEvents(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets invalidation events disabled status for per entry.
setDisablePerEntryInvalidationEvents(boolean) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setDiscoveryConfig(DiscoveryConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Defines the Discovery Provider SPI configuration
setDiscoveryConfig(DiscoveryConfig) - Method in class com.hazelcast.config.JoinConfig
Sets a custom defined DiscoveryConfig
setDiscoveryConfig(DiscoveryConfig) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the DiscoveryConfig used by the discovery mechanism for this WAN publisher.
setDiscoveryConfig(DiscoveryConfig) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
setDiscoveryMode(DiscoveryMode) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
setDiscoveryNode(DiscoveryNode) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
setDiscoveryServiceProvider(DiscoveryServiceProvider) - Method in class com.hazelcast.config.DiscoveryConfig
 
setDiscoveryServiceProvider(DiscoveryServiceProvider) - Method in class com.hazelcast.config.DiscoveryConfigReadOnly
Deprecated.
 
setDiscoveryStrategyConfigs(List<DiscoveryStrategyConfig>) - Method in class com.hazelcast.config.DiscoveryConfig
 
setDiscoveryStrategyConfigs(List<DiscoveryStrategyConfig>) - Method in class com.hazelcast.config.DiscoveryConfigReadOnly
Deprecated.
 
setDiscoveryToken(String) - Method in class com.hazelcast.client.config.ClientCloudConfig
 
setDoneCallback(Runnable) - Method in class com.hazelcast.spi.InvocationBuilder
Sets a callback that will respond to the "task done" event for the invocation this builder is about to create.
setDoubleAttribute(String, double) - Method in class com.hazelcast.config.MemberAttributeConfig
 
setDoubleAttribute(String, double) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
Deprecated.
 
setDoubleAttribute(String, double) - Method in interface com.hazelcast.core.Member
Defines a key-value pair double attribute for this member available to other cluster members.
setDurability(int) - Method in class com.hazelcast.config.DurableExecutorConfig
Sets the durability of the executor
setDurability(int) - Method in class com.hazelcast.config.ScheduledExecutorConfig
Sets the durability of the executor The durability represents the number of replicas that exist in a cluster for any given partition-owned task.
setDurability(int) - Method in class com.hazelcast.transaction.TransactionOptions
Sets the transaction durability.
setDurableExecutorConfigs(Map<String, DurableExecutorConfig>) - Method in class com.hazelcast.config.Config
Sets the map of durable executor configurations, mapped by config name.
setEchoFailFastOnStartup(boolean) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
setEmptyQueueTtl(int) - Method in class com.hazelcast.config.QueueConfig
Sets the TTL (time to live) for emptying the Queue.
setEmptyQueueTtl(int) - Method in class com.hazelcast.config.QueueConfigReadOnly
Deprecated.
 
setEnableCompression(boolean) - Method in class com.hazelcast.config.SerializationConfig
Enables compression when default java serialization is used.
setEnabled(boolean) - Method in class com.hazelcast.client.config.ClientCloudConfig
 
setEnabled(boolean) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
setEnabled(boolean) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
setEnabled(boolean) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
enables connection retry logic.
setEnabled(boolean) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
Enables or disables the join mechanism based on the given discovery config.
setEnabled(boolean) - Method in class com.hazelcast.config.AwsConfig
Enables or disables the AWS join mechanism.
setEnabled(boolean) - Method in class com.hazelcast.config.EventJournalConfig
Enables or disables the event journal.
setEnabled(boolean) - Method in class com.hazelcast.config.HotRestartConfig
Sets whether hot restart is enabled on related data structure.
setEnabled(boolean) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets whether hot restart is enabled on this member.
setEnabled(boolean) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
Set whether the ICMP failure detector should be enabled or not.
setEnabled(boolean) - Method in class com.hazelcast.config.InterfacesConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.ManagementCenterConfig
Set to true to enable management center, false to disable.
setEnabled(boolean) - Method in class com.hazelcast.config.MapStoreConfig
Enables and disables this configuration
setEnabled(boolean) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
Deprecated.
 
setEnabled(boolean) - Method in class com.hazelcast.config.MCMutualAuthConfig
Enables and disables this configuration.
setEnabled(boolean) - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.MerkleTreeConfig
Enables or disables the merkle tree.
setEnabled(boolean) - Method in class com.hazelcast.config.MulticastConfig
Enables or disables the multicast discovery mechanism
setEnabled(boolean) - Method in class com.hazelcast.config.NativeMemoryConfig
Enables or disables native memory allocation.
setEnabled(boolean) - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.PartitionGroupConfig
Enables or disables this PartitionGroupConfig.
setEnabled(boolean) - Method in class com.hazelcast.config.QueueStoreConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
Deprecated.
 
setEnabled(boolean) - Method in class com.hazelcast.config.QuorumConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.SecurityConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.ServiceConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.SocketInterceptorConfig
Enables and disables this configuration.
setEnabled(boolean) - Method in class com.hazelcast.config.SSLConfig
Enables and disables this configuration.
setEnabled(boolean) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.TcpIpConfig
Enables or disables the Tcp/Ip join mechanism.
setEnabled(boolean) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Enable or disable User Code Deployment.
setEnableDefaults(boolean) - Method in class com.hazelcast.config.ServicesConfig
 
setEnableSharedObject(boolean) - Method in class com.hazelcast.config.SerializationConfig
Enables shared object when default java serialization is used.
setEndpoint(String) - Method in class com.hazelcast.security.AbstractCredentials
 
setEndpoint(String) - Method in interface com.hazelcast.security.Credentials
Sets IP address of endpoint.
setEndpoints(Set<String>) - Method in class com.hazelcast.config.PermissionConfig
 
setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.config.MapConfig
 
setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.config.MultiMapConfig
Sets the list of entry listeners (listens for when entries are added or removed) for this MultiMap.
setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.config.QueryCacheConfig
 
setEurekaConfig(EurekaConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Sets configuration to connect nodes in Eureka environment.
setEurekaConfig(EurekaConfig) - Method in class com.hazelcast.config.JoinConfig
 
setEurekaConfig(EurekaConfig) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the EurekaConfig used by the discovery mechanism for this WAN publisher.
setEventObject(ReplicationEventObject) - Method in class com.hazelcast.wan.WanReplicationEvent
Sets the event object.
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.CacheConfig
Sets the EvictionConfig instance for eviction configuration for this ICache.
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the eviction configuration for this ICache.
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.NearCacheConfig
Sets the eviction configuration for this Near Cache.
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.QueryCacheConfig
Sets the EvictionConfig instance for this QueryCache
setEvictionPercentage(int) - Method in class com.hazelcast.config.MapConfig
Deprecated.
As of version 3.7, eviction mechanism changed. It uses a probabilistic algorithm based on sampling. Please see documentation for further details
setEvictionPercentage(int) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.CacheEvictionConfigReadOnly
Deprecated.
 
setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.EvictionConfig
Sets the EvictionPolicy of this eviction configuration.
setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.EvictionConfigReadOnly
Deprecated.
 
setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.MapConfig
Sets the EvictionPolicy.
setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setEvictionPolicy(String) - Method in class com.hazelcast.config.NearCacheConfig
setEvictionPolicy(String) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
setExecutionCallback(ExecutionCallback<Object>) - Method in class com.hazelcast.spi.InvocationBuilder
Sets the ExecutionCallback.
setExecutor(Executor) - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
Sets the Executor that is going to process the event.
setExecutor(Executor) - Method in class com.hazelcast.config.ReliableTopicConfig
Sets the Executor that is going to process the event.
setExecutorConfigs(Map<String, ExecutorConfig>) - Method in class com.hazelcast.config.Config
Sets the map of executor configurations, mapped by config name.
setExecutorPoolSize(int) - Method in class com.hazelcast.client.config.ClientConfig
Sets Client side Executor pool size.
setExpiryPolicy(K, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Associates the specified key with the given ExpiryPolicy.
setExpiryPolicy(Set<? extends K>, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Associates the specified key with the given ExpiryPolicy.
setExpiryPolicyFactory(Factory<? extends ExpiryPolicy>) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setExpiryPolicyFactory(Factory<? extends ExpiryPolicy>) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setExpiryPolicyFactory(Factory<? extends ExpiryPolicy>) - Method in interface com.hazelcast.config.CacheConfiguration
Set the Factory for the ExpiryPolicy.
setExpiryPolicyFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the factory for this ExpiryPolicy.
setExpiryPolicyFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setExpiryPolicyFactoryConfig(CacheSimpleConfig.ExpiryPolicyFactoryConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the factory configuration for this ExpiryPolicy.
setExpiryPolicyFactoryConfig(CacheSimpleConfig.ExpiryPolicyFactoryConfig) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setExtractor(String) - Method in class com.hazelcast.config.MapAttributeConfig
Sets the full class name of the extractor in a String format, e.g.
setExtractor(String) - Method in class com.hazelcast.config.MapAttributeConfigReadOnly
Deprecated.
 
setFactoryClassName(String) - Method in class com.hazelcast.config.MapStoreConfig
Sets the name for the MapStoreFactory implementation class
setFactoryClassName(String) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
Deprecated.
 
setFactoryClassName(String) - Method in class com.hazelcast.config.MCMutualAuthConfig
Sets the name for the implementation class.
setFactoryClassName(String) - Method in class com.hazelcast.config.QueueStoreConfig
 
setFactoryClassName(String) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
Deprecated.
 
setFactoryClassName(String) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
setFactoryClassName(String) - Method in class com.hazelcast.config.SSLConfig
Sets the name for the implementation class.
setFactoryImpl(ClientProxyFactory) - Method in class com.hazelcast.client.config.ProxyFactoryConfig
Sets factory implementation of proxy factory
setFactoryImplementation(Object) - Method in class com.hazelcast.config.MapStoreConfig
Sets the map store factory implementation object.
setFactoryImplementation(Object) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
Deprecated.
 
setFactoryImplementation(Object) - Method in class com.hazelcast.config.MCMutualAuthConfig
Sets the implementation object.
setFactoryImplementation(QueueStoreFactory) - Method in class com.hazelcast.config.QueueStoreConfig
 
setFactoryImplementation(QueueStoreFactory) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
Deprecated.
 
setFactoryImplementation(RingbufferStoreFactory) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
setFactoryImplementation(Object) - Method in class com.hazelcast.config.SSLConfig
Sets the implementation object.
setFailFastOnStartup(boolean) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
Sets whether the member should fail-fast on startup if ICMP is not allowed by the underlying OS.
setFailOnIndeterminateOperationState(boolean) - Method in class com.hazelcast.spi.InvocationBuilder
Enables / disables throwing IndeterminateOperationStateException for this invocation.
setFailOnMaxBackoff(boolean) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
 
setFilters(List<String>) - Method in class com.hazelcast.config.WanReplicationRef
Sets the list of class names implementing the CacheWanEventFilter or MapWanEventFilter for filtering outbound WAN replication events.
setFilters(List<String>) - Method in class com.hazelcast.config.WanReplicationRefReadOnly
Deprecated.
 
setFlakeIdGeneratorConfigMap(Map<String, ClientFlakeIdGeneratorConfig>) - Method in class com.hazelcast.client.config.ClientConfig
Sets the map of FlakeIdGenerator configurations, mapped by config name.
setFlakeIdGeneratorConfigs(Map<String, FlakeIdGeneratorConfig>) - Method in class com.hazelcast.config.Config
Sets the map of FlakeIdGenerator configurations, mapped by config name.
setFloatAttribute(String, float) - Method in class com.hazelcast.config.MemberAttributeConfig
 
setFloatAttribute(String, float) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
Deprecated.
 
setFloatAttribute(String, float) - Method in interface com.hazelcast.core.Member
Defines a key-value pair float attribute for this member available to other cluster members.
setFsync(boolean) - Method in class com.hazelcast.config.HotRestartConfig
Sets whether disk write should be followed by an fsync() system call.
setGcpConfig(GcpConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Sets configuration to connect nodes in GCP environment.
setGcpConfig(GcpConfig) - Method in class com.hazelcast.config.JoinConfig
 
setGcpConfig(GcpConfig) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the GcpConfig used by the discovery mechanism for this WAN publisher.
setGlobalOrderingEnabled(boolean) - Method in class com.hazelcast.config.TopicConfig
Enable global ordering (all nodes listening to the same topic get their messages in the same order), or disable it (nodes get the messages in the order that the messages are published).
setGlobalOrderingEnabled(boolean) - Method in class com.hazelcast.config.TopicConfigReadOnly
Deprecated.
 
setGlobalSerializerConfig(GlobalSerializerConfig) - Method in class com.hazelcast.config.SerializationConfig
 
setGroupConfig(GroupConfig) - Method in class com.hazelcast.client.config.ClientConfig
setGroupConfig(GroupConfig) - Method in class com.hazelcast.config.Config
Sets the configuration for hazelcast groups.
setGroupName(String) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the group name used as an endpoint group name for authentication on the target endpoint.
setGroupType(PartitionGroupConfig.MemberGroupType) - Method in class com.hazelcast.config.PartitionGroupConfig
Sets the MemberGroupType.
setHazelcast(HazelcastInstance) - Method in class com.hazelcast.console.ConsoleApp
 
setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.console.Echo
 
setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.console.SimulateLoadTask
 
setHazelcastInstance(HazelcastInstance) - Method in interface com.hazelcast.core.HazelcastInstanceAware
Gets the HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService.
setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
 
setHeadSequence(long) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Sets the head sequence.
setHostHeader(String) - Method in class com.hazelcast.config.AwsConfig
setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.AbstractCacheConfig
Sets the HotRestartConfig for this CacheConfiguration
setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the HotRestartConfig for this CacheSimpleConfig
setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.MapConfig
Sets the HotRestartConfig for this MapConfig
setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setHotRestartPersistenceConfig(HotRestartPersistenceConfig) - Method in class com.hazelcast.config.Config
Sets the Hot Restart configuration.
setIamRole(String) - Method in class com.hazelcast.config.AwsConfig
setIcmpFailureDetectorConfig(IcmpFailureDetectorConfig) - Method in class com.hazelcast.config.NetworkConfig
setIdOffset(long) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Sets the offset that will be added to the returned IDs.
setIdOffset(long) - Method in class com.hazelcast.config.FlakeIdGeneratorConfigReadOnly
Deprecated.
 
setImplementation(CachePartitionLostListener) - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
 
setImplementation(EventListener) - Method in class com.hazelcast.config.CachePartitionLostListenerConfigReadOnly
Deprecated.
 
setImplementation(CachePartitionLostListener) - Method in class com.hazelcast.config.CachePartitionLostListenerConfigReadOnly
Deprecated.
 
setImplementation(ICredentialsFactory) - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
setImplementation(EventListener) - Method in class com.hazelcast.config.EntryListenerConfig
 
setImplementation(EntryListener) - Method in class com.hazelcast.config.EntryListenerConfig
 
setImplementation(EntryListener) - Method in class com.hazelcast.config.EntryListenerConfigReadOnly
Deprecated.
 
setImplementation(EventListener) - Method in class com.hazelcast.config.EntryListenerConfigReadOnly
Deprecated.
 
setImplementation(Serializer) - Method in class com.hazelcast.config.GlobalSerializerConfig
 
setImplementation(ItemListener) - Method in class com.hazelcast.config.ItemListenerConfig
 
setImplementation(ItemListener) - Method in class com.hazelcast.config.ItemListenerConfigReadOnly
Deprecated.
 
setImplementation(EventListener) - Method in class com.hazelcast.config.ItemListenerConfigReadOnly
Deprecated.
 
setImplementation(EventListener) - Method in class com.hazelcast.config.ListenerConfig
Sets the EventListener implementation.
setImplementation(EventListener) - Method in class com.hazelcast.config.ListenerConfigReadOnly
Deprecated.
 
setImplementation(Object) - Method in class com.hazelcast.config.LoginModuleConfig
Deprecated.
setImplementation(MapPartitionLostListener) - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
 
setImplementation(EventListener) - Method in class com.hazelcast.config.MapPartitionLostListenerConfigReadOnly
Deprecated.
 
setImplementation(MapPartitionLostListener) - Method in class com.hazelcast.config.MapPartitionLostListenerConfigReadOnly
Deprecated.
 
setImplementation(Object) - Method in class com.hazelcast.config.MapStoreConfig
Sets the map store implementation object
setImplementation(Object) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
Deprecated.
 
setImplementation(MemberAddressProvider) - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
setImplementation(IPermissionPolicy) - Method in class com.hazelcast.config.PermissionPolicyConfig
 
setImplementation(Predicate) - Method in class com.hazelcast.config.PredicateConfig
Sets the Predicate implementation.
setImplementation(QuorumListener) - Method in class com.hazelcast.config.QuorumListenerConfig
 
setImplementation(SecurityInterceptor) - Method in class com.hazelcast.config.SecurityInterceptorConfig
 
setImplementation(Serializer) - Method in class com.hazelcast.config.SerializerConfig
Sets the serializer implementation instance.
setImplementation(Object) - Method in class com.hazelcast.config.ServiceConfig
 
setImplementation(Object) - Method in class com.hazelcast.config.SocketInterceptorConfig
Sets the SocketInterceptor implementation object.
setImplementation(Object) - Method in class com.hazelcast.config.WanConsumerConfig
Sets the implementation for this WAN consumer.
setImplementation(Object) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the implementation of the WanReplicationEndpoint.
setIncludeValue(boolean) - Method in class com.hazelcast.config.EntryListenerConfig
 
setIncludeValue(boolean) - Method in class com.hazelcast.config.EntryListenerConfigReadOnly
Deprecated.
 
setIncludeValue(boolean) - Method in class com.hazelcast.config.ItemListenerConfig
 
setIncludeValue(boolean) - Method in class com.hazelcast.config.ItemListenerConfigReadOnly
Deprecated.
 
setIncludeValue(boolean) - Method in class com.hazelcast.config.QueryCacheConfig
Set true to enable value caching, otherwise set false
setIndexConfigs(List<MapIndexConfig>) - Method in class com.hazelcast.config.QueryCacheConfig
 
setInitialBackoffMillis(int) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
 
setInitialLoadMode(MapStoreConfig.InitialLoadMode) - Method in class com.hazelcast.config.MapStoreConfig
Sets the initial load mode.
setInitialLoadMode(MapStoreConfig.InitialLoadMode) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
Deprecated.
 
setInitialPermits(int) - Method in class com.hazelcast.config.SemaphoreConfig
Sets the initial number of permits.
setInitialPermits(int) - Method in class com.hazelcast.config.SemaphoreConfigReadOnly
Deprecated.
 
setInitialPublisherState(WanPublisherState) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the initial publisher state.
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.CacheConfig
Data type that will be used to store records in this ICache.
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the InMemory Format for this ICache.
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.MapConfig
Binary type that will be used for storing records.
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.NearCacheConfig
Sets the data type used to store entries.
setInMemoryFormat(String) - Method in class com.hazelcast.config.NearCacheConfig
 
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
setInMemoryFormat(String) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.QueryCacheConfig
Sets memory format of values of entries in QueryCache.
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.ReplicatedMapConfig
Data type used to store entries.
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.RingbufferConfig
Sets the InMemoryFormat.
setInsideAws(boolean) - Method in class com.hazelcast.client.config.ClientAwsConfig
Deprecated.
setInstanceName(String) - Method in class com.hazelcast.client.config.ClientConfig
 
setInstanceName(String) - Method in class com.hazelcast.config.Config
Sets the instance name uniquely identifying the hazelcast instance created by this configuration.
setIntAttribute(String, int) - Method in class com.hazelcast.config.MemberAttributeConfig
 
setIntAttribute(String, int) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
Deprecated.
 
setIntAttribute(String, int) - Method in interface com.hazelcast.core.Member
Defines a key-value pair int attribute for this member available to other cluster members.
setInterfaces(Collection<String>) - Method in class com.hazelcast.config.InterfacesConfig
Adds a collection of interfaces.
setInterfaces(Collection<String>) - Method in class com.hazelcast.config.MemberGroupConfig
Sets the interfaces that are part of a group.
setInterfaces(InterfacesConfig) - Method in class com.hazelcast.config.NetworkConfig
 
setIntervalMilliseconds(int) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
setIntervalMilliseconds(int) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
Sets the time in milliseconds between each ping This value can not be smaller than 1000 milliseconds
setInvalidateOnChange(boolean) - Method in class com.hazelcast.config.NearCacheConfig
Sets if Near Cache entries are invalidated when the entries in the backing data structure are changed (updated or removed).
setInvalidateOnChange(boolean) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
setInvocationTime(Operation, long) - Static method in class com.hazelcast.spi.OperationAccessor
Sets the invocation time for the Operation.
setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.config.CollectionConfig
Sets the list of ItemListenerConfigs.
setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.config.ListConfigReadOnly
Deprecated.
 
setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.config.QueueConfig
Set the list of item listener configurations for this queue.
setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.config.QueueConfigReadOnly
Deprecated.
 
setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.config.SetConfigReadOnly
Deprecated.
 
setIterationCount(int) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
setIterationType(IterationType) - Method in class com.hazelcast.query.PagingPredicate
 
setJarPaths(List<String>) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
String jarPath is searched in following order: 1.
setJavaSerializationFilterConfig(JavaSerializationFilterConfig) - Method in class com.hazelcast.config.SerializationConfig
Allows to configure deserialization protection filter.
setJitter(double) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
At each iteration calculated back-off is randomized via following method Random(-jitter * current_backoff, jitter * current_backoff)
setJobTrackerConfigs(Map<String, JobTrackerConfig>) - Method in class com.hazelcast.config.Config
Sets the map of job tracker configurations, mapped by config name.
setJoin(JoinConfig) - Method in class com.hazelcast.config.NetworkConfig
 
setKeepAlive(boolean) - Method in class com.hazelcast.client.config.SocketOptions
Enable/disable SO_KEEPALIVE socket option.
setKey(byte[]) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
setKeyClassName(String) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setKeyType(Class<K>) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setKeyType(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the key type for this ICache.
setKeyType(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setKubernetesConfig(KubernetesConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Sets configuration to connect nodes in Kubernetes environment.
setKubernetesConfig(KubernetesConfig) - Method in class com.hazelcast.config.JoinConfig
 
setKubernetesConfig(KubernetesConfig) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the KubernetesConfig used by the discovery mechanism for this WAN publisher.
setLastAccessTime(long) - Method in interface com.hazelcast.monitor.LocalRecordStoreStats
Increases the number of hits of the locally owned entries of this partition.
setLastUpdateTime(long) - Method in interface com.hazelcast.monitor.LocalRecordStoreStats
Increases the number of hits of the locally owned entries of this partition.
setLicenseKey(String) - Method in class com.hazelcast.client.config.ClientConfig
Deprecated.
As of Hazelcast 3.10.3, enterprise license keys are required only for members, and not for clients
setLicenseKey(String) - Method in class com.hazelcast.config.Config
Sets the license key for this hazelcast instance.
setLingerSeconds(int) - Method in class com.hazelcast.client.config.SocketOptions
Enable/disable SO_LINGER with the specified linger time in seconds
setListConfigs(Map<String, ListConfig>) - Method in class com.hazelcast.config.Config
Sets the map of IList configurations, mapped by config name.
setListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.client.config.ClientConfig
Sets all ListenerConfig's
setListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.Config
Sets the list of EventListener configurations.
setListenerConfigs(List<QuorumListenerConfig>) - Method in class com.hazelcast.config.QuorumConfig
 
setListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.ReplicatedMapConfig
 
setListenerConfigurations() - Method in class com.hazelcast.config.AbstractCacheConfig
 
setListenerConfigurations(Set<CacheEntryListenerConfiguration<K, V>>) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setLiteMember(boolean) - Method in class com.hazelcast.config.Config
Sets the flag to indicate if this member is a lite member.
setLoadBalancer(LoadBalancer) - Method in class com.hazelcast.client.config.ClientConfig
Sets the LoadBalancer
setLocal(boolean) - Method in class com.hazelcast.config.EntryListenerConfig
 
setLocal(boolean) - Method in class com.hazelcast.config.EntryListenerConfigReadOnly
Deprecated.
 
setLocalUpdatePolicy(NearCacheConfig.LocalUpdatePolicy) - Method in class com.hazelcast.config.NearCacheConfig
Sets the NearCacheConfig.LocalUpdatePolicy of this Near Cache.
setLocalUpdatePolicy(NearCacheConfig.LocalUpdatePolicy) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
setLockConfigs(Map<String, LockConfig>) - Method in class com.hazelcast.config.Config
Sets the map of ILock configurations, mapped by config name.
setLogger(ILogger) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
setLongAttribute(String, long) - Method in class com.hazelcast.config.MemberAttributeConfig
 
setLongAttribute(String, long) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
Deprecated.
 
setLongAttribute(String, long) - Method in interface com.hazelcast.core.Member
Defines a key-value pair long attribute for this member available to other cluster members.
setLoopbackModeEnabled(boolean) - Method in class com.hazelcast.config.MulticastConfig
Enables or disables the loopback mode in the multicast discovery mechanism.
setManagedContext(ManagedContext) - Method in class com.hazelcast.client.config.ClientConfig
setManagedContext(ManagedContext) - Method in class com.hazelcast.config.Config
Sets the external managed context.
setManagementCenterConfig(ManagementCenterConfig) - Method in class com.hazelcast.config.Config
Sets the management center configuration for this hazelcast instance.
setManagementEnabled(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
Sets whether or not management is enabled on this cache.
setManagementEnabled(boolean) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setManagementEnabled(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
Sets whether management is enabled on a cache.
setManagementEnabled(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets management to enabled or disabled for this ICache.
setManagementEnabled(boolean) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setManagerPrefix(String) - Method in class com.hazelcast.config.CacheConfig
Sets the manager prefix of the ICache.
setManagerPrefix(String) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setMapAttributeConfigs(List<MapAttributeConfig>) - Method in class com.hazelcast.config.MapConfig
 
setMapAttributeConfigs(List<MapAttributeConfig>) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setMapConfigs(Map<String, MapConfig>) - Method in class com.hazelcast.config.Config
Sets the map of IMap configurations, mapped by config name.
setMapEventJournalConfigs(Map<String, EventJournalConfig>) - Method in class com.hazelcast.config.Config
Sets the map of map event journal configurations, mapped by config name.
setMapEvictionPolicy(MapEvictionPolicy) - Method in class com.hazelcast.config.MapConfig
Sets custom eviction policy implementation for this map.
setMapEvictionPolicy(MapEvictionPolicy) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setMapIndexConfigs(List<MapIndexConfig>) - Method in class com.hazelcast.config.MapConfig
 
setMapIndexConfigs(List<MapIndexConfig>) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setMapMerkleTreeConfigs(Map<String, MerkleTreeConfig>) - Method in class com.hazelcast.config.Config
Sets the map of map merkle configurations, mapped by config name.
setMapName(String) - Method in class com.hazelcast.config.EventJournalConfig
Sets the map name to which this config applies.
setMapName(String) - Method in class com.hazelcast.config.MerkleTreeConfig
Sets the map name to which this config applies.
setMapStoreConfig(MapStoreConfig) - Method in class com.hazelcast.config.MapConfig
Sets the map store configuration
setMapStoreConfig(MapStoreConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setMaxAttempts(int) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
setMaxAttempts(int) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
Set the max ping attempts before suspecting a member
setMaxBackoffMillis(int) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
When backoff reaches this upper bound, it does not increase any more.
setMaxConcurrentReplicationTargets(int) - Method in class com.hazelcast.config.CRDTReplicationConfig
Sets the maximum number of target members that we replicate the CRDT states to in one period.
setMaxIdleSeconds(int) - Method in class com.hazelcast.config.MapConfig
Maximum number of seconds for each entry to stay idle in the map.
setMaxIdleSeconds(int) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setMaxIdleSeconds(int) - Method in class com.hazelcast.config.NearCacheConfig
Set the maximum number of seconds each entry can stay in the Near Cache as untouched (not-read).
setMaxIdleSeconds(int) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
setMaximumSizePolicy(EvictionConfig.MaxSizePolicy) - Method in class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
setMaximumSizePolicy(EvictionConfig.MaxSizePolicy) - Method in class com.hazelcast.config.CacheEvictionConfigReadOnly
Deprecated.
 
setMaximumSizePolicy(EvictionConfig.MaxSizePolicy) - Method in class com.hazelcast.config.EvictionConfig
Sets the EvictionConfig.MaxSizePolicy of this eviction configuration.
setMaximumSizePolicy(EvictionConfig.MaxSizePolicy) - Method in class com.hazelcast.config.EvictionConfigReadOnly
Deprecated.
 
setMaxSize(int) - Method in class com.hazelcast.config.CollectionConfig
Sets the maximum size for the collection.
setMaxSize(int) - Method in class com.hazelcast.config.ListConfigReadOnly
Deprecated.
 
setMaxSize(int) - Method in class com.hazelcast.config.NearCacheConfig
setMaxSize(int) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
setMaxSize(int) - Method in class com.hazelcast.config.QueueConfig
Sets the maximum size of the Queue.
setMaxSize(int) - Method in class com.hazelcast.config.QueueConfigReadOnly
Deprecated.
 
setMaxSize(int) - Method in class com.hazelcast.config.SetConfigReadOnly
Deprecated.
 
setMaxSizeConfig(MaxSizeConfig) - Method in class com.hazelcast.config.MapConfig
 
setMaxSizeConfig(MaxSizeConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setMaxSizePolicy(CacheEvictionConfig.CacheMaxSizePolicy) - Method in class com.hazelcast.config.CacheEvictionConfig
setMaxSizePolicy(CacheEvictionConfig.CacheMaxSizePolicy) - Method in class com.hazelcast.config.CacheEvictionConfigReadOnly
Deprecated.
 
setMaxSizePolicy(MaxSizeConfig.MaxSizePolicy) - Method in class com.hazelcast.config.MaxSizeConfig
Ses the maximum size policy of the map.
setMaxSizePolicy(MaxSizeConfig.MaxSizePolicy) - Method in class com.hazelcast.config.MaxSizeConfigReadOnly
Deprecated.
 
setMaxThreadSize(int) - Method in class com.hazelcast.config.JobTrackerConfig
Sets the maximum thread pool size of this JobTracker.
setMaxThreadSize(int) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
Deprecated.
 
setMemberAddressProviderConfig(MemberAddressProviderConfig) - Method in class com.hazelcast.config.NetworkConfig
 
setMemberAttributeConfig(MemberAttributeConfig) - Method in class com.hazelcast.config.Config
Sets the member attribute configuration.
setMemberCredentialsConfig(CredentialsFactoryConfig) - Method in class com.hazelcast.config.SecurityConfig
 
setMemberGroupConfigs(Collection<MemberGroupConfig>) - Method in class com.hazelcast.config.PartitionGroupConfig
Adds a MemberGroupConfig.
setMemberLoginModuleConfigs(List<LoginModuleConfig>) - Method in class com.hazelcast.config.SecurityConfig
 
setMembers(List<String>) - Method in class com.hazelcast.config.TcpIpConfig
Sets the well known members.
setMergePolicy(String) - Method in class com.hazelcast.config.CacheConfig
Sets the class name of CacheMergePolicy implementation to this cache config.
setMergePolicy(String) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setMergePolicy(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the class name of CacheMergePolicy implementation to this cache config.
setMergePolicy(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setMergePolicy(String) - Method in class com.hazelcast.config.MapConfig
Deprecated.
setMergePolicy(String) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setMergePolicy(String) - Method in class com.hazelcast.config.ReplicatedMapConfig
setMergePolicy(String) - Method in class com.hazelcast.config.WanReplicationRef
Sets the merge policy sent to the WAN replication target to merge replicated entries with existing target entries.
setMergePolicy(String) - Method in class com.hazelcast.config.WanReplicationRefReadOnly
Deprecated.
 
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.AbstractBasicConfig
Sets the MergePolicyConfig for this data structure.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Sets the MergePolicyConfig for the scheduler.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.CollectionConfig
Sets the MergePolicyConfig for the collection.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.ListConfigReadOnly
Deprecated.
 
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.MapConfig
Sets the MergePolicyConfig for this map.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.MultiMapConfig
Sets the MergePolicyConfig for this MultiMap.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.QueueConfig
Sets the MergePolicyConfig for this queue.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.QueueConfigReadOnly
Deprecated.
 
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.ReplicatedMapConfig
Sets the MergePolicyConfig for this replicated map.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.RingbufferConfig
Sets the MergePolicyConfig for this ringbuffer.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.ScheduledExecutorConfig
Sets the MergePolicyConfig for the scheduler.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.SetConfigReadOnly
Deprecated.
 
setMessageListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.ReliableTopicConfig
Sets the list of message listeners (listens for when messages are added or removed) for this topic.
setMessageListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.TopicConfig
Sets the list of message listeners (listens for when messages are added or removed) for this topic.
setMessageListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.TopicConfigReadOnly
Deprecated.
 
setMetadataSpacePercentage(float) - Method in class com.hazelcast.config.NativeMemoryConfig
Sets the percentage of native memory space to be used to store metadata and internal memory structures by the native memory manager.
setMinBlockSize(int) - Method in class com.hazelcast.config.NativeMemoryConfig
Sets the minimum memory block size, in bytes, to be served by native memory manager.
setMinEvictionCheckMillis(long) - Method in class com.hazelcast.config.MapConfig
Deprecated.
As of version 3.7, eviction mechanism changed. It uses a probabilistic algorithm based on sampling. Please see documentation for further details.
setMinEvictionCheckMillis(long) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setMulticastConfig(MulticastConfig) - Method in class com.hazelcast.config.JoinConfig
 
setMulticastGroup(String) - Method in class com.hazelcast.config.MulticastConfig
Sets the multicast group.
setMulticastPort(int) - Method in class com.hazelcast.config.MulticastConfig
Sets the multicast port.
setMulticastTimeoutSeconds(int) - Method in class com.hazelcast.config.MulticastConfig
Specifies the time in seconds that a node should wait for a valid multicast response from another node running in the network before declaring itself as master node and creating its own cluster.
setMulticastTimeToLive(int) - Method in class com.hazelcast.config.MulticastConfig
Sets the time to live for the multicast package; a value between 0..255.
setMultiMapConfigs(Map<String, MultiMapConfig>) - Method in class com.hazelcast.config.Config
Sets the map of MultiMap configurations, mapped by config name.
setMultiplier(double) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
 
setMultiThreadingEnabled(boolean) - Method in class com.hazelcast.config.TopicConfig
Enable multi-threaded message handling.
setMultiThreadingEnabled(boolean) - Method in class com.hazelcast.config.TopicConfigReadOnly
Deprecated.
 
setMutualAuthConfig(MCMutualAuthConfig) - Method in class com.hazelcast.config.ManagementCenterConfig
Sets the management center mutual auth config
setName(String) - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
Sets the name or name pattern for this config.
setName(String) - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
Sets the name or name pattern for this config.
setName(String) - Method in class com.hazelcast.config.AbstractBasicConfig
Sets the name of this data structure.
setName(String) - Method in class com.hazelcast.config.CacheConfig
Sets the name of this ICache.
setName(String) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setName(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the name of this ICache.
setName(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setName(String) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Sets the name of the cardinality estimator.
setName(String) - Method in class com.hazelcast.config.CollectionConfig
Sets the name of this collection.
setName(String) - Method in class com.hazelcast.config.CountDownLatchConfig
Sets the name of the CountDownLatch.
setName(String) - Method in class com.hazelcast.config.DurableExecutorConfig
Sets the name of the executor task.
setName(String) - Method in class com.hazelcast.config.ExecutorConfig
Sets the name of the executor task.
setName(String) - Method in class com.hazelcast.config.ExecutorConfigReadOnly
Deprecated.
 
setName(String) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Sets the name or name pattern for this config.
setName(String) - Method in class com.hazelcast.config.FlakeIdGeneratorConfigReadOnly
Deprecated.
 
setName(String) - Method in class com.hazelcast.config.GroupConfig
Sets the group name of the group.
setName(String) - Method in class com.hazelcast.config.JobTrackerConfig
Sets the name of this JobTracker.
setName(String) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
Deprecated.
 
setName(String) - Method in class com.hazelcast.config.ListConfigReadOnly
Deprecated.
 
setName(String) - Method in class com.hazelcast.config.LockConfig
Sets the name of the lock.
setName(String) - Method in class com.hazelcast.config.MapAttributeConfig
Sets the name of the attribute extracted by the extractor.
setName(String) - Method in class com.hazelcast.config.MapAttributeConfigReadOnly
Deprecated.
 
setName(String) - Method in class com.hazelcast.config.MapConfig
Sets the name of the IMap
setName(String) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setName(String) - Method in class com.hazelcast.config.MultiMapConfig
Sets the name of this MultiMap.
setName(String) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
setName(String) - Method in interface com.hazelcast.config.NamedConfig
 
setName(String) - Method in class com.hazelcast.config.NearCacheConfig
Sets the name of the Near Cache.
setName(String) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
setName(String) - Method in class com.hazelcast.config.PermissionConfig
 
setName(String) - Method in class com.hazelcast.config.PNCounterConfig
Sets the name of the PN counter.
setName(String) - Method in class com.hazelcast.config.QueryCacheConfig
Sets the name of QueryCache.
setName(String) - Method in class com.hazelcast.config.QueueConfig
Set the name for this queue.
setName(String) - Method in class com.hazelcast.config.QueueConfigReadOnly
Deprecated.
 
setName(String) - Method in class com.hazelcast.config.QuorumConfig
 
setName(String) - Method in class com.hazelcast.config.ReliableTopicConfig
Sets the name of the reliable topic.
setName(String) - Method in class com.hazelcast.config.ReplicatedMapConfig
Sets the name of this ReplicatedMap.
setName(String) - Method in class com.hazelcast.config.RingbufferConfig
Sets the name of the ringbuffer.
setName(String) - Method in class com.hazelcast.config.ScheduledExecutorConfig
Sets the name of the executor task.
setName(String) - Method in class com.hazelcast.config.SemaphoreConfig
Sets the name of the semaphore.
setName(String) - Method in class com.hazelcast.config.SemaphoreConfigReadOnly
Deprecated.
 
setName(String) - Method in class com.hazelcast.config.ServiceConfig
 
setName(String) - Method in class com.hazelcast.config.SetConfigReadOnly
Deprecated.
 
setName(String) - Method in class com.hazelcast.config.TopicConfig
Sets the name of the topic.
setName(String) - Method in class com.hazelcast.config.TopicConfigReadOnly
Deprecated.
 
setName(String) - Method in class com.hazelcast.config.WanReplicationConfig
Sets the name of this WAN replication config.
setName(String) - Method in class com.hazelcast.config.WanReplicationRef
Sets the WAN replication reference name.
setName(String) - Method in class com.hazelcast.config.WanReplicationRefReadOnly
Deprecated.
 
setNativeMemoryConfig(NativeMemoryConfig) - Method in class com.hazelcast.client.config.ClientConfig
 
setNativeMemoryConfig(NativeMemoryConfig) - Method in class com.hazelcast.config.Config
Sets the native memory configuration for this hazelcast instance.
setNearCacheConfig(NearCacheConfig) - Method in class com.hazelcast.config.MapConfig
Sets the Near Cache configuration
setNearCacheConfig(NearCacheConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setNearCacheConfigMap(Map<String, NearCacheConfig>) - Method in class com.hazelcast.client.config.ClientConfig
Sets all NearCacheConfig's with the provided map
setNetworkConfig(ClientNetworkConfig) - Method in class com.hazelcast.client.config.ClientConfig
setNetworkConfig(NetworkConfig) - Method in class com.hazelcast.config.Config
Sets the network configuration for this hazelcast instance.
setNode(Node) - Method in interface com.hazelcast.spi.NodeAware
 
setNodeEngine(NodeEngine) - Method in class com.hazelcast.spi.Operation
 
setNodeFilter(NodeFilter) - Method in class com.hazelcast.config.DiscoveryConfig
 
setNodeFilter(NodeFilter) - Method in class com.hazelcast.config.DiscoveryConfigReadOnly
Deprecated.
 
setNodeFilterClass(String) - Method in class com.hazelcast.config.DiscoveryConfig
 
setNodeFilterClass(String) - Method in class com.hazelcast.config.DiscoveryConfigReadOnly
Deprecated.
 
setNodeIdOffset(long) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Sets the offset that will be added to the node ID assigned to cluster member for this generator.
setNodeIdOffset(long) - Method in class com.hazelcast.config.FlakeIdGeneratorConfigReadOnly
Deprecated.
 
setOldValueRequired(boolean) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
If true, previously assigned values for the affected keys will be sent to this cache entry listener implementation.
setOldValueRequired(boolean) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfigReadOnly
Deprecated.
 
setOperationResponseHandler(OperationResponseHandler) - Method in class com.hazelcast.spi.Operation
setOperationTryCount(int) - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
Sets the operation retry count for PN counter operations.
setOptimizeQueries(boolean) - Method in class com.hazelcast.config.MapConfig
setOptimizeQueries(boolean) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setOrdered(boolean) - Method in class com.hazelcast.config.MapIndexConfig
Configures the index to be ordered or not ordered.
setOrdered(boolean) - Method in class com.hazelcast.config.MapIndexConfigReadOnly
Deprecated.
 
setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Set outbound port definitions
setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.config.NetworkConfig
 
setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Set outbond ports
setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.config.NetworkConfig
 
setOutOfMemoryHandler(OutOfMemoryHandler) - Static method in class com.hazelcast.client.HazelcastClient
Sets OutOfMemoryHandler to be used when an OutOfMemoryError is caught by Hazelcast Client threads.
setOutOfMemoryHandler(OutOfMemoryHandler) - Static method in class com.hazelcast.client.HazelcastClientManager
 
setOutOfMemoryHandler(OutOfMemoryHandler) - Static method in class com.hazelcast.core.Hazelcast
Sets OutOfMemoryHandler to be used when an OutOfMemoryError is caught by Hazelcast threads.
setOverrideJavaSerialization(boolean) - Method in class com.hazelcast.config.GlobalSerializerConfig
 
setPackages(Collection<String>) - Method in class com.hazelcast.config.ClassFilter
 
setPacketType(Packet.Type) - Method in class com.hazelcast.nio.Packet
Sets the packet type by updating the packet type bits in the flags bitfield.
setPage(int) - Method in class com.hazelcast.query.PagingPredicate
 
setPageSize(int) - Method in class com.hazelcast.config.NativeMemoryConfig
Sets the page size, in bytes, to be allocated by native memory manager as a single block.
setParallelism(int) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets the number of Hot Restart store instances to create for one Hazelcast instance.
setParallelMode(boolean) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
Set the ICMP detector to run in parallel mode, independent from the other failure detectors.
setPartitionGroupConfig(PartitionGroupConfig) - Method in class com.hazelcast.config.Config
Sets the partition group configuration for this hazelcast instance.
setPartitionId(int) - Method in interface com.hazelcast.mapreduce.PartitionIdAware
Deprecated.
Sets the partition ID to the implementing instance it is executed against
setPartitionId(int) - Method in class com.hazelcast.spi.Operation
Sets the partition ID.
setPartitioningStrategy(PartitioningStrategy) - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
setPartitioningStrategy(PartitioningStrategy) - Method in class com.hazelcast.config.PartitioningStrategyConfigReadOnly
Deprecated.
 
setPartitioningStrategyClass(String) - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
setPartitioningStrategyClass(String) - Method in class com.hazelcast.config.PartitioningStrategyConfigReadOnly
Deprecated.
 
setPartitioningStrategyConfig(PartitioningStrategyConfig) - Method in class com.hazelcast.config.MapConfig
 
setPartitioningStrategyConfig(PartitioningStrategyConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setPartitionLostListenerConfigs(List<CachePartitionLostListenerConfig>) - Method in class com.hazelcast.config.CacheConfig
Sets the WAN target replication reference.
setPartitionLostListenerConfigs(List<CachePartitionLostListenerConfig>) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setPartitionLostListenerConfigs(List<CachePartitionLostListenerConfig>) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the PartitionLostListenerConfigs.
setPartitionLostListenerConfigs(List<CachePartitionLostListenerConfig>) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setPartitionLostListenerConfigs(List<MapPartitionLostListenerConfig>) - Method in class com.hazelcast.config.MapConfig
 
setPartitionLostListenerConfigs(List<MapPartitionLostListenerConfig>) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setPartitionStrategy(PartitioningStrategy) - Method in class com.hazelcast.config.PartitioningStrategyConfig
Deprecated.
setPartitionStrategy(PartitioningStrategy) - Method in class com.hazelcast.config.PartitioningStrategyConfigReadOnly
Deprecated.
 
setPassword(String) - Method in class com.hazelcast.config.GroupConfig
Deprecated.
since 3.11, password check is removed. use SecurityConfig() , ClientSecurityConfig() for authentication
setPassword(String) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
setPassword(String) - Method in class com.hazelcast.security.UsernamePasswordCredentials
Sets the password.
SetPermission - Class in com.hazelcast.security.permission
 
SetPermission(String, String...) - Constructor for class com.hazelcast.security.permission.SetPermission
 
setPersistWanReplicatedData(boolean) - Method in class com.hazelcast.config.WanConsumerConfig
 
setPNCounterConfigs(Map<String, PNCounterConfig>) - Method in class com.hazelcast.config.Config
Sets the map of PN counter configurations, mapped by config name.
setPolicy(String) - Method in class com.hazelcast.config.MergePolicyConfig
Sets the classname of your SplitBrainMergePolicy.
setPoolSize(int) - Method in class com.hazelcast.config.DurableExecutorConfig
Sets the number of executor threads per member for the executor.
setPoolSize(int) - Method in class com.hazelcast.config.ExecutorConfig
Sets the number of executor threads per member for the executor.
setPoolSize(int) - Method in class com.hazelcast.config.ExecutorConfigReadOnly
Deprecated.
 
setPoolSize(int) - Method in class com.hazelcast.config.ScheduledExecutorConfig
Sets the number of executor threads per member for the executor.
setPopulate(boolean) - Method in class com.hazelcast.config.QueryCacheConfig
Set true to enable initial population, otherwise set false.
setPort(int) - Method in class com.hazelcast.config.NetworkConfig
Sets the port the Hazelcast member will try to bind on.
setPortableFactories(Map<Integer, PortableFactory>) - Method in class com.hazelcast.config.SerializationConfig
 
setPortableFactoryClasses(Map<Integer, String>) - Method in class com.hazelcast.config.SerializationConfig
 
setPortableVersion(int) - Method in class com.hazelcast.config.SerializationConfig
 
setPortAutoIncrement(boolean) - Method in class com.hazelcast.config.NetworkConfig
Sets if a Hazelcast member is allowed to find a free port by incrementing the port number when it encounters an occupied port.
setPortCount(int) - Method in class com.hazelcast.config.NetworkConfig
The maximum number of ports allowed to use.
setPredicateConfig(PredicateConfig) - Method in class com.hazelcast.config.QueryCacheConfig
Sets the predicate of QueryCache.
setPrefetchCount(int) - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
Sets how many IDs are pre-fetched on the background when one call to FlakeIdGenerator.newId() is made.
setPrefetchCount(int) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Sets how many IDs are pre-fetched on the background when one call to FlakeIdGenerator.newId() is made.
setPrefetchCount(int) - Method in class com.hazelcast.config.FlakeIdGeneratorConfigReadOnly
Deprecated.
 
setPrefetchValidityMillis(long) - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
Sets for how long the pre-fetched IDs can be used.
setPrefetchValidityMillis(long) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Sets for how long the pre-fetched IDs can be used.
setPrefetchValidityMillis(long) - Method in class com.hazelcast.config.FlakeIdGeneratorConfigReadOnly
Deprecated.
 
setPrefixes(Collection<String>) - Method in class com.hazelcast.config.ClassFilter
 
setPreloaderConfig(NearCachePreloaderConfig) - Method in class com.hazelcast.config.NearCacheConfig
Sets the NearCachePreloaderConfig of this Near Cache.
setPreloaderConfig(NearCachePreloaderConfig) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
setPrincipal(String) - Method in class com.hazelcast.config.PermissionConfig
 
setPrincipal(String) - Method in class com.hazelcast.security.AbstractCredentials
 
setProperties(Properties) - Method in class com.hazelcast.client.config.ClientConfig
sets all properties
setProperties(Properties) - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
 
setProperties(Properties) - Method in class com.hazelcast.config.Config
Sets the properties for this config instance.
setProperties(Properties) - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
setProperties(Properties) - Method in class com.hazelcast.config.LoginModuleConfig
 
setProperties(Properties) - Method in class com.hazelcast.config.MapStoreConfig
Sets the properties
setProperties(Properties) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
Deprecated.
 
setProperties(Properties) - Method in class com.hazelcast.config.MCMutualAuthConfig
Sets the properties.
setProperties(Properties) - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
setProperties(Properties) - Method in class com.hazelcast.config.PermissionPolicyConfig
 
setProperties(Properties) - Method in class com.hazelcast.config.QueueStoreConfig
 
setProperties(Properties) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
Deprecated.
 
setProperties(Properties) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
setProperties(Properties) - Method in class com.hazelcast.config.ServiceConfig
 
setProperties(Properties) - Method in class com.hazelcast.config.SocketInterceptorConfig
Sets the properties.
setProperties(Properties) - Method in class com.hazelcast.config.SSLConfig
Sets the properties.
setProperties(Map<String, Comparable>) - Method in class com.hazelcast.config.WanConsumerConfig
Sets the properties for the custom WAN consumer.
setProperties(Map<String, Comparable>) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the WAN publisher properties.
setProperties(Properties) - Method in class com.hazelcast.config.XmlConfigBuilder
Sets the used properties.
setProperty(String, String) - Method in class com.hazelcast.client.config.ClientAwsConfig
Deprecated.
Sets the property understood by the AWS SPI Discovery Strategy.
setProperty(String, String) - Method in class com.hazelcast.client.config.ClientConfig
Sets the value of a named property.
setProperty(String, String) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
Sets the property understood by the given SPI Discovery Strategy.
setProperty(String, String) - Method in class com.hazelcast.config.Config
Sets the value of a named property.
setProperty(String, String) - Method in class com.hazelcast.config.MapStoreConfig
 
setProperty(String, String) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
Deprecated.
 
setProperty(String, String) - Method in class com.hazelcast.config.MCMutualAuthConfig
Sets a property.
setProperty(String, String) - Method in class com.hazelcast.config.QueueStoreConfig
 
setProperty(String, String) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
Deprecated.
 
setProperty(String, String) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
setProperty(String, String) - Method in class com.hazelcast.config.SocketInterceptorConfig
Sets a property.
setProperty(String, String) - Method in class com.hazelcast.config.SSLConfig
Sets a property.
setProviderFilter(String) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Filter to constraint members to be used for classloading request when a user class is not available locally.
setProviderMode(UserCodeDeploymentConfig.ProviderMode) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Configure behaviour when providing classes to remote members.
setProxyFactoryConfigs(List<ProxyFactoryConfig>) - Method in class com.hazelcast.client.config.ClientConfig
setPublicAddress(String) - Method in class com.hazelcast.config.NetworkConfig
Overrides the public address of a member.
setPublisherId(String) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the publisher ID used for identifying the publisher in a WanReplicationConfig.
setQueryCacheConfigs(Map<String, Map<String, QueryCacheConfig>>) - Method in class com.hazelcast.client.config.ClientConfig
 
setQueryCacheConfigs(List<QueryCacheConfig>) - Method in class com.hazelcast.config.MapConfig
Sets QueryCacheConfig instances to this MapConfig.
setQueryCacheConfigs(List<QueryCacheConfig>) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setQueueCapacity(int) - Method in class com.hazelcast.config.ExecutorConfig
Sets the queue capacity of the executor task.
setQueueCapacity(int) - Method in class com.hazelcast.config.ExecutorConfigReadOnly
Deprecated.
 
setQueueCapacity(int) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the capacity of the primary and backup queue for WAN replication events.
setQueueConfigs(Map<String, QueueConfig>) - Method in class com.hazelcast.config.Config
Sets the map of IQueue configurations, mapped by config name.
setQueueFullBehavior(WANQueueFullBehavior) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the configured behaviour of this WAN publisher when the WAN queue is full.
setQueueSize(int) - Method in class com.hazelcast.config.JobTrackerConfig
Sets the maximum size of the queue; the maximum number of tasks that can wait to be processed.
setQueueSize(int) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
Deprecated.
 
setQueueStoreConfig(QueueStoreConfig) - Method in class com.hazelcast.config.QueueConfig
Set the QueueStore (load and store queue items from/to a database) configuration.
setQueueStoreConfig(QueueStoreConfig) - Method in class com.hazelcast.config.QueueConfigReadOnly
Deprecated.
 
setQuorumConfigs(Map<String, QuorumConfig>) - Method in class com.hazelcast.config.Config
Sets the map of split-brain protection configurations, mapped by config name.
setQuorumFunctionClassName(String) - Method in class com.hazelcast.config.QuorumConfig
 
setQuorumFunctionImplementation(QuorumFunction) - Method in class com.hazelcast.config.QuorumConfig
 
setQuorumName(String) - Method in class com.hazelcast.config.AbstractBasicConfig
Sets the quorum name for operations.
setQuorumName(String) - Method in class com.hazelcast.config.CacheConfig
Associates this cache configuration to a quorum.
setQuorumName(String) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setQuorumName(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Associates this cache configuration to a quorum.
setQuorumName(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setQuorumName(String) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Sets the quorum name for operations.
setQuorumName(String) - Method in class com.hazelcast.config.CollectionConfig
Sets the quorum name for operations.
setQuorumName(String) - Method in class com.hazelcast.config.CountDownLatchConfig
 
setQuorumName(String) - Method in class com.hazelcast.config.DurableExecutorConfig
Sets the quorum name for operations.
setQuorumName(String) - Method in class com.hazelcast.config.ExecutorConfig
Sets the quorum name for operations.
setQuorumName(String) - Method in class com.hazelcast.config.ExecutorConfigReadOnly
Deprecated.
 
setQuorumName(String) - Method in class com.hazelcast.config.ListConfigReadOnly
Deprecated.
 
setQuorumName(String) - Method in class com.hazelcast.config.LockConfig
Sets the quorum name for lock operations.
setQuorumName(String) - Method in class com.hazelcast.config.MapConfig
 
setQuorumName(String) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setQuorumName(String) - Method in class com.hazelcast.config.MultiMapConfig
Sets the quorum name for operations.
setQuorumName(String) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
setQuorumName(String) - Method in class com.hazelcast.config.PNCounterConfig
Sets the quorum name for operations.
setQuorumName(String) - Method in class com.hazelcast.config.QueueConfig
Sets the quorum name for queue operations.
setQuorumName(String) - Method in class com.hazelcast.config.QueueConfigReadOnly
Deprecated.
 
setQuorumName(String) - Method in class com.hazelcast.config.ReplicatedMapConfig
Sets the quorum name for operations.
setQuorumName(String) - Method in class com.hazelcast.config.RingbufferConfig
Sets the quorum name for operations.
setQuorumName(String) - Method in class com.hazelcast.config.ScheduledExecutorConfig
Sets the quorum name for operations.
setQuorumName(String) - Method in class com.hazelcast.config.SemaphoreConfig
 
setQuorumName(String) - Method in class com.hazelcast.config.SemaphoreConfigReadOnly
Deprecated.
 
setQuorumName(String) - Method in class com.hazelcast.config.SetConfigReadOnly
Deprecated.
 
setReadBackupData(boolean) - Method in class com.hazelcast.config.MapConfig
Sets read-backup-data (reading local backup entries) for this map.
setReadBackupData(boolean) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setReadBatchSize(int) - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
Sets the read batch size.
setReadBatchSize(int) - Method in class com.hazelcast.config.ReliableTopicConfig
Sets the read batch size.
setReadThrough(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setReadThrough(boolean) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setReadThrough(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
Set if read-through caching should be used.
setReadThrough(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
Enables or disables read-through: a read loads the entry from the data store if it is not already in the cache.
setReadThrough(boolean) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setReadTimeout(long) - Method in class com.hazelcast.spring.cache.HazelcastCache
Set cache value retrieval timeout
setReconnectMode(ClientConnectionStrategyConfig.ReconnectMode) - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
How a client reconnect to cluster after a disconnect can be configured.
setRedoOperation(boolean) - Method in class com.hazelcast.client.config.ClientConfig
Deprecated.
setRedoOperation(boolean) - Method in class com.hazelcast.client.config.ClientNetworkConfig
If true, client will redo the operations that were executing on the server and client lost the connection.
setRegion(String) - Method in class com.hazelcast.config.AwsConfig
setReliableTopicConfigMap(Map<String, ClientReliableTopicConfig>) - Method in class com.hazelcast.client.config.ClientConfig
Sets the map of ClientReliableTopicConfig, mapped by config name.
setReliableTopicConfigs(Map<String, ReliableTopicConfig>) - Method in class com.hazelcast.config.Config
Sets the map of reliable topic configurations, mapped by config name.
setReplicaCount(int) - Method in class com.hazelcast.config.PNCounterConfig
Sets the number of replicas on which state for this PN counter will be kept.
setReplicaIndex(int) - Method in class com.hazelcast.spi.InvocationBuilder
Sets the replicaIndex.
setReplicaIndex(int) - Method in class com.hazelcast.spi.Operation
 
setReplicatedMapConfigs(Map<String, ReplicatedMapConfig>) - Method in class com.hazelcast.config.Config
Sets the map of ReplicatedMap configurations, mapped by config name.
setReplicationDelayMillis(long) - Method in class com.hazelcast.config.ReplicatedMapConfig
Deprecated.
since new implementation will route puts to the partition owner nodes, caching won't help replication speed because most of the time subsequent puts will end up in different nodes
setReplicationPeriodMillis(int) - Method in class com.hazelcast.config.CRDTReplicationConfig
Sets the period between two replications of CRDT states in milliseconds.
setReplicatorExecutorService(ScheduledExecutorService) - Method in class com.hazelcast.config.ReplicatedMapConfig
Deprecated.
new implementation doesn't use executor service for replication
setRepublishingEnabled(boolean) - Method in class com.hazelcast.config.WanReplicationRef
Sets if incoming WAN events to this member should be republished (forwarded) to this WAN replication reference.
setRepublishingEnabled(boolean) - Method in class com.hazelcast.config.WanReplicationRefReadOnly
Deprecated.
 
setRequiredMember(String) - Method in class com.hazelcast.config.TcpIpConfig
Sets the required member.
setResultDeserialized(boolean) - Method in class com.hazelcast.spi.InvocationBuilder
Sets the automatic deserialized option for the result.
setRetryCount(int) - Method in class com.hazelcast.config.JobTrackerConfig
retry count is currently not used but reserved for later use where the framework will automatically try to restart / retry operations from a available savepoint.
setRetryCount(int) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
Deprecated.
 
setReuseAddress(boolean) - Method in class com.hazelcast.client.config.SocketOptions
Enable/disable the SO_REUSEADDR socket option.
setReuseAddress(boolean) - Method in class com.hazelcast.config.NetworkConfig
Sets the reuse address.
setRingbufferConfigs(Map<String, RingbufferConfig>) - Method in class com.hazelcast.config.Config
Sets the map of Ringbuffer configurations, mapped by config name.
setRingbufferStoreConfig(RingbufferStoreConfig) - Method in class com.hazelcast.config.RingbufferConfig
Set the RingbufferStore (load and store ringbuffer items from/to a database) configuration.
setSalt(String) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
setScheduledExecutorConfigs(Map<String, ScheduledExecutorConfig>) - Method in class com.hazelcast.config.Config
Sets the map of scheduled executor configurations, mapped by config name.
setScopeId(String) - Method in class com.hazelcast.nio.Address
 
setSecretKey(String) - Method in class com.hazelcast.config.AwsConfig
setSecurityConfig(ClientSecurityConfig) - Method in class com.hazelcast.client.config.ClientConfig
setSecurityConfig(SecurityConfig) - Method in class com.hazelcast.config.Config
Sets the security configuration for this hazelcast instance.
setSecurityGroupName(String) - Method in class com.hazelcast.config.AwsConfig
setSecurityInterceptorConfigs(List<SecurityInterceptorConfig>) - Method in class com.hazelcast.config.SecurityConfig
 
setSemaphoreConfigs(Map<String, SemaphoreConfig>) - Method in class com.hazelcast.config.Config
Sets the map of semaphore configurations, mapped by config name.
setSerializationConfig(SerializationConfig) - Method in class com.hazelcast.client.config.ClientConfig
setSerializationConfig(SerializationConfig) - Method in class com.hazelcast.config.Config
Sets the serialization configuration for this hazelcast instance.
setSerializationService(SerializationService) - Method in interface com.hazelcast.spi.serialization.SerializationServiceAware
Gets the SerializationService reference injected.
setSerializeKeys(boolean) - Method in class com.hazelcast.config.NearCacheConfig
Sets if the Near Cache key is stored in serialized format or by-reference.
setSerializeKeys(boolean) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
setSerializerConfigs(Collection<SerializerConfig>) - Method in class com.hazelcast.config.SerializationConfig
 
setService(String) - Method in class com.hazelcast.client.config.ProxyFactoryConfig
 
setService(Object) - Method in class com.hazelcast.spi.Operation
 
setServiceConfigs(Collection<ServiceConfig>) - Method in class com.hazelcast.config.ServicesConfig
 
setServiceImpl(Object) - Method in class com.hazelcast.config.ServiceConfig
setServiceName(String) - Method in class com.hazelcast.spi.Operation
 
setServiceName(String) - Method in class com.hazelcast.wan.WanReplicationEvent
Sets the service name for this event object.
setServicesConfig(ServicesConfig) - Method in class com.hazelcast.config.Config
Sets the configuration for the user services managed by this hazelcast instance.
setSetConfigs(Map<String, SetConfig>) - Method in class com.hazelcast.config.Config
Sets the map of ISet configurations, mapped by config name.
setShortAttribute(String, short) - Method in class com.hazelcast.config.MemberAttributeConfig
 
setShortAttribute(String, short) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
Deprecated.
 
setShortAttribute(String, short) - Method in interface com.hazelcast.core.Member
Defines a key-value pair short attribute for this member available to other cluster members.
setSize(int) - Method in class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
setSize(int) - Method in class com.hazelcast.config.CacheEvictionConfigReadOnly
Deprecated.
 
setSize(int) - Method in class com.hazelcast.config.EvictionConfig
Sets the size which is used by the EvictionConfig.MaxSizePolicy.
setSize(int) - Method in class com.hazelcast.config.EvictionConfigReadOnly
Deprecated.
 
setSize(int) - Method in class com.hazelcast.config.MaxSizeConfig
Sets the maximum size of the map.
setSize(int) - Method in class com.hazelcast.config.MaxSizeConfigReadOnly
Deprecated.
 
setSize(MemorySize) - Method in class com.hazelcast.config.NativeMemoryConfig
Sets size of the native memory region.
setSize(int) - Method in class com.hazelcast.config.QuorumConfig
 
setSmartRouting(boolean) - Method in class com.hazelcast.client.config.ClientConfig
Deprecated.
setSmartRouting(boolean) - Method in class com.hazelcast.client.config.ClientNetworkConfig
If true, client will route the key based operations to owner of the key on best-effort basis.
setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.client.config.ClientConfig
Deprecated.
setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.config.NetworkConfig
setSocketOptions(SocketOptions) - Method in class com.hazelcast.client.config.ClientConfig
Deprecated.
setSocketOptions(SocketOptions) - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
setSql(String) - Method in class com.hazelcast.config.PredicateConfig
Sets sql string for this config.
setSSLConfig(SSLConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Sets the SSLConfig.
setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.NetworkConfig
Sets the SSLConfig.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
Sets whether or not statistics gathering is enabled on this cache.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setStatisticsEnabled(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
Sets whether statistics gathering is enabled on a cache.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets statistics to enabled or disabled for this ICache.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.CollectionConfig
Sets collection statistics to enabled or disabled.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ExecutorConfig
Enables or disables statistics gathering on the executor task.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ExecutorConfigReadOnly
Deprecated.
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Enables or disables statistics gathering of LocalFlakeIdGeneratorStats.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.FlakeIdGeneratorConfigReadOnly
Deprecated.
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ListConfigReadOnly
Deprecated.
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.MapConfig
Sets statistics to enabled or disabled for this map.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.MultiMapConfig
Enables or disables statistics for this MultiMap.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.PNCounterConfig
Enables or disables statistics for this PN counter
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.QueueConfig
Enables or disables statistics for this queue.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.QueueConfigReadOnly
Deprecated.
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ReliableTopicConfig
Enables or disables statistics for this reliable topic..
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ReplicatedMapConfig
Sets statistics to enabled or disabled for this replicated map.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.SetConfigReadOnly
Deprecated.
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.TopicConfig
Enables or disables statistics for this topic.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.TopicConfigReadOnly
Deprecated.
 
setStoreByValue(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
Set if a configured cache should use store-by-value or store-by-reference semantics.
setStoreByValue(boolean) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setStoreByValue(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
Set if a configured cache should use store-by-value or store-by-reference semantics.
setStoreImplementation(QueueStore) - Method in class com.hazelcast.config.QueueStoreConfig
 
setStoreImplementation(QueueStore) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
Deprecated.
 
setStoreImplementation(RingbufferStore) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
setStoreInitialDelaySeconds(int) - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
setStoreIntervalSeconds(int) - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
setStringAttribute(String, String) - Method in class com.hazelcast.config.MemberAttributeConfig
 
setStringAttribute(String, String) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
Deprecated.
 
setStringAttribute(String, String) - Method in interface com.hazelcast.core.Member
Defines a key-value pair string attribute for this member available to other cluster members.
setSymmetricEncryptionConfig(SymmetricEncryptionConfig) - Method in class com.hazelcast.config.NetworkConfig
setSyncBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfig
Deprecated.
setSyncBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
setSynchronous(boolean) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
If true, this cache entry listener implementation will be called in a synchronous manner.
setSynchronous(boolean) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfigReadOnly
Deprecated.
 
setSystemProperty(String) - Method in class com.hazelcast.spi.properties.HazelcastProperty
Sets the system property value of the property.
setTagKey(String) - Method in class com.hazelcast.config.AwsConfig
setTagValue(String) - Method in class com.hazelcast.config.AwsConfig
setTailSequence(long) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Sets the tail sequence.
setTargetAddress(Address) - Method in interface com.hazelcast.cluster.Joiner
Deprecated.
 
setTcpIpConfig(TcpIpConfig) - Method in class com.hazelcast.config.JoinConfig
 
setTcpNoDelay(boolean) - Method in class com.hazelcast.client.config.SocketOptions
Enable/disable TCP_NODELAY socket option.
setThisMember(MemberImpl) - Method in class com.hazelcast.logging.LoggingServiceImpl
 
setTimeout(long, TimeUnit) - Method in class com.hazelcast.transaction.TransactionOptions
Sets the timeout.
setTimeoutMilliseconds(int) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
setTimeoutMilliseconds(int) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
Sets the timeout in Milliseconds before declaring a failed ping This cannot be more than the interval value.
setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.EventJournalConfig
Sets the time to live in seconds.
setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.MapConfig
The maximum number of seconds for each entry to stay in the map.
setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.NearCacheConfig
Returns the maximum number of seconds for each entry to stay in the Near Cache (time to live).
setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.RingbufferConfig
Sets the time to live in seconds.
setTopicConfigs(Map<String, TopicConfig>) - Method in class com.hazelcast.config.Config
Sets the map of ITopic configurations, mapped by config name.
setTopicOverloadPolicy(TopicOverloadPolicy) - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
Sets the TopicOverloadPolicy for this reliable topic.
setTopicOverloadPolicy(TopicOverloadPolicy) - Method in class com.hazelcast.config.ReliableTopicConfig
Sets the TopicOverloadPolicy for this reliable topic.
setTopologyChangedStrategy(TopologyChangedStrategy) - Method in class com.hazelcast.config.JobTrackerConfig
Sets how the map reduce framework will react on topology changes while executing a job.
setTopologyChangedStrategy(TopologyChangedStrategy) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
Deprecated.
 
setTransactionType(TransactionOptions.TransactionType) - Method in class com.hazelcast.transaction.TransactionOptions
setTrustedInterfaces(Set<String>) - Method in class com.hazelcast.config.MulticastConfig
Sets the trusted interfaces.
setTryCount(int) - Method in class com.hazelcast.spi.InvocationBuilder
Sets the try count; the number of times this operation can be retried.
setTryPauseMillis(long) - Method in class com.hazelcast.spi.InvocationBuilder
Sets the pause time in milliseconds.
setTtl(int) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
setTtl(int) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
Sets the maximum number of times the IP Datagram (ping) can be forwarded, in most cases all Hazelcast cluster members would be within one network switch/router therefore
setTtl(K, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Updates TTL (time to live) value of the entry specified by key with a new TTL value.
setType(PermissionConfig.PermissionType) - Method in class com.hazelcast.config.PermissionConfig
 
setType(QuorumType) - Method in class com.hazelcast.config.QuorumConfig
 
setType(ConnectionType) - Method in interface com.hazelcast.nio.Connection
Sets the type of the connection
setTypeClass(Class) - Method in class com.hazelcast.config.SerializerConfig
Sets the type of the class that will be serialized via this implementation.
setTypeClassName(String) - Method in class com.hazelcast.config.SerializerConfig
This method is called only if typeClass is not set.
setTypes(Class<K>, Class<V>) - Method in class com.hazelcast.config.AbstractCacheConfig
Sets the expected type of keys and values for a Cache configured with this Configuration.
setTypes(Class<K>, Class<V>) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setTypes(Class<K>, Class<V>) - Method in interface com.hazelcast.config.CacheConfiguration
Sets the expected type of keys and values for a Cache configured with this Configuration.
setUpdateInterval(int) - Method in class com.hazelcast.config.ManagementCenterConfig
Sets the time frequency (in seconds) for which Management Center will take information from the Hazelcast cluster.
setUriString(String) - Method in class com.hazelcast.config.CacheConfig
Sets the URI string, which is the global identifier of the ICache.
setUriString(String) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setUrl(String) - Method in class com.hazelcast.config.ManagementCenterConfig
Sets the URL where management center will work.
setUsage(LoginModuleConfig.LoginModuleUsage) - Method in class com.hazelcast.config.LoginModuleConfig
 
setUseNativeByteOrder(boolean) - Method in class com.hazelcast.config.SerializationConfig
 
setUsePublicIp(boolean) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
Decides whether the public or private IP should be used to connect to Hazelcast members.
setUserCodeDeploymentConfig(ClientUserCodeDeploymentConfig) - Method in class com.hazelcast.client.config.ClientConfig
Set User Code Deployment configuration
setUserCodeDeploymentConfig(UserCodeDeploymentConfig) - Method in class com.hazelcast.config.Config
Set User Code Deployment configuration
setUserContext(ConcurrentMap<String, Object>) - Method in class com.hazelcast.client.config.ClientConfig
 
setUserContext(ConcurrentMap<String, Object>) - Method in class com.hazelcast.config.Config
Sets the user supplied context.
setUsername(String) - Method in class com.hazelcast.security.UsernamePasswordCredentials
Sets the user name.
setValidateTarget(boolean) - Method in class com.hazelcast.spi.Operation
 
setValidationTimeoutSeconds(int) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets validation timeout for hot-restart process, includes validating cluster members expected to join and partition table on all cluster.
setValueClassName(String) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setValueCollectionType(String) - Method in class com.hazelcast.config.MultiMapConfig
Sets the collection type for the values of this MultiMap.
setValueCollectionType(MultiMapConfig.ValueCollectionType) - Method in class com.hazelcast.config.MultiMapConfig
Sets the collection type for the values of this MultiMap.
setValueCollectionType(String) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
setValueCollectionType(MultiMapConfig.ValueCollectionType) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
setValueType(Class<V>) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setValueType(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the value type for this ICache.
setValueType(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setVersion(Version) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
setVersion(Version) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
setWaitTimeout(long) - Method in class com.hazelcast.spi.Operation
Sets the wait timeout in millis.
setWanConsumerConfig(WanConsumerConfig) - Method in class com.hazelcast.config.WanReplicationConfig
Sets the WAN consumer configuration for this WAN replication.
setWanPublisherConfigs(List<WanPublisherConfig>) - Method in class com.hazelcast.config.WanReplicationConfig
Sets the list of configured WAN publisher targets for this WAN replication.
setWanReplicationConfigs(Map<String, WanReplicationConfig>) - Method in class com.hazelcast.config.Config
Sets the map of WAN replication configurations, mapped by config name.
setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.CacheConfig
 
setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the WAN target replication reference.
setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.MapConfig
Sets the WAN target replication reference.
setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setWanSyncConfig(WanSyncConfig) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the config for the WAN sync mechanism.
setWhitelist(ClassFilter) - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
setWhitelistedPrefixes(String) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Comma separated list of prefixes of classes which will be loaded remotely.
setWriteBatchSize(int) - Method in class com.hazelcast.config.MapStoreConfig
Sets the number of operations to be included in each batch processing round.
setWriteBatchSize(int) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
Deprecated.
 
setWriteCoalescing(boolean) - Method in class com.hazelcast.config.MapStoreConfig
Setting MapStoreConfig.writeCoalescing is meaningful if you are using write-behind MapStore.
setWriteCoalescing(boolean) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
Deprecated.
 
setWriteDelaySeconds(int) - Method in class com.hazelcast.config.MapStoreConfig
Sets the number of seconds to delay before writing (storing) the dirty records
setWriteDelaySeconds(int) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
Deprecated.
 
setWriteThrough(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setWriteThrough(boolean) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setWriteThrough(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
Set if write-through caching should be used.
setWriteThrough(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
Enables or disables write-through for this ICache: a write to the queue also loads the entry into the data store.
setWriteThrough(boolean) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
severe(String) - Method in class com.hazelcast.logging.AbstractLogger
 
severe(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
severe(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
severe(String) - Method in interface com.hazelcast.logging.ILogger
Logs a message at Level.SEVERE.
severe(Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a throwable at the Level.SEVERE level.
severe(String, Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a message with an associated throwable at the Level.SEVERE level.
SharedService - Interface in com.hazelcast.spi
Deprecated.
since 3.7. A service can be retrieved using NodeEngine.getService(String)
SHORT_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
SHORT_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
SHORT_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
Short size in bytes
shouldBackup() - Method in interface com.hazelcast.spi.BackupAwareOperation
Checks if a backup needs to be made.
shouldConnectTo(Address) - Method in interface com.hazelcast.nio.IOService
 
shouldConnectTo(Address) - Method in class com.hazelcast.nio.NodeIOService
 
shouldFailOnIndeterminateOperationState() - Method in class com.hazelcast.spi.InvocationBuilder
Returns true if IndeterminateOperationStateException is enabled for this invocation
shouldHandle(OutOfMemoryError) - Method in class com.hazelcast.core.OutOfMemoryHandler
Decides if the OutOfMemoryError thrown will be handled by this OutOfMemoryHandler or not.
shouldNotify() - Method in interface com.hazelcast.spi.Notifier
 
shouldWait() - Method in interface com.hazelcast.spi.BlockingOperation
 
SHUFFLE_MEMBER_LIST - Static variable in class com.hazelcast.client.spi.properties.ClientProperty
Client shuffles the given member list to prevent all clients to connect to the same node when this property is set to true.
shutdown() - Method in class com.hazelcast.client.connection.ClientConnectionStrategy
The ClientConnectionManager will call this method as a last step of its shutdown.
shutdown(HazelcastInstance) - Static method in class com.hazelcast.client.HazelcastClient
Shutdown the provided client and remove it from the managed list
shutdown(String) - Static method in class com.hazelcast.client.HazelcastClient
Shutdown the provided client and remove it from the managed list
shutdown(HazelcastInstance) - Static method in class com.hazelcast.client.HazelcastClientManager
 
shutdown(String) - Static method in class com.hazelcast.client.HazelcastClientManager
 
shutdown() - Method in interface com.hazelcast.core.Cluster
Changes state of the cluster to the ClusterState.PASSIVE transactionally, then triggers the shutdown process on each node.
shutdown(TransactionOptions) - Method in interface com.hazelcast.core.Cluster
Changes state of the cluster to the ClusterState.PASSIVE transactionally, then triggers the shutdown process on each node.
shutdown() - Method in interface com.hazelcast.core.HazelcastInstance
Shuts down this HazelcastInstance.
shutdown() - Method in interface com.hazelcast.core.LifecycleService
Gracefully shuts down HazelcastInstance.
shutdown(boolean) - Method in class com.hazelcast.crdt.CRDTReplicationMigrationService
 
shutdown(boolean) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
shutdown() - Method in interface com.hazelcast.nio.ConnectionManager
Shutdowns ConnectionManager completely.
shutdown() - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Initiates an orderly shutdown in which previously submitted tasks are executed, but no new tasks will be accepted.
shutdown(boolean) - Method in interface com.hazelcast.spi.ManagedService
Shuts down this service.
shutdown() - Method in interface com.hazelcast.wan.WanReplicationEndpoint
Closes the endpoint and its internal connections and shuts down other internal states
shutdown() - Method in interface com.hazelcast.wan.WanReplicationService
Starts the shutdown process of the WAN replication service.
shutdownAll() - Static method in class com.hazelcast.client.HazelcastClient
Shuts down all the client HazelcastInstance created in this JVM.
shutdownAll() - Static method in class com.hazelcast.client.HazelcastClientManager
 
shutdownAll() - Static method in class com.hazelcast.core.Hazelcast
Shuts down all member HazelcastInstances running on this JVM.
shutdownAll() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Shuts down all running HazelcastOSGiInstances on the owner bundle.
shutdownExecutor(String) - Method in interface com.hazelcast.spi.ExecutionService
 
shutdownHazelcastInstance(HazelcastOSGiInstance) - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Shuts down the given HazelcastOSGiInstance on the owner bundle.
SHUTDOWNHOOK_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SHUTDOWNHOOK_POLICY - Static variable in class com.hazelcast.spi.properties.GroupProperty
Behaviour when JVM is about to exit while Hazelcast instance is still running.
SilentException - Interface in com.hazelcast.spi.exception
Marked interface for exceptions.
SIMPLE_CACHE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
SIMPLE_CACHE_CONFIG_DURATION_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
SIMPLE_CACHE_CONFIG_EXPIRY_POLICY_FACTORY_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
SIMPLE_CACHE_CONFIG_TIMED_EXPIRY_POLICY_FACTORY_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
SIMPLE_CACHE_ENTRY_LISTENER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
SimpleDiscoveryNode - Class in com.hazelcast.spi.discovery
Simple immutable implementation of the DiscoveryNode interface for convenience when implementing a DiscoveryStrategy.
SimpleDiscoveryNode(Address) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
This constructor will set private and public addresses to the same value and no properties are available.
SimpleDiscoveryNode(Address, Map<String, Object>) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
This constructor will set private and public addresses to the same value.
SimpleDiscoveryNode(Address, Address) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
This constructor will set private and public addresses separately and no properties are available.
SimpleDiscoveryNode(Address, Address, Map<String, Object>) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
This constructor will set private and public addresses separately.
SimplePropertyDefinition - Class in com.hazelcast.config.properties
Simple immutable implementation of PropertyDefinition for convenience of implementors.
SimplePropertyDefinition(String, TypeConverter) - Constructor for class com.hazelcast.config.properties.SimplePropertyDefinition
 
SimplePropertyDefinition(String, boolean, TypeConverter) - Constructor for class com.hazelcast.config.properties.SimplePropertyDefinition
 
SimplePropertyDefinition(String, boolean, TypeConverter, ValueValidator) - Constructor for class com.hazelcast.config.properties.SimplePropertyDefinition
 
SimulateLoadTask - Class in com.hazelcast.console
A simulated load test.
SimulateLoadTask(int, int, String) - Constructor for class com.hazelcast.console.SimulateLoadTask
 
singleAttribute(String) - Static method in class com.hazelcast.projection.Projections
Returns a projection that extracts the value of the given attributePath.
SingleMemberGroup - Class in com.hazelcast.partition.membergroup
 
SingleMemberGroup() - Constructor for class com.hazelcast.partition.membergroup.SingleMemberGroup
 
SingleMemberGroup(Member) - Constructor for class com.hazelcast.partition.membergroup.SingleMemberGroup
 
SingleMemberGroupFactory - Class in com.hazelcast.partition.membergroup
Arranges members in single-member groups (every member is its own group).
SingleMemberGroupFactory() - Constructor for class com.hazelcast.partition.membergroup.SingleMemberGroupFactory
 
size() - Method in interface com.hazelcast.cache.ICache
Total entry count.
size - Variable in class com.hazelcast.config.EvictionConfig
 
size - Variable in class com.hazelcast.config.QuorumConfigBuilder
Quorum size: expected number of live members in cluster for quorum to be present.
size() - Method in interface com.hazelcast.core.BaseMap
Returns the number of entries in this map.
size() - Method in interface com.hazelcast.core.BaseMultiMap
Returns the number of key-value pairs in the multimap.
size() - Method in interface com.hazelcast.core.BaseQueue
Returns the number of elements in this collection.
size() - Method in interface com.hazelcast.core.MultiMap
Returns the number of key-value pairs in the multimap.
size() - Method in interface com.hazelcast.core.TransactionalList
Returns the size of the list.
size() - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of Map.size().
size() - Method in interface com.hazelcast.core.TransactionalMultiMap
Returns the number of key-value pairs in the multimap.
size() - Method in interface com.hazelcast.core.TransactionalQueue
Returns the number of elements in this collection.
size() - Method in interface com.hazelcast.core.TransactionalSet
Returns the size of the set.
size() - Method in interface com.hazelcast.map.QueryCache
 
size() - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
size() - Method in interface com.hazelcast.partition.membergroup.MemberGroup
 
size() - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
size() - Method in interface com.hazelcast.ringbuffer.ReadResultSet
Return the result set size.
size() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Returns number of items in the Ringbuffer.
size() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Returns number of items in the ringbuffer (meaning the number of items between the RingbufferMergeData.getHeadSequence() and RingbufferMergeData.getTailSequence()).
Slf4jFactory - Class in com.hazelcast.logging
 
Slf4jFactory() - Constructor for class com.hazelcast.logging.Slf4jFactory
 
SLOW_INVOCATION_DETECTOR_THRESHOLD_MILLIS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
SLOW_OPERATION_DETECTOR_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Enables or disables the SlowOperationDetector.
SLOW_OPERATION_DETECTOR_LOG_PURGE_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Purge interval for slow operation logs.
SLOW_OPERATION_DETECTOR_LOG_RETENTION_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
This value defines the retention time of invocations in slow operation logs.
SLOW_OPERATION_DETECTOR_STACK_TRACE_LOGGING_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Defines if the stacktraces of slow operations are logged in the log file.
SLOW_OPERATION_DETECTOR_THRESHOLD_MILLIS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Defines a threshold above which a running operation in OperationService is considered to be slow.
SOCKET_BIND_ANY - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_BUFFER_DIRECT - Static variable in class com.hazelcast.spi.properties.GroupProperty
If the bytebuffers used in the socket should be a direct bytebuffer (true) or a regular bytebuffer (false).
SOCKET_CLIENT_BIND - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_CLIENT_BIND_ANY - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_CLIENT_BUFFER_DIRECT - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_CLIENT_RECEIVE_BUFFER_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Overrides receive buffer size for connections opened by clients.
SOCKET_CLIENT_SEND_BUFFER_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Overrides send buffer size for connections opened by clients.
SOCKET_CONNECT_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_KEEP_ALIVE - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_LINGER_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_NO_DELAY - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_RECEIVE_BUFFER_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_SEND_BUFFER_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_SERVER_BIND_ANY - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SocketInterceptor - Interface in com.hazelcast.nio
An interface that provides the ability to intercept the creation of sockets.
SocketInterceptorConfig - Class in com.hazelcast.config
Contains the configuration for interceptor socket.
SocketInterceptorConfig() - Constructor for class com.hazelcast.config.SocketInterceptorConfig
 
SocketOptions - Class in com.hazelcast.client.config
TCP Socket options
SocketOptions() - Constructor for class com.hazelcast.client.config.SocketOptions
 
SPIAwareMemberGroupFactory - Class in com.hazelcast.partition.membergroup
SPIAwareMemberGroupFactory is responsible for providing custom MemberGroups implemented by the user in DiscoveryStrategy.getPartitionGroupStrategy() to the PartitionStateManager.
SPIAwareMemberGroupFactory(DiscoveryService) - Constructor for class com.hazelcast.partition.membergroup.SPIAwareMemberGroupFactory
 
SplitBrainHandlerService - Interface in com.hazelcast.spi
An interface that can be implemented by SPI services that want to be able to resolve a split-brain.
SplitBrainMergePolicy<V,T extends MergingValue<V>> - Interface in com.hazelcast.spi.merge
Policy for merging data structure values after a split-brain has been healed.
SplitBrainMergePolicyProvider - Class in com.hazelcast.spi.merge
A provider for SplitBrainMergePolicy instances.
SplitBrainMergePolicyProvider(NodeEngine) - Constructor for class com.hazelcast.spi.merge.SplitBrainMergePolicyProvider
Constructs a new provider for SplitBrainMergePolicy classes.
SplitBrainMergeTypeProvider<T extends MergingValue> - Interface in com.hazelcast.spi.merge
Returns a class with the provided merge value types.
SplitBrainMergeTypes - Class in com.hazelcast.spi.merge
Collection of interfaces which define the provided merge types for each data structure.
SplitBrainMergeTypes() - Constructor for class com.hazelcast.spi.merge.SplitBrainMergeTypes
 
SplitBrainMergeTypes.AtomicLongMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of IAtomicLong.
SplitBrainMergeTypes.AtomicReferenceMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of IAtomicReference.
SplitBrainMergeTypes.CacheMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of ICache.
SplitBrainMergeTypes.CardinalityEstimatorMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of CardinalityEstimator.
SplitBrainMergeTypes.CollectionMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of collections (ISet and IList).
SplitBrainMergeTypes.MapMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of IMap.
SplitBrainMergeTypes.MultiMapMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of MultiMap.
SplitBrainMergeTypes.QueueMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of IQueue.
SplitBrainMergeTypes.ReplicatedMapMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of ReplicatedMap.
SplitBrainMergeTypes.RingbufferMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of Ringbuffer.
SplitBrainMergeTypes.ScheduledExecutorMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of IScheduledExecutorService.
SpringAware - Annotation Type in com.hazelcast.spring.context
Annotates a class for injection of Spring dependencies.
SpringHazelcastCachingProvider - Class in com.hazelcast.spring.cache
Spring utility class for connecting HazelcastCachingProvider interface and Hazelcast instance.
SpringManagedContext - Class in com.hazelcast.spring.context
ManagedContext implementation for Hazelcast.
SpringManagedContext() - Constructor for class com.hazelcast.spring.context.SpringManagedContext
 
SpringXmlBuilder(ParserContext, BeanDefinitionBuilder) - Constructor for class com.hazelcast.spring.HazelcastClientBeanDefinitionParser.SpringXmlBuilder
 
SpringXmlBuilderHelper() - Constructor for class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
sql - Variable in class com.hazelcast.config.PredicateConfig
 
SqlPredicate - Class in com.hazelcast.query
This class contains methods related to conversion of sql query to predicate.
SqlPredicate(String) - Constructor for class com.hazelcast.query.SqlPredicate
 
SqlPredicate() - Constructor for class com.hazelcast.query.SqlPredicate
 
SSLConfig - Class in com.hazelcast.config
SSL configuration.
SSLConfig() - Constructor for class com.hazelcast.config.SSLConfig
 
StaleSequenceException - Exception in com.hazelcast.ringbuffer
An RuntimeException that is thrown when accessing an item in the Ringbuffer using a sequence that is smaller than the current head sequence and that the ringbuffer store is disabled.
StaleSequenceException(String, long) - Constructor for exception com.hazelcast.ringbuffer.StaleSequenceException
Creates a StaleSequenceException with the given message.
StaleTaskException - Exception in com.hazelcast.scheduledexecutor
Exception thrown by the IScheduledFuture during any operation on a stale (=previously destroyed) task.
StaleTaskException(String) - Constructor for exception com.hazelcast.scheduledexecutor.StaleTaskException
 
StaleTaskIdException - Exception in com.hazelcast.durableexecutor
An RuntimeException that is thrown when retrieving the result of a task via DurableExecutorService if the result of the task is overwritten.
StaleTaskIdException(String) - Constructor for exception com.hazelcast.durableexecutor.StaleTaskIdException
 
StandardLoggerFactory - Class in com.hazelcast.logging
 
StandardLoggerFactory() - Constructor for class com.hazelcast.logging.StandardLoggerFactory
 
start() - Method in class com.hazelcast.client.connection.ClientConnectionStrategy
Called after ClientConnectionManager started.
start() - Method in class com.hazelcast.console.ConsoleApp
 
start() - Method in interface com.hazelcast.nio.ConnectionManager
Starts ConnectionManager, initializes its resources, starts threads, etc.
start() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
 
start() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategy
The start method is used to initialize internal state and perform any kind of startup procedure like multicast socket creation.
start() - Method in interface com.hazelcast.spi.discovery.integration.DiscoveryService
The start method is called on system startup to implement simple lifecycle management.
start() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategy
 
start() - Method in class com.hazelcast.spi.Offload
Starts the actual offloading.
STAT_NOT_AVAILABLE - Static variable in interface com.hazelcast.monitor.LocalInstanceStats
Default value for unavailable statistics.
stateChanged(LifecycleEvent) - Method in interface com.hazelcast.core.LifecycleListener
Called when instance's state changes.
StatefulTask<K,V> - Interface in com.hazelcast.scheduledexecutor
An interface to provide means for saving & loading state for Runnable and Callable tasks scheduled with an IScheduledExecutorService.
StatisticsAwareService<T extends LocalInstanceStats> - Interface in com.hazelcast.spi
A service implementating this interface provides local instance statistics.
stop() - Method in class com.hazelcast.console.ConsoleApp
 
stop() - Method in interface com.hazelcast.nio.ConnectionManager
Stops ConnectionManager, releases its resources, stops threads, etc.
stop(String, String) - Method in interface com.hazelcast.wan.WanReplicationService
Stops WAN replication for the given wanReplicationName and targetGroupName on this hazelcast instance.
StorageTypeAwareCacheMergePolicy - Interface in com.hazelcast.cache
Marker interface for indicating that key and value wrapped by CacheEntryView will be not converted to their original types.
store(K, V) - Method in interface com.hazelcast.core.MapStore
Stores the key-value pair.
store(K, V) - Method in class com.hazelcast.core.MapStoreAdapter
Stores the key-value pair.
store(Long, T) - Method in interface com.hazelcast.core.QueueStore
Stores the key-value pair.
store(long, T) - Method in interface com.hazelcast.core.RingbufferStore
Stores one item with it's corresponding sequence.
storeAll(Map<K, V>) - Method in interface com.hazelcast.core.MapStore
Stores multiple entries.
storeAll(Map<K, V>) - Method in class com.hazelcast.core.MapStoreAdapter
Stores multiple entries.
storeAll(Map<Long, T>) - Method in interface com.hazelcast.core.QueueStore
Stores multiple entries.
storeAll(long, T[]) - Method in interface com.hazelcast.core.RingbufferStore
Stores multiple items.
storeSequence(long) - Method in interface com.hazelcast.topic.ReliableMessageListener
Informs the ReliableMessageListener that it should store the sequence.
StreamSerializer<T> - Interface in com.hazelcast.nio.serialization
A base class for custom serialization.
StringAndPartitionAwarePartitioningStrategy - Class in com.hazelcast.partition.strategy
 
StringPartitioningStrategy - Class in com.hazelcast.partition.strategy
 
StringPartitioningStrategy() - Constructor for class com.hazelcast.partition.strategy.StringPartitioningStrategy
 
submit(Callable<T>, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to a randomly selected member and returns a Future representing that task.
submit(Runnable, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to a random member.
submit(Runnable, MemberSelector, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to randomly selected members.
submit(Callable<T>, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to a random member.
submit(Callable<T>, MemberSelector, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits task to a randomly selected member.
submit(Callable<T>) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Submits a value-returning task for execution and returns a Future representing the pending results of the task.
submit(Runnable, T) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Submits a Runnable task for execution and returns a Future representing that task.
submit(Runnable) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Submits a Runnable task for execution and returns a Future representing that task.
submit() - Method in interface com.hazelcast.mapreduce.MappingJob
Deprecated.
Submits the task to Hazelcast and executes the defined mapper and reducer on all cluster nodes.
submit(Collator<Map.Entry<KeyIn, List<ValueIn>>, ValueOut>) - Method in interface com.hazelcast.mapreduce.MappingJob
Deprecated.
Submits the task to Hazelcast, executes the defined mapper and reducer on all cluster nodes, and executes the collator before returning the final result.
submit() - Method in interface com.hazelcast.mapreduce.ReducingJob
Deprecated.
Submits the task to Hazelcast and executes the defined mapper and reducer on all cluster nodes
submit(Collator<Map.Entry<KeyIn, List<ValueIn>>, ValueOut>) - Method in interface com.hazelcast.mapreduce.ReducingJob
Deprecated.
Submits the task to Hazelcast and executes the defined mapper and reducer on all cluster nodes and executes the collator before returning the final result.
submit() - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
Deprecated.
Submits the task to Hazelcast and executes the defined mapper and reducer on all cluster nodes.
submit(Collator<Map.Entry<KeyIn, ValueIn>, ValueOut>) - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
Deprecated.
Submits the task to Hazelcast and executes the defined mapper and reducer on all cluster nodes and executes the collator before returning the final result.
submit(String, Runnable) - Method in interface com.hazelcast.spi.ExecutionService
 
submit(String, Callable<T>) - Method in interface com.hazelcast.spi.ExecutionService
 
submitToAllMembers(Callable<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits task to all cluster members and returns a map of Member-Future pairs representing pending completion of the task on each member.
submitToAllMembers(Runnable, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
Submits task to all the cluster members.
submitToAllMembers(Callable<T>, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
Submits task to all the cluster members.
submitToKey(K, EntryProcessor, ExecutionCallback) - Method in interface com.hazelcast.core.IMap
Applies the user defined EntryProcessor to the entry mapped by the key with specified ExecutionCallback to listen event status and returns immediately.
submitToKey(K, EntryProcessor) - Method in interface com.hazelcast.core.IMap
Applies the user defined EntryProcessor to the entry mapped by the key.
submitToKeyOwner(Callable<T>, Object) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to the owner of the specified key and returns a Future representing that task.
submitToKeyOwner(Runnable, Object, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to the owner of the specified key.
submitToKeyOwner(Callable<T>, Object, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits task to the owner of the specified key.
submitToKeyOwner(Callable<T>, Object) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Submits a task to the owner of the specified key and returns a Future representing that task.
submitToKeyOwner(Runnable, Object) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Submits a task to the owner of the specified key and returns a Future representing that task.
submitToMember(Callable<T>, Member) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to the specified member and returns a Future representing that task.
submitToMember(Runnable, Member, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to the specified member.
submitToMember(Callable<T>, Member, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to the specified member.
submitToMembers(Callable<T>, Collection<Member>) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to given members and returns map of Member-Future pairs representing pending completion of the task on each member
submitToMembers(Callable<T>, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to selected members and returns a map of Member-Future pairs representing pending completion of the task on each member.
submitToMembers(Runnable, Collection<Member>, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to the specified members.
submitToMembers(Runnable, MemberSelector, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
Submits task to the selected members.
submitToMembers(Callable<T>, Collection<Member>, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to the specified members.
submitToMembers(Callable<T>, MemberSelector, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
Submits task to the selected members.
subtractAndGet(long) - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Subtracts the given value from the current value.
subtractAndGet(long, VectorClock) - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
Subtracts the given value from the current value.
subtractAndGet(long) - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
 
sumHash(int, int) - Static method in class com.hazelcast.wan.merkletree.MerkleTreeUtil
Sums the hash of the left and the right children
Supplier<KeyIn,ValueIn,ValueOut> - Class in com.hazelcast.mapreduce.aggregation
Deprecated.
Use fast-aggregations Aggregator
Supplier() - Constructor for class com.hazelcast.mapreduce.aggregation.Supplier
Deprecated.
 
supports(String) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Checks whether the given XML tag is supported.
SymmetricEncryptionConfig - Class in com.hazelcast.config
Contains configuration for symmetric encryption
SymmetricEncryptionConfig() - Constructor for class com.hazelcast.config.SymmetricEncryptionConfig
 
syncAllMaps(String, String) - Method in interface com.hazelcast.wan.WanReplicationService
Initiate wan sync for all maps.
syncMap(String, String, String) - Method in interface com.hazelcast.wan.WanReplicationService
Initiate wan sync for a specific map.
SYSTEM_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
Name of the system executor.

T

tagFor(AliasedDiscoveryConfig) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Returns an XML tag (e.g.
tailSequence() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Returns the sequence of the tail.
take() - Method in interface com.hazelcast.core.BaseQueue
Retrieves and removes the head of this queue, waiting if necessary until an element becomes available.
take() - Method in interface com.hazelcast.core.IQueue
 
take() - Method in interface com.hazelcast.core.TransactionalQueue
Retrieves and removes the head of this queue, waiting if necessary until an element becomes available.
target - Variable in class com.hazelcast.spi.InvocationBuilder
 
TargetDisconnectedException - Exception in com.hazelcast.spi.exception
Thrown when a client invocation is failed because related target is disconnected and whether the invocation is run or not, is indeterminate
TargetDisconnectedException(String) - Constructor for exception com.hazelcast.spi.exception.TargetDisconnectedException
 
TargetDisconnectedException(String, Throwable) - Constructor for exception com.hazelcast.spi.exception.TargetDisconnectedException
 
TargetNotMemberException - Exception in com.hazelcast.spi.exception
A RetryableHazelcastException that indicates operation is send to a machine that isn't member of the cluster.
TargetNotMemberException(String) - Constructor for exception com.hazelcast.spi.exception.TargetNotMemberException
 
TargetNotMemberException(Address, int, String, String) - Constructor for exception com.hazelcast.spi.exception.TargetNotMemberException
 
TargetNotReplicaException - Exception in com.hazelcast.crdt
Exception that indicates that the receiver of a CRDT operation is not a CRDT replica.
TargetNotReplicaException(String) - Constructor for exception com.hazelcast.crdt.TargetNotReplicaException
 
TASK_SCHEDULER_REMOVE_ON_CANCEL - Static variable in class com.hazelcast.spi.properties.GroupProperty
This is a Java 6 specific property.
TaskScheduler - Interface in com.hazelcast.spi
ExecutorService can schedule a command to run after a given delay or execute periodically.
TaskUtils - Class in com.hazelcast.scheduledexecutor
A helper class with utilities to act upon Runnable and/or Callable tasks.
TCP_JOIN_PORT_TRY_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
The number of incremental ports, starting with port number defined in network configuration, that will be used to connect to a host which is defined without a port in the TCP-IP member list while a node is searching for a cluster.
TcpIpConfig - Class in com.hazelcast.config
Contains the configuration for the Tcp/Ip join mechanism.
TcpIpConfig() - Constructor for class com.hazelcast.config.TcpIpConfig
 
terminate() - Method in interface com.hazelcast.core.LifecycleService
Terminate HazelcastInstance ungracefully.
test(DiscoveryNode) - Method in interface com.hazelcast.spi.discovery.NodeFilter
Accepts or denies a DiscoveryNode based on the implemented rules.
TEXT - Static variable in class com.hazelcast.nio.Protocols
Protocol that is used by Memcache And Http
throwNotActiveException() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
TimedExpiryPolicyFactoryConfig() - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
TimedExpiryPolicyFactoryConfig(CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType, CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
toByteArray(InputStream) - Static method in class com.hazelcast.nio.IOUtil
 
toByteArray() - Method in interface com.hazelcast.nio.ObjectDataOutput
 
toByteArray(int) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
toByteArray() - Method in interface com.hazelcast.nio.serialization.Data
Returns byte array representation of internal binary format.
toBytes(long) - Method in enum com.hazelcast.memory.MemoryUnit
 
toData(Object) - Method in class com.hazelcast.client.spi.ClientProxy
 
toData(Object) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
toData(Object) - Method in interface com.hazelcast.spi.NodeEngine
Serializes an object to a Data.
toData(Object) - Method in interface com.hazelcast.spi.serialization.SerializationService
Serializes an object to a Data.
toData(Object, PartitioningStrategy) - Method in interface com.hazelcast.spi.serialization.SerializationService
Serializes an object to a Data.
toDebugString(String, ByteBuffer) - Static method in class com.hazelcast.nio.IOUtil
Creates a debug String for te given ByteBuffer.
toFileName(String) - Static method in class com.hazelcast.nio.IOUtil
 
toGigaBytes(long) - Method in enum com.hazelcast.memory.MemoryUnit
 
toKiloBytes(long) - Method in enum com.hazelcast.memory.MemoryUnit
 
toMaxSizePolicy() - Method in enum com.hazelcast.config.CacheEvictionConfig.CacheMaxSizePolicy
Deprecated.
 
toMegaBytes(long) - Method in enum com.hazelcast.memory.MemoryUnit
 
toObject(Object) - Method in class com.hazelcast.client.spi.ClientProxy
 
toObject(Object) - Method in interface com.hazelcast.spi.NodeEngine
Deserializes an object.
toObject(Object, Class) - Method in interface com.hazelcast.spi.NodeEngine
Deserializes an object.
toObject(Object) - Method in interface com.hazelcast.spi.serialization.SerializationService
Deserializes an object.
toObject(Object, Class) - Method in interface com.hazelcast.spi.serialization.SerializationService
Deserializes an object.
toObjectIfNeeded(Object) - Method in class com.hazelcast.spi.TransactionalDistributedObject
 
toOpControl(Address) - Method in class com.hazelcast.spi.CallsPerMember
 
TOPIC_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
TopicConfig - Class in com.hazelcast.config
Contains the configuration for a ITopic.
TopicConfig() - Constructor for class com.hazelcast.config.TopicConfig
Creates a TopicConfig.
TopicConfig(String) - Constructor for class com.hazelcast.config.TopicConfig
Creates a TopicConfig with the given name.
TopicConfig(TopicConfig) - Constructor for class com.hazelcast.config.TopicConfig
Creates a TopicConfig by cloning another TopicConfig.
TopicConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
TopicConfigReadOnly(TopicConfig) - Constructor for class com.hazelcast.config.TopicConfigReadOnly
Deprecated.
 
TopicOverloadException - Exception in com.hazelcast.topic
A HazelcastException thrown when a publisher wants to write to a topic, but there is not sufficient storage to deal with the event.
TopicOverloadException(String) - Constructor for exception com.hazelcast.topic.TopicOverloadException
Creates a TopicOverloadException.
TopicOverloadPolicy - Enum in com.hazelcast.topic
A policy to deal with an overloaded topic; so topic where there is no place to store new messages.
TopicPermission - Class in com.hazelcast.security.permission
 
TopicPermission(String, String...) - Constructor for class com.hazelcast.security.permission.TopicPermission
 
TopologyChangedException - Exception in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
TopologyChangedException() - Constructor for exception com.hazelcast.mapreduce.TopologyChangedException
Deprecated.
Creates a new instance of the TopologyChangedException
TopologyChangedException(String) - Constructor for exception com.hazelcast.mapreduce.TopologyChangedException
Deprecated.
Creates a new instance of the TopologyChangedException
topologyChangedStrategy(TopologyChangedStrategy) - Method in interface com.hazelcast.mapreduce.Job
Deprecated.
Defines the strategy to handle topology changes while executing the map reduce job.
topologyChangedStrategy(TopologyChangedStrategy) - Method in interface com.hazelcast.mapreduce.MappingJob
Deprecated.
Defines the strategy to handle topology changes while executing the map reduce job.
topologyChangedStrategy(TopologyChangedStrategy) - Method in interface com.hazelcast.mapreduce.ReducingJob
Deprecated.
Defines the strategy to handle topology changes while executing the map reduce job.
topologyChangedStrategy(TopologyChangedStrategy) - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
Deprecated.
Defines the strategy to handle topology changes while executing the map reduce job.
TopologyChangedStrategy - Enum in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
toPrettyString() - Method in class com.hazelcast.memory.MemorySize
Returns a pretty format String representation of this memory size.
toPrettyString(long) - Static method in class com.hazelcast.memory.MemorySize
Utility method to create a pretty format representation of given value in bytes.
toPrettyString(long, MemoryUnit) - Static method in class com.hazelcast.memory.MemorySize
Utility method to create a pretty format representation of given value in given unit.
toStoreValue(Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
 
toString() - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
toString() - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
 
toString() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
 
toString() - Method in class com.hazelcast.config.AbstractBasicConfig
 
toString() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
 
toString() - Method in class com.hazelcast.config.CacheConfig
 
toString() - Method in class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
toString() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
toString() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
toString() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
toString() - Method in class com.hazelcast.config.CacheSimpleConfig
 
toString() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
toString() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
toString() - Method in class com.hazelcast.config.ClassFilter
 
toString() - Method in class com.hazelcast.config.Config
 
toString() - Method in class com.hazelcast.config.CountDownLatchConfig
 
toString() - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
toString() - Method in class com.hazelcast.config.DiscoveryConfig
 
toString() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
toString() - Method in class com.hazelcast.config.DurableExecutorConfig
 
toString() - Method in class com.hazelcast.config.EntryListenerConfig
 
toString() - Method in class com.hazelcast.config.EventJournalConfig
 
toString() - Method in class com.hazelcast.config.EvictionConfig
 
toString() - Method in class com.hazelcast.config.ExecutorConfig
 
toString() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
toString() - Method in class com.hazelcast.config.GlobalSerializerConfig
 
toString() - Method in class com.hazelcast.config.GroupConfig
 
toString() - Method in class com.hazelcast.config.HotRestartConfig
 
toString() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
toString() - Method in class com.hazelcast.config.InterfacesConfig
 
toString() - Method in class com.hazelcast.config.ItemListenerConfig
 
toString() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
toString() - Method in class com.hazelcast.config.JoinConfig
 
toString() - Method in class com.hazelcast.config.ListConfig
 
toString() - Method in class com.hazelcast.config.ListenerConfig
 
toString() - Method in class com.hazelcast.config.LockConfig
 
toString() - Method in class com.hazelcast.config.LoginModuleConfig
 
toString() - Method in class com.hazelcast.config.ManagementCenterConfig
 
toString() - Method in class com.hazelcast.config.MapAttributeConfig
 
toString() - Method in class com.hazelcast.config.MapConfig
 
toString() - Method in class com.hazelcast.config.MapIndexConfig
 
toString() - Method in class com.hazelcast.config.MapStoreConfig
 
toString() - Method in class com.hazelcast.config.MaxSizeConfig
 
toString() - Method in class com.hazelcast.config.MCMutualAuthConfig
 
toString() - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
toString() - Method in class com.hazelcast.config.MemberGroupConfig
 
toString() - Method in class com.hazelcast.config.MergePolicyConfig
 
toString() - Method in class com.hazelcast.config.MerkleTreeConfig
 
toString() - Method in class com.hazelcast.config.MulticastConfig
 
toString() - Method in class com.hazelcast.config.MultiMapConfig
 
toString() - Method in class com.hazelcast.config.NativeMemoryConfig
 
toString() - Method in class com.hazelcast.config.NearCacheConfig
 
toString() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
toString() - Method in class com.hazelcast.config.NetworkConfig
 
toString() - Method in class com.hazelcast.config.PartitionGroupConfig
 
toString() - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
toString() - Method in class com.hazelcast.config.PermissionConfig
 
toString() - Method in class com.hazelcast.config.PermissionPolicyConfig
 
toString() - Method in class com.hazelcast.config.PredicateConfig
 
toString() - Method in class com.hazelcast.config.QueryCacheConfig
 
toString() - Method in class com.hazelcast.config.QueueConfig
 
toString() - Method in class com.hazelcast.config.QueueStoreConfig
 
toString() - Method in class com.hazelcast.config.QuorumConfig
 
toString() - Method in class com.hazelcast.config.ReliableTopicConfig
 
toString() - Method in class com.hazelcast.config.ReplicatedMapConfig
 
toString() - Method in class com.hazelcast.config.RingbufferConfig
 
toString() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
toString() - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
toString() - Method in class com.hazelcast.config.SecurityConfig
 
toString() - Method in class com.hazelcast.config.SemaphoreConfig
 
toString() - Method in class com.hazelcast.config.SerializationConfig
 
toString() - Method in class com.hazelcast.config.SerializerConfig
 
toString() - Method in class com.hazelcast.config.ServiceConfig
 
toString() - Method in class com.hazelcast.config.ServicesConfig
 
toString() - Method in class com.hazelcast.config.SetConfig
 
toString() - Method in class com.hazelcast.config.SocketInterceptorConfig
 
toString() - Method in class com.hazelcast.config.SSLConfig
 
toString() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
toString() - Method in class com.hazelcast.config.TcpIpConfig
 
toString() - Method in class com.hazelcast.config.TopicConfig
 
toString() - Method in class com.hazelcast.config.WanConsumerConfig
 
toString() - Method in class com.hazelcast.config.WanPublisherConfig
 
toString() - Method in class com.hazelcast.config.WanReplicationConfig
 
toString() - Method in class com.hazelcast.config.WanReplicationRef
 
toString() - Method in class com.hazelcast.config.WanSyncConfig
 
toString() - Method in class com.hazelcast.core.AbstractIMapEvent
Returns a String representation of this event.
toString() - Method in class com.hazelcast.core.DistributedObjectEvent
 
toString() - Method in class com.hazelcast.core.EntryEvent
 
toString() - Method in class com.hazelcast.core.InitialMembershipEvent
 
toString() - Method in class com.hazelcast.core.ItemEvent
 
toString() - Method in class com.hazelcast.core.LifecycleEvent
 
toString() - Method in class com.hazelcast.core.MapEvent
 
toString() - Method in class com.hazelcast.core.MembershipEvent
 
toString() - Method in class com.hazelcast.core.MigrationEvent
 
toString() - Method in class com.hazelcast.core.PartitionAwareKey
 
toString() - Method in class com.hazelcast.crdt.CRDTReplicationMigrationService
 
toString() - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
 
toString() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
toString() - Method in class com.hazelcast.map.EventLostEvent
 
toString() - Method in class com.hazelcast.map.MapPartitionLostEvent
 
toString() - Method in class com.hazelcast.memory.DefaultGarbageCollectorStats
 
toString() - Method in class com.hazelcast.memory.DefaultMemoryStats
 
toString() - Method in class com.hazelcast.memory.MemorySize
 
toString() - Method in class com.hazelcast.nio.Address
 
toString() - Method in class com.hazelcast.nio.Packet
 
toString() - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
toString() - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
toString() - Method in class com.hazelcast.partition.PartitionLostEvent
 
toString() - Method in class com.hazelcast.query.PartitionPredicate
 
toString() - Method in class com.hazelcast.query.PredicateBuilder
 
toString() - Method in class com.hazelcast.query.SqlPredicate
 
toString() - Method in class com.hazelcast.query.TruePredicate
 
toString() - Method in class com.hazelcast.quorum.QuorumEvent
 
toString() - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
toString() - Method in class com.hazelcast.security.permission.AllPermissions
 
toString() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
 
toString() - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
 
toString() - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
toString() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
toString() - Method in class com.hazelcast.spi.DefaultObjectNamespace
Deprecated.
 
toString(StringBuilder) - Method in class com.hazelcast.spi.Operation
A template method allows for additional information to be passed into the Operation.toString() method.
toString() - Method in class com.hazelcast.spi.Operation
 
toString() - Method in class com.hazelcast.spi.partition.IPartitionLostEvent
 
toString() - Method in class com.hazelcast.spi.PartitionMigrationEvent
 
toString() - Method in class com.hazelcast.spi.PartitionReplicationEvent
 
toString() - Method in class com.hazelcast.spi.properties.HazelcastProperty
 
toString() - Method in class com.hazelcast.transaction.TransactionOptions
 
toString() - Method in class com.hazelcast.version.MemberVersion
 
toString() - Method in class com.hazelcast.version.Version
 
total() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the total number of total operations
totalPhysicalMemory() - Static method in class com.hazelcast.memory.MemoryStatsSupport
Returns the total available physical memory on the system in bytes or -1 if not available.
totalSize() - Method in interface com.hazelcast.nio.serialization.Data
Returns the total size of Data in bytes.
totalSwapSpace() - Static method in class com.hazelcast.memory.MemoryStatsSupport
Returns the total amount of swap space in bytes or -1 if not available.
touch(File) - Static method in class com.hazelcast.nio.IOUtil
Simulates a Linux touch command, by setting the last modified time of given file.
toUrn() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
Returns the String representation of the handler.
toUserFriendlyString(String) - Static method in class com.hazelcast.nio.Protocols
 
TrackableJob<V> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
TransactionalDistributedObject<S extends RemoteService> - Class in com.hazelcast.spi
To centralize de-serialization for transactional proxies
TransactionalDistributedObject(NodeEngine, S, Transaction) - Constructor for class com.hazelcast.spi.TransactionalDistributedObject
 
TransactionalList<E> - Interface in com.hazelcast.core
Transactional implementation of IList.
TransactionalMap<K,V> - Interface in com.hazelcast.core
Transactional implementation of BaseMap.
TransactionalMultiMap<K,V> - Interface in com.hazelcast.core
Transactional implementation of BaseMultiMap.
TransactionalObject - Interface in com.hazelcast.transaction
Marker interface for all transactional distributed objects.
TransactionalQueue<E> - Interface in com.hazelcast.core
Transactional implementation of BaseQueue.
TransactionalService - Interface in com.hazelcast.spi
An interface that can be implemented by SPI services that want to deal with transactions.
TransactionalSet<E> - Interface in com.hazelcast.core
Transactional implementation of ISet.
TransactionalTask<T> - Interface in com.hazelcast.transaction
Contains the logic that is going to be executed within a transaction.
TransactionalTaskContext - Interface in com.hazelcast.transaction
Provides a context to access transactional data-structures, like the TransactionalMap.
TransactionContext - Interface in com.hazelcast.transaction
Provides a context to perform transactional operations: beginning/committing transactions, but also retrieving transactional data-structures like the TransactionalMap.
TransactionException - Exception in com.hazelcast.transaction
A HazelcastException that is thrown when something goes wrong while dealing with transactions and transactional data-structures.
TransactionException() - Constructor for exception com.hazelcast.transaction.TransactionException
 
TransactionException(String) - Constructor for exception com.hazelcast.transaction.TransactionException
 
TransactionException(String, Throwable) - Constructor for exception com.hazelcast.transaction.TransactionException
 
TransactionException(Throwable) - Constructor for exception com.hazelcast.transaction.TransactionException
 
TransactionManagerService - Interface in com.hazelcast.transaction
 
TransactionNotActiveException - Exception in com.hazelcast.transaction
A HazelcastException thrown when an a transactional operation is executed without an active transaction.
TransactionNotActiveException() - Constructor for exception com.hazelcast.transaction.TransactionNotActiveException
 
TransactionNotActiveException(String) - Constructor for exception com.hazelcast.transaction.TransactionNotActiveException
 
TransactionOptions - Class in com.hazelcast.transaction
Contains the configuration for a Hazelcast transaction.
TransactionOptions() - Constructor for class com.hazelcast.transaction.TransactionOptions
Creates a new default configured TransactionsOptions.
TransactionOptions.TransactionType - Enum in com.hazelcast.transaction
The type of transaction.
TransactionPermission - Class in com.hazelcast.security.permission
 
TransactionPermission() - Constructor for class com.hazelcast.security.permission.TransactionPermission
 
TransactionTimedOutException - Exception in com.hazelcast.transaction
Thrown when a transaction has timed out.
TransactionTimedOutException() - Constructor for exception com.hazelcast.transaction.TransactionTimedOutException
 
TransactionTimedOutException(String) - Constructor for exception com.hazelcast.transaction.TransactionTimedOutException
 
TransactionTimedOutException(String, Throwable) - Constructor for exception com.hazelcast.transaction.TransactionTimedOutException
 
TransactionTimedOutException(Throwable) - Constructor for exception com.hazelcast.transaction.TransactionTimedOutException
 
transform(I) - Method in class com.hazelcast.projection.Projection
Transforms the input object into the output object.
translate(Address) - Method in interface com.hazelcast.client.connection.AddressTranslator
Translates the given address to another address specific to network or service
transmit(Packet, Connection) - Method in interface com.hazelcast.nio.ConnectionManager
Transmits a packet to a certain connection.
transmit(Packet, Address) - Method in interface com.hazelcast.nio.ConnectionManager
Transmits a packet to a certain address.
triggerForceStart() - Method in interface com.hazelcast.hotrestart.InternalHotRestartService
Forces node to start by skipping hot-restart completely and removing all hot-restart data even if node is still on validation phase or loading hot-restart data.
triggerForceStart() - Method in class com.hazelcast.hotrestart.NoopInternalHotRestartService
 
triggerPartialStart() - Method in interface com.hazelcast.hotrestart.InternalHotRestartService
Triggers partial start if the cluster cannot be started with full recovery and HotRestartPersistenceConfig.clusterDataRecoveryPolicy is set accordingly.
triggerPartialStart() - Method in class com.hazelcast.hotrestart.NoopInternalHotRestartService
 
TruePredicate<K,V> - Class in com.hazelcast.query
A Predicate which always returns true.
TruePredicate() - Constructor for class com.hazelcast.query.TruePredicate
 
truePredicate() - Static method in class com.hazelcast.query.TruePredicate
 
tryAcquire() - Method in interface com.hazelcast.core.ISemaphore
Acquires a permit, if one is available and returns immediately, with the value true, reducing the number of available permits by one.
tryAcquire(int) - Method in interface com.hazelcast.core.ISemaphore
Acquires the given number of permits, if they are available, and returns immediately, with the value true, reducing the number of available permits by the given amount.
tryAcquire(long, TimeUnit) - Method in interface com.hazelcast.core.ISemaphore
Acquires a permit from this semaphore if one becomes available within the given waiting time and the current thread has not been interrupted.
tryAcquire(int, long, TimeUnit) - Method in interface com.hazelcast.core.ISemaphore
Acquires the given number of permits if they are available and returns immediately with the value true, reducing the number of available permits by the given amount.
tryCloseConnections(HazelcastInstance) - Method in class com.hazelcast.core.OutOfMemoryHandler
Tries to close the server socket and connections to other HazelcastInstances.
tryCount - Variable in class com.hazelcast.spi.InvocationBuilder
 
tryLoadClass(String) - Static method in class com.hazelcast.nio.ClassLoaderUtil
Tries to load the given class.
tryLock() - Method in interface com.hazelcast.core.ILock
tryLock(long, TimeUnit) - Method in interface com.hazelcast.core.ILock
tryLock(long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.core.ILock
Tries to acquire the lock for the specified lease time.
tryLock(K) - Method in interface com.hazelcast.core.IMap
Tries to acquire the lock for the specified key.
tryLock(K, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Tries to acquire the lock for the specified key.
tryLock(K, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Tries to acquire the lock for the specified key for the specified lease time.
tryLock(K) - Method in interface com.hazelcast.core.MultiMap
Tries to acquire the lock for the specified key.
tryLock(K, long, TimeUnit) - Method in interface com.hazelcast.core.MultiMap
Tries to acquire the lock for the specified key.
tryLock(K, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.core.MultiMap
Tries to acquire the lock for the specified key for the specified lease time.
tryPauseMillis - Variable in class com.hazelcast.spi.InvocationBuilder
 
tryPut(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Tries to put the given key and value into this map within a specified timeout value.
tryRecover() - Method in interface com.hazelcast.map.QueryCache
This method can be used to recover from a possible event loss situation.
tryRemove(K, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Tries to remove the entry with the given key from this map within the specified timeout value.
trySetCount(int) - Method in interface com.hazelcast.core.ICountDownLatch
Sets the count to the given value if the current count is zero.
tryShutdown(HazelcastInstance) - Method in class com.hazelcast.core.OutOfMemoryHandler
Tries to shutdown HazelcastInstance forcefully; including closing sockets and connections, stopping threads, etc.
tx - Variable in class com.hazelcast.spi.TransactionalDistributedObject
 
typeConverter() - Method in interface com.hazelcast.config.properties.PropertyDefinition
The TypeConverter to be used to convert the string value read from XML to the expected type automatically.
typeConverter() - Method in class com.hazelcast.config.properties.SimplePropertyDefinition
 
TypeConverter - Interface in com.hazelcast.core
Implementations of this interface define a certain type conversation.
TypedByteArrayDeserializer<T> - Interface in com.hazelcast.nio.serialization
This interface allows deserialization of a binary data with a provided class type.
TypedDataSerializable - Interface in com.hazelcast.nio.serialization
This interface adds the possibility for the class to act as if it is another class when being deserialized using DataSerializable
TypedStreamDeserializer<T> - Interface in com.hazelcast.nio.serialization
This interface allows deserialization of a binary data with a provided class type.

U

unblacklist(Address) - Method in interface com.hazelcast.cluster.Joiner
Deprecated.
Removes an address from the blacklist if it is temporarily blacklisted.
UndefinedErrorCodeException - Exception in com.hazelcast.client
This exception is thrown when an exception that is coming from server is not recognized by the protocol.
UndefinedErrorCodeException(String, String) - Constructor for exception com.hazelcast.client.UndefinedErrorCodeException
 
UNKNOWN - Static variable in class com.hazelcast.version.MemberVersion
UNKNOWN version.
UNKNOWN - Static variable in class com.hazelcast.version.Version
Version 0.0 is UNKNOWN constant
UNKNOWN_VERSION - Static variable in class com.hazelcast.version.Version
Use 0 as major & minor values for UNKNOWN version
unlock() - Method in interface com.hazelcast.core.ILock
Releases the lock.
unlock(K) - Method in interface com.hazelcast.core.IMap
Releases the lock for the specified key.
unlock(K) - Method in interface com.hazelcast.core.MultiMap
Releases the lock for the specified key.
UNSAFE - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
GlobalMemoryAccessorRegistry.MEM instead
UNSAFE_AVAILABLE - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
GlobalMemoryAccessorRegistry.MEM_AVAILABLE instead
UnsafeHelper - Class in com.hazelcast.nio
Deprecated.
Use MemoryAccessor instead due to following reasons:

Deprecated to MemoryAccessor due to following reasons:

  • Preventing hard-dependency to Unsafe/
  • Some platforms (such as SPARC) don't support unaligned memory access. So on these platforms memory access alignments must be checked and handled if possible.

updateAdd(Object, Object) - Method in class com.hazelcast.wan.merkletree.ArrayMerkleTree
 
updateAdd(Object, Object) - Method in interface com.hazelcast.wan.merkletree.MerkleTree
Updating the tree with adding a new entry to the tree
updateRemove(Object, Object) - Method in class com.hazelcast.wan.merkletree.ArrayMerkleTree
 
updateRemove(Object, Object) - Method in interface com.hazelcast.wan.merkletree.MerkleTree
Updating the tree with removing an entry
updateReplace(Object, Object, Object) - Method in class com.hazelcast.wan.merkletree.ArrayMerkleTree
 
updateReplace(Object, Object, Object) - Method in interface com.hazelcast.wan.merkletree.MerkleTree
Updating the tree with replacing an old value with a new one
UrgentSystemOperation - Interface in com.hazelcast.spi
An Marker interface that signals that an operation is an urgent System Operation.
UrlXmlConfig - Class in com.hazelcast.config
A Config which is loaded using some url pointing to a Hazelcast XML file.
UrlXmlConfig(String) - Constructor for class com.hazelcast.config.UrlXmlConfig
Creates new Config which is loaded from the given url and uses the System.properties to replace variables in the XML.
UrlXmlConfig(String, Properties) - Constructor for class com.hazelcast.config.UrlXmlConfig
Creates new Config which is loaded from the given url.
UrlXmlConfig(URL) - Constructor for class com.hazelcast.config.UrlXmlConfig
Creates new Config which is loaded from the given url and uses the System.properties to replace variables in the XML.
UrlXmlConfig(URL, Properties) - Constructor for class com.hazelcast.config.UrlXmlConfig
Creates new Config which is loaded from the given url.
USE_LEGACY_MEMBER_LIST_FORMAT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Enables legacy (pre-3.9) member list format which is printed in logs.
UserCodeDeploymentConfig - Class in com.hazelcast.config
Configuration of User Code Deployment.
UserCodeDeploymentConfig() - Constructor for class com.hazelcast.config.UserCodeDeploymentConfig
 
UserCodeDeploymentConfig.ClassCacheMode - Enum in com.hazelcast.config
Controls caching of caches loaded from remote members
UserCodeDeploymentConfig.ProviderMode - Enum in com.hazelcast.config
Controls how to react on receiving a classloading request from a remote member
UserCodeDeploymentPermission - Class in com.hazelcast.security.permission
 
UserCodeDeploymentPermission(String...) - Constructor for class com.hazelcast.security.permission.UserCodeDeploymentPermission
 
UsernamePasswordCredentials - Class in com.hazelcast.security
Simple implementation of Credentials using username and password as security attributes.
UsernamePasswordCredentials() - Constructor for class com.hazelcast.security.UsernamePasswordCredentials
 
UsernamePasswordCredentials(String, String) - Constructor for class com.hazelcast.security.UsernamePasswordCredentials
 
UTF_8 - Static variable in class com.hazelcast.nio.Bits
A reusable instance of the UTF-8 charset
UTF_BUFFER_SIZE - Static variable in interface com.hazelcast.nio.BufferObjectDataInput
 
UTF_BUFFER_SIZE - Static variable in interface com.hazelcast.nio.BufferObjectDataOutput
 

V

validate() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
validate(T) - Method in interface com.hazelcast.config.properties.ValueValidator
Validates the given value according to the defined validation logic and throws a ValidationException if configuration does not meet the requirements or logical errors are spotted.
validateIndexAttribute(String) - Static method in class com.hazelcast.config.MapIndexConfig
Validates index attribute content.
validatesTarget() - Method in class com.hazelcast.spi.Operation
 
ValidationException - Exception in com.hazelcast.config.properties
This exception is thrown from ValueValidator implementations whenever the validation has not succeed for any reason.
ValidationException(String) - Constructor for exception com.hazelcast.config.properties.ValidationException
 
ValidationException(String, Throwable) - Constructor for exception com.hazelcast.config.properties.ValidationException
 
ValidationException(Throwable) - Constructor for exception com.hazelcast.config.properties.ValidationException
 
validator() - Method in interface com.hazelcast.config.properties.PropertyDefinition
Returns an optional validator to validate a value before finalizing the configuration.
validator() - Method in class com.hazelcast.config.properties.SimplePropertyDefinition
 
value - Variable in class com.hazelcast.core.EntryEvent
 
value() - Method in enum com.hazelcast.query.QueryConstants
 
ValueCallback<T> - Class in com.hazelcast.query.extractor
Enables notifying about values extracted in a ValueExtractor
ValueCallback() - Constructor for class com.hazelcast.query.extractor.ValueCallback
 
ValueCollector<T> - Class in com.hazelcast.query.extractor
Enables collecting values extracted in a ValueExtractor
ValueCollector() - Constructor for class com.hazelcast.query.extractor.ValueCollector
 
valueCount(K) - Method in interface com.hazelcast.core.BaseMultiMap
Returns the number of values matching the given key in the multimap.
valueCount(K) - Method in interface com.hazelcast.core.MultiMap
Returns the number of values that match the given key in the multimap.
valueCount(K) - Method in interface com.hazelcast.core.TransactionalMultiMap
Returns the number of values matching the given key in the multimap.
ValueExtractor<T,A> - Class in com.hazelcast.query.extractor
Common superclass for all extractors that enable the user to define custom attributes and extract their values.
ValueExtractor() - Constructor for class com.hazelcast.query.extractor.ValueExtractor
 
valueOf(String) - Static method in enum com.hazelcast.cache.BuiltInCacheMergePolicies
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.cache.CacheEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.client.config.ClientConnectionStrategyConfig.ReconnectMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.cluster.ClusterState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.cluster.MemberAttributeOperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.AbstractConfigBuilder.ConfigType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.CacheDeserializedValues
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.CacheEvictionConfig.CacheMaxSizePolicy
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.ConsistencyCheckStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.EvictionConfig.MaxSizePolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.EvictionPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.HotRestartClusterDataRecoveryPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.InMemoryFormat
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.MapStoreConfig.InitialLoadMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.MaxSizeConfig.MaxSizePolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.MultiMapConfig.ValueCollectionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.NativeMemoryConfig.MemoryAllocatorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.NearCacheConfig.LocalUpdatePolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.OnJoinPermissionOperationName
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.PartitionGroupConfig.MemberGroupType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.PermissionConfig.PermissionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.properties.PropertyTypeConverter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.UserCodeDeploymentConfig.ClassCacheMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.UserCodeDeploymentConfig.ProviderMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.WanAcknowledgeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.WanPublisherState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.WANQueueFullBehavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.core.ClientType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.core.DistributedObjectEvent.EventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.core.EntryEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.core.ItemEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.core.LifecycleEvent.LifecycleState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.core.MigrationEvent.MigrationStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.hotrestart.BackupTaskState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.mapreduce.JobPartitionState.State
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.mapreduce.TopologyChangedStrategy
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.memory.MemoryUnit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.nio.ConnectionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.nio.Packet.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.nio.serialization.DataType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.nio.serialization.FieldType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.nio.serialization.SerializableByConvention.Reason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.query.QueryConstants
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.quorum.QuorumType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.ringbuffer.OverflowPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.spi.discovery.integration.DiscoveryMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.spi.ExceptionAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.spi.partition.MigrationEndpoint
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.topic.TopicOverloadPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.wan.WanSyncStatus
Returns the enum constant of this type with the specified name.
ValueReader - Class in com.hazelcast.query.extractor
Enables reading the value of the attribute specified by the path
ValueReader() - Constructor for class com.hazelcast.query.extractor.ValueReader
 
ValueReadingException - Exception in com.hazelcast.query.extractor
Exception thrown if there is any checked or unchecked exception caught in the value reading in ValueReader
ValueReadingException(String, Throwable) - Constructor for exception com.hazelcast.query.extractor.ValueReadingException
 
values() - Static method in enum com.hazelcast.cache.BuiltInCacheMergePolicies
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.cache.CacheEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.client.config.ClientConnectionStrategyConfig.ReconnectMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.cluster.ClusterState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.cluster.MemberAttributeOperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.AbstractConfigBuilder.ConfigType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.CacheDeserializedValues
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.CacheEvictionConfig.CacheMaxSizePolicy
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.ConsistencyCheckStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.EvictionConfig.MaxSizePolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.EvictionPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.HotRestartClusterDataRecoveryPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.InMemoryFormat
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.MapStoreConfig.InitialLoadMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.MaxSizeConfig.MaxSizePolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.MultiMapConfig.ValueCollectionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.NativeMemoryConfig.MemoryAllocatorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.NearCacheConfig.LocalUpdatePolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.OnJoinPermissionOperationName
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.PartitionGroupConfig.MemberGroupType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.PermissionConfig.PermissionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.properties.PropertyTypeConverter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.UserCodeDeploymentConfig.ClassCacheMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.UserCodeDeploymentConfig.ProviderMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.WanAcknowledgeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.WanPublisherState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.WANQueueFullBehavior
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface com.hazelcast.core.BaseMap
Returns a collection clone of the values contained in this map.
values(Predicate) - Method in interface com.hazelcast.core.BaseMap
Queries the map based on the specified predicate and returns the values of matching entries.
values() - Static method in enum com.hazelcast.core.ClientType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.core.DistributedObjectEvent.EventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.core.EntryEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface com.hazelcast.core.IMap
Returns a collection clone of the values contained in this map.
values(Predicate) - Method in interface com.hazelcast.core.IMap
Queries the map based on the specified predicate and returns the values of matching entries.
values() - Static method in enum com.hazelcast.core.ItemEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.core.LifecycleEvent.LifecycleState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.core.MigrationEvent.MigrationStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface com.hazelcast.core.MultiMap
Returns the collection of values in the multimap.
values() - Method in interface com.hazelcast.core.ReplicatedMap
Returns a lazy Collection view of the values contained in this map.
A LazyCollection is optimized for querying speed (preventing eager deserialization and hashing on HashSet insertion) and does NOT provide all operations.
values(Comparator<V>) - Method in interface com.hazelcast.core.ReplicatedMap
Returns an eagerly populated Collection view of the values contained in this map.
values() - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.values().
values(Predicate) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.values(com.hazelcast.query.Predicate).
values() - Static method in enum com.hazelcast.hotrestart.BackupTaskState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface com.hazelcast.map.QueryCache
 
values(Predicate) - Method in interface com.hazelcast.map.QueryCache
 
values() - Static method in enum com.hazelcast.mapreduce.JobPartitionState.State
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.mapreduce.TopologyChangedStrategy
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.memory.MemoryUnit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.nio.ConnectionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.nio.Packet.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.nio.serialization.DataType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.nio.serialization.FieldType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.nio.serialization.SerializableByConvention.Reason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.query.QueryConstants
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.quorum.QuorumType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.ringbuffer.OverflowPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.spi.discovery.integration.DiscoveryMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.spi.ExceptionAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.spi.partition.MigrationEndpoint
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.topic.TopicOverloadPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.wan.WanSyncStatus
Returns an array containing the constants of this enum type, in the order they are declared.
ValueValidator<T extends Comparable<T>> - Interface in com.hazelcast.config.properties
This interface defines a certain validation logic implementation to test if a given value is expected to be correct or not.
verify() - Method in class com.hazelcast.config.JoinConfig
Verifies this JoinConfig is valid.
VERSION - Static variable in class com.hazelcast.nio.Packet
 
Version - Class in com.hazelcast.version
A generic version to be used with VersionAware classes.
Version() - Constructor for class com.hazelcast.version.Version
 
VERSION_CHECK_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
VersionAware - Interface in com.hazelcast.nio
Enables getting the version from the implementing object.
VersionedPortable - Interface in com.hazelcast.nio.serialization
VersionedPortable is an extension to Portable to support per class version instead of a global serialization version.
VisitablePredicate - Interface in com.hazelcast.query
Predicates which can be visited by optimizer.

W

WAIT - Static variable in class com.hazelcast.spi.CallStatus
Indicates that the call could not complete because waiting is required.
WAIT_ORDINAL - Static variable in class com.hazelcast.spi.CallStatus
The ordinal value for a CallStatus.WAIT.
WAIT_SECONDS_BEFORE_JOIN - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
WaitNotifyKey - Interface in com.hazelcast.spi
A key for a wait notify object e.g.
waitPartitionReplicaSyncOnCluster(long, TimeUnit) - Method in interface com.hazelcast.hotrestart.InternalHotRestartService
Waits until partition replicas (primaries and backups) get in sync.
waitPartitionReplicaSyncOnCluster(long, TimeUnit) - Method in class com.hazelcast.hotrestart.NoopInternalHotRestartService
 
WAN_CONSUMER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
WAN_PUBLISHER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
WAN_REPLICATION_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
WAN_SYNC_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
WanAcknowledgeType - Enum in com.hazelcast.config
Determines acknowledge waiting type of wan replication operation invocation.
WanConsumerConfig - Class in com.hazelcast.config
Config for processing WAN events received from a target cluster.
WanConsumerConfig() - Constructor for class com.hazelcast.config.WanConsumerConfig
 
WanPublisherConfig - Class in com.hazelcast.config
Configuration object for a WAN publisher.
WanPublisherConfig() - Constructor for class com.hazelcast.config.WanPublisherConfig
 
WanPublisherState - Enum in com.hazelcast.config
Defines the state in which a WAN publisher can be in if it is not shutting down.
WANQueueFullBehavior - Enum in com.hazelcast.config
Determines the behavior of WAN replication impl.
WanReplicationConfig - Class in com.hazelcast.config
Configuration for WAN replication.
WanReplicationConfig() - Constructor for class com.hazelcast.config.WanReplicationConfig
 
WanReplicationEndpoint - Interface in com.hazelcast.wan
Implementations of this interface represent a replication endpoint, normally another Hazelcast cluster only reachable over a wide area network.
WanReplicationEvent - Class in com.hazelcast.wan
Event class used to transmit the actual event object
WanReplicationEvent() - Constructor for class com.hazelcast.wan.WanReplicationEvent
 
WanReplicationEvent(String, ReplicationEventObject) - Constructor for class com.hazelcast.wan.WanReplicationEvent
 
WanReplicationPublisher - Interface in com.hazelcast.wan
This interface offers the implementation of different kinds of replication techniques like TCP, UDP or maybe even an JMS based service
WANReplicationQueueFullException - Exception in com.hazelcast.wan
A HazelcastException that is thrown when the wan replication queues are full This exception is only thrown when WAN is configured with WANQueueFullBehavior.THROW_EXCEPTION
WANReplicationQueueFullException(String) - Constructor for exception com.hazelcast.wan.WANReplicationQueueFullException
 
WanReplicationRef - Class in com.hazelcast.config
Configuration for a WAN target replication reference.
WanReplicationRef() - Constructor for class com.hazelcast.config.WanReplicationRef
 
WanReplicationRef(WanReplicationRef) - Constructor for class com.hazelcast.config.WanReplicationRef
 
WanReplicationRef(String, String, List<String>, boolean) - Constructor for class com.hazelcast.config.WanReplicationRef
 
WanReplicationRefReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
WanReplicationRefReadOnly(WanReplicationRef) - Constructor for class com.hazelcast.config.WanReplicationRefReadOnly
Deprecated.
 
WanReplicationService - Interface in com.hazelcast.wan
This is the WAN replications service API core interface.
WanSyncConfig - Class in com.hazelcast.config
Configuration object for the WAN sync mechanism.
WanSyncConfig() - Constructor for class com.hazelcast.config.WanSyncConfig
 
WanSyncState - Interface in com.hazelcast.monitor
Local WAN sync statistics to be used by MemberState implementations.
WanSyncStats - Interface in com.hazelcast.wan
WAN Synchronization statistics
WanSyncStatus - Enum in com.hazelcast.wan
WanSyncStatus shows the current status of WAN sync.
warning(String) - Method in class com.hazelcast.logging.AbstractLogger
 
warning(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
warning(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
warning(String) - Method in interface com.hazelcast.logging.ILogger
Logs a message at the Level.WARNING level.
warning(Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a throwable at the Level.WARNING level.
warning(String, Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a message with an associated throwable at the Level.WARNING level.
WildcardConfigPatternMatcher - Class in com.hazelcast.config.matcher
This ConfigPatternMatcher supports a simplified wildcard matching.
WildcardConfigPatternMatcher() - Constructor for class com.hazelcast.config.matcher.WildcardConfigPatternMatcher
 
withAcceptableHeartbeatPauseMillis(long) - Method in class com.hazelcast.config.ProbabilisticQuorumConfigBuilder
Duration in milliseconds corresponding to number of potentially lost/delayed heartbeats that will be accepted before considering it to be an anomaly.
withHeartbeatIntervalMillis(long) - Method in class com.hazelcast.config.ProbabilisticQuorumConfigBuilder
Bootstrap the stats with heartbeats that corresponds to this duration in milliseconds, with a rather high standard deviation (since environment is unknown in the beginning).
withMaxSampleSize(int) - Method in class com.hazelcast.config.ProbabilisticQuorumConfigBuilder
Number of samples to use for calculation of mean and standard deviation of inter-arrival times.
withMinStdDeviationMillis(long) - Method in class com.hazelcast.config.ProbabilisticQuorumConfigBuilder
Minimum standard deviation (in milliseconds) to use for the normal distribution used when calculating phi.
withQuorumSize(int) - Method in class com.hazelcast.config.QuorumConfigBuilder
 
withSuspicionThreshold(double) - Method in class com.hazelcast.config.ProbabilisticQuorumConfigBuilder
Threshold for suspicion (φ) level.
write(int, int) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
write(OutboundFrame) - Method in interface com.hazelcast.nio.Connection
Writes a outbound frame so it can be received by the other side of the connection.
write(T) - Method in interface com.hazelcast.nio.serialization.ByteArraySerializer
Converts given object to byte array
write(ObjectDataOutput, T) - Method in interface com.hazelcast.nio.serialization.StreamSerializer
This method writes object to ObjectDataOutput
writeAttributeValue(Object, ObjectDataOutput) - Static method in class com.hazelcast.nio.IOUtil
 
writeBoolean(int, boolean) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeBoolean(String, boolean) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive boolean.
writeBooleanArray(boolean[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeBooleanArray(String, boolean[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive boolean-array.
writeByte(int, int) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeByte(String, byte) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive byte.
writeByteArray(ObjectDataOutput, byte[]) - Static method in class com.hazelcast.nio.IOUtil
 
writeByteArray(byte[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeByteArray(String, byte[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive byte-array.
writeChar(byte[], int, char, boolean) - Static method in class com.hazelcast.nio.Bits
 
writeChar(int, int) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeChar(String, int) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive char.
writeCharArray(char[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeCharArray(String, char[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive char-array.
writeCharB(byte[], int, char) - Static method in class com.hazelcast.nio.Bits
 
writeCharL(byte[], int, char) - Static method in class com.hazelcast.nio.Bits
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.AtomicLongConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.AtomicReferenceConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CollectionConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CountDownLatchConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.DurableExecutorConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.EntryListenerConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.EventJournalConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.EvictionConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ExecutorConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.HotRestartConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ItemListenerConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.LegacyCacheConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.LegacyCacheEvictionConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ListenerConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.LockConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MapAttributeConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MapConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MapIndexConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MapStoreConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MaxSizeConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MergePolicyConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MerkleTreeConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MultiMapConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.NearCacheConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.PNCounterConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.PredicateConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.QueryCacheConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.QueueConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.QueueStoreConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.QuorumConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ReliableTopicConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ReplicatedMapConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.RingbufferConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.SemaphoreConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.TopicConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanConsumerConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanPublisherConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanReplicationConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanReplicationRef
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanSyncConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.console.Echo
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.core.MemberAttributeEvent
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.core.MigrationEvent
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.core.PartitionAwareKey
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.eviction.LFUEvictionPolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.eviction.LRUEvictionPolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.eviction.RandomEvictionPolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.merge.HigherHitsMapMergePolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.merge.IgnoreMergingEntryMapMergePolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.merge.LatestUpdateMapMergePolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.merge.PassThroughMergePolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.merge.PutIfAbsentMapMergePolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.nio.Address
 
writeData(Data) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeData(ObjectDataOutput) - Method in interface com.hazelcast.nio.serialization.DataSerializable
Writes object fields to output stream
writeData(ObjectDataOutput) - Method in class com.hazelcast.partition.PartitionLostEvent
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.PagingPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.PartitionPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.PredicateBuilder
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.SqlPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.TruePredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.merge.HigherHitsMapMergePolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.merge.LatestUpdateMapMergePolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.merge.PassThroughMergePolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.merge.PutIfAbsentMapMergePolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.DefaultObjectNamespace
Deprecated.
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.DistributedObjectNamespace
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.Operation
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.OperationControl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.partition.IPartitionLostEvent
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.transaction.TransactionOptions
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.version.MemberVersion
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.version.Version
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.wan.WanReplicationEvent
 
writeDouble(int, double) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeDouble(double, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeDouble(int, double, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeDouble(String, double) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive double.
writeDoubleArray(double[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeDoubleArray(String, double[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive double array.
writeFactories(ObjectDataOutput) - Method in class com.hazelcast.config.CacheConfig
 
writeFloat(int, float) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeFloat(float, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeFloat(int, float, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeFloat(String, float) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive float.
writeFloatArray(float[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeFloatArray(String, float[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive float array.
writeInt(byte[], int, int, boolean) - Static method in class com.hazelcast.nio.Bits
 
writeInt(int, int) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeInt(int, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeInt(int, int, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeInt(String, int) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive int.
writeIntArray(int[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeIntArray(String, int[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive int-array.
writeIntB(byte[], int, int) - Static method in class com.hazelcast.nio.Bits
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.crdt.AbstractCRDTReplicationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.spi.AbstractLocalOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.spi.Operation
 
writeIntL(byte[], int, int) - Static method in class com.hazelcast.nio.Bits
 
writeKeyValueTypes(ObjectDataOutput) - Method in class com.hazelcast.config.CacheConfig
 
writeLeaves(DataOutput, MerkleTreeView) - Static method in class com.hazelcast.wan.merkletree.MerkleTreeUtil
Writes the hashes of the leaves of a Merkle tree into the provided DataOutput
writeListenerConfigurations(ObjectDataOutput) - Method in class com.hazelcast.config.CacheConfig
 
writeLong(byte[], int, long, boolean) - Static method in class com.hazelcast.nio.Bits
 
writeLong(int, long) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeLong(long, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeLong(int, long, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeLong(String, long) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive long.
writeLongArray(long[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeLongArray(String, long[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive long-array.
writeLongB(byte[], int, long) - Static method in class com.hazelcast.nio.Bits
 
writeLongL(byte[], int, long) - Static method in class com.hazelcast.nio.Bits
 
writeNullPortable(String, int, int) - Method in interface com.hazelcast.nio.serialization.PortableWriter
To write a null portable value, user needs to provide class and factoryIds of related class.
writeObject(ObjectDataOutput, Object) - Static method in class com.hazelcast.nio.IOUtil
 
writeObject(Object) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writePortable(PortableWriter) - Method in interface com.hazelcast.nio.serialization.Portable
Serialize this portable object using PortableWriter
writePortable(String, Portable) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a Portable.
writePortable(PortableWriter) - Method in class com.hazelcast.security.AbstractCredentials
 
writePortableArray(String, Portable[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a an array of Portables.
writePortableInternal(PortableWriter) - Method in class com.hazelcast.security.AbstractCredentials
 
writePortableInternal(PortableWriter) - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
writeShort(byte[], int, short, boolean) - Static method in class com.hazelcast.nio.Bits
 
writeShort(int, int) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeShort(int, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeShort(int, int, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeShort(String, short) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive short.
writeShortArray(short[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeShortArray(String, short[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive short-array.
writeShortB(byte[], int, short) - Static method in class com.hazelcast.nio.Bits
 
writeShortL(byte[], int, short) - Static method in class com.hazelcast.nio.Bits
 
writeTo(MigrationEvent.MigrationStatus, DataOutput) - Static method in enum com.hazelcast.core.MigrationEvent.MigrationStatus
 
writeTo(Packet, ByteBuffer) - Method in class com.hazelcast.nio.PacketIOHelper
Writes the packet data to the supplied ByteBuffer, up to the buffer's limit.
writeTo(MigrationEndpoint, DataOutput) - Static method in enum com.hazelcast.spi.partition.MigrationEndpoint
 
writeUTF(String, String) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes an UTF string.
writeUtf8Char(byte[], int, int) - Static method in class com.hazelcast.nio.Bits
 
writeUTFArray(String[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeUTFArray(String, String[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a String-array.
writeZeroBytes(int) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
WrongTargetException - Exception in com.hazelcast.spi.exception
A RetryableHazelcastException indicating that an operation is executed on the wrong machine.
WrongTargetException(Address, Address, int, int, String) - Constructor for exception com.hazelcast.spi.exception.WrongTargetException
 
WrongTargetException(Address, Address, int, int, String, String) - Constructor for exception com.hazelcast.spi.exception.WrongTargetException
 
WrongTargetException(String) - Constructor for exception com.hazelcast.spi.exception.WrongTargetException
 

X

XmlClientConfigBuilder - Class in com.hazelcast.client.config
Loads the ClientConfig using XML.
XmlClientConfigBuilder(String) - Constructor for class com.hazelcast.client.config.XmlClientConfigBuilder
 
XmlClientConfigBuilder(File) - Constructor for class com.hazelcast.client.config.XmlClientConfigBuilder
 
XmlClientConfigBuilder(URL) - Constructor for class com.hazelcast.client.config.XmlClientConfigBuilder
 
XmlClientConfigBuilder(InputStream) - Constructor for class com.hazelcast.client.config.XmlClientConfigBuilder
 
XmlClientConfigBuilder() - Constructor for class com.hazelcast.client.config.XmlClientConfigBuilder
Loads the client config using the following resolution mechanism: first it checks if a system property 'hazelcast.client.config' is set.
XmlClientConfigLocator - Class in com.hazelcast.client.config
A support class for the XmlClientConfigBuilder to locate the client xml configuration.
XmlClientConfigLocator() - Constructor for class com.hazelcast.client.config.XmlClientConfigLocator
Constructs a XmlClientConfigBuilder.
XmlConfigBuilder - Class in com.hazelcast.config
A XML ConfigBuilder implementation.
XmlConfigBuilder(String) - Constructor for class com.hazelcast.config.XmlConfigBuilder
Constructs a XmlConfigBuilder that reads from the provided XML file.
XmlConfigBuilder(InputStream) - Constructor for class com.hazelcast.config.XmlConfigBuilder
Constructs a XmlConfigBuilder that reads from the given InputStream.
XmlConfigBuilder(URL) - Constructor for class com.hazelcast.config.XmlConfigBuilder
Constructs a XMLConfigBuilder that reads from the given URL.
XmlConfigBuilder() - Constructor for class com.hazelcast.config.XmlConfigBuilder
Constructs a XmlConfigBuilder that tries to find a usable XML configuration file.
XmlConfigLocator - Class in com.hazelcast.config
Support class for the XmlConfigBuilder that locates the XML configuration: system property working directory classpath default
XmlConfigLocator() - Constructor for class com.hazelcast.config.XmlConfigLocator
Constructs a XmlConfigLocator that tries to find a usable XML configuration file.
XmlGenerator(StringBuilder) - Constructor for class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
xmlToJavaName(String) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 

Z

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

Copyright © 2019 Hazelcast, Inc.. All Rights Reserved.