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

A

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
 
AbstractClusterLoginConfig<T extends AbstractClusterLoginConfig<T>> - Class in com.hazelcast.config.security
 
AbstractClusterLoginConfig() - Constructor for class com.hazelcast.config.security.AbstractClusterLoginConfig
 
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
 
AbstractFactoryWithPropertiesConfig<T extends AbstractFactoryWithPropertiesConfig<T>> - Class in com.hazelcast.config
Configuration base for config types with a factory class and its properties.
AbstractFactoryWithPropertiesConfig() - Constructor for class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
 
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.map
The abstract class for a map event IMapEvent.
AbstractIMapEvent(Object, Member, int) - Constructor for class com.hazelcast.map.AbstractIMapEvent
Constructs a prototypical map Event.
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
 
AbstractSymmetricEncryptionConfig<T extends AbstractSymmetricEncryptionConfig> - Class in com.hazelcast.config
Base class for symmetric encryption configuration classes.
AbstractSymmetricEncryptionConfig() - Constructor for class com.hazelcast.config.AbstractSymmetricEncryptionConfig
 
AbstractWanPublisherConfig - Class in com.hazelcast.config
Base class for WAN publisher configuration.
AbstractWanPublisherConfig() - Constructor for class com.hazelcast.config.AbstractWanPublisherConfig
 
AbstractXmlConfigBuilder - Class in com.hazelcast.config
Contains logic for replacing system variables in the XML file and importing XML files from different locations.
AbstractXmlConfigBuilder() - Constructor for class com.hazelcast.config.AbstractXmlConfigBuilder
 
AbstractXmlConfigBuilder.ConfigType - Enum in com.hazelcast.config
 
AbstractXmlConfigHelper - Class in com.hazelcast.config
Contains Hazelcast XML Configuration helper methods and variables.
AbstractXmlConfigHelper() - Constructor for class com.hazelcast.config.AbstractXmlConfigHelper
 
AbstractYamlConfigBuilder - Class in com.hazelcast.config
Contains logic for replacing system variables in the YAML file and importing YAML files from different locations.
AbstractYamlConfigBuilder() - Constructor for class com.hazelcast.config.AbstractYamlConfigBuilder
 
accept(T, U) - Method in interface com.hazelcast.function.BiConsumerEx
 
accept(T) - Method in interface com.hazelcast.function.ConsumerEx
 
acceptEx(T, U) - Method in interface com.hazelcast.function.BiConsumerEx
Exception-declaring version of BiConsumer.accept(T, U).
acceptEx(T) - Method in interface com.hazelcast.function.ConsumerEx
Exception-declaring version of Consumer.accept(T)
accumulate(I) - Method in interface com.hazelcast.aggregation.Aggregator
Accumulates the given entries.
acquire() - Method in interface com.hazelcast.cp.ISemaphore
Acquires a permit if one is available, and returns immediately, reducing the number of available permits by one.
acquire(int) - Method in interface com.hazelcast.cp.ISemaphore
Acquires the given number of permits if they are available, and returns immediately, reducing the number of available permits by the given amount.
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(CompletionStage<E>) - Method in class com.hazelcast.core.Pipelining
Adds a future to this Pipelining or blocks until there is capacity to add the future to the Pipelining.
add(E) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Adds an item to the tail of the Ringbuffer.
add(Permission) - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
add(Permission) - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
 
add(PermissionCollection) - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
 
add(Permission) - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
 
add(Object) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Adds an item to the tail of the ringbuffer.
add(E) - Method in interface com.hazelcast.transaction.TransactionalList
Adds a new item to the transactional list.
add(E) - Method in interface com.hazelcast.transaction.TransactionalSet
Add new item to transactional set.
addAction(String) - Method in class com.hazelcast.config.PermissionConfig
 
addAddress(String...) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Adds given addresses to candidate address list that client will use to establish initial connection
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.cp.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.
addAndGetAsync(long) - Method in interface com.hazelcast.cp.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.
addAttribute(String) - Method in class com.hazelcast.config.IndexConfig
Adds an index attribute with the given.
addAttributeConfig(AttributeConfig) - Method in class com.hazelcast.config.MapConfig
 
addAttributeInternal(String) - Method in class com.hazelcast.config.IndexConfig
 
addBatchReplicationPublisherConfig(WanBatchPublisherConfig) - Method in class com.hazelcast.config.WanReplicationConfig
Adds a WAN publisher configuration using the built-in batching WAN implementation to this WAN replication.
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 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.
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
 
addClientConfig(ClientConfig) - Method in class com.hazelcast.client.config.ClientFailoverConfig
Adds the client config to the end of the alternative client configurations list.
addClientListener(ClientListener) - Method in interface com.hazelcast.client.ClientService
Adds a ClientListener.
addClientPermissionConfig(PermissionConfig) - Method in class com.hazelcast.config.SecurityConfig
 
addCustomPublisherConfig(WanCustomPublisherConfig) - Method in class com.hazelcast.config.WanReplicationConfig
Adds a custom WAN publisher implementation configuration to this WAN replication.
addDataSerializableFactory(int, DataSerializableFactory) - Method in class com.hazelcast.config.SerializationConfig
 
addDataSerializableFactoryClass(int, String) - Method in class com.hazelcast.config.SerializationConfig
 
addDataSerializableFactoryClass(int, Class<? extends DataSerializableFactory>) - Method in class com.hazelcast.config.SerializationConfig
 
addDirectoryConfig(PersistentMemoryDirectoryConfig) - Method in class com.hazelcast.config.PersistentMemoryConfig
Adds the persistent memory directory configuration to be used to store memory structures allocated by native memory manager.
addDiscoveryStrategyConfig(DiscoveryStrategyConfig) - Method in class com.hazelcast.config.DiscoveryConfig
Adds an enabled DiscoveryStrategy configuration.
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.map.IMap
Adds a MapListener for this map.
addEntryListener(MapListener, K, boolean) - Method in interface com.hazelcast.map.IMap
Adds a MapListener for this map.
addEntryListener(MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.map.IMap
Adds a MapListener for this map.
addEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.map.IMap
Adds a MapListener 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
 
addEntryListener(EntryListener<K, V>, boolean) - Method in interface com.hazelcast.multimap.MultiMap
Adds an entry listener for this multimap.
addEntryListener(EntryListener<K, V>, K, boolean) - Method in interface com.hazelcast.multimap.MultiMap
Adds the specified entry listener for the specified key.
addEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Adds an entry listener for this map.
addEntryListener(EntryListener<K, V>, K) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Adds the specified entry listener for the specified key.
addEntryListener(EntryListener<K, V>, Predicate<K, V>) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Adds an continuous entry listener for this map.
addEntryListener(EntryListener<K, V>, Predicate<K, V>, K) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Adds an continuous entry listener for this map.
addEntryListenerConfig(CacheSimpleEntryListenerConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MapConfig
 
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MultiMapConfig
Adds an entry listener to this MultiMap (listens for when entries are added or removed).
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.QueryCacheConfig
Adds EntryListenerConfig to this QueryCacheConfig.
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.ReplicatedMapConfig
 
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.
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
 
addGroupAvailabilityListener(CPGroupAvailabilityListener) - Method in interface com.hazelcast.cp.CPSubsystem
Registers a new CPGroupAvailabilityListener to listen CP group availability changes.
addIndex(IndexType, String...) - Method in interface com.hazelcast.map.IMap
Convenient method to add an index to this map with the given type and attributes.
addIndex(IndexConfig) - Method in interface com.hazelcast.map.IMap
Adds an index to this map for the specified entries so that queries can run faster.
addIndex(IndexType, String...) - Method in interface com.hazelcast.map.QueryCache
 
addIndex(IndexConfig) - Method in interface com.hazelcast.map.QueryCache
 
addIndexConfig(IndexConfig) - Method in class com.hazelcast.config.MapConfig
 
addIndexConfig(IndexConfig) - Method in class com.hazelcast.config.QueryCacheConfig
 
addIntArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addInterceptor(MapInterceptor) - Method in interface com.hazelcast.map.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.collection.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.QueueConfig
Add an item listener configuration to this queue.
addJar(String) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
String jarPath is searched in following order: 1.
addJar(File) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
addLabel(String) - Method in class com.hazelcast.client.config.ClientConfig
Adds a label for this client Client available
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(SplitBrainProtectionListenerConfig) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
addLocalEntryListener(MapListener) - Method in interface com.hazelcast.map.IMap
Adds a MapListener for this map.
addLocalEntryListener(MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.map.IMap
Adds a MapListener for this map.
addLocalEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.map.IMap
Adds a local entry listener for this map.
addLocalEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.multimap.MultiMap
Adds a local entry listener for this multimap.
addLockConfig(FencedLockConfig) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Adds the FencedLock configuration.
addLoginModuleConfig(LoginModuleConfig) - Method in class com.hazelcast.config.security.JaasAuthenticationConfig
 
addLogListener(Level, LogListener) - Method in interface com.hazelcast.logging.LoggingService
 
addLongArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addLongField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addMapConfig(MapConfig) - Method in class com.hazelcast.config.Config
Adds the map configuration.
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 interface com.hazelcast.spi.partitiongroup.MemberGroup
 
addMemberGroupConfig(MemberGroupConfig) - Method in class com.hazelcast.config.PartitionGroupConfig
addMembers(Collection<Member>) - Method in interface com.hazelcast.spi.partitiongroup.MemberGroup
 
addMembershipListener(MembershipListener) - Method in interface com.hazelcast.cluster.Cluster
Adds MembershipListener to listen for membership updates.
addMembershipListener(CPMembershipListener) - Method in interface com.hazelcast.cp.CPSubsystem
Registers a new CPMembershipListener to listen CP membership changes.
addMessageListener(MessageListener<E>) - Method in interface com.hazelcast.topic.ITopic
Subscribes to this topic.
addMessageListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.ReliableTopicConfig
Adds a message listener (listens for when messages are added or removed) to this reliable topic.
addMessageListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.TopicConfig
Adds a message listener to this topic (listens for when messages are added or removed).
addMigrationListener(MigrationListener) - Method in interface com.hazelcast.partition.PartitionService
Adds a MigrationListener.
addMultiMapConfig(MultiMapConfig) - Method in class com.hazelcast.config.Config
Adds the multimap configuration.
addNearCacheConfig(NearCacheConfig) - Method in class com.hazelcast.client.config.ClientConfig
Helper method to add a new NearCacheConfig
addObject(T) - Method in interface com.hazelcast.query.extractor.ValueCollector
Collects a value passed as an argument
addOutboundPort(int) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Add outbound port to the outbound port list
addOutboundPort(int) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
addOutboundPort(int) - Method in class com.hazelcast.config.EndpointConfig
 
addOutboundPort(int) - Method in class com.hazelcast.config.NetworkConfig
 
addOutboundPort(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
addOutboundPortDefinition(String) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Add outbound port definition to the outbound port definition list
addOutboundPortDefinition(String) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
addOutboundPortDefinition(String) - Method in class com.hazelcast.config.EndpointConfig
 
addOutboundPortDefinition(String) - Method in class com.hazelcast.config.NetworkConfig
 
addOutboundPortDefinition(String) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
addPackages(String...) - Method in class com.hazelcast.config.ClassFilter
 
addParameter(String, Object) - Method in interface com.hazelcast.auditlog.EventBuilder
Adds single event parameter to the parameters Map.
addParameter(Object) - Method in class com.hazelcast.sql.SqlStatement
Adds a single parameter to the end of the parameters list.
addPartitionLostListener(CachePartitionLostListener) - Method in interface com.hazelcast.cache.ICache
Adds a CachePartitionLostListener.
addPartitionLostListener(MapPartitionLostListener) - Method in interface com.hazelcast.map.IMap
Adds a MapPartitionLostListener.
addPartitionLostListener(PartitionLostListener) - Method in interface com.hazelcast.partition.PartitionService
Adds a PartitionLostListener.
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
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.
addRealmConfig(String, RealmConfig) - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
addRealmConfig(String, RealmConfig) - Method in class com.hazelcast.config.SecurityConfig
 
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.cluster
Represents an address of a member in the cluster.
Address() - Constructor for class com.hazelcast.cluster.Address
 
Address(String, int) - Constructor for class com.hazelcast.cluster.Address
 
Address(InetAddress, int) - Constructor for class com.hazelcast.cluster.Address
 
Address(InetSocketAddress) - Constructor for class com.hazelcast.cluster.Address
Creates a new Address
Address(String, InetAddress, int) - Constructor for class com.hazelcast.cluster.Address
 
Address(Address) - Constructor for class com.hazelcast.cluster.Address
 
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.cp.CPSubsystemConfig
Adds the CP ISemaphore configuration.
addSerializerConfig(SerializerConfig) - Method in class com.hazelcast.config.SerializationConfig
 
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
 
addSplitBrainProtectionConfig(SplitBrainProtectionConfig) - Method in class com.hazelcast.config.Config
Adds the split-brain protection configuration.
addTopicConfig(TopicConfig) - Method in class com.hazelcast.config.Config
Adds the topic configuration.
addTrustedInterface(String) - Method in class com.hazelcast.config.ManagementCenterConfig
Adds a trusted interface.
addTrustedInterface(String) - Method in class com.hazelcast.config.MulticastConfig
Adds a trusted interface.
addTrustedInterface(String) - Method in interface com.hazelcast.config.TrustedInterfacesConfigurable
Adds trusted interface (i.e.
addUTFArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addUTFField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addWanEndpointConfig(EndpointConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
Adds the given WAN EndpointConfig to the endpoints configuration.
addWanReplicationConfig(WanReplicationConfig) - Method in class com.hazelcast.config.Config
Adds the WAN replication config under the name defined by WanReplicationConfig.getName().
AdvancedNetworkConfig - Class in com.hazelcast.config
Similar to NetworkConfig with the additional ability to define multiple endpoints, each with its own separate protocol/security and/or socket properties.
AdvancedNetworkConfig() - Constructor for class com.hazelcast.config.AdvancedNetworkConfig
 
AdvancedNetworkConfig.MemberNetworkingView - Class in com.hazelcast.config
Member endpoint decorated as a NetworkConfig Facade used during bootstrap to hide if-logic between the two networking configuration approaches
after(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.
aggregate() - Method in interface com.hazelcast.aggregation.Aggregator
Returns the result of the aggregation.
aggregate(Aggregator<? super Map.Entry<K, V>, R>) - Method in interface com.hazelcast.map.IMap
Applies the aggregation logic on all map entries and returns the result
aggregate(Aggregator<? super Map.Entry<K, V>, R>, Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
Applies the aggregation logic on map entries filtered with the Predicated and returns the result
AGGREGATION_ACCUMULATION_PARALLEL_EVALUATION - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Run aggregation accumulation for multiple entries in parallel.
Aggregator<I,R> - Interface in com.hazelcast.aggregation
Defines a contract for all aggregators.
Aggregators - Class in com.hazelcast.aggregation
A utility class to create basic Aggregator instances.
AliasedDiscoveryConfig<T extends AliasedDiscoveryConfig<T>> - Class in com.hazelcast.config
Configuration for discovery strategy aliases, e.g.
AliasedDiscoveryConfig(String) - Constructor for class com.hazelcast.config.AliasedDiscoveryConfig
 
AliasedDiscoveryConfig(AliasedDiscoveryConfig) - Constructor for class com.hazelcast.config.AliasedDiscoveryConfig
 
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
 
allReplicasInPartitionLost() - Method in interface com.hazelcast.partition.PartitionLostEvent
Returns true if all replicas of a partition are lost
alter(IFunction<Long, Long>) - Method in interface com.hazelcast.cp.IAtomicLong
Alters the currently stored value by applying a function on it.
alter(IFunction<E, E>) - Method in interface com.hazelcast.cp.IAtomicReference
Alters the currently stored reference by applying a function on it.
alterAndGet(IFunction<Long, Long>) - Method in interface com.hazelcast.cp.IAtomicLong
Alters the currently stored value by applying a function on it and gets the result.
alterAndGet(IFunction<E, E>) - Method in interface com.hazelcast.cp.IAtomicReference
Alters the currently stored reference by applying a function on it and gets the result.
alterAndGetAsync(IFunction<Long, Long>) - Method in interface com.hazelcast.cp.IAtomicLong
Alters the currently stored value by applying a function on it and gets the result.
alterAndGetAsync(IFunction<E, E>) - Method in interface com.hazelcast.cp.IAtomicReference
Alters the currently stored reference by applying a function on it and gets the result.
alterAsync(IFunction<Long, Long>) - Method in interface com.hazelcast.cp.IAtomicLong
Alters the currently stored value by applying a function on it.
alterAsync(IFunction<E, E>) - Method in interface com.hazelcast.cp.IAtomicReference
Alters the currently stored reference by applying a function on it.
alwaysFalse() - Static method in interface com.hazelcast.function.PredicateEx
Returns a predicate that always evaluates to false.
alwaysFalse() - Static method in class com.hazelcast.query.Predicates
Creates an always false predicate that will filter out all items.
alwaysTrue() - Static method in interface com.hazelcast.function.PredicateEx
Returns a predicate that always evaluates to true.
alwaysTrue() - Static method in class com.hazelcast.query.Predicates
Creates an always true predicate that will pass all items.
and(MemberSelector...) - Static method in class com.hazelcast.cluster.memberselector.MemberSelectors
Selects a member when all of the selectors succeed
and(BiPredicateEx<? super T, ? super U>) - Method in interface com.hazelcast.function.BiPredicateEx
and(PredicateEx<? super T>) - Method in interface com.hazelcast.function.PredicateEx
and(Predicate) - Method in interface com.hazelcast.query.PredicateBuilder
 
and(Predicate...) - Static method in class com.hazelcast.query.Predicates
Creates an and predicate that will perform the logical and operation on the given predicates.
andThen(BiConsumerEx<? super T, ? super U>) - Method in interface com.hazelcast.function.BiConsumerEx
andThen(FunctionEx<? super R, ? extends V>) - Method in interface com.hazelcast.function.BiFunctionEx
andThen(ConsumerEx<? super T>) - Method in interface com.hazelcast.function.ConsumerEx
andThen(FunctionEx<? super R, ? extends V>) - Method in interface com.hazelcast.function.FunctionEx
appendLabels(Set<String>) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
appendProperties(Properties) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
appendProperties(Map<String, ? extends Comparable>) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
appendToken(StringBuilder, StringBuilder) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
apply(T) - Method in interface com.hazelcast.core.IFunction
 
apply(IFunction<Long, R>) - Method in interface com.hazelcast.cp.IAtomicLong
Applies a function on the value, the actual stored value will not change.
apply(IFunction<E, R>) - Method in interface com.hazelcast.cp.IAtomicReference
Applies a function on the value, the actual stored value will not change.
apply(T, U) - Method in interface com.hazelcast.function.BiFunctionEx
 
apply(T, T) - Method in interface com.hazelcast.function.BinaryOperatorEx
 
apply(T) - Method in interface com.hazelcast.function.FunctionEx
 
apply(Map.Entry<K, V>) - Method in interface com.hazelcast.query.Predicate
Applies this predicate to the given map entry.
apply(Collection<Member>) - Method in interface com.hazelcast.splitbrainprotection.SplitBrainProtectionFunction
Determines whether the minimum cluster size property is satisfied based on the current list of members in the cluster.
applyAsDouble(T) - Method in interface com.hazelcast.function.ToDoubleFunctionEx
 
applyAsDoubleEx(T) - Method in interface com.hazelcast.function.ToDoubleFunctionEx
Exception-declaring version of ToDoubleFunction.applyAsDouble(T).
applyAsInt(T) - Method in interface com.hazelcast.function.ToIntFunctionEx
 
applyAsIntEx(T) - Method in interface com.hazelcast.function.ToIntFunctionEx
Exception-declaring version of ToIntFunction.applyAsInt(T).
applyAsLong(T) - Method in interface com.hazelcast.function.ToLongFunctionEx
 
applyAsLongEx(T) - Method in interface com.hazelcast.function.ToLongFunctionEx
Exception-declaring version of ToLongFunction.applyAsLong(T).
applyAsync(IFunction<Long, R>) - Method in interface com.hazelcast.cp.IAtomicLong
Applies a function on the value, the actual stored value will not change.
applyAsync(IFunction<E, R>) - Method in interface com.hazelcast.cp.IAtomicReference
Applies a function on the value, the actual stored value will not change.
applyEx(T, U) - Method in interface com.hazelcast.function.BiFunctionEx
Exception-declaring version of BiFunction.apply(T, U).
applyEx(T, T) - Method in interface com.hazelcast.function.BinaryOperatorEx
Exception-declaring version of BiFunction.apply(T, U).
applyEx(T) - Method in interface com.hazelcast.function.FunctionEx
Exception-declaring version of Function.apply(T).
asCredentialsFactory(ClassLoader) - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
asCredentialsFactory(ClassLoader) - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
asCredentialsFactory(ClassLoader) - Method in class com.hazelcast.config.security.CredentialsIdentityConfig
 
asCredentialsFactory(ClassLoader) - Method in interface com.hazelcast.config.security.IdentityConfig
Converts current configuration to a ICredentialsFactory instance.
asCredentialsFactory(ClassLoader) - Method in class com.hazelcast.config.security.KerberosIdentityConfig
 
asCredentialsFactory() - Method in class com.hazelcast.config.security.RealmConfig
 
asCredentialsFactory(ClassLoader) - Method in class com.hazelcast.config.security.TokenIdentityConfig
 
asCredentialsFactory(ClassLoader) - Method in class com.hazelcast.config.security.UsernamePasswordIdentityConfig
 
asLoginModuleConfigs() - Method in interface com.hazelcast.config.security.AuthenticationConfig
Converts current configuration to stack of login modules.
asLoginModuleConfigs() - Method in class com.hazelcast.config.security.DefaultAuthenticationConfig
 
asLoginModuleConfigs() - Method in class com.hazelcast.config.security.JaasAuthenticationConfig
 
asLoginModuleConfigs() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
 
asLoginModuleConfigs() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
asLoginModuleConfigs() - Method in class com.hazelcast.config.security.RealmConfig
 
asLoginModuleConfigs() - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
 
asVersion() - Method in class com.hazelcast.version.MemberVersion
 
AtomicLongPermission - Class in com.hazelcast.security.permission
 
AtomicLongPermission(String, String...) - Constructor for class com.hazelcast.security.permission.AtomicLongPermission
 
AtomicReferencePermission - Class in com.hazelcast.security.permission
 
AtomicReferencePermission(String, String...) - Constructor for class com.hazelcast.security.permission.AtomicReferencePermission
 
AttributeConfig - Class in com.hazelcast.config
Contains the configuration of a custom attribute that will be extracted from a Map's entry using a given ValueExtractor.
AttributeConfig() - Constructor for class com.hazelcast.config.AttributeConfig
Creates an empty AttributeConfig.
AttributeConfig(String, String) - Constructor for class com.hazelcast.config.AttributeConfig
Creates a AttributeConfig with the given attribute and ordered setting.
AttributeConfig(AttributeConfig) - Constructor for class com.hazelcast.config.AttributeConfig
 
AuditableEvent - Interface in com.hazelcast.auditlog
Observable event in the system.
AuditlogConfig - Class in com.hazelcast.config
Auditlog configuration.
AuditlogConfig() - Constructor for class com.hazelcast.config.AuditlogConfig
 
AuditlogService - Interface in com.hazelcast.auditlog
Service for logging AuditableEvents.
AuditlogServiceFactory - Interface in com.hazelcast.auditlog
Interface implemented by AuditlogService factory classes.
AuditlogTypeIds - Class in com.hazelcast.auditlog
Auditable event type identifiers.
AUTHENTICATION_CLIENT - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
Event type ID: Client authentication.
AUTHENTICATION_MEMBER - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
Event type ID: Member authentication.
AUTHENTICATION_REST - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
Event type ID: REST authentication.
AuthenticationConfig - Interface in com.hazelcast.config.security
This interface represents authentication configuration in a security realm.
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.
AutoDetectionConfig - Class in com.hazelcast.config
Configuration for the Discovery Strategy Auto Detection.
AutoDetectionConfig() - Constructor for class com.hazelcast.config.AutoDetectionConfig
 
autoDisposable(Runnable) - Static method in class com.hazelcast.scheduledexecutor.TaskUtils
Decorate any Runnable with a AutoDisposableTask to destroy automatically after execution
autoDisposable(Callable<V>) - Static method in class com.hazelcast.scheduledexecutor.TaskUtils
Decorate any Callable with a AutoDisposableTask to destroy automatically after execution
AutoDisposableTask - Interface in com.hazelcast.scheduledexecutor
The AutoDisposableTask interface should be implemented by any single run task which is to be destroyed automatically after execution
availabilityDecreased(CPGroupAvailabilityEvent) - Method in interface com.hazelcast.cp.event.CPGroupAvailabilityListener
Called when a CP group's availability decreases, but still has the majority of members available.
available() - Method in class com.hazelcast.config.ConfigStream
 
availablePermits() - Method in interface com.hazelcast.cp.ISemaphore
Returns the current number of permits currently available in this semaphore.
await(long, TimeUnit) - Method in interface com.hazelcast.cp.ICountDownLatch
Causes the current thread to wait until the latch has counted down to zero, or an exception is thrown, or the specified waiting time elapses.
awaitUntilDiscoveryCompleted(long, TimeUnit) - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Blocks until the CP discovery process is completed, or the given timeout occurs, or the current thread is interrupted, whichever happens first.
AwsConfig - Class in com.hazelcast.config
The AWSConfig contains the configuration for AWS join mechanism.
AwsConfig() - Constructor for class com.hazelcast.config.AwsConfig
 
AwsConfig(AwsConfig) - Constructor for class com.hazelcast.config.AwsConfig
 
AzureConfig - Class in com.hazelcast.config
Configuration for the Azure Discovery Strategy.
AzureConfig() - Constructor for class com.hazelcast.config.AzureConfig
 
AzureConfig(AzureConfig) - Constructor for class com.hazelcast.config.AzureConfig
 

B

BACKPRESSURE_BACKOFF_TIMEOUT_MILLIS - Static variable in class com.hazelcast.client.properties.ClientProperty
Control the maximum timeout in millis to wait for an invocation space to be available.
BACKPRESSURE_BACKOFF_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
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.ClusterProperty
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.ClusterProperty
The maximum number of concurrent invocations per partition.
BACKPRESSURE_SYNCWINDOW - Static variable in class com.hazelcast.spi.properties.ClusterProperty
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_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.
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.map
Base interface for Hazelcast distributed maps.
BaseMetricsConfig<T extends BaseMetricsConfig> - Class in com.hazelcast.config
Base class of configuration options specific to metrics collection.
BaseMetricsConfig() - Constructor for class com.hazelcast.config.BaseMetricsConfig
 
BaseMetricsConfig(BaseMetricsConfig) - Constructor for class com.hazelcast.config.BaseMetricsConfig
 
BaseMultiMap<K,V> - Interface in com.hazelcast.multimap
Base interface for Hazelcast distributed multi-maps.
BaseQueue<E> - Interface in com.hazelcast.collection
Base interface for Hazelcast distributed queues.
before(Credentials, String, String, String, Parameters) - Method in interface com.hazelcast.security.SecurityInterceptor
 
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 interface com.hazelcast.query.PredicateBuilder.EntryObject
 
between(String, Comparable, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates a between predicate that will pass items if the value stored under the given item attribute is contained inside the given range.
BiConsumerEx<T,U> - Interface in com.hazelcast.function
Serializable variant of java.util.function.BiConsumer which declares checked exception.
BiFunctionEx<T,U,R> - Interface in com.hazelcast.function
Serializable variant of java.util.function.BiFunction which declares checked exception.
bigDecimalAvg() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalMax() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalMin() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerAvg() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerMax() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerMin() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
BinaryOperatorEx<T> - Interface in com.hazelcast.function
Serializable variant of java.util.function.BinaryOperator which declares checked exception.
BIND_SPOOFING_CHECKS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Controls whether we apply more strict checks upon BIND requests towards a cluster member.
BiPredicateEx<T,U> - Interface in com.hazelcast.function
Serializable variant of java.util.function.BiPredicate which declares checked exception.
BitmapIndexOptions - Class in com.hazelcast.config
Configures indexing options specific to bitmap indexes.
BitmapIndexOptions() - Constructor for class com.hazelcast.config.BitmapIndexOptions
Constructs a new bitmap index options instance with all options set to default values.
BitmapIndexOptions(BitmapIndexOptions) - Constructor for class com.hazelcast.config.BitmapIndexOptions
Constructs a new bitmap index options instance by copying the passed bitmap index options.
BitmapIndexOptions.UniqueKeyTransformation - Enum in com.hazelcast.config
Defines an assortment of transformations which can be applied to unique key values.
build() - Method in interface com.hazelcast.auditlog.EventBuilder
Builds the AuditableEvent instance.
build() - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
 
build(ClassLoader) - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
 
build() - Method in class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
 
build(ClientFailoverConfig) - Method in class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
 
build() - Method in class com.hazelcast.client.config.YamlClientConfigBuilder
 
build(ClassLoader) - Method in class com.hazelcast.client.config.YamlClientConfigBuilder
 
build() - Method in class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
 
build() - Method in interface com.hazelcast.config.ConfigBuilder
Builds Config object.
build() - Method in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
 
build() - Method in class com.hazelcast.config.RecentlyActiveSplitBrainProtectionConfigBuilder
 
build() - Method in class com.hazelcast.config.SplitBrainProtectionConfigBuilder
 
build() - Method in class com.hazelcast.config.XmlConfigBuilder
 
build() - Method in class com.hazelcast.config.YamlConfigBuilder
 
build() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
build() - Method in interface com.hazelcast.nio.serialization.GenericRecord.Builder
 
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.ClusterProperty
Defines cache invalidation event batch sending is enabled or not.
CACHE_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Defines the cache invalidation event batch sending frequency in seconds.
CACHE_INVALIDATION_MESSAGE_BATCH_SIZE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Defines the maximum number of cache invalidation events to be drained and sent to the event listeners in a batch.
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_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
 
CacheConfigAccessor - Class in com.hazelcast.config
Accessor for CacheConfig fields
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.
CacheEvictionPolicyComparator<K,V> - Interface in com.hazelcast.cache
ICache specific EvictionPolicyComparator for comparing CacheEntryViews to be evicted.
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
 
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
 
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(String) - Constructor for class com.hazelcast.config.CacheSimpleConfig
Create a Cache Simple Config for a cache with a specific name.
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".
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
 
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
 
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
 
cancel(boolean) - Method in interface com.hazelcast.scheduledexecutor.IScheduledFuture
Attempts to cancel further scheduling of this task.
canGetNextDataMember() - Method in interface com.hazelcast.client.LoadBalancer
Returns whether this instance supports getting data members through a call to LoadBalancer.nextDataMember().
CannotReplicateException - Exception in com.hazelcast.cp.exception
A CPSubsystemException which is thrown when an entry cannot be replicated, which can occur in one of the following cases: a member leaves the CP group CP group itself is terminated uncommitted entry count reaches to (see RaftAlgorithmConfig.getUncommittedEntryCountToRejectNewAppends()) a membership change is requested before an entry is committed on a term
CannotReplicateException(RaftEndpoint) - Constructor for exception com.hazelcast.cp.exception.CannotReplicateException
 
canTransformResource(String) - Method in class com.hazelcast.buildutils.HazelcastManifestTransformer
 
capacity() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Returns the capacity of this Ringbuffer.
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
 
cause() - Method in interface com.hazelcast.auditlog.AuditableEvent
Return an exception or error (if any) which caused this event.
cause(Throwable) - Method in interface com.hazelcast.auditlog.EventBuilder
Sets error/exception which caused the event (if any).
changeClusterState(ClusterState) - Method in interface com.hazelcast.cluster.Cluster
Changes state of the cluster to the given state transactionally.
changeClusterState(ClusterState, TransactionOptions) - Method in interface com.hazelcast.cluster.Cluster
Changes state of the cluster to the given state transactionally.
changeClusterVersion(Version) - Method in interface com.hazelcast.cluster.Cluster
Changes the cluster version transactionally.
changeClusterVersion(Version, TransactionOptions) - Method in interface com.hazelcast.cluster.Cluster
Changes the cluster version transactionally, with the transaction options provided.
CHANNEL_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Number of parallel connection between members.
checkPermission(Subject, Permission) - Method in interface com.hazelcast.security.SecurityContext
Checks whether current Subject has been granted specified permission or not.
ClassDefinition - Interface in com.hazelcast.nio.serialization
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
 
ClassFilter(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
className - Variable in class com.hazelcast.config.AbstractWanPublisherConfig
 
className - Variable in class com.hazelcast.config.ListenerConfig
 
className - Variable in class com.hazelcast.config.PredicateConfig
 
className - Variable in class com.hazelcast.config.SecurityInterceptorConfig
 
ClassNameFilter - Interface in com.hazelcast.nio.serialization
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.
ClasspathYamlConfig - Class in com.hazelcast.config
A Config which is initialized by loading a YAML configuration file from the classpath.
ClasspathYamlConfig(String) - Constructor for class com.hazelcast.config.ClasspathYamlConfig
Creates a config which is loaded from a classpath resource using the Thread.currentThread() contextClassLoader.
ClasspathYamlConfig(String, Properties) - Constructor for class com.hazelcast.config.ClasspathYamlConfig
Creates a config which is loaded from a classpath resource using the Thread.currentThread() contextClassLoader.
ClasspathYamlConfig(ClassLoader, String) - Constructor for class com.hazelcast.config.ClasspathYamlConfig
Creates a config which is loaded from a classpath resource.
ClasspathYamlConfig(ClassLoader, String, Properties) - Constructor for class com.hazelcast.config.ClasspathYamlConfig
Creates a config which is loaded from a classpath resource.
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.TcpIpConfig
Removes all members.
clear() - Method in interface com.hazelcast.cp.IAtomicReference
Clears the current stored reference.
clear() - Method in interface com.hazelcast.map.IMap
Clears the map and deletes the items from the backing map store.
clear() - Method in interface com.hazelcast.multimap.MultiMap
Clears the multimap.
clear() - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
The clear operation wipes data out of the replicated maps.
clear() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Clears the data in the ringbuffer.
clear() - Method in class com.hazelcast.spring.cache.HazelcastCache
 
clearAsync() - Method in interface com.hazelcast.cp.IAtomicReference
Clears the current stored reference.
clearLoadedLoggers() - Method in class com.hazelcast.logging.LoggerFactorySupport
 
clearParameters() - Method in class com.hazelcast.sql.SqlStatement
Clears statement parameters.
Client - Interface in com.hazelcast.client
The Client interface allows to get information about a connected client's socket address, type and UUID.
CLIENT_CACHING_PROVIDER - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
Class name of the client-side Caching Provider
CLIENT_CLEANUP_PERIOD - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Time period to check if a client is still part of the cluster.
CLIENT_CLEANUP_TIMEOUT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Timeout duration to decide if a client is still part of the cluster.
CLIENT_ENGINE_BLOCKING_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
The number of threads that the client engine has available for processing requests that are blocking (example: related to transactions) When not set it is set as core-size * 20.
CLIENT_ENGINE_QUERY_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
The number of threads that the client engine has available for processing requests that are related to the query engine.
CLIENT_ENGINE_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
The number of threads that the client engine has available for processing requests that are not partition specific.
CLIENT_HEARTBEAT_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Time after which the member assumes the client is dead and closes its connections to the client.
CLIENT_PROTOCOL_UNVERIFIED_MESSAGE_BYTES - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Client protocol message size limit (in bytes) for unverified connections (i.e.
ClientClasspathXmlConfig - Class in com.hazelcast.client.config
A ClientConfig which is initialized by loading an XML configuration file from the classpath.
ClientClasspathXmlConfig(String) - Constructor for class com.hazelcast.client.config.ClientClasspathXmlConfig
Creates a config which is loaded from a classpath resource using the Thread.currentThread() contextClassLoader.
ClientClasspathXmlConfig(String, Properties) - Constructor for class com.hazelcast.client.config.ClientClasspathXmlConfig
Creates a config which is loaded from a classpath resource using the Thread.currentThread() contextClassLoader.
ClientClasspathXmlConfig(ClassLoader, String, Properties) - Constructor for class com.hazelcast.client.config.ClientClasspathXmlConfig
Creates a config which is loaded from a classpath resource.
ClientClasspathYamlConfig - Class in com.hazelcast.client.config
A ClientConfig which is initialized by loading an YAML configuration file from the classpath.
ClientClasspathYamlConfig(String) - Constructor for class com.hazelcast.client.config.ClientClasspathYamlConfig
Creates a config which is loaded from a classpath resource using the Thread.currentThread() contextClassLoader.
ClientClasspathYamlConfig(String, Properties) - Constructor for class com.hazelcast.client.config.ClientClasspathYamlConfig
Creates a config which is loaded from a classpath resource using the Thread.currentThread() contextClassLoader.
ClientClasspathYamlConfig(ClassLoader, String, Properties) - Constructor for class com.hazelcast.client.config.ClientClasspathYamlConfig
Creates a config which is loaded from a classpath resource.
ClientCloudConfig - Class in com.hazelcast.client.config
hazelcast.cloud configuration to let the client connect the cluster via hazelcast.cloud
ClientCloudConfig() - Constructor for class com.hazelcast.client.config.ClientCloudConfig
 
ClientCloudConfig(ClientCloudConfig) - Constructor for class com.hazelcast.client.config.ClientCloudConfig
 
ClientConfig - Class in com.hazelcast.client.config
Main configuration to setup a Hazelcast Client
ClientConfig() - Constructor for class com.hazelcast.client.config.ClientConfig
 
ClientConfig(ClientConfig) - Constructor for class com.hazelcast.client.config.ClientConfig
 
ClientConfigRecognizer - Class in com.hazelcast.client.config
ConfigRecognizer implementation that recognizes Hazelcast client declarative configurations based on an extensible set of built-in ConfigRecognizer implementations.
ClientConfigRecognizer() - Constructor for class com.hazelcast.client.config.ClientConfigRecognizer
Constructs an instance with the built-in set of ConfigRecognizer implementations only.
ClientConfigRecognizer(ConfigRecognizer...) - Constructor for class com.hazelcast.client.config.ClientConfigRecognizer
Constructs an instance with the built-in set of ConfigRecognizer implementations extended with ones provided in customRecognizers.
ClientConfigXmlGenerator - Class in com.hazelcast.client.config
The ClientConfigXmlGenerator is responsible for transforming a ClientConfig to a Hazelcast Client XML string.
clientConnected(Client) - Method in interface com.hazelcast.client.ClientListener
Invoked when a client is connected.
ClientConnectionStrategyConfig - Class in com.hazelcast.client.config
Client connection strategy configuration is used for setting custom strategies and configuring strategy parameters.
ClientConnectionStrategyConfig() - Constructor for class com.hazelcast.client.config.ClientConnectionStrategyConfig
 
ClientConnectionStrategyConfig(ClientConnectionStrategyConfig) - Constructor for class com.hazelcast.client.config.ClientConnectionStrategyConfig
 
ClientConnectionStrategyConfig.ReconnectMode - Enum in com.hazelcast.client.config
Reconnect options.
clientDisconnected(Client) - Method in interface com.hazelcast.client.ClientListener
Invoked when a client is disconnected.
ClientFailoverClasspathXmlConfig - Class in com.hazelcast.client.config
A ClientFailoverConfig which is initialized by loading an XML configuration file from the classpath.
ClientFailoverClasspathXmlConfig(String) - Constructor for class com.hazelcast.client.config.ClientFailoverClasspathXmlConfig
Creates a config which is loaded from a classpath resource using the Thread.currentThread() contextClassLoader.
ClientFailoverClasspathXmlConfig(String, Properties) - Constructor for class com.hazelcast.client.config.ClientFailoverClasspathXmlConfig
Creates a config which is loaded from a classpath resource using the Thread.currentThread() contextClassLoader.
ClientFailoverClasspathXmlConfig(ClassLoader, String, Properties) - Constructor for class com.hazelcast.client.config.ClientFailoverClasspathXmlConfig
Creates a config which is loaded from a classpath resource.
ClientFailoverClasspathYamlConfig - Class in com.hazelcast.client.config
A ClientFailoverConfig which is initialized by loading a YAML configuration file from the classpath.
ClientFailoverClasspathYamlConfig(String) - Constructor for class com.hazelcast.client.config.ClientFailoverClasspathYamlConfig
Creates a config which is loaded from a classpath resource using the Thread.currentThread() contextClassLoader.
ClientFailoverClasspathYamlConfig(String, Properties) - Constructor for class com.hazelcast.client.config.ClientFailoverClasspathYamlConfig
Creates a config which is loaded from a classpath resource using the Thread.currentThread() contextClassLoader.
ClientFailoverClasspathYamlConfig(ClassLoader, String, Properties) - Constructor for class com.hazelcast.client.config.ClientFailoverClasspathYamlConfig
Creates a config which is loaded from a classpath resource.
ClientFailoverConfig - Class in com.hazelcast.client.config
Config class to configure multiple client configs to be used by single client instance.
ClientFailoverConfig() - Constructor for class com.hazelcast.client.config.ClientFailoverConfig
 
ClientFailoverConfigRecognizer - Class in com.hazelcast.client.config
ConfigRecognizer implementation that recognizes Hazelcast client failover declarative configurations based on an extensible set of built-in ConfigRecognizer implementations.
ClientFailoverConfigRecognizer() - Constructor for class com.hazelcast.client.config.ClientFailoverConfigRecognizer
Constructs an instance with the built-in set of ConfigRecognizer implementations only.
ClientFailoverConfigRecognizer(ConfigRecognizer...) - Constructor for class com.hazelcast.client.config.ClientFailoverConfigRecognizer
Constructs an instance with the built-in set of ConfigRecognizer implementations extended with ones provided in customRecognizers.
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
 
ClientIcmpPingConfig(ClientIcmpPingConfig) - Constructor for class com.hazelcast.client.config.ClientIcmpPingConfig
 
ClientListener - Interface in com.hazelcast.client
The ClientListener provides the ability to listen to clients connecting and disconnecting from the member.
ClientMetricsConfig - Class in com.hazelcast.client.config
Client-side metrics collection configuration.
ClientMetricsConfig() - Constructor for class com.hazelcast.client.config.ClientMetricsConfig
 
ClientMetricsConfig(ClientMetricsConfig) - Constructor for class com.hazelcast.client.config.ClientMetricsConfig
 
ClientNetworkConfig - Class in com.hazelcast.client.config
Contains configuration parameters for client network related behaviour
ClientNetworkConfig() - Constructor for class com.hazelcast.client.config.ClientNetworkConfig
 
ClientNetworkConfig(ClientNetworkConfig) - Constructor for class com.hazelcast.client.config.ClientNetworkConfig
 
ClientNotAllowedInClusterException - Exception in com.hazelcast.client
A HazelcastException that is thrown when the client can not use a cluster.
ClientNotAllowedInClusterException(String) - Constructor for exception com.hazelcast.client.ClientNotAllowedInClusterException
Creates a ClientNotAllowedInClusterException with the given message.
ClientOutOfMemoryHandler - Class in com.hazelcast.client
To clear resources of the client upon OutOfMemory
ClientOutOfMemoryHandler() - Constructor for class com.hazelcast.client.ClientOutOfMemoryHandler
 
ClientProperty - Class in com.hazelcast.client.properties
Defines the name and default value for Hazelcast Client properties.
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
 
ClientSecurityConfig(ClientSecurityConfig) - Constructor for class com.hazelcast.client.config.ClientSecurityConfig
 
ClientService - Interface in com.hazelcast.client
ClientService allows you to query connected Clients and attach/detach ClientListeners to listen to connection events.
ClientUserCodeDeploymentConfig - Class in com.hazelcast.client.config
Configuration of User Code Deployment.
ClientUserCodeDeploymentConfig() - Constructor for class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
ClientUserCodeDeploymentConfig(ClientUserCodeDeploymentConfig) - Constructor for class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
cloneWithBuilder() - Method in interface com.hazelcast.nio.serialization.GenericRecord
Returned GenericRecord.Builder can be used to have exact copy and also just to update a couple of fields.
close() - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
close(ClassLoader) - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
close(URI, ClassLoader) - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
close() - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
 
close(ClassLoader) - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
 
close(URI, ClassLoader) - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
 
close() - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
 
close(ClassLoader) - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
 
close(URI, ClassLoader) - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
 
close() - Method in class com.hazelcast.config.ConfigStream
 
close() - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
close() - Method in interface com.hazelcast.sql.SqlResult
Release the resources associated with the query result.
Cluster - Interface in com.hazelcast.cluster
Hazelcast cluster interface.
CLUSTER_MEMBER_ADDED - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
Event type ID: Member joined.
CLUSTER_MEMBER_REMOVED - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
Event type ID: Member removed from the cluster.
CLUSTER_MEMBER_SUSPECTED - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
Event type ID: Cluster member suspected.
CLUSTER_MERGE - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
Event type ID: Clusters merged.
CLUSTER_PROMOTE_MEMBER - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
Event type ID: Lite member promoted.
CLUSTER_SHUTDOWN - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
Event type ID: Cluster shutdown.
CLUSTER_SHUTDOWN_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Once a member initiates cluster shutdown, it will either wait for all members to leave the cluster before shutting itself down.
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
 
ClusterProperty - Class in com.hazelcast.spi.properties
Defines the name and default value for Hazelcast properties.
ClusterState - Enum in com.hazelcast.cluster
ClusterState are several possible states of the cluster where each state can allow and/or deny specific actions and/or change behavior of specific actions.
collectAllServiceNamespaces(PartitionReplicationEvent, Set<ServiceNamespace>) - Method in interface com.hazelcast.wan.WanMigrationAwarePublisher
Collect the namespaces of all WAN event containers that should be replicated by the replication event.
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
 
collectionFrequencySeconds - Variable in class com.hazelcast.config.BaseMetricsConfig
 
COLUMN_NOT_FOUND - Static variable in class com.hazelcast.sql.SqlRowMetadata
Constant indicating that the column is not found.
com.hazelcast - package com.hazelcast
This package contains PlaceHolder
com.hazelcast.aggregation - package com.hazelcast.aggregation
Contains classes related to aggregations.
com.hazelcast.auditlog - package com.hazelcast.auditlog
Contains interfaces and classes related to auditable events.
com.hazelcast.buildutils - package com.hazelcast.buildutils
This module contains Maven and other build additions that are used by Hazelcast to build bundle modules
com.hazelcast.cache - package com.hazelcast.cache
This package contains the public API extension for Hazelcast JCache, the Hazelcast implementation of the JSR-107 commonly referred to as JCache.
com.hazelcast.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.cache - package com.hazelcast.client.cache
Public API of client-side CachingProvider
com.hazelcast.client.config - package com.hazelcast.client.config
Contains classes related to config for com.hazelcast.client
com.hazelcast.client.properties - package com.hazelcast.client.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.collection - package com.hazelcast.collection
This package contains classes to support the collection API.
com.hazelcast.config - package com.hazelcast.config
Provides classes for configuring HazelcastInstance.
com.hazelcast.config.cp - package com.hazelcast.config.cp
This package contains configuration classes for the CPSubsystem
com.hazelcast.config.matcher - package com.hazelcast.config.matcher
Provides implementations for ConfigPatternMatcher.
com.hazelcast.config.properties - package com.hazelcast.config.properties
This package contains the public API for properties defined in the XML configuration.
com.hazelcast.config.replacer - package com.hazelcast.config.replacer
This package contains the public API and default implementation of variable replacers for configuration files.
com.hazelcast.config.replacer.spi - package com.hazelcast.config.replacer.spi
This package contains the SPI for configuration files variable replacers.
com.hazelcast.config.security - package com.hazelcast.config.security
Provides classes for configuring security realms in Hazelcast.
com.hazelcast.console - package com.hazelcast.console
This package contains classes related to ConsoleApp
com.hazelcast.core - package com.hazelcast.core
Provides core API interfaces/classes.
com.hazelcast.cp - package com.hazelcast.cp
Contains public APIs of CP Subsystem
com.hazelcast.cp.event - package com.hazelcast.cp.event
Contains definitions of CP Subsystem events and listeners.
com.hazelcast.cp.exception - package com.hazelcast.cp.exception
Contains exceptions that can be thrown by APIs of CP Subsystem
com.hazelcast.cp.lock - package com.hazelcast.cp.lock
Contains locking APIs of CP Subsystem
com.hazelcast.cp.lock.exception - package com.hazelcast.cp.lock.exception
Contains exception classes related to the locking API of CP Subsystem
com.hazelcast.cp.session - package com.hazelcast.cp.session
Contains session abstractions of CP Subsystem
com.hazelcast.crdt - package com.hazelcast.crdt
This package contains the common classes for CRDT (conflict-free replicated data type) implementations based on the Hazelcast infrastructure.
com.hazelcast.crdt.pncounter - package com.hazelcast.crdt.pncounter
This package contains the PN (Positive-Negative) CRDT counter interface.
com.hazelcast.durableexecutor - package com.hazelcast.durableexecutor
This package contains DurableExecutorService functionality for Hazelcast.
The DurableExecutorService extends the ExecutorService and provides additional methods like executing tasks on a member who is owner of a specific key.
com.hazelcast.executor - package com.hazelcast.executor
This package contains public API for Hazelcast executors.
com.hazelcast.flakeidgen - package com.hazelcast.flakeidgen
This package contains Flake ID Generator functionality for Hazelcast.
com.hazelcast.function - package com.hazelcast.function
Serializable and exception-declaring variants of functional interfaces from java.util.function.
com.hazelcast.hotrestart - package com.hazelcast.hotrestart
This package contains Hot Restart classes needed for open source Hazelcast code
com.hazelcast.json - package com.hazelcast.json
Contains Json interface
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.listener - package com.hazelcast.map.listener
Contains various MapListener interfaces.
com.hazelcast.memory - package com.hazelcast.memory
Provides classes/interfaces for memory utilities, heap/native memory storage support.
com.hazelcast.multimap - package com.hazelcast.multimap
Contains the API for the MultiMap.
com.hazelcast.nearcache - package com.hazelcast.nearcache
This package contains public API for near cache.
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.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.replicatedmap - package com.hazelcast.replicatedmap
Classes for replicated map.
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.jsm - package com.hazelcast.security.jsm
Contains Java Security Manager permissions.
com.hazelcast.security.permission - package com.hazelcast.security.permission
Contains Hazelcast client permissions.
com.hazelcast.spi - package com.hazelcast.spi
Contains functionality for the Hazelcast SPI
com.hazelcast.spi.annotation - package com.hazelcast.spi.annotation
Contains annotations for Hazelcast SPI.
com.hazelcast.spi.discovery - package com.hazelcast.spi.discovery
This package contains the public SPI for vendors and users to implement their custom node / IP discovery strategy.
com.hazelcast.spi.discovery.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.eviction - package com.hazelcast.spi.eviction
This package contains interfaces for eviction
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.partitiongroup - package com.hazelcast.spi.partitiongroup
This package contains the basic SPI for the Partition Group SPI to define or configure how Hazelcast will configure and distribute backups in the cluster.
com.hazelcast.spi.properties - package com.hazelcast.spi.properties
Contains the Hazelcast properties implementation.
com.hazelcast.spi.tenantcontrol - package com.hazelcast.spi.tenantcontrol
Classes for tenant control
com.hazelcast.splitbrainprotection - package com.hazelcast.splitbrainprotection
Contains classes related to cluster split brain protection.
com.hazelcast.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.sql - package com.hazelcast.sql
This package contains the SQL 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
combine(Aggregator) - Method in interface com.hazelcast.aggregation.Aggregator
Incorporates the intermediary result of the given aggregator to this instance of the aggregator.
commitTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
Commits a transaction.
compact() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
 
comparableMax() - Static method in class com.hazelcast.aggregation.Aggregators
 
comparableMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
comparableMin() - Static method in class com.hazelcast.aggregation.Aggregators
 
comparableMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
comparator - Variable in class com.hazelcast.config.EvictionConfig
 
comparatorClassName - Variable in class com.hazelcast.config.EvictionConfig
 
ComparatorEx<T> - Interface in com.hazelcast.function
Serializable variant of java.util.Comparator which declares checked exception.
compare(CacheEntryView<K, V>, CacheEntryView<K, V>) - Method in interface com.hazelcast.cache.CacheEvictionPolicyComparator
Compares the given CacheEntryView instances and returns the result.
compare(T, T) - Method in interface com.hazelcast.function.ComparatorEx
 
compare(EntryView<K, V>, EntryView<K, V>) - Method in interface com.hazelcast.map.MapEvictionPolicyComparator
Compares the given EntryView instances and returns the result.
compareAndSet(long, long) - Method in interface com.hazelcast.cp.IAtomicLong
Atomically sets the value to the given updated value only if the current value == the expected value.
compareAndSet(E, E) - Method in interface com.hazelcast.cp.IAtomicReference
Atomically sets the value to the given updated value only if the current value == the expected value.
compareAndSetAsync(long, long) - Method in interface com.hazelcast.cp.IAtomicLong
Atomically sets the value to the given updated value only if the current value == the expected value.
compareAndSetAsync(E, E) - Method in interface com.hazelcast.cp.IAtomicReference
Atomically sets the value to the given updated value only if the current value == the expected value.
compareEx(T, T) - Method in interface com.hazelcast.function.ComparatorEx
Exception-declaring version of Comparator.compare(T, T).
compareTo(MemberVersion) - Method in class com.hazelcast.version.MemberVersion
 
compareTo(Version) - Method in class com.hazelcast.version.Version
 
comparing(Function<? super T, ? extends U>, Comparator<? super U>) - Static method in interface com.hazelcast.function.ComparatorEx
comparing(FunctionEx<? super T, ? extends U>, ComparatorEx<? super U>) - Static method in interface com.hazelcast.function.ComparatorEx
comparing(Function<? super T, ? extends U>) - Static method in interface com.hazelcast.function.ComparatorEx
comparing(FunctionEx<? super T, ? extends U>) - Static method in interface com.hazelcast.function.ComparatorEx
comparingDouble(ToDoubleFunction<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
comparingDouble(ToDoubleFunctionEx<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
comparingInt(ToIntFunction<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
comparingInt(ToIntFunctionEx<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
comparingLong(ToLongFunction<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
comparingLong(ToLongFunctionEx<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
compose(FunctionEx<? super V, ? extends T>) - Method in interface com.hazelcast.function.FunctionEx
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.hazelcast.map.IMap
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in interface com.hazelcast.map.IMap
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.hazelcast.map.IMap
CONCURRENT_WINDOW_MS - Static variable in class com.hazelcast.client.properties.ClientProperty
Property needed for concurrency detection so that write through and dynamic response handling can be done correctly.
CONCURRENT_WINDOW_MS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Property needed for concurrency detection so that write through can be done correctly.
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
 
ConfigAccessor - Class in com.hazelcast.config
Private API for accessing configuration at runtime
ConfigBuilder - Interface in com.hazelcast.config
Interface for all config builders.
configBuilder - Variable in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
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
 
ConfigRecognizer - Interface in com.hazelcast.config
Interface for recognizing a declarative Hazelcast configuration based on the rules defined in the actual implementation.
ConfigReplacer - Interface in com.hazelcast.config.replacer.spi
Interface to be implemented by pluggable variable replacers for the configuration files.
ConfigStream - Class in com.hazelcast.config
Stream wrapping or copying a generic InputStream for the ConfigRecognizer API.
ConfigStream(InputStream) - Constructor for class com.hazelcast.config.ConfigStream
 
ConfigStream(InputStream, int) - Constructor for class com.hazelcast.config.ConfigStream
 
configure(CallbackHandler) - Method in class com.hazelcast.config.security.StaticCredentialsFactory
 
configure(CallbackHandler) - Method in interface com.hazelcast.security.ICredentialsFactory
configure(Config, Properties) - Method in interface com.hazelcast.security.IPermissionPolicy
Configures IPermissionPolicy.
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.ClusterProperty
Timeout to connect all other cluster members when a member is joining to a cluster.
CONNECTION_MONITOR_INTERVAL - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Minimum interval in milliseconds to consider a connection error as critical.
CONNECTION_MONITOR_MAX_FAULTS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Maximum I/O error count before disconnecting from a member.
ConnectionRetryConfig - Class in com.hazelcast.client.config
Connection Retry Config is controls the period among the retries and when should a client gave up retrying.
ConnectionRetryConfig() - Constructor for class com.hazelcast.client.config.ConnectionRetryConfig
 
ConnectionRetryConfig(ConnectionRetryConfig) - Constructor for class com.hazelcast.client.config.ConnectionRetryConfig
 
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, PrintStream) - Constructor for class com.hazelcast.console.ConsoleApp
 
ConsumerEx<T> - Interface in com.hazelcast.function
Serializable variant of java.util.function.Consumer which declares checked exception.
contains(E) - Method in interface com.hazelcast.cp.IAtomicReference
Checks if the reference contains the value.
containsAsync(E) - Method in interface com.hazelcast.cp.IAtomicReference
Checks if the reference contains the value.
containsEntry(K, V) - Method in interface com.hazelcast.multimap.MultiMap
Returns whether the multimap contains the given key-value pair.
containsKey(Object) - Method in interface com.hazelcast.map.BaseMap
Returns true if this map contains an entry for the specified key.
containsKey(Object) - Method in interface com.hazelcast.map.IMap
Returns true if this map contains an entry for the specified key.
containsKey(Object) - Method in interface com.hazelcast.map.QueryCache
 
containsKey(K) - Method in interface com.hazelcast.multimap.MultiMap
Returns whether the multimap contains an entry with the key.
containsKey(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns true if value for given key is provided (either as a HazelcastProperty or a System property).
containsKey(Object) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.containsKey(Object).
containsValue(Object) - Method in interface com.hazelcast.map.IMap
containsValue(Object) - Method in interface com.hazelcast.map.QueryCache
 
containsValue(Object) - Method in interface com.hazelcast.multimap.MultiMap
Returns whether the multimap contains an entry with the value.
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() - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
copy() - Method in class com.hazelcast.config.security.CredentialsIdentityConfig
 
copy() - Method in interface com.hazelcast.config.security.IdentityConfig
Makes a copy (or clone) of the config object.
copy() - Method in class com.hazelcast.config.security.KerberosIdentityConfig
 
copy() - Method in class com.hazelcast.config.security.TokenIdentityConfig
 
copy() - Method in class com.hazelcast.config.security.UsernamePasswordIdentityConfig
 
copy() - Method in class com.hazelcast.sql.SqlStatement
Creates a copy of this instance
copyWithInitializedDefaultMaxSizeForOnHeapMaps(NearCacheConfig) - Static method in class com.hazelcast.config.NearCacheConfigAccessor
 
count() - Static method in class com.hazelcast.aggregation.Aggregators
 
count(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
countDown() - Method in interface com.hazelcast.cp.ICountDownLatch
Decrements the count of the latch, releasing all waiting threads if the count reaches zero.
CountDownLatchPermission - Class in com.hazelcast.security.permission
 
CountDownLatchPermission(String, String...) - Constructor for class com.hazelcast.security.permission.CountDownLatchPermission
 
CP_BASE_DIR_DEFAULT - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
The default directory name for storing CP data.
CPGroup - Interface in com.hazelcast.cp
Contains information about a CP group.
CPGroup.CPGroupStatus - Enum in com.hazelcast.cp
Represents status of a CP group
CPGroupAvailabilityEvent - Interface in com.hazelcast.cp.event
CPGroupAvailabilityEvent is published when a CP group's availability is decreased or it has lost the majority completely.
CPGroupAvailabilityListener - Interface in com.hazelcast.cp.event
CPGroupAvailabilityListener is notified when availability of a CP group decreases or it loses the majority completely.
CPGroupDestroyedException - Exception in com.hazelcast.cp.exception
A CPSubsystemException which is thrown when a request is sent to a destroyed CP group.
CPGroupDestroyedException() - Constructor for exception com.hazelcast.cp.exception.CPGroupDestroyedException
 
CPGroupDestroyedException(CPGroupId) - Constructor for exception com.hazelcast.cp.exception.CPGroupDestroyedException
 
CPGroupId - Interface in com.hazelcast.cp
Identifier for CP groups.
CPMember - Interface in com.hazelcast.cp
A CP member is a Hazelcast member that is internally elected to be part of the CPSubsystem, hence maintain CP data structures.
CPMembershipEvent - Interface in com.hazelcast.cp.event
CPMembershipEvent is published when a CP member is added to or removed from the CP Subsystem.
CPMembershipEvent.EventType - Enum in com.hazelcast.cp.event
Membership event type.
CPMembershipListener - Interface in com.hazelcast.cp.event
CPMembershipListener is notified when a CP member is added to or removed from the CP Subsystem.
CPSession - Interface in com.hazelcast.cp.session
Represents a CP session.
CPSession.CPSessionOwnerType - Enum in com.hazelcast.cp.session
Represents type of endpoints that create CP sessions
CPSessionManagementService - Interface in com.hazelcast.cp.session
This interface offers API for managing CP sessions.
CPSubsystem - Interface in com.hazelcast.cp
CP Subsystem is a component of Hazelcast that builds a strongly consistent layer for a set of distributed data structures.
CPSubsystemConfig - Class in com.hazelcast.config.cp
Contains configuration options for CP Subsystem.
CPSubsystemConfig() - Constructor for class com.hazelcast.config.cp.CPSubsystemConfig
 
CPSubsystemConfig(CPSubsystemConfig) - Constructor for class com.hazelcast.config.cp.CPSubsystemConfig
 
CPSubsystemException - Exception in com.hazelcast.cp.exception
Base exception for failures in CP Subsystem
CPSubsystemException(UUID) - Constructor for exception com.hazelcast.cp.exception.CPSubsystemException
 
CPSubsystemException(String, UUID) - Constructor for exception com.hazelcast.cp.exception.CPSubsystemException
 
CPSubsystemException(String, Throwable, UUID) - Constructor for exception com.hazelcast.cp.exception.CPSubsystemException
 
CPSubsystemManagementService - Interface in com.hazelcast.cp
This interface offers APIs for managing CP members and groups.
CRDTReplicationConfig - Class in com.hazelcast.config
Configures the replication mechanism for all CRDT implementations.
CRDTReplicationConfig() - Constructor for class com.hazelcast.config.CRDTReplicationConfig
 
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 the given class ID
CREATE - Static variable in class com.hazelcast.security.permission.InstancePermission
 
create(RelOptPlanner, RexBuilder, DistributionTraitDef) - Static method in class org.apache.calcite.plan.HazelcastRelOptCluster
 
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
 
createAuditlog() - Method in interface com.hazelcast.auditlog.AuditlogServiceFactory
Creates the configured AuditlogService instance.
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
 
createBeanBuilder(String) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
createClientLoginContext(String, Credentials, Connection) - Method in interface com.hazelcast.security.SecurityContext
Creates client LoginContext.
createConcurrentSet() - Method in class com.hazelcast.config.AbstractCacheConfig
 
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
 
createMemberLoginContext(String, Credentials, Connection) - Method in interface com.hazelcast.security.SecurityContext
Creates member LoginContext.
createSecureCallable(Subject, Callable<V>) - Method in interface com.hazelcast.security.SecurityContext
Creates secure callable that runs in a sandbox.
createSecureCallable(Subject, Runnable) - Method in interface com.hazelcast.security.SecurityContext
Creates secure callable that runs in a sandbox.
createSerializer() - Method in interface com.hazelcast.nio.serialization.SerializerHook
Creates a new serializer for the serialization type
createSnapshot(SchemaVersion) - Method in class org.apache.calcite.jdbc.HazelcastRootCalciteSchema
 
createSqlContext(Subject) - Method in interface com.hazelcast.security.SecurityContext
 
createUnresolvedAddress(String, int) - Static method in class com.hazelcast.cluster.Address
Creates an unresolved address.
creationTime() - Method in interface com.hazelcast.cp.session.CPSession
Returns the timestamp of when the session was created
Credentials - Interface in com.hazelcast.security
Credentials represents an identity to be authenticated.
CredentialsFactoryConfig - Class in com.hazelcast.config
Contains the configuration for Credentials Factory.
CredentialsFactoryConfig() - Constructor for class com.hazelcast.config.CredentialsFactoryConfig
 
CredentialsFactoryConfig(String) - Constructor for class com.hazelcast.config.CredentialsFactoryConfig
 
CredentialsIdentityConfig - Class in com.hazelcast.config.security
Identity configuration which just holds given credentials instance.
CredentialsIdentityConfig(Credentials) - Constructor for class com.hazelcast.config.security.CredentialsIdentityConfig
 

D

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.
decode(String) - Method in enum com.hazelcast.config.security.TokenEncoding
 
decrementAndGet() - Method in interface com.hazelcast.cp.IAtomicLong
Atomically decrements the current value by one.
decrementAndGet() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Decrements by one the current value.
decrementAndGetAsync() - Method in interface com.hazelcast.cp.IAtomicLong
Atomically decrements the current value by one.
decrypt(String) - Method in class com.hazelcast.config.replacer.AbstractPbeReplacer
Decrypts given encrypted variable.
DEFAULT_ACKNOWLEDGE_TYPE - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
 
DEFAULT_ALLOWED_FUTURE_MILLIS - Static variable in class com.hazelcast.config.FlakeIdGeneratorConfig
DEFAULT_APPEND_REQUEST_BACKOFF_TIMEOUT_IN_MILLIS - Static variable in class com.hazelcast.config.cp.RaftAlgorithmConfig
Default append request backoff timeout in millis.
DEFAULT_APPEND_REQUEST_MAX_ENTRY_COUNT - Static variable in class com.hazelcast.config.cp.RaftAlgorithmConfig
The default maximum append request entry count.
DEFAULT_ASNYC_FILLUP - Static variable in class com.hazelcast.config.ReplicatedMapConfig
Default value of asynchronous fill up
DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.CardinalityEstimatorConfig
The number of async backups per estimator
DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.CollectionConfig
The default number of asynchronous backups
DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.MultiMapConfig
The default number of asynchronous backups for this MultiMap.
DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.QueueConfig
Default value of the asynchronous backup count.
DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.RingbufferConfig
Default value of asynchronous backup count
DEFAULT_BACKUP_COUNT - Static variable in class com.hazelcast.config.CacheSimpleConfig
The default number of backups.
DEFAULT_BACKUP_COUNT - Static variable in class com.hazelcast.config.MapConfig
The default number of backups
DEFAULT_BATCH_MAX_DELAY_MILLIS - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
 
DEFAULT_BATCH_SIZE - Static variable in class com.hazelcast.config.MergePolicyConfig
Default batch size.
DEFAULT_BATCH_SIZE - Static variable in class com.hazelcast.config.QueryCacheConfig
By default, after reaching this minimum size, node immediately sends buffered events to QueryCache.
DEFAULT_BATCH_SIZE - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
 
DEFAULT_BITS_NODE_ID - Static variable in class com.hazelcast.config.FlakeIdGeneratorConfig
DEFAULT_BITS_SEQUENCE - Static variable in class com.hazelcast.config.FlakeIdGeneratorConfig
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_BULK_LOAD - Static variable in class com.hazelcast.config.QueueStoreConfig
The default size of batches in which the queue will be loaded from the queue store.
DEFAULT_CACHED_DESERIALIZED_VALUES - Static variable in class com.hazelcast.config.MapConfig
We want to cache values only when an index is defined.
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_CIPHER_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Default value for "cipherAlgorithm" property.
DEFAULT_CLUSTER_NAME - Static variable in class com.hazelcast.config.Config
Default cluster name.
DEFAULT_CLUSTER_NAME - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
 
DEFAULT_COALESCE - Static variable in class com.hazelcast.config.QueryCacheConfig
Default value of coalesce property.
DEFAULT_COMMIT_INDEX_ADVANCE_COUNT_TO_SNAPSHOT - Static variable in class com.hazelcast.config.cp.RaftAlgorithmConfig
The default commit index advance count on Raft log to take a snapshot.
DEFAULT_CURSOR_BUFFER_SIZE - Static variable in class com.hazelcast.sql.SqlStatement
Default cursor buffer size.
DEFAULT_DATA_LOAD_TIMEOUT - Static variable in class com.hazelcast.config.HotRestartPersistenceConfig
Default load timeout
DEFAULT_DATA_LOAD_TIMEOUT_SECONDS - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
The default data load timeout duration for restoring CP data from disk.
DEFAULT_DELAY_SECONDS - Static variable in class com.hazelcast.config.QueryCacheConfig
Default value of delay seconds which an event wait in the buffer of a node, before sending to QueryCache.
DEFAULT_DISCOVERY_PERIOD_SECONDS - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
 
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_EPOCH_START - Static variable in class com.hazelcast.config.FlakeIdGeneratorConfig
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 eviction policy
DEFAULT_EXECUTOR_POOL_SIZE - Static variable in class com.hazelcast.config.SqlConfig
Default number of threads responsible for execution of SQL statements.
DEFAULT_FILE - Static variable in class com.hazelcast.config.InstanceTrackingConfig
Default file to which the instance metadata will be written.
DEFAULT_GLOBAL_ORDERING_ENABLED - Static variable in class com.hazelcast.config.TopicConfig
Default global ordering configuration.
DEFAULT_GROUP_NAME - Static variable in interface com.hazelcast.cp.CPGroup
Name of the DEFAULT CP group that is used when no group name is specified while creating a CP data structure proxy.
DEFAULT_HEARTBEAT_INTERVAL_MILLIS - Static variable in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
Default value of heartbeat interval (in milliseconds).
DEFAULT_HEARTBEAT_INTERVAL_SECONDS - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
The default duration for the periodically-committed CP session heartbeats.
DEFAULT_HEARTBEAT_PAUSE_MILLIS - Static variable in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
Default duration in milliseconds corresponding to number of potentially lost/delayed heartbeats that will be accepted before considering it to be an anomaly.
DEFAULT_HEARTBEAT_TOLERANCE_MILLIS - Static variable in class com.hazelcast.config.RecentlyActiveSplitBrainProtectionConfigBuilder
Default duration of time window during which a heartbeat must have been received from a member, for it to be considered present for split brain protection (in milliseconds).
DEFAULT_IDLE_MAX_PARK_NS - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
 
DEFAULT_IDLE_MIN_PARK_NS - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
 
DEFAULT_IN_MEMORY_FORMAT - Static variable in class com.hazelcast.config.CacheSimpleConfig
Default InMemory Format.
DEFAULT_IN_MEMORY_FORMAT - Static variable in class com.hazelcast.config.MapConfig
Default In-Memory format is binary.
DEFAULT_IN_MEMORY_FORMAT - Static variable in class com.hazelcast.config.QueryCacheConfig
By default, hold values of entries in QueryCache as binary.
DEFAULT_IN_MEMORY_FORMAT - Static variable in class com.hazelcast.config.ReplicatedMapConfig
Default value of In-memory format
DEFAULT_IN_MEMORY_FORMAT - Static variable in class com.hazelcast.config.RingbufferConfig
Default value for the in-memory format.
DEFAULT_INCLUDE_VALUE - Static variable in class com.hazelcast.config.QueryCacheConfig
By default, also cache values of entries besides keys.
DEFAULT_INITIAL_PERMITS - Static variable in class com.hazelcast.config.cp.SemaphoreConfig
Default value for the initial permit count of Semaphores.
DEFAULT_INITIAL_PUBLISHER_STATE - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
 
DEFAULT_INTERVAL_MILLISECONDS - Static variable in class com.hazelcast.client.config.ClientIcmpPingConfig
Default interval between icmp ping attempts see ClientIcmpPingConfig.intervalMilliseconds
DEFAULT_INVALIDATE_ON_CHANGE - Static variable in class com.hazelcast.config.NearCacheConfig
 
DEFAULT_KEYSTORE_TYPE - Static variable in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
The default Java KeyStore type (PKCS12).
DEFAULT_LEADER_ELECTION_TIMEOUT_IN_MILLIS - Static variable in class com.hazelcast.config.cp.RaftAlgorithmConfig
The default leader election timeout in millis.
DEFAULT_LEADER_HEARTBEAT_PERIOD_IN_MILLIS - Static variable in class com.hazelcast.config.cp.RaftAlgorithmConfig
The default leader heartbeat period in millis.
DEFAULT_LOCAL_UPDATE_POLICY - Static variable in class com.hazelcast.config.NearCacheConfig
 
DEFAULT_LOCK_ACQUIRE_LIMIT - Static variable in class com.hazelcast.config.cp.FencedLockConfig
The default reentrant lock acquire limit of FencedLock.
DEFAULT_LOOPBACK_MODE_ENABLED - Static variable in class com.hazelcast.config.MulticastConfig
Default flag that indicates if the loopback mode is turned on or off.
DEFAULT_MAX_ATTEMPT - Static variable in class com.hazelcast.client.config.ClientIcmpPingConfig
Default max number of attempts ClientIcmpPingConfig.maxAttempts
DEFAULT_MAX_CONCURRENT_INVOCATIONS - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
 
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_IDLE_SECONDS - Static variable in class com.hazelcast.config.MapConfig
The number of default time to wait eviction in seconds.
DEFAULT_MAX_IDLE_SECONDS - Static variable in class com.hazelcast.config.NearCacheConfig
Default value of the maximum idle time for eviction in seconds.
DEFAULT_MAX_MISSED_LEADER_HEARTBEAT_COUNT - Static variable in class com.hazelcast.config.cp.RaftAlgorithmConfig
Default max number of missed heartbeats to trigger a new leader election.
DEFAULT_MAX_SIZE - Static variable in class com.hazelcast.config.CollectionConfig
Default maximum size for the Configuration.
DEFAULT_MAX_SIZE - Static variable in class com.hazelcast.config.MapConfig
Default max size.
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_SIZE_POLICY - Static variable in class com.hazelcast.config.MapConfig
Default max size policy
DEFAULT_MAX_TARGET_ENDPOINTS - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
 
DEFAULT_MEMORY_FORMAT - Static variable in class com.hazelcast.config.NearCacheConfig
Default value for the in-memory format.
DEFAULT_MEMORY_LIMIT - Static variable in class com.hazelcast.config.QueueStoreConfig
The default number of queue item values to keep in memory.
DEFAULT_MERGE_POLICY - Static variable in class com.hazelcast.config.MergePolicyConfig
Default merge policy.
DEFAULT_MERGE_POLICY_CONFIG - Static variable in class com.hazelcast.config.CardinalityEstimatorConfig
The default merge policy used for cardinality estimators
DEFAULT_METADATA_POLICY - Static variable in class com.hazelcast.config.MapConfig
Default metadata policy
DEFAULT_METADATA_SPACE_PERCENTAGE - Static variable in class com.hazelcast.config.NativeMemoryConfig
Default metadata space percentage
DEFAULT_METRICS_RETENTION_SECONDS - Static variable in class com.hazelcast.config.MetricsManagementCenterConfig
Default retention period for metrics.
DEFAULT_MIN_BLOCK_SIZE - Static variable in class com.hazelcast.config.NativeMemoryConfig
Default minimum block size in bytes
DEFAULT_MIN_STD_DEVIATION - Static variable in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
Default minimum standard deviation (in milliseconds) to use for the normal distribution used when calculating phi.
DEFAULT_MISSING_CP_MEMBER_AUTO_REMOVAL_SECONDS - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
The default duration to wait before automatically removing a missing CP member from CP Subsystem.
DEFAULT_MULTICAST_GROUP - Static variable in class com.hazelcast.config.MulticastConfig
Default group of multicast.
DEFAULT_MULTICAST_PORT - Static variable in class com.hazelcast.config.MulticastConfig
Default value of port.
DEFAULT_MULTICAST_TIMEOUT_SECONDS - Static variable in class com.hazelcast.config.MulticastConfig
Default timeout of multicast in seconds.
DEFAULT_MULTICAST_TTL - Static variable in class com.hazelcast.config.MulticastConfig
Default value of time to live of multicast.
DEFAULT_OPERATION_POOL_SIZE - Static variable in class com.hazelcast.config.SqlConfig
Default number of threads responsible for network operations processing.
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.ProbabilisticSplitBrainProtectionConfigBuilder
Default threshold for suspicion (φ) level.
DEFAULT_POLLING_INTERVAL - Static variable in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
Default interval (in seconds) for polling for changes in the KeyStore: 0 (polling disabled).
DEFAULT_POLLING_INTERVAL - Static variable in class com.hazelcast.config.VaultSecureStoreConfig
Default interval (in seconds) for polling for changes to the encryption key: 0 (polling disabled).
DEFAULT_POOL_SIZE - Static variable in class com.hazelcast.config.DurableExecutorConfig
The number of executor threads per Member for the Executor based on this configuration.
DEFAULT_POOL_SIZE - Static variable in class com.hazelcast.config.ExecutorConfig
The number of executor threads per Member for the Executor based on this configuration.
DEFAULT_POPULATE - Static variable in class com.hazelcast.config.QueryCacheConfig
By default, execute an initial population query prior to creation of the QueryCache.
DEFAULT_PORT - Static variable in class com.hazelcast.config.NetworkConfig
Default value of port number.
DEFAULT_PORT - Static variable in class com.hazelcast.config.ServerSocketEndpointConfig
Default value of port number.
DEFAULT_PREFETCH_COUNT - Static variable in class com.hazelcast.config.FlakeIdGeneratorConfig
DEFAULT_PREFETCH_VALIDITY_MILLIS - Static variable in class com.hazelcast.config.FlakeIdGeneratorConfig
DEFAULT_QUEUE_CAPACITY - Static variable in class com.hazelcast.config.ExecutorConfig
Capacity of queue.
DEFAULT_QUEUE_CAPACITY - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
 
DEFAULT_QUEUE_FULL_BEHAVIOUR - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
 
DEFAULT_READ_BATCH_SIZE - Static variable in class com.hazelcast.client.config.ClientReliableTopicConfig
The default read batch size.
DEFAULT_READ_BATCH_SIZE - Static variable in class com.hazelcast.config.ReliableTopicConfig
The default read batch size.
DEFAULT_REALM - Static variable in class com.hazelcast.config.security.RealmConfig
Default security realm instance.
DEFAULT_REPLICA_COUNT - Static variable in class com.hazelcast.config.PNCounterConfig
The default number of replicas on which state for this CRDT is kept
DEFAULT_REPLICATION_PERIOD_MILLIS - Static variable in class com.hazelcast.config.CRDTReplicationConfig
The default period between two CRDT replication rounds.
DEFAULT_RESPONSE_TIMEOUT_MILLIS - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
 
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.ProbabilisticSplitBrainProtectionConfigBuilder
Default number of samples to use for calculation of mean and standard deviation of inter-arrival times.
DEFAULT_SECRET_KEY_FACTORY_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Default value for "secretKeyFactoryAlgorithm" property.
DEFAULT_SEMAPHORE_JDK_COMPATIBILITY - Static variable in class com.hazelcast.config.cp.SemaphoreConfig
The default value for the JDK compatibility mode of CP ISemaphore
DEFAULT_SERIALIZE_KEYS - Static variable in class com.hazelcast.config.NearCacheConfig
Do not serialize by default
DEFAULT_SESSION_TTL_SECONDS - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
The default value for a CP session to be kept alive after the last heartbeat it has received.
DEFAULT_SNAPSHOT_ENABLED - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
 
DEFAULT_SOCKET_CONNECT_TIMEOUT_SECONDS - Static variable in class com.hazelcast.config.EndpointConfig
DEFAULT_SOCKET_LINGER_SECONDS - Static variable in class com.hazelcast.config.EndpointConfig
DEFAULT_SOCKET_RECEIVE_BUFFER_SIZE_KB - Static variable in class com.hazelcast.config.EndpointConfig
DEFAULT_SOCKET_SEND_BUFFER_SIZE_KB - Static variable in class com.hazelcast.config.EndpointConfig
DEFAULT_STATEMENT_TIMEOUT_MILLIS - Static variable in class com.hazelcast.config.SqlConfig
Default timeout in milliseconds that is applied to statements without explicit timeout.
DEFAULT_STATISTICS_ENABLED - Static variable in class com.hazelcast.config.MapConfig
Default value of whether statistics are enabled or not
DEFAULT_STATISTICS_ENABLED - Static variable in class com.hazelcast.config.PNCounterConfig
Default value for statistics enabled.
DEFAULT_STATISTICS_ENABLED - Static variable in class com.hazelcast.config.ReliableTopicConfig
Default value for statistics enabled.
DEFAULT_STORE_INITIAL_DELAY_SECONDS - Static variable in class com.hazelcast.config.NearCachePreloaderConfig
Default initial delay for the Near Cache key storage.
DEFAULT_STORE_INTERVAL_SECONDS - Static variable in class com.hazelcast.config.NearCachePreloaderConfig
Default interval for the Near Cache key storage (in seconds).
DEFAULT_SYMMETRIC_ALGORITHM - Static variable in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
Default symmetric encryption algorithm.
DEFAULT_SYMMETRIC_ALGORITHM - Static variable in class com.hazelcast.config.SymmetricEncryptionConfig
Default symmetric encryption algorithm
DEFAULT_SYMMETRIC_PASSWORD - Static variable in class com.hazelcast.config.SymmetricEncryptionConfig
Default symmetric encryption password
DEFAULT_SYMMETRIC_SALT - Static variable in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
Default symmetric encryption salt.
DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.CardinalityEstimatorConfig
The number of sync backups per estimator
DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.CollectionConfig
The default number of synchronous backups
DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.MultiMapConfig
The default number of synchronous backups for this MultiMap.
DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.QueueConfig
Default value for the synchronous backup count.
DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.RingbufferConfig
Default value of synchronous backup count
DEFAULT_TARGET_ENDPOINTS - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
 
DEFAULT_TIMEOUT - Static variable in class com.hazelcast.sql.SqlStatement
Default timeout.
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_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_TYPE - Static variable in class com.hazelcast.config.IndexConfig
Default index type.
DEFAULT_UNCOMMITTED_ENTRY_COUNT_TO_REJECT_NEW_APPENDS - Static variable in class com.hazelcast.config.cp.RaftAlgorithmConfig
The default maximum allowed uncommitted entry count.
DEFAULT_UNIQUE_KEY - Static variable in class com.hazelcast.config.BitmapIndexOptions
The default for unique key.
DEFAULT_UNIQUE_KEY_TRANSFORMATION - Static variable in class com.hazelcast.config.BitmapIndexOptions
The default for unique key transformation.
DEFAULT_USE_ENDPOINT_PRIVATE_ADDRESS - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
 
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
DefaultAuthenticationConfig - Class in com.hazelcast.config.security
Default AuthenticationConfig implementation which just references the DefaultLoginModule.
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(Long) - Method in interface com.hazelcast.collection.QueueStore
Deletes the entry with a given key from the store.
delete(Object) - Method in interface com.hazelcast.map.BaseMap
Removes the mapping for a key from this map if it is present.
delete(Object) - Method in interface com.hazelcast.map.IMap
Removes the mapping for the key from this map if it is present.
delete(K) - Method in interface com.hazelcast.map.MapStore
Deletes the entry with a given key from the store.
delete(K) - Method in class com.hazelcast.map.MapStoreAdapter
Deletes the entry with a given key from the store.
delete(Object) - Method in interface com.hazelcast.multimap.MultiMap
Deletes all the entries with the given key.
delete(Object) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.delete(Object).
deleteAll(Collection<Long>) - Method in interface com.hazelcast.collection.QueueStore
Deletes multiple entries from the store.
deleteAll(Collection<K>) - Method in interface com.hazelcast.map.MapStore
Deletes multiple entries from the store.
deleteAll(Collection<K>) - Method in class com.hazelcast.map.MapStoreAdapter
Deletes multiple entries from the store.
DenyAllPermissionCollection - Class in com.hazelcast.security.permission
 
DenyAllPermissionCollection() - Constructor for class com.hazelcast.security.permission.DenyAllPermissionCollection
 
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.config.security.StaticCredentialsFactory
 
destroy() - Method in interface com.hazelcast.core.DistributedObject
Destroys this object cluster-wide.
destroy() - Method in interface com.hazelcast.map.MapLoaderLifecycleSupport
Hazelcast will call this method before shutting down.
destroy() - Method in interface com.hazelcast.map.QueryCache
Destroys this cache.
destroy() - Method in 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.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
 
destroy(T) - Method in interface com.hazelcast.spi.tenantcontrol.DestroyEventContext
Called to decouple Hazelcast object from the tenant
DestroyEventContext<T> - Interface in com.hazelcast.spi.tenantcontrol
Hook to decouple Hazelcast object from the tenant
DISABLE_STALE_READ_ON_PARTITION_MIGRATION - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Hazelcast allows read operations to be performed while a partition is being migrated.
disableAllGroups() - Method in class com.hazelcast.config.RestApiConfig
Disables all REST endpoint groups.
disableAllGroups() - Method in class com.hazelcast.config.RestServerEndpointConfig
Disables all REST endpoint groups.
disableGroups(RestEndpointGroup...) - Method in class com.hazelcast.config.RestApiConfig
Disables provided REST endpoint groups.
disableGroups(RestEndpointGroup...) - Method in class com.hazelcast.config.RestServerEndpointConfig
Disables provided REST endpoint groups.
disableReentrancy() - Method in class com.hazelcast.config.cp.FencedLockConfig
Disable reentrancy.
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.
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.properties.ClientProperty
Enables the Discovery SPI
DISCOVERY_SPI_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Enables the Discovery SPI lookup
DISCOVERY_SPI_PUBLIC_IP_ENABLED - Static variable in class com.hazelcast.client.properties.ClientProperty
Enables the Discovery Joiner to use public IP from DiscoveredNode.
DISCOVERY_SPI_PUBLIC_IP_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Enables the Discovery Joiner to use public IP 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
 
DiscoveryConfig(DiscoveryConfig) - Constructor for class com.hazelcast.config.DiscoveryConfig
 
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() - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
 
DiscoveryStrategyConfig(String) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
 
DiscoveryStrategyConfig(String, Map<String, Comparable>) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
 
DiscoveryStrategyConfig(DiscoveryStrategyFactory) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
 
DiscoveryStrategyConfig(DiscoveryStrategyFactory, Map<String, Comparable>) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
 
DiscoveryStrategyConfig(DiscoveryStrategyConfig) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
 
DiscoveryStrategyFactory - Interface in com.hazelcast.spi.discovery
The DiscoveryStrategyFactory is the entry point for strategy vendors.
DiscoveryStrategyFactory.DiscoveryStrategyLevel - Enum in com.hazelcast.spi.discovery
Level of the discovery strategy.
discoveryStrategyLevel() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategyFactory
Level of the discovery strategy.
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
 
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, UUID) - 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.
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
 
doPrepublicationChecks() - Method in interface com.hazelcast.wan.WanPublisher
Performs pre-publication checks (e.g.
doRollback(DefaultTransactionStatus) - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
 
doSetRollbackOnly(DefaultTransactionStatus) - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
 
doubleAvg() - Static method in class com.hazelcast.aggregation.Aggregators
 
doubleAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
doubleMax() - Static method in class com.hazelcast.aggregation.Aggregators
 
doubleMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
doubleMin() - Static method in class com.hazelcast.aggregation.Aggregators
 
doubleMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
doubleSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
doubleSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
drainPermits() - Method in interface com.hazelcast.cp.ISemaphore
Acquires and returns all permits that are available at invocation time.
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
 
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, boolean) - Constructor for class com.hazelcast.config.DurableExecutorConfig
 
DurableExecutorConfig(String, int, int, int, String, boolean) - 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
 

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
 
ElementParser - Class in com.hazelcast.buildutils
Originally taken from JBOSS project (thanks guys, great work) Original class: org.jboss.osgi.metadata.spi.ElementParser -> JBossOSGi Resolver Metadata
elements() - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
elements() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
 
elements() - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
 
ENABLE_JMX - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Enable JMX agent.
enableAllGroups() - Method in class com.hazelcast.config.RestApiConfig
Enables all REST endpoint groups.
enableAllGroups() - Method in class com.hazelcast.config.RestServerEndpointConfig
Enables all REST endpoint groups.
enabled - Variable in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
 
enabled - Variable in class com.hazelcast.config.BaseMetricsConfig
 
enabled - Variable in class com.hazelcast.config.SplitBrainProtectionConfigBuilder
Whether this split brain protection config is enabled or not
enabled(boolean) - Method in class com.hazelcast.config.SplitBrainProtectionConfigBuilder
 
enableGroups(RestEndpointGroup...) - Method in class com.hazelcast.config.RestApiConfig
Enables provided REST endpoint groups.
enableGroups(RestEndpointGroup...) - Method in class com.hazelcast.config.RestServerEndpointConfig
Enables provided REST endpoint groups.
enableReentrancy() - Method in class com.hazelcast.config.cp.FencedLockConfig
Enables reentrancy.
encode(byte[]) - Method in enum com.hazelcast.config.security.TokenEncoding
 
encrypt(String, int) - Method in class com.hazelcast.config.replacer.AbstractPbeReplacer
Encrypts given string with key generated from AbstractPbeReplacer.getPassword() with given iteration count and return the masked value (to be used as the variable).
encrypt(String...) - Static method in class com.hazelcast.config.replacer.EncryptionReplacer
 
EncryptionAtRestConfig - Class in com.hazelcast.config
Contains configuration for the Hot Restart Persistence at Rest encryption
EncryptionAtRestConfig() - Constructor for class com.hazelcast.config.EncryptionAtRestConfig
 
EncryptionReplacer - Class in com.hazelcast.config.replacer
This class is an example ConfigReplacer implementation which decrypts encrypted values.
EncryptionReplacer() - Constructor for class com.hazelcast.config.replacer.EncryptionReplacer
 
Endpoint - Interface in com.hazelcast.cluster
Endpoint represents a peer in the cluster.
endpoint() - Method in interface com.hazelcast.cp.session.CPSession
Returns the endpoint that has created this session
EndpointConfig - Class in com.hazelcast.config
Endpoint configuration that defines communication/networking properties common to both incoming/outgoing connections eg.
EndpointConfig() - Constructor for class com.hazelcast.config.EndpointConfig
 
endpointName() - Method in interface com.hazelcast.cp.session.CPSession
Returns name of the endpoint that has created this session
endpointType() - Method in interface com.hazelcast.cp.session.CPSession
Returns type of the endpoint that has created this session
ensureNoSplitBrain(String, SplitBrainProtectionOn) - Method in interface com.hazelcast.splitbrainprotection.SplitBrainProtectionService
Ensures that the split brain protection with the given name is present.
ENTERPRISE_LICENSE_KEY - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Hazelcast IMDG Enterprise license key.
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.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.
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.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<Object, Object>) - Method in class com.hazelcast.console.ConsoleApp
 
entryExpired(EntryEvent<K, V>) - Method in class com.hazelcast.core.EntryAdapter
 
entryExpired(EntryEvent<K, V>) - Method in interface com.hazelcast.map.listener.EntryExpiredListener
Invoked upon expiration of an entry.
EntryExpiredListener<K,V> - Interface in com.hazelcast.map.listener
Listener which is notified after removal of an entry due to the expiration-based-eviction.
entryKey() - Static method in class com.hazelcast.function.Functions
Returns a function that extracts the key of a Map.Entry.
EntryListener<K,V> - Interface in com.hazelcast.core
Map Entry listener to get notified when a map entry is added, removed, updated, evicted or expired.
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(MapListener, boolean, boolean) - Constructor for class com.hazelcast.config.EntryListenerConfig
 
EntryListenerConfig(EntryListenerConfig) - Constructor for class com.hazelcast.config.EntryListenerConfig
 
entryLoaded(EntryEvent<K, V>) - Method in interface com.hazelcast.map.listener.EntryLoadedListener
Invoked upon load of an entry.
EntryLoadedListener<K,V> - Interface in com.hazelcast.map.listener
Invoked upon load of an entry.
EntryLoader<K,V> - Interface in com.hazelcast.map
This is an extension to MapLoader.
EntryLoader.MetadataAwareValue<V> - Class in com.hazelcast.map
Represents a value with an expiration time attached to it.
entryMerged(EntryEvent<K, V>) - Method in 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.
EntryProcessor<K,V,R> - Interface in com.hazelcast.map
An EntryProcessor processes a Map.Entry.
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.map.IMap
Returns an immutable Set clone of the mappings contained in this map.
entrySet(Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
Queries the map based on the specified predicate and returns an immutable set of the matching entries.
entrySet() - Method in interface com.hazelcast.map.QueryCache
 
entrySet(Predicate<K, V>) - Method in interface com.hazelcast.map.QueryCache
 
entrySet() - Method in interface com.hazelcast.multimap.MultiMap
Returns the set of key-value pairs in the multimap.
entrySet() - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Returns a lazy Set view of the mappings contained in this map.
A LazySet is optimized for querying speed (preventing eager deserialization and hashing on HashSet insertion) and does NOT provide all operations.
EntryStore<K,V> - Interface in com.hazelcast.map
This is an extension to MapStore.
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.
entryValue() - Static method in class com.hazelcast.function.Functions
Returns a function that extracts the value of a Map.Entry.
EntryView<K,V> - Interface in com.hazelcast.core
Represents a read-only view of a data structure entry.
equal(Comparable) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
equal(String, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates an equal predicate that will pass items if the given value and the value stored under the given item attribute are equal.
equals(Object) - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
 
equals(Object) - Method in class com.hazelcast.client.config.ClientCloudConfig
 
equals(Object) - Method in class com.hazelcast.client.config.ClientConfig
 
equals(Object) - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
 
equals(Object) - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
 
equals(Object) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
equals(Object) - Method in class com.hazelcast.client.config.ClientMetricsConfig
 
equals(Object) - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
equals(Object) - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
 
equals(Object) - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
equals(Object) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
equals(Object) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
 
equals(Object) - Method in class com.hazelcast.client.config.ProxyFactoryConfig
 
equals(Object) - Method in class com.hazelcast.client.config.SocketOptions
 
equals(Object) - Method in class com.hazelcast.cluster.Address
 
equals(Object) - Method in class com.hazelcast.config.AbstractCacheConfig
 
equals(Object) - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
 
equals(Object) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
 
equals(Object) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
 
equals(Object) - Method in class com.hazelcast.config.AttributeConfig
 
equals(Object) - Method in class com.hazelcast.config.BitmapIndexOptions
 
equals(Object) - Method in class com.hazelcast.config.CacheConfig
 
equals(Object) - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
 
equals(Object) - Method in class com.hazelcast.config.CacheSimpleConfig
 
equals(Object) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
equals(Object) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
equals(Object) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
equals(Object) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
equals(Object) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
equals(Object) - Method in class com.hazelcast.config.ClassFilter
 
equals(Object) - Method in class com.hazelcast.config.CollectionConfig
 
equals(Object) - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
equals(Object) - Method in class com.hazelcast.config.DiscoveryConfig
 
equals(Object) - Method in class com.hazelcast.config.DurableExecutorConfig
 
equals(Object) - Method in class com.hazelcast.config.EncryptionAtRestConfig
 
equals(Object) - Method in class com.hazelcast.config.EntryListenerConfig
 
equals(Object) - Method in class com.hazelcast.config.EventJournalConfig
 
equals(Object) - Method in class com.hazelcast.config.EvictionConfig
 
equals(Object) - Method in class com.hazelcast.config.ExecutorConfig
 
equals(Object) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
equals(Object) - Method in class com.hazelcast.config.GlobalSerializerConfig
 
equals(Object) - Method in class com.hazelcast.config.HotRestartConfig
 
equals(Object) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
 
equals(Object) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
equals(Object) - Method in class com.hazelcast.config.IndexConfig
 
equals(Object) - Method in class com.hazelcast.config.InstanceTrackingConfig
 
equals(Object) - Method in class com.hazelcast.config.InterfacesConfig
 
equals(Object) - Method in class com.hazelcast.config.ItemListenerConfig
 
equals(Object) - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
 
equals(Object) - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
equals(Object) - Method in class com.hazelcast.config.ListenerConfig
 
equals(Object) - Method in class com.hazelcast.config.LoginModuleConfig
 
equals(Object) - Method in class com.hazelcast.config.ManagementCenterConfig
 
equals(Object) - Method in class com.hazelcast.config.MapConfig
 
equals(Object) - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
 
equals(Object) - Method in class com.hazelcast.config.MapStoreConfig
 
equals(Object) - Method in class com.hazelcast.config.matcher.MatchingPointConfigPatternMatcher
 
equals(Object) - Method in class com.hazelcast.config.matcher.RegexConfigPatternMatcher
 
equals(Object) - Method in class com.hazelcast.config.matcher.WildcardConfigPatternMatcher
 
equals(Object) - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
equals(Object) - Method in class com.hazelcast.config.MemberGroupConfig
 
equals(Object) - Method in class com.hazelcast.config.MergePolicyConfig
 
equals(Object) - Method in class com.hazelcast.config.MerkleTreeConfig
 
equals(Object) - Method in class com.hazelcast.config.MetricsConfig
 
equals(Object) - Method in class com.hazelcast.config.MetricsJmxConfig
 
equals(Object) - Method in class com.hazelcast.config.MetricsManagementCenterConfig
 
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.PersistentMemoryConfig
 
equals(Object) - Method in class com.hazelcast.config.PersistentMemoryDirectoryConfig
 
equals(Object) - Method in class com.hazelcast.config.PNCounterConfig
 
equals(Object) - Method in class com.hazelcast.config.PredicateConfig
 
equals(Object) - Method in class com.hazelcast.config.QueryCacheConfig
 
equals(Object) - Method in class com.hazelcast.config.QueueConfig
 
equals(Object) - Method in class com.hazelcast.config.QueueStoreConfig
 
equals(Object) - Method in class com.hazelcast.config.ReliableTopicConfig
 
equals(Object) - Method in class com.hazelcast.config.ReplicatedMapConfig
 
equals(Object) - Method in class com.hazelcast.config.RingbufferConfig
 
equals(Object) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
equals(Object) - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
equals(Object) - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
 
equals(Object) - Method in class com.hazelcast.config.security.CredentialsIdentityConfig
 
equals(Object) - Method in class com.hazelcast.config.security.JaasAuthenticationConfig
 
equals(Object) - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
 
equals(Object) - Method in class com.hazelcast.config.security.KerberosIdentityConfig
 
equals(Object) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
equals(Object) - Method in class com.hazelcast.config.security.RealmConfig
 
equals(Object) - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
 
equals(Object) - Method in class com.hazelcast.config.security.TokenIdentityConfig
 
equals(Object) - Method in class com.hazelcast.config.security.UsernamePasswordIdentityConfig
 
equals(Object) - Method in class com.hazelcast.config.SecurityConfig
 
equals(Object) - Method in class com.hazelcast.config.SerializationConfig
 
equals(Object) - Method in class com.hazelcast.config.SerializerConfig
 
equals(Object) - Method in class com.hazelcast.config.ServiceConfig
 
equals(Object) - Method in class com.hazelcast.config.SocketInterceptorConfig
 
equals(Object) - Method in class com.hazelcast.config.SSLConfig
 
equals(Object) - Method in class com.hazelcast.config.TcpIpConfig
 
equals(Object) - Method in class com.hazelcast.config.TopicConfig
 
equals(Object) - Method in class com.hazelcast.config.VaultSecureStoreConfig
 
equals(Object) - Method in class com.hazelcast.config.WanConsumerConfig
 
equals(Object) - Method in class com.hazelcast.config.WanReplicationConfig
 
equals(Object) - Method in class com.hazelcast.config.WanReplicationRef
 
equals(Object) - Method in class com.hazelcast.config.WanSyncConfig
 
equals(Object) - Method in class com.hazelcast.core.HazelcastJsonValue
 
equals(Object) - Method in class com.hazelcast.core.LifecycleEvent
 
equals(Object) - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
equals(Object) - Method in class com.hazelcast.memory.MemorySize
 
equals(Object) - Method in class com.hazelcast.partition.PartitionAwareKey
 
equals(Object) - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
equals(Object) - Method in class com.hazelcast.security.permission.AllPermissions
 
equals(Object) - Method in class com.hazelcast.security.permission.ClusterPermission
 
equals(Object) - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
 
equals(Object) - Method in class com.hazelcast.security.permission.InstancePermission
 
equals(Object) - Method in class com.hazelcast.security.SimpleTokenCredentials
 
equals(Object) - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
equals(Object) - Method in class com.hazelcast.sql.SqlColumnMetadata
 
equals(Object) - Method in class com.hazelcast.sql.SqlRowMetadata
 
equals(Object) - Method in class com.hazelcast.sql.SqlStatement
 
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
 
EurekaConfig(EurekaConfig) - Constructor for class com.hazelcast.config.EurekaConfig
 
EVENT_QUEUE_CAPACITY - Static variable in class com.hazelcast.client.properties.ClientProperty
Capacity of the executor that handles the incoming event packets.
EVENT_QUEUE_CAPACITY - Static variable in class com.hazelcast.spi.properties.ClusterProperty
The capacity of the EventServiceImpl executor.
EVENT_QUEUE_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
The timeout for offering an event to the event executor for processing.
EVENT_SYNC_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
To prevent overloading of the outbound connections, once in a while an event is made synchronous by wrapping it in a fake operation and waiting for a fake response.
EVENT_THREAD_COUNT - Static variable in class com.hazelcast.client.properties.ClientProperty
Number of the threads to handle the incoming event packets.
EVENT_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Number of threads for the EventServiceImpl executor.
EVENT_TYPE - Static variable in class com.hazelcast.map.EventLostEvent
Event type ID.
eventBuilder(String) - Method in interface com.hazelcast.auditlog.AuditlogService
Returns an instance of the EventBuilder interface.
EventBuilder<T extends EventBuilder<T>> - Interface in com.hazelcast.auditlog
Builder interface for AuditableEvent instances.
EventJournalCacheEvent<K,V> - Interface in com.hazelcast.cache
The event for the cache event journal.
eventJournalConfig - Variable in class com.hazelcast.config.AbstractCacheConfig
 
EventJournalConfig - Class in com.hazelcast.config
Configuration for an event journal.
EventJournalConfig() - Constructor for class com.hazelcast.config.EventJournalConfig
 
EventJournalConfig(EventJournalConfig) - Constructor for class com.hazelcast.config.EventJournalConfig
EventJournalMapEvent<K,V> - Interface in com.hazelcast.map
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.
evict(K) - Method in interface com.hazelcast.map.IMap
Evicts the specified key from this map.
evict(Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
 
EvictableEntryView<K,V> - Interface in com.hazelcast.spi.eviction
Contract point (from the end user perspective) for serving/accessing entries that can be evicted.
evictAll() - Method in interface com.hazelcast.map.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(EvictionConfig) - Constructor for class com.hazelcast.config.EvictionConfig
 
evictionPolicy - Variable in class com.hazelcast.config.EvictionConfig
 
EvictionPolicy - Enum in com.hazelcast.config
Eviction Policy enum.
EvictionPolicyComparator<K,V,E extends EvictableEntryView<K,V>> - Interface in com.hazelcast.spi.eviction
A kind of Comparator to be used while comparing entries to be evicted.
execute(Runnable, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
Executes a task on a randomly selected member.
execute(String, Object...) - Method in interface com.hazelcast.sql.SqlService
Convenient method to execute a distributed query with the given parameters.
execute(SqlStatement) - Method in interface com.hazelcast.sql.SqlService
Executes an SQL statement.
execute(TransactionalTaskContext) - Method in interface com.hazelcast.transaction.TransactionalTask
Executes the transactional logic.
executeOnAllMembers(Runnable) - Method in interface com.hazelcast.core.IExecutorService
Executes a task on all of the known cluster members.
executeOnEntries(EntryProcessor<K, V, R>) - Method in interface com.hazelcast.map.IMap
Applies the user defined EntryProcessor to the all entries in the map.
executeOnEntries(EntryProcessor<K, V, R>, Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
Applies the user defined EntryProcessor to the entries in the map which satisfy provided predicate.
executeOnKey(K, EntryProcessor<K, V, R>) - Method in interface com.hazelcast.map.IMap
Applies the user defined EntryProcessor to the entry mapped by the key.
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<K, V, R>) - Method in interface com.hazelcast.map.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.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.
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
 
ExecutorServicePermission - Class in com.hazelcast.security.permission
 
ExecutorServicePermission(String, String...) - Constructor for class com.hazelcast.security.permission.ExecutorServicePermission
 
expirationTime() - Method in interface com.hazelcast.cp.session.CPSession
Returns the timestamp of when the session will expire
ExpirationTimeMergePolicy<V,T extends MergingValue<V> & MergingExpirationTime> - 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
 
ExtendedMapEntry<K,V> - Interface in com.hazelcast.map
Interface to provide parity with IMap set and put operations.
extract(T, A, ValueCollector) - Method in interface com.hazelcast.query.extractor.ValueExtractor
Extracts a value from the given target object.

F

factoryClassName - Variable in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
 
factoryWithPropertiesXmlGenerator(ConfigXmlGenerator.XmlGenerator, String, AbstractFactoryWithPropertiesConfig<?>) - Method in class com.hazelcast.config.ConfigXmlGenerator
 
FAIL_ON_INDETERMINATE_OPERATION_STATE - Static variable in class com.hazelcast.client.properties.ClientProperty
When this configuration is enabled, if an operation has sync backups and acks are not received from backup replicas in time, or the member which owns primary replica of the target partition leaves the cluster, then the invocation fails with IndeterminateOperationStateException.
FAIL_ON_INDETERMINATE_OPERATION_STATE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
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.
FencedLock - Interface in com.hazelcast.cp.lock
A linearizable & distributed & reentrant implementation of Lock.
FencedLockConfig - Class in com.hazelcast.config.cp
Contains configuration options for FencedLock
FencedLockConfig() - Constructor for class com.hazelcast.config.cp.FencedLockConfig
 
FencedLockConfig(String) - Constructor for class com.hazelcast.config.cp.FencedLockConfig
 
FencedLockConfig(String, int) - Constructor for class com.hazelcast.config.cp.FencedLockConfig
 
FieldDefinition - Interface in com.hazelcast.nio.serialization
Defines the name, type and 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.
FileSystemYamlConfig - Class in com.hazelcast.config
A Config which includes functionality for loading itself from a YAML configuration file.
FileSystemYamlConfig(String) - Constructor for class com.hazelcast.config.FileSystemYamlConfig
Creates a Config based on a Hazelcast yaml file and uses the System.properties to resolve variables in the YAML.
FileSystemYamlConfig(String, Properties) - Constructor for class com.hazelcast.config.FileSystemYamlConfig
Creates a Config based on a Hazelcast YAML file.
FileSystemYamlConfig(File) - Constructor for class com.hazelcast.config.FileSystemYamlConfig
Creates a Config based on a Hazelcast yaml file and uses the System.properties to resolve variables in the YAML.
FileSystemYamlConfig(File, Properties) - Constructor for class com.hazelcast.config.FileSystemYamlConfig
Creates a Config based on a Hazelcast YAML file.
fillAttributesForAliasedDiscoveryStrategy(AliasedDiscoveryConfig, Node, BeanDefinitionBuilder, String) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
fillAttributeValues(Node, BeanDefinitionBuilder, String...) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
fillAttributeValues(Node, BeanDefinitionBuilder, Collection<String>) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
fillValues(Node, BeanDefinitionBuilder, String...) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
filter(String) - Method in interface com.hazelcast.nio.serialization.ClassNameFilter
FinalRemovalAgent - Class in com.hazelcast.buildutils
 
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.
findCardinalityEstimatorConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only CardinalityEstimator configuration for the given name.
findColumn(String) - Method in class com.hazelcast.sql.SqlRowMetadata
Find index of the column with 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.
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.cp.CPSubsystemConfig
Returns the FencedLock configuration for the given name.
findMapConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only IMap configuration for the given name.
findMultiMapConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only MultiMap configuration for the given name.
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.
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.cp.CPSubsystemConfig
Returns the CP 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.
findSplitBrainProtectionConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only split-brain protection 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
 
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() - Constructor for class com.hazelcast.config.FlakeIdGeneratorConfig
 
FlakeIdGeneratorConfig(String) - Constructor for class com.hazelcast.config.FlakeIdGeneratorConfig
 
FlakeIdGeneratorConfig(FlakeIdGeneratorConfig) - Constructor for class com.hazelcast.config.FlakeIdGeneratorConfig
Copy-constructor
FlakeIdGeneratorPermission - Class in com.hazelcast.security.permission
 
FlakeIdGeneratorPermission(String, String...) - Constructor for class com.hazelcast.security.permission.FlakeIdGeneratorPermission
 
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.map.IMap
If this map has a MapStore, this method flushes all the local dirty entries.
forceCloseSession(String, long) - Method in interface com.hazelcast.cp.session.CPSessionManagementService
If a Hazelcast instance that owns a CP session crashes, its CP session is not terminated immediately.
forceDestroyCPGroup(String) - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Unconditionally destroys the given active CP group without using the Raft algorithm mechanics.
forceLocalMemberToBeSafe(long, TimeUnit) - Method in interface com.hazelcast.partition.PartitionService
Force the local member to be safe by checking and syncing partitions owned by the local member with at least one of the backups.
forceUnlock(K) - Method in interface com.hazelcast.map.IMap
Releases the lock for the specified key regardless of the lock owner.
forceUnlock(K) - Method in interface com.hazelcast.multimap.MultiMap
Releases the lock for the specified key regardless of the lock owner.
forEach(BiConsumer<? super K, ? super V>) - Method in interface com.hazelcast.map.IMap
fromId(int) - Static method in enum com.hazelcast.config.BitmapIndexOptions.UniqueKeyTransformation
 
fromName(String) - Static method in enum com.hazelcast.config.BitmapIndexOptions.UniqueKeyTransformation
Resolves one of the BitmapIndexOptions.UniqueKeyTransformation values by its name.
fromStoreValue(Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
 
FunctionEx<T,R> - Interface in com.hazelcast.function
Serializable variant of java.util.function.Function which declares checked exception.
Functions - Class in com.hazelcast.function
Factory methods for several common functions.

G

GcpConfig - Class in com.hazelcast.config
Configuration for the GCP Discovery Strategy.
GcpConfig() - Constructor for class com.hazelcast.config.GcpConfig
 
GcpConfig(GcpConfig) - Constructor for class com.hazelcast.config.GcpConfig
 
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.ClusterProperty
The number of generic operation handler threads per member.
GenericRecord - Interface in com.hazelcast.nio.serialization
A generic object interface that is returned to user when the domain class can not be created from any of the distributed hazelcast data structures like IMap ,IQueue etc.
GenericRecord.Builder - Interface in com.hazelcast.nio.serialization
Interface for creating GenericRecord instances.
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() - Method in interface com.hazelcast.cp.IAtomicLong
Gets the current value.
get() - Method in interface com.hazelcast.cp.IAtomicReference
Gets the current value.
get() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Returns the current value of the counter.
get() - Method in interface com.hazelcast.function.SupplierEx
 
get(Object) - Method in interface com.hazelcast.map.BaseMap
Returns the value for the specified key, or null if this map does not contain this key.
get(Object) - Method in interface com.hazelcast.map.IMap
Returns the value for the specified key, or null if this map does not contain this key.
get(Object) - Method in interface com.hazelcast.map.QueryCache
 
get(K) - Method in interface com.hazelcast.multimap.BaseMultiMap
Returns the collection of values associated with the key.
get(K) - Method in interface com.hazelcast.multimap.MultiMap
Returns the collection of values associated with the key.
get(byte) - Static method in enum com.hazelcast.nio.serialization.FieldType
 
get(String) - Method in interface com.hazelcast.query.PredicateBuilder.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
 
get(Object) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.get(Object).
get(K) - Method in interface com.hazelcast.transaction.TransactionalMultiMap
Returns the collection of values associated with the key.
getAcknowledgeType() - Method in class com.hazelcast.config.WanBatchPublisherConfig
Returns the strategy for when the target cluster should acknowledge that a WAN event batch has been processed.
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
 
getActiveMemberNetworkConfig(Config) - Static method in class com.hazelcast.config.ConfigAccessor
 
getAddress() - Method in interface com.hazelcast.cluster.Member
Returns the Address of this Member.
getAddress() - Method in class com.hazelcast.config.VaultSecureStoreConfig
Returns the Vault server address.
getAddress() - Method in interface com.hazelcast.cp.CPMember
Returns the address of this CP member.
getAddresses() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Returns the list of candidate addresses that client will use to establish initial connection
getAddressMap() - Method in interface com.hazelcast.cluster.Member
 
getAdvancedNetworkConfig() - Method in class com.hazelcast.config.Config
 
getAlgorithm() - Method in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
Returns the encryption algorithm.
getAll(Set<? extends K>, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Gets a collection of entries from the cache with custom expiry policy, returning them as Map of the values associated with the set of keys requested.
getAll(Set<K>) - Method in interface com.hazelcast.map.IMap
Returns an immutable map of 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
 
getAllHazelcastClients() - Static method in class com.hazelcast.client.HazelcastClient
Gets an immutable collection of all client HazelcastInstances created in this JVM.
getAllHazelcastInstances() - Static method in class com.hazelcast.core.Hazelcast
Returns all active/running HazelcastInstances on this JVM.
getAllHazelcastInstances() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Gets all active/running HazelcastOSGiInstances on the owner bundle.
getAllocatorType() - Method in class com.hazelcast.config.NativeMemoryConfig
Returns the NativeMemoryConfig.MemoryAllocatorType to be used while allocating native memory.
getAllowedFutureMillis() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
getAllScheduledFutures() - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Fetches and returns all scheduled (not disposed yet) futures from all members in the cluster.
getAllSessions(String) - Method in interface com.hazelcast.cp.session.CPSessionManagementService
Returns a non-null collection of CP sessions that are currently active in the given CP group.
getAnchor() - Method in interface com.hazelcast.query.PagingPredicate
Retrieve the anchor object which is the last value object on the previous page.
getAndAdd(long) - Method in interface com.hazelcast.cp.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.
getAndAddAsync(long) - Method in interface com.hazelcast.cp.IAtomicLong
Atomically adds the given value to the current value.
getAndAlter(IFunction<Long, Long>) - Method in interface com.hazelcast.cp.IAtomicLong
Alters the currently stored value by applying a function on it on and gets the old value.
getAndAlter(IFunction<E, E>) - Method in interface com.hazelcast.cp.IAtomicReference
Alters the currently stored reference by applying a function on it on and gets the old value.
getAndAlterAsync(IFunction<Long, Long>) - Method in interface com.hazelcast.cp.IAtomicLong
Alters the currently stored value by applying a function on it on and gets the old value.
getAndAlterAsync(IFunction<E, E>) - Method in interface com.hazelcast.cp.IAtomicReference
Alters the currently stored reference by applying a function on it on and gets the old value.
getAndDecrement() - Method in interface com.hazelcast.cp.IAtomicLong
Atomically decrements the current value by one.
getAndDecrement() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Decrements by one the current value.
getAndDecrementAsync() - Method in interface com.hazelcast.cp.IAtomicLong
Atomically decrements the current value by one.
getAndIncrement() - Method in interface com.hazelcast.cp.IAtomicLong
Atomically increments the current value by one.
getAndIncrement() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Increments by one the current value.
getAndIncrementAsync() - Method in interface com.hazelcast.cp.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.cp.IAtomicLong
Atomically sets the given value and returns the old value.
getAndSet(E) - Method in interface com.hazelcast.cp.IAtomicReference
Gets the old value and sets the new value.
getAndSetAsync(long) - Method in interface com.hazelcast.cp.IAtomicLong
Atomically sets the given value and returns the old value.
getAndSetAsync(E) - Method in interface com.hazelcast.cp.IAtomicReference
Gets the value and sets the new value.
getAndSubtract(long) - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Subtracts the given value from the current value.
getAppendRequestBackoffTimeoutInMillis() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
getAppendRequestMaxEntryCount() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
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.cp.IAtomicLong
Gets the current value.
getAsync() - Method in interface com.hazelcast.cp.IAtomicReference
Gets the current value.
getAsync(K) - Method in interface com.hazelcast.map.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.
getAtomicLong(String) - Method in interface com.hazelcast.cp.CPSubsystem
Returns a proxy for an IAtomicLong instance created on CP Subsystem.
getAtomicNumber() - Method in class com.hazelcast.console.ConsoleApp
 
getAtomicReference(String) - Method in interface com.hazelcast.cp.CPSubsystem
Returns a proxy for an IAtomicReference instance created on CP Subsystem.
getAttribute(String) - Method in interface com.hazelcast.cluster.Member
Returns the value of the specified key for this member or null if value is undefined.
getAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
 
getAttribute() - Method in interface com.hazelcast.query.PredicateBuilder
 
getAttribute(Node, String) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
getAttributeConfigs() - Method in class com.hazelcast.config.MapConfig
 
getAttributes() - Method in interface com.hazelcast.cluster.Member
Returns configured attributes for this member.
This method might not be available on all native clients.
getAttributes() - Method in class com.hazelcast.config.IndexConfig
Gets index attributes.
getAttributes() - Method in class com.hazelcast.config.MemberAttributeConfig
 
getAuditlogConfig() - Method in class com.hazelcast.config.Config
 
getAutoDetectionConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Returns the configuration of the Auto Detection discovery.
getAutoDetectionConfig() - Method in class com.hazelcast.config.JoinConfig
 
getAverageAge() - Method in interface com.hazelcast.collection.LocalQueueStats
Returns the average age of the items in this member.
getAverageGetTime() - Method in interface com.hazelcast.cache.CacheStatistics
The mean time to execute gets.
getAverageHitLatency() - Method in interface com.hazelcast.query.LocalIndexStats
Returns the average hit latency (in nanoseconds) for the index.
getAverageHitSelectivity() - Method in interface com.hazelcast.query.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.
getAverageRemoveTime() - Method in interface com.hazelcast.cache.CacheStatistics
The mean time to execute removes.
getAwsConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Returns the current AwsConfig.
getAwsConfig() - Method in class com.hazelcast.config.JoinConfig
 
getAwsConfig() - Method in class com.hazelcast.config.WanBatchPublisherConfig
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.WanBatchPublisherConfig
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 interface com.hazelcast.map.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.
getBackupEntryCount() - Method in interface com.hazelcast.map.LocalMapStats
Returns the number of backup entries hold by this member.
getBackupEntryMemoryCost() - Method in interface com.hazelcast.map.LocalMapStats
Returns memory cost (number of bytes) of backup entries in this member.
getBackupItemCount() - Method in interface com.hazelcast.collection.LocalQueueStats
Returns the number of backup items in this member.
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).
getBaseDir() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the base directory for persisting CP data.
getBaseDir() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Base directory for all Hot Restart stores.
getBaseName(String) - Static method in class com.hazelcast.partition.strategy.StringPartitioningStrategy
 
getBatchMaxDelayMillis() - Method in class com.hazelcast.config.WanBatchPublisherConfig
Returns the maximum amount of time in milliseconds to wait before sending a batch of events to target cluster, if WanBatchPublisherConfig.getBatchSize() of events have not arrived within this duration.
getBatchPublisherConfigs() - Method in class com.hazelcast.config.WanReplicationConfig
Returns the list of WAN publisher configurations using the built-in batching WAN implementation for this WAN replication.
getBatchSize() - Method in class com.hazelcast.config.MergePolicyConfig
Returns the batch size, which will be used to determine the number of entries to be sent in a merge operation.
getBatchSize() - Method in class com.hazelcast.config.QueryCacheConfig
After reaching this size, node sends buffered events to QueryCache.
getBatchSize() - Method in class com.hazelcast.config.WanBatchPublisherConfig
Returns the maximum batch size that can be sent to target cluster.
getBindAddress() - Method in interface com.hazelcast.spi.MemberAddressProvider
What address should Hazelcast bind to.
getBindAddress(EndpointQualifier) - Method in interface com.hazelcast.spi.MemberAddressProvider
 
getBitmapIndexOptions() - Method in class com.hazelcast.config.IndexConfig
Provides access to index options specific to bitmap indexes.
getBitsNodeId() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
getBitsSequence() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
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.
getBufferSize() - Method in class com.hazelcast.client.config.SocketOptions
Gets the SO_SNDBUF and SO_RCVBUF option value
getBufferSize() - Method in class com.hazelcast.config.QueryCacheConfig
Returns the maximum number of events which can be stored in a buffer of partition.
getById(int) - Static method in enum com.hazelcast.cluster.ClusterState
 
getById(int) - Static method in enum com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
 
getById(byte) - Static method in enum com.hazelcast.config.ConsistencyCheckStrategy
Returns the ConsistencyCheckStrategy for the given ID.
getById(int) - Static method in enum com.hazelcast.config.EvictionPolicy
 
getById(int) - Static method in enum com.hazelcast.config.IndexType
Returns the IndexType as an enum.
getById(int) - Static method in enum com.hazelcast.config.InMemoryFormat
 
getById(int) - Static method in enum com.hazelcast.config.MaxSizePolicy
 
getById(int) - Static method in enum com.hazelcast.config.MetadataPolicy
Returns the MetadataPolicy for the given ID.
getById(byte) - Static method in enum com.hazelcast.config.ScheduledExecutorConfig.CapacityPolicy
 
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.
getById(int) - Static method in enum com.hazelcast.sql.SqlColumnType
Returns the IndexType as an enum.
getById(int) - Static method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
 
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(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
 
getByType(byte) - Static method in enum com.hazelcast.wan.WanPublisherState
Returns the WanPublisherState as an enum.
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
 
getCacheEntryListenerFactory() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
getCacheEntryListeners() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets a list of CacheSimpleEntryListenerConfig from this ICache.
getCacheEvictions() - Method in interface com.hazelcast.cache.CacheStatistics
The total number of evictions from the cache.
getCacheGets() - Method in interface com.hazelcast.cache.CacheStatistics
The total number of requests to the cache.
getCacheHitPercentage() - Method in interface com.hazelcast.cache.CacheStatistics
This is a measure of cache efficiency.
getCacheHits() - Method in interface com.hazelcast.cache.CacheStatistics
The number of get requests that were satisfied by 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(URI, ClassLoader, Properties) - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
 
getCacheManager(URI, ClassLoader) - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
 
getCacheManager() - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
 
getCacheManager(URI, ClassLoader, Properties) - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
 
getCacheManager(URI, ClassLoader) - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
 
getCacheManager() - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
 
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.
getCacheMissPercentage() - Method in interface com.hazelcast.cache.CacheStatistics
Returns the percentage of cache accesses that did not find a requested entry in the cache.
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.
getCacheRemovals() - Method in interface com.hazelcast.cache.CacheStatistics
The total number of removals from the cache.
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.
getCancelledTaskCount() - Method in interface com.hazelcast.executor.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.
getCapacityPolicy() - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
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.
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 class com.hazelcast.cache.HazelcastExpiryPolicy
 
getClassId() - Method in class com.hazelcast.cluster.Address
 
getClassId() - Method in class com.hazelcast.config.AttributeConfig
 
getClassId() - Method in class com.hazelcast.config.AwsConfig
 
getClassId() - Method in class com.hazelcast.config.AzureConfig
 
getClassId() - Method in class com.hazelcast.config.BitmapIndexOptions
 
getClassId() - Method in class com.hazelcast.config.CacheConfig
 
getClassId() - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
 
getClassId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
getClassId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
getClassId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
getClassId() - Method in class com.hazelcast.config.CacheSimpleConfig
 
getClassId() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
getClassId() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
getClassId() - Method in class com.hazelcast.config.DiscoveryConfig
 
getClassId() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
getClassId() - Method in class com.hazelcast.config.DurableExecutorConfig
 
getClassId() - Method in class com.hazelcast.config.EntryListenerConfig
 
getClassId() - Method in class com.hazelcast.config.EurekaConfig
 
getClassId() - Method in class com.hazelcast.config.EventJournalConfig
 
getClassId() - Method in class com.hazelcast.config.EvictionConfig
 
getClassId() - Method in class com.hazelcast.config.ExecutorConfig
 
getClassId() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
getClassId() - Method in class com.hazelcast.config.GcpConfig
 
getClassId() - Method in class com.hazelcast.config.HotRestartConfig
 
getClassId() - Method in class com.hazelcast.config.IndexConfig
 
getClassId() - Method in class com.hazelcast.config.ItemListenerConfig
 
getClassId() - Method in class com.hazelcast.config.KubernetesConfig
 
getClassId() - Method in class com.hazelcast.config.ListConfig
 
getClassId() - Method in class com.hazelcast.config.ListenerConfig
 
getClassId() - Method in class com.hazelcast.config.MapConfig
 
getClassId() - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
 
getClassId() - Method in class com.hazelcast.config.MapStoreConfig
 
getClassId() - Method in class com.hazelcast.config.MergePolicyConfig
 
getClassId() - Method in class com.hazelcast.config.MerkleTreeConfig
 
getClassId() - Method in class com.hazelcast.config.MultiMapConfig
 
getClassId() - Method in class com.hazelcast.config.NearCacheConfig
 
getClassId() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
getClassId() - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
getClassId() - Method in class com.hazelcast.config.PermissionConfig
 
getClassId() - Method in class com.hazelcast.config.PNCounterConfig
 
getClassId() - Method in class com.hazelcast.config.PredicateConfig
 
getClassId() - Method in class com.hazelcast.config.QueryCacheConfig
 
getClassId() - Method in class com.hazelcast.config.QueueConfig
 
getClassId() - Method in class com.hazelcast.config.QueueStoreConfig
 
getClassId() - Method in class com.hazelcast.config.ReliableTopicConfig
 
getClassId() - Method in class com.hazelcast.config.ReplicatedMapConfig
 
getClassId() - Method in class com.hazelcast.config.RingbufferConfig
 
getClassId() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
getClassId() - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
getClassId() - Method in class com.hazelcast.config.SetConfig
 
getClassId() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
getClassId() - Method in class com.hazelcast.config.SplitBrainProtectionListenerConfig
 
getClassId() - Method in class com.hazelcast.config.TopicConfig
 
getClassId() - Method in class com.hazelcast.config.WanBatchPublisherConfig
 
getClassId() - Method in class com.hazelcast.config.WanConsumerConfig
 
getClassId() - Method in class com.hazelcast.config.WanCustomPublisherConfig
 
getClassId() - Method in class com.hazelcast.config.WanReplicationConfig
 
getClassId() - Method in class com.hazelcast.config.WanReplicationRef
 
getClassId() - Method in class com.hazelcast.config.WanSyncConfig
 
getClassId() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
Returns the class ID.
getClassId() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
getClassId() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
 
getClassId() - Method in interface com.hazelcast.nio.serialization.IdentifiedDataSerializable
Returns type identifier for this class.
getClassId() - Method in interface com.hazelcast.nio.serialization.Portable
Returns class identifier for this portable class.
getClassId() - Method in class com.hazelcast.security.SimpleTokenCredentials
 
getClassId() - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
getClassId() - Method in class com.hazelcast.spi.merge.DiscardMergePolicy
 
getClassId() - Method in class com.hazelcast.spi.merge.ExpirationTimeMergePolicy
 
getClassId() - Method in class com.hazelcast.spi.merge.HigherHitsMergePolicy
 
getClassId() - Method in class com.hazelcast.spi.merge.HyperLogLogMergePolicy
 
getClassId() - Method in class com.hazelcast.spi.merge.LatestAccessMergePolicy
 
getClassId() - Method in class com.hazelcast.spi.merge.LatestUpdateMergePolicy
 
getClassId() - Method in class com.hazelcast.spi.merge.PassThroughMergePolicy
 
getClassId() - Method in class com.hazelcast.spi.merge.PutIfAbsentMergePolicy
 
getClassId() - Method in class com.hazelcast.version.MemberVersion
 
getClassId() - Method in class com.hazelcast.version.Version
 
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.AbstractWanPublisherConfig
Returns the name of the class implementing WanPublisher.
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
Returns the class name of the queue store implementation to be used when instantiating the queue store.
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 WanConsumer.
getClassNames() - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
getClassType() - Method in interface com.hazelcast.nio.serialization.TypedDataSerializable
 
getClassVersion() - Method in interface com.hazelcast.nio.serialization.VersionedPortable
Returns version for this Portable class
getClientBlockUnmappedActions() - Method in class com.hazelcast.config.SecurityConfig
 
getClientConfigs() - Method in class com.hazelcast.client.config.ClientFailoverConfig
Gets the configured list of alternative client configurations.
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
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
 
getClientRealm() - Method in class com.hazelcast.config.SecurityConfig
 
getClientService() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the client service of this Hazelcast instance.
getClientType() - Method in interface com.hazelcast.client.Client
Type could be a client type from ConnectionType or it can be a custom client implementation with a name outside of this @{link ConnectionType}
getCloudConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
getCluster() - Method in class com.hazelcast.cluster.InitialMembershipEvent
Returns the cluster of the event.
getCluster() - Method in class com.hazelcast.cluster.MembershipEvent
Returns the cluster of the event.
getCluster() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the Cluster that this Hazelcast instance is part of.
getClusterConnectTimeoutMillis() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
Timeout value in seconds for the client to give up to connect to the current cluster Depending on FailoverConfig, a client can shutdown or start trying on alternative cluster after reaching the timeout.
getClusterDataRecoveryPolicy() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Returns the policy to be used when the cluster is started
getClusterName() - Method in class com.hazelcast.client.config.ClientConfig
Returns the configured cluster name.
getClusterName() - Method in class com.hazelcast.config.Config
Returns the cluster name uniquely identifying the hazelcast cluster.
getClusterName() - Method in class com.hazelcast.config.WanBatchPublisherConfig
Returns the cluster name used as a publisher cluster name for authentication on the target endpoint.
getClusterState() - Method in interface com.hazelcast.cluster.Cluster
Returns the state of the cluster.
getClusterTime() - Method in interface com.hazelcast.cluster.Cluster
Returns the cluster-wide time in milliseconds.
getClusterVersion() - Method in interface com.hazelcast.cluster.Cluster
The cluster version indicates the operating version of the cluster.
getCode() - Method in exception com.hazelcast.sql.HazelcastSqlException
Gets the internal error code associated with the exception.
getCollectionFrequencySeconds() - Method in class com.hazelcast.config.BaseMetricsConfig
Returns the metrics collection frequency in seconds.
getColumn(int) - Method in class com.hazelcast.sql.SqlRowMetadata
Gets column metadata.
getColumnCount() - Method in class com.hazelcast.sql.SqlRowMetadata
Gets the number of columns in the row.
getColumns() - Method in class com.hazelcast.sql.SqlRowMetadata
Gets columns metadata.
getCommitIndexAdvanceCountToSnapshot() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
getComparator() - Method in class com.hazelcast.config.EvictionConfig
Returns the instance of the configured EvictionPolicyComparator implementation.
getComparator() - Method in interface com.hazelcast.query.PagingPredicate
Returns the comparator used by this predicate (if any).
getComparatorClassName() - Method in class com.hazelcast.config.EvictionConfig
Returns the class name of the configured EvictionPolicyComparator implementation.
getCompleted() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
getCompletedMigrations() - Method in interface com.hazelcast.partition.MigrationState
Returns the number of completed migrations in the migration plan.
getCompletedTaskCount() - Method in interface com.hazelcast.executor.LocalExecutorStats
Returns the number of completed operations on the executor service.
getConfig() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the configuration of this Hazelcast instance.
getConfig() - Method in class com.hazelcast.spi.properties.HazelcastProperties
 
getConfigClassLoader() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
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.
getConfigRoot() - Method in class com.hazelcast.client.config.YamlClientConfigBuilder
 
getConfigRoot() - Method in class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
 
getConfigRoot() - Method in class com.hazelcast.config.AbstractYamlConfigBuilder
 
getConfigRoot() - Method in class com.hazelcast.config.YamlConfigBuilder
 
getConfigType() - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
 
getConfigType() - Method in class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
 
getConfigType() - Method in class com.hazelcast.config.AbstractXmlConfigBuilder
 
getConfigType() - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
getConfigType() - Method in class com.hazelcast.config.XmlConfigBuilder
 
getConfigurationFile() - Method in class com.hazelcast.config.Config
Returns the File to the declarative configuration, which has been parsed to create this Config instance.
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 declarative configuration, which has been parsed to create this Config instance.
getConnectedClients() - Method in interface com.hazelcast.client.ClientService
Returns all connected clients to this member.
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.ClientNetworkConfig
Timeout value in millis for nodes to accept client connection requests.
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.
getConsumerConfig() - Method in class com.hazelcast.config.WanReplicationConfig
Returns the WAN consumer configuration for this WAN replication.
getContextType() - Method in interface com.hazelcast.spi.tenantcontrol.DestroyEventContext
 
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.cp.ICountDownLatch
Returns the current count.
getCountDownLatch(String) - Method in interface com.hazelcast.cp.CPSubsystem
Returns a proxy for an ICountDownLatch instance created on CP Subsystem.
getCPGroup(String) - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Returns the active CP group with the given name.
getCPGroupIds() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Returns all active CP group ids.
getCPMemberCount() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the number of CP members that will initialize CP Subsystem.
getCPMembers() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Returns the current list of CP members
getCPSessionManagementService() - Method in interface com.hazelcast.cp.CPSubsystem
Returns the CPSessionManagementService of this Hazelcast instance.
getCPSubsystem() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the CP subsystem that offers a set of in-memory linearizable data structures
getCPSubsystemConfig() - Method in class com.hazelcast.config.Config
Get current configuration for the CP subsystem
getCPSubsystemManagementService() - Method in interface com.hazelcast.cp.CPSubsystem
Returns the CPSubsystemManagementService of this Hazelcast instance.
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.map.LocalMapStats
Returns the creation time of this map on this member.
getCreationTime() - Method in interface com.hazelcast.nearcache.NearCacheStats
Returns the creation time of this Near Cache on this member.
getCreationTime() - Method in interface com.hazelcast.spi.eviction.EvictableEntryView
Gets the creation time of this EvictableEntryView in milliseconds.
getCreationTime() - Method in interface com.hazelcast.spi.merge.MergingCreationTime
Returns the creation time of the merge data.
getCreationTime() - Method in interface com.hazelcast.topic.LocalTopicStats
Returns the creation time of this topic on this member
getCredentials() - Method in class com.hazelcast.config.security.CredentialsIdentityConfig
 
getCredentialsFactory() - Method in interface com.hazelcast.security.SecurityContext
Returns current ICredentialsFactory.
getCredentialsFactoryConfig() - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
getCredentialsFactoryConfig() - Method in class com.hazelcast.config.security.RealmConfig
 
getCredentialsIdentityConfig() - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
getCredentialsIdentityConfig() - Method in class com.hazelcast.config.security.RealmConfig
 
getCurrentKeyAlias() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
Returns the alias for the current encryption key entry or null if no alias is set.
getCurrentMembers() - Method in class com.hazelcast.splitbrainprotection.SplitBrainProtectionEvent
Returns the snapshot of member list at the time split brain protection happened
getCursorBufferSize() - Method in class com.hazelcast.sql.SqlStatement
Gets the cursor buffer size (measured in the number of rows).
getCustomPublisherConfigs() - Method in class com.hazelcast.config.WanReplicationConfig
Returns the list of custom WAN publisher implementations for this WAN replication.
getDataLoadTimeoutSeconds() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the timeout duration for CP members to restore their data from stable storage.
getDataLoadTimeoutSeconds() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Returns configured data load timeout for hot-restart process.
getDataSerializableFactories() - Method in class com.hazelcast.config.SerializationConfig
 
getDataSerializableFactoryClasses() - Method in class com.hazelcast.config.SerializationConfig
 
getDefault() - Static method in class com.hazelcast.transaction.TransactionOptions
Creates a new TransactionOptions configured with default settings.
getDefaultClassLoader() - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
getDefaultClassLoader() - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
 
getDefaultClassLoader() - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
 
getDefaultHazelcastInstance() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Gets the default HazelcastOSGiInstance.
getDefaultProperties() - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
getDefaultProperties() - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
 
getDefaultProperties() - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
 
getDefaultReadTimeout() - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
Return default cache value retrieval timeout in milliseconds.
getDefaultURI() - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
getDefaultURI() - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
 
getDefaultURI() - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
 
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.
getDestination() - Method in interface com.hazelcast.partition.ReplicaMigrationEvent
Returns the new owner of the migrating partition replica.
getDirectory() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
getDirectory() - Method in class com.hazelcast.config.PersistentMemoryDirectoryConfig
Returns the directory of this PersistentMemoryDirectoryConfig.
getDirectoryConfigs() - Method in class com.hazelcast.config.PersistentMemoryConfig
Returns the persistent memory directory configurations to be used to store memory structures allocated by native memory manager.
getDirtyEntryCount() - Method in interface com.hazelcast.map.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.WanBatchPublisherConfig
Returns the currently defined DiscoveryConfig used by the discovery mechanism for this WAN publisher.
getDiscoveryConfig() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
getDiscoveryMode() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
getDiscoveryNode() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
getDiscoveryPeriodSeconds() - Method in class com.hazelcast.config.WanBatchPublisherConfig
Returns the period in seconds in which WAN tries to discover new target endpoints and reestablish connections to failed endpoints.
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
 
getDistributedObjectName(String) - Static method in class com.hazelcast.cache.CacheUtil
Convenience method to obtain the name of Hazelcast distributed object corresponding to the cache identified by the given cacheName, assuming null URI and ClassLoader prefixes.
getDistributedObjectName(String, URI, ClassLoader) - Static method in class com.hazelcast.cache.CacheUtil
Convenience method to obtain the name of Hazelcast distributed object corresponding to the cache identified by the given arguments.
getDistributedObjectName() - Method in interface com.hazelcast.spi.tenantcontrol.DestroyEventContext
 
getDistributedObjects() - Method in interface com.hazelcast.core.HazelcastInstance
Returns all DistributedObjects, that is all maps, queues, topics, locks etc.
getDistributionTraitDef() - Method in class org.apache.calcite.plan.HazelcastRelOptCluster
 
getDouble(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured double value of a HazelcastProperty.
getDroppedCount() - Method in class com.hazelcast.wan.WanEventCounters.DistributedObjectWanEventCounters
Returns the number of dropped entry events
getDurability() - Method in class com.hazelcast.config.DurableExecutorConfig
Gets the durability of the executor
getDurability() - Method in class com.hazelcast.config.ScheduledExecutorConfig
Gets the durability of the executor
getDurability() - Method in class com.hazelcast.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
 
getElapsedTime() - Method in interface com.hazelcast.partition.ReplicaMigrationEvent
Returns the elapsed the time of this migration in milliseconds.
getEmptyPollOperationCount() - Method in interface com.hazelcast.collection.LocalQueueStats
Returns number of null returning poll operations.
getEmptyQueueTtl() - Method in class com.hazelcast.config.QueueConfig
Returns the TTL (time to live) for emptying the Queue.
getEnabledGroups() - Method in class com.hazelcast.config.RestApiConfig
Returns a not-null set of enabled REST endpoint groups.
getEnabledGroups() - Method in class com.hazelcast.config.RestServerEndpointConfig
Returns a not-null set of enabled REST endpoint groups.
getEncoding() - Method in class com.hazelcast.config.security.TokenIdentityConfig
 
getEncodingForBytes(byte[]) - Static method in enum com.hazelcast.config.security.TokenEncoding
 
getEncryptionAtRestConfig() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Returns the Hot Restart Encryption at Rest configuration.
getEndpoint() - Method in class com.hazelcast.config.WanBatchPublisherConfig
Returns the WAN endpoint configuration qualifier.
getEndpointConfigs() - Method in class com.hazelcast.config.AdvancedNetworkConfig
 
getEndpoints() - Method in class com.hazelcast.config.PermissionConfig
 
getEntryListenerConfigs() - Method in class com.hazelcast.config.MapConfig
 
getEntryListenerConfigs() - Method in class com.hazelcast.config.MultiMapConfig
Gets the list of entry listeners (listens for when entries are added or removed) for this MultiMap.
getEntryListenerConfigs() - Method in class com.hazelcast.config.QueryCacheConfig
 
getEntryObject() - Method in interface com.hazelcast.query.PredicateBuilder
 
getEntryView(K) - Method in interface com.hazelcast.map.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 ClusterProperty.
getEpochStart() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
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.WanBatchPublisherConfig
Returns the EurekaConfig used by the discovery mechanism for this WAN publisher.
getEventCounterMap() - Method in class com.hazelcast.wan.WanEventCounters
Returns a map from distributed object name to WanEventCounters.DistributedObjectWanEventCounters.
getEventJournalConfig() - Method in class com.hazelcast.config.AbstractCacheConfig
Gets the EventJournalConfig for this CacheConfiguration
getEventJournalConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the EventJournalConfig for this CacheSimpleConfig
getEventJournalConfig() - Method in class com.hazelcast.config.MapConfig
Gets the EventJournalConfig for this MapConfig
getEventObject() - Method in interface com.hazelcast.wan.WanEvent
Returns the event object/data.
getEventOperationCount() - Method in interface com.hazelcast.collection.LocalQueueStats
Returns number of event operations
getEventOperationCount() - Method in interface com.hazelcast.map.LocalMapStats
Returns the number of Events Received
getEventSource() - Method in interface com.hazelcast.partition.PartitionLostEvent
Returns the address of the node that dispatches the event
getEventType() - Method in class com.hazelcast.cluster.MembershipEvent
Returns the membership event type; #MEMBER_ADDED #MEMBER_REMOVED
getEventType() - Method in class com.hazelcast.collection.ItemEvent
Returns the event type.
getEventType() - Method in class com.hazelcast.core.DistributedObjectEvent
getEventType() - Method in class com.hazelcast.map.AbstractIMapEvent
Returns the event type EntryEventType.
getEventType() - Method in class com.hazelcast.map.EventLostEvent
Intentionally returns null.
getEventType() - Method in interface com.hazelcast.map.IMapEvent
Return the event type
getEventType() - Method in interface com.hazelcast.wan.WanEvent
Returns the type of this event.
getEvictionConfig() - Method in class com.hazelcast.config.CacheConfig
Gets the EvictionConfig instance of the eviction configuration for this ICache.
getEvictionConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the eviction configuration for this ICache.
getEvictionConfig() - Method in class com.hazelcast.config.MapConfig
Gets the EvictionConfig instance of the eviction configuration for this IMap.
getEvictionConfig() - Method in class com.hazelcast.config.NearCacheConfig
Returns the eviction configuration for this Near Cache.
getEvictionConfig() - Method in class com.hazelcast.config.QueryCacheConfig
Returns EvictionConfig instance for this QueryCache
getEvictionConfig(Node, boolean, boolean) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
getEvictionPolicy() - Method in class com.hazelcast.config.EvictionConfig
Returns the EvictionPolicy of this eviction configuration.
getEvictions() - Method in interface com.hazelcast.nearcache.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.
getEx() - Method in interface com.hazelcast.function.SupplierEx
Exception-declaring version of Supplier.get().
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.
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.config.SqlConfig
Gets the number of threads responsible for execution of SQL statements.
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.nearcache.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 class com.hazelcast.map.EntryLoader.MetadataAwareValue
The expiration date of this 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
 
getExtractorClassName() - Method in class com.hazelcast.config.AttributeConfig
Gets the full class name of the extractor in a String format, e.g.
getFactoryClassName() - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
Returns the factory class name.
getFactoryClassName() - Method in class com.hazelcast.config.MapStoreConfig
Returns the name of the MapStoreFactory implementation class
getFactoryClassName() - Method in class com.hazelcast.config.QueueStoreConfig
Returns the factory class name which will be used to instantiate the queue store.
getFactoryClassName() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
getFactoryId() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
 
getFactoryId() - Method in class com.hazelcast.cluster.Address
 
getFactoryId() - Method in class com.hazelcast.config.AbstractCacheConfig
 
getFactoryId() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
 
getFactoryId() - Method in class com.hazelcast.config.AttributeConfig
 
getFactoryId() - Method in class com.hazelcast.config.BitmapIndexOptions
 
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.DiscoveryConfig
 
getFactoryId() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
getFactoryId() - Method in class com.hazelcast.config.DurableExecutorConfig
 
getFactoryId() - Method in class com.hazelcast.config.EventJournalConfig
 
getFactoryId() - Method in class com.hazelcast.config.EvictionConfig
 
getFactoryId() - Method in class com.hazelcast.config.ExecutorConfig
 
getFactoryId() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
getFactoryId() - Method in class com.hazelcast.config.HotRestartConfig
 
getFactoryId() - Method in class com.hazelcast.config.IndexConfig
 
getFactoryId() - Method in class com.hazelcast.config.ListenerConfig
 
getFactoryId() - Method in class com.hazelcast.config.MapConfig
 
getFactoryId() - Method in class com.hazelcast.config.MapStoreConfig
 
getFactoryId() - Method in class com.hazelcast.config.MergePolicyConfig
 
getFactoryId() - Method in class com.hazelcast.config.MerkleTreeConfig
 
getFactoryId() - Method in class com.hazelcast.config.MultiMapConfig
 
getFactoryId() - Method in class com.hazelcast.config.NearCacheConfig
 
getFactoryId() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
getFactoryId() - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
getFactoryId() - Method in class com.hazelcast.config.PermissionConfig
 
getFactoryId() - Method in class com.hazelcast.config.PNCounterConfig
 
getFactoryId() - Method in class com.hazelcast.config.PredicateConfig
 
getFactoryId() - Method in class com.hazelcast.config.QueryCacheConfig
 
getFactoryId() - Method in class com.hazelcast.config.QueueConfig
 
getFactoryId() - Method in class com.hazelcast.config.QueueStoreConfig
 
getFactoryId() - Method in class com.hazelcast.config.ReliableTopicConfig
 
getFactoryId() - Method in class com.hazelcast.config.ReplicatedMapConfig
 
getFactoryId() - Method in class com.hazelcast.config.RingbufferConfig
 
getFactoryId() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
getFactoryId() - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
getFactoryId() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
getFactoryId() - Method in class com.hazelcast.config.TopicConfig
 
getFactoryId() - Method in class com.hazelcast.config.WanBatchPublisherConfig
 
getFactoryId() - Method in class com.hazelcast.config.WanConsumerConfig
 
getFactoryId() - Method in class com.hazelcast.config.WanCustomPublisherConfig
 
getFactoryId() - Method in class com.hazelcast.config.WanReplicationConfig
 
getFactoryId() - Method in class com.hazelcast.config.WanReplicationRef
 
getFactoryId() - Method in class com.hazelcast.config.WanSyncConfig
 
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.security.SimpleTokenCredentials
 
getFactoryId() - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
getFactoryId() - Method in class com.hazelcast.version.MemberVersion
 
getFactoryId() - Method in class com.hazelcast.version.Version
 
getFactoryImpl() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
 
getFactoryImplementation() - Method in class com.hazelcast.config.MapStoreConfig
Returns the map store factory implementation object.
getFactoryImplementation() - Method in class com.hazelcast.config.QueueStoreConfig
Returns the queue store factory implementation which will be used to instantiate the queue store.
getFactoryImplementation() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
getFactoryImplementation() - Method in class com.hazelcast.config.SSLConfig
Returns the factory implementation object.
getFence() - Method in interface com.hazelcast.cp.lock.FencedLock
Returns the fencing token if the lock is held by the current thread.
getField(String) - Method in 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.GenericRecord
 
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.GenericRecord
 
getFieldType(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
getFileName() - Method in class com.hazelcast.config.InstanceTrackingConfig
Returns the name of the file which will contain the tracking metadata.
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.
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.
getFormatPattern() - Method in class com.hazelcast.config.InstanceTrackingConfig
Returns the pattern used to render the contents of the instance tracking file.
getForUpdate(Object) - Method in interface com.hazelcast.transaction.TransactionalMap
Locks the key and then gets and returns the value to which the specified key is mapped.
getFunction() - Method in class com.hazelcast.spi.properties.HazelcastProperty
 
getFunctionClassName() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
getFunctionImplementation() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
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.WanBatchPublisherConfig
Returns the GcpConfig used by the discovery mechanism for this WAN publisher.
getGetOperationCount() - Method in interface com.hazelcast.map.LocalMapStats
Returns the number of get operations
getGlobalSerializerConfig() - Method in class com.hazelcast.config.SerializationConfig
 
getGroupId() - Method in interface com.hazelcast.cp.event.CPGroupAvailabilityEvent
Returns the id of the related CP group.
getGroupId() - Method in exception com.hazelcast.cp.exception.CPGroupDestroyedException
 
getGroupId() - Method in interface com.hazelcast.cp.lock.FencedLock
Returns id of the CP group that runs this FencedLock instance
getGroupMembers() - Method in interface com.hazelcast.cp.event.CPGroupAvailabilityEvent
Returns the current members of the CP group.
getGroupSize() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the number of CP members to form CP groups.
getGroupType() - Method in class com.hazelcast.config.PartitionGroupConfig
Returns the MemberGroupType configured.
getHandler() - Method in 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.
getHazelcastInstance() - Method in interface com.hazelcast.cache.HazelcastCacheManager
Gets the underlying HazelcastInstance implementation.
getHazelcastInstance() - Method in class com.hazelcast.security.HazelcastInstanceCallback
 
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.
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.map.LocalMapStats
Cost of map & Near Cache & backup & Merkle trees in bytes
getHitCount() - Method in interface com.hazelcast.query.LocalIndexStats
Returns the total number of hits into the index.
getHits() - Method in interface com.hazelcast.cache.CacheEntryView
Gets the count of how many time this cache entry has been accessed.
getHits() - Method in interface com.hazelcast.core.EntryView
Returns number of hits of the entry.
getHits() - Method in interface com.hazelcast.map.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.nearcache.NearCacheStats
Returns the number of hits (reads) of Near Cache entries owned by this member.
getHits() - Method in interface com.hazelcast.spi.eviction.EvictableEntryView
Gets the access hit count of this EvictableEntryView.
getHits() - Method in interface com.hazelcast.spi.merge.MergingHits
Returns the access hits of the merge data.
getHost() - Method in class com.hazelcast.cluster.Address
 
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.cluster.Cluster
Returns the Hot Restart service for interacting with Hot Restart.
getIcmpFailureDetectorConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig
Returns the current IcmpFailureDetectorConfig.
getIcmpFailureDetectorConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getIcmpFailureDetectorConfig() - Method in class com.hazelcast.config.NetworkConfig
Returns the current IcmpFailureDetectorConfig.
getId() - Method in enum com.hazelcast.cluster.ClusterState
 
getId() - Method in enum com.hazelcast.config.BitmapIndexOptions.UniqueKeyTransformation
 
getId() - Method in enum com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
 
getId() - Method in enum com.hazelcast.config.ConsistencyCheckStrategy
Gets the ID for this ConsistencyCheckStrategy.
getId() - Method in enum com.hazelcast.config.EvictionPolicy
 
getId() - Method in enum com.hazelcast.config.IndexType
Gets the ID for the given IndexType.
getId() - Method in enum com.hazelcast.config.InMemoryFormat
 
getId() - Method in enum com.hazelcast.config.MaxSizePolicy
 
getId() - Method in enum com.hazelcast.config.MetadataPolicy
Returns enumeration id of this policy.
getId() - Method in enum com.hazelcast.config.ScheduledExecutorConfig.CapacityPolicy
 
getId() - Method in enum com.hazelcast.config.WanAcknowledgeType
Gets the ID for the given WanAcknowledgeType.
getId() - Method in enum com.hazelcast.config.WanQueueFullBehavior
Gets the ID for the given WanQueueFullBehavior.
getId() - Method in interface com.hazelcast.cp.CPGroupId
Returns unique id of the CP group.
getId() - Method in enum com.hazelcast.nio.serialization.FieldType
 
getId() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Gets the ID of service.
getId() - Method in enum com.hazelcast.ringbuffer.OverflowPolicy
Gets the ID for the given OverflowPolicy.
getId() - Method in enum com.hazelcast.sql.SqlColumnType
Gets the ID for the given SqlColumnType.
getId() - Method in enum com.hazelcast.wan.WanPublisherState
Returns the ID of the WAN publisher state.
getIdleMaxParkNs() - Method in class com.hazelcast.config.WanBatchPublisherConfig
Returns the maximum duration in nanoseconds that the WAN replication thread will be parked if there are no events to replicate.
getIdleMinParkNs() - Method in class com.hazelcast.config.WanBatchPublisherConfig
Returns the minimum duration in nanoseconds that the WAN replication thread will be parked if there are no events to replicate.
getImplementation() - Method in class com.hazelcast.config.AbstractWanPublisherConfig
Returns the implementation of WanPublisher.
getImplementation() - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
 
getImplementation() - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
getImplementation() - Method in class com.hazelcast.config.EntryListenerConfig
 
getImplementation() - Method in class com.hazelcast.config.GlobalSerializerConfig
 
getImplementation() - Method in class com.hazelcast.config.ItemListenerConfig
 
getImplementation() - Method in class com.hazelcast.config.ListenerConfig
Returns the EventListener implementation.
getImplementation() - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
 
getImplementation() - Method in class com.hazelcast.config.MapStoreConfig
Returns the map store implementation object.
getImplementation() - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
getImplementation() - Method in class com.hazelcast.config.PermissionPolicyConfig
 
getImplementation() - Method in class com.hazelcast.config.PredicateConfig
Returns the Predicate implementation.
getImplementation() - Method in class com.hazelcast.config.SecurityInterceptorConfig
 
getImplementation() - Method in class com.hazelcast.config.SerializerConfig
Returns the implementation of the serializer class.
getImplementation() - Method in class com.hazelcast.config.ServiceConfig
 
getImplementation() - Method in class com.hazelcast.config.SocketInterceptorConfig
Returns the SocketInterceptor implementation object.
getImplementation() - Method in class com.hazelcast.config.SplitBrainProtectionListenerConfig
 
getImplementation() - Method in class com.hazelcast.config.WanBatchPublisherConfig
 
getImplementation() - Method in class com.hazelcast.config.WanConsumerConfig
Returns the implementation implementing WanConsumer.
getIndex() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
 
getIndexConfigs() - Method in class com.hazelcast.config.MapConfig
 
getIndexConfigs() - Method in class com.hazelcast.config.QueryCacheConfig
 
getIndexedQueryCount() - Method in interface com.hazelcast.map.LocalMapStats
Returns the total number of indexed queries performed on the map.
getIndexStats() - Method in interface com.hazelcast.map.LocalMapStats
Returns the per-index statistics map keyed by the index name.
getInetAddress() - Method in class com.hazelcast.cluster.Address
 
getInetSocketAddress() - Method in class com.hazelcast.cluster.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.cp.SemaphoreConfig
Returns initial permit count of the Semaphore
getInitialPublisherState() - Method in class com.hazelcast.config.WanBatchPublisherConfig
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
Returns the in-memory format.
getInsertCount() - Method in interface com.hazelcast.query.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.
getInstanceTrackingConfig() - Method in class com.hazelcast.client.config.ClientConfig
Returns the configuration for tracking use of this Hazelcast instance.
getInstanceTrackingConfig() - Method in class com.hazelcast.config.Config
Returns the configuration for tracking use of this Hazelcast instance.
getInteger(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured int value of a HazelcastProperty.
getInterfaces() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getInterfaces() - Method in class com.hazelcast.config.EndpointConfig
 
getInterfaces() - Method in class com.hazelcast.config.InterfacesConfig
 
getInterfaces() - Method in class com.hazelcast.config.MemberGroupConfig
Gets an unmodifiable collection containing all interfaces.
getInterfaces() - Method in class com.hazelcast.config.NetworkConfig
 
getIntervalMilliseconds() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
getIntervalMilliseconds() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
getInvalidations() - Method in interface com.hazelcast.nearcache.NearCacheStats
Returns the number of invalidations of Near Cache entries owned by this member.
getItem() - Method in class com.hazelcast.collection.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.QueueConfig
Get the list of item listener configurations for this queue.
getItems() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Returns the array representing this ringbuffer.
getIterationCount() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
getJaasAuthenticationConfig() - Method in class com.hazelcast.config.security.RealmConfig
 
getJarPaths() - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
getJavaSerializationFilterConfig() - Method in class com.hazelcast.config.SerializationConfig
 
getJitter() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
by how much to randomize backoffs.
getJmxConfig() - Method in class com.hazelcast.config.BaseMetricsConfig
 
getJoin() - Method in class com.hazelcast.config.AdvancedNetworkConfig
Returns the JoinConfig.
getJoin() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getJoin() - Method in class com.hazelcast.config.NetworkConfig
Returns the JoinConfig.
getKerberosAuthenticationConfig() - Method in class com.hazelcast.config.security.RealmConfig
 
getKerberosIdentityConfig() - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
getKerberosIdentityConfig() - Method in class com.hazelcast.config.security.RealmConfig
 
getKey() - Method in interface com.hazelcast.cache.CacheEntryView
Gets the key of the cache entry.
getKey() - Method in interface com.hazelcast.cache.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.map.EventJournalMapEvent
Returns the key for the event entry.
getKey() - Method in class com.hazelcast.partition.PartitionAwareKey
Gets the key (not the partitionKey).
getKey() - Method in interface com.hazelcast.spi.eviction.EvictableEntryView
Gets the key of the entry.
getKey() - Method in interface com.hazelcast.spi.merge.MergingEntry
Returns the deserialized merging key.
getKeyClassName() - Method in class com.hazelcast.config.AbstractCacheConfig
 
getKeySize() - Method in class com.hazelcast.config.EncryptionAtRestConfig
Returns the size (in bits) of the Hot Restart Store-level encryption key.
getKeytabFile() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
 
getKeytabFile() - Method in class com.hazelcast.config.security.KerberosIdentityConfig
 
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.WanBatchPublisherConfig
Returns the KubernetesConfig used by the discovery mechanism for this WAN publisher.
getLabels() - Method in interface com.hazelcast.client.Client
 
getLabels() - Method in class com.hazelcast.client.config.ClientConfig
 
getLargestSequence() - Method in interface com.hazelcast.ringbuffer.RingbufferStore
Return the largest sequence seen by the data store.
getLastAccessTime() - Method in interface com.hazelcast.cache.CacheEntryView
Gets the last access time in milliseconds of the cache entry.
getLastAccessTime() - Method in interface com.hazelcast.cache.CacheStatistics
Gets the last access time to cache.
getLastAccessTime() - Method in interface com.hazelcast.collection.LocalCollectionStats
Returns the last access (read) time of the list.
getLastAccessTime() - Method in interface com.hazelcast.core.EntryView
Returns the last access time for the entry.
getLastAccessTime() - Method in interface com.hazelcast.map.LocalMapStats
Returns the last access (read) time of the locally owned entries.
getLastAccessTime() - Method in interface com.hazelcast.spi.eviction.EvictableEntryView
Gets the latest access time difference of this EvictableEntryView in milliseconds.
getLastAccessTime() - Method in interface com.hazelcast.spi.merge.MergingLastAccessTime
Returns the last access time of the merge data.
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.nearcache.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.nearcache.NearCacheStats
Returns the failure reason of the last Near Cache persistence (when the pre-load feature is enabled).
getLastPersistenceKeyCount() - Method in interface com.hazelcast.nearcache.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.nearcache.NearCacheStats
Returns the timestamp of the last Near Cache key persistence (when the pre-load feature is enabled).
getLastPersistenceWrittenBytes() - Method in interface com.hazelcast.nearcache.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.
getLastUpdateTime() - Method in interface com.hazelcast.cache.CacheStatistics
Gets the last update time to cache.
getLastUpdateTime() - Method in interface com.hazelcast.collection.LocalCollectionStats
Returns the last update time of the list.
getLastUpdateTime() - Method in interface com.hazelcast.core.EntryView
Returns the last time the value was updated.
getLastUpdateTime() - Method in interface com.hazelcast.map.LocalMapStats
Returns the last update time of the locally owned entries.
getLastUpdateTime() - Method in interface com.hazelcast.spi.merge.MergingLastUpdateTime
Returns the last update time of the merge data.
getLdapAuthenticationConfig() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
 
getLdapAuthenticationConfig() - Method in class com.hazelcast.config.security.RealmConfig
 
getLeaderElectionTimeoutInMillis() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
getLeaderHeartbeatPeriodInMillis() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
getLeaderUuid() - Method in exception com.hazelcast.cp.exception.CPSubsystemException
Returns the leader endpoint of related CP group, if known/available by the time this exception is thrown.
getLevel() - Method in interface com.hazelcast.logging.ILogger
Gets the logging level.
getLevel() - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
 
getLicenseKey() - Method in class com.hazelcast.config.Config
Returns the license key for this hazelcast instance.
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.
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.ReplicatedMapConfig
 
getListenerConfigs() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
getListenerConfigurations() - Method in class com.hazelcast.config.AbstractCacheConfig
 
getLoadBalancer() - Method in class com.hazelcast.client.config.ClientConfig
Gets LoadBalancer
getLoadBalancerClassName() - Method in class com.hazelcast.client.config.ClientConfig
Gets load balancer class name
getLocalCacheStatistics() - Method in interface com.hazelcast.cache.ICache
Directly access local Cache Statistics.
getLocalCPMember() - Method in interface com.hazelcast.cp.CPSubsystem
Returns the local CP member if this Hazelcast member is part of CP Subsystem, returns null otherwise.
getLocalCPMember() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Returns the local CP member if this Hazelcast member is part of CP Subsystem, returns null otherwise.
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.
getLocalListStats() - Method in interface com.hazelcast.collection.IList
Returns LocalListStats for this collection.
getLocalMapStats() - Method in interface com.hazelcast.map.IMap
Returns LocalMapStats for this map.
getLocalMember() - Method in interface com.hazelcast.cluster.Cluster
Returns this Hazelcast instance member.
getLocalMultiMapStats() - Method in interface com.hazelcast.multimap.MultiMap
Returns LocalMultiMapStats for this map.
getLocalQueueStats() - Method in interface com.hazelcast.collection.IQueue
Returns LocalQueueStats for this queue.
getLocalSetStats() - Method in interface com.hazelcast.collection.ISet
Returns LocalSetStats for this collection.
getLocalTopicStats() - Method in interface com.hazelcast.topic.ITopic
Returns statistics about this topic, like total number of publishes/receives.
getLocalUpdatePolicy() - Method in class com.hazelcast.config.NearCacheConfig
Returns the NearCacheConfig.LocalUpdatePolicy of this Near Cache.
getLock(String) - Method in interface com.hazelcast.cp.CPSubsystem
Returns a proxy for an FencedLock instance created on CP Subsystem.
getLockAcquireLimit() - Method in class com.hazelcast.config.cp.FencedLockConfig
Returns the maximum number of lock acquires a lock holder can perform.
getLockConfigs() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the map of FencedLock configurations
getLockCount() - Method in interface com.hazelcast.cp.lock.FencedLock
Returns the reentrant lock count if the lock is held by any thread in the cluster.
getLockedEntryCount() - Method in interface com.hazelcast.map.LocalMapStats
Returns the number of currently locked 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.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
 
getLoggingService() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the logging service of this Hazelcast instance.
getLoggingService() - Method in class com.hazelcast.security.LoggingServiceCallback
 
getLoginModuleConfigs() - Method in class com.hazelcast.config.security.JaasAuthenticationConfig
 
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.
getLostBackupCount() - Method in interface com.hazelcast.partition.PartitionLostEvent
Returns the number of lost backups for the partition.
getMajor() - Method in class com.hazelcast.version.MemberVersion
 
getMajor() - Method in class com.hazelcast.version.Version
 
getMajority() - Method in interface com.hazelcast.cp.event.CPGroupAvailabilityEvent
Returns the majority member count of the CP group.
getManagedContext() - Method in class com.hazelcast.client.config.ClientConfig
getManagedContext() - Method in class com.hazelcast.config.Config
Returns the external managed context.
getManagementCenterConfig() - Method in class com.hazelcast.config.Config
Returns the management center configuration for this hazelcast instance.
getManagementCenterConfig() - Method in class com.hazelcast.config.MetricsConfig
 
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.
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.
getMapStoreConfig() - Method in class com.hazelcast.config.MapConfig
Returns the map store configuration
getMaxAge() - Method in interface com.hazelcast.collection.LocalQueueStats
Returns the maximum age of the items in this member.
getMaxAttempts() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
getMaxAttempts() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
getMaxBackoffMillis() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
When backoff reaches this upper bound, it does not increase any more.
getMaxConcurrentInvocations() - Method in class com.hazelcast.config.WanBatchPublisherConfig
Returns the maximum number of WAN event batches being sent to the target cluster concurrently.
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.map.LocalMapStats
Returns the maximum latency of get operations.
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).
getMaxMissedLeaderHeartbeatCount() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
getMaxPutLatency() - Method in interface com.hazelcast.map.LocalMapStats
Returns the maximum latency of put operations.
getMaxRemoveLatency() - Method in interface com.hazelcast.map.LocalMapStats
Returns the maximum latency of remove operations.
getMaxSetLatency() - Method in interface com.hazelcast.map.LocalMapStats
Returns the maximum latency of set operations.
getMaxSize() - Method in class com.hazelcast.config.CollectionConfig
Gets the maximum size for the Configuration.
getMaxSize() - Method in class com.hazelcast.config.QueueConfig
Returns the maximum size of the Queue.
getMaxSizePolicy() - Method in class com.hazelcast.config.EvictionConfig
Returns the MaxSizePolicy of this eviction configuration.
getMaxTargetEndpoints() - Method in class com.hazelcast.config.WanBatchPublisherConfig
Returns the maximum number of endpoints that WAN will connect to when using a discovery mechanism to define endpoints.
getMember() - Method in class com.hazelcast.cluster.MembershipEvent
Returns the removed or added member.
getMember() - Method in class com.hazelcast.collection.ItemEvent
Returns the member that fired this event.
getMember() - Method in exception com.hazelcast.core.MemberLeftException
Returns the member that left the cluster
getMember() - Method in interface com.hazelcast.cp.event.CPMembershipEvent
Returns the CPMember that is added to or removed from CP Subsystem.
getMember() - Method in class com.hazelcast.logging.LogEvent
 
getMember() - Method in class com.hazelcast.map.AbstractIMapEvent
Returns the member that fired this event.
getMember() - Method in class com.hazelcast.map.EventLostEvent
 
getMember() - Method in interface com.hazelcast.map.IMapEvent
Returns the member that fired this event.
getMemberAddressProviderConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig
 
getMemberAddressProviderConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getMemberAddressProviderConfig() - Method in class com.hazelcast.config.NetworkConfig
 
getMemberAttributeConfig() - Method in class com.hazelcast.config.Config
Returns the member attribute configuration.
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
 
getMemberRealm() - Method in class com.hazelcast.config.SecurityConfig
 
getMembers() - Method in interface com.hazelcast.cluster.Cluster
Set of the current members in the cluster.
getMembers() - Method in class com.hazelcast.cluster.InitialMembershipEvent
Returns an immutable set of ordered members at the moment this InitialMembershipListener is registered.
getMembers() - Method in class com.hazelcast.cluster.MembershipEvent
Returns a consistent view of the the members immediately after this MembershipEvent has been processed.
getMembers() - Method in class com.hazelcast.config.TcpIpConfig
Gets a list of all the well known members.
getMemcacheProtocolConfig() - Method in class com.hazelcast.config.NetworkConfig
 
getMemoryCost() - Method in interface com.hazelcast.query.LocalIndexStats
Returns the memory cost of the index in bytes.
getMergePolicy(String) - Method in class com.hazelcast.spi.merge.SplitBrainMergePolicyProvider
Resolves the SplitBrainMergePolicy class by its classname.
getMergePolicyClassName() - 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.
getMergePolicyConfig() - Method in class com.hazelcast.config.CacheConfig
Gets the MergePolicyConfig for this map.
getMergePolicyConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the MergePolicyConfig for this map.
getMergePolicyConfig() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Gets the MergePolicyConfig for the cardinality estimator.
getMergePolicyConfig() - Method in class com.hazelcast.config.CollectionConfig
Gets the MergePolicyConfig for the collection.
getMergePolicyConfig() - Method in class com.hazelcast.config.MapConfig
Gets the MergePolicyConfig for this map.
getMergePolicyConfig() - Method in class com.hazelcast.config.MultiMapConfig
Gets the MergePolicyConfig for this MultiMap.
getMergePolicyConfig() - Method in class com.hazelcast.config.QueueConfig
Gets the MergePolicyConfig for this queue.
getMergePolicyConfig() - Method in class com.hazelcast.config.ReplicatedMapConfig
Gets the MergePolicyConfig for this replicated map.
getMergePolicyConfig() - Method in class com.hazelcast.config.RingbufferConfig
Gets the MergePolicyConfig for this ringbuffer.
getMergePolicyConfig() - Method in class com.hazelcast.config.ScheduledExecutorConfig
Gets the MergePolicyConfig for the scheduler.
getMergingValue() - Method in class com.hazelcast.core.EntryEvent
Returns the incoming merging value of the entry event.
getMerkleTreeConfig() - Method in class com.hazelcast.config.MapConfig
Gets the MerkleTreeConfig for this MapConfig
getMerkleTreesCost() - Method in interface com.hazelcast.map.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.
getMessageObject() - Method in class com.hazelcast.topic.Message
Returns the published message
getMetadata() - Method in interface com.hazelcast.sql.SqlRow
Gets row metadata.
getMetadataPolicy() - Method in class com.hazelcast.config.MapConfig
Returns MetadataPolicy for this map.
getMetadataSpacePercentage() - Method in class com.hazelcast.config.NativeMemoryConfig
Returns the percentage of native memory space to be used to store metadata and internal memory structures by the native memory manager.
getMetricsConfig() - Method in class com.hazelcast.client.config.ClientConfig
Returns the metrics collection config.
getMetricsConfig() - Method in class com.hazelcast.config.Config
Returns the metrics collection config.
getMigrationState() - Method in interface com.hazelcast.partition.ReplicaMigrationEvent
Returns the progress information of the overall migration.
getMillis(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured value of a HazelcastProperty converted to milliseconds.
getMinAge() - Method in interface com.hazelcast.collection.LocalQueueStats
Returns the minimum age of the items in this member.
getMinBlockSize() - Method in class com.hazelcast.config.NativeMemoryConfig
Returns the minimum memory block size, in bytes, to be served by native memory manager.
getMinimumClusterSize() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
getMinor() - Method in class com.hazelcast.version.MemberVersion
 
getMinor() - Method in class com.hazelcast.version.Version
 
getMisses() - Method in interface com.hazelcast.nearcache.NearCacheStats
Returns the number of misses of Near Cache entries owned by this member.
getMissingCPMemberAutoRemovalSeconds() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the duration to wait before automatically removing a missing CP member from CP Subsystem
getMode() - Method in class com.hazelcast.config.PersistentMemoryConfig
Returns the mode in which the persistent memory should be used.
getModeName() - Method in enum com.hazelcast.config.InstanceTrackingConfig.InstanceMode
Returns the string representation of the instance mode name.
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
getName() - Method in interface com.hazelcast.client.Client
This method may return null depending on the client version and the client type Java client provides client name starting with 3.12
getName() - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
Returns the configuration name.
getName() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
Gets the name of the reliable topic.
getName() - Method in interface com.hazelcast.collection.ICollection
Returns the name of this collection.
getName() - Method in class com.hazelcast.config.AttributeConfig
Gets the name of the attribute extracted by the extractor.
getName() - Method in class com.hazelcast.config.CacheConfig
Gets the name of this ICache.
getName() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the name of this ICache.
getName() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Gets the name of the cardinality estimator.
getName() - Method in class com.hazelcast.config.CollectionConfig
Gets the name of this collection.
getName() - Method in class com.hazelcast.config.cp.FencedLockConfig
Returns the name of FencedLock
getName() - Method in class com.hazelcast.config.cp.SemaphoreConfig
Returns the name of CP ISemaphore
getName() - Method in class com.hazelcast.config.DurableExecutorConfig
Gets the name of the executor task.
getName() - Method in class com.hazelcast.config.EndpointConfig
 
getName() - Method in class com.hazelcast.config.ExecutorConfig
Gets the name of the executor task.
getName() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Returns the configuration name.
getName() - Method in class com.hazelcast.config.IndexConfig
Gets name of the index.
getName() - Method in class com.hazelcast.config.MapConfig
Returns the name of this IMap
getName() - Method in class com.hazelcast.config.MultiMapConfig
Gets the name of this MultiMap.
getName() - Method in interface com.hazelcast.config.NamedConfig
 
getName() - Method in class com.hazelcast.config.NearCacheConfig
Returns the name of the Near Cache.
getName() - Method in class com.hazelcast.config.PermissionConfig
 
getName() - Method in class com.hazelcast.config.PNCounterConfig
Gets the name of the PN counter.
getName() - Method in class com.hazelcast.config.QueryCacheConfig
Returns the name of QueryCache.
getName() - Method in class com.hazelcast.config.QueueConfig
 
getName() - Method in class com.hazelcast.config.ReliableTopicConfig
Gets the name of the reliable topic.
getName() - Method in class com.hazelcast.config.ReplicatedMapConfig
Returns the name of this ReplicatedMap.
getName() - Method in class com.hazelcast.config.RingbufferConfig
Returns the name of the ringbuffer.
getName() - Method in class com.hazelcast.config.ScheduledExecutorConfig
Gets the name of the executor task.
getName() - Method in class com.hazelcast.config.ServiceConfig
 
getName() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
getName() - Method in class com.hazelcast.config.TopicConfig
Gets the name of the topic, null if nothing is set.
getName() - Method in class com.hazelcast.config.WanReplicationConfig
 
getName() - Method in class com.hazelcast.config.WanReplicationRef
Returns the WAN replication reference name.
getName() - Method in interface com.hazelcast.core.DistributedObject
Returns the unique name for this DistributedObject.
getName(DistributedObject) - Static method in class com.hazelcast.core.DistributedObjectUtil
Gets the name of the given distributed object.
getName() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the name of this Hazelcast instance.
getName() - Method in interface com.hazelcast.cp.CPGroupId
Returns name of the CP group.
getName() - Method in interface com.hazelcast.cp.IAtomicLong
Returns the name of this IAtomicLong instance.
getName() - Method in interface com.hazelcast.cp.ISemaphore
Returns the name of this ISemaphore instance.
getName() - Method in class com.hazelcast.map.AbstractIMapEvent
Returns the name of the map for this event.
getName() - Method in class com.hazelcast.map.EventLostEvent
 
getName() - Method in interface com.hazelcast.map.IMapEvent
Returns the name of the map for this event.
getName() - Method in interface com.hazelcast.map.QueryCache
Returns the name of this QueryCache.
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.security.Credentials
 
getName() - Method in class com.hazelcast.security.SimpleTokenCredentials
Simple implementation which returns "<empty>" for null tokens and "<token>" for all other tokens.
getName() - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
getName() - Method in class com.hazelcast.spi.properties.HazelcastProperty
Returns the property name.
getName() - Method in class com.hazelcast.spring.cache.HazelcastCache
 
getName() - Method in class com.hazelcast.sql.SqlColumnMetadata
Get column name.
getName() - Method in interface com.hazelcast.topic.ITopic
Returns the name of this ITopic instance.
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
getNearCacheConfigMap() - Method in class com.hazelcast.client.config.ClientConfig
Map of all configured NearCacheConfig's with the name key and configuration as the value
getNearCacheStatistics() - Method in interface com.hazelcast.cache.CacheStatistics
Gets the Near Cache statistics.
getNearCacheStats() - Method in interface com.hazelcast.map.LocalMapStats
Returns statistics related to the Near Cache.
getNetworkConfig() - Method in class com.hazelcast.client.config.ClientConfig
getNetworkConfig() - Method in class com.hazelcast.config.Config
Returns the network configuration for this hazelcast instance.
getNewValue() - Method in interface com.hazelcast.cache.EventJournalCacheEvent
Returns the new value for the event entry.
getNewValue() - Method in interface com.hazelcast.map.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.
getNodeFilter() - Method in class com.hazelcast.config.DiscoveryConfig
 
getNodeFilterClass() - Method in class com.hazelcast.config.DiscoveryConfig
 
getNodeIdOffset() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
getNodeName() - Method in enum com.hazelcast.config.PermissionConfig.PermissionType
 
getNumaNode() - Method in class com.hazelcast.config.PersistentMemoryDirectoryConfig
Returns the NUMA node the persistent memory mounted to the given directory is attached to.
getNumberOfEntriesAffected() - Method in class com.hazelcast.map.MapEvent
Returns the number of entries affected by this event.
getObject(int) - Method in interface com.hazelcast.sql.SqlRow
Gets the value of the column by index.
getObject(String) - Method in interface com.hazelcast.sql.SqlRow
Gets the value of the column by column name.
getObjectName() - Method in class com.hazelcast.core.DistributedObjectEvent
Returns the name of related DistributedObject.
getObjectName() - Method in interface com.hazelcast.wan.WanEvent
Returns the name of the distributed object (map or cache) on which this event occurred.
getOfferOperationCount() - Method in interface com.hazelcast.collection.LocalQueueStats
Returns the number of offer/put/add operations.
getOldValue() - Method in interface com.hazelcast.cache.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.EventJournalMapEvent
Returns the old value for the event entry.
getOnJoinPermissionOperation() - Method in class com.hazelcast.config.SecurityConfig
 
getOperationPoolSize() - Method in class com.hazelcast.config.SqlConfig
Gets the number of threads responsible for network operations processing.
getOrCreateHazelcastClient() - Static method in class com.hazelcast.client.HazelcastClient
Gets or creates a new HazelcastInstance (a new client in a cluster) with the default XML configuration looked up in: System property: Hazelcast will first check if "hazelcast.client.config" system property is set to a file or a classpath:... path.
getOrCreateHazelcastClient(ClientConfig) - Static method in class com.hazelcast.client.HazelcastClient
Gets or creates a new HazelcastInstance (a new client in a cluster) with a certain name.
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.
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.
getOriginatingMemberId() - Method in exception com.hazelcast.sql.HazelcastSqlException
Gets ID of the member that caused or initiated an error condition.
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
 
getOtherOperationCount() - Method in interface com.hazelcast.map.LocalMapStats
Returns the total number of Other Operations
getOtherOperationsCount() - Method in interface com.hazelcast.collection.LocalQueueStats
Returns number of other operations
getOutboundPortDefinitions() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Returns the outbound port definitions.
getOutboundPortDefinitions() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getOutboundPortDefinitions() - Method in class com.hazelcast.config.EndpointConfig
 
getOutboundPortDefinitions() - Method in class com.hazelcast.config.NetworkConfig
 
getOutboundPorts() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Returns the outbound ports.
getOutboundPorts() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getOutboundPorts() - Method in class com.hazelcast.config.EndpointConfig
 
getOutboundPorts() - Method in class com.hazelcast.config.NetworkConfig
 
getOwnedEntryCount() - Method in interface com.hazelcast.cache.CacheStatistics
Returns the owned entry count in the cache.
getOwnedEntryCount() - Method in interface com.hazelcast.map.LocalMapStats
Returns the number of entries owned by this member.
getOwnedEntryCount() - Method in interface com.hazelcast.nearcache.NearCacheStats
Returns the number of Near Cache entries owned by this member.
getOwnedEntryMemoryCost() - Method in interface com.hazelcast.map.LocalMapStats
Returns memory cost (number of bytes) of owned entries in this member.
getOwnedEntryMemoryCost() - Method in interface com.hazelcast.nearcache.NearCacheStats
Returns memory cost (number of bytes) of Near Cache entries owned by this member.
getOwnedItemCount() - Method in interface com.hazelcast.collection.LocalQueueStats
Returns the number of owned items in this member.
getOwner() - Method in interface com.hazelcast.partition.Partition
Returns the current member that owns this partition.
getOwnerBundle() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Gets the owner Bundle of this instance.
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.
getPage() - Method in interface com.hazelcast.query.PagingPredicate
Returns the current page value.
getPageSize() - Method in class com.hazelcast.config.NativeMemoryConfig
Returns the page size, in bytes, to be allocated by native memory manager as a single block.
getPageSize() - Method in interface com.hazelcast.query.PagingPredicate
Returns the page size.
getParallelism() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Gets the configured number of Hot Restart store instance to create for one Hazelcast instance.
getParameterMetadata() - Method in class org.apache.calcite.plan.HazelcastRelOptCluster
 
getParameters() - Method in class com.hazelcast.sql.SqlStatement
Gets the statement parameters.
getParent() - Method in class com.hazelcast.spi.properties.HazelcastProperty
Returns the parent ClusterProperty of the property.
getPartition(Object) - Method in interface com.hazelcast.partition.PartitionService
Returns the partition that the given key belongs to.
getPartitionGroupConfig() - Method in class com.hazelcast.config.Config
Returns the partition group configuration for this hazelcast instance.