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
 
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.
getPartitionGroupStrategy() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
 
getPartitionGroupStrategy() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategy
Returns a custom implementation of a PartitionGroupStrategy to override default behavior of zone aware backup strategies PartitionGroupMetaData or to provide a specific behavior in case the discovery environment does not provide information about the infrastructure to be used for automatic configuration.
getPartitionGroupStrategy() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategy
 
getPartitionId() - Method in class com.hazelcast.map.EventLostEvent
 
getPartitionId() - Method in class com.hazelcast.map.MapPartitionLostEvent
Returns the partition ID that has been lost for the given map
getPartitionId() - Method in interface com.hazelcast.partition.Partition
Returns the ID of the partition.
getPartitionId() - Method in interface com.hazelcast.partition.PartitionEvent
Returns the partition ID that the event is dispatched for.
getPartitionId() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
Returns the partition ID the task is associated with.
getPartitioningStrategy() - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
getPartitioningStrategyClass() - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
getPartitioningStrategyConfig() - Method in class com.hazelcast.config.MapConfig
 
getPartitionKey() - Method in interface com.hazelcast.core.DistributedObject
Returns the key of the partition that this DistributedObject is assigned to.
getPartitionKey() - Method in interface com.hazelcast.partition.PartitionAware
The key that will be used by Hazelcast to specify the partition.
getPartitionKey() - Method in class com.hazelcast.partition.PartitionAwareKey
 
getPartitionKey(K) - Method in interface com.hazelcast.partition.PartitioningStrategy
Returns the key object that will be used by Hazelcast to specify the partition.
getPartitionKey(Object) - Method in class com.hazelcast.partition.strategy.DefaultPartitioningStrategy
 
getPartitionKey(Object) - Method in class com.hazelcast.partition.strategy.StringAndPartitionAwarePartitioningStrategy
 
getPartitionKey(Object) - Method in class com.hazelcast.partition.strategy.StringPartitioningStrategy
 
getPartitionKey(String) - Static method in class com.hazelcast.partition.strategy.StringPartitioningStrategy
 
getPartitionKey() - Method in interface com.hazelcast.query.PartitionPredicate
Returns the partition key that determines the partition the target Predicate is going to execute on.
getPartitionLostListenerConfigs() - Method in class com.hazelcast.config.CacheConfig
Gets the partition lost listener references added to cache configuration.
getPartitionLostListenerConfigs() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the partition lost listener references added to cache configuration.
getPartitionLostListenerConfigs() - Method in class com.hazelcast.config.MapConfig
 
getPartitions() - Method in interface com.hazelcast.partition.PartitionService
Returns a set containing all the Partitions in the cluster.
getPartitionService() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the partition service of this Hazelcast instance.
getPassword() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
Returns the Java KeyStore password.
getPassword() - Method in class com.hazelcast.config.replacer.AbstractPbeReplacer
Provides password for a chosen SecretKeyFactory.
getPassword() - Method in class com.hazelcast.config.replacer.EncryptionReplacer
 
getPassword() - Method in class com.hazelcast.config.security.UsernamePasswordIdentityConfig
 
getPassword() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
getPassword() - Method in interface com.hazelcast.security.PasswordCredentials
 
getPassword() - Method in class com.hazelcast.security.UsernamePasswordCredentials
Gets the password.
getPasswordAttribute() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getPatch() - Method in class com.hazelcast.version.MemberVersion
 
getPath() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
Returns the Java KeyStore file path.
getPendingTaskCount() - Method in interface com.hazelcast.executor.LocalExecutorStats
Returns the number of pending operations on the executor service.
getPermission(String, String, String...) - Static method in class com.hazelcast.security.permission.ActionConstants
Creates a permission
getPermissions(Subject, Class<? extends Permission>) - Method in interface com.hazelcast.security.IPermissionPolicy
Determines permissions of subject.
getPermissions() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
 
getPersistenceCount() - Method in interface com.hazelcast.nearcache.NearCacheStats
Returns the number of Near Cache key persistences (when the pre-load feature is enabled).
getPersistentMemoryConfig() - Method in class com.hazelcast.config.NativeMemoryConfig
Returns the persistent memory configuration this native memory configuration uses.
getPersistentMemoryDirectory() - Method in class com.hazelcast.config.NativeMemoryConfig
Deprecated.
Since 4.1 multiple persistent memory directories are supported. Please use PersistentMemoryConfig.getDirectoryConfigs() instead.
getPlannedMigrations() - Method in interface com.hazelcast.partition.MigrationState
Returns the number of planned migrations in the migration plan.
getPNCounter(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns a PNCounter with the given name.
getPNCounterConfig(String) - Method in class com.hazelcast.config.Config
Returns the PNCounterConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getPNCounterConfigs() - Method in class com.hazelcast.config.Config
Returns the map of PN counter configurations, mapped by config name.
getPolicy() - Method in class com.hazelcast.config.MergePolicyConfig
Returns the classname of the SplitBrainMergePolicy.
getPollingInterval() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
Returns the polling interval (in seconds) for checking for changes in the KeyStore.
getPollingInterval() - Method in class com.hazelcast.config.VaultSecureStoreConfig
Returns the Vault polling interval (in seconds).
getPollOperationCount() - Method in interface com.hazelcast.collection.LocalQueueStats
Returns the number of poll/take/remove operations.
getPoolSize() - Method in class com.hazelcast.config.DurableExecutorConfig
Gets the number of executor threads per member for the executor.
getPoolSize() - Method in class com.hazelcast.config.ExecutorConfig
Gets the number of executor threads per member for the executor.
getPoolSize() - Method in class com.hazelcast.config.ScheduledExecutorConfig
Gets the number of executor threads per member for the executor.
getPort() - Method in class com.hazelcast.cluster.Address
 
getPort() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getPort() - Method in class com.hazelcast.config.NetworkConfig
Returns the port the Hazelcast member will try to bind on.
getPort() - Method in class com.hazelcast.config.ServerSocketEndpointConfig
Returns the port the Hazelcast member will try to bind on.
getPortableFactories() - Method in class com.hazelcast.config.SerializationConfig
 
getPortableFactoryClasses() - Method in class com.hazelcast.config.SerializationConfig
 
getPortableVersion() - Method in class com.hazelcast.config.SerializationConfig
Portable version will be used to differentiate two versions of the same class that have changes on the class, like adding/removing a field or changing a type of a field.
getPortCount() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getPortCount() - Method in class com.hazelcast.config.NetworkConfig
Returns the maximum number of ports allowed to try to bind on.
getPortCount() - Method in class com.hazelcast.config.ServerSocketEndpointConfig
Returns the maximum number of ports allowed to try to bind on.
getPositiveMillisOrDefault(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured value of a HazelcastProperty converted to milliseconds if it is positive, otherwise returns its default value.
getPositiveMillisOrDefault(HazelcastProperty, long) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured value of a HazelcastProperty converted to milliseconds if it is positive, otherwise returns the passed default value.
getPredicateConfig() - Method in class com.hazelcast.config.QueryCacheConfig
Returns the predicate of QueryCache.
getPrefetchCount() - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
 
getPrefetchCount() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
getPrefetchValidityMillis() - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
 
getPrefetchValidityMillis() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
getPrefix(URI, ClassLoader) - Static method in class com.hazelcast.cache.CacheUtil
Gets the prefix of cache name without Hazelcast's CacheManager specific prefix HazelcastCacheManager.CACHE_MANAGER_PREFIX.
getPrefix() - Method in class com.hazelcast.config.replacer.EncryptionReplacer
 
getPrefix() - Method in class com.hazelcast.config.replacer.PropertyReplacer
 
getPrefix() - Method in interface com.hazelcast.config.replacer.spi.ConfigReplacer
Variable replacer prefix string.
getPrefixedCacheName(String, URI, ClassLoader) - Static method in class com.hazelcast.cache.CacheUtil
Gets the cache name with prefix but without Hazelcast's CacheManager specific prefix HazelcastCacheManager.CACHE_MANAGER_PREFIX.
getPrefixedName() - Method in interface com.hazelcast.core.PrefixedDistributedObject
Returns the unique prefixed name for this DistributedObject.
getPrefixes() - Method in class com.hazelcast.config.ClassFilter
Returns unmodifiable set of class name prefixes.
getPreloaderConfig() - Method in class com.hazelcast.config.NearCacheConfig
Returns the NearCachePreloaderConfig of this Near Cache.
getPreloaderConfig(Node) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
getPrincipal() - Method in class com.hazelcast.config.PermissionConfig
 
getPrincipal() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
 
getPrincipal() - Method in class com.hazelcast.config.security.KerberosIdentityConfig
 
getPriority() - Method in enum com.hazelcast.spi.discovery.DiscoveryStrategyFactory.DiscoveryStrategyLevel
 
getPriorityComparatorClassName() - Method in class com.hazelcast.config.QueueConfig
Returns the class name that will be used to compare queue items.
getPrivateAddress() - Method in class com.hazelcast.spi.discovery.DiscoveryNode
Returns the private address of the discovered node.
getPrivateAddress() - Method in class com.hazelcast.spi.discovery.SimpleDiscoveryNode
 
getProductName() - Method in enum com.hazelcast.config.InstanceTrackingConfig.InstanceProductName
Returns the string representation of the instance product name
getProgress() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
getProperties() - Method in class com.hazelcast.client.config.ClientConfig
Gets Properties object
getProperties() - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
Gets all properties.
getProperties() - Method in class com.hazelcast.config.AbstractWanPublisherConfig
Returns the WAN publisher properties.
getProperties() - Method in class com.hazelcast.config.AbstractXmlConfigBuilder
Gets the current used properties.
getProperties() - Method in class com.hazelcast.config.AbstractYamlConfigBuilder
Gets the current used properties.
getProperties() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
Returns all properties.
getProperties() - Method in class com.hazelcast.config.Config
Returns the properties set on this config instance.
getProperties() - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
getProperties() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
getProperties() - Method in class com.hazelcast.config.LoginModuleConfig
 
getProperties() - Method in class com.hazelcast.config.MapStoreConfig
Returns all the properties
getProperties() - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
getProperties() - Method in class com.hazelcast.config.PermissionPolicyConfig
 
getProperties() - Method in class com.hazelcast.config.QueueStoreConfig
Returns the properties to be used when instantiating the queue store.
getProperties() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
getProperties() - Method in class com.hazelcast.config.ServiceConfig
 
getProperties() - Method in class com.hazelcast.config.SocketInterceptorConfig
Gets all properties.
getProperties() - Method in class com.hazelcast.config.WanConsumerConfig
Returns the properties for the custom WAN consumer.
getProperties() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
Returns an immutable copy of the configuration properties.
getProperties() - Method in class com.hazelcast.spi.discovery.DiscoveryNode
Returns a set of unmodifiable properties that are assigned to the discovered node.
getProperties() - Method in class com.hazelcast.spi.discovery.SimpleDiscoveryNode
 
getProperty(String) - Method in class com.hazelcast.client.config.ClientConfig
Gets a named property already set or from system properties if not exists.
getProperty(String) - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
Gets a property.
getProperty(String) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
Returns property value by the property name.
getProperty(String) - Method in class com.hazelcast.config.Config
Returns the value for a named property.
getProperty(String) - Method in class com.hazelcast.config.MapStoreConfig
Returns the given property
getProperty(String) - Method in class com.hazelcast.config.QueueStoreConfig
Returns the property with the given name which is used when instantiating and interacting with the queue store.
getProperty(String) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
getProperty(String) - Method in class com.hazelcast.config.SocketInterceptorConfig
Gets a property.
getPropertyName() - Method in enum com.hazelcast.config.InstanceTrackingConfig.InstanceTrackingProperties
Returns the property name which can be used in placeholders to be resolved to an actual property value.
getProtectOn() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
getProtocolType() - Method in class com.hazelcast.config.EndpointConfig
 
getProtocolType() - Method in class com.hazelcast.config.RestServerEndpointConfig
 
getProviderFilter() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Get current filter or null when no filter is defined.
getProviderMode() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Return the current ProviderMode
getProxyFactoryConfigs() - Method in class com.hazelcast.client.config.ClientConfig
Gets list of ProxyFactoryConfig
getPublicAddress() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getPublicAddress() - Method in class com.hazelcast.config.NetworkConfig
 
getPublicAddress() - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
getPublicAddress() - Method in class com.hazelcast.spi.discovery.DiscoveryNode
Returns the public address of the discovered node if available.
getPublicAddress() - Method in class com.hazelcast.spi.discovery.SimpleDiscoveryNode
 
getPublicAddress() - Method in interface com.hazelcast.spi.MemberAddressProvider
What address should Hazelcast advertise to other members and clients.
getPublicAddress(EndpointQualifier) - Method in interface com.hazelcast.spi.MemberAddressProvider
 
getPublisherId() - Method in class com.hazelcast.config.AbstractWanPublisherConfig
Returns the publisher ID used for identifying the publisher in a WanReplicationConfig.
getPublisherId() - Method in class com.hazelcast.config.WanCustomPublisherConfig
 
getPublishingMember() - Method in class com.hazelcast.topic.Message
Returns the member that published the message.
getPublishOperationCount() - Method in interface com.hazelcast.topic.LocalTopicStats
Returns the total number of published messages of this topic on this member
getPublishTime() - Method in class com.hazelcast.topic.Message
Return the time when the message is published
getPutOperationCount() - Method in interface com.hazelcast.map.LocalMapStats
Returns the number of put operations
getQualifier() - Method in class com.hazelcast.config.EndpointConfig
 
getQualifier() - Method in class com.hazelcast.config.RestServerEndpointConfig
 
getQueryCache(String) - Method in interface com.hazelcast.map.IMap
Returns corresponding QueryCache instance for the supplied name or null.
getQueryCache(String, Predicate<K, V>, boolean) - Method in interface com.hazelcast.map.IMap
Creates an always up to date snapshot of this IMap according to the supplied parameters.
getQueryCache(String, MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.map.IMap
Creates an always up to date snapshot of this IMap according to the supplied parameters.
getQueryCacheConfigs() - Method in class com.hazelcast.client.config.ClientConfig
 
getQueryCacheConfigs() - Method in class com.hazelcast.config.MapConfig
Returns all QueryCacheConfig instances defined on this MapConfig.
getQueryCount() - Method in interface com.hazelcast.map.LocalMapStats
Returns the total number of queries performed on the map.
getQueryCount() - Method in interface com.hazelcast.query.LocalIndexStats
Returns the total number of queries served by the index.
getQueue() - Method in class com.hazelcast.console.ConsoleApp
 
getQueue(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed queue instance with the specified name.
getQueue(String) - Method in class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
 
getQueue(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
Returns the transactional queue instance with the specified name.
getQueueCapacity() - Method in class com.hazelcast.config.ExecutorConfig
Gets the queue capacity of the executor task.
getQueueCapacity() - Method in class com.hazelcast.config.WanBatchPublisherConfig
Returns the capacity of the primary and backup queue for WAN replication events.
getQueueConfig(String) - Method in class com.hazelcast.config.Config
Returns the QueueConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getQueueConfigs() - Method in class com.hazelcast.config.Config
Returns the map of IQueue configurations, mapped by config name.
getQueueFullBehavior() - Method in class com.hazelcast.config.WanBatchPublisherConfig
Returns the configured behaviour of this WAN publisher when the WAN queue is full.
getQueueStoreConfig() - Method in class com.hazelcast.config.QueueConfig
Get the QueueStore (load and store queue items from/to a database) configuration.
getRaftAlgorithmConfig() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns configuration options for Hazelcast's Raft consensus algorithm implementation
getRatio() - Method in interface com.hazelcast.nearcache.NearCacheStats
Returns the hit/miss ratio of Near Cache entries owned by this member.
getRawDataInput() - Method in interface com.hazelcast.nio.serialization.PortableReader
getRawDataOutput() - Method in interface com.hazelcast.nio.serialization.PortableWriter
After writing portable fields one can subsequently write remaining fields in the old-fashioned way.
getRawKey() - Method in interface com.hazelcast.spi.merge.MergingEntry
Returns the merging key in the in-memory format of the backing data structure.
getRawValue() - Method in interface com.hazelcast.spi.merge.MergingValue
Returns the merging value in the in-memory format of the backing data structure.
getReadBatchSize() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
Gets the maximum number of items to read in a batch.
getReadBatchSize() - Method in class com.hazelcast.config.ReliableTopicConfig
Gets the maximum number of items to read in a batch.
getReadTimeout() - Method in class com.hazelcast.spring.cache.HazelcastCache
Return cache retrieval timeout in milliseconds
getReadTimeoutMap() - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
Return cache-specific value retrieval timeouts.
getRealm() - Method in class com.hazelcast.config.security.KerberosIdentityConfig
 
getRealmConfig(String) - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
getRealmConfig(String) - Method in class com.hazelcast.config.SecurityConfig
 
getRealmConfig() - Method in class com.hazelcast.security.RealmConfigCallback
 
getRealmConfigs() - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
getRealmConfigs() - Method in class com.hazelcast.config.SecurityConfig
 
getRealmCredentialsFactory(String) - Method in class com.hazelcast.config.SecurityConfig
 
getRealmLoginModuleConfigs(String) - Method in class com.hazelcast.config.SecurityConfig
 
getRealmName() - Method in class com.hazelcast.security.RealmConfigCallback
 
getReceiveOperationCount() - Method in interface com.hazelcast.topic.LocalTopicStats
Returns the total number of received messages of this topic on this member
getReconnectMode() - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
 
getRejectedOfferOperationCount() - Method in interface com.hazelcast.collection.LocalQueueStats
Returns the number of rejected offers.
getRelaxFlagsCheck() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
 
getReleaseVersion() - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
getReliableTopic(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the reliable topic instance with the specified name.
getReliableTopicConfig(String) - Method in class com.hazelcast.client.config.ClientConfig
Gets the ClientReliableTopicConfig for a given reliable topic name.
getReliableTopicConfig(String) - Method in class com.hazelcast.config.Config
Returns the ReliableTopicConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getReliableTopicConfigMap() - Method in class com.hazelcast.client.config.ClientConfig
Returns the map of reliable topic configurations, mapped by config name.
getReliableTopicConfigs() - Method in class com.hazelcast.config.Config
Returns the map of reliable topic configurations, mapped by config name.
getRemainingMigrations() - Method in interface com.hazelcast.partition.MigrationState
Returns the number of remaining migrations in the migration plan.
getRemoveCount() - Method in interface com.hazelcast.query.LocalIndexStats
Returns the number of remove operations performed on the index.
getRemoveCount() - Method in class com.hazelcast.wan.WanEventCounters.DistributedObjectWanEventCounters
Returns the number of entry remove events
getRemoveOperationCount() - Method in interface com.hazelcast.map.LocalMapStats
Returns the number of Remove operations
getReplacement(String) - Method in class com.hazelcast.config.replacer.AbstractPbeReplacer
 
getReplacement(String) - Method in class com.hazelcast.config.replacer.PropertyReplacer
 
getReplacement(String) - Method in interface com.hazelcast.config.replacer.spi.ConfigReplacer
Provides String which should be used as a variable replacement for given masked value.
getReplicaCount() - Method in class com.hazelcast.config.PNCounterConfig
Returns the number of replicas on which state for this PN counter will be kept.
getReplicaIndex() - Method in interface com.hazelcast.partition.ReplicaMigrationEvent
Returns the index of the partition replica.
getReplicatedMap(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the replicated map instance with the specified name.
getReplicatedMapConfig(String) - Method in class com.hazelcast.config.Config
Returns the ReplicatedMapConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getReplicatedMapConfigs() - Method in class com.hazelcast.config.Config
Returns the map of ReplicatedMap configurations, mapped by config name.
getReplicatedMapStats() - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Returns LocalReplicatedMapStats for this replicated map.
getReplicationPeriodMillis() - Method in class com.hazelcast.config.CRDTReplicationConfig
Returns the period between two replications of CRDT states in milliseconds.
getRequiredMember() - Method in class com.hazelcast.config.TcpIpConfig
Gets the required member.
getResourceFactory() - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
 
getResponseTimeoutMillis() - Method in class com.hazelcast.config.WanBatchPublisherConfig
Returns the duration in milliseconds for the wait time before retrying to send the events to target cluster again in case the acknowledgement has not arrived.
getRestApiConfig() - Method in class com.hazelcast.config.NetworkConfig
 
getRestEndpointConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig
 
getRetentionSeconds() - Method in class com.hazelcast.config.MetricsManagementCenterConfig
Returns the number of seconds the metrics will be retained on the instance.
getRingbuffer(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed Ringbuffer instance with the specified name.
getRingbufferConfig(String) - Method in class com.hazelcast.config.Config
Returns the RingbufferConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getRingbufferConfigs() - Method in class com.hazelcast.config.Config
Returns the map of Ringbuffer configurations, mapped by config name.
getRingbufferStoreConfig() - Method in class com.hazelcast.config.RingbufferConfig
Get the RingbufferStore (load and store ringbuffer items from/to a database) configuration.
getRoleAttribute() - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
 
getRoleContext() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getRoleFilter() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getRoleMappingAttribute() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getRoleMappingMode() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getRoleMappingMode(String) - Static method in enum com.hazelcast.config.security.LdapRoleMappingMode
 
getRoleNameAttribute() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getRoleRecursionMaxDepth() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getRoleSearchScope() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getRowMetadata() - Method in interface com.hazelcast.sql.SqlResult
Gets the row metadata.
getSalt() - Method in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
Returns the salt.
getScheduledExecutorConfig(String) - Method in class com.hazelcast.config.Config
Returns the ScheduledExecutorConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getScheduledExecutorConfigs() - Method in class com.hazelcast.config.Config
Returns the map of scheduled executor configurations, mapped by config name.
getScheduledExecutorService(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the IScheduledExecutorService scheduled executor service for the given name.
getScheduledFuture(ScheduledTaskHandler) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates a new IScheduledFuture from the given handler.
getSchedulerName() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
Return the name of the ScheduledExecutor this tasks is running on.
getScopedHost() - Method in class com.hazelcast.cluster.Address
 
getScopeId() - Method in class com.hazelcast.cluster.Address
 
getSearchScope(String) - Static method in enum com.hazelcast.config.security.LdapSearchScope
 
getSeconds(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured value of a HazelcastProperty converted to seconds.
getSecretPath() - Method in class com.hazelcast.config.VaultSecureStoreConfig
Returns the Vault secret path.
getSecureStoreConfig() - Method in class com.hazelcast.config.EncryptionAtRestConfig
Returns the Secure Store configuration.
getSecurityConfig() - Method in class com.hazelcast.client.config.ClientConfig
Gets ClientSecurityConfig object which allows client credentials configuration.
getSecurityConfig() - Method in class com.hazelcast.config.Config
Returns the security configuration for this hazelcast instance.
getSecurityInterceptorConfigs() - Method in class com.hazelcast.config.SecurityConfig
 
getSecurityRealm() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
 
getSecurityRealm() - Method in class com.hazelcast.config.security.KerberosIdentityConfig
 
getSecurityRealm() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getSemaphore(String) - Method in interface com.hazelcast.cp.CPSubsystem
Returns a proxy for an ISemaphore instance created on CP Subsystem.
getSemaphoreConfigs() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the map of CP ISemaphore configurations
getSequence(int) - Method in interface com.hazelcast.ringbuffer.ReadResultSet
Return the sequence number for the item at the given index.
getSerializationConfig() - Method in class com.hazelcast.client.config.ClientConfig
getSerializationConfig() - Method in class com.hazelcast.config.Config
Returns the serialization configuration for this hazelcast instance.
getSerializationType() - Method in interface com.hazelcast.nio.serialization.SerializerHook
Returns the actual class type of the serialized object
getSerializerConfigs() - Method in class com.hazelcast.config.SerializationConfig
 
getService() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
 
getServiceName() - Method in interface com.hazelcast.core.DistributedObject
Returns the service name for this object.
getServiceName() - Method in class com.hazelcast.core.DistributedObjectEvent
Returns the service name of related DistributedObject.
getServiceName() - Method in interface com.hazelcast.spi.tenantcontrol.DestroyEventContext
 
getServiceName() - Method in interface com.hazelcast.wan.WanEvent
Returns the service name on which this event occurred.
getServiceNamePrefix() - Method in class com.hazelcast.config.security.KerberosIdentityConfig
 
getServicesConfig() - Method in class com.hazelcast.config.Config
Returns the configuration for the user services managed by this hazelcast instance.
getServicesConfig(Config) - Static method in class com.hazelcast.config.ConfigAccessor
 
getSessionHeartbeatIntervalSeconds() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the interval for the periodically-committed CP session heartbeats.
getSessionTimeToLiveSeconds() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the duration for a CP session to be kept alive after its last session heartbeat.
getSet() - Method in class com.hazelcast.console.ConsoleApp
 
getSet(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed set instance with the specified name.
getSet(String) - Method in class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
 
getSet(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
Returns the transactional set instance with the specified name.
getSetConfig(String) - Method in class com.hazelcast.config.Config
Returns the SetConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getSetConfigs() - Method in class com.hazelcast.config.Config
Returns the map of ISet configurations, mapped by config name.
getSetOperationCount() - Method in interface com.hazelcast.map.LocalMapStats
Returns the number of set operations
getSingleType() - Method in enum com.hazelcast.nio.serialization.FieldType
 
getSize() - Method in class com.hazelcast.config.EvictionConfig
Returns the size which is used by the MaxSizePolicy.
getSize() - Method in class com.hazelcast.config.NativeMemoryConfig
Returns size of the native memory region.
getSkipAuthentication() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getSkipEndpoint() - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
 
getSkipIdentity() - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
 
getSkipRole() - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
 
getSocketAddress() - Method in interface com.hazelcast.client.Client
Returns the socket address of this client.
getSocketAddress() - Method in interface com.hazelcast.cluster.Endpoint
Returns the socket address for this endpoint.
getSocketAddress() - Method in interface com.hazelcast.cluster.Member
Returns the socket address of this member for member to member communications or unified depending on config.
getSocketAddress(EndpointQualifier) - Method in interface com.hazelcast.cluster.Member
Returns the socket address of this member.
getSocketConnectTimeoutSeconds() - Method in class com.hazelcast.config.EndpointConfig
 
getSocketFactoryClassName() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getSocketInterceptorConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
getSocketInterceptorConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getSocketInterceptorConfig() - Method in class com.hazelcast.config.EndpointConfig
getSocketInterceptorConfig() - Method in class com.hazelcast.config.NetworkConfig
getSocketLingerSeconds() - Method in class com.hazelcast.config.EndpointConfig
 
getSocketOptions() - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
getSocketRcvBufferSizeKb() - Method in class com.hazelcast.config.EndpointConfig
 
getSocketSendBufferSizeKb() - Method in class com.hazelcast.config.EndpointConfig
 
getSource() - Method in class com.hazelcast.map.AbstractIMapEvent
Returns the object on which the event initially occurred.
getSource() - Method in interface com.hazelcast.partition.ReplicaMigrationEvent
Returns the old owner of the migrating partition replica.
getSplitBrainProtection(String) - Method in interface com.hazelcast.splitbrainprotection.SplitBrainProtectionService
Returns the SplitBrainProtection instance for a given split brain protection name.
getSplitBrainProtectionConfig(String) - Method in class com.hazelcast.config.Config
Returns the SplitBrainProtectionConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getSplitBrainProtectionConfigs() - Method in class com.hazelcast.config.Config
Returns the map of split brain protection configurations, mapped by config name.
getSplitBrainProtectionName() - Method in class com.hazelcast.config.CacheConfig
Gets the name of the associated split brain protection if any.
getSplitBrainProtectionName() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the name of the associated split brain protection if any.
getSplitBrainProtectionName() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Returns the split brain protection name for operations.
getSplitBrainProtectionName() - Method in class com.hazelcast.config.CollectionConfig
Returns the split brain protection name for operations.
getSplitBrainProtectionName() - Method in class com.hazelcast.config.DurableExecutorConfig
Returns the split brain protection name for operations.
getSplitBrainProtectionName() - Method in class com.hazelcast.config.ExecutorConfig
Returns the split brain protection name for operations.
getSplitBrainProtectionName() - Method in class com.hazelcast.config.MapConfig
 
getSplitBrainProtectionName() - Method in class com.hazelcast.config.MultiMapConfig
Returns the split brain protection name for operations.
getSplitBrainProtectionName() - Method in class com.hazelcast.config.PNCounterConfig
Returns the split brain protection name for operations.
getSplitBrainProtectionName() - Method in class com.hazelcast.config.QueueConfig
Returns the split brain protection name for queue operations.
getSplitBrainProtectionName() - Method in class com.hazelcast.config.ReplicatedMapConfig
Returns the split brain protection name for operations.
getSplitBrainProtectionName() - Method in class com.hazelcast.config.RingbufferConfig
Returns the split brain protection name for operations.
getSplitBrainProtectionName() - Method in class com.hazelcast.config.ScheduledExecutorConfig
Returns the split brain protection name for operations.
getSplitBrainProtectionService() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the split brain protection service of this Hazelcast instance.
getSpn() - Method in class com.hazelcast.config.security.KerberosIdentityConfig
 
getSql() - Method in class com.hazelcast.config.PredicateConfig
Returns sql string for this config.
getSql() - Method in interface com.hazelcast.core.HazelcastInstance
Returns a service to execute distributed SQL queries.
getSql() - Method in class com.hazelcast.sql.SqlStatement
Gets the SQL string to be executed.
getSqlConfig() - Method in class com.hazelcast.config.Config
 
getSSLConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Returns the current SSLConfig.
getSSLConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getSSLConfig() - Method in class com.hazelcast.config.EndpointConfig
Returns the current SSLConfig.
getSSLConfig() - Method in class com.hazelcast.config.NetworkConfig
Returns the current SSLConfig.
getSSLConfig() - Method in class com.hazelcast.config.VaultSecureStoreConfig
Returns the SSL/TLS configuration.
getStartedTaskCount() - Method in interface com.hazelcast.executor.LocalExecutorStats
Returns the number of started operations on the executor service.
getStartTime() - Method in interface com.hazelcast.partition.MigrationState
Returns the start time of the migration in milliseconds since the epoch.
getState() - Method in class com.hazelcast.core.LifecycleEvent
 
getState() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
getStatementTimeoutMillis() - Method in class com.hazelcast.config.SqlConfig
Gets the timeout in milliseconds that is applied to statements without an explicit timeout.
getStats() - Method in interface com.hazelcast.scheduledexecutor.IScheduledFuture
Returns the statistics and time measurement info of the execution of this scheduled future in the IScheduledExecutorService it was scheduled.
getStoreImplementation() - Method in class com.hazelcast.config.QueueStoreConfig
Returns the implementation of the queue store which will be used to store queue items.
getStoreImplementation() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
getStoreInitialDelaySeconds() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
getStoreIntervalSeconds() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
getString(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured value of a HazelcastProperty as String.
getSymmetricEncryptionConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getSymmetricEncryptionConfig() - Method in class com.hazelcast.config.EndpointConfig
getSymmetricEncryptionConfig() - Method in class com.hazelcast.config.NetworkConfig
getSyncConfig() - Method in class com.hazelcast.config.WanBatchPublisherConfig
Returns the config for the WAN sync mechanism.
getSyncCount() - Method in class com.hazelcast.wan.WanEventCounters.DistributedObjectWanEventCounters
Returns the number of entry sync events
getSystemAuthentication() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getSystemProperty() - Method in class com.hazelcast.spi.properties.HazelcastProperty
Gets the system property value of the property.
getSystemUserDn() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getSystemUserPassword() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getTag() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
 
getTailSequence() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Returns the sequence of the tail.
getTarget() - Method in interface com.hazelcast.query.PartitionPredicate
Returns the target Predicate.
getTarget() - Method in exception com.hazelcast.spi.exception.WrongTargetException
 
getTargetEndpoints() - Method in class com.hazelcast.config.WanBatchPublisherConfig
Returns the comma separated list of target cluster members, e.g.
getTaskId() - Method in interface com.hazelcast.durableexecutor.DurableExecutorServiceFuture
A unique ID for the executing task
getTaskName() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
Returns the name of the task.
getTcpIpConfig() - Method in class com.hazelcast.config.JoinConfig
 
getTenantControl(CacheConfig<K, V>) - Static method in class com.hazelcast.config.CacheConfigAccessor
 
getTextContent(Node) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
getThreshold() - Method in class com.hazelcast.splitbrainprotection.SplitBrainProtectionEvent
Returns the predefined split brain protection threshold
getTimedExpiryPolicyFactoryConfig() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
getTimeoutMillis() - Method in class com.hazelcast.sql.SqlStatement
Gets the execution timeout in milliseconds.
getTimeoutMillis() - Method in class com.hazelcast.transaction.TransactionOptions
Gets the timeout in milliseconds.
getTimeoutMilliseconds() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
getTimeoutMilliseconds() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
getTimestamp() - Method in interface com.hazelcast.auditlog.AuditableEvent
Returns event timestamp as milliseconds from the epoch.
getTimeToLiveSeconds() - Method in class com.hazelcast.config.EventJournalConfig
Gets the time to live in seconds.
getTimeToLiveSeconds() - Method in class com.hazelcast.config.MapConfig
Returns the maximum number of seconds for each entry to stay in the map.
getTimeToLiveSeconds() - Method in class com.hazelcast.config.NearCacheConfig
Returns the maximum number of seconds for each entry to stay in the Near Cache (time to live).
getTimeToLiveSeconds() - Method in class com.hazelcast.config.RingbufferConfig
Gets the time to live in seconds.
getTimeUnit() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
getTimeUnit() - Method in class com.hazelcast.spi.properties.HazelcastProperty
Returns the TimeUnit of the property.
getTlsAuthenticationConfig() - Method in class com.hazelcast.config.security.RealmConfig
 
getToken() - Method in class com.hazelcast.config.security.TokenIdentityConfig
 
getToken() - Method in class com.hazelcast.config.VaultSecureStoreConfig
Returns the Vault access token.
getToken() - Method in class com.hazelcast.security.SimpleTokenCredentials
Gets the token.
getToken() - Method in interface com.hazelcast.security.TokenCredentials
Returns the token as a byte array.
getTokenEncoded() - Method in class com.hazelcast.config.security.TokenIdentityConfig
 
getTokenEncoding(String) - Static method in enum com.hazelcast.config.security.TokenEncoding
 
getTokenIdentityConfig() - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
getTokenIdentityConfig() - Method in class com.hazelcast.config.security.RealmConfig
 
getTopic() - Method in class com.hazelcast.console.ConsoleApp
 
getTopic(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed topic instance with the specified name.
getTopicConfig(String) - Method in class com.hazelcast.config.Config
Returns the TopicConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getTopicConfigs() - Method in class com.hazelcast.config.Config
Returns the map of reliable topic configurations, mapped by config name.
getTopicOverloadPolicy() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
Gets the TopicOverloadPolicy for this reliable topic.
getTopicOverloadPolicy() - Method in class com.hazelcast.config.ReliableTopicConfig
Gets the TopicOverloadPolicy for this reliable topic.
getTotal() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
getTotalBackupCount() - Method in class com.hazelcast.config.CacheConfig
Gets the total backup count (backupCount + asyncBackupCount) of the cache.
getTotalBackupCount() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Returns the total number of backups: backupCount plus asyncBackupCount.
getTotalBackupCount() - Method in class com.hazelcast.config.CollectionConfig
Gets the total number of synchronous and asynchronous backups for this collection.
getTotalBackupCount() - Method in class com.hazelcast.config.MapConfig
Returns the total number of backups: backupCount plus asyncBackupCount.
getTotalBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
Gets the total number of backups (synchronous + asynchronous) for this MultiMap.
getTotalBackupCount() - Method in class com.hazelcast.config.QueueConfig
Get the total number of backups: the backup count plus the asynchronous backup count.
getTotalBackupCount() - Method in class com.hazelcast.config.RingbufferConfig
Returns the total number of backups: backupCount plus asyncBackupCount.
getTotalElapsedTime() - Method in interface com.hazelcast.partition.MigrationState
Returns the total elapsed time of completed migrations in milliseconds.
getTotalExecutionLatency() - Method in interface com.hazelcast.executor.LocalExecutorStats
Returns the total execution time of operations finished.
getTotalGetLatency() - Method in interface com.hazelcast.map.LocalMapStats
Returns the total latency of get operations.
getTotalIdleTime(TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.ScheduledTaskStatistics
Returns the total amount of time the task was idle, waiting to get scheduled in.
getTotalInsertLatency() - Method in interface com.hazelcast.query.LocalIndexStats
Returns the total latency (in nanoseconds) of insert operations performed on the index.
getTotalPutLatency() - Method in interface com.hazelcast.map.LocalMapStats
Returns the total latency of put operations.
getTotalRemoveLatency() - Method in interface com.hazelcast.map.LocalMapStats
Returns the total latency of remove operations.
getTotalRemoveLatency() - Method in interface com.hazelcast.query.LocalIndexStats
Returns the total latency (in nanoseconds) of remove operations performed on the index.
getTotalRuns() - Method in interface com.hazelcast.scheduledexecutor.ScheduledTaskStatistics
Returns how many times the task was ran/called.
getTotalRunTime(TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.ScheduledTaskStatistics
Returns the total amount of time the task spent while scheduled in.
getTotalSetLatency() - Method in interface com.hazelcast.map.LocalMapStats
Returns the total latency of set operations.
getTotalStartLatency() - Method in interface com.hazelcast.executor.LocalExecutorStats
Returns the total start latency of operations started.
getTotalUpdateLatency() - Method in interface com.hazelcast.query.LocalIndexStats
Returns the total latency (in nanoseconds) of update operations performed on the index.
getTransactionalObject(String, String) - Method in class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
 
getTransactionalObject(String, String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
Returns the transactional object instance with the specified name and service name.
getTransactionContext(HazelcastInstance) - Static method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
Returns the transaction context for the given Hazelcast instance bounded to the current thread.
getTransactionContext() - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
Returns the transaction context
getTransactionContext() - Method in interface com.hazelcast.transaction.HazelcastXAResource
Returns the TransactionContext associated with the current thread.
getTransactionType() - Method in class com.hazelcast.transaction.TransactionOptions
getTrustedInterfaces() - Method in class com.hazelcast.config.ManagementCenterConfig
Gets the trusted interfaces.
getTrustedInterfaces() - Method in class com.hazelcast.config.MulticastConfig
Gets the trusted interfaces.
getTrustedInterfaces() - Method in interface com.hazelcast.config.TrustedInterfacesConfigurable
Gets the trusted interfaces.
getTryCount() - Method in class com.hazelcast.client.config.ClientFailoverConfig
Returns the count of attempts to connect to a cluster.
getTtl() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
getTtl() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
getTtl() - Method in interface com.hazelcast.core.EntryView
Returns the last set time to live in milliseconds.
getTtl() - Method in interface com.hazelcast.spi.merge.MergingTTL
Returns the TTL of the merge data.
getTxnId() - Method in interface com.hazelcast.transaction.TransactionContext
Gets the ID that uniquely identifies the transaction.
getType() - Method in enum com.hazelcast.cache.CacheEventType
 
getType() - Method in interface com.hazelcast.cache.EventJournalCacheEvent
Returns the event type.
getType() - Method in class com.hazelcast.config.IndexConfig
Gets type of the index.
getType() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
Returns the type of the Java KeyStore.
getType() - Method in class com.hazelcast.config.PermissionConfig
 
getType(String) - Static method in enum com.hazelcast.config.PermissionConfig.PermissionType
 
getType() - Method in enum com.hazelcast.core.EntryEventType
 
getType() - Method in enum com.hazelcast.core.ItemEventType
 
getType() - Method in interface com.hazelcast.cp.event.CPMembershipEvent
Returns the type of membership change.
getType() - Method in interface com.hazelcast.map.EventJournalMapEvent
Returns the event type.
getType() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
 
getType() - Method in class com.hazelcast.sql.SqlColumnMetadata
Gets column type.
getTypeClass() - Method in class com.hazelcast.config.SerializerConfig
Gets the type of the class that will be serialized via this implementation.
getTypeClassName() - Method in class com.hazelcast.config.SerializerConfig
Gets the name of the class that will be serialized via this implementation.
getTypeId() - Method in interface com.hazelcast.nio.serialization.Serializer
Uniquely identifies given serializer.
getTypeSize() - Method in enum com.hazelcast.nio.serialization.FieldType
 
getUnavailableMembers() - Method in interface com.hazelcast.cp.event.CPGroupAvailabilityEvent
Returns the unavailable members of the CP group.
getUncommittedEntryCountToRejectNewAppends() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
getUniqueKey() - Method in class com.hazelcast.config.BitmapIndexOptions
Returns the unique key attribute configured in this index config.
getUniqueKeyTransformation() - Method in class com.hazelcast.config.BitmapIndexOptions
Returns the unique key transformation configured in this index.
getUnit() - Method in class com.hazelcast.memory.MemorySize
Returns unit of memory size
getUpdateCount() - Method in interface com.hazelcast.query.LocalIndexStats
Returns the number of update operations performed on the index.
getUpdateCount() - Method in class com.hazelcast.wan.WanEventCounters.DistributedObjectWanEventCounters
Returns the number of entry update events
getUriString() - Method in class com.hazelcast.config.CacheConfig
Gets the URI string which is the global identifier for this ICache.
getUrl() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getUsage() - Method in class com.hazelcast.config.LoginModuleConfig
 
getUseCanonicalHostname() - Method in class com.hazelcast.config.security.KerberosIdentityConfig
 
getUseNameWithoutRealm() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
 
getUserCodeDeploymentConfig() - Method in class com.hazelcast.client.config.ClientConfig
Get current configuration of User Code Deployment.
getUserCodeDeploymentConfig() - Method in class com.hazelcast.config.Config
Get current configuration of User Code Deployment.
getUserContext() - Method in class com.hazelcast.client.config.ClientConfig
 
getUserContext() - Method in class com.hazelcast.config.Config
Returns the user supplied context.
getUserContext() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getUserContext() - Method in interface com.hazelcast.core.HazelcastInstance
Returns a ConcurrentMap that can be used to add user-context to the HazelcastInstance.
getUserFilter() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getUsername() - Method in class com.hazelcast.config.security.UsernamePasswordIdentityConfig
 
getUserNameAttribute() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getUsernamePasswordIdentityConfig() - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
getUsernamePasswordIdentityConfig() - Method in class com.hazelcast.config.security.RealmConfig
 
getUserSearchScope() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getUuid() - Method in interface com.hazelcast.client.Client
Returns a unique UUID for this client.
getUuid() - Method in interface com.hazelcast.cluster.Endpoint
Returns the UUID of this endpoint
getUuid() - Method in interface com.hazelcast.cluster.Member
Returns the UUID of this member.
getUuid() - Method in interface com.hazelcast.cp.CPMember
Returns the UUID of this CP member.
getUuid() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
Returns the uuid of the member the task is associated with.
getValidationTimeoutSeconds() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Returns configured validation timeout for hot-restart process.
getValue() - Method in interface com.hazelcast.cache.CacheEntryView
Gets the value of the cache entry.
getValue() - Method in class com.hazelcast.core.EntryEvent
Returns the value of the entry event.
getValue() - Method in interface com.hazelcast.core.EntryView
Returns the value of the entry.
getValue() - Method in class com.hazelcast.map.EntryLoader.MetadataAwareValue
Returns the value
getValue() - Method in class com.hazelcast.memory.MemorySize
Returns value of memory size in its original unit.
getValue() - Method in interface com.hazelcast.spi.eviction.EvictableEntryView
Gets the value of the entry.
getValue() - Method in interface com.hazelcast.spi.merge.MergingValue
Returns the deserialized merging value.
getValueClass() - Method in enum com.hazelcast.sql.SqlColumnType
Gets the Java class of the value of this SQL type.
getValueClassName() - Method in class com.hazelcast.config.AbstractCacheConfig
 
getValueCollectionType() - Method in class com.hazelcast.config.MultiMapConfig
Gets the collection type for the values of this MultiMap.
getValueType() - Method in class com.hazelcast.config.AbstractCacheConfig
 
getValueType() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the value type for this ICache.
getVersion() - Method in interface com.hazelcast.cluster.Member
Returns the Hazelcast codebase version of this member; this may or may not be different from the version reported by Cluster.getClusterVersion(), for example when a node with a different codebase version is added to an existing cluster.
getVersion() - Method in interface com.hazelcast.core.EntryView
Returns the version of the entry.
getVersion() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
Returns the version.
getVersion() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
getVersion() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
 
getVersion() - Method in interface com.hazelcast.nio.serialization.PortableReader
 
getVersion() - Method in interface com.hazelcast.nio.VersionAware
 
getVersion() - Method in interface com.hazelcast.spi.merge.MergingVersion
Returns the version of the merge data.
getWanProtocolVersion() - Method in interface com.hazelcast.nio.WanProtocolVersionAware
Returns the WAN protocol version.
getWanReplicationConfig(String) - Method in class com.hazelcast.config.Config
Returns the WAN replication configuration with the given name.
getWanReplicationConfigs() - Method in class com.hazelcast.config.Config
Returns the map of WAN replication configurations, mapped by config name.
getWanReplicationRef() - Method in class com.hazelcast.config.CacheConfig
 
getWanReplicationRef() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the WAN target replication reference.
getWanReplicationRef() - Method in class com.hazelcast.config.MapConfig
Gets the WAN target replication reference.
getWhitelist() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
getWhitelistedPrefixes() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Return currently configured whitelist prefixes
getWriteBatchSize() - Method in class com.hazelcast.config.MapStoreConfig
Returns the number of operations to be included in each batch processing round.
getWriteDelaySeconds() - Method in class com.hazelcast.config.MapStoreConfig
Returns the number of seconds to delay the store writes.
getXAResource() - Method in interface com.hazelcast.core.HazelcastInstance
Gets xaResource which will participate in XATransaction.
gigaBytes() - Method in class com.hazelcast.memory.MemorySize
Returns value of memory size in giga-bytes.
GLOBAL_HD_INDEX_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Enables use of the concurrent HD index introduced in 4.1 for the IMDG predicate API (old query engine) and reverts to using the per-partition indexes.
GlobalSerializerConfig - Class in com.hazelcast.config
Contains the configuration for global serializer.
GlobalSerializerConfig() - Constructor for class com.hazelcast.config.GlobalSerializerConfig
 
GlobalSerializerConfig(GlobalSerializerConfig) - Constructor for class com.hazelcast.config.GlobalSerializerConfig
 
GRACEFUL_SHUTDOWN_MAX_WAIT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Maximum wait in seconds during graceful shutdown.
greaterEqual(Comparable) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
greaterEqual(String, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates a greater than or equal to predicate that will pass items if the value stored under the given item attribute is greater than or equal to the given value.
greaterThan(Comparable) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
greaterThan(String, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates a greater than predicate that will pass items if the value stored under the given item attribute is greater than the given value.
GROUP - Static variable in class com.hazelcast.spi.discovery.multicast.MulticastProperties
Property used to define zones for node filtering.

H

handleAddListener(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleAutoDetection(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleClear(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleClient(Node) - Method in class com.hazelcast.spring.HazelcastClientBeanDefinitionParser.SpringXmlBuilder
 
handleCommand(String) - Method in class com.hazelcast.console.ConsoleApp
Handles a command.
handleCommonBeanAttributes(Node, BeanDefinitionBuilder, ParserContext) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleContains(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleDataSerializableFactories(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleDestroy(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleDiscoveryStrategies(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleExit() - Method in class com.hazelcast.console.ConsoleApp
 
handleIndex(ManagedList<BeanDefinition>, Node) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleInstances(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleIterator(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleJavaSerializationFilter(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleListAdd(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleListAddMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleListContains(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleListRemove(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleListSet(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapDelete(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapEntries() - Method in class com.hazelcast.console.ConsoleApp
 
handleMapEvict(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapGet(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapGetAsync(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapGetMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapGetMapEntry(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapKeys() - Method in class com.hazelcast.console.ConsoleApp
 
handleMapLocalKeys() - Method in class com.hazelcast.console.ConsoleApp
 
handleMapLocalSize() - Method in class com.hazelcast.console.ConsoleApp
 
handleMapLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapPut(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapPutAsync(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapPutIfAbsent(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapPutMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapRemove(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapRemoveMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapReplace(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapTryLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapUnlock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapValues() - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapEntries() - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapGet(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapKeys() - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapPut(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapRemove(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapTryLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapUnlock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapValues() - Method in class com.hazelcast.console.ConsoleApp
 
handleNativeMemory(Node) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handlePartitions(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handlePortableFactories(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleProperties(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleQCapacity(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQOffer(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQOfferMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQPeek(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQPoll(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQPollMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQTake(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleRemoveListener(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleSerialization(Node) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleSerializers(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleSetAdd(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleSetAddMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleSetRemove(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleSetRemoveMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleShutdown() - Method in class com.hazelcast.console.ConsoleApp
 
handleSize(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleSocketInterceptorConfig(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleSpringAware() - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleTopicPublish(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
hasDefiniteSize() - Method in enum com.hazelcast.nio.serialization.FieldType
 
hasField(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
Checks if there exists a FieldDefinition with the given fieldName.
hasField(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
 
hasField(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
hashCode() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
 
hashCode() - Method in class com.hazelcast.client.config.ClientCloudConfig
 
hashCode() - Method in class com.hazelcast.client.config.ClientConfig
 
hashCode() - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
 
hashCode() - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
 
hashCode() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
hashCode() - Method in class com.hazelcast.client.config.ClientMetricsConfig
 
hashCode() - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
hashCode() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
 
hashCode() - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
hashCode() - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
hashCode() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
 
hashCode() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
 
hashCode() - Method in class com.hazelcast.client.config.SocketOptions
 
hashCode() - Method in class com.hazelcast.cluster.Address
 
hashCode() - Method in class com.hazelcast.config.AbstractCacheConfig
 
hashCode() - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
 
hashCode() - Method in class com.hazelcast.config.AbstractWanPublisherConfig
 
hashCode() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
 
hashCode() - Method in class com.hazelcast.config.AttributeConfig
 
hashCode() - Method in class com.hazelcast.config.BitmapIndexOptions
 
hashCode() - Method in class com.hazelcast.config.CacheConfig
 
hashCode() - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
 
hashCode() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
hashCode() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
hashCode() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
hashCode() - Method in class com.hazelcast.config.CacheSimpleConfig
 
hashCode() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
hashCode() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
hashCode() - Method in class com.hazelcast.config.ClassFilter
 
hashCode() - Method in class com.hazelcast.config.CollectionConfig
 
hashCode() - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
hashCode() - Method in class com.hazelcast.config.DiscoveryConfig
 
hashCode() - Method in class com.hazelcast.config.DurableExecutorConfig
 
hashCode() - Method in class com.hazelcast.config.EncryptionAtRestConfig
 
hashCode() - Method in class com.hazelcast.config.EntryListenerConfig
 
hashCode() - Method in class com.hazelcast.config.EventJournalConfig
 
hashCode() - Method in class com.hazelcast.config.EvictionConfig
 
hashCode() - Method in class com.hazelcast.config.ExecutorConfig
 
hashCode() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
hashCode() - Method in class com.hazelcast.config.GlobalSerializerConfig
 
hashCode() - Method in class com.hazelcast.config.HotRestartConfig
 
hashCode() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
 
hashCode() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
hashCode() - Method in class com.hazelcast.config.IndexConfig
 
hashCode() - Method in class com.hazelcast.config.InstanceTrackingConfig
 
hashCode() - Method in class com.hazelcast.config.InterfacesConfig
 
hashCode() - Method in class com.hazelcast.config.ItemListenerConfig
 
hashCode() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
 
hashCode() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
hashCode() - Method in class com.hazelcast.config.ListenerConfig
 
hashCode() - Method in class com.hazelcast.config.LoginModuleConfig
 
hashCode() - Method in class com.hazelcast.config.ManagementCenterConfig
 
hashCode() - Method in class com.hazelcast.config.MapConfig
 
hashCode() - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
 
hashCode() - Method in class com.hazelcast.config.MapStoreConfig
 
hashCode() - Method in class com.hazelcast.config.matcher.MatchingPointConfigPatternMatcher
 
hashCode() - Method in class com.hazelcast.config.matcher.RegexConfigPatternMatcher
 
hashCode() - Method in class com.hazelcast.config.matcher.WildcardConfigPatternMatcher
 
hashCode() - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
hashCode() - Method in class com.hazelcast.config.MemberGroupConfig
 
hashCode() - Method in class com.hazelcast.config.MergePolicyConfig
 
hashCode() - Method in class com.hazelcast.config.MerkleTreeConfig
 
hashCode() - Method in class com.hazelcast.config.MetricsConfig
 
hashCode() - Method in class com.hazelcast.config.MetricsJmxConfig
 
hashCode() - Method in class com.hazelcast.config.MetricsManagementCenterConfig
 
hashCode() - Method in class com.hazelcast.config.MulticastConfig
 
hashCode() - Method in class com.hazelcast.config.MultiMapConfig
 
hashCode() - Method in class com.hazelcast.config.NativeMemoryConfig
 
hashCode() - Method in class com.hazelcast.config.NearCacheConfig
 
hashCode() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
hashCode() - Method in class com.hazelcast.config.PartitionGroupConfig
 
hashCode() - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
hashCode() - Method in class com.hazelcast.config.PermissionConfig
 
hashCode() - Method in class com.hazelcast.config.PermissionPolicyConfig
 
hashCode() - Method in class com.hazelcast.config.PersistentMemoryConfig
 
hashCode() - Method in class com.hazelcast.config.PersistentMemoryDirectoryConfig
 
hashCode() - Method in class com.hazelcast.config.PNCounterConfig
 
hashCode() - Method in class com.hazelcast.config.PredicateConfig
 
hashCode() - Method in class com.hazelcast.config.QueryCacheConfig
 
hashCode() - Method in class com.hazelcast.config.QueueConfig
 
hashCode() - Method in class com.hazelcast.config.QueueStoreConfig
 
hashCode() - Method in class com.hazelcast.config.ReliableTopicConfig
 
hashCode() - Method in class com.hazelcast.config.ReplicatedMapConfig
 
hashCode() - Method in class com.hazelcast.config.RingbufferConfig
 
hashCode() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
hashCode() - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
hashCode() - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
 
hashCode() - Method in class com.hazelcast.config.security.CredentialsIdentityConfig
 
hashCode() - Method in class com.hazelcast.config.security.JaasAuthenticationConfig
 
hashCode() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
 
hashCode() - Method in class com.hazelcast.config.security.KerberosIdentityConfig
 
hashCode() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
hashCode() - Method in class com.hazelcast.config.security.RealmConfig
 
hashCode() - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
 
hashCode() - Method in class com.hazelcast.config.security.TokenIdentityConfig
 
hashCode() - Method in class com.hazelcast.config.security.UsernamePasswordIdentityConfig
 
hashCode() - Method in class com.hazelcast.config.SecurityConfig
 
hashCode() - Method in class com.hazelcast.config.SerializationConfig
 
hashCode() - Method in class com.hazelcast.config.SerializerConfig
 
hashCode() - Method in class com.hazelcast.config.ServiceConfig
 
hashCode() - Method in class com.hazelcast.config.SocketInterceptorConfig
 
hashCode() - Method in class com.hazelcast.config.SSLConfig
 
hashCode() - Method in class com.hazelcast.config.TcpIpConfig
 
hashCode() - Method in class com.hazelcast.config.TopicConfig
 
hashCode() - Method in class com.hazelcast.config.VaultSecureStoreConfig
 
hashCode() - Method in class com.hazelcast.config.WanConsumerConfig
 
hashCode() - Method in class com.hazelcast.config.WanReplicationConfig
 
hashCode() - Method in class com.hazelcast.config.WanReplicationRef
 
hashCode() - Method in class com.hazelcast.config.WanSyncConfig
 
hashCode() - Method in class com.hazelcast.core.HazelcastJsonValue
 
hashCode() - Method in class com.hazelcast.core.LifecycleEvent
 
hashCode() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
hashCode() - Method in class com.hazelcast.memory.MemorySize
 
hashCode() - Method in class com.hazelcast.partition.PartitionAwareKey
 
hashCode() - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
hashCode() - Method in class com.hazelcast.security.permission.AllPermissions
 
hashCode() - Method in class com.hazelcast.security.permission.ClusterPermission
 
hashCode() - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
 
hashCode() - Method in class com.hazelcast.security.permission.InstancePermission
 
hashCode() - Method in class com.hazelcast.security.SimpleTokenCredentials
 
hashCode() - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
hashCode() - Method in class com.hazelcast.sql.SqlColumnMetadata
 
hashCode() - Method in class com.hazelcast.sql.SqlRowMetadata
 
hashCode() - Method in class com.hazelcast.sql.SqlStatement
 
hashCode() - Method in class com.hazelcast.version.MemberVersion
 
hashCode() - Method in class com.hazelcast.version.Version
 
hasIdentityConfig() - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
hasListenerConfiguration() - Method in class com.hazelcast.config.AbstractCacheConfig
 
hasMember(Member) - Method in interface com.hazelcast.spi.partitiongroup.MemberGroup
 
hasMinimumSize() - Method in interface com.hazelcast.splitbrainprotection.SplitBrainProtection
Returns true if the minimum cluster size is satisfied, otherwise false.
hasNext() - Method in class com.hazelcast.spi.merge.RingbufferMergeDataReadOnlyIterator
 
hasTransformedResource() - Method in class com.hazelcast.buildutils.HazelcastManifestTransformer
 
Hazelcast - Class in com.hazelcast.core
Factory for HazelcastInstance's, a node in a cluster.
HAZELCAST_CLOUD_DISCOVERY_TOKEN - Static variable in class com.hazelcast.client.properties.ClientProperty
Token to use when discovering cluster via hazelcast.cloud
HAZELCAST_CONFIG_LOCATION - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
Hazelcast config location property
HAZELCAST_INSTANCE_ITSELF - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
Hazelcast instance itself property
HAZELCAST_INSTANCE_NAME - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
Hazelcast instance name property
HAZELCAST_OSGI_GROUPING_DISABLED - Static variable in interface com.hazelcast.osgi.HazelcastOSGiService
System property for disabling the behaviour that gives different cluster name to each Hazelcast bundle.
HAZELCAST_OSGI_JSR223_DISABLED - Static variable in interface com.hazelcast.osgi.HazelcastOSGiService
System property for disabling the JSR-223 script engine scan by the Hazelcast OSGI service.
HAZELCAST_OSGI_REGISTER_DISABLED - Static variable in interface com.hazelcast.osgi.HazelcastOSGiService
System property for disabling the behaviour that registers created Hazelcast instances as OSGI service.
HAZELCAST_OSGI_START - Static variable in interface com.hazelcast.osgi.HazelcastOSGiService
System property for starting a default Hazelcast instance per Hazelcast OSGI bundle.
HazelcastCache - Class in com.hazelcast.spring.cache
Sprint related Cache implementation for Hazelcast.
HazelcastCache(IMap<Object, Object>) - Constructor for class com.hazelcast.spring.cache.HazelcastCache
 
HazelcastCacheManager - Interface in com.hazelcast.cache
Contract point of Hazelcast cache manager implementations (client + server) based on CacheManager.
HazelcastCacheManager - Class in com.hazelcast.spring.cache
Sprint related HazelcastCacheManager implementation for Hazelcast.
HazelcastCacheManager() - Constructor for class com.hazelcast.spring.cache.HazelcastCacheManager
 
HazelcastCacheManager(HazelcastInstance) - Constructor for class com.hazelcast.spring.cache.HazelcastCacheManager
 
HazelcastCachingProvider - Class in com.hazelcast.cache
Hazelcast implementation of JCache CachingProvider.
HazelcastCachingProvider() - Constructor for class com.hazelcast.cache.HazelcastCachingProvider
 
HazelcastClient - Class in com.hazelcast.client
The HazelcastClient is comparable to the Hazelcast class and provides the ability the create and manage Hazelcast clients.
HazelcastClientBeanDefinitionParser - Class in com.hazelcast.spring
BeanDefinitionParser for Hazelcast Client Configuration.
HazelcastClientBeanDefinitionParser() - Constructor for class com.hazelcast.spring.HazelcastClientBeanDefinitionParser
 
HazelcastClientBeanDefinitionParser.SpringXmlBuilder - Class in com.hazelcast.spring
Client bean definition builder
HazelcastClientCachingProvider - Class in com.hazelcast.client.cache
Client-side CachingProvider implementation.
HazelcastClientCachingProvider() - Constructor for class com.hazelcast.client.cache.HazelcastClientCachingProvider
 
HazelcastClientNotActiveException - Exception in com.hazelcast.client
Thrown when Hazelcast client is not active during an invocation.
HazelcastClientNotActiveException() - Constructor for exception com.hazelcast.client.HazelcastClientNotActiveException
 
HazelcastClientNotActiveException(String) - Constructor for exception com.hazelcast.client.HazelcastClientNotActiveException
 
HazelcastClientNotActiveException(String, Throwable) - Constructor for exception com.hazelcast.client.HazelcastClientNotActiveException
 
HazelcastClientOfflineException - Exception in com.hazelcast.client
Thrown when Hazelcast client is offline during an invocation.
HazelcastClientOfflineException() - Constructor for exception com.hazelcast.client.HazelcastClientOfflineException
 
HazelcastConfigBeanDefinitionParser - Class in com.hazelcast.spring
BeanDefinitionParser for Hazelcast Config Configuration.
HazelcastConfigBeanDefinitionParser() - Constructor for class com.hazelcast.spring.HazelcastConfigBeanDefinitionParser
 
HazelcastException - Exception in com.hazelcast.core
Base Hazelcast exception.
HazelcastException() - Constructor for exception com.hazelcast.core.HazelcastException
 
HazelcastException(String) - Constructor for exception com.hazelcast.core.HazelcastException
 
HazelcastException(String, Throwable) - Constructor for exception com.hazelcast.core.HazelcastException
 
HazelcastException(Throwable) - Constructor for exception com.hazelcast.core.HazelcastException
 
HazelcastExpiryPolicy - Class in com.hazelcast.cache
Hazelcast provides overloads of the typical cache operations with a custom ExpiryPolicy parameter.
This class provides a custom implementation of an ExpiryPolicy to react on all three types of policies: Create Access Update
HazelcastExpiryPolicy() - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
Default constructor to serialize/deserialize
HazelcastExpiryPolicy(long, long, long) - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
Constructs an expiry policy with provided values for creation, access and update in milliseconds.
HazelcastExpiryPolicy(long, long, long, TimeUnit) - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
Constructs an expiry policy with provided values for creation, access and update as well as a TimeUnit to convert those values to internally used time unites.
HazelcastExpiryPolicy(ExpiryPolicy) - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
Copy Constructor for an already existing ExpiryPolicy.
HazelcastExpiryPolicy(Duration, Duration, Duration) - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
Constructs an expiry policy with provided values for creation, access and update by providing instances of the Duration class.
HazelcastFailoverClientBeanDefinitionParser - Class in com.hazelcast.spring
BeanDefinitionParser for Hazelcast Client Configuration.
HazelcastFailoverClientBeanDefinitionParser() - Constructor for class com.hazelcast.spring.HazelcastFailoverClientBeanDefinitionParser
 
HazelcastInstance - Interface in com.hazelcast.core
Hazelcast instance.
HazelcastInstanceAware - Interface in com.hazelcast.core
Used to get HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService.
HazelcastInstanceCallback - Class in com.hazelcast.security
This JAAS Callback is used to retrieve the current HazelcastInstance.
HazelcastInstanceCallback() - Constructor for class com.hazelcast.security.HazelcastInstanceCallback
 
HazelcastInstanceDefinitionParser - Class in com.hazelcast.spring
BeanDefinitionParser for Hazelcast Instance Configuration.
HazelcastInstanceDefinitionParser() - Constructor for class com.hazelcast.spring.HazelcastInstanceDefinitionParser
 
HazelcastInstanceNotActiveException - Exception in com.hazelcast.core
Thrown when HazelcastInstance is not active during an invocation.
HazelcastInstanceNotActiveException() - Constructor for exception com.hazelcast.core.HazelcastInstanceNotActiveException
 
HazelcastInstanceNotActiveException(String) - Constructor for exception com.hazelcast.core.HazelcastInstanceNotActiveException
 
HazelcastJsonValue - Class in com.hazelcast.core
HazelcastJsonValue is a wrapper for JSON formatted strings.
HazelcastJsonValue(String) - Constructor for class com.hazelcast.core.HazelcastJsonValue
Creates a HazelcastJsonValue from the given string.
HazelcastManifestTransformer - Class in com.hazelcast.buildutils
This transformer implementation is used to merge MANIFEST and OSGi bundle metadata in conjunction with the Maven Shade plugin when integrating multiple dependencies into one output JAR.
HazelcastManifestTransformer() - Constructor for class com.hazelcast.buildutils.HazelcastManifestTransformer
 
HazelcastMemberCachingProvider - Class in com.hazelcast.cache
Member-side CachingProvider implementation.
HazelcastMemberCachingProvider() - Constructor for class com.hazelcast.cache.HazelcastMemberCachingProvider
 
HazelcastNamespaceHandler - Class in com.hazelcast.spring
Hazelcast Custom Namespace Definitions.
HazelcastNamespaceHandler() - Constructor for class com.hazelcast.spring.HazelcastNamespaceHandler
 
HazelcastOSGiInstance - Interface in com.hazelcast.osgi
Contract point for HazelcastInstance implementations based on OSGi service.
HazelcastOSGiService - Interface in com.hazelcast.osgi
Contract point for Hazelcast services on top of OSGI.
HazelcastOverloadException - Exception in com.hazelcast.core
A HazelcastException that is thrown when the system won't handle more load due to an overload.
HazelcastOverloadException(String) - Constructor for exception com.hazelcast.core.HazelcastOverloadException
 
HazelcastOverloadException(String, Throwable) - Constructor for exception com.hazelcast.core.HazelcastOverloadException
 
HazelcastProperties - Class in com.hazelcast.spi.properties
Container for configured Hazelcast properties (see HazelcastProperty).
HazelcastProperties(Config) - Constructor for class com.hazelcast.spi.properties.HazelcastProperties
Creates a container with configured Hazelcast properties.
HazelcastProperties(Properties) - Constructor for class com.hazelcast.spi.properties.HazelcastProperties
Creates a container with configured Hazelcast properties.
HazelcastProperty - Class in com.hazelcast.spi.properties
Interface for Hazelcast Member and Client properties.
HazelcastProperty(String) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, Function<HazelcastProperties, ?>) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, Enum<?>) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, boolean) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, Integer) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, Double) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, Float) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, Byte) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, Integer, TimeUnit) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, Long, TimeUnit) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, HazelcastProperty) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, String) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, String, TimeUnit) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, String, TimeUnit, HazelcastProperty) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastRelOptCluster - Class in org.apache.calcite.plan
Extended RelOptCluster with Hazelcast-specific data.
HazelcastRootCalciteSchema - Class in org.apache.calcite.jdbc
Root Calcite schema.
HazelcastRootCalciteSchema(HazelcastSchema) - Constructor for class org.apache.calcite.jdbc.HazelcastRootCalciteSchema
 
HazelcastRuntimePermission - Class in com.hazelcast.security.jsm
Class which holds named Hazelcast permissions for Security Manager checks.
HazelcastRuntimePermission(String) - Constructor for class com.hazelcast.security.jsm.HazelcastRuntimePermission
Creates permission with given name.
HazelcastRuntimePermission(String, String) - Constructor for class com.hazelcast.security.jsm.HazelcastRuntimePermission
Creates permission with given name.
HazelcastSerializationException - Exception in com.hazelcast.nio.serialization
An exception thrown when a problem occurs while serializing/deserializing objects.
HazelcastSerializationException(String) - Constructor for exception com.hazelcast.nio.serialization.HazelcastSerializationException
 
HazelcastSerializationException(String, Throwable) - Constructor for exception com.hazelcast.nio.serialization.HazelcastSerializationException
 
HazelcastSerializationException(Throwable) - Constructor for exception com.hazelcast.nio.serialization.HazelcastSerializationException
 
HazelcastSqlException - Exception in com.hazelcast.sql
An exception occurred during SQL query execution.
HazelcastSqlException(UUID, int, String, Throwable) - Constructor for exception com.hazelcast.sql.HazelcastSqlException
 
HazelcastTransactionManager - Class in com.hazelcast.spring.transaction
PlatformTransactionManager implementation for a single HazelcastInstance.
HazelcastTransactionManager(HazelcastInstance) - Constructor for class com.hazelcast.spring.transaction.HazelcastTransactionManager
 
HazelcastTypeBeanDefinitionParser - Class in com.hazelcast.spring
BeanDefinitionParser for Type Configuration of Hazelcast Types like map, queue, topic etc.
HazelcastTypeBeanDefinitionParser(String) - Constructor for class com.hazelcast.spring.HazelcastTypeBeanDefinitionParser
 
HazelcastXAResource - Interface in com.hazelcast.transaction
Interface for providing Hazelcast as an XAResource
headSequence() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Returns the sequence of the head.
HEALTH_MONITORING_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Health monitoring logging interval in seconds.
HEALTH_MONITORING_LEVEL - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Health monitoring log level.
HEALTH_MONITORING_THRESHOLD_CPU_PERCENTAGE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
When the health monitoring level is SILENT, logs are printed only when the CPU usage exceeds this threshold.
HEALTH_MONITORING_THRESHOLD_MEMORY_PERCENTAGE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
When the health monitoring level is SILENT, logs are printed only when the memory usage exceeds this threshold.
HEARTBEAT_FAILURE_DETECTOR_TYPE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Heartbeat failure detector type.
HEARTBEAT_INTERVAL - Static variable in class com.hazelcast.client.properties.ClientProperty
Time interval between the heartbeats sent by the client to the nodes.
HEARTBEAT_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
The interval at which member heartbeat messages are sent
HEARTBEAT_TIMEOUT - Static variable in class com.hazelcast.client.properties.ClientProperty
Client sends heartbeat messages to the members and this is the timeout for this sending operations.
HeartbeatAware - Interface in com.hazelcast.splitbrainprotection
SplitBrainProtectionFunctions which implement this interface will be notified of member heartbeats.
HigherHitsMergePolicy<V,T extends MergingValue<V> & MergingHits> - Class in com.hazelcast.spi.merge
Merges data structure entries from source to destination data structure if the source entry has more hits than the destination one.
HigherHitsMergePolicy() - Constructor for class com.hazelcast.spi.merge.HigherHitsMergePolicy
 
HOT_RESTART_BASE_DIR_DEFAULT - Static variable in class com.hazelcast.config.HotRestartPersistenceConfig
Default directory name for the Hot Restart store's home
HOT_RESTART_FREE_NATIVE_MEMORY_PERCENTAGE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
XML and system property for setting the hot restart required free space.
HotRestartClusterDataRecoveryPolicy - Enum in com.hazelcast.config
Specifies the policy that will be respected during hot restart cluster start
hotRestartConfig - Variable in class com.hazelcast.config.AbstractCacheConfig
 
HotRestartConfig - Class in com.hazelcast.config
Configures the Hot Restart Persistence per Hazelcast data structure.
HotRestartConfig() - Constructor for class com.hazelcast.config.HotRestartConfig
 
HotRestartConfig(HotRestartConfig) - Constructor for class com.hazelcast.config.HotRestartConfig
 
HotRestartPersistenceConfig - Class in com.hazelcast.config
Configures the Hot Restart stores.
HotRestartPersistenceConfig() - Constructor for class com.hazelcast.config.HotRestartPersistenceConfig
 
HotRestartService - Interface in com.hazelcast.hotrestart
Service for interacting with Hot Restart.
HyperLogLogMergePolicy - Class in com.hazelcast.spi.merge
Only available for HyperLogLog backed CardinalityEstimator.
HyperLogLogMergePolicy() - Constructor for class com.hazelcast.spi.merge.HyperLogLogMergePolicy
 

I

IAtomicLong - Interface in com.hazelcast.cp
IAtomicLong is a redundant and highly available distributed alternative to the AtomicLong.
IAtomicReference<E> - Interface in com.hazelcast.cp
IAtomicReference is a redundant and highly available distributed alternative to the AtomicReference.
ICache<K,V> - Interface in com.hazelcast.cache
This ICache interface is the Cache extension offered by Hazelcast JCache.
In addition to the standard set of JCache methods defined in the JSR 107 specification, Hazelcast provides additional operations to support a broader range of programing styles.
ICacheManager - Interface in com.hazelcast.core
ICacheManager is the entry point to access JSR-107 (JCache) caches via HazelcastInstance interface.
IcmpFailureDetectorConfig - Class in com.hazelcast.config
This Failure Detector may be configured in addition to one of Deadline and Phi Accual Failure Detectors.
It operates at Layer 3 of the OSI protocol, and provides much quicker and more deterministic detection of hardware
and other lower level events.
IcmpFailureDetectorConfig() - Constructor for class com.hazelcast.config.IcmpFailureDetectorConfig
 
ICollection<E> - Interface in com.hazelcast.collection
Concurrent, distributed, partitioned, listenable collection.
ICountDownLatch - Interface in com.hazelcast.cp
ICountDownLatch is a backed-up distributed alternative to the java.util.concurrent.CountDownLatch.
ICredentialsFactory - Interface in com.hazelcast.security
ICredentialsFactory is used to create Credentials objects to be used during node authentication before connection is accepted by the master node.
id() - Method in interface com.hazelcast.cp.CPGroup
Returns unique id of the CP group
id() - Method in enum com.hazelcast.cp.event.CPMembershipEvent.EventType
 
id() - Method in interface com.hazelcast.cp.session.CPSession
Returns id of the session
id() - Method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
 
IdentifiedDataSerializable - Interface in com.hazelcast.nio.serialization
IdentifiedDataSerializable is an extension to DataSerializable to avoid reflection during de-serialization.
identity() - Static method in interface com.hazelcast.function.FunctionEx
identity() - Static method in class com.hazelcast.projection.Projections
Returns a projection that does no transformation.
IdentityConfig - Interface in com.hazelcast.config.security
This interface represents identity configuration in security realms or client security configurations.
IExecutorService - Interface in com.hazelcast.core
Distributed implementation of ExecutorService.
IFunction<T,R> - Interface in com.hazelcast.core
Represents a function that accepts one argument and produces a result.
ilike(String, String) - Static method in class com.hazelcast.query.Predicates
Creates a case-insensitive like predicate that will pass items if the given pattern matches the value stored under the given item attribute in a case-insensitive manner.
IList<E> - Interface in com.hazelcast.collection
Concurrent, distributed implementation of List.
ILogger - Interface in com.hazelcast.logging
The Hazelcast logging interface.
IMap<K,V> - Interface in com.hazelcast.map
Concurrent, distributed, observable and queryable map.
IMapEvent - Interface in com.hazelcast.map
Map events common contract.
implementation - Variable in class com.hazelcast.config.AbstractWanPublisherConfig
 
implementation - Variable in class com.hazelcast.config.ListenerConfig
 
implementation - Variable in class com.hazelcast.config.PredicateConfig
 
implementation - Variable in class com.hazelcast.config.SecurityInterceptorConfig
 
implies(Permission) - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
implies(Permission) - Method in class com.hazelcast.security.permission.AllPermissions
 
implies(Permission) - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
 
implies(Permission) - Method in class com.hazelcast.security.permission.ConfigPermission
 
implies(Permission) - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
 
implies(Permission) - Method in class com.hazelcast.security.permission.InstancePermission
 
implies(Permission) - Method in class com.hazelcast.security.permission.TransactionPermission
 
importDocuments(YamlNode) - Method in class com.hazelcast.config.AbstractYamlConfigBuilder
Imports external YAML documents into the provided main YAML document.
in(Comparable...) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
in(String, Comparable...) - Static method in class com.hazelcast.query.Predicates
Creates a in predicate that will pass items if the value stored under the given item attribute is a member of the given values set.
increasePermits(int) - Method in interface com.hazelcast.cp.ISemaphore
Increases the number of available permits by the indicated amount.
incrementAndGet() - Method in interface com.hazelcast.cp.IAtomicLong
Atomically increments the current value by one.
incrementAndGet() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Increments by one the current value.
incrementAndGetAsync() - Method in interface com.hazelcast.cp.IAtomicLong
Atomically increments the current value by one.
incrementDropped(String) - Method in class com.hazelcast.wan.WanEventCounters
Increment the number of dropped events for the distributedObjectName.
incrementRemove(String) - Method in class com.hazelcast.wan.WanEventCounters
Increment the number of remove events for the distributedObjectName.
incrementSync(String) - Method in class com.hazelcast.wan.WanEventCounters
Increment the number of sync events for the distributedObjectName.
incrementSync(String, int) - Method in class com.hazelcast.wan.WanEventCounters
Increment the number of sync events for the distributedObjectName by count.
incrementUpdate(String) - Method in class com.hazelcast.wan.WanEventCounters
Increment the number of update events for the distributedObjectName.
IndeterminateOperationState - Interface in com.hazelcast.core
A marker interface for exceptions to denote that execution status of an invocation is not known
IndeterminateOperationStateException - Exception in com.hazelcast.core
IndeterminateOperationStateException is thrown when result of an invocation becomes indecisive.
IndeterminateOperationStateException() - Constructor for exception com.hazelcast.core.IndeterminateOperationStateException
 
IndeterminateOperationStateException(String) - Constructor for exception com.hazelcast.core.IndeterminateOperationStateException
 
IndeterminateOperationStateException(String, Throwable) - Constructor for exception com.hazelcast.core.IndeterminateOperationStateException
 
INDEX_COPY_BEHAVIOR - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Type of Query Index result copying behavior.
IndexConfig - Class in com.hazelcast.config
Configuration of an index.
IndexConfig() - Constructor for class com.hazelcast.config.IndexConfig
 
IndexConfig(IndexType) - Constructor for class com.hazelcast.config.IndexConfig
Creates an index configuration of the given type.
IndexConfig(IndexType, String...) - Constructor for class com.hazelcast.config.IndexConfig
Creates an index configuration of the given type with provided attributes.
IndexConfig(IndexConfig) - Constructor for class com.hazelcast.config.IndexConfig
 
IndexType - Enum in com.hazelcast.config
Type of the index.
info(String) - Method in class com.hazelcast.logging.AbstractLogger
 
info(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
info(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
info(String) - Method in interface com.hazelcast.logging.ILogger
Logs a message at the Level.INFO level.
info(Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a throwable at the Level.INFO level.
info(String, Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a message with an associated throwable at the Level.INFO level.
init(CallbackHandler, Properties) - Method in interface com.hazelcast.auditlog.AuditlogServiceFactory
Initializes this class with given properties.
init(Cluster, ClientConfig) - Method in interface com.hazelcast.client.LoadBalancer
Initializes the LoadBalancer.
init(InitialMembershipEvent) - Method in interface com.hazelcast.cluster.InitialMembershipListener
Called when this listener is registered.
init(Properties) - Method in class com.hazelcast.config.replacer.AbstractPbeReplacer
 
init(Properties) - Method in class com.hazelcast.config.replacer.EncryptionReplacer
 
init(Properties) - Method in class com.hazelcast.config.replacer.PropertyReplacer
 
init(Properties) - Method in interface com.hazelcast.config.replacer.spi.ConfigReplacer
Initialization method called before first usage of the config replacer.
init(int) - Method in interface com.hazelcast.cp.ISemaphore
Tries to initialize this ISemaphore instance with the given permit count
init(HazelcastInstance, Properties, String) - Method in interface com.hazelcast.map.MapLoaderLifecycleSupport
Initializes this MapLoader implementation.
init(Properties) - Method in interface com.hazelcast.nio.SocketInterceptor
Initializes socket interceptor with properties which is set by Config.setProperty(String, String)
init(Properties) - Method in interface com.hazelcast.security.ICredentialsFactory
This method is (only) called if the factory instance is newly created from a class name provided in CredentialsFactoryConfig.
init() - Method in class com.hazelcast.spring.HazelcastNamespaceHandler
 
init(String, WanConsumerConfig) - Method in interface com.hazelcast.wan.WanConsumer
Initialize the WAN consumer.
init(WanReplicationConfig, AbstractWanPublisherConfig) - Method in interface com.hazelcast.wan.WanPublisher
Initializes the publisher.
INIT_CLUSTER_VERSION - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Override cluster version to use while node is not yet member of a cluster.
INITIAL_MEMORY_SIZE - Static variable in class com.hazelcast.config.NativeMemoryConfig
Initial memory size in megabytes
INITIAL_MIN_CLUSTER_SIZE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Initial expected cluster size to wait before member to start completely.
INITIAL_WAIT_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Initial time in seconds to wait before member to start completely.
initialize(Object) - Method in interface com.hazelcast.core.ManagedContext
Initialize the given object instance.
initialize(Object) - Method in class com.hazelcast.spring.context.SpringManagedContext
 
InitialMembershipEvent - Class in com.hazelcast.cluster
An event that is sent when a InitialMembershipListener registers itself on a Cluster.
InitialMembershipEvent(Cluster, Set<Member>) - Constructor for class com.hazelcast.cluster.InitialMembershipEvent
 
InitialMembershipListener - Interface in com.hazelcast.cluster
The InitializingMembershipListener is a MembershipListener that first receives a InitialMembershipEvent when it is registered so it immediately knows which members are available.
initLoginModuleProperties() - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
 
initLoginModuleProperties() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
 
initLoginModuleProperties() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
initLoginModuleProperties() - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
 
initMask(String[]) - Method in class com.hazelcast.security.permission.AtomicLongPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.AtomicReferencePermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.CachePermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.CardinalityEstimatorPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.CountDownLatchPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.DurableExecutorServicePermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.ExecutorServicePermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.FlakeIdGeneratorPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.InstancePermission
init mask
initMask(String[]) - Method in class com.hazelcast.security.permission.ListPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.LockPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.MapPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.PNCounterPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.QueuePermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.ReliableTopicPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.ReplicatedMapPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.RingBufferPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.ScheduledExecutorPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.SemaphorePermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.TopicPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.UserCodeDeploymentPermission
 
InMemoryFormat - Enum in com.hazelcast.config
Storage format type of values stored in cluster
InMemoryXmlConfig - Class in com.hazelcast.config
Creates a Config loaded from an in-memory Hazelcast XML String.
InMemoryXmlConfig(String) - Constructor for class com.hazelcast.config.InMemoryXmlConfig
Creates a Config from the provided XML string and uses the System.properties to resolve variables in the XML.
InMemoryXmlConfig(String, Properties) - Constructor for class com.hazelcast.config.InMemoryXmlConfig
Creates a Config from the provided XML string and properties to resolve the variables in the XML.
InMemoryYamlConfig - Class in com.hazelcast.config
Creates a Config loaded from an in-memory Hazelcast YAML String.
InMemoryYamlConfig(String) - Constructor for class com.hazelcast.config.InMemoryYamlConfig
Creates a Config from the provided YAML string and uses the System.properties to resolve variables in the YAML.
InMemoryYamlConfig(String, Properties) - Constructor for class com.hazelcast.config.InMemoryYamlConfig
Creates a Config from the provided YAML string and properties to resolve the variables in the YAML.
inProgress() - Method in enum com.hazelcast.hotrestart.BackupTaskState
Returns if the backup task is in progress.
INSTANCE - Static variable in class com.hazelcast.config.security.DefaultAuthenticationConfig
Singleton instance.
INSTANCE - Static variable in class com.hazelcast.partition.strategy.StringAndPartitionAwarePartitioningStrategy
 
INSTANCE - Static variable in class com.hazelcast.partition.strategy.StringPartitioningStrategy
 
instanceOf(Class) - Static method in class com.hazelcast.query.Predicates
Creates an instance of predicate that will pass entries for which the value class is an instanceof the given klass.
InstancePermission - Class in com.hazelcast.security.permission
TODO: Object Permission
InstancePermission(String, String...) - Constructor for class com.hazelcast.security.permission.InstancePermission
 
InstanceTrackingConfig - Class in com.hazelcast.config
Configures tracking of a running Hazelcast instance.
InstanceTrackingConfig() - Constructor for class com.hazelcast.config.InstanceTrackingConfig
 
InstanceTrackingConfig(InstanceTrackingConfig) - Constructor for class com.hazelcast.config.InstanceTrackingConfig
 
InstanceTrackingConfig.InstanceMode - Enum in com.hazelcast.config
The mode in which this instance is running.
InstanceTrackingConfig.InstanceProductName - Enum in com.hazelcast.config
Product name for the Hazelcast instance
InstanceTrackingConfig.InstanceTrackingProperties - Enum in com.hazelcast.config
Enumeration of instance properties provided to the format pattern for output.
integerAvg() - Static method in class com.hazelcast.aggregation.Aggregators
 
integerAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
integerMax() - Static method in class com.hazelcast.aggregation.Aggregators
 
integerMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
integerMin() - Static method in class com.hazelcast.aggregation.Aggregators
 
integerMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
integerSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
integerSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
interceptAfter(Credentials, String, String, String) - Method in interface com.hazelcast.security.SecurityContext
intercepts a request after process if any SecurityInterceptor configured Any exception thrown during interception will be ignored
interceptBefore(Credentials, String, String, String, Object[]) - Method in interface com.hazelcast.security.SecurityContext
intercepts a request before process if any SecurityInterceptor configured
interceptGet(Object) - Method in interface com.hazelcast.map.MapInterceptor
Intercepts the get operation before returning value.
interceptPut(Object, Object) - Method in interface com.hazelcast.map.MapInterceptor
Intercepts the put operation before modifying the map data.
interceptRemove(Object) - Method in interface com.hazelcast.map.MapInterceptor
Intercepts the remove operation before removing the data.
interfaces - Variable in class com.hazelcast.config.EndpointConfig
 
InterfacesConfig - Class in com.hazelcast.config
Contains the configuration for Interfaces.
InterfacesConfig() - Constructor for class com.hazelcast.config.InterfacesConfig
 
interruptBackupTask() - Method in interface com.hazelcast.hotrestart.HotRestartService
Interrupts the backup tasks on each cluster member if one is currently running.
interruptLocalBackupTask() - Method in interface com.hazelcast.hotrestart.HotRestartService
Interrupts the local backup task if one is currently running.
INVALID_FENCE - Static variable in interface com.hazelcast.cp.lock.FencedLock
Representation of a failed lock attempt where the caller thread has not acquired the lock
InvalidConfigurationException - Exception in com.hazelcast.config
A InvalidConfigurationException is thrown when an Hazelcast faces an invalid configuration.
InvalidConfigurationException(String) - Constructor for exception com.hazelcast.config.InvalidConfigurationException
Creates a InvalidConfigurationException with the given message.
InvalidConfigurationException(String, Throwable) - Constructor for exception com.hazelcast.config.InvalidConfigurationException
Constructs a new runtime exception with the specified detail message and cause.
INVOCATION_MAX_RETRY_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Maximum number of retries for an invocation.
INVOCATION_RETRY_PAUSE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Pause time between each retry cycle of an invocation in milliseconds.
INVOCATION_RETRY_PAUSE_MILLIS - Static variable in class com.hazelcast.client.properties.ClientProperty
Pause time between each retry cycle of an invocation in milliseconds.
INVOCATION_TIMEOUT_SECONDS - Static variable in class com.hazelcast.client.properties.ClientProperty
When an invocation gets an exception because : - Member throws an exception.
IO_BALANCER_INTERVAL_SECONDS - Static variable in class com.hazelcast.client.properties.ClientProperty
The interval in seconds between IOBalancer executions.
IO_BALANCER_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
The interval in seconds between IOBalancer executions.
IO_INPUT_THREAD_COUNT - Static variable in class com.hazelcast.client.properties.ClientProperty
Controls the number of IO input threads.
IO_INPUT_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Controls the number of socket input threads.
IO_OUTPUT_THREAD_COUNT - Static variable in class com.hazelcast.client.properties.ClientProperty
Controls the number of IO output threads.
IO_OUTPUT_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Controls the number of socket output threads.
IO_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
The number of threads doing socket input and the number of threads doing socket output.
IO_WRITE_THROUGH_ENABLED - Static variable in class com.hazelcast.client.properties.ClientProperty
Optimization that allows sending of packets over the network to be done on the calling thread if the conditions are right.
IO_WRITE_THROUGH_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Optimization that allows sending of packets over the network to be done on the calling thread if the conditions are right.
IPermissionPolicy - Interface in com.hazelcast.security
IPermissionPolicy is used to determine any Subject's permissions to perform a security sensitive Hazelcast operation.
IQueue<E> - Interface in com.hazelcast.collection
Concurrent, blocking, distributed, observable queue.
is(String) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
isAllowUnsafe() - Method in class com.hazelcast.config.SerializationConfig
Unsafe, it is not public api of java.
isArrayType() - Method in enum com.hazelcast.nio.serialization.FieldType
 
isAssignedToMember() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
 
isAssignedToPartition() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
 
isAsyncFillup() - Method in class com.hazelcast.config.ReplicatedMapConfig
True if the replicated map is available for reads before the initial replication is completed, false otherwise.
isAsyncStart() - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
Client instance creation won't block on HazelcastClient.newHazelcastClient() if this value is true
isAuthenticationConfigured() - Method in class com.hazelcast.config.security.RealmConfig
 
isAutoDetectionApplicable() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategyFactory
Checks whether the given discovery strategy may be applied with no additional config to the environment in which Hazelcast is currently running.
isAutoDetectionEnabled() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Any other connect configuration takes precedence over auto-discovery, so auto-discovery is enabled only when no other strategy is enabled.
isAutoDetectionEnabled() - Method in class com.hazelcast.config.JoinConfig
Any other join configuration takes precedence over auto-discovery, so auto-discovery is enabled only when no other join strategy is enabled.
isAutoDetectionEnabled() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
isAutoRemoveStaleData() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Returns whether or not automatically removal of stale Hot Restart data is enabled.
isBackupAckToClientEnabled() - Method in class com.hazelcast.client.config.ClientConfig
Note that backup acks to client can be enabled only for smart client.
isBetween(Version, Version) - Method in class com.hazelcast.version.Version
Checks if the version is between specified version (both ends inclusive)
isBinary() - Method in class com.hazelcast.config.MultiMapConfig
Checks if the MultiMap is in binary (serialized) form.
isCacheLocalEntries() - Method in class com.hazelcast.config.NearCacheConfig
Checks if local entries are also cached in the Near Cache.
isCheckClassDefErrors() - Method in class com.hazelcast.config.SerializationConfig
Default value is true (enabled).
IScheduledExecutorService - Interface in com.hazelcast.scheduledexecutor
Distributed & durable implementation similar to, but not directly inherited ScheduledExecutorService.
IScheduledFuture<V> - Interface in com.hazelcast.scheduledexecutor
A delayed result-bearing action that can be cancelled.
isClusterSafe() - Method in interface com.hazelcast.partition.PartitionService
Checks whether the cluster is in a safe state.
isCoalesce() - Method in class com.hazelcast.config.QueryCacheConfig
Returns true if coalescing is is enabled, otherwise returns false.
isDefaultsDisabled() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
isDestroyed() - Method in interface com.hazelcast.cache.ICache
Determines whether this Cache instance has been destroyed.
isDisablePerEntryInvalidationEvents() - Method in class com.hazelcast.config.CacheConfig
Returns invalidation events disabled status for per entry.
isDisablePerEntryInvalidationEvents() - Method in class com.hazelcast.config.CacheSimpleConfig
Returns invalidation events disabled status for per entry.
isDiscoveryCompleted() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Returns whether the CP discovery process is completed or not.
isDone() - Method in enum com.hazelcast.hotrestart.BackupTaskState
Returns true if the backup task completed (successfully or with failure)
isEchoFailFastOnStartup() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
ISemaphore - Interface in com.hazelcast.cp
ISemaphore is a fault-tolerant distributed alternative to the Semaphore.
isEmpty() - Method in class com.hazelcast.config.ClassFilter
 
isEmpty() - Method in interface com.hazelcast.map.BaseMap
Returns true if this map contains no entries.
isEmpty() - Method in interface com.hazelcast.map.QueryCache
 
isEmpty() - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of Map.isEmpty().
isEnableCompression() - Method in class com.hazelcast.config.SerializationConfig
Enables compression when default java serialization is used.
isEnabled() - Method in class com.hazelcast.client.config.ClientCloudConfig
 
isEnabled() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
isEnabled() - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
isEnabled() - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
Returns if this configuration is enabled.
isEnabled() - Method in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
Returns if this configuration is enabled.
isEnabled() - Method in class com.hazelcast.config.AdvancedNetworkConfig
 
isEnabled() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
Checks whether the given join mechanism is enabled.
isEnabled() - Method in class com.hazelcast.config.AutoDetectionConfig
Checks whether the auto detection mechanism is enabled.
isEnabled() - Method in class com.hazelcast.config.BaseMetricsConfig
Returns if metrics collection is enabled.
isEnabled() - Method in class com.hazelcast.config.DiscoveryConfig
 
isEnabled() - Method in class com.hazelcast.config.EventJournalConfig
Returns if the event journal is enabled.
isEnabled() - Method in class com.hazelcast.config.HotRestartConfig
Returns whether hot restart enabled on related data structure.
isEnabled() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Returns whether hot restart enabled on this member.
isEnabled() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
isEnabled() - Method in class com.hazelcast.config.InstanceTrackingConfig
Returns true if instance tracking is enabled.
isEnabled() - Method in class com.hazelcast.config.InterfacesConfig
 
isEnabled() - Method in class com.hazelcast.config.MapStoreConfig
Returns if this configuration is enabled
isEnabled() - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
isEnabled() - Method in class com.hazelcast.config.MemcacheProtocolConfig
Returns if MEMCACHE protocol support is enabled.
isEnabled() - Method in class com.hazelcast.config.MerkleTreeConfig
Returns if the merkle tree is enabled.
isEnabled() - Method in class com.hazelcast.config.MetricsJmxConfig
Returns whether metrics will be exposed through JMX MBeans.
isEnabled() - Method in class com.hazelcast.config.MetricsManagementCenterConfig
Returns whether metrics will be exposed to Hazelcast Management Center.
isEnabled() - Method in class com.hazelcast.config.MulticastConfig
Check if the multicast discovery mechanism has been enabled.
isEnabled() - Method in class com.hazelcast.config.NativeMemoryConfig
Returns true if native memory allocation is enabled, false otherwise.
isEnabled() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
isEnabled() - Method in class com.hazelcast.config.PartitionGroupConfig
Checks if this PartitionGroupConfig is enabled.
isEnabled() - Method in class com.hazelcast.config.PersistentMemoryConfig
Returns if the persistent memory is enabled.
isEnabled() - Method in class com.hazelcast.config.QueueStoreConfig
Returns true if the queue store is enabled, false otherwise.
isEnabled() - Method in class com.hazelcast.config.RestApiConfig
Checks if REST API access is enabled.
isEnabled() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
isEnabled() - Method in class com.hazelcast.config.SecurityConfig
 
isEnabled() - Method in class com.hazelcast.config.ServiceConfig
 
isEnabled() - Method in class com.hazelcast.config.SocketInterceptorConfig
Returns if this configuration is enabled.
isEnabled() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
isEnabled() - Method in class com.hazelcast.config.TcpIpConfig
Checks if the Tcp/Ip join mechanism is enabled.
isEnabled() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Returns true if User Code Deployment is enabled
isEnabledAndNotEmpty() - Method in class com.hazelcast.config.RestApiConfig
Return true if the REST API is enabled and at least one REST endpoint group is allowed.
isEnabledAndNotEmpty() - Method in class com.hazelcast.config.RestServerEndpointConfig
Return true if the REST API is enabled and at least one REST endpoint group is allowed.
isEnabledByDefault() - Method in enum com.hazelcast.config.RestEndpointGroup
Returns if this group is enabled by default.
isEnableSharedObject() - Method in class com.hazelcast.config.SerializationConfig
Enables shared object when default java serialization is used.
isEnqueueNewEvents() - Method in enum com.hazelcast.wan.WanPublisherState
Returns true if this state allows enqueueing new events, false otherwise.
isEqual(Object) - Static method in interface com.hazelcast.function.PredicateEx
Serializable variant of
isEqualTo(Version) - Method in class com.hazelcast.version.Version
 
ISet<E> - Interface in com.hazelcast.collection
Concurrent, distributed implementation of Set
isExistingTransaction(Object) - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
 
isExpired(long) - Method in interface com.hazelcast.cp.session.CPSession
Returns true if the session expires before the given timestamp.
isFailFastOnStartup() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
isFailOnIndeterminateOperationState() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the value to determine if CP Subsystem API calls will fail when result of an API call becomes indeterminate.
isFineEnabled() - Method in class com.hazelcast.logging.AbstractLogger
 
isFineEnabled() - Method in interface com.hazelcast.logging.ILogger
Checks if the Level.FINE level is enabled.
isFinestEnabled() - Method in class com.hazelcast.logging.AbstractLogger
 
isFinestEnabled() - Method in interface com.hazelcast.logging.ILogger
Checks if the Level.FINEST level is enabled.
isFsync() - Method in class com.hazelcast.config.HotRestartConfig
Returns whether disk write should be followed by an fsync() system call.
isGlobalOrderingEnabled() - Method in class com.hazelcast.config.TopicConfig
Checks if global ordering is enabled (all nodes listening to the same topic get their messages in the same order), or disabled (nodes get the messages in the order that the messages are published).
isGreaterOrEqual(Version) - Method in class com.hazelcast.version.Version
 
isGreaterThan(Version) - Method in class com.hazelcast.version.Version
 
isGroupEnabled(RestEndpointGroup) - Method in class com.hazelcast.config.RestApiConfig
Checks if given REST endpoint group is enabled.
isGroupEnabled(RestEndpointGroup) - Method in class com.hazelcast.config.RestServerEndpointConfig
Checks if given REST endpoint group is enabled.
isHotBackupEnabled() - Method in interface com.hazelcast.hotrestart.HotRestartService
Returns if hot backup is enabled.
isIdentityConfigured() - Method in class com.hazelcast.config.security.RealmConfig
 
isIncludeValue() - Method in class com.hazelcast.config.EntryListenerConfig
 
isIncludeValue() - Method in class com.hazelcast.config.ItemListenerConfig
 
isIncludeValue() - Method in class com.hazelcast.config.ListenerConfig
 
isIncludeValue() - Method in class com.hazelcast.config.QueryCacheConfig
Returns true if value caching enabled, otherwise returns false.
isIncludeValue() - Method in class com.hazelcast.config.SplitBrainProtectionListenerConfig
 
isInfoEnabled() - Method in class com.hazelcast.logging.AbstractLogger
 
isInfoEnabled() - Method in interface com.hazelcast.logging.ILogger
Checks if the Level.INFO level is enabled.
isInvalidateOnChange() - Method in class com.hazelcast.config.NearCacheConfig
Checks if Near Cache entries are invalidated when the entries in the backing data structure are changed (updated or removed).
isIPv4() - Method in class com.hazelcast.cluster.Address
 
isIPv6() - Method in class com.hazelcast.cluster.Address
 
isJDKCompatible() - Method in class com.hazelcast.config.cp.SemaphoreConfig
Returns true if CP ISemaphore is compatible with its JDK counterpart
isJoinAllowed() - Method in enum com.hazelcast.cluster.ClusterState
Returns true, if joining of a new member is allowed in this state.
isKeepAlive() - Method in class com.hazelcast.client.config.SocketOptions
SO_KEEPALIVE socket option
isLessOrEqual(Version) - Method in class com.hazelcast.version.Version
 
isLessThan(Version) - Method in class com.hazelcast.version.Version
 
isListed(String) - Method in class com.hazelcast.config.ClassFilter
 
isLiteMember() - Method in interface com.hazelcast.cluster.Member
Returns true if this member is a lite member.
isLiteMember() - Method in class com.hazelcast.config.Config
Returns true if this member is a lite member.
isLocal() - Method in class com.hazelcast.config.EntryListenerConfig
 
isLocal() - Method in class com.hazelcast.config.ListenerConfig
 
isLocal() - Method in class com.hazelcast.config.SplitBrainProtectionListenerConfig
 
isLocalMemberSafe() - Method in interface com.hazelcast.partition.PartitionService
Checks whether local member is in safe state.
isLocked() - Method in interface com.hazelcast.cp.lock.FencedLock
Returns whether this lock is locked or not.
isLocked(K) - Method in interface com.hazelcast.map.IMap
Checks the lock for the specified key.
isLocked() - Method in interface com.hazelcast.map.LockAware
 
isLocked(K) - Method in interface com.hazelcast.multimap.MultiMap
Checks the lock for the specified key.
isLockedByCurrentThread() - Method in interface com.hazelcast.cp.lock.FencedLock
Returns whether the lock is held by the current thread or not.
isLoggable(Level) - Method in interface com.hazelcast.logging.ILogger
Checks if a message at the given level is going to be logged by this logger.
isLoggable(Level) - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
 
isLoopbackModeEnabled() - Method in class com.hazelcast.config.MulticastConfig
Check if the loopback mode is enabled in the multicast discovery mechanism.
isLossTolerant() - Method in interface com.hazelcast.topic.ReliableMessageListener
Checks if this ReliableMessageListener is able to deal with message loss.
isMajorityAvailable() - Method in interface com.hazelcast.cp.event.CPGroupAvailabilityEvent
Returns whether this group has the majority of its members available or not.
isManagementEnabled - Variable in class com.hazelcast.config.AbstractCacheConfig
Whether management is enabled
isManagementEnabled() - Method in class com.hazelcast.config.AbstractCacheConfig
 
isManagementEnabled() - Method in class com.hazelcast.config.CacheSimpleConfig
Checks if management is enabled for this ICache.
isMemberSafe(Member) - Method in interface com.hazelcast.partition.PartitionService
Checks whether the given member is in safe state.
isMetadataGroup() - Method in interface com.hazelcast.cp.event.CPGroupAvailabilityEvent
Returns whether this is the METADATA CP group or not.
isMigrationAllowed() - Method in enum com.hazelcast.cluster.ClusterState
Returns true, if migrations and replications are allowed in this state.
isMultiThreadingEnabled() - Method in class com.hazelcast.config.TopicConfig
Checks if multi-threaded processing of incoming messages is enabled or not.
isNearCacheEnabled() - Method in class com.hazelcast.config.MapConfig
Checks if Near Cache is enabled.
isNot(String) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
isNotNull() - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
isNull() - Method in interface com.hazelcast.cp.IAtomicReference
Checks if the stored reference is null.
isNull() - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
isNullAsync() - Method in interface com.hazelcast.cp.IAtomicReference
Checks if the stored reference is null.
isNumaNodeSet() - Method in class com.hazelcast.config.PersistentMemoryDirectoryConfig
Returns if the NUMA node for the given persistent memory directory is set.
isOldValueRequired() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
If old value is required, previously assigned values for the affected keys will be sent to this cache entry listener implementation.
isOverrideJavaSerialization() - Method in class com.hazelcast.config.GlobalSerializerConfig
 
isOverwritable() - Method in interface com.hazelcast.nio.serialization.SerializerHook
Defines if this serializer can be overridden by defining a custom serializer in the configurations (codebase or configuration file)
isParallelMode() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
isParseDn() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
isPartitionPromotionAllowed() - Method in enum com.hazelcast.cluster.ClusterState
Returns true, if partition promotions are allowed in this state.
isPersistenceEnabled() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns whether CP Subsystem Persistence enabled on this member.
isPersistWanReplicatedData() - Method in class com.hazelcast.config.WanConsumerConfig
 
isPopulate() - Method in class com.hazelcast.config.QueryCacheConfig
Returns true if initial population of QueryCache is enabled, otherwise returns false.
isPortAutoIncrement() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
isPortAutoIncrement() - Method in class com.hazelcast.config.NetworkConfig
Checks if a Hazelcast member is allowed find a free port by incrementing the port number when it encounters an occupied port.
isPortAutoIncrement() - Method in class com.hazelcast.config.ServerSocketEndpointConfig
Checks if a Hazelcast member is allowed find a free port by incrementing the port number when it encounters an occupied port.
isPresent() - Method in class com.hazelcast.splitbrainprotection.SplitBrainProtectionEvent
Returns the presence of the split brain protection
isPriorityQueue() - Method in class com.hazelcast.config.QueueConfig
Check if underlying implementation is a PriorityQueue.
isReadBackupData() - Method in class com.hazelcast.config.MapConfig
Checks if read-backup-data (reading local backup entries) is enabled for this map.
isReadThrough - Variable in class com.hazelcast.config.AbstractCacheConfig
A flag indicating if "read-through" mode is required.
isReadThrough() - Method in class com.hazelcast.config.AbstractCacheConfig
 
isReadThrough() - Method in class com.hazelcast.config.CacheSimpleConfig
Checks if this ICache is read-through: a read loads the entry from the data store if it is not already in the cache.
isRealm(String) - Method in class com.hazelcast.config.SecurityConfig
Returns if the given name is a valid realm name.
isRecognized(ConfigStream) - Method in interface com.hazelcast.config.ConfigRecognizer
Recognizes the configuration given in the configStream argument.
isRedoOperation() - Method in class com.hazelcast.client.config.ClientNetworkConfig
isReplicateEnqueuedEvents() - Method in enum com.hazelcast.wan.WanPublisherState
Returns true if this state allows dequeueing and replicating events, false otherwise.
isRepublishingEnabled() - Method in class com.hazelcast.config.WanReplicationRef
Returns true if incoming WAN events to this member should be republished (forwarded) to this WAN replication reference.
isReuseAddress() - Method in class com.hazelcast.client.config.SocketOptions
SO_REUSEADDR socket option.
isReuseAddress() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
isReuseAddress() - Method in class com.hazelcast.config.NetworkConfig
 
isReuseAddress() - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
isRowSet() - Method in interface com.hazelcast.sql.SqlResult
Return whether this result has rows to iterate using the SqlResult.iterator() method.
isRunning() - Method in interface com.hazelcast.core.LifecycleService
Checks whether or not the instance is running.
isScriptingEnabled() - Method in class com.hazelcast.config.ManagementCenterConfig
Returns if scripting is allowed (true) or disallowed (false).
isSerializeKeys() - Method in class com.hazelcast.config.NearCacheConfig
Checks if the Near Cache key is stored in serialized format or by-reference.
isSevereEnabled() - Method in class com.hazelcast.logging.AbstractLogger
 
isSevereEnabled() - Method in interface com.hazelcast.logging.ILogger
Checks if the Level.SEVERE is enabled.
isSmartRouting() - Method in class com.hazelcast.client.config.ClientNetworkConfig
isSnapshotEnabled() - Method in class com.hazelcast.config.WanBatchPublisherConfig
Returns true if key-based coalescing is configured for this WAN publisher.
isSocketBufferDirect() - Method in class com.hazelcast.config.EndpointConfig
 
isSocketKeepAlive() - Method in class com.hazelcast.config.EndpointConfig
 
isSocketTcpNoDelay() - Method in class com.hazelcast.config.EndpointConfig
 
isStatisticsEnabled - Variable in class com.hazelcast.config.AbstractCacheConfig
A flag indicating if statistics gathering is enabled.
isStatisticsEnabled() - Method in class com.hazelcast.config.AbstractCacheConfig
 
isStatisticsEnabled() - Method in class com.hazelcast.config.CacheSimpleConfig
Checks if statistics are enabled for this ICache.
isStatisticsEnabled() - Method in class com.hazelcast.config.CollectionConfig
Checks if collection statistics are enabled.
isStatisticsEnabled() - Method in class com.hazelcast.config.DurableExecutorConfig
 
isStatisticsEnabled() - Method in class com.hazelcast.config.ExecutorConfig
 
isStatisticsEnabled() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
isStatisticsEnabled() - Method in class com.hazelcast.config.MapConfig
Checks if statistics are enabled for this map.
isStatisticsEnabled() - Method in class com.hazelcast.config.MultiMapConfig
Checks to see if statistics are enabled for this MultiMap.
isStatisticsEnabled() - Method in class com.hazelcast.config.PNCounterConfig
Checks if statistics are enabled for this PN counter
isStatisticsEnabled() - Method in class com.hazelcast.config.QueueConfig
Check if statistics are enabled for this queue.
isStatisticsEnabled() - Method in class com.hazelcast.config.ReliableTopicConfig
Checks if statistics are enabled for this reliable topic.
isStatisticsEnabled() - Method in class com.hazelcast.config.ReplicatedMapConfig
Checks if statistics are enabled for this replicated map.
isStatisticsEnabled() - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
isStatisticsEnabled() - Method in class com.hazelcast.config.TopicConfig
Checks if statistics are enabled for this topic.
isStoreByValue - Variable in class com.hazelcast.config.AbstractCacheConfig
A flag indicating if the cache will be store-by-value or store-by-reference.
isStoreByValue() - Method in class com.hazelcast.config.AbstractCacheConfig
 
isSuccess() - Method in interface com.hazelcast.partition.ReplicaMigrationEvent
Returns the result of the migration: completed or failed.
isSupported(OptionalFeature) - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
isSupported(OptionalFeature) - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
 
isSupported(OptionalFeature) - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
 
isSynchronous() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
If true, this cache entry listener implementation will be called in a synchronous manner.
isTcpNoDelay() - Method in class com.hazelcast.client.config.SocketOptions
TCP_NODELAY socket option
isTerminal(Throwable) - Method in interface com.hazelcast.topic.ReliableMessageListener
Checks if the ReliableMessageListener should be terminated based on an exception thrown while calling MessageListener.onMessage(Message).
isUnknown() - Method in class com.hazelcast.version.MemberVersion
 
isUnknown() - Method in class com.hazelcast.version.Version
 
isUnknownOrGreaterOrEqual(Version) - Method in class com.hazelcast.version.Version
 
isUnknownOrGreaterThan(Version) - Method in class com.hazelcast.version.Version
 
isUnknownOrLessOrEqual(Version) - Method in class com.hazelcast.version.Version
 
isUnknownOrLessThan(Version) - Method in class com.hazelcast.version.Version
 
isUseEndpointPrivateAddress() - Method in class com.hazelcast.config.WanBatchPublisherConfig
Returns whether the WAN connection manager should connect to the endpoint on the private address returned by the discovery SPI.
isUseNativeByteOrder() - Method in class com.hazelcast.config.SerializationConfig
 
isUsePublicIp() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
Checks whether the public or private IP should be used to connect to Hazelcast members.
isWarningEnabled() - Method in class com.hazelcast.logging.AbstractLogger
 
isWarningEnabled() - Method in interface com.hazelcast.logging.ILogger
Checks if the Level.WARNING is enabled.
isWriteCoalescing() - Method in class com.hazelcast.config.MapStoreConfig
Returns true if write-coalescing is enabled.
isWriteThrough - Variable in class com.hazelcast.config.AbstractCacheConfig
A flag indicating if "write-through" mode is required.
isWriteThrough() - Method in class com.hazelcast.config.AbstractCacheConfig
 
isWriteThrough() - Method in class com.hazelcast.config.CacheSimpleConfig
Checks if the ICache is write-through: a write to the queue also loads the entry into the data store.
item - Variable in class com.hazelcast.collection.ItemEvent
 
itemAdded(ItemEvent<E>) - Method in interface com.hazelcast.collection.ItemListener
Invoked when an item is added.
itemAdded(ItemEvent) - Method in class com.hazelcast.console.ConsoleApp
 
ItemEvent<E> - Class in com.hazelcast.collection
Event for a collection item.
ItemEvent(String, ItemEventType, E, Member) - Constructor for class com.hazelcast.collection.ItemEvent
 
ItemEventType - Enum in com.hazelcast.core
Type of item events.
ItemListener<E> - Interface in com.hazelcast.collection
Item listener for IQueue, ISet and IList
ItemListenerConfig - Class in com.hazelcast.config
Contains the configuration for an Item Listener.
ItemListenerConfig() - Constructor for class com.hazelcast.config.ItemListenerConfig
 
ItemListenerConfig(String, boolean) - Constructor for class com.hazelcast.config.ItemListenerConfig
 
ItemListenerConfig(ItemListener, boolean) - Constructor for class com.hazelcast.config.ItemListenerConfig
 
ItemListenerConfig(ItemListenerConfig) - Constructor for class com.hazelcast.config.ItemListenerConfig
 
itemRemoved(ItemEvent<E>) - Method in interface com.hazelcast.collection.ItemListener
Invoked when an item is removed.
itemRemoved(ItemEvent) - Method in class com.hazelcast.console.ConsoleApp
 
iterator(int) - Method in interface com.hazelcast.cache.ICache
Creates and returns a cluster wide iterator to iterate on all entries owned by this cache.
iterator() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Returns a read-only iterator.
iterator() - Method in interface com.hazelcast.spi.partitiongroup.MemberGroup
 
iterator() - Method in interface com.hazelcast.sql.SqlResult
Returns the iterator over the result rows.
ITopic<E> - Interface in com.hazelcast.topic
Hazelcast provides distribution mechanism for publishing messages that are delivered to multiple subscribers, which is also known as a publish/subscribe (pub/sub) messaging model.

J

JaasAuthenticationConfig - Class in com.hazelcast.config.security
This AuthenticationConfig implementation is a imple holder for login module configurations.
JaasAuthenticationConfig() - Constructor for class com.hazelcast.config.security.JaasAuthenticationConfig
 
JavaKeyStoreSecureStoreConfig - Class in com.hazelcast.config
Java KeyStore Secure Store configuration.
JavaKeyStoreSecureStoreConfig(File) - Constructor for class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
Creates a new Java KeyStore Secure Store configuration.
JavaSerializationFilterConfig - Class in com.hazelcast.config
Configuration for Serialization Filter.
JavaSerializationFilterConfig() - Constructor for class com.hazelcast.config.JavaSerializationFilterConfig
 
JavaSerializationFilterConfig(JavaSerializationFilterConfig) - Constructor for class com.hazelcast.config.JavaSerializationFilterConfig
 
JCACHE_PROVIDER_TYPE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Forces the JCache provider, which can have values client or server, to force the provider type.
JMX_UPDATE_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Some JMX MBeans are cached (e.g.
jmxConfig - Variable in class com.hazelcast.config.BaseMetricsConfig
 
JoinConfig - Class in com.hazelcast.config
Contains the multiple different join configuration.
JoinConfig() - Constructor for class com.hazelcast.config.JoinConfig
 

K

KerberosAuthenticationConfig - Class in com.hazelcast.config.security
 
KerberosAuthenticationConfig() - Constructor for class com.hazelcast.config.security.KerberosAuthenticationConfig
 
KerberosIdentityConfig - Class in com.hazelcast.config.security
 
KerberosIdentityConfig() - Constructor for class com.hazelcast.config.security.KerberosIdentityConfig
 
key() - Method in interface com.hazelcast.config.properties.PropertyDefinition
Returns the key (the name) of this property inside the configuration.
key() - Method in class com.hazelcast.config.properties.SimplePropertyDefinition
 
key - Variable in class com.hazelcast.core.EntryEvent
 
key() - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
keySet() - Method in interface com.hazelcast.map.BaseMap
Returns a set clone of the keys contained in this map.
keySet(Predicate<K, V>) - Method in interface com.hazelcast.map.BaseMap
Queries the map based on the specified predicate and returns the keys of matching entries.
keySet() - Method in interface com.hazelcast.map.IMap
Returns an immutable set clone of the keys contained in this map.
keySet(Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
Queries the map based on the specified predicate and returns an immutable Set clone of the keys of matching entries.
keySet() - Method in interface com.hazelcast.map.QueryCache
 
keySet(Predicate<K, V>) - Method in interface com.hazelcast.map.QueryCache
 
keySet() - Method in interface com.hazelcast.multimap.MultiMap
Returns the set of keys in the multimap.
keySet() - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Returns a lazy Set view of the key contained in this map.
A LazySet is optimized for querying speed (preventing eager deserialization and hashing on HashSet insertion) and does NOT provide all operations.
keySet() - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns an immutable set of all keys in this HazelcastProperties.
keySet() - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.keySet().
keySet(Predicate<K, V>) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.keySet(com.hazelcast.query.Predicate).
keyValueTypesEqual(AbstractCacheConfig) - Method in class com.hazelcast.config.AbstractCacheConfig
 
KILO_BYTE - Static variable in class com.hazelcast.client.config.SocketOptions
constant for kilobyte
kiloBytes() - Method in class com.hazelcast.memory.MemorySize
Returns value of memory size in kilo-bytes.
KubernetesConfig - Class in com.hazelcast.config
Configuration for the Kubernetes Discovery Strategy.
KubernetesConfig() - Constructor for class com.hazelcast.config.KubernetesConfig
 
KubernetesConfig(KubernetesConfig) - Constructor for class com.hazelcast.config.KubernetesConfig
 

L

LatestAccessMergePolicy<V,T extends MergingValue<V> & MergingLastAccessTime> - Class in com.hazelcast.spi.merge
Merges data structure entries from source to destination data structure if the source entry has been accessed more recently than the destination entry.
LatestAccessMergePolicy() - Constructor for class com.hazelcast.spi.merge.LatestAccessMergePolicy
 
LatestUpdateMergePolicy<V,T extends MergingValue<V> & MergingLastUpdateTime> - Class in com.hazelcast.spi.merge
Merges data structure entries from source to destination data structure if the source entry was updated more frequently than the destination entry.
LatestUpdateMergePolicy() - Constructor for class com.hazelcast.spi.merge.LatestUpdateMergePolicy
 
LdapAuthenticationConfig - Class in com.hazelcast.config.security
Typed authentication configuration for BasicLdapLoginModule and LdapLoginModule.
LdapAuthenticationConfig() - Constructor for class com.hazelcast.config.security.LdapAuthenticationConfig
 
LdapRoleMappingMode - Enum in com.hazelcast.config.security
Enum for LDAP role mapping modes.
LdapSearchScope - Enum in com.hazelcast.config.security
Search scope types for LDAP queries.
LeaderDemotedException - Exception in com.hazelcast.cp.exception
A CPSubsystemException which is thrown when an appended but not-committed entry is truncated by the new leader.
LeaderDemotedException(RaftEndpoint, RaftEndpoint) - Constructor for exception com.hazelcast.cp.exception.LeaderDemotedException
 
length() - Method in interface com.hazelcast.security.Parameters
 
lessEqual(Comparable) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
lessEqual(String, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates a less than or equal to predicate that will pass items if the value stored under the given item attribute is less than or equal to the given value.
lessThan(Comparable) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
lessThan(String, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates a less than predicate that will pass items if the value stored under the given item attribute is less than the given value.
level() - Method in interface com.hazelcast.auditlog.AuditableEvent
 
level(Level) - Method in interface com.hazelcast.auditlog.EventBuilder
Sets the event Level.
Level - Enum in com.hazelcast.auditlog
Event importance levels.
LifecycleEvent - Class in com.hazelcast.core
Lifecycle events are fired when the HazelcastInstance state changes.
LifecycleEvent(LifecycleEvent.LifecycleState) - Constructor for class com.hazelcast.core.LifecycleEvent
 
LifecycleEvent.LifecycleState - Enum in com.hazelcast.core
Lifecycle states
LifecycleListener - Interface in com.hazelcast.core
Listener object for listening to lifecycle events of the Hazelcast instance
LifecycleService - Interface in com.hazelcast.core
LifecycleService allows you to shutdown, terminate, and listen to LifecycleEvents on HazelcastInstance.
like(String, String) - Static method in class com.hazelcast.query.Predicates
Creates a like predicate that will pass items if the given pattern matches the value stored under the given item attribute.
LineReader - Interface in com.hazelcast.console
Reads a line of input.
ListConfig - Class in com.hazelcast.config
Contains the configuration for an IList.
ListConfig() - Constructor for class com.hazelcast.config.ListConfig
 
ListConfig(String) - Constructor for class com.hazelcast.config.ListConfig
 
ListConfig(ListConfig) - Constructor for class com.hazelcast.config.ListConfig
 
LISTENER_INSTANCE - Static variable in class com.hazelcast.security.permission.ActionConstants
 
LISTENER_MEMBER - Static variable in class com.hazelcast.security.permission.ActionConstants
 
LISTENER_MIGRATION - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ListenerConfig - Class in com.hazelcast.config
Contains the configuration for an EventListener.
ListenerConfig() - Constructor for class com.hazelcast.config.ListenerConfig
Creates a ListenerConfig without className/implementation.
ListenerConfig(String) - Constructor for class com.hazelcast.config.ListenerConfig
Creates a ListenerConfig with the given className.
ListenerConfig(EventListener) - Constructor for class com.hazelcast.config.ListenerConfig
Creates a ListenerConfig with the given implementation.
ListenerConfig(ListenerConfig) - Constructor for class com.hazelcast.config.ListenerConfig
 
listenerConfigurations - Variable in class com.hazelcast.config.AbstractCacheConfig
The CacheEntryListenerConfigurations for the Configuration.
ListPermission - Class in com.hazelcast.security.permission
 
ListPermission(String, String...) - Constructor for class com.hazelcast.security.permission.ListPermission
 
LITE_MEMBER_SELECTOR - Static variable in class com.hazelcast.cluster.memberselector.MemberSelectors
A MemberSelector instance that selects only lite members that own no partition
load() - Static method in class com.hazelcast.client.config.ClientConfig
Populates Hazelcast ClientConfig object from an external configuration file.
load() - Static method in class com.hazelcast.client.config.ClientFailoverConfig
Populates Hazelcast ClientFailoverConfig object from an external configuration file.
load(Long) - Method in interface com.hazelcast.collection.QueueStore
Loads the value of a given key.
load() - Static method in class com.hazelcast.config.Config
Populates Hazelcast Config object from an external configuration file.
load(K) - Method in interface com.hazelcast.map.MapLoader
Loads the value of a given key.
load(K) - Method in class com.hazelcast.map.MapStoreAdapter
Loads the value of a given key.
load(long) - Method in interface com.hazelcast.ringbuffer.RingbufferStore
Loads the value of a given sequence.
load(Map<K, V>) - Method in interface com.hazelcast.scheduledexecutor.StatefulTask
Task callback to initialize its inner state, after a replica promotion, from the given map.
loadAll(Collection<Long>) - Method in interface com.hazelcast.collection.QueueStore
Loads the given keys.
loadAll(boolean) - Method in interface com.hazelcast.map.IMap
Loads all keys into the store.
loadAll(Set<K>, boolean) - Method in interface com.hazelcast.map.IMap
Loads the given keys.
loadAll(Collection<K>) - Method in interface com.hazelcast.map.MapLoader
Loads given keys.
loadAll(Collection<K>) - Method in class com.hazelcast.map.MapStoreAdapter
Loads given keys.
loadAllKeys() - Method in interface com.hazelcast.collection.QueueStore
Loads all of the keys from the store.
loadAllKeys() - Method in interface com.hazelcast.map.MapLoader
Loads all of the keys from the store.
loadAllKeys() - Method in class com.hazelcast.map.MapStoreAdapter
Loads all of the keys from the store.
LoadBalancer - Interface in com.hazelcast.client
LoadBalancer allows you to send operations to one of a number of endpoints(Members).
loadSchemaFile(String) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
LOCAL_MEMBER_SELECTOR - Static variable in class com.hazelcast.cluster.memberselector.MemberSelectors
A MemberSelector instance that selects only local members
LocalCollectionStats - Interface in com.hazelcast.collection
Local collections statistics to be used by MemberState implementations.
LocalExecutorStats - Interface in com.hazelcast.executor
Local executor service statistics.
LocalIndexStats - Interface in com.hazelcast.query
Provides local statistics for an index to be used by MemberState implementations.
localKeySet() - Method in interface com.hazelcast.map.IMap
Returns the locally owned immutable set of keys.
localKeySet(Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
Returns an immutable set of the keys of matching locally owned entries.
localKeySet() - Method in interface com.hazelcast.multimap.MultiMap
Returns the locally owned set of keys.
LocalListStats - Interface in com.hazelcast.collection
Local List statistics to be used by MemberState implementations.
LocalMapStats - Interface in com.hazelcast.map
Local map statistics to be used by MemberState implementations.
localMember() - Method in interface com.hazelcast.cluster.Member
Returns true if this member is the local member.
LocalMemberResetException - Exception in com.hazelcast.core
An exception provided to MemberLeftException as a cause when the local member is resetting itself
LocalMemberResetException(String) - Constructor for exception com.hazelcast.core.LocalMemberResetException
 
LocalMultiMapStats - Interface in com.hazelcast.multimap
Local multi map statistics to be used by MemberState implementations.
LocalQueueStats - Interface in com.hazelcast.collection
Local queue statistics to be used by MemberState implementations.
LocalReplicatedMapStats - Interface in com.hazelcast.replicatedmap
Local replicated map statistics to be used by MemberState implementations.
LocalSetStats - Interface in com.hazelcast.collection
Local Set statistics to be used by MemberState implementations.
LocalTopicStats - Interface in com.hazelcast.topic
Local topic statistics to be used by MemberState implementations.
lock() - Method in interface com.hazelcast.cp.lock.FencedLock
Acquires the lock.
lock(K) - Method in interface com.hazelcast.map.IMap
Acquires the lock for the specified key.
lock(K, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Acquires the lock for the specified key for the specified lease time.
lock(K) - Method in interface com.hazelcast.multimap.MultiMap
Acquires a lock for the specified key.
lock(K, long, TimeUnit) - Method in interface com.hazelcast.multimap.MultiMap
Acquires the lock for the specified key for the specified lease time.
LOCK_MAX_LEASE_TIME_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
All locks which are acquired without an explicit lease time use this value (in seconds) as the lease time.
LockAcquireLimitReachedException - Exception in com.hazelcast.cp.lock.exception
Thrown when the current lock holder could not acquired the lock reentrantly because the configured lock acquire limit is reached.
LockAcquireLimitReachedException() - Constructor for exception com.hazelcast.cp.lock.exception.LockAcquireLimitReachedException
 
LockAcquireLimitReachedException(String) - Constructor for exception com.hazelcast.cp.lock.exception.LockAcquireLimitReachedException
 
lockAndGetFence() - Method in interface com.hazelcast.cp.lock.FencedLock
Acquires the lock and returns the fencing token assigned to the current thread for this lock acquire.
LockAware - Interface in com.hazelcast.map
Determines if the object implementing this interface is locked or not.
lockInterruptibly() - Method in interface com.hazelcast.cp.lock.FencedLock
Acquires the lock unless the current thread is interrupted.
LockOwnershipLostException - Exception in com.hazelcast.cp.lock.exception
Thrown when an endpoint (either a Hazelcast server or a client) interacts with a FencedLock instance after its CP session is closed in the underlying CP group and its lock ownership is cancelled.
LockOwnershipLostException() - Constructor for exception com.hazelcast.cp.lock.exception.LockOwnershipLostException
 
LockOwnershipLostException(String) - Constructor for exception com.hazelcast.cp.lock.exception.LockOwnershipLostException
 
LockPermission - Class in com.hazelcast.security.permission
 
LockPermission(String, String...) - Constructor for class com.hazelcast.security.permission.LockPermission
 
log(AuditableEvent) - Method in interface com.hazelcast.auditlog.AuditlogService
Logs given event.
log(String, Level, String) - Method in interface com.hazelcast.auditlog.AuditlogService
Creates and logs a simple parameterless message at the given level.
log(String, Level, String, Throwable) - Method in interface com.hazelcast.auditlog.AuditlogService
Creates and logs a simple parameterless message with an associated throwable at the given level.
log() - Method in interface com.hazelcast.auditlog.EventBuilder
Builds the event and logs it to the service which provided this builder (if any).
log(Level, String) - Method in interface com.hazelcast.logging.ILogger
Logs a message at the given level.
log(Level, String, Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a message with an associated throwable at the given level.
log(LogEvent) - Method in interface com.hazelcast.logging.ILogger
Logs a LogEvent.
log(LogEvent) - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
 
log(Level, String) - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
 
log(Level, String, Throwable) - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
 
log(LogEvent) - Method in interface com.hazelcast.logging.LogListener
 
Log4j2Factory - Class in com.hazelcast.logging
Logging to Log4j 2.x.
Log4j2Factory() - Constructor for class com.hazelcast.logging.Log4j2Factory
 
Log4j2Factory.Log4j2Logger - Class in com.hazelcast.logging
 
Log4j2Logger(ExtendedLogger) - Constructor for class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
 
Log4jFactory - Class in com.hazelcast.logging
 
Log4jFactory() - Constructor for class com.hazelcast.logging.Log4jFactory
 
LogEvent - Class in com.hazelcast.logging
 
LogEvent(LogRecord, Member) - Constructor for class com.hazelcast.logging.LogEvent
 
Logger - Class in com.hazelcast.logging
Provides static utilities to access the global shared logging machinery.
LoggerFactory - Interface in com.hazelcast.logging
 
LoggerFactorySupport - Class in com.hazelcast.logging
 
LoggerFactorySupport() - Constructor for class com.hazelcast.logging.LoggerFactorySupport
 
LOGGING_ENABLE_DETAILS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Controls whether cluster name, ip and version should be included in all log messages.
LOGGING_TYPE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Name of logging framework type to send logging events.
LoggingService - Interface in com.hazelcast.logging
 
LoggingServiceCallback - Class in com.hazelcast.security
This JAAS Callback is used to retrieve a LoggingService from the current member.
LoggingServiceCallback() - Constructor for class com.hazelcast.security.LoggingServiceCallback
 
LoginModuleConfig - Class in com.hazelcast.config
Configuration for Login Module
LoginModuleConfig() - Constructor for class com.hazelcast.config.LoginModuleConfig
 
LoginModuleConfig(String, LoginModuleConfig.LoginModuleUsage) - Constructor for class com.hazelcast.config.LoginModuleConfig
 
LoginModuleConfig.LoginModuleUsage - Enum in com.hazelcast.config
Usage of Login Module
LogListener - Interface in com.hazelcast.logging
 
longAvg() - Static method in class com.hazelcast.aggregation.Aggregators
 
longAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
longMax() - Static method in class com.hazelcast.aggregation.Aggregators
 
longMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
longMin() - Static method in class com.hazelcast.aggregation.Aggregators
 
longMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
longSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
longSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 

M

main(String...) - Static method in class com.hazelcast.config.replacer.EncryptionReplacer
 
main(String[]) - Static method in class com.hazelcast.console.ConsoleApp
Starts the test application.
MAJOR_MINOR_VERSION_COMPARATOR - Static variable in class com.hazelcast.version.MemberVersion
Version comparator that takes into account only major & minor version, disregarding patch version number.
majorityLost(CPGroupAvailabilityEvent) - Method in interface com.hazelcast.cp.event.CPGroupAvailabilityListener
Called when a CP group has lost its majority.
ManagedContext - Interface in com.hazelcast.core
Container managed context, such as Spring, Guice and etc.
ManagedTransactionalTaskContext - Class in com.hazelcast.spring.transaction
TransactionalTaskContext proxying implementation to make the one created by HazelcastTransactionManager available to actual business logic.
ManagedTransactionalTaskContext(HazelcastTransactionManager) - Constructor for class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
 
ManagementCenterConfig - Class in com.hazelcast.config
Contains the configuration for Hazelcast Management Center.
ManagementCenterConfig() - Constructor for class com.hazelcast.config.ManagementCenterConfig
 
MAP_EVICTION_BATCH_SIZE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Maximum number of IMap entries Hazelcast will evict during a single eviction cycle.
MAP_EXPIRY_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
You can use MAP_EXPIRY_DELAY_SECONDS to deal with some possible edge cases, such as using EntryProcessor.
MAP_INVALIDATION_MESSAGE_BATCH_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Defines Near Cache invalidation event batch sending is enabled or not.
MAP_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Defines the Near Cache invalidation event batch sending frequency in seconds.
MAP_INVALIDATION_MESSAGE_BATCH_SIZE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Defines the maximum number of Near Cache invalidation events to be drained and sent to the event Near Cache in a batch.
MAP_LOAD_CHUNK_SIZE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
The maximum size of the key batch sent to the partition owners for value loading and the maximum size of a key batch for which values are loaded in a single partition.
MAP_REPLICA_SCHEDULED_TASK_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Scheduler delay for map tasks those are executed on backup members.
MAP_WRITE_BEHIND_QUEUE_CAPACITY - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Setting this capacity is valid if you set writeCoalescing to false (see MapStoreConfig.setWriteCoalescing(boolean)).
mapCleared(MapEvent) - Method in class com.hazelcast.console.ConsoleApp
 
mapCleared(MapEvent) - Method in class com.hazelcast.core.EntryAdapter
 
mapCleared(MapEvent) - Method in interface com.hazelcast.map.listener.MapClearedListener
Invoked when all entries are removed by IMap.clear().
MapClearedListener - Interface in com.hazelcast.map.listener
Invoked after all entries are removed by IMap.clear().
MapConfig - Class in com.hazelcast.config
Contains the configuration for an IMap.
MapConfig() - Constructor for class com.hazelcast.config.MapConfig
 
MapConfig(String) - Constructor for class com.hazelcast.config.MapConfig
 
MapConfig(MapConfig) - Constructor for class com.hazelcast.config.MapConfig
 
MapEvent - Class in com.hazelcast.map
Used for map-wide events like EntryEventType.EVICT_ALL and EntryEventType.CLEAR_ALL.
MapEvent(Object, Member, int, int) - Constructor for class com.hazelcast.map.MapEvent
 
mapEvicted(MapEvent) - Method in class com.hazelcast.console.ConsoleApp
 
mapEvicted(MapEvent) - Method in class com.hazelcast.core.EntryAdapter
 
mapEvicted(MapEvent) - Method in interface com.hazelcast.map.listener.MapEvictedListener
Invoked when all entries are evicted by IMap.evictAll().
MapEvictedListener - Interface in com.hazelcast.map.listener
Invoked after all entries are evicted by IMap.evictAll().
MapEvictionPolicyComparator<K,V> - Interface in com.hazelcast.map
IMap specific EvictionPolicyComparator for comparing EntryViews to be evicted.
MapInterceptor - Interface in com.hazelcast.map
MapInterceptor is used to intercept changes to the map, allowing access to the values before and after adding them to the map.
MapListener - Interface in com.hazelcast.map.listener
A marker interface which is used to get notified upon a map or an entry event.
MapLoader<K,V> - Interface in com.hazelcast.map
Hazelcast distributed map implementation is an in-memory data store but it can be backed by any type of data store such as RDBMS, OODBMS, or simply a file based data store.
MapLoaderLifecycleSupport - Interface in com.hazelcast.map
Provides Lifecycle support for the implementing MapLoader class.
MapPartitionLostEvent - Class in com.hazelcast.map
Used for providing information about the lost partition for a map
MapPartitionLostEvent(Object, Member, int, int) - Constructor for class com.hazelcast.map.MapPartitionLostEvent
 
MapPartitionLostListener - Interface in com.hazelcast.map.listener
Invoked when owner and all backups of a partition is lost for a specific map.
MapPartitionLostListenerConfig - Class in com.hazelcast.config
Configuration for MapPartitionLostListener
MapPartitionLostListenerConfig() - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfig
 
MapPartitionLostListenerConfig(String) - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfig
 
MapPartitionLostListenerConfig(MapPartitionLostListener) - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfig
 
MapPartitionLostListenerConfig(MapPartitionLostListenerConfig) - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfig
 
MapPermission - Class in com.hazelcast.security.permission
 
MapPermission(String, String...) - Constructor for class com.hazelcast.security.permission.MapPermission
 
MapStore<K,V> - Interface in com.hazelcast.map
Hazelcast distributed map implementation is an in-memory data store, but it can be backed by any type of data store such as RDBMS, OODBMS, NOSQL, or simply a file-based data store.
MapStoreAdapter<K,V> - Class in com.hazelcast.map
Adapter for MapStore.
MapStoreAdapter() - Constructor for class com.hazelcast.map.MapStoreAdapter
 
MapStoreConfig - Class in com.hazelcast.config
Contains the configuration for a Map Store.
MapStoreConfig() - Constructor for class com.hazelcast.config.MapStoreConfig
 
MapStoreConfig(MapStoreConfig) - Constructor for class com.hazelcast.config.MapStoreConfig
 
MapStoreConfig.InitialLoadMode - Enum in com.hazelcast.config
Initial load module
MapStoreFactory<K,V> - Interface in com.hazelcast.map
Factory for MapLoader or MapStore instances, specifiable in MapStoreConfig.
mark(int) - Method in class com.hazelcast.config.ConfigStream
 
markSupported() - Method in class com.hazelcast.config.ConfigStream
 
mask - Variable in class com.hazelcast.security.permission.InstancePermission
 
MASK_FOR_SENSITIVE_DATA - Static variable in class com.hazelcast.config.ConfigXmlGenerator
 
MASTERSHIP_CLAIM_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
The timeout which defines when master candidate gives up waiting for response to its mastership claim.
matches(Iterable<String>, String) - Method in interface com.hazelcast.config.ConfigPatternMatcher
Returns the best match for an item name out of a list of configuration patterns.
matches(Iterable<String>, String) - Method in class com.hazelcast.config.matcher.MatchingPointConfigPatternMatcher
 
matches(Iterable<String>, String) - Method in class com.hazelcast.config.matcher.RegexConfigPatternMatcher
 
matches(Iterable<String>, String) - Method in class com.hazelcast.config.matcher.WildcardConfigPatternMatcher
 
matches(String, String) - Method in class com.hazelcast.config.matcher.WildcardConfigPatternMatcher
This method is public to be accessible by InstancePermission.
MatchingPointConfigPatternMatcher - Class in com.hazelcast.config.matcher
This ConfigPatternMatcher supports a simplified wildcard matching.
MatchingPointConfigPatternMatcher() - Constructor for class com.hazelcast.config.matcher.MatchingPointConfigPatternMatcher
 
MAX_BACKUP_COUNT - Static variable in class com.hazelcast.config.CacheSimpleConfig
The maximum number of backups.
MAX_BACKUP_COUNT - Static variable in class com.hazelcast.config.MapConfig
The maximum number of backups
MAX_CONCURRENT_INVOCATIONS - Static variable in class com.hazelcast.client.properties.ClientProperty
The maximum number of concurrent invocations allowed.
MAX_GROUP_SIZE - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
The maximum number of CP members that can form a CP group.
MAX_JOIN_MERGE_TARGET_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Split-brain merge timeout for a specific target.
MAX_JOIN_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Join timeout, maximum time to try to join before giving up.
MAX_NO_HEARTBEAT_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
The timeout which defines when a cluster member is removed because it has not sent any heartbeats.
MAX_WAIT_SECONDS_BEFORE_JOIN - Static variable in class com.hazelcast.spi.properties.ClusterProperty
The maximum time that a newly-appointed master node waits before forming a cluster.
maxBy(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
maxBy(Comparator<? super T>) - Static method in interface com.hazelcast.function.BinaryOperatorEx
MAXIMUM_PREFETCH_COUNT - Static variable in class com.hazelcast.config.FlakeIdGeneratorConfig
Maximum value for prefetch count.
maxSizePolicy - Variable in class com.hazelcast.config.EvictionConfig
 
MaxSizePolicy - Enum in com.hazelcast.config
Maximum Size Policy
MC_EXECUTOR_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
The number of threads that the Management Center service has available for processing operations sent from connected Management Center instance.
MC_MAX_VISIBLE_SLOW_OPERATION_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Management Center maximum visible slow operations count.
megaBytes() - Method in class com.hazelcast.memory.MemorySize
Returns value of memory size in mega-bytes.
Member - Interface in com.hazelcast.cluster
Cluster member interface.
member - Variable in class com.hazelcast.cluster.MembershipEvent
 
MEMBER_ADDED - Static variable in class com.hazelcast.cluster.MembershipEvent
This event type is fired when a new member joins the cluster.
MEMBER_ADDED - Static variable in interface com.hazelcast.cp.event.CPMembershipEvent
Member ADDED event ID.
MEMBER_CACHING_PROVIDER - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
Class name of the member-side Caching Provider
MEMBER_LIST_PUBLISH_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
The interval at which the master sends the member lists are sent to other non-master members.
MEMBER_REMOVED - Static variable in class com.hazelcast.cluster.MembershipEvent
This event type is fired if a member left the cluster or was decided to be unresponsive by other members for a extended time.
MEMBER_REMOVED - Static variable in interface com.hazelcast.cp.event.CPMembershipEvent
Member REMOVED event ID.
memberAdded(MembershipEvent) - Method in class com.hazelcast.cluster.MembershipAdapter
 
memberAdded(MembershipEvent) - Method in interface com.hazelcast.cluster.MembershipListener
Invoked when a new member is added to the cluster.
memberAdded(CPMembershipEvent) - Method in interface com.hazelcast.cp.event.CPMembershipListener
Called when a new CP member is added to the CP Subsystem.
MemberAddressProvider - Interface in com.hazelcast.spi
IMPORTANT This interface is not intended to provide addresses of other cluster members with which the hazelcast instance will form a cluster.
MemberAddressProviderConfig - Class in com.hazelcast.config
Configuration for a custom MemberAddressProvider strategy.
MemberAddressProviderConfig() - Constructor for class com.hazelcast.config.MemberAddressProviderConfig
 
MemberAttributeConfig - Class in com.hazelcast.config
Contains configuration for attribute of member.
MemberAttributeConfig() - Constructor for class com.hazelcast.config.MemberAttributeConfig
 
MemberAttributeConfig(MemberAttributeConfig) - Constructor for class com.hazelcast.config.MemberAttributeConfig
 
MemberConfigRecognizer - Class in com.hazelcast.config
ConfigRecognizer implementation that recognizes Hazelcast member declarative configurations based on an extensible set of built-in ConfigRecognizer implementations.
MemberConfigRecognizer() - Constructor for class com.hazelcast.config.MemberConfigRecognizer
Constructs an instance with the built-in set of ConfigRecognizer implementations only.
MemberConfigRecognizer(ConfigRecognizer...) - Constructor for class com.hazelcast.config.MemberConfigRecognizer
Constructs an instance with the built-in set of ConfigRecognizer implementations extended with ones provided in customRecognizers.
MemberGroup - Interface in com.hazelcast.spi.partitiongroup
A collection of members to which a single partition replica can be assigned.
MemberGroupConfig - Class in com.hazelcast.config
Contains the configuration for a single member group.
MemberGroupConfig() - Constructor for class com.hazelcast.config.MemberGroupConfig
 
MemberLeftException - Exception in com.hazelcast.core
A ExecutionException thrown when a member left during an invocation or execution.
MemberLeftException() - Constructor for exception com.hazelcast.core.MemberLeftException
 
MemberLeftException(String) - Constructor for exception com.hazelcast.core.MemberLeftException
 
MemberLeftException(Member) - Constructor for exception com.hazelcast.core.MemberLeftException
 
MemberLeftException(Throwable) - Constructor for exception com.hazelcast.core.MemberLeftException
 
memberRemoved(MembershipEvent) - Method in class com.hazelcast.cluster.MembershipAdapter
 
memberRemoved(MembershipEvent) - Method in interface com.hazelcast.cluster.MembershipListener
Invoked when an existing member leaves the cluster.
memberRemoved(CPMembershipEvent) - Method in interface com.hazelcast.cp.event.CPMembershipListener
Called when a CP member is removed from the CP Subsystem.
members - Variable in class com.hazelcast.cluster.MembershipEvent
 
members() - Method in interface com.hazelcast.cp.CPGroup
Returns current members of the CP group
MemberSelector - Interface in com.hazelcast.cluster
Implementations of this interface select members that are capable of executing a special kind of task.
The MemberSelector.select(Member) method is called for every available member in the cluster and it is up to the implementation to decide if the member is going to be used or not.
MemberSelectors - Class in com.hazelcast.cluster.memberselector
A utility class to get MemberSelector instances.
MembershipAdapter - Class in com.hazelcast.cluster
Adapter for MembershipListener.
MembershipAdapter() - Constructor for class com.hazelcast.cluster.MembershipAdapter
 
MembershipEvent - Class in com.hazelcast.cluster
Membership event fired when a new member is added to the cluster and/or when a member leaves the cluster and similar methods.
MembershipEvent(Cluster, Member, int, Set<Member>) - Constructor for class com.hazelcast.cluster.MembershipEvent
 
MembershipListener - Interface in com.hazelcast.cluster
Cluster membership listener.
MemberSocketInterceptor - Interface in com.hazelcast.nio
Member Socket Interceptor can be registered via see SocketInterceptorConfig Warning: a MemberSocketInterceptor provides access to the socket and will bypass any TLS encryption.
MemberVersion - Class in com.hazelcast.version
Determines the Hazelcast codebase version in terms of major.minor.patch version.
MemberVersion() - Constructor for class com.hazelcast.version.MemberVersion
 
MemberVersion(int, int, int) - Constructor for class com.hazelcast.version.MemberVersion
 
MemberVersion(String) - Constructor for class com.hazelcast.version.MemberVersion
 
MemcacheProtocolConfig - Class in com.hazelcast.config
This class allows to enable MEMCACHE text protocol support in Hazelcast.
MemcacheProtocolConfig() - Constructor for class com.hazelcast.config.MemcacheProtocolConfig
 
MemorySize - Class in com.hazelcast.memory
MemorySize represents a memory size with given value and MemoryUnit.
MemorySize(long) - Constructor for class com.hazelcast.memory.MemorySize
 
MemorySize(long, MemoryUnit) - Constructor for class com.hazelcast.memory.MemorySize
 
MemoryUnit - Enum in com.hazelcast.memory
MemoryUnit represents memory size at a given unit of granularity and provides utility methods to convert across units.
merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in interface com.hazelcast.map.IMap
merge(T, T) - Method in class com.hazelcast.spi.merge.DiscardMergePolicy
 
merge(T, T) - Method in class com.hazelcast.spi.merge.ExpirationTimeMergePolicy
 
merge(T, T) - Method in class com.hazelcast.spi.merge.HigherHitsMergePolicy
 
merge(SplitBrainMergeTypes.CardinalityEstimatorMergeTypes, SplitBrainMergeTypes.CardinalityEstimatorMergeTypes) - Method in class com.hazelcast.spi.merge.HyperLogLogMergePolicy
 
merge(T, T) - Method in class com.hazelcast.spi.merge.LatestAccessMergePolicy
 
merge(T, T) - Method in class com.hazelcast.spi.merge.LatestUpdateMergePolicy
 
merge(T, T) - Method in class com.hazelcast.spi.merge.PassThroughMergePolicy
 
merge(T, T) - Method in class com.hazelcast.spi.merge.PutIfAbsentMergePolicy
 
merge(T, T) - Method in interface com.hazelcast.spi.merge.SplitBrainMergePolicy
Selects the value of either the merging or the existing MergingValue which should be merged.
MERGE_FIRST_RUN_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
The delay until the first run of the split-brain handler.
MERGE_NEXT_RUN_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
The interval between invocations of the split-brain handler.
MergePolicyConfig - Class in com.hazelcast.config
Configuration for SplitBrainMergePolicy.
MergePolicyConfig() - Constructor for class com.hazelcast.config.MergePolicyConfig
 
MergePolicyConfig(String, int) - Constructor for class com.hazelcast.config.MergePolicyConfig
 
MergePolicyConfig(MergePolicyConfig) - Constructor for class com.hazelcast.config.MergePolicyConfig
 
MergingCosts - Interface in com.hazelcast.spi.merge
Represents a read-only view of memory costs for the merging process after a split-brain.
MergingCreationTime - Interface in com.hazelcast.spi.merge
Represents a read-only view a creation time for the merging process after a split-brain.
MergingEntry<K,V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a data structure key/value-pair for the merging process after a split-brain.
MergingExpirationTime - Interface in com.hazelcast.spi.merge
Represents a read-only view of an expiration time for the merging process after a split-brain.
MergingHits - Interface in com.hazelcast.spi.merge
Represents a read-only view access hits for the merging process after a split-brain.
MergingLastAccessTime - Interface in com.hazelcast.spi.merge
Represents a read-only view of a last access time for the merging process after a split-brain.
MergingLastStoredTime - Interface in com.hazelcast.spi.merge
Represents a read-only view of a last stored time for the merging process after a split-brain.
MergingLastUpdateTime - Interface in com.hazelcast.spi.merge
Represents a read-only view of a last update time for the merging process after a split-brain.
MergingMaxIdle - Interface in com.hazelcast.spi.merge
Represents a read-only view of a MaxIdle for the merging process after a split-brain.
MergingTTL - Interface in com.hazelcast.spi.merge
Represents a read-only view of a TTL for the merging process after a split-brain.
mergingValue - Variable in class com.hazelcast.core.EntryEvent
 
MergingValue<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a data structure value for the merging process after a split-brain.
MergingVersion - Interface in com.hazelcast.spi.merge
Represents a read-only view of a version for the merging process after a split-brain.
MergingView - Interface in com.hazelcast.spi.merge
Marker interface representing a read-only view of a data structure for the merging process after a split-brain.
MerkleTreeConfig - Class in com.hazelcast.config
Configuration for a merkle tree.
MerkleTreeConfig() - Constructor for class com.hazelcast.config.MerkleTreeConfig
 
MerkleTreeConfig(MerkleTreeConfig) - Constructor for class com.hazelcast.config.MerkleTreeConfig
message() - Method in interface com.hazelcast.auditlog.AuditableEvent
Return a text description of the event.
message(String) - Method in interface com.hazelcast.auditlog.EventBuilder
 
Message<E> - Class in com.hazelcast.topic
Message for ITopic.
Message(String, E, long, Member) - Constructor for class com.hazelcast.topic.Message
 
MessageListener<E> - Interface in com.hazelcast.topic
Message listener for ITopic.
messageObject - Variable in class com.hazelcast.topic.Message
 
METADATA_CP_GROUP_NAME - Static variable in interface com.hazelcast.cp.CPGroup
Name of the internal CP group that is used for maintaining CP groups and CP members
MetadataAwareValue(V) - Constructor for class com.hazelcast.map.EntryLoader.MetadataAwareValue
Creates a value without attaching an expiration time
MetadataAwareValue(V, long) - Constructor for class com.hazelcast.map.EntryLoader.MetadataAwareValue
Creates a value and attaches an expiration time to it.
MetadataPolicy - Enum in com.hazelcast.config
Hazelcast may process objects of supported types ahead of time to create additional metadata about them.
METRICS_COLLECTION_FREQUENCY - Static variable in class com.hazelcast.client.properties.ClientProperty
Sets the metrics collection frequency in seconds.
METRICS_COLLECTION_FREQUENCY - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Sets the metrics collection frequency in seconds.
METRICS_DATASTRUCTURES - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Enables/disables collecting metrics from the distributed data structures.
METRICS_DEBUG - Static variable in class com.hazelcast.client.properties.ClientProperty
Enables collecting debug metrics.
METRICS_DEBUG - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Enables collecting debug metrics.
METRICS_ENABLED - Static variable in class com.hazelcast.client.properties.ClientProperty
Enables/disables metrics collection altogether.
METRICS_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Enables/disables metrics collection altogether.
METRICS_JMX_ENABLED - Static variable in class com.hazelcast.client.properties.ClientProperty
Enables/disables exposing metrics on JMX.
METRICS_JMX_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Enables/disables exposing metrics on JMX.
METRICS_MC_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Enables/disables collecting metrics for Management Center.
METRICS_MC_RETENTION - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Sets the duration in seconds for which the collected metrics are retained and Management Center can consume them.
MetricsConfig - Class in com.hazelcast.config
Member-side metrics collection configuration.
MetricsConfig() - Constructor for class com.hazelcast.config.MetricsConfig
 
MetricsConfig(MetricsConfig) - Constructor for class com.hazelcast.config.MetricsConfig
 
MetricsJmxConfig - Class in com.hazelcast.config
JMX related metrics configuration.
MetricsJmxConfig() - Constructor for class com.hazelcast.config.MetricsJmxConfig
 
MetricsJmxConfig(MetricsJmxConfig) - Constructor for class com.hazelcast.config.MetricsJmxConfig
 
MetricsManagementCenterConfig - Class in com.hazelcast.config
Management Center related metrics configuration.
MetricsManagementCenterConfig() - Constructor for class com.hazelcast.config.MetricsManagementCenterConfig
 
MetricsManagementCenterConfig(MetricsManagementCenterConfig) - Constructor for class com.hazelcast.config.MetricsManagementCenterConfig
 
migrationFinished(MigrationState) - Method in interface com.hazelcast.partition.MigrationListener
Called when the migration process finishes.
MigrationListener - Interface in com.hazelcast.partition
MigrationListener provides the ability to listen to partition migration process and events.
migrationStarted(MigrationState) - Method in interface com.hazelcast.partition.MigrationListener
Called when the migration process starts.
MigrationState - Interface in com.hazelcast.partition
MigrationState shows statistical information about the migration, such as; migration start time, number of planned replica migrations, number of completed replica migrations, total elapsed migration time etc.
MIN_BACKUP_COUNT - Static variable in class com.hazelcast.config.CacheSimpleConfig
The minimum number of backups.
MIN_BACKUP_COUNT - Static variable in class com.hazelcast.config.MapConfig
The minimum number of backups
MIN_GROUP_SIZE - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
The minimum number of CP members that can form a CP group.
MIN_INITIAL_MEMORY_SIZE - Static variable in class com.hazelcast.config.NativeMemoryConfig
Minimum initial memory size in megabytes
minBy(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
minBy(Comparator<? super T>) - Static method in interface com.hazelcast.function.BinaryOperatorEx
minimumClusterSize - Variable in class com.hazelcast.config.SplitBrainProtectionConfigBuilder
The minimum cluster size: expected number of live members in cluster not to be considered it split
MOBY_NAMING_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Defines whether Moby Names should be used for instance name generating when it is not provided by user.
modifyOutputStream(JarOutputStream) - Method in class com.hazelcast.buildutils.HazelcastManifestTransformer
 
multiAttribute(String...) - Static method in class com.hazelcast.projection.Projections
Returns a projection that extracts the value of the given attributePaths.
MulticastConfig - Class in com.hazelcast.config
Contains the configuration for the multicast discovery mechanism.
MulticastConfig() - Constructor for class com.hazelcast.config.MulticastConfig
 
MulticastDiscoveryStrategy - Class in com.hazelcast.spi.discovery.multicast
The multicast DiscoveryStrategy.
MulticastDiscoveryStrategy(DiscoveryNode, ILogger, Map<String, Comparable>) - Constructor for class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategy
 
MulticastDiscoveryStrategyFactory - Class in com.hazelcast.spi.discovery.multicast
Factory class which returns MulticastDiscoveryStrategy to Discovery SPI
MulticastDiscoveryStrategyFactory() - Constructor for class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategyFactory
 
MulticastProperties - Class in com.hazelcast.spi.discovery.multicast
Defines the name and default value for the Multicast Discovery Strategy.
MultiExecutionCallback - Interface in com.hazelcast.core
MultiExecutionCallback provides notification for when an execution is completed on each member that a task is submitted to.
MultiMap<K,V> - Interface in com.hazelcast.multimap
A specialized map whose keys can be associated with multiple values.
MultiMapConfig - Class in com.hazelcast.config
Configuration for MultiMap.
MultiMapConfig() - Constructor for class com.hazelcast.config.MultiMapConfig
 
MultiMapConfig(String) - Constructor for class com.hazelcast.config.MultiMapConfig
 
MultiMapConfig(MultiMapConfig) - Constructor for class com.hazelcast.config.MultiMapConfig
 
MultiMapConfig.ValueCollectionType - Enum in com.hazelcast.config
Type of value collection
MultiMapPermission - Class in com.hazelcast.security.permission
 
MultiMapPermission(String, String...) - Constructor for class com.hazelcast.security.permission.MultiMapPermission
 
MutationDisallowedException - Exception in com.hazelcast.crdt
Exception that indicates that the state found on this replica disallows mutation.
MutationDisallowedException(String) - Constructor for exception com.hazelcast.crdt.MutationDisallowedException
 

N

name - Variable in class com.hazelcast.config.EndpointConfig
 
name - Variable in class com.hazelcast.map.AbstractIMapEvent
 
named(String, Runnable) - Static method in class com.hazelcast.scheduledexecutor.TaskUtils
Decorate any Runnable with a NamedTask to provide naming information to scheduler.
named(String, Callable<V>) - Static method in class com.hazelcast.scheduledexecutor.TaskUtils
Decorate any Callable with a NamedTask to provide naming information to scheduler.
NamedConfig - Interface in com.hazelcast.config
Interface for hazelcast data structures with name
NamedTask - Interface in com.hazelcast.scheduledexecutor
The NamedTask interface should be implemented by any task that needs to have an identification and enhanced atomicity upon scheduling the task.
NativeMemoryConfig - Class in com.hazelcast.config
Configures native memory region.
NativeMemoryConfig() - Constructor for class com.hazelcast.config.NativeMemoryConfig
 
NativeMemoryConfig(NativeMemoryConfig) - Constructor for class com.hazelcast.config.NativeMemoryConfig
 
NativeMemoryConfig.MemoryAllocatorType - Enum in com.hazelcast.config
Type of memory allocator: STANDARD: allocate/free memory using default OS memory manager POOLED: manage memory blocks in pool
NativeOutOfMemoryError - Error in com.hazelcast.memory
Thrown when Hazelcast cannot allocate required native memory.
NativeOutOfMemoryError() - Constructor for error com.hazelcast.memory.NativeOutOfMemoryError
 
NativeOutOfMemoryError(String) - Constructor for error com.hazelcast.memory.NativeOutOfMemoryError
 
NativeOutOfMemoryError(String, Throwable) - Constructor for error com.hazelcast.memory.NativeOutOfMemoryError
 
naturalOrder() - Static method in interface com.hazelcast.function.ComparatorEx
Serializable variant of java.util.Comparator#naturalOrder().
NearCacheConfig - Class in com.hazelcast.config
Contains the configuration for a Near Cache.
NearCacheConfig() - Constructor for class com.hazelcast.config.NearCacheConfig
 
NearCacheConfig(String) - Constructor for class com.hazelcast.config.NearCacheConfig
 
NearCacheConfig(NearCacheConfig) - Constructor for class com.hazelcast.config.NearCacheConfig
 
NearCacheConfig.LocalUpdatePolicy - Enum in com.hazelcast.config
Defines how to reflect local updates to the Near Cache.
NearCacheConfigAccessor - Class in com.hazelcast.config
Accessor for the EvictionConfig of a NearCacheConfig to initialize the old default max size, if no size was configured by the user.
NearCachePreloaderConfig - Class in com.hazelcast.config
Configuration for storing and pre-loading Near Cache keys.
NearCachePreloaderConfig() - Constructor for class com.hazelcast.config.NearCachePreloaderConfig
 
NearCachePreloaderConfig(NearCachePreloaderConfig) - Constructor for class com.hazelcast.config.NearCachePreloaderConfig
 
NearCachePreloaderConfig(String) - Constructor for class com.hazelcast.config.NearCachePreloaderConfig
 
NearCachePreloaderConfig(boolean, String) - Constructor for class com.hazelcast.config.NearCachePreloaderConfig
 
NearCacheStats - Interface in com.hazelcast.nearcache
Near Cache statistics to be used by MemberState implementations.
negate() - Method in interface com.hazelcast.function.BiPredicateEx
negate() - Method in interface com.hazelcast.function.PredicateEx
Serializable variant of Predicate.negate().
NETWORK_CONNECT - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
Event type ID: Connection accepted.
NETWORK_DISCONNECT - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
Event type ID: Connection closed.
NETWORK_SELECT_PROTOCOL - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
Event type ID: Protocol selected.
NETWORK_STATS_REFRESH_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
The interval at which network stats (bytes sent and received) are re-calculated and published.
NetworkConfig - Class in com.hazelcast.config
Contains configuration for Network.
NetworkConfig() - Constructor for class com.hazelcast.config.NetworkConfig
 
newBuilder() - Method in interface com.hazelcast.nio.serialization.GenericRecord
Creates a GenericRecord.Builder allows to create a new object.
newClientTransactionContext(TransactionOptions, UUID) - Method in interface com.hazelcast.transaction.TransactionManagerService
 
newCondition() - Method in interface com.hazelcast.cp.lock.FencedLock
NOT IMPLEMENTED.
newCredentials() - Method in class com.hazelcast.config.security.StaticCredentialsFactory
 
newCredentials() - Method in interface com.hazelcast.security.ICredentialsFactory
Creates new Credentials object.
newCredentials(Address) - Method in interface com.hazelcast.security.ICredentialsFactory
Creates new Credentials object for given target Address.
newDiscoveryService(DiscoveryServiceSettings) - Method in interface com.hazelcast.spi.discovery.integration.DiscoveryServiceProvider
Instantiates a new instance of the DiscoveryService.
newDiscoveryStrategy(DiscoveryNode, ILogger, Map<String, Comparable>) - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategyFactory
Instantiates a new instance of the DiscoveryStrategy with the given configuration properties.
newDiscoveryStrategy(DiscoveryNode, ILogger, Map<String, Comparable>) - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategyFactory
 
newHazelcastClient() - Static method in class com.hazelcast.client.HazelcastClient
Creates a new HazelcastInstance (a new client in a cluster).
newHazelcastClient(ClientConfig) - Static method in class com.hazelcast.client.HazelcastClient
Creates a new HazelcastInstance (a new client in a cluster).
newHazelcastFailoverClient() - Static method in class com.hazelcast.client.HazelcastClient
Creates a client with cluster switch capability.
newHazelcastFailoverClient(ClientFailoverConfig) - Static method in class com.hazelcast.client.HazelcastClient
Creates a client with cluster switch capability.
newHazelcastInstance(Config) - Static method in class com.hazelcast.core.Hazelcast
Creates a new HazelcastInstance (a new node in a cluster).
newHazelcastInstance() - Static method in class com.hazelcast.core.Hazelcast
Creates a new HazelcastInstance (a new node in a cluster).
newHazelcastInstance(Config) - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Creates a new HazelcastOSGiInstance on the owner bundle with specified configuration.
newHazelcastInstance() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Creates a new HazelcastOSGiInstance on the owner bundle with default configuration.
newId() - Method in interface com.hazelcast.flakeidgen.FlakeIdGenerator
Generates and returns a cluster-wide unique ID.
newLoggerFactory(String) - Static method in class com.hazelcast.logging.Logger
Creates a logger factory instance of the given preferred type.
newMapStore(String, Properties) - Method in interface com.hazelcast.map.MapStoreFactory
Produces a MapLoader or a MapStore for the given map name and properties.
newPermissionCollection() - Method in class com.hazelcast.security.permission.AllPermissions
 
newPermissionCollection() - Method in class com.hazelcast.security.permission.ClusterPermission
 
newPredicateBuilder() - Static method in class com.hazelcast.query.Predicates
Creates a new instance of PredicateBuilder.
newProbabilisticSplitBrainProtectionConfigBuilder(String, int) - Static method in class com.hazelcast.config.SplitBrainProtectionConfig
Returns a builder for SplitBrainProtectionConfig with the given name using a probabilistic split brain protection function, for the given split brain protection size that is enabled by default.
newQueueStore(String, Properties) - Method in interface com.hazelcast.collection.QueueStoreFactory
 
newRecentlyActiveSplitBrainProtectionConfigBuilder(String, int, int) - Static method in class com.hazelcast.config.SplitBrainProtectionConfig
Returns a builder for a SplitBrainProtectionConfig with the given name using a recently-active split brain protection function for the given split brain protection size that is enabled by default.
newRingbufferStore(String, Properties) - Method in interface com.hazelcast.ringbuffer.RingbufferStoreFactory
 
newTransactionContext() - Method in interface com.hazelcast.core.HazelcastInstance
Creates a new TransactionContext associated with the current thread using default options.
newTransactionContext(TransactionOptions) - Method in interface com.hazelcast.core.HazelcastInstance
Creates a new TransactionContext associated with the current thread with given options.
newTransactionContext(TransactionOptions) - Method in interface com.hazelcast.transaction.TransactionManagerService
 
next() - Method in interface com.hazelcast.client.LoadBalancer
Returns the next member to route to.
next() - Method in class com.hazelcast.spi.merge.RingbufferMergeDataReadOnlyIterator
 
nextDataMember() - Method in interface com.hazelcast.client.LoadBalancer
Returns the next data member to route to.
nextPage() - Method in interface com.hazelcast.query.PagingPredicate
Sets the page value to next page.
NO_OFFLOADING - Static variable in interface com.hazelcast.core.Offloadable
Constant meaning that there will be no off-loading if returned from the Offloadable.getExecutorName() method.
NO_TIME_SET - Static variable in class com.hazelcast.map.EntryLoader.MetadataAwareValue
Represents no expiration time for a particular value
NoDataMemberInClusterException - Exception in com.hazelcast.partition
Thrown when there is no data member in the cluster to assign partitions.
NoDataMemberInClusterException(String) - Constructor for exception com.hazelcast.partition.NoDataMemberInClusterException
 
node(String, Object, Object...) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
NodeFilter - Interface in com.hazelcast.spi.discovery
The NodeFilter, if supplied, will retrieve all discovered nodes and might apply additional filtering based on vendor provided metadata.
nodeIfContents(String, Object, Object...) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
NoLogFactory - Class in com.hazelcast.logging
 
NoLogFactory() - Constructor for class com.hazelcast.logging.NoLogFactory
 
noLogger() - Static method in class com.hazelcast.logging.Logger
 
NON_LOCAL_MEMBER_SELECTOR - Static variable in class com.hazelcast.cluster.memberselector.MemberSelectors
A MemberSelector instance that selects only remote members
NONE - Static variable in class com.hazelcast.security.permission.InstancePermission
 
noop() - Static method in interface com.hazelcast.function.ConsumerEx
Returns a consumer that does nothing.
NOOP_TENANT_CONTROL - Static variable in interface com.hazelcast.spi.tenantcontrol.TenantControl
Default no-op tenant control
NOOP_TENANT_CONTROL_FACTORY - Static variable in interface com.hazelcast.spi.tenantcontrol.TenantControlFactory
Default tenant control factory.
not(Predicate) - Static method in class com.hazelcast.query.Predicates
Creates a not predicate that will negate the result of the given predicate.
notEqual(Comparable) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
notEqual(String, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates a not equal predicate that will pass items if the given value and the value stored under the given item attribute are not equal.
NotLeaderException - Exception in com.hazelcast.cp.exception
A CPSubsystemException which is thrown when a leader-only request is received by a non-leader member.
NotLeaderException(CPGroupId, RaftEndpoint, RaftEndpoint) - Constructor for exception com.hazelcast.cp.exception.NotLeaderException
 
nullsFirst(Comparator<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
nullsFirst(ComparatorEx<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
nullsLast(Comparator<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
nullsLast(ComparatorEx<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
numberAvg() - Static method in class com.hazelcast.aggregation.Aggregators
 
numberAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
 

O

ObjectDataInput - Interface in com.hazelcast.nio
Provides serialization methods for arrays of primitive types.
ObjectDataOutput - Interface in com.hazelcast.nio
Provides serialization methods for arrays by extending DataOutput
of(String) - Static method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
Reconstructs a ScheduledTaskHandler from a URN String.
of(int, int, int) - Static method in class com.hazelcast.version.MemberVersion
 
of(String) - Static method in class com.hazelcast.version.MemberVersion
 
of(int, int) - Static method in class com.hazelcast.version.Version
 
of(String) - Static method in class com.hazelcast.version.Version
Parse the given string to a Version.
offer(E) - Method in interface com.hazelcast.collection.BaseQueue
Inserts the specified element into this queue if it is possible to do so immediately without violating capacity restrictions.
offer(E, long, TimeUnit) - Method in interface com.hazelcast.collection.BaseQueue
Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to become available.
offer(E) - Method in interface com.hazelcast.transaction.TransactionalQueue
Inserts the specified element into this queue if it is possible to do so immediately without violating capacity restrictions.
offer(E, long, TimeUnit) - Method in interface com.hazelcast.transaction.TransactionalQueue
Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to become available.
Offloadable - Interface in com.hazelcast.core
Allows off-loading the processing unit implementing this interface to the specified or default Executor.
OFFLOADABLE_EXECUTOR - Static variable in interface com.hazelcast.core.Offloadable
Constant meaning that processing will be off-loaded to the default OFFLOADABLE_EXECUTOR executor.
oldValue - Variable in class com.hazelcast.core.EntryEvent
 
onAccept(Socket) - Method in interface com.hazelcast.nio.MemberSocketInterceptor
This method will be called when a connection to a member node is accepted meaning security requirements and clusters are matching.
onAccumulationFinished() - Method in interface com.hazelcast.aggregation.Aggregator
Called after the last call to combine on a specific instance.
onChange(SplitBrainProtectionEvent) - Method in interface com.hazelcast.splitbrainprotection.SplitBrainProtectionListener
Called when the state of the split brain detector is changed.
onCombinationFinished() - Method in interface com.hazelcast.aggregation.Aggregator
Called after the last call to combine on a specific instance.
onComplete(Map<Member, Object>) - Method in interface com.hazelcast.core.MultiExecutionCallback
Called after all executions are completed.
onConnect(Socket) - Method in interface com.hazelcast.nio.SocketInterceptor
Called when a connection is established.
onEntryEvent(EntryEvent<K, V>) - Method in class com.hazelcast.core.EntryAdapter
This method is called when an one of the methods of the EntryListener is not overridden.
onFailure(Throwable) - Method in interface com.hazelcast.core.ExecutionCallback
Called when an execution is completed with an error.
onHeartbeat(Member, long) - Method in interface com.hazelcast.splitbrainprotection.HeartbeatAware
Notifies of a received heartbeat.
OnJoinPermissionOperationName - Enum in com.hazelcast.config
Enum of operation names for handling client permissions when the member is joining into the cluster.
onMapEvent(MapEvent) - Method in class com.hazelcast.core.EntryAdapter
This method is called when an one of the methods of the EntryListener is not overridden.
onMessage(Message) - Method in class com.hazelcast.console.ConsoleApp
 
onMessage(Message<E>) - Method in interface com.hazelcast.topic.MessageListener
Invoked when a message is received for the added topic.
onMigrationCommit(PartitionMigrationEvent) - Method in interface com.hazelcast.wan.WanMigrationAwarePublisher
Indicates that migration is committing for a given partition
onMigrationRollback(PartitionMigrationEvent) - Method in interface com.hazelcast.wan.WanMigrationAwarePublisher
Indicates that migration is rolling back for a given partition
onMigrationStart(PartitionMigrationEvent) - Method in interface com.hazelcast.wan.WanMigrationAwarePublisher
Indicates that migration started for a given partition
onOutOfMemory(OutOfMemoryError, HazelcastInstance[]) - Method in class com.hazelcast.client.ClientOutOfMemoryHandler
 
onOutOfMemory(OutOfMemoryError, HazelcastInstance[]) - Method in class com.hazelcast.core.OutOfMemoryHandler
When an OutOfMemoryError is caught by Hazelcast threads, this method is called for ALL HazelcastInstances knows by current JVM (actually ClassLoader).
onPingLost(Member) - Method in interface com.hazelcast.splitbrainprotection.PingAware
Notifies the SplitBrainProtectionFunction of ping loss.
onPingRestored(Member) - Method in interface com.hazelcast.splitbrainprotection.PingAware
Notifies the SplitBrainProtectionFunction of a successful ping after one or more pings to that member were lost.
onResponse(V) - Method in interface com.hazelcast.core.ExecutionCallback
Called when an execution is completed successfully.
onResponse(Member, Object) - Method in interface com.hazelcast.core.MultiExecutionCallback
Called when an execution is completed on a member.
onResult(T) - Method in interface com.hazelcast.query.extractor.ValueCallback
Notifies about a value passed as an argument
open(String, Object...) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
OPERATION_BACKUP_TIMEOUT_MILLIS - Static variable in class com.hazelcast.client.properties.ClientProperty
If an operation has backups, this property specifies how long the invocation will wait for acks from the backup replicas.
OPERATION_BACKUP_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
If an operation has backups, this property specifies how long the invocation will wait for acks from the backup replicas.
OPERATION_CALL_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Timeout to wait for a response when a remote call is sent, in milliseconds.
OperationTimeoutException - Exception in com.hazelcast.core
An unchecked version of TimeoutException.
OperationTimeoutException() - Constructor for exception com.hazelcast.core.OperationTimeoutException
 
OperationTimeoutException(String) - Constructor for exception com.hazelcast.core.OperationTimeoutException
 
OperationTimeoutException(String, String) - Constructor for exception com.hazelcast.core.OperationTimeoutException
 
OperationTimeoutException(String, Throwable) - Constructor for exception com.hazelcast.core.OperationTimeoutException
 
optional() - Method in interface com.hazelcast.config.properties.PropertyDefinition
Defines if this property is optional or not.
optional() - Method in class com.hazelcast.config.properties.SimplePropertyDefinition
 
or(MemberSelector...) - Static method in class com.hazelcast.cluster.memberselector.MemberSelectors
Selects a member when one of the selectors succeed
or(BiPredicateEx<? super T, ? super U>) - Method in interface com.hazelcast.function.BiPredicateEx
or(PredicateEx<? super T>) - Method in interface com.hazelcast.function.PredicateEx
or(Predicate) - Method in interface com.hazelcast.query.PredicateBuilder
 
or(Predicate...) - Static method in class com.hazelcast.query.Predicates
Creates an or predicate that will perform the logical or operation on the given predicates.
org.apache.calcite.jdbc - package org.apache.calcite.jdbc
Contains Calcite-related classes.
org.apache.calcite.plan - package org.apache.calcite.plan
Contains Calcite-related classes.
OutOfMemoryHandler - Class in com.hazelcast.core
Handler for OutOfMemoryError.
OutOfMemoryHandler() - Constructor for class com.hazelcast.core.OutOfMemoryHandler
 
OverflowPolicy - Enum in com.hazelcast.ringbuffer
Using this policy one can control the behavior what should to be done when an item is about to be added to the ringbuffer, but there is 0 remaining capacity.

P

PagingPredicate<K,V> - Interface in com.hazelcast.query
This interface is a special Predicate which helps to get a page-by-page result of a query.
pagingPredicate(int) - Static method in class com.hazelcast.query.Predicates
Creates a paging predicate with a page size.
pagingPredicate(Predicate, int) - Static method in class com.hazelcast.query.Predicates
Creates a paging predicate with an inner predicate and page size.
pagingPredicate(Comparator<Map.Entry<K, V>>, int) - Static method in class com.hazelcast.query.Predicates
Creates a paging predicate with a comparator and page size.
pagingPredicate(Predicate<K, V>, Comparator<Map.Entry<K, V>>, int) - Static method in class com.hazelcast.query.Predicates
Creates a paging predicate with an inner predicate, comparator and page size.
parameters() - Method in interface com.hazelcast.auditlog.AuditableEvent
Return Map of parameters for given event.
parameters(Map<String, Object>) - Method in interface com.hazelcast.auditlog.EventBuilder
 
Parameters - Interface in com.hazelcast.security
This interface is used to pass parameters of a method call to a SecurityInterceptor.
parse(InputStream) - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
 
parse(InputStream) - Method in class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
 
parse(InputStream) - Method in class com.hazelcast.config.AbstractXmlConfigBuilder
Reads XML from InputStream and parses.
parse(InputStream) - Method in class com.hazelcast.config.XmlConfigBuilder
 
parse(String) - Static method in class com.hazelcast.memory.MemorySize
Parses string representation of a memory size value.
parse(String, MemoryUnit) - Static method in class com.hazelcast.memory.MemorySize
Parses string representation of a memory size value.
parseDelimitedString(String, char) - Static method in class com.hazelcast.buildutils.ElementParser
 
parseDelimitedString(String, char, boolean) - Static method in class com.hazelcast.buildutils.ElementParser
Parses delimited string and returns an array containing the tokens.
parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.CacheManagerBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.HazelcastClientBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.HazelcastConfigBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.HazelcastFailoverClientBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.HazelcastInstanceDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.HazelcastTypeBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.hibernate.RegionFactoryBeanDefinitionParser
 
parseListeners(Node, Class) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
parseProperties(Node) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
parseProxyFactories(Node, Class) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
parseString(String) - Static method in enum com.hazelcast.config.CacheDeserializedValues
Create instance from String
PARTIAL_MEMBER_DISCONNECTION_RESOLUTION_ALGORITHM_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
The partial member disconnection resolution mechanism uses a graph algorithm that finds a max-clique in non-polynomial time.
PARTIAL_MEMBER_DISCONNECTION_RESOLUTION_HEARTBEAT_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
The master member, i.e, the first member in the cluster member list administrates the cluster and kicks unreachable members with the heartbeat mechanism.
Partition - Interface in com.hazelcast.partition
In Hazelcast the data is split up in partitions: by default, 271 and configurable through the 'hazelcast.partition.count' ClusterProperty.
PARTITION_BACKUP_SYNC_INTERVAL - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Interval for syncing backup replicas in seconds.
PARTITION_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Total number of partitions in the Hazelcast cluster.
PARTITION_FRAGMENTED_MIGRATION_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
When enabled, which is the default behavior, partitions are migrated/replicated in small fragments instead of one big chunk.
PARTITION_GROUP_HOST - Static variable in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
Metadata key definition for a low-latency link on a shared physical node, in case of virtualization being used
PARTITION_GROUP_NODE - Static variable in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
Metadata key definition for a node machine that containers/pods run on, in case of container orchestration tools being used.
PARTITION_GROUP_RACK - Static variable in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
Metadata key definition for a low-latency link inside the same data center but for different racks
PARTITION_GROUP_ZONE - Static variable in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
Metadata key definition for a low-latency link between (virtual) data centers in the same area
PARTITION_MAX_PARALLEL_MIGRATIONS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Maximum number of partition migrations to be executed concurrently on a member.
PARTITION_MAX_PARALLEL_REPLICATIONS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Maximum number of anti-entropy partition replications to be executed on a member.
PARTITION_MIGRATION_INTERVAL - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Time in seconds to sleep after a migration task.
PARTITION_MIGRATION_TIMEOUT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Timeout in seconds for all migration operations.
PARTITION_OPERATION_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
The number of partition operation handler threads per member.
PARTITION_TABLE_SEND_INTERVAL - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Interval for publishing partition table periodically to all cluster members in seconds.
PartitionAware<T> - Interface in com.hazelcast.partition
PartitionAware means that data will be based in the same member based on the partition key and implementing tasks will be executed on the PartitionAware.getPartitionKey()'s owner member.
PartitionAwareKey<K,P> - Class in com.hazelcast.partition
PartitionAwareKey(K, P) - Constructor for class com.hazelcast.partition.PartitionAwareKey
Creates a new PartitionAwareKey.
PartitionEvent - Interface in com.hazelcast.partition
PartitionEvent is a base interface for partition related events.
PartitionGroupConfig - Class in com.hazelcast.config
With PartitionGroupConfig, you can control how primary and backup partitions are mapped to physical Members.
PartitionGroupConfig() - Constructor for class com.hazelcast.config.PartitionGroupConfig
 
PartitionGroupConfig.MemberGroupType - Enum in com.hazelcast.config
Type of member groups.
PartitionGroupMetaData - Enum in com.hazelcast.spi.partitiongroup
This class contains the definition of known Discovery SPI metadata to support automatic generation of zone aware and node aware backup strategies.
PartitionGroupStrategy - Interface in com.hazelcast.spi.partitiongroup
A PartitionGroupStrategy implementation defines a strategy how backup groups are designed.
PARTITIONING_STRATEGY_CLASS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Class name implementing PartitioningStrategy, which defines key to partition mapping.
PartitioningStrategy<K> - Interface in com.hazelcast.partition
PartitioningStrategy allows keys to be located on the same member.
PartitioningStrategyConfig - Class in com.hazelcast.config
Contains the configuration for partitioning strategy.
PartitioningStrategyConfig() - Constructor for class com.hazelcast.config.PartitioningStrategyConfig
 
PartitioningStrategyConfig(PartitioningStrategyConfig) - Constructor for class com.hazelcast.config.PartitioningStrategyConfig
 
PartitioningStrategyConfig(String) - Constructor for class com.hazelcast.config.PartitioningStrategyConfig
 
PartitioningStrategyConfig(PartitioningStrategy) - Constructor for class com.hazelcast.config.PartitioningStrategyConfig
 
partitionLost(MapPartitionLostEvent) - Method in interface com.hazelcast.map.listener.MapPartitionLostListener
Invoked when owner and all backups of a partition is lost for a specific map.
partitionLost(PartitionLostEvent) - Method in interface com.hazelcast.partition.PartitionLostListener
Invoked when a partition loses its owner and all backups.
PartitionLostEvent - Interface in com.hazelcast.partition
The event that is fired when a partition lost its owner and all backups.
PartitionLostListener - Interface in com.hazelcast.partition
PartitionLostListener provides the ability to be notified upon a possible data loss when a partition loses a replica.
PartitionMigratingException - Exception in com.hazelcast.spi.exception
A RetryableHazelcastException that is thrown when an operation is executed on a partition, but that partition is currently being moved around.
PartitionMigratingException(Address, int, String, String) - Constructor for exception com.hazelcast.spi.exception.PartitionMigratingException
 
PartitionMigratingException(String) - Constructor for exception com.hazelcast.spi.exception.PartitionMigratingException
 
PartitionPredicate<K,V> - Interface in com.hazelcast.query
A Predicate that restricts the execution of a Predicate to a single partition.
partitionPredicate(Object, Predicate<K, V>) - Static method in class com.hazelcast.query.Predicates
Creates a new partition predicate that restricts the execution of the target predicate to a single partition.
PartitionService - Interface in com.hazelcast.partition
PartitionService allows you to query Partitions and attach/detach MigrationListeners to listen to partition migration events.
PassThroughMergePolicy<V,T extends MergingValue<V>> - Class in com.hazelcast.spi.merge
Merges data structure entries from source to destination directly unless the merging entry is null.
PassThroughMergePolicy() - Constructor for class com.hazelcast.spi.merge.PassThroughMergePolicy
 
PasswordCredentials - Interface in com.hazelcast.security
Credentials type for name/password representation.
peek() - Method in interface com.hazelcast.transaction.TransactionalQueue
peek(long, TimeUnit) - Method in interface com.hazelcast.transaction.TransactionalQueue
PermissionConfig - Class in com.hazelcast.config
Contains the configuration for a permission.
PermissionConfig() - Constructor for class com.hazelcast.config.PermissionConfig
 
PermissionConfig(PermissionConfig.PermissionType, String, String) - Constructor for class com.hazelcast.config.PermissionConfig
 
PermissionConfig(PermissionConfig) - Constructor for class com.hazelcast.config.PermissionConfig
 
PermissionConfig.PermissionType - Enum in com.hazelcast.config
Type of permission
PermissionPolicyConfig - Class in com.hazelcast.config
Contains the configuration for policy of permission
PermissionPolicyConfig() - Constructor for class com.hazelcast.config.PermissionPolicyConfig
 
PermissionPolicyConfig(String) - Constructor for class com.hazelcast.config.PermissionPolicyConfig
 
PersistentMemoryConfig - Class in com.hazelcast.config
Configuration class for persistent memory devices (e.g.
PersistentMemoryConfig() - Constructor for class com.hazelcast.config.PersistentMemoryConfig
 
PersistentMemoryConfig(PersistentMemoryConfig) - Constructor for class com.hazelcast.config.PersistentMemoryConfig
Constructs an instance with copying the fields of the provided PersistentMemoryConfig.
PersistentMemoryDirectoryConfig - Class in com.hazelcast.config
Configuration class for directories that persistent memories are mounted at.
PersistentMemoryDirectoryConfig(String) - Constructor for class com.hazelcast.config.PersistentMemoryDirectoryConfig
Creates an instance with the directory specified.
PersistentMemoryDirectoryConfig(String, int) - Constructor for class com.hazelcast.config.PersistentMemoryDirectoryConfig
Creates an instance with the directory and NUMA node specified.
PersistentMemoryDirectoryConfig(PersistentMemoryDirectoryConfig) - Constructor for class com.hazelcast.config.PersistentMemoryDirectoryConfig
Constructs an instance by copying the provided PersistentMemoryDirectoryConfig.
PersistentMemoryMode - Enum in com.hazelcast.config
The enumeration of the supported persistent memory operational modes.
PHONE_HOME_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Enable or disable the sending of phone home data to Hazelcast’s phone home server.
PingAware - Interface in com.hazelcast.splitbrainprotection
Split brain protection functions that need access to ICMP ping failure detector should implement this interface; the instance of PingFailureDetector used by this member's ClusterHeartbeatManager will be provided on initialization.
Pipelining<E> - Class in com.hazelcast.core
The Pipelining can be used to speed up requests.
Pipelining(int) - Constructor for class com.hazelcast.core.Pipelining
Creates a Pipelining with the given depth.
PlaceHolder - Class in com.hazelcast
 
PlaceHolder() - Constructor for class com.hazelcast.PlaceHolder
 
PLACEHOLDER_NAMESPACE - Static variable in class com.hazelcast.config.InstanceTrackingConfig
Namespace for the placeholders in the file name and format pattern to distinguish between different types of placeholders.
PNCounter - Interface in com.hazelcast.crdt.pncounter
PN (Positive-Negative) CRDT counter.
PNCounterConfig - Class in com.hazelcast.config
Configuration for a PNCounter
PNCounterConfig() - Constructor for class com.hazelcast.config.PNCounterConfig
 
PNCounterConfig(String, int, String, boolean) - Constructor for class com.hazelcast.config.PNCounterConfig
 
PNCounterConfig(String) - Constructor for class com.hazelcast.config.PNCounterConfig
 
PNCounterConfig(PNCounterConfig) - Constructor for class com.hazelcast.config.PNCounterConfig
 
PNCounterPermission - Class in com.hazelcast.security.permission
 
PNCounterPermission(String, String...) - Constructor for class com.hazelcast.security.permission.PNCounterPermission
 
poll() - Method in interface com.hazelcast.collection.BaseQueue
Retrieves and removes the head of this queue, or returns null if this queue is empty.
poll(long, TimeUnit) - Method in interface com.hazelcast.collection.BaseQueue
Retrieves and removes the head of this queue, waiting up to the specified wait time if necessary for an element to become available.
poll() - Method in interface com.hazelcast.collection.IQueue
Retrieves and removes the head of this queue, or returns null if this queue is empty.
poll(long, TimeUnit) - Method in interface com.hazelcast.collection.IQueue
Retrieves and removes the head of this queue, waiting up to the specified wait time if necessary for an element to become available.
poll() - Method in interface com.hazelcast.transaction.TransactionalQueue
Retrieves and removes the head of this queue, or returns null if this queue is empty.
poll(long, TimeUnit) - Method in interface com.hazelcast.transaction.TransactionalQueue
Retrieves and removes the head of this queue, waiting up to the specified wait time if necessary for an element to become available.
PORT - Static variable in class com.hazelcast.spi.discovery.multicast.MulticastProperties
Property used to define multicast port.
PORT_AUTO_INCREMENT - Static variable in class com.hazelcast.config.ServerSocketEndpointConfig
Default port auto-increment count.
portable(ClassDefinition) - Static method in interface com.hazelcast.nio.serialization.GenericRecord.Builder
Creates a Builder that will build a GenericRecord in Portable format with a new class definition:
Portable - Interface in com.hazelcast.nio.serialization
Portable provides an alternative serialization method.
PortableFactory - Interface in com.hazelcast.nio.serialization
PortableFactory is used to create Portable instances during de-serialization.
PortableReader - Interface in com.hazelcast.nio.serialization
Provides means for reading portable fields from binary data in the form of java primitives, arrays of java primitives, nested portable fields and array of portable fields.
PortableWriter - Interface in com.hazelcast.nio.serialization
Provides means for writing portable fields to binary data in the form of java primitives, arrays of java primitives, nested portable fields and arrays of portable fields.
PostProcessingMapStore - Interface in com.hazelcast.map
Implement this interface if you modify the value in MapStore.store(K key, V value) method.
Predicate<K,V> - Interface in com.hazelcast.query
Represents a map entry predicate.
PredicateBuilder - Interface in com.hazelcast.query
This interface provides functionality to build a predicate.
PredicateBuilder.EntryObject - Interface in com.hazelcast.query
This interface provides entry-level functionality related to building a predicate.
PredicateConfig - Class in com.hazelcast.config
Contains the configuration for an Predicate.
PredicateConfig() - Constructor for class com.hazelcast.config.PredicateConfig
Creates a PredicateConfig without className/implementation.
PredicateConfig(String) - Constructor for class com.hazelcast.config.PredicateConfig
Creates a PredicateConfig with the given className.
PredicateConfig(PredicateConfig) - Constructor for class com.hazelcast.config.PredicateConfig
 
PredicateConfig(Predicate) - Constructor for class com.hazelcast.config.PredicateConfig
Creates a PredicateConfig with the given implementation.
PredicateEx<T> - Interface in com.hazelcast.function
Serializable variant of java.util.function.Predicate which declares checked exception.
Predicates - Class in com.hazelcast.query
A utility class to create new PredicateBuilder and Predicate instances.
PREFER_IPv4_STACK - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Prefer IPv4 network interface when picking a local address.
PrefixedDistributedObject - Interface in com.hazelcast.core
Contact point for special DistributedObject's which has prefixed name.
premain(String, Instrumentation) - Static method in class com.hazelcast.buildutils.FinalRemovalAgent
When running a compatibility test, all com.hazelcast.* classes are transformed so that none are loaded with final modifier to allow subclass proxying.
prepareEventContainerReplicationData(PartitionReplicationEvent, Collection<ServiceNamespace>) - Method in interface com.hazelcast.wan.WanMigrationAwarePublisher
Returns a container containing the WAN events for the given replication event and namespaces to be replicated.
previousPage() - Method in interface com.hazelcast.query.PagingPredicate
Sets the page value to previous page.
print(Object) - Method in class com.hazelcast.console.ConsoleApp
 
println(Object) - Method in class com.hazelcast.console.ConsoleApp
 
PRIORITY_GENERIC_OPERATION_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
The number of priority generic operation handler threads per member.
PrivateApi - Annotation Type in com.hazelcast.spi.annotation
Marker for private functionality.
ProbabilisticSplitBrainProtectionConfigBuilder - Class in com.hazelcast.config
Builder for a SplitBrainProtectionConfig configured with ProbabilisticSplitBrainProtectionFunction that considers members present in the context of a split brain protection using a probabilistic, adaptive split brain protection function.
process(Node) - Method in class com.hazelcast.config.AbstractXmlConfigBuilder
 
process(Map.Entry<K, V>) - Method in interface com.hazelcast.map.EntryProcessor
Process the entry without worrying about concurrency.
processEventContainerReplicationData(int, T) - Method in interface com.hazelcast.wan.WanMigrationAwarePublisher
Processes the WAN event container received through intra-cluster replication or migration.
processResource(String, InputStream, List<Relocator>, long) - Method in class com.hazelcast.buildutils.HazelcastManifestTransformer
 
project(Projection<? super Map.Entry<K, V>, R>) - Method in interface com.hazelcast.map.IMap
Applies the projection logic on all map entries and returns the result
project(Projection<? super Map.Entry<K, V>, R>, Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
Applies the projection logic on map entries filtered with the Predicated and returns the result
Projection<I,O> - Interface in com.hazelcast.projection
Enables transforming object into other objects.
Projections - Class in com.hazelcast.projection
A utility class to create basic Projection instances.
promoteLocalLiteMember() - Method in interface com.hazelcast.cluster.Cluster
Promotes local lite member to data member.
promoteToCPMember() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Promotes the local Hazelcast member to the CP role.
properties - Variable in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
 
properties - Variable in class com.hazelcast.config.AbstractWanPublisherConfig
 
propertiesByInstanceItself(HazelcastInstance) - Static method in class com.hazelcast.cache.HazelcastCachingProvider
Create the Properties with the provided instance itself.
propertiesByInstanceName(String) - Static method in class com.hazelcast.cache.HazelcastCachingProvider
Create the Properties with the provided instance name.
propertiesByLocation(String) - Static method in class com.hazelcast.cache.HazelcastCachingProvider
Create the Properties with the provided config file location.
PROPERTY_CIPHER_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Replacer property name to configure Cipher algorithm name.
PROPERTY_KEY_LENGTH_BITS - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Replacer property name to configure key length (in bits).
PROPERTY_PASSWORD_FILE - Static variable in class com.hazelcast.config.replacer.EncryptionReplacer
Replacer property name to configure path to a password file which content should be used as part of the encryption password.
PROPERTY_PASSWORD_NETWORK_INTERFACE - Static variable in class com.hazelcast.config.replacer.EncryptionReplacer
Replacer property name to configure network interface name used to retrieve MAC address used as part of the encryption password.
PROPERTY_PASSWORD_USER_PROPERTIES - Static variable in class com.hazelcast.config.replacer.EncryptionReplacer
Replacer property name to configure true/false flag contolling if users properties should be used as part of the encryption password.
PROPERTY_SALT_LENGTH_BYTES - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Replacer property name to configure salt length (in bytes).
PROPERTY_SECRET_KEY_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Replacer property name to configure SecretKeySpec algorithm name.
PROPERTY_SECRET_KEY_FACTORY_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Replacer property name to configure SecretKeyFactory algorithm name.
PROPERTY_SECURITY_PROVIDER - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Replacer property name to configure Java Security provider name used for Cipher and SecretKeyFactory selection.
PropertyDefinition - Interface in com.hazelcast.config.properties
This interface describes an extended approach of the currently available pure property based configuration inside Hazelcast and helps implementing an automatic and transparent way to verify configuration as well as converting types based on provided validators and converters.
PropertyReplacer - Class in com.hazelcast.config.replacer
ConfigReplacer for replacing property names with property values for properties provided in PropertyReplacer.init(Properties) method.
PropertyReplacer() - Constructor for class com.hazelcast.config.replacer.PropertyReplacer
 
PropertyTypeConverter - Enum in com.hazelcast.config.properties
This enum class contains basic TypeConverter implementations to convert strings to all common basic Java types.
protocolType - Variable in class com.hazelcast.config.EndpointConfig
 
ProxyFactoryConfig - Class in com.hazelcast.client.config
This class is related to SPI.
ProxyFactoryConfig() - Constructor for class com.hazelcast.client.config.ProxyFactoryConfig
 
ProxyFactoryConfig(String, String) - Constructor for class com.hazelcast.client.config.ProxyFactoryConfig
 
ProxyFactoryConfig(String, ClientProxyFactory) - Constructor for class com.hazelcast.client.config.ProxyFactoryConfig
 
ProxyFactoryConfig(ProxyFactoryConfig) - Constructor for class com.hazelcast.client.config.ProxyFactoryConfig
 
publish(E) - Method in interface com.hazelcast.topic.ITopic
Publishes the message to all subscribers of this topic.
publishAll(Collection<? extends E>) - Method in interface com.hazelcast.topic.ITopic
Publishes all messages to all subscribers of this topic.
publishAllAsync(Collection<? extends E>) - Method in interface com.hazelcast.topic.ITopic
Publishes all messages asynchronously to all subscribers of this topic.
publishAsync(E) - Method in interface com.hazelcast.topic.ITopic
Publishes the message asynchronously to all subscribers of this topic.
publisherId - Variable in class com.hazelcast.config.AbstractWanPublisherConfig
 
publishReplicationEvent(WanEvent<T>) - Method in interface com.hazelcast.wan.WanPublisher
Publish the eventObject WAN replication event.
publishReplicationEventBackup(WanEvent<T>) - Method in interface com.hazelcast.wan.WanPublisher
Publish the eventObject WAN replication event backup.
put(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Associates the specified value with the specified key in the cache using a custom ExpiryPolicy.
put(K, V) - Method in interface com.hazelcast.map.BaseMap
Associates the specified value with the specified key in this map.
put(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.BaseMap
Associates the specified value with the specified key in this map with a given ttl (time to live) value.
put(K, V) - Method in interface com.hazelcast.map.IMap
Associates the specified value with the specified key in this map.
put(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Puts an entry into this map with a given TTL (time to live) value.
put(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Puts an entry into this map with a given TTL (time to live) value and max idle time value.
put(K, V) - Method in interface com.hazelcast.multimap.BaseMultiMap
Stores a key-value pair in the multimap.
put(K, V) - Method in interface com.hazelcast.multimap.MultiMap
Stores a key-value pair in the multimap.
put(K, V, long, TimeUnit) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Associates a given value to the specified key and replicates it to the cluster.
put(Object, Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
 
put(K, V) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.put(Object, Object).
put(K, V, long, TimeUnit) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.put(Object, Object, long, TimeUnit).
put(K, V) - Method in interface com.hazelcast.transaction.TransactionalMultiMap
Stores a key-value pair in the multimap.
putAll(Map<? extends K, ? extends V>, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Copies all of the entries from the given map to the cache using a custom ExpiryPolicy.
putAll(Map<? extends K, ? extends V>) - Method in interface com.hazelcast.map.IMap
putAllAsync(Map<? extends K, ? extends V>) - Method in interface com.hazelcast.map.IMap
Asynchronously copies all of the mappings from the specified map to this map.
putAllAsync(Map<? extends K, Collection<? extends V>>) - Method in interface com.hazelcast.multimap.MultiMap
Stores the given Map in the MultiMap asynchronously.
putAllAsync(K, Collection<? extends V>) - Method in interface com.hazelcast.multimap.MultiMap
Stores the given Collection in the specified key of a MultiMap asynchronously.
putAsync(K, V) - Method in interface com.hazelcast.cache.ICache
Asynchronously associates the specified value with the specified key in the cache.
putAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Asynchronously associates the specified value with the specified key in the cache using a custom ExpiryPolicy.
putAsync(K, V) - Method in interface com.hazelcast.map.IMap
Asynchronously puts the given key and value.
putAsync(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Asynchronously puts the given key and value into this map with a given TTL (time to live) value.
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Asynchronously puts the given key and value into this map with a given TTL (time to live) value and max idle time value.
putIfAbsent(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Associates the specified key with the given value if and only if there is not yet a mapping defined for the specified key.
putIfAbsent(K, V) - Method in interface com.hazelcast.map.BaseMap
If the specified key is not already associated with a value, associate it with the given value.
putIfAbsent(K, V) - Method in interface com.hazelcast.map.IMap
If the specified key is not already associated with a value, associate it with the given value.
putIfAbsent(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Puts an entry into this map with a given TTL (time to live) value, if the specified key is not already associated with a value.
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Puts an entry into this map with a given TTL (time to live) value and max idle time value.
putIfAbsent(Object, Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
 
putIfAbsent(K, V) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.putIfAbsent(Object, Object).
putIfAbsentAsync(K, V) - Method in interface com.hazelcast.cache.ICache
Asynchronously associates the specified key with the given value if and only if there is not yet a mapping defined for the specified key.
putIfAbsentAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Asynchronously associates the specified key with the given value if and only if there is not yet a mapping defined for the specified key.
PutIfAbsentMergePolicy<V,T extends MergingValue<V>> - Class in com.hazelcast.spi.merge
Merges data structure entries from source to destination if they don't exist in the destination data structure.
PutIfAbsentMergePolicy() - Constructor for class com.hazelcast.spi.merge.PutIfAbsentMergePolicy
 
putTransient(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Same as IMap.put(Object, Object, long, TimeUnit) except that the map store, if defined, will not be called to load/store/persist the entry.
putTransient(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Same as IMap.put(Object, Object, long, TimeUnit) except that the map store, if defined, will not be called to load/store/persist the entry.

Q

QUERY_MAX_LOCAL_PARTITION_LIMIT_FOR_PRE_CHECK - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Maximum value of local partitions to trigger local pre-check for Predicates.alwaysTrue() predicate query operations on maps.
QUERY_OPTIMIZER_TYPE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Type of Query Optimizer.
QUERY_PREDICATE_PARALLEL_EVALUATION - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Run Query Evaluations for multiple partitions in parallel.
QUERY_RESULT_SIZE_LIMIT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Result size limit for query operations on maps.
QueryCache<K,V> - Interface in com.hazelcast.map
A concurrent, queryable data structure which is used to cache results of a continuous query executed on an IMap.
QueryCacheConfig - Class in com.hazelcast.config
Contains configuration for QueryCache.
QueryCacheConfig() - Constructor for class com.hazelcast.config.QueryCacheConfig
 
QueryCacheConfig(String) - Constructor for class com.hazelcast.config.QueryCacheConfig
 
QueryCacheConfig(QueryCacheConfig) - Constructor for class com.hazelcast.config.QueryCacheConfig
 
QueryConstants - Enum in com.hazelcast.query
Contains constants for Query.
QueryException - Exception in com.hazelcast.query
Exception class for the Query.
QueryException() - Constructor for exception com.hazelcast.query.QueryException
 
QueryException(String) - Constructor for exception com.hazelcast.query.QueryException
 
QueryException(String, Throwable) - Constructor for exception com.hazelcast.query.QueryException
 
QueryException(Throwable) - Constructor for exception com.hazelcast.query.QueryException
 
QueryResultSizeExceededException - Exception in com.hazelcast.map
This exception is thrown when a query exceeds a configurable result size limit.
QueryResultSizeExceededException(String) - Constructor for exception com.hazelcast.map.QueryResultSizeExceededException
 
QueryResultSizeExceededException() - Constructor for exception com.hazelcast.map.QueryResultSizeExceededException
 
QueryResultSizeExceededException(int, String) - Constructor for exception com.hazelcast.map.QueryResultSizeExceededException
 
QueueConfig - Class in com.hazelcast.config
Contains the configuration for an IQueue.
QueueConfig() - Constructor for class com.hazelcast.config.QueueConfig
 
QueueConfig(String) - Constructor for class com.hazelcast.config.QueueConfig
 
QueueConfig(QueueConfig) - Constructor for class com.hazelcast.config.QueueConfig
 
QueuePermission - Class in com.hazelcast.security.permission
 
QueuePermission(String, String...) - Constructor for class com.hazelcast.security.permission.QueuePermission
 
QueueStore<T> - Interface in com.hazelcast.collection
QueueStore makes a queue backed by a central data store; such as database, disk, etc.
QueueStoreConfig - Class in com.hazelcast.config
Configuration for the QueueStore.
QueueStoreConfig() - Constructor for class com.hazelcast.config.QueueStoreConfig
 
QueueStoreConfig(QueueStoreConfig) - Constructor for class com.hazelcast.config.QueueStoreConfig
 
QueueStoreFactory<T> - Interface in com.hazelcast.collection
Creates a new QueueStore.

R

RaftAlgorithmConfig - Class in com.hazelcast.config.cp
Configuration for Hazelcast's implementation of the Raft consensus algorithm
RaftAlgorithmConfig() - Constructor for class com.hazelcast.config.cp.RaftAlgorithmConfig
 
RaftAlgorithmConfig(RaftAlgorithmConfig) - Constructor for class com.hazelcast.config.cp.RaftAlgorithmConfig
 
ReachedMaxSizeException - Exception in com.hazelcast.map
Exception thrown when a write-behind MapStore rejects to accept a new element.
ReachedMaxSizeException(String) - Constructor for exception com.hazelcast.map.ReachedMaxSizeException
 
read() - Method in class com.hazelcast.config.ConfigStream
 
read(byte[]) - Method in class com.hazelcast.config.ConfigStream
 
read(byte[], int, int) - Method in class com.hazelcast.config.ConfigStream
 
read(byte[]) - Method in interface com.hazelcast.nio.serialization.ByteArraySerializer
Converts given byte array to object
read(ObjectDataInput) - Method in interface com.hazelcast.nio.serialization.StreamSerializer
Reads object from objectDataInputStream
read(byte[], Class) - Method in interface com.hazelcast.nio.serialization.TypedByteArrayDeserializer
Reads object from objectDataInputStream
read(ObjectDataInput, Class) - Method in interface com.hazelcast.nio.serialization.TypedStreamDeserializer
Reads object from objectDataInputStream
read(String, ValueCallback<T>) - Method in interface com.hazelcast.query.extractor.ValueReader
Read the value of the attribute specified by the path and returns the result via the callback.
read(String, ValueCollector<T>) - Method in interface com.hazelcast.query.extractor.ValueReader
Read the value of the attribute specified by the path and returns the result directly to the collector.
read(long) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Reads one item from the ringbuffer.
readBoolean(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
 
readBoolean(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readBooleanArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readBooleanArray(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
 
readBooleanArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readByte(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
 
readByte(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readByteArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readByteArray(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
 
readByteArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readChar(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
 
readChar(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readCharArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readCharArray(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
 
readCharArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readCount() - Method in interface com.hazelcast.ringbuffer.ReadResultSet
Returns the number of items that have been read before filtering.
readData(ObjectDataInput) - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.cluster.Address
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.AttributeConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.BitmapIndexOptions
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CollectionConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.DiscoveryConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.DurableExecutorConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.EntryListenerConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.EventJournalConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.EvictionConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.ExecutorConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.HotRestartConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.IndexConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.ItemListenerConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.ListenerConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.MapConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.MapStoreConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.MergePolicyConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.MerkleTreeConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.MultiMapConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.NearCacheConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.PermissionConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.PNCounterConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.PredicateConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.QueryCacheConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.QueueConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.QueueStoreConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.ReliableTopicConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.ReplicatedMapConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.RingbufferConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.TopicConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.WanBatchPublisherConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.WanConsumerConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.WanReplicationConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.WanReplicationRef
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.WanSyncConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.console.Echo
 
readData(ObjectDataInput) - Method in interface com.hazelcast.nio.serialization.DataSerializable
Reads fields from the input stream
readData(ObjectDataInput) - Method in class com.hazelcast.partition.PartitionAwareKey
 
readData(ObjectDataInput) - Method in class com.hazelcast.security.SimpleTokenCredentials
 
readData(ObjectDataInput) - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
readData(ObjectDataInput) - Method in class com.hazelcast.transaction.TransactionOptions
 
readData(ObjectDataInput) - Method in class com.hazelcast.version.MemberVersion
 
readData(ObjectDataInput) - Method in class com.hazelcast.version.Version
 
readDouble(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
 
readDouble(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readDoubleArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readDoubleArray(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
 
readDoubleArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readFactories(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
 
readFloat(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
 
readFloat(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readFloatArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readFloatArray(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
 
readFloatArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readGenericRecord(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
 
readGenericRecordArray(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
 
readInt(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
 
readInt(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readIntArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readIntArray(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
 
readIntArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readKeyValueTypes(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
 
readLine() - Method in interface com.hazelcast.console.LineReader
 
readListenerConfigurations(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
 
readLong(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
 
readLong(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readLongArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readLongArray(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
 
readLongArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readManyAsync(long, int, int, IFunction<E, Boolean>) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Reads a batch of items from the Ringbuffer.
readObject() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readObject(Class) - Method in interface com.hazelcast.nio.ObjectDataInput
 
readOne(long) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Reads one item from the Ringbuffer.
ReadOnly - Interface in com.hazelcast.core
Allows notifying Hazelcast that the processing unit implementing this interface will not do any modifications.
readPortable(PortableReader) - Method in interface com.hazelcast.nio.serialization.Portable
Read portable fields using PortableReader
readPortable(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readPortableArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
ReadResultSet<E> - Interface in com.hazelcast.ringbuffer
readShort(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
 
readShort(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readShortArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readShortArray(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
 
readShortArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readTenant(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
 
readUTF(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
 
readUTF(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readUTFArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readUTFArray(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
 
readUTFArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
RealmConfig - Class in com.hazelcast.config.security
Security realm represents the security configuration for part of the system (e.g.
RealmConfig() - Constructor for class com.hazelcast.config.security.RealmConfig
 
RealmConfigCallback - Class in com.hazelcast.security
This JAAS Callback is used to retrieve a RealmConfig from client or member configuration.
RealmConfigCallback(String) - Constructor for class com.hazelcast.security.RealmConfigCallback
 
RecentlyActiveSplitBrainProtectionConfigBuilder - Class in com.hazelcast.config
Builder for a SplitBrainProtectionConfig configured with RecentlyActiveSplitBrainProtectionFunction that considers members present in the context of a split brain protection if the last received heartbeat is within a recent window of time.
reducePermits(int) - Method in interface com.hazelcast.cp.ISemaphore
Reduces the number of available permits by the indicated amount.
refreshClientPermissions(Set<PermissionConfig>) - Method in interface com.hazelcast.security.SecurityService
Propagates changes made to client permissions to all members and reinitiates IPermissionPolicy with new configuration.
refreshPermissions(Set<PermissionConfig>) - Method in interface com.hazelcast.security.IPermissionPolicy
Replaces existing permissions with given set of permissions.
refreshPermissions(Set<PermissionConfig>) - Method in interface com.hazelcast.security.SecurityContext
 
regex(String, String) - Static method in class com.hazelcast.query.Predicates
Creates a regex predicate that will pass items if the given pattern matches the value stored under the given item attribute.
RegexConfigPatternMatcher - Class in com.hazelcast.config.matcher
This ConfigPatternMatcher uses Java regular expressions for matching.
RegexConfigPatternMatcher() - Constructor for class com.hazelcast.config.matcher.RegexConfigPatternMatcher
 
RegexConfigPatternMatcher(int) - Constructor for class com.hazelcast.config.matcher.RegexConfigPatternMatcher
 
RegionFactoryBeanDefinitionParser - Class in com.hazelcast.spring.hibernate
Parser for RegionFactory.
RegionFactoryBeanDefinitionParser() - Constructor for class com.hazelcast.spring.hibernate.RegionFactoryBeanDefinitionParser
 
release() - Method in interface com.hazelcast.cp.ISemaphore
Releases a permit and increases the number of available permits by one.
release(int) - Method in interface com.hazelcast.cp.ISemaphore
Releases the given number of permits and increases the number of available permits by that amount.
ReliableMessageListener<E> - Interface in com.hazelcast.topic
A MessageListener to better integrate with the reliable topic.
ReliableTopicConfig - Class in com.hazelcast.config
Configuration for a reliable ITopic.
ReliableTopicConfig() - Constructor for class com.hazelcast.config.ReliableTopicConfig
 
ReliableTopicConfig(String) - Constructor for class com.hazelcast.config.ReliableTopicConfig
Creates a new ReliableTopicConfig with default settings.
ReliableTopicConfig(ReliableTopicConfig) - Constructor for class com.hazelcast.config.ReliableTopicConfig
Creates a new ReliableTopicConfig by cloning an existing one.
ReliableTopicPermission - Class in com.hazelcast.security.permission
 
ReliableTopicPermission(String, String...) - Constructor for class com.hazelcast.security.permission.ReliableTopicPermission
 
remainingCapacity() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Returns the remaining capacity of the ringbuffer.
remove(Object) - Method in interface com.hazelcast.map.BaseMap
Removes the mapping for a key from this map if it is present.
remove(Object, Object) - Method in interface com.hazelcast.map.BaseMap
Removes the entry for a key only if currently mapped to a given value.
remove(Object) - Method in interface com.hazelcast.map.IMap
Removes the mapping for a key from this map if it is present.
remove(Object, Object) - Method in interface com.hazelcast.map.IMap
Removes the entry for a key only if currently mapped to a given value.
remove(Object, Object) - Method in interface com.hazelcast.multimap.BaseMultiMap
Removes the given key value pair from the multimap.
remove(Object) - Method in interface com.hazelcast.multimap.BaseMultiMap
Removes all the entries associated with the given key.
remove(Object, Object) - Method in interface com.hazelcast.multimap.MultiMap
Removes the given key value pair from the multimap.
remove(Object) - Method in interface com.hazelcast.multimap.MultiMap
Removes all the entries with the given key.
remove() - Method in class com.hazelcast.spi.merge.RingbufferMergeDataReadOnlyIterator
 
remove(E) - Method in interface com.hazelcast.transaction.TransactionalList
Removes an item from the transactional list.
remove(Object) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.remove(Object).
remove(Object, Object) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.remove(Object, Object).
remove(Object, Object) - Method in interface com.hazelcast.transaction.TransactionalMultiMap
Removes the given key value pair from the multimap.
remove(Object) - Method in interface com.hazelcast.transaction.TransactionalMultiMap
Removes all the entries associated with the given key.
remove(E) - Method in interface com.hazelcast.transaction.TransactionalSet
Remove item from transactional set.
removeAll(Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
Removes all entries which match with the supplied predicate.
removeAsync(K) - Method in interface com.hazelcast.cache.ICache
Asynchronously removes the mapping for a key from this cache if it is present.
removeAsync(K, V) - Method in interface com.hazelcast.cache.ICache
Asynchronously removes the mapping for the given key if and only if the currently mapped value equals to the value of oldValue.
removeAsync(K) - Method in interface com.hazelcast.map.IMap
Asynchronously removes the given key, returning an CompletionStage on which the caller can register further computation stages to be invoked upon remove operation completion or block waiting for the operation to complete using one of blocking ways to wait on CompletionStage.toCompletableFuture().
removeAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
 
removeCache(String, boolean) - Method in interface com.hazelcast.cache.HazelcastCacheManager
Removes the associated cache with the given cache name.
removeCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.config.AbstractCacheConfig
Remove a configuration for a CacheEntryListener.
removeCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in interface com.hazelcast.config.CacheConfiguration
Remove a configuration for a CacheEntryListener.
removeClientListener(UUID) - Method in interface com.hazelcast.client.ClientService
Removes a ClientListener.
removeCounter(String) - Method in class com.hazelcast.wan.WanEventCounters
Removes the counter for the given dataStructureName.
removeCPMember(UUID) - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Removes the given unreachable CP member from the active CP members list and all CP groups it belongs to.
removeDistributedObjectListener(UUID) - Method in interface com.hazelcast.core.HazelcastInstance
Removes the specified Distributed Object listener.
removeEntryListener(UUID) - Method in interface com.hazelcast.map.IMap
Removes the specified entry listener.
removeEntryListener(UUID) - Method in interface com.hazelcast.map.QueryCache
 
removeEntryListener(UUID) - Method in interface com.hazelcast.multimap.MultiMap
Removes the specified entry listener.
removeEntryListener(UUID) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Removes the specified entry listener.
removeGroupAvailabilityListener(UUID) - Method in interface com.hazelcast.cp.CPSubsystem
Removes CPGroupAvailabilityListener registration.
removeInterceptor(String) - Method in interface com.hazelcast.map.IMap
Removes the given interceptor for this map, so it will not intercept operations anymore.
removeItemListener(UUID) - Method in interface com.hazelcast.collection.ICollection
Removes the specified item listener.
removeLifecycleListener(UUID) - Method in interface com.hazelcast.core.LifecycleService
Removes a lifecycle listener.
removeLogListener(LogListener) - Method in interface com.hazelcast.logging.LoggingService
 
removeMember(Member) - Method in interface com.hazelcast.spi.partitiongroup.MemberGroup
 
removeMembershipListener(UUID) - Method in interface com.hazelcast.cluster.Cluster
Removes the specified MembershipListener.
removeMembershipListener(UUID) - Method in interface com.hazelcast.cp.CPSubsystem
Removes membership listener registration.
removeMessageListener(UUID) - Method in interface com.hazelcast.topic.ITopic
Stops receiving messages for the given message listener.
removeMigrationListener(UUID) - Method in interface com.hazelcast.partition.PartitionService
Removes a MigrationListener.
removePartitionLostListener(UUID) - Method in interface com.hazelcast.cache.ICache
Removes the specified cache partition lost listener.
removePartitionLostListener(UUID) - Method in interface com.hazelcast.map.IMap
Removes the specified map partition lost listener.
removePartitionLostListener(UUID) - Method in interface com.hazelcast.partition.PartitionService
Removes a PartitionLostListener.
removeProperty(String) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
replace(K, V, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Atomically replaces the currently assigned value for the given key with the specified newValue if and only if the currently assigned value equals the value of oldValue using a custom ExpiryPolicy.
replace(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Atomically replaces the assigned value of the given key by the specified value using a custom ExpiryPolicy.
replace(K, V) - Method in interface com.hazelcast.map.BaseMap
Replaces the entry for a key only if it is currently mapped to some value.
replace(K, V, V) - Method in interface com.hazelcast.map.BaseMap
Replaces the entry for a key only if currently mapped to a given value.
replace(K, V, V) - Method in interface com.hazelcast.map.IMap
Replaces the entry for a key only if currently mapped to a given value.
replace(K, V) - Method in interface com.hazelcast.map.IMap
Replaces the entry for a key only if it is currently mapped to some value.
replace(K, V) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.replace(Object, Object).
replace(K, V, V) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.replace(Object, Object, Object).
replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.hazelcast.map.IMap
replaceAsync(K, V) - Method in interface com.hazelcast.cache.ICache
Asynchronously replaces the assigned value of the given key by the specified value.
replaceAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Asynchronously replaces the assigned value of the given key by the specified value using a custom ExpiryPolicy.
replaceAsync(K, V, V) - Method in interface com.hazelcast.cache.ICache
Asynchronously replaces the currently assigned value for the given key with the specified newValue if and only if the currently assigned value equals the value of oldValue.
replaceAsync(K, V, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Asynchronously replaces the currently assigned value for the given key with the specified newValue if and only if the currently assigned value equals the value of oldValue using a custom ExpiryPolicy.
replaceVariables(Node) - Method in class com.hazelcast.config.AbstractYamlConfigBuilder
 
replicaMigrationCompleted(ReplicaMigrationEvent) - Method in interface com.hazelcast.partition.MigrationListener
Called when a partition replica migration is completed successfully.
ReplicaMigrationEvent - Interface in com.hazelcast.partition
An event fired when a partition replica migration completes or fails.
replicaMigrationFailed(ReplicaMigrationEvent) - Method in interface com.hazelcast.partition.MigrationListener
Called when a partition replica migration is failed.
ReplicatedMap<K,V> - Interface in com.hazelcast.replicatedmap
A ReplicatedMap is a map-like data structure with weak consistency and values locally stored on every node of the cluster.
ReplicatedMapCantBeCreatedOnLiteMemberException - Exception in com.hazelcast.replicatedmap
Thrown when HazelcastInstance.getReplicatedMap(String) is invoked on a lite member.
ReplicatedMapCantBeCreatedOnLiteMemberException(Address) - Constructor for exception com.hazelcast.replicatedmap.ReplicatedMapCantBeCreatedOnLiteMemberException
 
ReplicatedMapCantBeCreatedOnLiteMemberException(String) - Constructor for exception com.hazelcast.replicatedmap.ReplicatedMapCantBeCreatedOnLiteMemberException
 
ReplicatedMapConfig - Class in com.hazelcast.config
Contains the configuration for an ReplicatedMap
ReplicatedMapConfig() - Constructor for class com.hazelcast.config.ReplicatedMapConfig
 
ReplicatedMapConfig(String) - Constructor for class com.hazelcast.config.ReplicatedMapConfig
Creates a ReplicatedMapConfig with the given name.
ReplicatedMapConfig(ReplicatedMapConfig) - Constructor for class com.hazelcast.config.ReplicatedMapConfig
 
ReplicatedMapPermission - Class in com.hazelcast.security.permission
 
ReplicatedMapPermission(String, String...) - Constructor for class com.hazelcast.security.permission.ReplicatedMapPermission
 
reset() - Method in class com.hazelcast.config.ConfigStream
 
reset() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Wipes and resets the whole CP Subsystem state and initializes it as if the Hazelcast cluster is starting up initially.
reset() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Resets the observed state by this PN counter.
reset() - Method in interface com.hazelcast.query.PagingPredicate
Resets for reuse.
reset() - Method in interface com.hazelcast.wan.WanPublisher
Resets the publisher (e.g.
RESPONSE_THREAD_COUNT - Static variable in class com.hazelcast.client.properties.ClientProperty
The number of response threads.
RESPONSE_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
The number of threads that process responses.
RESPONSE_THREAD_DYNAMIC - Static variable in class com.hazelcast.client.properties.ClientProperty
Enabled dynamic switching between processing responses on the io threads and offloading the response threads.
ResponseAlreadySentException - Exception in com.hazelcast.spi.exception
A HazelcastException indicating that there is some kind of system error causing a response to be send multiple times for some operation.
ResponseAlreadySentException() - Constructor for exception com.hazelcast.spi.exception.ResponseAlreadySentException
 
ResponseAlreadySentException(String) - Constructor for exception com.hazelcast.spi.exception.ResponseAlreadySentException
 
RestApiConfig - Class in com.hazelcast.config
This class allows to control which parts of Hazelcast REST API will be enabled.
RestApiConfig() - Constructor for class com.hazelcast.config.RestApiConfig
 
RestEndpointGroup - Enum in com.hazelcast.config
Enum of REST endpoint groups.
RestServerEndpointConfig - Class in com.hazelcast.config
Server socket endpoint config specialized for REST service Allows configuring access to REST groups similar to RestApiConfig
RestServerEndpointConfig() - Constructor for class com.hazelcast.config.RestServerEndpointConfig
 
results() - Method in class com.hazelcast.core.Pipelining
Returns the results.
retrieveAndDisposeResult(long) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Retrieves and disposes the result with the given taskId
retrieveInitialSequence() - Method in interface com.hazelcast.topic.ReliableMessageListener
Retrieves the initial sequence from which this ReliableMessageListener should start.
retrieveResult(long) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Retrieves the result with the given taskId
RetryableException - Interface in com.hazelcast.spi.exception
Marker interface for exceptions to indicate that an operation can be retried.
RetryableHazelcastException - Exception in com.hazelcast.spi.exception
A 'marker' exception that indicates that an operation can be retried.
RetryableHazelcastException() - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
 
RetryableHazelcastException(String) - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
 
RetryableHazelcastException(String, Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
 
RetryableHazelcastException(Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
 
RetryableIOException - Exception in com.hazelcast.spi.exception
A IOException indicating that there was a IO failure, but it can be retried.
RetryableIOException() - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
 
RetryableIOException(String) - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
 
RetryableIOException(String, Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
 
RetryableIOException(Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
 
reversed() - Method in interface com.hazelcast.function.ComparatorEx
Serializable variant of java.util.Comparator#reversed()
reverseOrder() - Static method in interface com.hazelcast.function.ComparatorEx
Serializable variant of java.util.Comparator#reverseOrder().
Ringbuffer<E> - Interface in com.hazelcast.ringbuffer
A Ringbuffer is a data structure where the content is stored in a ring-like structure.
RingbufferConfig - Class in com.hazelcast.config
Contains the configuration for the Ringbuffer.
RingbufferConfig() - Constructor for class com.hazelcast.config.RingbufferConfig
 
RingbufferConfig(String) - Constructor for class com.hazelcast.config.RingbufferConfig
Creates a RingbufferConfig with the provided name.
RingbufferConfig(RingbufferConfig) - Constructor for class com.hazelcast.config.RingbufferConfig
Clones a RingbufferConfig
RingbufferConfig(String, RingbufferConfig) - Constructor for class com.hazelcast.config.RingbufferConfig
Creates a new RingbufferConfig by cloning an existing config and overriding the name.
RingbufferMergeData - Class in com.hazelcast.spi.merge
A ringbuffer implementation holding data involved in split-brain healing.
RingbufferMergeData(int) - Constructor for class com.hazelcast.spi.merge.RingbufferMergeData
 
RingbufferMergeData(Ringbuffer<Object>) - Constructor for class com.hazelcast.spi.merge.RingbufferMergeData
 
RingbufferMergeDataReadOnlyIterator<E> - Class in com.hazelcast.spi.merge
Read-only iterator over items in a provided RingbufferMergeData.
RingBufferPermission - Class in com.hazelcast.security.permission
 
RingBufferPermission(String, String...) - Constructor for class com.hazelcast.security.permission.RingBufferPermission
 
RingbufferStore<T> - Interface in com.hazelcast.ringbuffer
Ringbuffer store makes a ring buffer backed by a central data store; such as database, disk, etc.
RingbufferStoreConfig - Class in com.hazelcast.config
Configuration for the RingbufferStore.
RingbufferStoreConfig() - Constructor for class com.hazelcast.config.RingbufferStoreConfig
 
RingbufferStoreConfig(RingbufferStoreConfig) - Constructor for class com.hazelcast.config.RingbufferStoreConfig
 
RingbufferStoreFactory<T> - Interface in com.hazelcast.ringbuffer
Creates a new RingbufferStore.
rollbackTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
Rollback of the current transaction.
RuntimeInterruptedException - Exception in com.hazelcast.core
An unchecked version of InterruptedException.
RuntimeInterruptedException() - Constructor for exception com.hazelcast.core.RuntimeInterruptedException
 
RuntimeInterruptedException(String) - Constructor for exception com.hazelcast.core.RuntimeInterruptedException
 

S

save(Map<K, V>) - Method in interface com.hazelcast.scheduledexecutor.StatefulTask
Task callback to capture its state on the provided map.
saveCurrentTenant(DestroyEventContext) - Method in interface com.hazelcast.spi.tenantcontrol.TenantControlFactory
To be called from the application's thread to connect a Hazelcast object with a particular tenant, e.g.
schedule(Runnable, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay.
schedule(Callable<V>, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay.
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period.
ScheduledExecutorConfig - Class in com.hazelcast.config
Configuration options for the IScheduledExecutorService.
ScheduledExecutorConfig() - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
 
ScheduledExecutorConfig(String) - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
 
ScheduledExecutorConfig(String, int, int, int, boolean) - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
 
ScheduledExecutorConfig(String, int, int, int, String, MergePolicyConfig, ScheduledExecutorConfig.CapacityPolicy, boolean) - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
 
ScheduledExecutorConfig(ScheduledExecutorConfig) - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
 
ScheduledExecutorConfig.CapacityPolicy - Enum in com.hazelcast.config
Capacity policy options
ScheduledExecutorPermission - Class in com.hazelcast.security.permission
 
ScheduledExecutorPermission(String, String...) - Constructor for class com.hazelcast.security.permission.ScheduledExecutorPermission
 
ScheduledTaskHandler - Class in com.hazelcast.scheduledexecutor
Resource handler pointing to a IScheduledFuture.
ScheduledTaskHandler() - Constructor for class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
 
ScheduledTaskStatistics - Interface in com.hazelcast.scheduledexecutor
Statistics and timing info for a IScheduledFuture accessible through IScheduledFuture.getStats()
scheduleOnAllMembers(Runnable, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay on all cluster Members.
scheduleOnAllMembers(Callable<V>, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay on all cluster Members.
scheduleOnAllMembersAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period on all cluster Members.
scheduleOnKeyOwner(Runnable, Object, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay on the partition owner of the given key.
scheduleOnKeyOwner(Callable<V>, Object, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay on the partition owner of the given key.
scheduleOnKeyOwnerAtFixedRate(Runnable, Object, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period on the partition owner of the given key.
scheduleOnMember(Runnable, Member, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay at the given Member.
scheduleOnMember(Callable<V>, Member, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay at the given Member.
scheduleOnMemberAtFixedRate(Runnable, Member, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period at the given Member.
scheduleOnMembers(Runnable, Collection<Member>, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay on all Members given.
scheduleOnMembers(Callable<V>, Collection<Member>, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay on all Members given.
scheduleOnMembersAtFixedRate(Runnable, Collection<Member>, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period on all Members given.
schemaValidation(Document) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
SEARCH_DYNAMIC_CONFIG_FIRST - Static variable in class com.hazelcast.spi.properties.ClusterProperty
By default, search for data structures config is performed within static configuration first: Exact match in static config Wildcard match in static config Exact match in dynamic config Wildcard match in dynamic config Fallback to default But sometimes it makes sense to perform search within dynamic configs first.
SecureCallable<V> - Interface in com.hazelcast.security
A secure callable that runs in a sandbox.
SecureStoreConfig - Class in com.hazelcast.config
Abstract Secure Store configuration class.
SecureStoreConfig() - Constructor for class com.hazelcast.config.SecureStoreConfig
 
SecurityConfig - Class in com.hazelcast.config
Contains configuration for Security
SecurityConfig() - Constructor for class com.hazelcast.config.SecurityConfig
 
SecurityContext - Interface in com.hazelcast.security
SecurityContext is responsible for managing lifecycle of security object such as ICredentialsFactory, IPermissionPolicy etc, to creating LoginContextes for member and client authentications and checking permissions for client operations.
SecurityInterceptor - Interface in com.hazelcast.security
This interface allows to intercept requests which were produced by an API call like map.put, queue.offer...
SecurityInterceptorConfig - Class in com.hazelcast.config
This class is used to configure SecurityInterceptor
SecurityInterceptorConfig() - Constructor for class com.hazelcast.config.SecurityInterceptorConfig
 
SecurityInterceptorConfig(String) - Constructor for class com.hazelcast.config.SecurityInterceptorConfig
 
SecurityInterceptorConfig(SecurityInterceptor) - Constructor for class com.hazelcast.config.SecurityInterceptorConfig
 
securityRealmGenerator(ConfigXmlGenerator.XmlGenerator, String, RealmConfig) - Method in class com.hazelcast.config.ConfigXmlGenerator
 
SecurityService - Interface in com.hazelcast.security
Provides necessary methods to initiate security related config changes.
select(Member) - Method in interface com.hazelcast.cluster.MemberSelector
Decides if the given member will be part of an operation or not.
self() - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
 
self() - Method in class com.hazelcast.config.AuditlogConfig
 
self() - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
 
self() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
 
self() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
self() - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
 
self() - Method in class com.hazelcast.config.SSLConfig
 
SemaphoreConfig - Class in com.hazelcast.config.cp
Contains configuration options for CP ISemaphore
SemaphoreConfig() - Constructor for class com.hazelcast.config.cp.SemaphoreConfig
 
SemaphoreConfig(String) - Constructor for class com.hazelcast.config.cp.SemaphoreConfig
 
SemaphoreConfig(String, boolean, int) - Constructor for class com.hazelcast.config.cp.SemaphoreConfig
 
SemaphorePermission - Class in com.hazelcast.security.permission
 
SemaphorePermission(String, String...) - Constructor for class com.hazelcast.security.permission.SemaphorePermission
 
SEQUENCE_UNAVAILABLE - Static variable in interface com.hazelcast.ringbuffer.ReadResultSet
Value returned from methods returning a sequence number when the information is not available (e.g.
SERIALIZATION_VERSION - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Hazelcast serialization version.
SerializationConfig - Class in com.hazelcast.config
Contains the serialization configuration of HazelcastInstance.
SerializationConfig() - Constructor for class com.hazelcast.config.SerializationConfig
 
SerializationConfig(SerializationConfig) - Constructor for class com.hazelcast.config.SerializationConfig
 
serializationService - Variable in class com.hazelcast.config.AbstractCacheConfig
 
Serializer - Interface in com.hazelcast.nio.serialization
Base interface of custom serialization interfaces
SerializerConfig - Class in com.hazelcast.config
Contains the serialization configuration for a particular class.
SerializerConfig() - Constructor for class com.hazelcast.config.SerializerConfig
 
SerializerConfig(SerializerConfig) - Constructor for class com.hazelcast.config.SerializerConfig
 
SerializerHook<T> - Interface in com.hazelcast.nio.serialization
This interface is used to automatically register serializers from external Hazelcast or user modules.
Both types of Serializers are supported (StreamSerializer and ByteArraySerializer).
SERVER_CACHING_PROVIDER - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
Deprecated.
ServerSocketEndpointConfig - Class in com.hazelcast.config
Endpoint configuration that defines a listening side (server)
ServerSocketEndpointConfig() - Constructor for class com.hazelcast.config.ServerSocketEndpointConfig
 
ServiceConfig - Class in com.hazelcast.config
Configuration for a single service.
ServiceConfig() - Constructor for class com.hazelcast.config.ServiceConfig
 
ServiceNotFoundException - Exception in com.hazelcast.spi.exception
A HazelcastException that indicates that a requested service is not exist.
ServiceNotFoundException(String) - Constructor for exception com.hazelcast.spi.exception.ServiceNotFoundException
 
set(long) - Method in interface com.hazelcast.cp.IAtomicLong
Atomically sets the given value.
set(E) - Method in interface com.hazelcast.cp.IAtomicReference
Atomically sets the given value.
set(K, V) - Method in interface com.hazelcast.map.BaseMap
Associates the specified value with the specified key in this map.
set(K, V) - Method in interface com.hazelcast.map.IMap
Puts an entry into this map without returning the old value (which is more efficient than put()).
set(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Puts an entry into this map with a given TTL (time to live) value, without returning the old value (which is more efficient than put()).
set(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Puts an entry into this map with a given TTL (time to live) value and max idle time value without returning the old value (which is more efficient than put()).
set(long, Object) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Sets the item at the given sequence.
set(K, V) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.set(Object, Object).
setAcknowledgeType(WanAcknowledgeType) - Method in class com.hazelcast.config.WanBatchPublisherConfig
Sets the strategy for when the target cluster should acknowledge that a WAN event batch has been processed.
setActions(Set<String>) - Method in class com.hazelcast.config.PermissionConfig
 
setAddress(String) - Method in class com.hazelcast.config.VaultSecureStoreConfig
Sets the Vault server address.
setAddresses(List<String>) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Sets given addresses as candidate address list that client will use to establish initial connection
setAdvancedNetworkConfig(AdvancedNetworkConfig) - Method in class com.hazelcast.config.Config
 
setAlgorithm(String) - Method in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
Sets the encryption algorithm, such as AES/CBC/PKCS5Padding.
setAliasedDiscoveryConfigs(List<DiscoveryStrategyConfig>) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
setAll(Map<? extends K, ? extends V>) - Method in interface com.hazelcast.map.IMap
Copies all of the mappings from the specified map to this map without loading non-existing elements from map store (which is more efficient than putAll()).
setAllAsync(Map<? extends K, ? extends V>) - Method in interface com.hazelcast.map.IMap
Asynchronously copies all of the mappings from the specified map to this map without loading non-existing elements from map store.
setAllocatorType(NativeMemoryConfig.MemoryAllocatorType) - Method in class com.hazelcast.config.NativeMemoryConfig
Sets the NativeMemoryConfig.MemoryAllocatorType to be used while allocating native memory.
setAllowedFutureMillis(long) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Sets how far to the future is the generator allowed to go to generate IDs without blocking.
setAllowUnsafe(boolean) - Method in class com.hazelcast.config.SerializationConfig
Unsafe, it is not public api of java.
setAppendRequestBackoffTimeoutInMillis(long) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
setAppendRequestMaxEntryCount(int) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
setApplicationContext(ApplicationContext) - Method in class com.hazelcast.spring.context.SpringManagedContext
 
setAsync(long) - Method in interface com.hazelcast.cp.IAtomicLong
Atomically sets the given value.
setAsync(E) - Method in interface com.hazelcast.cp.IAtomicReference
Atomically sets the given value.
setAsync(K, V) - Method in interface com.hazelcast.map.IMap
Asynchronously puts the given key and value.
setAsync(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Asynchronously puts an entry into this map with a given TTL (time to live) value, without returning the old value (which is more efficient than put()).
setAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Asynchronously puts an entry into this map with a given TTL (time to live) value and max idle time value without returning the old value (which is more efficient than put()).
setAsyncBackupCount(int) - Method in class com.hazelcast.config.CacheConfig
Sets the number of asynchronous backups for this ICache.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the number of asynchronous backups for this ICache.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Sets the number of synchronous backups.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.CollectionConfig
Sets the number of asynchronous backups.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.MapConfig
Sets the number of asynchronous backups.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfig
Sets the number of asynchronous backups.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.QueueConfig
Sets the number of asynchronous backups.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.RingbufferConfig
Sets the number of asynchronous backups.
setAsyncFillup(boolean) - Method in class com.hazelcast.config.ReplicatedMapConfig
True if the replicated map is available for reads before the initial replication is completed, false otherwise.
setAsyncStart(boolean) - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
Set true for non blocking HazelcastClient.newHazelcastClient().
setAttribute(String, String) - Method in class com.hazelcast.config.MemberAttributeConfig
 
setAttribute(String) - Method in interface com.hazelcast.query.PredicateBuilder
 
setAttributeConfigs(List<AttributeConfig>) - Method in class com.hazelcast.config.MapConfig
 
setAttributes(List<String>) - Method in class com.hazelcast.config.IndexConfig
Sets index attributes.
setAttributes(Map<String, String>) - Method in class com.hazelcast.config.MemberAttributeConfig
 
setAuditlogConfig(AuditlogConfig) - Method in class com.hazelcast.config.Config
 
setAutoDetectionConfig(AutoDetectionConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Defines the Auto Detection configuration.
setAutoDetectionConfig(AutoDetectionConfig) - Method in class com.hazelcast.config.JoinConfig
 
setAutoDetectionEnabled(boolean) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
setAutoRemoveStaleData(boolean) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets whether or not automatically removal of stale Hot Restart data is enabled.
setAwsConfig(AwsConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Sets configuration to connect nodes in AWS environment.
setAwsConfig(AwsConfig) - Method in class com.hazelcast.config.JoinConfig
 
setAwsConfig(AwsConfig) - Method in class com.hazelcast.config.WanBatchPublisherConfig
Sets the AwsConfig used by the discovery mechanism for this WAN publisher.
setAzureConfig(AzureConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Sets configuration to connect nodes in Azure environment.
setAzureConfig(AzureConfig) - Method in class com.hazelcast.config.JoinConfig
 
setAzureConfig(AzureConfig) - Method in class com.hazelcast.config.WanBatchPublisherConfig
Sets the AzureConfig used by the discovery mechanism for this WAN publisher.
setBackupAckToClientEnabled(boolean) - Method in class com.hazelcast.client.config.ClientConfig
This feature reduces number of hops and increase performance for smart clients.
setBackupCount(int) - Method in class com.hazelcast.config.CacheConfig
Sets the number of synchronous backups.
setBackupCount(int) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the number of synchronous backups for this ICache.
setBackupCount(int) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Sets the number of synchronous backups.
setBackupCount(int) - Method in class com.hazelcast.config.CollectionConfig
Sets the number of synchronous backups for this collection.
setBackupCount(int) - Method in class com.hazelcast.config.MapConfig
Number of synchronous backups.
setBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfig
Sets the number of synchronous backups.
setBackupCount(int) - Method in class com.hazelcast.config.QueueConfig
Sets the number of synchronous backups for this queue.
setBackupCount(int) - Method in class com.hazelcast.config.RingbufferConfig
Sets the number of synchronous backups.
setBackupDir(File) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets base directory for all Hot Restart stores.
setBaseDir(File) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets the base directory for persisting CP data.
setBaseDir(File) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets base directory for all Hot Restart stores.
setBatchMaxDelayMillis(int) - Method in class com.hazelcast.config.WanBatchPublisherConfig
Sets 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.
setBatchPublisherConfigs(List<WanBatchPublisherConfig>) - Method in class com.hazelcast.config.WanReplicationConfig
Sets the list of WAN publisher configurations using the built-in batching WAN implementation for this WAN replication.
setBatchSize(int) - Method in class com.hazelcast.config.MergePolicyConfig
Sets the batch size, which will be used to determine the number of entries to be sent in a merge operation.
setBatchSize(int) - Method in class com.hazelcast.config.QueryCacheConfig
Sets the batch size which will be used to determine number of events to be sent in a batch to QueryCache
setBatchSize(int) - Method in class com.hazelcast.config.WanBatchPublisherConfig
Sets the maximum batch size that can be sent to target cluster.
setBinary(boolean) - Method in class com.hazelcast.config.MultiMapConfig
Enables or disables binary (serialized) form for this MultiMap.
setBitmapIndexOptions(BitmapIndexOptions) - Method in class com.hazelcast.config.IndexConfig
Sets bitmap index options of this index config to the given ones.
setBitsNodeId(int) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Sets the bit-length of node id component.
setBitsSequence(int) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Sets the bit-length of the sequence component.
setBlacklist(ClassFilter) - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
setBlacklistedPrefixes(String) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Comma-separated list of class prefixes which will never be loaded remotely.
setBufferSize(int) - Method in class com.hazelcast.client.config.SocketOptions
Sets the SO_SNDBUF and SO_RCVBUF options to the specified value in KB
setBufferSize(int) - Method in class com.hazelcast.config.QueryCacheConfig
Sets the maximum number of events which can be stored in a buffer of partition.
setByteOrder(ByteOrder) - Method in class com.hazelcast.config.SerializationConfig
Note that configuring use native byte order as enabled will override the byte order set by this method.
setCacheConfigs(Map<String, CacheSimpleConfig>) - Method in class com.hazelcast.config.Config
Sets the map of cache configurations, mapped by config name.
setCacheDeserializedValues(CacheDeserializedValues) - Method in class com.hazelcast.config.MapConfig
Configure de-serialized value caching.
setCacheEntryEventFilterFactory(String) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
setCacheEntryListenerFactory(String) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
setCacheEntryListeners(List<CacheSimpleEntryListenerConfig>) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets a list of CacheSimpleEntryListenerConfig for this ICache.
setCacheLoader(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Set classname of a class to be used as CacheLoader.
setCacheLoaderFactory(Factory<? extends CacheLoader<K, V>>) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setCacheLoaderFactory(Factory<? extends CacheLoader<K, V>>) - Method in interface com.hazelcast.config.CacheConfiguration
Set the CacheLoader factory.
setCacheLoaderFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the factory for this CacheLoader.
setCacheLocalEntries(boolean) - Method in class com.hazelcast.config.NearCacheConfig
Sets if local entries are also cached in the Near Cache.
setCacheOptions(String) - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
Set the cache ead-timeout params
setCacheWriter(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Set classname of a class to be used as CacheWriter.
setCacheWriterFactory(Factory<? extends CacheWriter<? super K, ? super V>>) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setCacheWriterFactory(Factory<? extends CacheWriter<? super K, ? super V>>) - Method in interface com.hazelcast.config.CacheConfiguration
Set the CacheWriter factory.
setCacheWriterFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the factory for this CacheWriter.
setCapacity(int) - Method in class com.hazelcast.config.DurableExecutorConfig
Sets the ring buffer capacity of the executor task.
setCapacity(int) - Method in class com.hazelcast.config.EventJournalConfig
Sets the capacity of the event journal.
setCapacity(int) - Method in class com.hazelcast.config.RingbufferConfig
Sets the capacity of the ringbuffer.
setCapacity(int) - Method in class com.hazelcast.config.ScheduledExecutorConfig
Sets the capacity of the executor The capacity represents the maximum number of tasks that a scheduler can have at any given point in time per partition.
setCapacityPolicy(ScheduledExecutorConfig.CapacityPolicy) - Method in class com.hazelcast.config.ScheduledExecutorConfig
Set the capacity policy for the configured capacity value To prevent any undesirable data-loss, capacity is ignored during partition migrations, the count is updated accordingly, however the rejection is not enforced.
setCardinalityEstimatorConfigs(Map<String, CardinalityEstimatorConfig>) - Method in class com.hazelcast.config.Config
Sets the map of cardinality estimator configurations, mapped by config name.
setCheckClassDefErrors(boolean) - Method in class com.hazelcast.config.SerializationConfig
When enabled, serialization system will check for class definitions error at start and throw an Serialization Exception with error definition.
setClass(Class<? extends Serializer>) - Method in class com.hazelcast.config.SerializerConfig
Sets the class of the serializer implementation.
setClassCacheMode(UserCodeDeploymentConfig.ClassCacheMode) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Configure caching of classes loaded from remote members.
setClassDefinitions(Set<ClassDefinition>) - Method in class com.hazelcast.config.SerializationConfig
 
setClasses(Collection<String>) - Method in class com.hazelcast.config.ClassFilter
 
setClassLoader(ClassLoader) - Method in class com.hazelcast.client.config.ClientConfig
Sets the classLoader which is used by serialization and listener configuration
setClassLoader(ClassLoader) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setClassLoader(ClassLoader) - Method in class com.hazelcast.config.Config
Sets the class-loader to be used during de-serialization and as context class-loader of Hazelcast internal threads.
setClassName(String) - Method in class com.hazelcast.client.config.ProxyFactoryConfig
Sets class name of proxy factory
setClassName(String) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
Sets the name of the class implementing WanPublisher.
setClassName(String) - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
setClassName(String) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
setClassName(String) - Method in class com.hazelcast.config.GlobalSerializerConfig
 
setClassName(String) - Method in class com.hazelcast.config.ListenerConfig
Sets the class name of the EventListener.
setClassName(String) - Method in class com.hazelcast.config.LoginModuleConfig
 
setClassName(String) - Method in class com.hazelcast.config.MapStoreConfig
Sets the name for the MapStore implementation class
setClassName(String) - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
setClassName(String) - Method in class com.hazelcast.config.PermissionPolicyConfig
 
setClassName(String) - Method in class com.hazelcast.config.PredicateConfig
Sets the class name of the Predicate.
setClassName(String) - Method in class com.hazelcast.config.QueueStoreConfig
Sets the class name of the queue store implementation to be used when instantiating the queue store.
setClassName(String) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
setClassName(String) - Method in class com.hazelcast.config.SecurityInterceptorConfig
 
setClassName(String) - Method in class com.hazelcast.config.SerializerConfig
Sets the class name of the serializer implementation.
setClassName(String) - Method in class com.hazelcast.config.ServiceConfig
 
setClassName(String) - Method in class com.hazelcast.config.SocketInterceptorConfig
Sets the name for the SocketInterceptor implementation class.
setClassName(String) - Method in class com.hazelcast.config.WanBatchPublisherConfig
 
setClassName(String) - Method in class com.hazelcast.config.WanConsumerConfig
Sets the fully qualified class name of the class implementing WanConsumer.
setClassName(String) - Method in class com.hazelcast.config.WanCustomPublisherConfig
 
setClassNames(List<String>) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
setClientBlockUnmappedActions(boolean) - Method in class com.hazelcast.config.SecurityConfig
Block or allow actions, submitted as tasks in an Executor from clients and have no permission mappings.
setClientConfigs(List<ClientConfig>) - Method in class com.hazelcast.client.config.ClientFailoverConfig
Sets the configured list of alternative client configurations.
setClientEndpointConfig(ServerSocketEndpointConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
Sets the server socket endpoint config for CLIENT protocol.
setClientIcmpPingConfig(ClientIcmpPingConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
ICMP ping is used to detect if machine that a remote hazelcast member runs on alive or not
setClientPermissionConfigs(Set<PermissionConfig>) - Method in class com.hazelcast.config.SecurityConfig
 
setClientPolicyConfig(PermissionPolicyConfig) - Method in class com.hazelcast.config.SecurityConfig
 
setClientRealm(String) - Method in class com.hazelcast.config.SecurityConfig
 
setClientRealmConfig(String, RealmConfig) - Method in class com.hazelcast.config.SecurityConfig
 
setCloudConfig(ClientCloudConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
setClusterConnectTimeoutMillis(long) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
 
setClusterDataRecoveryPolicy(HotRestartClusterDataRecoveryPolicy) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets the policy to be used when the cluster is started
setClusterName(String) - Method in class com.hazelcast.client.config.ClientConfig
 
setClusterName(String) - Method in class com.hazelcast.config.Config
Sets the cluster name uniquely identifying the hazelcast cluster.
setClusterName(String) - Method in class com.hazelcast.config.WanBatchPublisherConfig
Sets the cluster name used as an endpoint group password for authentication on the target endpoint.
setCoalesce(boolean) - Method in class com.hazelcast.config.QueryCacheConfig
Set true to enable coalescing, otherwise set false.
setCollectionFrequencySeconds(int) - Method in class com.hazelcast.config.BaseMetricsConfig
Sets the metrics collection frequency in seconds.
setCommitIndexAdvanceCountToSnapshot(int) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
setComparator(EvictionPolicyComparator) - Method in class com.hazelcast.config.EvictionConfig
Sets the instance of the configured EvictionPolicyComparator implementation.
setComparatorClassName(String) - Method in class com.hazelcast.config.EvictionConfig
Sets the class name of the configured EvictionPolicyComparator implementation.
SetConfig - Class in com.hazelcast.config
Contains the configuration for an ISet.
SetConfig() - Constructor for class com.hazelcast.config.SetConfig
 
SetConfig(String) - Constructor for class com.hazelcast.config.SetConfig
 
SetConfig(SetConfig) - Constructor for class com.hazelcast.config.SetConfig
 
setConfigClassLoader(ClassLoader) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
setConfigObject(Object) - Method in class com.hazelcast.config.ServiceConfig
 
setConfigPatternMatcher(ConfigPatternMatcher) - Method in class com.hazelcast.client.config.ClientConfig
Sets the pattern matcher which is used to match item names to configuration objects.
setConfigPatternMatcher(ConfigPatternMatcher) - Method in class com.hazelcast.config.Config
Sets the pattern matcher which is used to match item names to configuration objects.
setConfigurationFile(File) - Method in class com.hazelcast.config.Config
Sets the File from which this configuration has been retrieved and created.
setConfigurationUrl(URL) - Method in class com.hazelcast.config.Config
Sets the URL from which this configuration has been retrieved and created.
setConnectionRetryConfig(ConnectionRetryConfig) - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
Connection Retry Config is controls the period among the retries and when should a client gave up retrying.
setConnectionStrategyConfig(ClientConnectionStrategyConfig) - Method in class com.hazelcast.client.config.ClientConfig
 
setConnectionTimeout(int) - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
setConnectionTimeoutSeconds(int) - Method in class com.hazelcast.config.TcpIpConfig
Sets the connection timeout.
setConsistencyCheckStrategy(ConsistencyCheckStrategy) - Method in class com.hazelcast.config.WanSyncConfig
Sets the strategy for checking consistency of data between source and target cluster.
setConsumerConfig(WanConsumerConfig) - Method in class com.hazelcast.config.WanReplicationConfig
Sets the WAN consumer configuration for this WAN replication.
setCPMemberCount(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets the CP member count to initialize CP Subsystem.
setCPSubsystemConfig(CPSubsystemConfig) - Method in class com.hazelcast.config.Config
Set CP subsystem configuration
setCRDTReplicationConfig(CRDTReplicationConfig) - Method in class com.hazelcast.config.Config
Sets the replication configuration for CRDT implementations.
setCredentials(Credentials) - Method in class com.hazelcast.client.config.ClientConfig
Shortcut for getSecurityConfig().setCredentials()
setCredentials(Credentials) - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
setCredentials(Credentials) - Method in class com.hazelcast.config.security.RealmConfig
 
setCredentialsFactoryConfig(CredentialsFactoryConfig) - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
setCredentialsFactoryConfig(CredentialsFactoryConfig) - Method in class com.hazelcast.config.security.RealmConfig
 
setCredentialsIdentityConfig(CredentialsIdentityConfig) - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
setCredentialsIdentityConfig(CredentialsIdentityConfig) - Method in class com.hazelcast.config.security.RealmConfig
 
setCurrentKeyAlias(String) - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
Sets the alias for the current encryption key entry.
setCursorBufferSize(int) - Method in class com.hazelcast.sql.SqlStatement
Sets the cursor buffer size (measured in the number of rows).
setCustomPublisherConfigs(List<WanCustomPublisherConfig>) - Method in class com.hazelcast.config.WanReplicationConfig
Sets the list of custom WAN publisher implementations for this WAN replication.
setDataLoadTimeoutSeconds(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets the timeout duration for CP members to restore their data from stable storage.
setDataLoadTimeoutSeconds(int) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets data load timeout for hot-restart process, all members in the cluster should complete restoring their local data before this timeout.
setDataSerializableFactories(Map<Integer, DataSerializableFactory>) - Method in class com.hazelcast.config.SerializationConfig
 
setDataSerializableFactoryClasses(Map<Integer, String>) - Method in class com.hazelcast.config.SerializationConfig
 
setDefaultReadTimeout(long) - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
Set default cache value retrieval timeout.
setDefaultsDisabled(boolean) - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
setDelaySeconds(int) - Method in class com.hazelcast.config.QueryCacheConfig
Sets the minimum number of delay seconds which an event waits in the buffer of node before sending to a QueryCache
setDeprecatedName(String) - Method in class com.hazelcast.spi.properties.HazelcastProperty
Sets the deprecated name of ths property.
setDepth(int) - Method in class com.hazelcast.config.MerkleTreeConfig
Sets the depth of the merkle tree.
setDirectory(String) - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
setDirectory(String) - Method in class com.hazelcast.config.PersistentMemoryDirectoryConfig
Returns the directory of this PersistentMemoryDirectoryConfig.
setDirectoryConfigs(List<PersistentMemoryDirectoryConfig>) - Method in class com.hazelcast.config.PersistentMemoryConfig
Sets the persistent memory directory configuration to the set of directories provided in the directoryConfigs argument.
setDisablePerEntryInvalidationEvents(boolean) - Method in class com.hazelcast.config.CacheConfig
Sets invalidation events disabled status for per entry.
setDisablePerEntryInvalidationEvents(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets invalidation events disabled status for per entry.
setDiscoveryConfig(DiscoveryConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Defines the Discovery Provider SPI configuration
setDiscoveryConfig(DiscoveryConfig) - Method in class com.hazelcast.config.JoinConfig
Sets a custom defined DiscoveryConfig
setDiscoveryConfig(DiscoveryConfig) - Method in class com.hazelcast.config.WanBatchPublisherConfig
Sets the DiscoveryConfig used by the discovery mechanism for this WAN publisher.
setDiscoveryConfig(DiscoveryConfig) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
setDiscoveryMode(DiscoveryMode) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
setDiscoveryNode(DiscoveryNode) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
setDiscoveryPeriodSeconds(int) - Method in class com.hazelcast.config.WanBatchPublisherConfig
Sets the period in seconds in which WAN tries to discover new target endpoints and reestablish connections to failed endpoints.
setDiscoveryServiceProvider(DiscoveryServiceProvider) - Method in class com.hazelcast.config.DiscoveryConfig
 
setDiscoveryStrategyConfigs(List<DiscoveryStrategyConfig>) - Method in class com.hazelcast.config.DiscoveryConfig
Sets the strategy configurations for this discovery config.
setDiscoveryStrategyFactory(DiscoveryStrategyFactory) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
setDiscoveryToken(String) - Method in class com.hazelcast.client.config.ClientCloudConfig
 
setDurability(int) - Method in class com.hazelcast.config.DurableExecutorConfig
Sets the durability of the executor
setDurability(int) - Method in class com.hazelcast.config.ScheduledExecutorConfig
Sets the durability of the executor The durability represents the number of replicas that exist in a cluster for any given partition-owned task.
setDurability(int) - Method in class com.hazelcast.transaction.TransactionOptions
Sets the transaction durability.
setDurableExecutorConfigs(Map<String, DurableExecutorConfig>) - Method in class com.hazelcast.config.Config
Sets the map of durable executor configurations, mapped by config name.
setEchoFailFastOnStartup(boolean) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
setEmptyQueueTtl(int) - Method in class com.hazelcast.config.QueueConfig
Sets the TTL (time to live) for emptying the Queue.
setEnableCompression(boolean) - Method in class com.hazelcast.config.SerializationConfig
Enables compression when default java serialization is used.
setEnabled(boolean) - Method in class com.hazelcast.client.config.ClientCloudConfig
 
setEnabled(boolean) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
setEnabled(boolean) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
Enables and disables this configuration.
setEnabled(boolean) - Method in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
Enables and disables this configuration.
setEnabled(boolean) - Method in class com.hazelcast.config.AdvancedNetworkConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
Enables or disables the join mechanism based on the given discovery config.
setEnabled(boolean) - Method in class com.hazelcast.config.AutoDetectionConfig
Enables or disables the auto detection join mechanism.
setEnabled(boolean) - Method in class com.hazelcast.config.BaseMetricsConfig
Sets whether metrics collection should be enabled for the node.
setEnabled(boolean) - Method in class com.hazelcast.config.EventJournalConfig
Enables or disables the event journal.
setEnabled(boolean) - Method in class com.hazelcast.config.HotRestartConfig
Sets whether hot restart is enabled on related data structure.
setEnabled(boolean) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets whether hot restart is enabled on this member.
setEnabled(boolean) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
Set whether the ICMP failure detector should be enabled or not.
setEnabled(boolean) - Method in class com.hazelcast.config.InstanceTrackingConfig
Enables or disables instance tracking.
setEnabled(boolean) - Method in class com.hazelcast.config.InterfacesConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.MapStoreConfig
Enables and disables this configuration
setEnabled(boolean) - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.MemcacheProtocolConfig
Enables or disables the MEMCACHE protocol on the member.
setEnabled(boolean) - Method in class com.hazelcast.config.MerkleTreeConfig
Enables or disables the merkle tree.
setEnabled(boolean) - Method in class com.hazelcast.config.MetricsJmxConfig
Enables metrics exposure through JMX.
setEnabled(boolean) - Method in class com.hazelcast.config.MetricsManagementCenterConfig
Enables exposing metrics to Hazelcast Management Center.
setEnabled(boolean) - Method in class com.hazelcast.config.MulticastConfig
Enables or disables the multicast discovery mechanism
setEnabled(boolean) - Method in class com.hazelcast.config.NativeMemoryConfig
Enables or disables native memory allocation.
setEnabled(boolean) - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.PartitionGroupConfig
Enables or disables this PartitionGroupConfig.
setEnabled(boolean) - Method in class com.hazelcast.config.PersistentMemoryConfig
Enables or disables persistent memory.
setEnabled(boolean) - Method in class com.hazelcast.config.QueueStoreConfig
Enables or disables the queue store.
setEnabled(boolean) - Method in class com.hazelcast.config.RestApiConfig
Enables or disables the REST API on the member.
setEnabled(boolean) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.SecurityConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.ServiceConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.SocketInterceptorConfig
Enables and disables this configuration.
setEnabled(boolean) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.TcpIpConfig
Enables or disables the Tcp/Ip join mechanism.
setEnabled(boolean) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Enable or disable User Code Deployment.
setEnabledGroups(Collection<RestEndpointGroup>) - Method in class com.hazelcast.config.RestApiConfig
 
setEnabledGroups(Collection<RestEndpointGroup>) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setEnableSharedObject(boolean) - Method in class com.hazelcast.config.SerializationConfig
Enables shared object when default java serialization is used.
setEncryptionAtRestConfig(EncryptionAtRestConfig) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets the Hot Restart Encryption at Rest configuration.
setEndpoint(String) - Method in class com.hazelcast.config.WanBatchPublisherConfig
Sets the WAN endpoint configuration qualifier.
setEndpointConfigs(Map<EndpointQualifier, EndpointConfig>) - Method in class com.hazelcast.config.AdvancedNetworkConfig
 
setEndpoints(Set<String>) - Method in class com.hazelcast.config.PermissionConfig
 
setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.config.MapConfig
 
setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.config.MultiMapConfig
Sets the list of entry listeners (listens for when entries are added or removed) for this MultiMap.
setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.config.QueryCacheConfig
 
setEpochStart(long) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Sets the offset of timestamp component in milliseconds.
setEurekaConfig(EurekaConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Sets configuration to connect nodes in Eureka environment.
setEurekaConfig(EurekaConfig) - Method in class com.hazelcast.config.JoinConfig
 
setEurekaConfig(EurekaConfig) - Method in class com.hazelcast.config.WanBatchPublisherConfig
Sets the EurekaConfig used by the discovery mechanism for this WAN publisher.
setEventJournalConfig(EventJournalConfig) - Method in class com.hazelcast.config.AbstractCacheConfig
Sets the EventJournalConfig for this CacheConfiguration
setEventJournalConfig(EventJournalConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the EventJournalConfig for this CacheSimpleConfig
setEventJournalConfig(EventJournalConfig) - Method in class com.hazelcast.config.MapConfig
Sets the EventJournalConfig for this MapConfig
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.CacheConfig
Sets the EvictionConfig instance for eviction configuration for this ICache.
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the eviction configuration for this ICache.
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.MapConfig
Sets the EvictionConfig instance for eviction configuration for this IMap.
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.NearCacheConfig
Sets the eviction configuration for this Near Cache.
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.QueryCacheConfig
Sets the EvictionConfig instance for this QueryCache
setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.EvictionConfig
Sets the EvictionPolicy of this eviction configuration.
setExecutor(Executor) - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
Sets the Executor that is going to process the event.
setExecutor(Executor) - Method in class com.hazelcast.config.ReliableTopicConfig
Sets the executor that is going to process the event.
setExecutorConfigs(Map<String, ExecutorConfig>) - Method in class com.hazelcast.config.Config
Sets the map of executor configurations, mapped by config name.
setExecutorPoolSize(int) - Method in class com.hazelcast.config.SqlConfig
Sets the number of threads responsible for execution of SQL statements.
setExpiryPolicy(K, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Associates the specified key with the given ExpiryPolicy.
setExpiryPolicy(Set<? extends K>, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Associates the specified key with the given ExpiryPolicy.
setExpiryPolicyFactory(Factory<? extends ExpiryPolicy>) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setExpiryPolicyFactory(Factory<? extends ExpiryPolicy>) - Method in interface com.hazelcast.config.CacheConfiguration
Set the Factory for the ExpiryPolicy.
setExpiryPolicyFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the factory for this ExpiryPolicy.
setExpiryPolicyFactoryConfig(CacheSimpleConfig.ExpiryPolicyFactoryConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the factory configuration for this ExpiryPolicy.
setExtractorClassName(String) - Method in class com.hazelcast.config.AttributeConfig
Sets the full class name of the extractor in a String format, e.g.
setFactoryClassName(String) - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
Sets the factory class name.
setFactoryClassName(String) - Method in class com.hazelcast.config.MapStoreConfig
Sets the name for the MapStoreFactory implementation class
setFactoryClassName(String) - Method in class com.hazelcast.config.QueueStoreConfig
Sets the factory class name which will be used to instantiate the queue store.
setFactoryClassName(String) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
setFactoryClassName(String) - Method in class com.hazelcast.config.SSLConfig
Sets the name for the implementation class.
setFactoryImpl(ClientProxyFactory) - Method in class com.hazelcast.client.config.ProxyFactoryConfig
Sets factory implementation of proxy factory
setFactoryImplementation(Object) - Method in class com.hazelcast.config.MapStoreConfig
Sets the map store factory implementation object.
setFactoryImplementation(QueueStoreFactory) - Method in class com.hazelcast.config.QueueStoreConfig
Sets the queue store factory implementation which will be used to instantiate the queue store.
setFactoryImplementation(RingbufferStoreFactory) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
setFactoryImplementation(Object) - Method in class com.hazelcast.config.SSLConfig
Sets the implementation object.
setFailFastOnStartup(boolean) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
Sets whether the member should fail-fast on startup if ICMP is not allowed by the underlying OS.
setFailOnIndeterminateOperationState(boolean) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets the value to determine if CP Subsystem calls will fail when result of an API call becomes indeterminate.
setFileName(String) - Method in class com.hazelcast.config.InstanceTrackingConfig
Sets the name of the file which will contain the tracking metadata.
setFilters(List<String>) - Method in class com.hazelcast.config.WanReplicationRef
Sets the list of class names implementing the CacheWanEventFilter or MapWanEventFilter for filtering outbound WAN replication events.
setFlakeIdGeneratorConfigMap(Map<String, ClientFlakeIdGeneratorConfig>) - Method in class com.hazelcast.client.config.ClientConfig
Sets the map of FlakeIdGenerator configurations, mapped by config name.
setFlakeIdGeneratorConfigs(Map<String, FlakeIdGeneratorConfig>) - Method in class com.hazelcast.config.Config
Sets the map of FlakeIdGenerator configurations, mapped by config name.
setFormatPattern(String) - Method in class com.hazelcast.config.InstanceTrackingConfig
Sets the pattern used to render the contents of the instance tracking file.
setFsync(boolean) - Method in class com.hazelcast.config.HotRestartConfig
Sets whether disk write should be followed by an fsync() system call.
setFunctionClassName(String) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
setFunctionImplementation(SplitBrainProtectionFunction) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
setGcpConfig(GcpConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Sets configuration to connect nodes in GCP environment.
setGcpConfig(GcpConfig) - Method in class com.hazelcast.config.JoinConfig
 
setGcpConfig(GcpConfig) - Method in class com.hazelcast.config.WanBatchPublisherConfig
Sets the GcpConfig used by the discovery mechanism for this WAN publisher.
setGlobalOrderingEnabled(boolean) - Method in class com.hazelcast.config.TopicConfig
Enable global ordering (all nodes listening to the same topic get their messages in the same order), or disable it (nodes get the messages in the order that the messages are published).
setGlobalSerializerConfig(GlobalSerializerConfig) - Method in class com.hazelcast.config.SerializationConfig
 
setGroupSize(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets the number of CP members to form CP groups.
setGroupType(PartitionGroupConfig.MemberGroupType) - Method in class com.hazelcast.config.PartitionGroupConfig
Sets the MemberGroupType.
setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.console.Echo
 
setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.console.SimulateLoadTask
 
setHazelcastInstance(HazelcastInstance) - Method in interface com.hazelcast.core.HazelcastInstanceAware
Gets the HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService.
setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.security.HazelcastInstanceCallback
 
setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
 
setHeadSequence(long) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Sets the head sequence.
setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.AbstractCacheConfig
Sets the HotRestartConfig for this CacheConfiguration
setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the HotRestartConfig for this CacheSimpleConfig
setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.MapConfig
Sets the HotRestartConfig for this MapConfig
setHotRestartPersistenceConfig(HotRestartPersistenceConfig) - Method in class com.hazelcast.config.Config
Sets the Hot Restart configuration.
setIcmpFailureDetectorConfig(IcmpFailureDetectorConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setIcmpFailureDetectorConfig(IcmpFailureDetectorConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
setIcmpFailureDetectorConfig(IcmpFailureDetectorConfig) - Method in class com.hazelcast.config.NetworkConfig
setIdleMaxParkNs(long) - Method in class com.hazelcast.config.WanBatchPublisherConfig
Sets the maximum duration in nanoseconds that the WAN replication thread will be parked if there are no events to replicate.
setIdleMinParkNs(long) - Method in class com.hazelcast.config.WanBatchPublisherConfig
Sets the minimum duration in nanoseconds that the WAN replication thread will be parked if there are no events to replicate.
setIfConfigured(Properties, String, String) - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
 
setIfConfigured(Properties, String, Object) - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
 
setIfConfigured(Properties, String, Enum<?>) - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
 
setImplementation(WanPublisher) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
Sets the implementation of WanPublisher.
setImplementation(CachePartitionLostListener) - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
 
setImplementation(ICredentialsFactory) - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
setImplementation(EventListener) - Method in class com.hazelcast.config.EntryListenerConfig
 
setImplementation(MapListener) - Method in class com.hazelcast.config.EntryListenerConfig
 
setImplementation(Serializer) - Method in class com.hazelcast.config.GlobalSerializerConfig
 
setImplementation(ItemListener) - Method in class com.hazelcast.config.ItemListenerConfig
 
setImplementation(EventListener) - Method in class com.hazelcast.config.ListenerConfig
Sets the EventListener implementation.
setImplementation(MapPartitionLostListener) - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
 
setImplementation(Object) - Method in class com.hazelcast.config.MapStoreConfig
Sets the map store implementation object
setImplementation(MemberAddressProvider) - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
setImplementation(IPermissionPolicy) - Method in class com.hazelcast.config.PermissionPolicyConfig
 
setImplementation(Predicate) - Method in class com.hazelcast.config.PredicateConfig
Sets the Predicate implementation.
setImplementation(SecurityInterceptor) - Method in class com.hazelcast.config.SecurityInterceptorConfig
 
setImplementation(Serializer) - Method in class com.hazelcast.config.SerializerConfig
Sets the serializer implementation instance.
setImplementation(Object) - Method in class com.hazelcast.config.ServiceConfig
 
setImplementation(Object) - Method in class com.hazelcast.config.SocketInterceptorConfig
Sets the SocketInterceptor implementation object.
setImplementation(SplitBrainProtectionListener) - Method in class com.hazelcast.config.SplitBrainProtectionListenerConfig
 
setImplementation(WanPublisher) - Method in class com.hazelcast.config.WanBatchPublisherConfig
No-op method as the implementation cannot be changed for this publisher.
setImplementation(WanConsumer) - Method in class com.hazelcast.config.WanConsumerConfig
Sets the implementation for this WAN consumer.
setImplementation(WanPublisher) - Method in class com.hazelcast.config.WanCustomPublisherConfig
 
setIncludeValue(boolean) - Method in class com.hazelcast.config.EntryListenerConfig
 
setIncludeValue(boolean) - Method in class com.hazelcast.config.ItemListenerConfig
 
setIncludeValue(boolean) - Method in class com.hazelcast.config.QueryCacheConfig
Set true to enable value caching, otherwise set false
setIndexConfigs(List<IndexConfig>) - Method in class com.hazelcast.config.MapConfig
 
setIndexConfigs(List<IndexConfig>) - Method in class com.hazelcast.config.QueryCacheConfig
 
setInitialBackoffMillis(int) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
 
setInitialLoadMode(MapStoreConfig.InitialLoadMode) - Method in class com.hazelcast.config.MapStoreConfig
Sets the initial load mode.
setInitialPermits(int) - Method in class com.hazelcast.config.cp.SemaphoreConfig
Sets initial permit count of the Semaphore
setInitialPublisherState(WanPublisherState) - Method in class com.hazelcast.config.WanBatchPublisherConfig
Sets the initial publisher state.
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.CacheConfig
Data type that will be used to store records in this ICache.
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the InMemory Format for this ICache.
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.MapConfig
Binary type that will be used for storing records.
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.NearCacheConfig
Sets the data type used to store entries.
setInMemoryFormat(String) - Method in class com.hazelcast.config.NearCacheConfig
 
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.QueryCacheConfig
Sets memory format of values of entries in QueryCache.
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.ReplicatedMapConfig
Data type used to store entries.
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.RingbufferConfig
Sets the in-memory format.
setInstanceName(String) - Method in class com.hazelcast.client.config.ClientConfig
 
setInstanceName(String) - Method in class com.hazelcast.config.Config
Sets the instance name uniquely identifying the hazelcast instance created by this configuration.
setInstanceTrackingConfig(InstanceTrackingConfig) - Method in class com.hazelcast.client.config.ClientConfig
Returns the configuration for tracking use of this Hazelcast instance.
setInstanceTrackingConfig(InstanceTrackingConfig) - Method in class com.hazelcast.config.Config
Returns the configuration for tracking use of this Hazelcast instance.
setInterfaces(InterfacesConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setInterfaces(InterfacesConfig) - Method in class com.hazelcast.config.EndpointConfig
 
setInterfaces(Collection<String>) - Method in class com.hazelcast.config.InterfacesConfig
Adds a collection of interfaces.
setInterfaces(Collection<String>) - Method in class com.hazelcast.config.MemberGroupConfig
Sets the interfaces that are part of a group.
setInterfaces(InterfacesConfig) - Method in class com.hazelcast.config.NetworkConfig
 
setInterfaces(InterfacesConfig) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setInterfaces(InterfacesConfig) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setIntervalMilliseconds(int) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
setIntervalMilliseconds(int) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
Sets the time in milliseconds between each ping This value can not be smaller than 1000 milliseconds
setInvalidateOnChange(boolean) - Method in class com.hazelcast.config.NearCacheConfig
Sets if Near Cache entries are invalidated when the entries in the backing data structure are changed (updated or removed).
setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.config.CollectionConfig
Sets the list of ItemListenerConfigs.
setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.config.QueueConfig
Set the list of item listener configurations for this queue.
setIterationCount(int) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
setJaasAuthenticationConfig(JaasAuthenticationConfig) - Method in class com.hazelcast.config.security.RealmConfig
 
setJarPaths(List<String>) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
String jarPath is searched in following order: 1.
setJavaSerializationFilterConfig(JavaSerializationFilterConfig) - Method in class com.hazelcast.config.SerializationConfig
Allows to configure deserialization protection filter.
setJDKCompatible(boolean) - Method in class com.hazelcast.config.cp.SemaphoreConfig
Sets JDK compatibility mode of CP ISemaphore
setJitter(double) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
At each iteration calculated back-off is randomized via following method Random(-jitter * current_backoff, jitter * current_backoff)
setJmxConfig(MetricsJmxConfig) - Method in class com.hazelcast.config.BaseMetricsConfig
 
setJoin(JoinConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setJoin(JoinConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
 
setJoin(JoinConfig) - Method in class com.hazelcast.config.NetworkConfig
 
setKeepAlive(boolean) - Method in class com.hazelcast.client.config.SocketOptions
Enable/disable SO_KEEPALIVE socket option.
setKerberosAuthenticationConfig(KerberosAuthenticationConfig) - Method in class com.hazelcast.config.security.RealmConfig
 
setKerberosIdentityConfig(KerberosIdentityConfig) - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
setKerberosIdentityConfig(KerberosIdentityConfig) - Method in class com.hazelcast.config.security.RealmConfig
 
setKey(byte[]) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
setKeyClassName(String) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setKeySize(int) - Method in class com.hazelcast.config.EncryptionAtRestConfig
Sets the size (in bits) of the Hot Restart Store-level encryption key (non-positive value implies falling back to the cipher-specific default key length).
setKeytabFile(String) - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
 
setKeytabFile(String) - Method in class com.hazelcast.config.security.KerberosIdentityConfig
 
setKeyType(Class<K>) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setKeyType(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the key type for this ICache.
setKubernetesConfig(KubernetesConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Sets configuration to connect nodes in Kubernetes environment.
setKubernetesConfig(KubernetesConfig) - Method in class com.hazelcast.config.JoinConfig
 
setKubernetesConfig(KubernetesConfig) - Method in class com.hazelcast.config.WanBatchPublisherConfig
Sets the KubernetesConfig used by the discovery mechanism for this WAN publisher.
setLabels(Set<String>) - Method in class com.hazelcast.client.config.ClientConfig
Set labels for the client.
setLdapAuthenticationConfig(LdapAuthenticationConfig) - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
 
setLdapAuthenticationConfig(LdapAuthenticationConfig) - Method in class com.hazelcast.config.security.RealmConfig
 
setLeaderElectionTimeoutInMillis(long) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
setLeaderHeartbeatPeriodInMillis(long) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
setLicenseKey(String) - Method in class com.hazelcast.config.Config
Sets the license key for this hazelcast instance.
setLingerSeconds(int) - Method in class com.hazelcast.client.config.SocketOptions
Enable/disable SO_LINGER with the specified linger time in seconds If set to a value of 0 or less then it is disabled.
setListConfigs(Map<String, ListConfig>) - Method in class com.hazelcast.config.Config
Sets the map of IList configurations, mapped by config name.
setListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.client.config.ClientConfig
Sets all ListenerConfig's
setListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.Config
Sets the list of EventListener configurations.
setListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.ReplicatedMapConfig
 
setListenerConfigs(List<SplitBrainProtectionListenerConfig>) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
setListenerConfigurations() - Method in class com.hazelcast.config.AbstractCacheConfig
 
setListenerConfigurations(Set<CacheEntryListenerConfiguration<K, V>>) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setLiteMember(boolean) - Method in class com.hazelcast.config.Config
Sets the flag to indicate if this member is a lite member.
setLoadBalancer(LoadBalancer) - Method in class com.hazelcast.client.config.ClientConfig
Sets the LoadBalancer.
setLoadBalancerClassName(String) - Method in class com.hazelcast.client.config.ClientConfig
Sets load balancer class name.
setLocal(boolean) - Method in class com.hazelcast.config.EntryListenerConfig
 
setLocalUpdatePolicy(NearCacheConfig.LocalUpdatePolicy) - Method in class com.hazelcast.config.NearCacheConfig
Sets the NearCacheConfig.LocalUpdatePolicy of this Near Cache.
setLockAcquireLimit(int) - Method in class com.hazelcast.config.cp.FencedLockConfig
Sets the number of lock acquires a lock holder can perform.
setLockConfigs(Map<String, FencedLockConfig>) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets the map of FencedLock configurations, mapped by config name.
setLogger(ILogger) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
setLoggingService(LoggingService) - Method in class com.hazelcast.security.LoggingServiceCallback
 
setLoginModuleConfigs(List<LoginModuleConfig>) - Method in class com.hazelcast.config.security.JaasAuthenticationConfig
 
setLoopbackModeEnabled(boolean) - Method in class com.hazelcast.config.MulticastConfig
Enables or disables the loopback mode in the multicast discovery mechanism.
setMainClass(String) - Method in class com.hazelcast.buildutils.HazelcastManifestTransformer
 
setManagedContext(ManagedContext) - Method in class com.hazelcast.client.config.ClientConfig
setManagedContext(ManagedContext) - Method in class com.hazelcast.config.Config
Sets the external managed context.
setManagementCenterConfig(ManagementCenterConfig) - Method in class com.hazelcast.config.Config
Sets the management center configuration for this hazelcast instance.
setManagementCenterConfig(MetricsManagementCenterConfig) - Method in class com.hazelcast.config.MetricsConfig
 
setManagementEnabled(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
Sets whether or not management is enabled on this cache.
setManagementEnabled(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
Sets whether management is enabled on a cache.
setManagementEnabled(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets management to enabled or disabled for this ICache.
setManagerPrefix(String) - Method in class com.hazelcast.config.CacheConfig
Sets the manager prefix of the ICache.
setManifestEntries(Map<String, Object>) - Method in class com.hazelcast.buildutils.HazelcastManifestTransformer
 
setMapConfigs(Map<String, MapConfig>) - Method in class com.hazelcast.config.Config
Sets the map of IMap configurations, mapped by config name.
setMapStoreConfig(MapStoreConfig) - Method in class com.hazelcast.config.MapConfig
Sets the map store configuration
setMaxAttempts(int) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
setMaxAttempts(int) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
Set the max ping attempts before suspecting a member
setMaxBackoffMillis(int) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
When backoff reaches this upper bound, it does not increase any more.
setMaxConcurrentInvocations(int) - Method in class com.hazelcast.config.WanBatchPublisherConfig
Sets the maximum number of WAN event batches being sent to the target cluster concurrently.
setMaxConcurrentReplicationTargets(int) - Method in class com.hazelcast.config.CRDTReplicationConfig
Sets the maximum number of target members that we replicate the CRDT states to in one period.
setMaxIdleSeconds(int) - Method in class com.hazelcast.config.MapConfig
Maximum number of seconds for each entry to stay idle in the map.
setMaxIdleSeconds(int) - Method in class com.hazelcast.config.NearCacheConfig
Set the maximum number of seconds each entry can stay in the Near Cache as untouched (not-read).
setMaxMissedLeaderHeartbeatCount(int) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
setMaxSize(int) - Method in class com.hazelcast.config.CollectionConfig
Sets the maximum size for the collection.
setMaxSize(int) - Method in class com.hazelcast.config.QueueConfig
Sets the maximum size of the Queue.
setMaxSizePolicy(MaxSizePolicy) - Method in class com.hazelcast.config.EvictionConfig
Sets the MaxSizePolicy of this eviction configuration.
setMaxTargetEndpoints(int) - Method in class com.hazelcast.config.WanBatchPublisherConfig
Sets the maximum number of endpoints that WAN will connect to when using a discovery mechanism to define endpoints.
setMemberAddressProviderConfig(MemberAddressProviderConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setMemberAddressProviderConfig(MemberAddressProviderConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
 
setMemberAddressProviderConfig(MemberAddressProviderConfig) - Method in class com.hazelcast.config.NetworkConfig
 
setMemberAttributeConfig(MemberAttributeConfig) - Method in class com.hazelcast.config.Config
Sets the member attribute configuration.
setMemberEndpointConfig(ServerSocketEndpointConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
Sets the server socket endpoint config for MEMBER protocol.
setMemberGroupConfigs(Collection<MemberGroupConfig>) - Method in class com.hazelcast.config.PartitionGroupConfig
Adds a MemberGroupConfig.
setMemberRealm(String) - Method in class com.hazelcast.config.SecurityConfig
 
setMemberRealmConfig(String, RealmConfig) - Method in class com.hazelcast.config.SecurityConfig
 
setMembers(List<String>) - Method in class com.hazelcast.config.TcpIpConfig
Sets the well known members.
setMemcacheEndpointConfig(ServerSocketEndpointConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
Sets the server socket endpoint config for memcache protocol.
setMemcacheProtocolConfig(MemcacheProtocolConfig) - Method in class com.hazelcast.config.NetworkConfig
 
setMergePolicyClassName(String) - Method in class com.hazelcast.config.WanReplicationRef
Sets the merge policy sent to the WAN replication target to merge replicated entries with existing target entries.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.CacheConfig
Sets the MergePolicyConfig for this map.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the MergePolicyConfig for this map.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Sets the MergePolicyConfig for the scheduler.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.CollectionConfig
Sets the MergePolicyConfig for the collection.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.MapConfig
Sets the MergePolicyConfig for this map.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.MultiMapConfig
Sets the MergePolicyConfig for this MultiMap.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.QueueConfig
Sets the MergePolicyConfig for this queue.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.ReplicatedMapConfig
Sets the MergePolicyConfig for this replicated map.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.RingbufferConfig
Sets the MergePolicyConfig for this ringbuffer.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.ScheduledExecutorConfig
Sets the MergePolicyConfig for the scheduler.
setMerkleTreeConfig(MerkleTreeConfig) - Method in class com.hazelcast.config.MapConfig
Sets the MerkleTreeConfig for this MapConfig
setMessageListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.ReliableTopicConfig
Sets the list of message listeners (listens for when messages are added or removed) for this topic.
setMessageListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.TopicConfig
Sets the list of message listeners (listens for when messages are added or removed) for this topic.
setMetadataPolicy(MetadataPolicy) - Method in class com.hazelcast.config.MapConfig
Sets the metadata policy.
setMetadataSpacePercentage(float) - Method in class com.hazelcast.config.NativeMemoryConfig
Sets the percentage of native memory space to be used to store metadata and internal memory structures by the native memory manager.
setMetricsConfig(ClientMetricsConfig) - Method in class com.hazelcast.client.config.ClientConfig
Sets the metrics collection config.
setMetricsConfig(MetricsConfig) - Method in class com.hazelcast.config.Config
Sets the metrics collection config.
setMinBlockSize(int) - Method in class com.hazelcast.config.NativeMemoryConfig
Sets the minimum memory block size, in bytes, to be served by native memory manager.
setMinimumClusterSize(int) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
setMissingCPMemberAutoRemovalSeconds(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets the duration to wait before automatically removing a missing CP member from CP Subsystem.
setMode(PersistentMemoryMode) - Method in class com.hazelcast.config.PersistentMemoryConfig
Sets the mode in which the persistent memory should be used.
setMulticastConfig(MulticastConfig) - Method in class com.hazelcast.config.JoinConfig
 
setMulticastGroup(String) - Method in class com.hazelcast.config.MulticastConfig
Sets the multicast group.
setMulticastPort(int) - Method in class com.hazelcast.config.MulticastConfig
Sets the multicast port.
setMulticastTimeoutSeconds(int) - Method in class com.hazelcast.config.MulticastConfig
Specifies the time in seconds that a node should wait for a valid multicast response from another node running in the network before declaring itself as master node and creating its own cluster.
setMulticastTimeToLive(int) - Method in class com.hazelcast.config.MulticastConfig
Sets the time to live for the multicast package; a value between 0..255.
setMultiMapConfigs(Map<String, MultiMapConfig>) - Method in class com.hazelcast.config.Config
Sets the map of MultiMap configurations, mapped by config name.
setMultiplier(double) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
 
setMultiThreadingEnabled(boolean) - Method in class com.hazelcast.config.TopicConfig
Enable multi-threaded message handling.
setName(String) - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
Sets the name or name pattern for this config.
setName(String) - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
Sets the name or name pattern for this config.
setName(String) - Method in class com.hazelcast.config.AttributeConfig
Sets the name of the attribute extracted by the extractor.
setName(String) - Method in class com.hazelcast.config.CacheConfig
Sets the name of this ICache.
setName(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the name of this ICache.
setName(String) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Sets the name of the cardinality estimator.
setName(String) - Method in class com.hazelcast.config.CollectionConfig
Sets the name of this collection.
setName(String) - Method in class com.hazelcast.config.cp.FencedLockConfig
Sets the name of FencedLock
setName(String) - Method in class com.hazelcast.config.cp.SemaphoreConfig
Sets the name of CP ISemaphore
setName(String) - Method in class com.hazelcast.config.DurableExecutorConfig
Sets the name of the executor task.
setName(String) - Method in class com.hazelcast.config.EndpointConfig
 
setName(String) - Method in class com.hazelcast.config.ExecutorConfig
Sets the name of the executor task.
setName(String) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Sets the name or name pattern for this config.
setName(String) - Method in class com.hazelcast.config.IndexConfig
Sets name of the index.
setName(String) - Method in class com.hazelcast.config.MapConfig
Sets the name of the IMap
setName(String) - Method in class com.hazelcast.config.MultiMapConfig
Sets the name of this MultiMap.
setName(String) - Method in interface com.hazelcast.config.NamedConfig
 
setName(String) - Method in class com.hazelcast.config.NearCacheConfig
Sets the name of the Near Cache.
setName(String) - Method in class com.hazelcast.config.PermissionConfig
 
setName(String) - Method in class com.hazelcast.config.PNCounterConfig
Sets the name of the PN counter.
setName(String) - Method in class com.hazelcast.config.QueryCacheConfig
Sets the name of QueryCache.
setName(String) - Method in class com.hazelcast.config.QueueConfig
Set the name for this queue.
setName(String) - Method in class com.hazelcast.config.ReliableTopicConfig
Sets the name of the reliable topic.
setName(String) - Method in class com.hazelcast.config.ReplicatedMapConfig
Sets the name of this ReplicatedMap.
setName(String) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setName(String) - Method in class com.hazelcast.config.RingbufferConfig
Sets the name of the ringbuffer.
setName(String) - Method in class com.hazelcast.config.ScheduledExecutorConfig
Sets the name of the executor task.
setName(String) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setName(String) - Method in class com.hazelcast.config.ServiceConfig
 
setName(String) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
setName(String) - Method in class com.hazelcast.config.TopicConfig
Sets the name of the topic.
setName(String) - Method in class com.hazelcast.config.WanReplicationConfig
Sets the name of this WAN replication config.
setName(String) - Method in class com.hazelcast.config.WanReplicationRef
Sets the WAN replication reference name.
setName(String) - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
setNativeMemoryConfig(NativeMemoryConfig) - Method in class com.hazelcast.client.config.ClientConfig
 
setNativeMemoryConfig(NativeMemoryConfig) - Method in class com.hazelcast.config.Config
Sets the native memory configuration for this hazelcast instance.
setNearCacheConfig(NearCacheConfig) - Method in class com.hazelcast.config.MapConfig
Sets the Near Cache configuration
setNearCacheConfigMap(Map<String, NearCacheConfig>) - Method in class com.hazelcast.client.config.ClientConfig
Sets all NearCacheConfig's with the provided map
setNetworkConfig(ClientNetworkConfig) - Method in class com.hazelcast.client.config.ClientConfig
setNetworkConfig(NetworkConfig) - Method in class com.hazelcast.config.Config
Sets the network configuration for this hazelcast instance.
setNodeFilter(NodeFilter) - Method in class com.hazelcast.config.DiscoveryConfig
 
setNodeFilterClass(String) - Method in class com.hazelcast.config.DiscoveryConfig
 
setNodeIdOffset(long) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Sets the offset that will be added to the node ID assigned to cluster member for this generator.
setNumaNode(int) - Method in class com.hazelcast.config.PersistentMemoryDirectoryConfig
Sets the NUMA node the persistent memory mounted to the given directory is attached to.
setOf(T...) - Static method in class com.hazelcast.buildutils.FinalRemovalAgent
 
setOldValueRequired(boolean) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
If true, previously assigned values for the affected keys will be sent to this cache entry listener implementation.
setOnJoinPermissionOperation(OnJoinPermissionOperationName) - Method in class com.hazelcast.config.SecurityConfig
 
setOperationPoolSize(int) - Method in class com.hazelcast.config.SqlConfig
Sets the number of threads responsible for network operations processing.
setOrClear(String, String) - Method in class com.hazelcast.config.LoginModuleConfig
setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Set outbound port definitions
setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.config.EndpointConfig
 
setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.config.NetworkConfig
 
setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Set outbond ports
setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.config.EndpointConfig
 
setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.config.NetworkConfig
 
setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setOutOfMemoryHandler(OutOfMemoryHandler) - Static method in class com.hazelcast.client.HazelcastClient
Sets OutOfMemoryHandler to be used when an OutOfMemoryError is caught by Hazelcast Client threads.
setOutOfMemoryHandler(OutOfMemoryHandler) - Static method in class com.hazelcast.core.Hazelcast
Sets OutOfMemoryHandler to be used when an OutOfMemoryError is caught by Hazelcast threads.
setOverrideInstructions(Map<String, String>) - Method in class com.hazelcast.buildutils.HazelcastManifestTransformer
 
setOverrideJavaSerialization(boolean) - Method in class com.hazelcast.config.GlobalSerializerConfig
 
setPackages(Collection<String>) - Method in class com.hazelcast.config.ClassFilter
 
setPage(int) - Method in interface com.hazelcast.query.PagingPredicate
Sets the current page value.
setPageSize(int) - Method in class com.hazelcast.config.NativeMemoryConfig
Sets the page size, in bytes, to be allocated by native memory manager as a single block.
setParallelism(int) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets the number of Hot Restart store instances to create for one Hazelcast instance.
setParallelMode(boolean) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
Set the ICMP detector to run in parallel mode, independent from the other failure detectors.
setParameterMetadata(QueryParameterMetadata) - Method in class org.apache.calcite.plan.HazelcastRelOptCluster
 
setParameters(List<Object>) - Method in class com.hazelcast.sql.SqlStatement
Sets the statement parameters.
setParseDn(boolean) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setPartitionGroupConfig(PartitionGroupConfig) - Method in class com.hazelcast.config.Config
Sets the partition group configuration for this hazelcast instance.
setPartitioningStrategy(PartitioningStrategy) - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
setPartitioningStrategyClass(String) - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
setPartitioningStrategyConfig(PartitioningStrategyConfig) - Method in class com.hazelcast.config.MapConfig
 
setPartitionLostListenerConfigs(List<CachePartitionLostListenerConfig>) - Method in class com.hazelcast.config.CacheConfig
Sets the WAN target replication reference.
setPartitionLostListenerConfigs(List<CachePartitionLostListenerConfig>) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the PartitionLostListenerConfigs.
setPartitionLostListenerConfigs(List<MapPartitionLostListenerConfig>) - Method in class com.hazelcast.config.MapConfig
 
setPassword(String) - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
Sets the Java KeyStore password.
setPassword(String) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
setPassword(String) - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
setPasswordAttribute(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setPath(File) - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
Sets the Java KeyStore file path.
SetPermission - Class in com.hazelcast.security.permission
 
SetPermission(String, String...) - Constructor for class com.hazelcast.security.permission.SetPermission
 
setPersistenceEnabled(boolean) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets whether CP Subsystem Persistence is enabled on this member.
setPersistentMemoryConfig(PersistentMemoryConfig) - Method in class com.hazelcast.config.NativeMemoryConfig
Sets the persistent memory configuration this native memory configuration uses.
setPersistentMemoryDirectory(String) - Method in class com.hazelcast.config.NativeMemoryConfig
Deprecated.
setPersistWanReplicatedData(boolean) - Method in class com.hazelcast.config.WanConsumerConfig
 
setPNCounterConfigs(Map<String, PNCounterConfig>) - Method in class com.hazelcast.config.Config
Sets the map of PN counter configurations, mapped by config name.
setPolicy(String) - Method in class com.hazelcast.config.MergePolicyConfig
Sets the classname of your SplitBrainMergePolicy.
setPollingInterval(int) - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
Sets the polling interval (in seconds) for checking for changes in the KeyStore.
setPollingInterval(int) - Method in class com.hazelcast.config.VaultSecureStoreConfig
Sets the polling interval (in seconds) for checking for changes in Vault.
setPoolSize(int) - Method in class com.hazelcast.config.DurableExecutorConfig
Sets the number of executor threads per member for the executor.
setPoolSize(int) - Method in class com.hazelcast.config.ExecutorConfig
Sets the number of executor threads per member for the executor.
setPoolSize(int) - Method in class com.hazelcast.config.ScheduledExecutorConfig
Sets the number of executor threads per member for the executor.
setPopulate(boolean) - Method in class com.hazelcast.config.QueryCacheConfig
Set true to enable initial population, otherwise set false.
setPort(int) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setPort(int) - Method in class com.hazelcast.config.NetworkConfig
Sets the port the Hazelcast member will try to bind on.
setPort(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setPort(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
Sets the port the Hazelcast member will try to bind on.
setPortableFactories(Map<Integer, PortableFactory>) - Method in class com.hazelcast.config.SerializationConfig
 
setPortableFactoryClasses(Map<Integer, String>) - Method in class com.hazelcast.config.SerializationConfig
 
setPortableVersion(int) - Method in class com.hazelcast.config.SerializationConfig
 
setPortAutoIncrement(boolean) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setPortAutoIncrement(boolean) - Method in class com.hazelcast.config.NetworkConfig
Sets if a Hazelcast member is allowed to find a free port by incrementing the port number when it encounters an occupied port.
setPortAutoIncrement(boolean) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setPortAutoIncrement(boolean) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
Sets if a Hazelcast member is allowed to find a free port by incrementing the port number when it encounters an occupied port.
setPortCount(int) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setPortCount(int) - Method in class com.hazelcast.config.NetworkConfig
The maximum number of ports allowed to use.
setPortCount(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
The maximum number of ports allowed to use.
setPredicateConfig(PredicateConfig) - Method in class com.hazelcast.config.QueryCacheConfig
Sets the predicate of QueryCache.
setPrefetchCount(int) - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
Sets how many IDs are pre-fetched on the background when one call to FlakeIdGenerator.newId() is made.
setPrefetchCount(int) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Sets how many IDs are pre-fetched on the background when one call to FlakeIdGenerator.newId() is made.
setPrefetchValidityMillis(long) - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
Sets for how long the pre-fetched IDs can be used.
setPrefetchValidityMillis(long) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Sets for how long the pre-fetched IDs can be used.
setPrefixes(Collection<String>) - Method in class com.hazelcast.config.ClassFilter
 
setPreloaderConfig(NearCachePreloaderConfig) - Method in class com.hazelcast.config.NearCacheConfig
Sets the NearCachePreloaderConfig of this Near Cache.
setPrincipal(String) - Method in class com.hazelcast.config.PermissionConfig
 
setPrincipal(String) - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
 
setPrincipal(String) - Method in class com.hazelcast.config.security.KerberosIdentityConfig
 
setPriorityComparatorClassName(String) - Method in class com.hazelcast.config.QueueConfig
Sets the class name that will be used to compare queue items.
setProperties(Properties) - Method in class com.hazelcast.client.config.ClientConfig
sets all properties
setProperties(Properties) - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
 
setProperties(Properties) - Method in class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
 
setProperties(Properties) - Method in class com.hazelcast.client.config.YamlClientConfigBuilder
 
setProperties(Properties) - Method in class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
 
setProperties(Properties) - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
Sets the properties.
setProperties(Map<String, Comparable>) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
Sets the WAN publisher properties.
setProperties(Properties) - Method in class com.hazelcast.config.Config
Sets the properties for this config instance.
setProperties(Properties) - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
setProperties(Map<String, Comparable>) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
setProperties(Properties) - Method in class com.hazelcast.config.LoginModuleConfig
 
setProperties(Properties) - Method in class com.hazelcast.config.MapStoreConfig
Sets the properties
setProperties(Properties) - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
setProperties(Properties) - Method in class com.hazelcast.config.PermissionPolicyConfig
 
setProperties(Properties) - Method in class com.hazelcast.config.QueueStoreConfig
Sets the properties to be used when instantiating the queue store.
setProperties(Properties) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
setProperties(Properties) - Method in class com.hazelcast.config.ServiceConfig
 
setProperties(Properties) - Method in class com.hazelcast.config.SocketInterceptorConfig
Sets the properties.
setProperties(Map<String, Comparable>) - Method in class com.hazelcast.config.WanBatchPublisherConfig
 
setProperties(Map<String, Comparable>) - Method in class com.hazelcast.config.WanConsumerConfig
Sets the properties for the custom WAN consumer.
setProperties(Map<String, Comparable>) - Method in class com.hazelcast.config.WanCustomPublisherConfig
 
setProperties(Properties) - Method in class com.hazelcast.config.XmlConfigBuilder
Sets the used properties.
setProperties(Properties) - Method in class com.hazelcast.config.YamlConfigBuilder
 
setPropertiesInternal(Properties) - Method in class com.hazelcast.config.AbstractXmlConfigBuilder
Sets the used properties.
setPropertiesInternal(Properties) - Method in class com.hazelcast.config.AbstractYamlConfigBuilder
 
setProperty(String, String) - Method in class com.hazelcast.client.config.ClientConfig
Sets the value of a named property.
setProperty(String, String) - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
Sets a single property.
setProperty(String, String) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
Sets the property understood by the given SPI Discovery Strategy.
setProperty(String, String) - Method in class com.hazelcast.config.Config
Sets the value of a named property.
setProperty(String, String) - Method in class com.hazelcast.config.LoginModuleConfig
 
setProperty(String, String) - Method in class com.hazelcast.config.MapStoreConfig
 
setProperty(String, String) - Method in class com.hazelcast.config.QueueStoreConfig
Sets a property to be used when instantiating the queue store.
setProperty(String, String) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
setProperty(String, String) - Method in class com.hazelcast.config.SocketInterceptorConfig
Sets a property.
setProtectOn(SplitBrainProtectionOn) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
setProtocolType(ProtocolType) - Method in class com.hazelcast.config.EndpointConfig
 
setProtocolType(ProtocolType) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setProviderFilter(String) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Filter to limit members that can be used for classloading request when a user class is not available locally.
setProviderMode(UserCodeDeploymentConfig.ProviderMode) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Configure behaviour when providing classes to remote members.
setProxyFactoryConfigs(List<ProxyFactoryConfig>) - Method in class com.hazelcast.client.config.ClientConfig
setPublicAddress(String) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setPublicAddress(String) - Method in class com.hazelcast.config.NetworkConfig
Overrides the public address of a member.
setPublicAddress(String) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setPublicAddress(String) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
Overrides the public address of a member.
setPublisherId(String) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
Sets the publisher ID used for identifying the publisher in a WanReplicationConfig.
setPublisherId(String) - Method in class com.hazelcast.config.WanBatchPublisherConfig
 
setPublisherId(String) - Method in class com.hazelcast.config.WanCustomPublisherConfig
 
setQueryCacheConfigs(Map<String, Map<String, QueryCacheConfig>>) - Method in class com.hazelcast.client.config.ClientConfig
 
setQueryCacheConfigs(List<QueryCacheConfig>) - Method in class com.hazelcast.config.MapConfig
Sets QueryCacheConfig instances to this MapConfig.
setQueueCapacity(int) - Method in class com.hazelcast.config.ExecutorConfig
Sets the queue capacity of the executor task.
setQueueCapacity(int) - Method in class com.hazelcast.config.WanBatchPublisherConfig
Sets the capacity of the primary and backup queue for WAN replication events.
setQueueConfigs(Map<String, QueueConfig>) - Method in class com.hazelcast.config.Config
Sets the map of IQueue configurations, mapped by config name.
setQueueFullBehavior(WanQueueFullBehavior) - Method in class com.hazelcast.config.WanBatchPublisherConfig
Sets the configured behaviour of this WAN publisher when the WAN queue is full.
setQueueStoreConfig(QueueStoreConfig) - Method in class com.hazelcast.config.QueueConfig
Set the QueueStore (load and store queue items from/to a database) configuration.
setRaftAlgorithmConfig(RaftAlgorithmConfig) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets configuration options for Hazelcast's Raft consensus algorithm implementation
setReadBackupData(boolean) - Method in class com.hazelcast.config.MapConfig
Sets read-backup-data (reading local backup entries) for this map.
setReadBatchSize(int) - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
Sets the read batch size.
setReadBatchSize(int) - Method in class com.hazelcast.config.ReliableTopicConfig
Sets the read batch size.
setReadThrough(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setReadThrough(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
Set if read-through caching should be used.
setReadThrough(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
Enables or disables read-through: a read loads the entry from the data store if it is not already in the cache.
setReadTimeout(long) - Method in class com.hazelcast.spring.cache.HazelcastCache
Set cache value retrieval timeout
setRealm(String) - Method in class com.hazelcast.config.security.KerberosIdentityConfig
 
setRealmConfig(RealmConfig) - Method in class com.hazelcast.security.RealmConfigCallback
 
setRealmConfigs(Map<String, RealmConfig>) - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
setRealmConfigs(Map<String, RealmConfig>) - Method in class com.hazelcast.config.SecurityConfig
 
setReconnectMode(ClientConnectionStrategyConfig.ReconnectMode) - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
How a client reconnect to cluster after a disconnect can be configured.
setRedoOperation(boolean) - Method in class com.hazelcast.client.config.ClientNetworkConfig
If true, client will redo the operations that were executing on the server and client lost the connection.
setRelaxFlagsCheck(Boolean) - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
 
setReliableTopicConfigMap(Map<String, ClientReliableTopicConfig>) - Method in class com.hazelcast.client.config.ClientConfig
Sets the map of ClientReliableTopicConfig, mapped by config name.
setReliableTopicConfigs(Map<String, ReliableTopicConfig>) - Method in class com.hazelcast.config.Config
Sets the map of reliable topic configurations, mapped by config name.
setReplicaCount(int) - Method in class com.hazelcast.config.PNCounterConfig
Sets the number of replicas on which state for this PN counter will be kept.
setReplicatedMapConfigs(Map<String, ReplicatedMapConfig>) - Method in class com.hazelcast.config.Config
Sets the map of ReplicatedMap configurations, mapped by config name.
setReplicationPeriodMillis(int) - Method in class com.hazelcast.config.CRDTReplicationConfig
Sets the period between two replications of CRDT states in milliseconds.
setRepublishingEnabled(boolean) - Method in class com.hazelcast.config.WanReplicationRef
Sets if incoming WAN events to this member should be republished (forwarded) to this WAN replication reference.
setRequiredMember(String) - Method in class com.hazelcast.config.TcpIpConfig
Sets the required member.
setResponseTimeoutMillis(int) - Method in class com.hazelcast.config.WanBatchPublisherConfig
Sets the duration in milliseconds for the waiting time before retrying to send the events to target cluster again in case of acknowledgement is not arrived.
setRestApiConfig(RestApiConfig) - Method in class com.hazelcast.config.NetworkConfig
 
setRestEndpointConfig(RestServerEndpointConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
Sets the server socket endpoint config for REST protocol.
setRetentionSeconds(int) - Method in class com.hazelcast.config.MetricsManagementCenterConfig
Sets the number of seconds the metrics will be retained on the instance.
setReuseAddress(boolean) - Method in class com.hazelcast.client.config.SocketOptions
Enable/disable the SO_REUSEADDR socket option.
setReuseAddress(boolean) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setReuseAddress(boolean) - Method in class com.hazelcast.config.NetworkConfig
Sets the reuse address.
setReuseAddress(boolean) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setReuseAddress(boolean) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
Sets the reuse address.
setRingbufferConfigs(Map<String, RingbufferConfig>) - Method in class com.hazelcast.config.Config
Sets the map of Ringbuffer configurations, mapped by config name.
setRingbufferStoreConfig(RingbufferStoreConfig) - Method in class com.hazelcast.config.RingbufferConfig
Set the RingbufferStore (load and store ringbuffer items from/to a database) configuration.
setRoleAttribute(String) - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
 
setRoleContext(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setRoleFilter(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setRoleMappingAttribute(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setRoleMappingMode(LdapRoleMappingMode) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setRoleNameAttribute(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setRoleRecursionMaxDepth(Integer) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setRoleSearchScope(LdapSearchScope) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setSalt(String) - Method in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
Sets the salt used for encryption.
setScheduledExecutorConfigs(Map<String, ScheduledExecutorConfig>) - Method in class com.hazelcast.config.Config
Sets the map of scheduled executor configurations, mapped by config name.
setScopeId(String) - Method in class com.hazelcast.cluster.Address
 
setScriptingEnabled(boolean) - Method in class com.hazelcast.config.ManagementCenterConfig
Enables/disables scripting on the member.
setSecretPath(String) - Method in class com.hazelcast.config.VaultSecureStoreConfig
Sets the Vault secret path where the encryption keys is expected to be stored.
setSecureStoreConfig(SecureStoreConfig) - Method in class com.hazelcast.config.EncryptionAtRestConfig
Sets the Secure Store configuration.
setSecurityConfig(ClientSecurityConfig) - Method in class com.hazelcast.client.config.ClientConfig
setSecurityConfig(SecurityConfig) - Method in class com.hazelcast.config.Config
Sets the security configuration for this hazelcast instance.
setSecurityInterceptorConfigs(List<SecurityInterceptorConfig>) - Method in class com.hazelcast.config.SecurityConfig
 
setSecurityRealm(String) - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
 
setSecurityRealm(String) - Method in class com.hazelcast.config.security.KerberosIdentityConfig
 
setSecurityRealm(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setSemaphoreConfigs(Map<String, SemaphoreConfig>) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets the map of CP ISemaphore configurations, mapped by config name.
setSerializationConfig(SerializationConfig) - Method in class com.hazelcast.client.config.ClientConfig
setSerializationConfig(SerializationConfig) - Method in class com.hazelcast.config.Config
Sets the serialization configuration for this hazelcast instance.
setSerializeKeys(boolean) - Method in class com.hazelcast.config.NearCacheConfig
Sets if the Near Cache key is stored in serialized format or by-reference.
setSerializerConfigs(Collection<SerializerConfig>) - Method in class com.hazelcast.config.SerializationConfig
 
setService(String) - Method in class com.hazelcast.client.config.ProxyFactoryConfig
 
setServiceNamePrefix(String) - Method in class com.hazelcast.config.security.KerberosIdentityConfig
 
setSessionHeartbeatIntervalSeconds(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets the interval for the periodically-committed CP session heartbeats.
setSessionTimeToLiveSeconds(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets the duration for a CP session to be kept alive after its last session heartbeat.
setSetConfigs(Map<String, SetConfig>) - Method in class com.hazelcast.config.Config
Sets the map of ISet configurations, mapped by config name.
setSize(int) - Method in class com.hazelcast.config.EvictionConfig
Sets the size which is used by the MaxSizePolicy.
setSize(MemorySize) - Method in class com.hazelcast.config.NativeMemoryConfig
Sets size of the native memory region.
setSkipAuthentication(Boolean) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setSkipEndpoint(Boolean) - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
 
setSkipIdentity(Boolean) - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
 
setSkipRole(Boolean) - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
 
setSmartRouting(boolean) - Method in class com.hazelcast.client.config.ClientNetworkConfig
If true, client will route the key based operations to owner of the key on best-effort basis.
setSnapshotEnabled(boolean) - Method in class com.hazelcast.config.WanBatchPublisherConfig
Sets if key-based coalescing is configured for this WAN publisher.
setSocketBufferDirect(boolean) - Method in class com.hazelcast.config.EndpointConfig
 
setSocketBufferDirect(boolean) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setSocketBufferDirect(boolean) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setSocketConnectTimeoutSeconds(int) - Method in class com.hazelcast.config.EndpointConfig
 
setSocketConnectTimeoutSeconds(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setSocketConnectTimeoutSeconds(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setSocketFactoryClassName(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.config.EndpointConfig
setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.config.NetworkConfig
setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setSocketKeepAlive(boolean) - Method in class com.hazelcast.config.EndpointConfig
 
setSocketKeepAlive(boolean) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setSocketKeepAlive(boolean) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setSocketLingerSeconds(int) - Method in class com.hazelcast.config.EndpointConfig
 
setSocketLingerSeconds(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setSocketLingerSeconds(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setSocketOptions(SocketOptions) - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
setSocketRcvBufferSizeKb(int) - Method in class com.hazelcast.config.EndpointConfig
 
setSocketRcvBufferSizeKb(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setSocketRcvBufferSizeKb(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setSocketSendBufferSizeKb(int) - Method in class com.hazelcast.config.EndpointConfig
 
setSocketSendBufferSizeKb(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setSocketSendBufferSizeKb(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setSocketTcpNoDelay(boolean) - Method in class com.hazelcast.config.EndpointConfig
 
setSocketTcpNoDelay(boolean) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setSocketTcpNoDelay(boolean) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setSplitBrainProtectionConfigs(Map<String, SplitBrainProtectionConfig>) - Method in class com.hazelcast.config.Config
Sets the map of split-brain protection configurations, mapped by config name.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.CacheConfig
Associates this cache configuration to a split brain protection.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Associates this cache configuration to a split brain protection.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Sets the split brain protection name for operations.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.CollectionConfig
Sets the split brain protection name for operations.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.DurableExecutorConfig
Sets the split brain protection name for operations.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.ExecutorConfig
Sets the split brain protection name for operations.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.MapConfig
 
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.MultiMapConfig
Sets the split brain protection name for operations.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.PNCounterConfig
Sets the split brain protection name for operations.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.QueueConfig
Sets the split brain protection name for queue operations.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.ReplicatedMapConfig
Sets the split brain protection name for operations.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.RingbufferConfig
Sets the split brain protection name for operations.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.ScheduledExecutorConfig
Sets the split brain protection name for operations.
setSpn(String) - Method in class com.hazelcast.config.security.KerberosIdentityConfig
 
setSql(String) - Method in class com.hazelcast.config.PredicateConfig
Sets sql string for this config.
setSql(String) - Method in class com.hazelcast.sql.SqlStatement
Sets the SQL string to be executed.
setSqlConfig(SqlConfig) - Method in class com.hazelcast.config.Config
Sets SQL config.
setSSLConfig(SSLConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Sets the SSLConfig.
setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.EndpointConfig
Sets the SSLConfig.
setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.NetworkConfig
Sets the SSLConfig.
setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.VaultSecureStoreConfig
Sets the SSL/TLS configuration.
setStatementTimeoutMillis(long) - Method in class com.hazelcast.config.SqlConfig
Sets the timeout in milliseconds that is applied to statements without an explicit timeout.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
Sets whether or not statistics gathering is enabled on this cache.
setStatisticsEnabled(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
Sets whether statistics gathering is enabled on a cache.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets statistics to enabled or disabled for this ICache.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.CollectionConfig
Sets collection statistics to enabled or disabled.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.DurableExecutorConfig
Enables or disables statistics gathering on the executor task.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ExecutorConfig
Enables or disables statistics gathering on the executor task.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Enables or disables statistics gathering of LocalFlakeIdGeneratorStats.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.MapConfig
Sets statistics to enabled or disabled for this map.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.MultiMapConfig
Enables or disables statistics for this MultiMap.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.PNCounterConfig
Enables or disables statistics for this PN counter
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.QueueConfig
Enables or disables statistics for this queue.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ReliableTopicConfig
Enables or disables statistics for this reliable topic.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ReplicatedMapConfig
Sets statistics to enabled or disabled for this replicated map.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ScheduledExecutorConfig
Enables or disables statistics gathering on the executor task.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.TopicConfig
Enables or disables statistics for this topic.
setStoreByValue(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
Set if a configured cache should use store-by-value or store-by-reference semantics.
setStoreByValue(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
Set if a configured cache should use store-by-value or store-by-reference semantics.
setStoreImplementation(QueueStore) - Method in class com.hazelcast.config.QueueStoreConfig
Sets the implementation of the queue store which will be used to store queue items.
setStoreImplementation(RingbufferStore) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
setStoreInitialDelaySeconds(int) - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
setStoreIntervalSeconds(int) - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
setSymmetricEncryptionConfig(SymmetricEncryptionConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setSymmetricEncryptionConfig(SymmetricEncryptionConfig) - Method in class com.hazelcast.config.EndpointConfig
setSymmetricEncryptionConfig(SymmetricEncryptionConfig) - Method in class com.hazelcast.config.NetworkConfig
setSymmetricEncryptionConfig(SymmetricEncryptionConfig) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setSymmetricEncryptionConfig(SymmetricEncryptionConfig) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setSyncConfig(WanSyncConfig) - Method in class com.hazelcast.config.WanBatchPublisherConfig
Sets the config for the WAN sync mechanism.
setSynchronous(boolean) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
If true, this cache entry listener implementation will be called in a synchronous manner.
setSystemAuthentication(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setSystemProperty(String) - Method in class com.hazelcast.spi.properties.HazelcastProperty
Sets the system property value of the property.
setSystemUserDn(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setSystemUserPassword(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setTailSequence(long) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Sets the tail sequence.
setTargetEndpoints(String) - Method in class com.hazelcast.config.WanBatchPublisherConfig
Sets the comma separated list of target cluster members, e.g.
setTcpIpConfig(TcpIpConfig) - Method in class com.hazelcast.config.JoinConfig
 
setTcpNoDelay(boolean) - Method in class com.hazelcast.client.config.SocketOptions
Enable/disable TCP_NODELAY socket option.
setTenant(boolean) - Method in interface com.hazelcast.spi.tenantcontrol.TenantControl
Establish this tenant's thread-local context Particular TenantControl implementation will control the details of how createRequestScope parameter is handled, but in general, if createRequestScope = false, only ClassLoader is set up, if createRequestScope = true, in addition to ClassLoader, other things like invocation, EJB/JPA/CDI context should be set up as well In other words, if only app class needs to be resolved, set createRequestScope to false If actually calling into user's code, set createRequestScope to true
setTenantControl(CacheConfig<K, V>, TenantControl) - Static method in class com.hazelcast.config.CacheConfigAccessor
 
setTimeout(long, TimeUnit) - Method in class com.hazelcast.transaction.TransactionOptions
Sets the timeout.
setTimeoutMillis(long) - Method in class com.hazelcast.sql.SqlStatement
Sets the execution timeout in milliseconds.
setTimeoutMilliseconds(int) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
setTimeoutMilliseconds(int) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
Sets the timeout in Milliseconds before declaring a failed ping This cannot be more than the interval value.
setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.EventJournalConfig
Sets the time to live in seconds.
setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.MapConfig
The maximum number of seconds for each entry to stay in the map.
setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.NearCacheConfig
Returns the maximum number of seconds for each entry to stay in the Near Cache (time to live).
setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.RingbufferConfig
Sets the time to live in seconds which is the maximum number of seconds for each item to stay in the ringbuffer before being removed.
setTlsAuthenticationConfig(TlsAuthenticationConfig) - Method in class com.hazelcast.config.security.RealmConfig
 
setToken(String) - Method in class com.hazelcast.config.VaultSecureStoreConfig
Sets the Vault access token.
setTokenIdentityConfig(TokenIdentityConfig) - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
setTokenIdentityConfig(TokenIdentityConfig) - Method in class com.hazelcast.config.security.RealmConfig
 
setTopicConfigs(Map<String, TopicConfig>) - Method in class com.hazelcast.config.Config
Sets the map of ITopic configurations, mapped by config name.
setTopicOverloadPolicy(TopicOverloadPolicy) - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
Sets the TopicOverloadPolicy for this reliable topic.
setTopicOverloadPolicy(TopicOverloadPolicy) - Method in class com.hazelcast.config.ReliableTopicConfig
Sets the TopicOverloadPolicy for this reliable topic.
setTransactionType(TransactionOptions.TransactionType) - Method in class com.hazelcast.transaction.TransactionOptions
setTrustedInterfaces(Set<String>) - Method in class com.hazelcast.config.ManagementCenterConfig
Sets the trusted interfaces.
setTrustedInterfaces(Set<String>) - Method in class com.hazelcast.config.MulticastConfig
Sets the trusted interfaces.
setTrustedInterfaces(Set<String>) - Method in interface com.hazelcast.config.TrustedInterfacesConfigurable
Sets the trusted interfaces.
setTryCount(int) - Method in class com.hazelcast.client.config.ClientFailoverConfig
Sets the count of attempts to connect to a cluster.
setTtl(int) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
setTtl(int) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
Sets the maximum number of times the IP Datagram (ping) can be forwarded, in most cases all Hazelcast cluster members would be within one network switch/router therefore
setTtl(K, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Updates the TTL (time to live) value of the entry specified by key with a new TTL value.
setType(IndexType) - Method in class com.hazelcast.config.IndexConfig
Sets type of the index.
setType(String) - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
Sets the Java KeyStore type (PKCS12, JCEKS etc.)
setType(PermissionConfig.PermissionType) - Method in class com.hazelcast.config.PermissionConfig
 
setTypeClass(Class) - Method in class com.hazelcast.config.SerializerConfig
Sets the type of the class that will be serialized via this implementation.
setTypeClassName(String) - Method in class com.hazelcast.config.SerializerConfig
This method is called only if typeClass is not set.
setTypes(Class<K>, Class<V>) - Method in class com.hazelcast.config.AbstractCacheConfig
Sets the expected type of keys and values for a Cache configured with this Configuration.
setTypes(Class<K>, Class<V>) - Method in interface com.hazelcast.config.CacheConfiguration
Sets the expected type of keys and values for a Cache configured with this Configuration.
setUncommittedEntryCountToRejectNewAppends(int) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
setUniqueKey(String) - Method in class com.hazelcast.config.BitmapIndexOptions
Sets unique key attribute in this index config.
setUniqueKeyTransformation(BitmapIndexOptions.UniqueKeyTransformation) - Method in class com.hazelcast.config.BitmapIndexOptions
Sets unique key transformation in this index config.
setUriString(String) - Method in class com.hazelcast.config.CacheConfig
Sets the URI string, which is the global identifier of the ICache.
setUrl(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setUsage(LoginModuleConfig.LoginModuleUsage) - Method in class com.hazelcast.config.LoginModuleConfig
 
setUseCanonicalHostname(Boolean) - Method in class com.hazelcast.config.security.KerberosIdentityConfig
 
setUseEndpointPrivateAddress(boolean) - Method in class com.hazelcast.config.WanBatchPublisherConfig
Sets whether the WAN connection manager should connect to the endpoint on the private address returned by the discovery SPI.
setUseNameWithoutRealm(Boolean) - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
 
setUseNativeByteOrder(boolean) - Method in class com.hazelcast.config.SerializationConfig
 
setUsePublicIp(boolean) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
Decides whether the public or private IP should be used to connect to Hazelcast members.
setUserCodeDeploymentConfig(ClientUserCodeDeploymentConfig) - Method in class com.hazelcast.client.config.ClientConfig
Set User Code Deployment configuration
setUserCodeDeploymentConfig(UserCodeDeploymentConfig) - Method in class com.hazelcast.config.Config
Set User Code Deployment configuration
setUserContext(ConcurrentMap<String, Object>) - Method in class com.hazelcast.client.config.ClientConfig
 
setUserContext(ConcurrentMap<String, Object>) - Method in class com.hazelcast.config.Config
Sets the user supplied context.
setUserContext(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setUserFilter(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setUserNameAttribute(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setUsernamePasswordIdentityConfig(UsernamePasswordIdentityConfig) - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
setUsernamePasswordIdentityConfig(String, String) - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
setUsernamePasswordIdentityConfig(UsernamePasswordIdentityConfig) - Method in class com.hazelcast.config.security.RealmConfig
 
setUsernamePasswordIdentityConfig(String, String) - Method in class com.hazelcast.config.security.RealmConfig
 
setUserSearchScope(LdapSearchScope) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setValidationTimeoutSeconds(int) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets validation timeout for hot-restart process, includes validating cluster members expected to join and partition table on all cluster.
setValue(V, long, TimeUnit) - Method in interface com.hazelcast.map.ExtendedMapEntry
Set the value and set the TTL to a non-default value for the IMap
setValueClassName(String) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setValueCollectionType(String) - Method in class com.hazelcast.config.MultiMapConfig
Sets the collection type for the values of this MultiMap.
setValueCollectionType(MultiMapConfig.ValueCollectionType) - Method in class com.hazelcast.config.MultiMapConfig
Sets the collection type for the values of this MultiMap.
setValueType(Class<V>) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setValueType(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the value type for this ICache.
setVersion(Version) - Method in interface com.hazelcast.nio.VersionAware
If the serializer supports versioning it may set the version to use for the serialization on this object.
setWanProtocolVersion(Version) - Method in interface com.hazelcast.nio.WanProtocolVersionAware
Sets the WAN protocol version.
setWanReplicationConfigs(Map<String, WanReplicationConfig>) - Method in class com.hazelcast.config.Config
Sets the map of WAN replication configurations, mapped by config name.
setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.CacheConfig
 
setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the WAN target replication reference.
setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.MapConfig
Sets the WAN target replication reference.
setWhitelist(ClassFilter) - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
setWhitelistedPrefixes(String) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Comma-separated list of class prefixes which will be loaded remotely.
setWriteBatchSize(int) - Method in class com.hazelcast.config.MapStoreConfig
Sets the number of operations to be included in each batch processing round.
setWriteCoalescing(boolean) - Method in class com.hazelcast.config.MapStoreConfig
Setting MapStoreConfig.writeCoalescing is meaningful if you are using write-behind MapStore.
setWriteDelaySeconds(int) - Method in class com.hazelcast.config.MapStoreConfig
Sets the number of seconds to delay before writing (storing) the dirty records
setWriteThrough(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setWriteThrough(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
Set if write-through caching should be used.
setWriteThrough(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
Enables or disables write-through for this ICache: a write to the queue also loads the entry into the data store.
severe(String) - Method in class com.hazelcast.logging.AbstractLogger
 
severe(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
severe(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
severe(String) - Method in interface com.hazelcast.logging.ILogger
Logs a message at Level.SEVERE.
severe(Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a throwable at the Level.SEVERE level.
severe(String, Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a message with an associated throwable at the Level.SEVERE level.
SHARED_JCACHE_INSTANCE_NAME - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
Name of default HazelcastInstance which may be started when obtaining the default CachingProvider.
shouldHandle(OutOfMemoryError) - Method in class com.hazelcast.core.OutOfMemoryHandler
Decides if the OutOfMemoryError thrown will be handled by this OutOfMemoryHandler or not.
SHUFFLE_MEMBER_LIST - Static variable in class com.hazelcast.client.properties.ClientProperty
Client shuffles the given member list to prevent all clients to connect to the same node when this property is set to true.
shutdown(HazelcastInstance) - Static method in class com.hazelcast.client.HazelcastClient
Shutdown the provided client and remove it from the managed list
shutdown(String) - Static method in class com.hazelcast.client.HazelcastClient
Shutdown the provided client and remove it from the managed list
shutdown() - Method in interface com.hazelcast.cluster.Cluster
Changes state of the cluster to the ClusterState.PASSIVE transactionally, then triggers the shutdown process on each node.
shutdown(TransactionOptions) - Method in interface com.hazelcast.cluster.Cluster
Changes state of the cluster to the ClusterState.PASSIVE transactionally, then triggers the shutdown process on each node.
shutdown() - Method in interface com.hazelcast.core.HazelcastInstance
Shuts down this HazelcastInstance.
shutdown() - Method in interface com.hazelcast.core.LifecycleService
Gracefully shuts down HazelcastInstance.
shutdown() - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Initiates an orderly shutdown in which previously submitted tasks are executed, but no new tasks will be accepted.
shutdown() - Method in interface com.hazelcast.wan.WanConsumer
Callback method to shutdown the WAN replication consumer.
shutdown() - Method in interface com.hazelcast.wan.WanPublisher
Closes the publisher and its internal connections and shuts down other internal states.
shutdownAll() - Static method in class com.hazelcast.client.HazelcastClient
Shuts down all the client HazelcastInstance created in this JVM.
shutdownAll() - Static method in class com.hazelcast.core.Hazelcast
Shuts down all member HazelcastInstances running on this JVM.
shutdownAll() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Shuts down all running HazelcastOSGiInstances on the owner bundle.
shutdownHazelcastInstance(HazelcastOSGiInstance) - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Shuts down the given HazelcastOSGiInstance on the owner bundle.
SHUTDOWNHOOK_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Enable Hazelcast shutdownhook thread.
SHUTDOWNHOOK_POLICY - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Behaviour when JVM is about to exit while Hazelcast instance is still running.
SilentException - Interface in com.hazelcast.spi.exception
Marked interface for exceptions.
SimpleDiscoveryNode - Class in com.hazelcast.spi.discovery
Simple immutable implementation of the DiscoveryNode interface for convenience when implementing a DiscoveryStrategy.
SimpleDiscoveryNode(Address) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
This constructor will set private and public addresses to the same value and no properties are available.
SimpleDiscoveryNode(Address, Map<String, String>) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
This constructor will set private and public addresses to the same value.
SimpleDiscoveryNode(Address, Address) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
This constructor will set private and public addresses separately and no properties are available.
SimpleDiscoveryNode(Address, Address, Map<String, String>) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
This constructor will set private and public addresses separately.
SimplePropertyDefinition - Class in com.hazelcast.config.properties
Simple immutable implementation of PropertyDefinition for convenience of implementors.
SimplePropertyDefinition(String, TypeConverter) - Constructor for class com.hazelcast.config.properties.SimplePropertyDefinition
 
SimplePropertyDefinition(String, boolean, TypeConverter) - Constructor for class com.hazelcast.config.properties.SimplePropertyDefinition
 
SimplePropertyDefinition(String, boolean, TypeConverter, ValueValidator) - Constructor for class com.hazelcast.config.properties.SimplePropertyDefinition
 
SimpleTokenCredentials - Class in com.hazelcast.security
Simple implementation of Credentials using a raw byte array token.
SimpleTokenCredentials() - Constructor for class com.hazelcast.security.SimpleTokenCredentials
 
SimpleTokenCredentials(byte[]) - Constructor for class com.hazelcast.security.SimpleTokenCredentials
 
SimulateLoadTask - Class in com.hazelcast.console
A simulated load test.
SimulateLoadTask(int, int, String) - Constructor for class com.hazelcast.console.SimulateLoadTask
 
singleAttribute(String) - Static method in class com.hazelcast.projection.Projections
Returns a projection that extracts the value of the given attributePath.
size() - Method in interface com.hazelcast.cache.ICache
Total entry count.
size() - Method in interface com.hazelcast.collection.BaseQueue
Returns the number of elements in this collection.
size - Variable in class com.hazelcast.config.EvictionConfig
 
size() - Method in interface com.hazelcast.map.BaseMap
Returns the number of entries in this map.
size() - Method in interface com.hazelcast.map.QueryCache
 
size() - Method in interface com.hazelcast.multimap.BaseMultiMap
Returns the number of key-value pairs in the multimap.
size() - Method in interface com.hazelcast.multimap.MultiMap
Returns the number of key-value pairs in the multimap.
size() - Method in interface com.hazelcast.ringbuffer.ReadResultSet
Return the result set size.
size() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Returns number of items in the Ringbuffer.
size() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Returns number of items in the ringbuffer (meaning the number of items between the RingbufferMergeData.getHeadSequence() and RingbufferMergeData.getTailSequence()).
size() - Method in interface com.hazelcast.spi.partitiongroup.MemberGroup
 
size() - Method in interface com.hazelcast.transaction.TransactionalList
Returns the size of the list.
size() - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of Map.size().
size() - Method in interface com.hazelcast.transaction.TransactionalMultiMap
Returns the number of key-value pairs in the multimap.
size() - Method in interface com.hazelcast.transaction.TransactionalQueue
Returns the number of elements in this collection.
size() - Method in interface com.hazelcast.transaction.TransactionalSet
Returns the size of the set.
skip(long) - Method in class com.hazelcast.config.ConfigStream
 
Slf4jFactory - Class in com.hazelcast.logging
 
Slf4jFactory() - Constructor for class com.hazelcast.logging.Slf4jFactory
 
SLOW_OPERATION_DETECTOR_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Enables or disables the SlowOperationDetector.
SLOW_OPERATION_DETECTOR_LOG_PURGE_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Purge interval for slow operation logs.
SLOW_OPERATION_DETECTOR_LOG_RETENTION_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
This value defines the retention time of invocations in slow operation logs.
SLOW_OPERATION_DETECTOR_STACK_TRACE_LOGGING_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Defines if the stacktraces of slow operations are logged in the log file.
SLOW_OPERATION_DETECTOR_THRESHOLD_MILLIS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Defines a threshold above which a running operation in OperationService is considered to be slow.
SOCKET_BIND_ANY - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Bind both server-socket and client-sockets to any local interface.
SOCKET_BUFFER_DIRECT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
If the bytebuffers used in the socket should be a direct bytebuffer (true) or a regular bytebuffer (false).
SOCKET_CLIENT_BIND - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Bind client socket to an interface when connecting to a remote server socket.
SOCKET_CLIENT_BIND_ANY - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Bind client-sockets to any local interface.
SOCKET_CLIENT_BUFFER_DIRECT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
If the bytebuffers used in the socket should be a direct bytebuffer (true) or a regular bytebuffer (false).
SOCKET_CLIENT_RECEIVE_BUFFER_SIZE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Overrides receive buffer size for connections opened by clients.
SOCKET_CLIENT_SEND_BUFFER_SIZE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Overrides send buffer size for connections opened by clients.
SOCKET_CONNECT_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Socket connection timeout in seconds.
SOCKET_KEEP_ALIVE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Socket set keep alive (SO_KEEPALIVE).
SOCKET_LINGER_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Set socket SO_LINGER option.
SOCKET_NO_DELAY - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Socket set TCP no delay.
SOCKET_RECEIVE_BUFFER_SIZE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Socket receive buffer (SO_RCVBUF) size in KB.
SOCKET_SEND_BUFFER_SIZE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Socket send buffer (SO_SNDBUF) size in KB.
SOCKET_SERVER_BIND_ANY - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Bind server-socket to any local interface.
SocketInterceptor - Interface in com.hazelcast.nio
An interface that provides the ability to intercept the creation of sockets.
socketInterceptorConfig - Variable in class com.hazelcast.config.EndpointConfig
 
SocketInterceptorConfig - Class in com.hazelcast.config
Contains the configuration for interceptor socket.
SocketInterceptorConfig() - Constructor for class com.hazelcast.config.SocketInterceptorConfig
 
SocketInterceptorConfig(SocketInterceptorConfig) - Constructor for class com.hazelcast.config.SocketInterceptorConfig
 
SocketOptions - Class in com.hazelcast.client.config
TCP Socket options
SocketOptions() - Constructor for class com.hazelcast.client.config.SocketOptions
 
SocketOptions(SocketOptions) - Constructor for class com.hazelcast.client.config.SocketOptions
 
SplitBrainMergePolicy<V,T extends MergingValue<V>,R> - Interface in com.hazelcast.spi.merge
Policy for merging data structure values after a split-brain has been healed.
SplitBrainMergePolicyProvider - Class in com.hazelcast.spi.merge
A provider for SplitBrainMergePolicy instances.
SplitBrainMergePolicyProvider(NodeEngine) - Constructor for class com.hazelcast.spi.merge.SplitBrainMergePolicyProvider
Constructs a new provider for SplitBrainMergePolicy classes.
SplitBrainMergeTypes - Class in com.hazelcast.spi.merge
Collection of interfaces which define the provided merge types for each data structure.
SplitBrainMergeTypes() - Constructor for class com.hazelcast.spi.merge.SplitBrainMergeTypes
 
SplitBrainMergeTypes.AtomicLongMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of IAtomicLong.
SplitBrainMergeTypes.AtomicReferenceMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of IAtomicReference.
SplitBrainMergeTypes.CacheMergeTypes<K,V> - Interface in com.hazelcast.spi.merge
Provided merge types of ICache.
SplitBrainMergeTypes.CardinalityEstimatorMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of CardinalityEstimator.
SplitBrainMergeTypes.CollectionMergeTypes<V> - Interface in com.hazelcast.spi.merge
Provided merge types of collections (ISet and IList).
SplitBrainMergeTypes.MapMergeTypes<K,V> - Interface in com.hazelcast.spi.merge
Provided merge types of IMap.
SplitBrainMergeTypes.MultiMapMergeTypes<K,V> - Interface in com.hazelcast.spi.merge
Provided merge types of MultiMap.
SplitBrainMergeTypes.QueueMergeTypes<V> - Interface in com.hazelcast.spi.merge
Provided merge types of IQueue.
SplitBrainMergeTypes.ReplicatedMapMergeTypes<K,V> - Interface in com.hazelcast.spi.merge
Provided merge types of ReplicatedMap.
SplitBrainMergeTypes.RingbufferMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of Ringbuffer.
SplitBrainMergeTypes.ScheduledExecutorMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of IScheduledExecutorService.
SplitBrainProtection - Interface in com.hazelcast.splitbrainprotection
SplitBrainProtection provides access to the current status of a split brain protection.
SplitBrainProtectionConfig - Class in com.hazelcast.config
Configuration for cluster split brain protection, a means to protect consistency of data from network partitions.
SplitBrainProtectionConfig() - Constructor for class com.hazelcast.config.SplitBrainProtectionConfig
 
SplitBrainProtectionConfig(String, boolean) - Constructor for class com.hazelcast.config.SplitBrainProtectionConfig
 
SplitBrainProtectionConfig(String, boolean, int) - Constructor for class com.hazelcast.config.SplitBrainProtectionConfig
 
SplitBrainProtectionConfig(SplitBrainProtectionConfig) - Constructor for class com.hazelcast.config.SplitBrainProtectionConfig
 
SplitBrainProtectionConfigBuilder - Class in com.hazelcast.config
Commons for split brain protection config builders.
SplitBrainProtectionConfigBuilder() - Constructor for class com.hazelcast.config.SplitBrainProtectionConfigBuilder
 
SplitBrainProtectionEvent - Class in com.hazelcast.splitbrainprotection
An Event that is send when a SplitBrainProtection changes.
SplitBrainProtectionEvent(Object, int, Collection<Member>, boolean) - Constructor for class com.hazelcast.splitbrainprotection.SplitBrainProtectionEvent
 
SplitBrainProtectionException - Exception in com.hazelcast.splitbrainprotection
An exception thrown when the cluster size is below the defined threshold.
SplitBrainProtectionException(String) - Constructor for exception com.hazelcast.splitbrainprotection.SplitBrainProtectionException
 
SplitBrainProtectionFunction - Interface in com.hazelcast.splitbrainprotection
A function that can be used to conclude whether the minimum cluster size property is satisfied? The split brain protection function is consulted:
When a cluster membership change occurs (member added or removed) Whenever a hearbeat is received from a member, in case the SplitBrainProtectionFunction also implements HeartbeatAware A SplitBrainProtectionFunction that implements HeartbeatAware will be also notified of heartbeats.
SplitBrainProtectionListener - Interface in com.hazelcast.splitbrainprotection
Listener to get notified when a split brain protection state is changed.
SplitBrainProtectionListenerConfig - Class in com.hazelcast.config
Configuration class for SplitBrainProtectionListener
SplitBrainProtectionListenerConfig() - Constructor for class com.hazelcast.config.SplitBrainProtectionListenerConfig
 
SplitBrainProtectionListenerConfig(String) - Constructor for class com.hazelcast.config.SplitBrainProtectionListenerConfig
 
SplitBrainProtectionListenerConfig(SplitBrainProtectionListener) - Constructor for class com.hazelcast.config.SplitBrainProtectionListenerConfig
 
SplitBrainProtectionOn - Enum in com.hazelcast.splitbrainprotection
Represents a cluster split brain protection type
SplitBrainProtectionService - Interface in com.hazelcast.splitbrainprotection
Split brain protection service can be used to trigger cluster split brain protections at any time.
SpringAware - Annotation Type in com.hazelcast.spring.context
Annotates a class for injection of Spring dependencies.
SpringHazelcastCachingProvider - Class in com.hazelcast.spring.cache
Spring utility class for connecting HazelcastCachingProvider interface and Hazelcast instance.
SpringManagedContext - Class in com.hazelcast.spring.context
ManagedContext implementation for Hazelcast.
SpringManagedContext() - Constructor for class com.hazelcast.spring.context.SpringManagedContext
 
SpringManagedContext(ApplicationContext) - Constructor for class com.hazelcast.spring.context.SpringManagedContext
 
SpringXmlBuilder(ParserContext, BeanDefinitionBuilder) - Constructor for class com.hazelcast.spring.HazelcastClientBeanDefinitionParser.SpringXmlBuilder
 
SpringXmlBuilderHelper() - Constructor for class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
sql - Variable in class com.hazelcast.config.PredicateConfig
 
sql(String) - Static method in class com.hazelcast.query.Predicates
Creates a predicate that will pass items that match the given SQL 'where' expression.
SqlColumnMetadata - Class in com.hazelcast.sql
SQL column metadata.
SqlColumnMetadata(String, SqlColumnType) - Constructor for class com.hazelcast.sql.SqlColumnMetadata
 
SqlColumnType - Enum in com.hazelcast.sql
SQL column type.
SqlConfig - Class in com.hazelcast.config
SQL service configuration.
SqlConfig() - Constructor for class com.hazelcast.config.SqlConfig
 
SqlResult - Interface in com.hazelcast.sql
SQL query result.
SqlRow - Interface in com.hazelcast.sql
SQL row.
SqlRowMetadata - Class in com.hazelcast.sql
SQL row metadata.
SqlRowMetadata(List<SqlColumnMetadata>) - Constructor for class com.hazelcast.sql.SqlRowMetadata
 
SqlService - Interface in com.hazelcast.sql
A service to execute SQL statements.
SqlStatement - Class in com.hazelcast.sql
Definition of an SQL statement.
SqlStatement(String) - Constructor for class com.hazelcast.sql.SqlStatement
 
sslConfig - Variable in class com.hazelcast.config.EndpointConfig
 
SSLConfig - Class in com.hazelcast.config
SSL configuration.
SSLConfig() - Constructor for class com.hazelcast.config.SSLConfig
 
SSLConfig(SSLConfig) - Constructor for class com.hazelcast.config.SSLConfig
 
StaleAppendRequestException - Exception in com.hazelcast.cp.exception
A CPSubsystemException which is thrown when a Raft leader node appends an entry to its local Raft log, but demotes to the follower role before learning the commit status of the entry.
StaleAppendRequestException(RaftEndpoint) - Constructor for exception com.hazelcast.cp.exception.StaleAppendRequestException
 
StaleSequenceException - Exception in com.hazelcast.ringbuffer
An RuntimeException that is thrown when accessing an item in the Ringbuffer using a sequence that is smaller than the current head sequence and that the ringbuffer store is disabled.
StaleSequenceException(String, long) - Constructor for exception com.hazelcast.ringbuffer.StaleSequenceException
Creates a StaleSequenceException with the given message.
StaleSequenceException(String, long, Throwable) - Constructor for exception com.hazelcast.ringbuffer.StaleSequenceException
 
StaleTaskException - Exception in com.hazelcast.scheduledexecutor
Exception thrown by the IScheduledFuture during any operation on a stale (=previously destroyed) task.
StaleTaskException(String) - Constructor for exception com.hazelcast.scheduledexecutor.StaleTaskException
 
StaleTaskIdException - Exception in com.hazelcast.durableexecutor
An RuntimeException that is thrown when retrieving the result of a task via DurableExecutorService if the result of the task is overwritten.
StaleTaskIdException(String) - Constructor for exception com.hazelcast.durableexecutor.StaleTaskIdException
 
StandardLoggerFactory - Class in com.hazelcast.logging
 
StandardLoggerFactory() - Constructor for class com.hazelcast.logging.StandardLoggerFactory
 
start() - Method in class com.hazelcast.console.ConsoleApp
 
start() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
 
start() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategy
The start method is used to initialize internal state and perform any kind of startup procedure like multicast socket creation.
start() - Method in interface com.hazelcast.spi.discovery.integration.DiscoveryService
The start method is called on system startup to implement simple lifecycle management.
start() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategy
 
stateChanged(LifecycleEvent) - Method in interface com.hazelcast.core.LifecycleListener
Called when instance's state changes.
StatefulTask<K,V> - Interface in com.hazelcast.scheduledexecutor
An interface to provide means for saving & loading state for Runnable and Callable tasks scheduled with an IScheduledExecutorService.
StaticCredentialsFactory - Class in com.hazelcast.config.security
The credentials factory implementation which just takes credentials in a constructor and provides it for every StaticCredentialsFactory.newCredentials() call.
StaticCredentialsFactory(Credentials) - Constructor for class com.hazelcast.config.security.StaticCredentialsFactory
 
STATISTICS_ENABLED - Static variable in class com.hazelcast.client.properties.ClientProperty
Use to enable the client statistics collection.
STATISTICS_PERIOD_SECONDS - Static variable in class com.hazelcast.client.properties.ClientProperty
The period in seconds the statistics run.
status() - Method in interface com.hazelcast.cp.CPGroup
Returns status of the CP group
stop() - Method in class com.hazelcast.console.ConsoleApp
 
store(Long, T) - Method in interface com.hazelcast.collection.QueueStore
Stores the key-value pair.
store(K, V) - Method in interface com.hazelcast.map.MapStore
Stores the key-value pair.
store(K, V) - Method in class com.hazelcast.map.MapStoreAdapter
Stores the key-value pair.
store(long, T) - Method in interface com.hazelcast.ringbuffer.RingbufferStore
Stores one item with it's corresponding sequence.
STORE_BINARY - Static variable in class com.hazelcast.config.QueueStoreConfig
Binary: By default, Hazelcast stores the queue items in serialized form in memory.
STORE_BULK_LOAD - Static variable in class com.hazelcast.config.QueueStoreConfig
Bulk Load: When the queue is initialized, items are loaded from QueueStore in bulks.
STORE_MEMORY_LIMIT - Static variable in class com.hazelcast.config.QueueStoreConfig
Memory Limit: This is the number of items after which Hazelcast will store items only to datastore.
storeAll(Map<Long, T>) - Method in interface com.hazelcast.collection.QueueStore
Stores multiple entries.
storeAll(Map<K, V>) - Method in interface com.hazelcast.map.MapStore
Stores multiple entries.
storeAll(Map<K, V>) - Method in class com.hazelcast.map.MapStoreAdapter
Stores multiple entries.
storeAll(long, T[]) - Method in interface com.hazelcast.ringbuffer.RingbufferStore
Stores multiple items.
storeSequence(long) - Method in interface com.hazelcast.topic.ReliableMessageListener
Informs the ReliableMessageListener that it should store the sequence.
StreamSerializer<T> - Interface in com.hazelcast.nio.serialization
A base class for custom serialization.
StringAndPartitionAwarePartitioningStrategy - Class in com.hazelcast.partition.strategy
 
StringPartitioningStrategy - Class in com.hazelcast.partition.strategy
 
StringPartitioningStrategy() - Constructor for class com.hazelcast.partition.strategy.StringPartitioningStrategy
 
submit(Callable<T>, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to a randomly selected member and returns a Future representing that task.
submit(Runnable, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to a random member.
submit(Runnable, MemberSelector, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to randomly selected members.
submit(Callable<T>, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to a random member.
submit(Callable<T>, MemberSelector, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits task to a randomly selected member.
submit(Callable<T>) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Submits a value-returning task for execution and returns a Future representing the pending results of the task.
submit(Runnable, T) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Submits a Runnable task for execution and returns a Future representing that task.
submit(Runnable) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Submits a Runnable task for execution and returns a Future representing that task.
submitToAllMembers(Callable<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits task to all cluster members and returns a map of Member-Future pairs representing pending completion of the task on each member.
submitToAllMembers(Runnable, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
Submits task to all the cluster members.
submitToAllMembers(Callable<T>, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
Submits task to all the cluster members.
submitToKey(K, EntryProcessor<K, V, R>) - Method in interface com.hazelcast.map.IMap
Applies the user defined EntryProcessor to the entry mapped by the key.
submitToKeyOwner(Callable<T>, Object) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to the owner of the specified key and returns a Future representing that task.
submitToKeyOwner(Runnable, Object, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to the owner of the specified key.
submitToKeyOwner(Callable<T>, Object, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits task to the owner of the specified key.
submitToKeyOwner(Callable<T>, Object) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Submits a task to the owner of the specified key and returns a Future representing that task.
submitToKeyOwner(Runnable, Object) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Submits a task to the owner of the specified key and returns a Future representing that task.
submitToKeys(Set<K>, EntryProcessor<K, V, R>) - Method in interface com.hazelcast.map.IMap
submitToMember(Callable<T>, Member) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to the specified member and returns a Future representing that task.
submitToMember(Runnable, Member, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to the specified member.
submitToMember(Callable<T>, Member, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to the specified member.
submitToMembers(Callable<T>, Collection<Member>) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to given members and returns map of Member-Future pairs representing pending completion of the task on each member
submitToMembers(Callable<T>, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to selected members and returns a map of Member-Future pairs representing pending completion of the task on each member.
submitToMembers(Runnable, Collection<Member>, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to the specified members.
submitToMembers(Runnable, MemberSelector, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
Submits task to the selected members.
submitToMembers(Callable<T>, Collection<Member>, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to the specified members.
submitToMembers(Callable<T>, MemberSelector, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
Submits task to the selected members.
subtractAndGet(long) - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Subtracts the given value from the current value.
SupplierEx<T> - Interface in com.hazelcast.function
Serializable variant of java.util.function.Supplier which declares checked exception.
symmetricEncryptionConfig - Variable in class com.hazelcast.config.EndpointConfig
 
SymmetricEncryptionConfig - Class in com.hazelcast.config
Contains configuration for symmetric encryption
SymmetricEncryptionConfig() - Constructor for class com.hazelcast.config.SymmetricEncryptionConfig
 

T

tailSequence() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Returns the sequence of the tail.
take() - Method in interface com.hazelcast.collection.BaseQueue
Retrieves and removes the head of this queue, waiting if necessary until an element becomes available.
take() - Method in interface com.hazelcast.collection.IQueue
Retrieves and removes the head of this queue, waiting if necessary until an element becomes available.
take() - Method in interface com.hazelcast.transaction.TransactionalQueue
Retrieves and removes the head of this queue, waiting if necessary until an element becomes available.
TargetDisconnectedException - Exception in com.hazelcast.spi.exception
Thrown when a client invocation is failed because related target is disconnected and whether the invocation is run or not, is indeterminate
TargetDisconnectedException(String) - Constructor for exception com.hazelcast.spi.exception.TargetDisconnectedException
 
TargetDisconnectedException(String, Throwable) - Constructor for exception com.hazelcast.spi.exception.TargetDisconnectedException
 
TargetNotMemberException - Exception in com.hazelcast.spi.exception
A RetryableHazelcastException that indicates operation was sent to a machine that isn't member of the cluster.
TargetNotMemberException(String) - Constructor for exception com.hazelcast.spi.exception.TargetNotMemberException
 
TargetNotMemberException(Object, int, String, String) - Constructor for exception com.hazelcast.spi.exception.TargetNotMemberException
 
TargetNotReplicaException - Exception in com.hazelcast.crdt
Exception that indicates that the receiver of a CRDT operation is not a CRDT replica.
TargetNotReplicaException(String) - Constructor for exception com.hazelcast.crdt.TargetNotReplicaException
 
TaskUtils - Class in com.hazelcast.scheduledexecutor
A helper class with utilities to act upon Runnable and/or Callable tasks.
TCP_JOIN_PORT_TRY_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
The number of incremental ports, starting with port number defined in network configuration, that will be used to connect to a host which is defined without a port in the TCP-IP member list while a node is searching for a cluster.
TcpIpConfig - Class in com.hazelcast.config
Contains the configuration for the Tcp/Ip join mechanism.
TcpIpConfig() - Constructor for class com.hazelcast.config.TcpIpConfig
 
TenantControl - Interface in com.hazelcast.spi.tenantcontrol
Hooks for multi-tenancy for application servers Hazelcast uses separate threads to invoke operations this interface acts a hook to establish a thread-local tenant context so that operation invocations into application servers are handled correctly This is used by application servers to establish thread context for class loading, CDI, EJB and JPA invocations
TenantControlFactory - Interface in com.hazelcast.spi.tenantcontrol
A TenantControlFactory supplies TenantControl objects when Hazelcast service attaches the tenant control to a distributed object.
terminate() - Method in interface com.hazelcast.core.LifecycleService
Terminate HazelcastInstance ungracefully.
test(T, U) - Method in interface com.hazelcast.function.BiPredicateEx
 
test(T) - Method in interface com.hazelcast.function.PredicateEx
 
test(DiscoveryNode) - Method in interface com.hazelcast.spi.discovery.NodeFilter
Accepts or denies a DiscoveryNode based on the implemented rules.
testEx(T, U) - Method in interface com.hazelcast.function.BiPredicateEx
Exception-declaring version of BiPredicate.test(T, U).
testEx(T) - Method in interface com.hazelcast.function.PredicateEx
Exception-declaring version of Predicate.test(T).
thenComparing(Comparator<? super T>) - Method in interface com.hazelcast.function.ComparatorEx
thenComparing(ComparatorEx<? super T>) - Method in interface com.hazelcast.function.ComparatorEx
thenComparing(Function<? super T, ? extends U>, Comparator<? super U>) - Method in interface com.hazelcast.function.ComparatorEx
thenComparing(FunctionEx<? super T, ? extends U>, ComparatorEx<? super U>) - Method in interface com.hazelcast.function.ComparatorEx
thenComparing(Function<? super T, ? extends U>) - Method in interface com.hazelcast.function.ComparatorEx
thenComparing(FunctionEx<? super T, ? extends U>) - Method in interface com.hazelcast.function.ComparatorEx
thenComparingDouble(ToDoubleFunction<? super T>) - Method in interface com.hazelcast.function.ComparatorEx
thenComparingDouble(ToDoubleFunctionEx<? super T>) - Method in interface com.hazelcast.function.ComparatorEx
thenComparingInt(ToIntFunction<? super T>) - Method in interface com.hazelcast.function.ComparatorEx
thenComparingInt(ToIntFunctionEx<? super T>) - Method in interface com.hazelcast.function.ComparatorEx
thenComparingLong(ToLongFunction<? super T>) - Method in interface com.hazelcast.function.ComparatorEx
thenComparingLong(ToLongFunctionEx<? super T>) - Method in interface com.hazelcast.function.ComparatorEx
TimedExpiryPolicyFactoryConfig() - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
TimedExpiryPolicyFactoryConfig(CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType, CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
TIMEOUT_DISABLED - Static variable in class com.hazelcast.sql.SqlStatement
Value for the timeout that is disabled.
TIMEOUT_NOT_SET - Static variable in class com.hazelcast.sql.SqlStatement
Value for the timeout that is not set.
timestamp(long) - Method in interface com.hazelcast.auditlog.EventBuilder
If provided value greater than zero, then it sets the event timestamp explicitly.
TlsAuthenticationConfig - Class in com.hazelcast.config.security
Typed authentication configuration for the X509CertificateLoginModule.
TlsAuthenticationConfig() - Constructor for class com.hazelcast.config.security.TlsAuthenticationConfig
 
toByteArray() - Method in interface com.hazelcast.nio.ObjectDataOutput
 
toByteArray(int) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
toBytes(long) - Method in enum com.hazelcast.memory.MemoryUnit
 
ToDoubleFunctionEx<T> - Interface in com.hazelcast.function
Serializable variant of java.util.function.ToDoubleFunction which declares checked exception.
toGigaBytes(long) - Method in enum com.hazelcast.memory.MemoryUnit
 
ToIntFunctionEx<T> - Interface in com.hazelcast.function
Serializable variant of java.util.function.ToIntFunction which declares checked exception.
TokenCredentials - Interface in com.hazelcast.security
Credentials type for custom authentication (token based).
TokenEncoding - Enum in com.hazelcast.config.security
Possible token encodings.
TokenIdentityConfig - Class in com.hazelcast.config.security
Simple token identity configuration.
TokenIdentityConfig(TokenEncoding, String) - Constructor for class com.hazelcast.config.security.TokenIdentityConfig
 
TokenIdentityConfig(byte[]) - Constructor for class com.hazelcast.config.security.TokenIdentityConfig
 
toKiloBytes(long) - Method in enum com.hazelcast.memory.MemoryUnit
 
ToLongFunctionEx<T> - Interface in com.hazelcast.function
Serializable variant of java.util.function.ToLongFunction which declares checked exception.
toMegaBytes(long) - Method in enum com.hazelcast.memory.MemoryUnit
 
TopicConfig - Class in com.hazelcast.config
Contains the configuration for a ITopic.
TopicConfig() - Constructor for class com.hazelcast.config.TopicConfig
Creates a TopicConfig.
TopicConfig(String) - Constructor for class com.hazelcast.config.TopicConfig
Creates a TopicConfig with the given name.
TopicConfig(TopicConfig) - Constructor for class com.hazelcast.config.TopicConfig
Creates a TopicConfig by cloning another TopicConfig.
TopicOverloadException - Exception in com.hazelcast.topic
A HazelcastException thrown when a publisher wants to write to a topic, but there is not sufficient storage to deal with the event.
TopicOverloadException(String) - Constructor for exception com.hazelcast.topic.TopicOverloadException
Creates a TopicOverloadException.
TopicOverloadPolicy - Enum in com.hazelcast.topic
A policy to deal with an overloaded topic; so topic where there is no place to store new messages.
TopicPermission - Class in com.hazelcast.security.permission
 
TopicPermission(String, String...) - Constructor for class com.hazelcast.security.permission.TopicPermission
 
toPrettyString() - Method in class com.hazelcast.memory.MemorySize
Returns a pretty format String representation of this memory size.
toPrettyString(long) - Static method in class com.hazelcast.memory.MemorySize
Utility method to create a pretty format representation of given value in bytes.
toPrettyString(long, MemoryUnit) - Static method in class com.hazelcast.memory.MemorySize
Utility method to create a pretty format representation of given value in given unit.
toSearchControlValue() - Method in enum com.hazelcast.config.security.LdapSearchScope
 
toStoreValue(Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
 
toString() - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
toString() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
 
toString() - Method in class com.hazelcast.client.config.ClientCloudConfig
 
toString() - Method in class com.hazelcast.client.config.ClientConfig
 
toString() - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
 
toString() - Method in class com.hazelcast.client.config.ClientFailoverConfig
 
toString() - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
 
toString() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
toString() - Method in class com.hazelcast.client.config.ClientMetricsConfig
 
toString() - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
toString() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
 
toString() - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
toString() - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
toString() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
 
toString() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
 
toString() - Method in class com.hazelcast.client.config.SocketOptions
 
toString() - Method in class com.hazelcast.cluster.Address
 
toString() - Method in class com.hazelcast.cluster.InitialMembershipEvent
 
toString() - Method in class com.hazelcast.cluster.MembershipEvent
 
toString() - Method in class com.hazelcast.collection.ItemEvent
 
toString() - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
 
toString() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
toString() - Method in class com.hazelcast.config.AdvancedNetworkConfig
 
toString() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
 
toString() - Method in class com.hazelcast.config.AttributeConfig
 
toString() - Method in class com.hazelcast.config.AutoDetectionConfig
 
toString() - Method in class com.hazelcast.config.BitmapIndexOptions
 
toString() - Method in enum com.hazelcast.config.BitmapIndexOptions.UniqueKeyTransformation
 
toString() - Method in class com.hazelcast.config.CacheConfig
 
toString() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
toString() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
toString() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
toString() - Method in class com.hazelcast.config.CacheSimpleConfig
 
toString() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
toString() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
toString() - Method in class com.hazelcast.config.ClassFilter
 
toString() - Method in class com.hazelcast.config.Config
 
toString() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
 
toString() - Method in class com.hazelcast.config.cp.FencedLockConfig
 
toString() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
toString() - Method in class com.hazelcast.config.cp.SemaphoreConfig
 
toString() - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
toString() - Method in class com.hazelcast.config.DiscoveryConfig
 
toString() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
toString() - Method in class com.hazelcast.config.DurableExecutorConfig
 
toString() - Method in class com.hazelcast.config.EncryptionAtRestConfig
 
toString() - Method in class com.hazelcast.config.EntryListenerConfig
 
toString() - Method in class com.hazelcast.config.EventJournalConfig
 
toString() - Method in class com.hazelcast.config.EvictionConfig
 
toString() - Method in class com.hazelcast.config.ExecutorConfig
 
toString() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
toString() - Method in class com.hazelcast.config.GlobalSerializerConfig
 
toString() - Method in class com.hazelcast.config.HotRestartConfig
 
toString() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
 
toString() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
toString() - Method in class com.hazelcast.config.IndexConfig
 
toString() - Method in class com.hazelcast.config.InstanceTrackingConfig
 
toString() - Method in class com.hazelcast.config.InterfacesConfig
 
toString() - Method in class com.hazelcast.config.ItemListenerConfig
 
toString() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
 
toString() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
toString() - Method in class com.hazelcast.config.JoinConfig
 
toString() - Method in class com.hazelcast.config.ListConfig
 
toString() - Method in class com.hazelcast.config.ListenerConfig
 
toString() - Method in class com.hazelcast.config.LoginModuleConfig
 
toString() - Method in class com.hazelcast.config.ManagementCenterConfig
 
toString() - Method in class com.hazelcast.config.MapConfig
 
toString() - Method in class com.hazelcast.config.MapStoreConfig
 
toString() - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
toString() - Method in class com.hazelcast.config.MemberGroupConfig
 
toString() - Method in class com.hazelcast.config.MemcacheProtocolConfig
 
toString() - Method in class com.hazelcast.config.MergePolicyConfig
 
toString() - Method in class com.hazelcast.config.MerkleTreeConfig
 
toString() - Method in class com.hazelcast.config.MetricsConfig
 
toString() - Method in class com.hazelcast.config.MetricsJmxConfig
 
toString() - Method in class com.hazelcast.config.MetricsManagementCenterConfig
 
toString() - Method in class com.hazelcast.config.MulticastConfig
 
toString() - Method in class com.hazelcast.config.MultiMapConfig
 
toString() - Method in class com.hazelcast.config.NativeMemoryConfig
 
toString() - Method in class com.hazelcast.config.NearCacheConfig
 
toString() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
toString() - Method in class com.hazelcast.config.NetworkConfig
 
toString() - Method in class com.hazelcast.config.PartitionGroupConfig
 
toString() - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
toString() - Method in class com.hazelcast.config.PermissionConfig
 
toString() - Method in class com.hazelcast.config.PermissionPolicyConfig
 
toString() - Method in class com.hazelcast.config.PersistentMemoryConfig
 
toString() - Method in class com.hazelcast.config.PersistentMemoryDirectoryConfig
 
toString() - Method in class com.hazelcast.config.PredicateConfig
 
toString() - Method in class com.hazelcast.config.QueryCacheConfig
 
toString() - Method in class com.hazelcast.config.QueueConfig
 
toString() - Method in class com.hazelcast.config.QueueStoreConfig
 
toString() - Method in class com.hazelcast.config.ReliableTopicConfig
 
toString() - Method in class com.hazelcast.config.ReplicatedMapConfig
 
toString() - Method in class com.hazelcast.config.RestApiConfig
 
toString() - Method in class com.hazelcast.config.RestServerEndpointConfig
 
toString() - Method in class com.hazelcast.config.RingbufferConfig
 
toString() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
toString() - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
toString() - Method in class com.hazelcast.config.security.CredentialsIdentityConfig
 
toString() - Method in class com.hazelcast.config.security.JaasAuthenticationConfig
 
toString() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
 
toString() - Method in class com.hazelcast.config.security.KerberosIdentityConfig
 
toString() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
toString() - Method in enum com.hazelcast.config.security.LdapRoleMappingMode
 
toString() - Method in enum com.hazelcast.config.security.LdapSearchScope
 
toString() - Method in class com.hazelcast.config.security.RealmConfig
 
toString() - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
 
toString() - Method in enum com.hazelcast.config.security.TokenEncoding
 
toString() - Method in class com.hazelcast.config.security.TokenIdentityConfig
 
toString() - Method in class com.hazelcast.config.security.UsernamePasswordIdentityConfig
 
toString() - Method in class com.hazelcast.config.SecurityConfig
 
toString() - Method in class com.hazelcast.config.SerializationConfig
 
toString() - Method in class com.hazelcast.config.SerializerConfig
 
toString() - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
toString() - Method in class com.hazelcast.config.ServiceConfig
 
toString() - Method in class com.hazelcast.config.SetConfig
 
toString() - Method in class com.hazelcast.config.SocketInterceptorConfig
 
toString() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
toString() - Method in class com.hazelcast.config.SqlConfig
 
toString() - Method in class com.hazelcast.config.SSLConfig
 
toString() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
toString() - Method in class com.hazelcast.config.TcpIpConfig
 
toString() - Method in class com.hazelcast.config.TopicConfig
 
toString() - Method in class com.hazelcast.config.VaultSecureStoreConfig
 
toString() - Method in class com.hazelcast.config.WanBatchPublisherConfig
 
toString() - Method in class com.hazelcast.config.WanConsumerConfig
 
toString() - Method in class com.hazelcast.config.WanCustomPublisherConfig
 
toString() - Method in class com.hazelcast.config.WanReplicationConfig
 
toString() - Method in class com.hazelcast.config.WanReplicationRef
 
toString() - Method in class com.hazelcast.config.WanSyncConfig
 
toString() - Method in class com.hazelcast.core.DistributedObjectEvent
 
toString() - Method in class com.hazelcast.core.EntryEvent
 
toString() - Method in class com.hazelcast.core.HazelcastJsonValue
Returns unaltered string that was used to create this object.
toString() - Method in class com.hazelcast.core.LifecycleEvent
 
toString() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
toString() - Method in class com.hazelcast.map.AbstractIMapEvent
Returns a String representation of this event.
toString() - Method in class com.hazelcast.map.EventLostEvent
 
toString() - Method in class com.hazelcast.map.MapEvent
 
toString() - Method in class com.hazelcast.map.MapPartitionLostEvent
 
toString() - Method in class com.hazelcast.memory.MemorySize
 
toString() - Method in class com.hazelcast.partition.PartitionAwareKey
 
toString() - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
toString() - Method in class com.hazelcast.security.permission.AllPermissions
 
toString() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
 
toString() - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
 
toString() - Method in class com.hazelcast.security.SimpleTokenCredentials
 
toString() - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
toString() - Method in class com.hazelcast.spi.properties.HazelcastProperty
 
toString() - Method in class com.hazelcast.splitbrainprotection.SplitBrainProtectionEvent
 
toString() - Method in class com.hazelcast.sql.SqlColumnMetadata
 
toString() - Method in class com.hazelcast.sql.SqlRowMetadata
 
toString() - Method in class com.hazelcast.sql.SqlStatement
 
toString() - Method in class com.hazelcast.transaction.TransactionOptions
 
toString() - Method in class com.hazelcast.version.MemberVersion
 
toString() - Method in class com.hazelcast.version.Version
 
toString() - Method in class org.apache.calcite.plan.HazelcastRelOptCluster
 
total() - Method in interface com.hazelcast.map.LocalMapStats
Returns the total number of total operations
toUrn() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
Returns the String representation of the handler.
TransactionalList<E> - Interface in com.hazelcast.transaction
Transactional implementation of IList.
TransactionalMap<K,V> - Interface in com.hazelcast.transaction
Transactional implementation of BaseMap.
TransactionalMultiMap<K,V> - Interface in com.hazelcast.transaction
Transactional implementation of BaseMultiMap.
TransactionalObject - Interface in com.hazelcast.transaction
Marker interface for all transactional distributed objects.
TransactionalQueue<E> - Interface in com.hazelcast.transaction
Transactional implementation of BaseQueue.
TransactionalSet<E> - Interface in com.hazelcast.transaction
Transactional implementation of ISet.
TransactionalTask<T> - Interface in com.hazelcast.transaction
Contains the logic that is going to be executed within a transaction.
TransactionalTaskContext - Interface in com.hazelcast.transaction
Provides a context to access transactional data-structures, like the TransactionalMap.
TransactionContext - Interface in com.hazelcast.transaction
Provides a context to perform transactional operations: beginning/committing transactions, but also retrieving transactional data-structures like the TransactionalMap.
TransactionException - Exception in com.hazelcast.transaction
A HazelcastException that is thrown when something goes wrong while dealing with transactions and transactional data-structures.
TransactionException() - Constructor for exception com.hazelcast.transaction.TransactionException
 
TransactionException(String) - Constructor for exception com.hazelcast.transaction.TransactionException
 
TransactionException(String, Throwable) - Constructor for exception com.hazelcast.transaction.TransactionException
 
TransactionException(Throwable) - Constructor for exception com.hazelcast.transaction.TransactionException
 
TransactionManagerService - Interface in com.hazelcast.transaction
 
TransactionNotActiveException - Exception in com.hazelcast.transaction
A HazelcastException thrown when an a transactional operation is executed without an active transaction.
TransactionNotActiveException() - Constructor for exception com.hazelcast.transaction.TransactionNotActiveException
 
TransactionNotActiveException(String) - Constructor for exception com.hazelcast.transaction.TransactionNotActiveException
 
TransactionOptions - Class in com.hazelcast.transaction
Contains the configuration for a Hazelcast transaction.
TransactionOptions() - Constructor for class com.hazelcast.transaction.TransactionOptions
Creates a new default configured TransactionsOptions.
TransactionOptions.TransactionType - Enum in com.hazelcast.transaction
The type of transaction.
TransactionPermission - Class in com.hazelcast.security.permission
 
TransactionPermission() - Constructor for class com.hazelcast.security.permission.TransactionPermission
 
TransactionTimedOutException - Exception in com.hazelcast.transaction
Thrown when a transaction has timed out.
TransactionTimedOutException() - Constructor for exception com.hazelcast.transaction.TransactionTimedOutException
 
TransactionTimedOutException(String) - Constructor for exception com.hazelcast.transaction.TransactionTimedOutException
 
TransactionTimedOutException(String, Throwable) - Constructor for exception com.hazelcast.transaction.TransactionTimedOutException
 
TransactionTimedOutException(Throwable) - Constructor for exception com.hazelcast.transaction.TransactionTimedOutException
 
transform(I) - Method in interface com.hazelcast.projection.Projection
Transforms the input object into the output object.
TrustedInterfacesConfigurable<T extends TrustedInterfacesConfigurable<?>> - Interface in com.hazelcast.config
Interface defining methods used to configure trusted interfaces (source IP addresses).
tryAcquire() - Method in interface com.hazelcast.cp.ISemaphore
Acquires a permit if one is available, and returns true immediately.
tryAcquire(int) - Method in interface com.hazelcast.cp.ISemaphore
Acquires the given number of permits if they are available, and returns true immediately.
tryAcquire(long, TimeUnit) - Method in interface com.hazelcast.cp.ISemaphore
Acquires a permit and returns true, if one becomes available during the given waiting time and the current thread has not been interrupted.
tryAcquire(int, long, TimeUnit) - Method in interface com.hazelcast.cp.ISemaphore
Acquires the given number of permits and returns true, if they become available during the given waiting time.
tryCloseConnections(HazelcastInstance) - Method in class com.hazelcast.core.OutOfMemoryHandler
Tries to close the server socket and connections to other HazelcastInstances.
tryLock() - Method in interface com.hazelcast.cp.lock.FencedLock
Acquires the lock if it is available or already held by the current thread at the time of invocation & the acquire limit is not exceeded, and immediately returns with the value true.
tryLock(long, TimeUnit) - Method in interface com.hazelcast.cp.lock.FencedLock
Acquires the lock if it is free within the given waiting time, or already held by the current thread.
tryLock(K) - Method in interface com.hazelcast.map.IMap
Tries to acquire the lock for the specified key.
tryLock(K, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Tries to acquire the lock for the specified key.
tryLock(K, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Tries to acquire the lock for the specified key for the specified lease time.
tryLock(K) - Method in interface com.hazelcast.multimap.MultiMap
Tries to acquire the lock for the specified key.
tryLock(K, long, TimeUnit) - Method in interface com.hazelcast.multimap.MultiMap
Tries to acquire the lock for the specified key.
tryLock(K, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.multimap.MultiMap
Tries to acquire the lock for the specified key for the specified lease time.
tryLockAndGetFence() - Method in interface com.hazelcast.cp.lock.FencedLock
Acquires the lock only if it is free or already held by the current thread at the time of invocation & the acquire limit is not exceeded, and returns the fencing token assigned to the current thread for this lock acquire.
tryLockAndGetFence(long, TimeUnit) - Method in interface com.hazelcast.cp.lock.FencedLock
Acquires the lock if it is free within the given waiting time, or already held by the current thread at the time of invocation & the acquire limit is not exceeded, and returns the fencing token assigned to the current thread for this lock acquire.
tryPut(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Tries to put the given key and value into this map within a specified timeout value.
tryRecover() - Method in interface com.hazelcast.map.QueryCache
This method can be used to recover from a possible event loss situation.
tryRemove(K, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Tries to remove the entry with the given key from this map within the specified timeout value.
trySetCount(int) - Method in interface com.hazelcast.cp.ICountDownLatch
Sets the count to the given value if the current count is zero.
tryShutdown(HazelcastInstance) - Method in class com.hazelcast.core.OutOfMemoryHandler
Tries to shutdown HazelcastInstance forcefully; including closing sockets and connections, stopping threads, etc.
typeConverter() - Method in interface com.hazelcast.config.properties.PropertyDefinition
The TypeConverter to be used to convert the string value read from XML to the expected type automatically.
typeConverter() - Method in class com.hazelcast.config.properties.SimplePropertyDefinition
 
TypeConverter - Interface in com.hazelcast.core
Implementations of this interface define a certain type conversation.
TypedByteArrayDeserializer<T> - Interface in com.hazelcast.nio.serialization
This interface allows deserialization of a binary data with a provided class type.
TypedDataSerializable - Interface in com.hazelcast.nio.serialization
This interface adds the possibility for the class to act as if it is another class when being deserialized using DataSerializable
TypedStreamDeserializer<T> - Interface in com.hazelcast.nio.serialization
This interface allows deserialization of a binary data with a provided class type.
typeId() - Method in interface com.hazelcast.auditlog.AuditableEvent
 

U

UndefinedErrorCodeException - Exception in com.hazelcast.client
This exception is thrown when an exception that is coming from server is not recognized by the protocol and it can not be constructed by the client via reflection.
UndefinedErrorCodeException(String, String, Throwable) - Constructor for exception com.hazelcast.client.UndefinedErrorCodeException
 
UNKNOWN - Static variable in class com.hazelcast.version.MemberVersion
UNKNOWN version.
UNKNOWN - Static variable in class com.hazelcast.version.Version
Version 0.0 is UNKNOWN constant UNKNOWN is only equal to itself. is(Less|Greater)Than method with an UNKNOWN operand returns false. is(Less|Greater)OrEqual with an UNKNOWN operand returns false, unless both operands are UNKNOWN. UNKNOWN.isUnknown(Less|Greater)(Than|OrEqual) returns true. otherVersion.isUnknown(Less|Greater)(Than|OrEqual) with an UNKNOWN argument returns false.
UNKNOWN_VERSION - Static variable in class com.hazelcast.version.Version
Use 0 as major & minor values for UNKNOWN version
unlock() - Method in interface com.hazelcast.cp.lock.FencedLock
Releases the lock if the lock is currently held by the current thread.
unlock(K) - Method in interface com.hazelcast.map.IMap
Releases the lock for the specified key.
unlock(K) - Method in interface com.hazelcast.multimap.MultiMap
Releases the lock for the specified key.
unregister() - Method in interface com.hazelcast.spi.tenantcontrol.TenantControl
To be called when the Hazelcast object attached to this tenant is destroyed.
updateCount() - Method in interface com.hazelcast.sql.SqlResult
Returns the number of rows updated by the statement or -1 if this result is a row set.
UrlXmlConfig - Class in com.hazelcast.config
A Config which is loaded using some url pointing to a Hazelcast XML file.
UrlXmlConfig(String) - Constructor for class com.hazelcast.config.UrlXmlConfig
Creates new Config which is loaded from the given url and uses the System.properties to replace variables in the XML.
UrlXmlConfig(String, Properties) - Constructor for class com.hazelcast.config.UrlXmlConfig
Creates new Config which is loaded from the given url.
UrlXmlConfig(URL) - Constructor for class com.hazelcast.config.UrlXmlConfig
Creates new Config which is loaded from the given url and uses the System.properties to replace variables in the XML.
UrlXmlConfig(URL, Properties) - Constructor for class com.hazelcast.config.UrlXmlConfig
Creates new Config which is loaded from the given url.
UrlYamlConfig - Class in com.hazelcast.config
A Config which is loaded using some url pointing to a Hazelcast YAML file.
UrlYamlConfig(String) - Constructor for class com.hazelcast.config.UrlYamlConfig
Creates new Config which is loaded from the given url and uses the System.properties to replace variables in the YAML.
UrlYamlConfig(String, Properties) - Constructor for class com.hazelcast.config.UrlYamlConfig
Creates new Config which is loaded from the given url.
UrlYamlConfig(URL) - Constructor for class com.hazelcast.config.UrlYamlConfig
Creates new Config which is loaded from the given url and uses the System.properties to replace variables in the YAML.
UrlYamlConfig(URL, Properties) - Constructor for class com.hazelcast.config.UrlYamlConfig
Creates new Config which is loaded from the given url.
UserCodeDeploymentConfig - Class in com.hazelcast.config
Configuration of User Code Deployment.
UserCodeDeploymentConfig() - Constructor for class com.hazelcast.config.UserCodeDeploymentConfig
 
UserCodeDeploymentConfig.ClassCacheMode - Enum in com.hazelcast.config
Controls caching of classes loaded from remote members
UserCodeDeploymentConfig.ProviderMode - Enum in com.hazelcast.config
Controls how to react to receiving a classloading request from a remote member
UserCodeDeploymentPermission - Class in com.hazelcast.security.permission
 
UserCodeDeploymentPermission(String...) - Constructor for class com.hazelcast.security.permission.UserCodeDeploymentPermission
 
UsernamePasswordCredentials - Class in com.hazelcast.security
Simple implementation of PasswordCredentials using name and password as security attributes.
UsernamePasswordCredentials() - Constructor for class com.hazelcast.security.UsernamePasswordCredentials
 
UsernamePasswordCredentials(String, String) - Constructor for class com.hazelcast.security.UsernamePasswordCredentials
 
UsernamePasswordIdentityConfig - Class in com.hazelcast.config.security
Simple username/password identity configuration.
UsernamePasswordIdentityConfig(String, String) - Constructor for class com.hazelcast.config.security.UsernamePasswordIdentityConfig
 

V

validate() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
validate(T) - Method in interface com.hazelcast.config.properties.ValueValidator
Validates the given value according to the defined validation logic and throws a ValidationException if configuration does not meet the requirements or logical errors are spotted.
ValidationException - Exception in com.hazelcast.config.properties
This exception is thrown from ValueValidator implementations whenever the validation has not succeed for any reason.
ValidationException(String) - Constructor for exception com.hazelcast.config.properties.ValidationException
 
ValidationException(String, Throwable) - Constructor for exception com.hazelcast.config.properties.ValidationException
 
ValidationException(Throwable) - Constructor for exception com.hazelcast.config.properties.ValidationException
 
validator() - Method in interface com.hazelcast.config.properties.PropertyDefinition
Returns an optional validator to validate a value before finalizing the configuration.
validator() - Method in class com.hazelcast.config.properties.SimplePropertyDefinition
 
value - Variable in class com.hazelcast.core.EntryEvent
 
value() - Method in enum com.hazelcast.query.QueryConstants
 
ValueCallback<T> - Interface in com.hazelcast.query.extractor
Enables notifying about values extracted in a ValueExtractor
ValueCollector<T> - Interface in com.hazelcast.query.extractor
Enables collecting values extracted in a ValueExtractor
valueCount(K) - Method in interface com.hazelcast.multimap.BaseMultiMap
Returns the number of values matching the given key in the multimap.
valueCount(K) - Method in interface com.hazelcast.multimap.MultiMap
Returns the number of values that match the given key in the multimap.
valueCount(K) - Method in interface com.hazelcast.transaction.TransactionalMultiMap
Returns the number of values matching the given key in the multimap.
ValueExtractor<T,A> - Interface in com.hazelcast.query.extractor
Common superclass for all extractors that enable the user to define custom attributes and extract their values.
valueOf(String) - Static method in enum com.hazelcast.auditlog.Level
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.cache.CacheEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.client.config.ClientConnectionStrategyConfig.ReconnectMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.cluster.ClusterState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.AbstractXmlConfigBuilder.ConfigType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.BitmapIndexOptions.UniqueKeyTransformation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.CacheDeserializedValues
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.ConsistencyCheckStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.EvictionPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.HotRestartClusterDataRecoveryPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.IndexType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.InMemoryFormat
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.InstanceTrackingConfig.InstanceMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.InstanceTrackingConfig.InstanceProductName
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.InstanceTrackingConfig.InstanceTrackingProperties
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.MapStoreConfig.InitialLoadMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.MaxSizePolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.MetadataPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.MultiMapConfig.ValueCollectionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.NativeMemoryConfig.MemoryAllocatorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.NearCacheConfig.LocalUpdatePolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.OnJoinPermissionOperationName
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.PartitionGroupConfig.MemberGroupType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.PermissionConfig.PermissionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.PersistentMemoryMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.properties.PropertyTypeConverter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.RestEndpointGroup
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.ScheduledExecutorConfig.CapacityPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.security.LdapRoleMappingMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.security.LdapSearchScope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.security.TokenEncoding
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.UserCodeDeploymentConfig.ClassCacheMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.UserCodeDeploymentConfig.ProviderMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.WanAcknowledgeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.WanQueueFullBehavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.core.DistributedObjectEvent.EventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.core.EntryEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.core.ItemEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.core.LifecycleEvent.LifecycleState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.cp.CPGroup.CPGroupStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.cp.event.CPMembershipEvent.EventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.cp.session.CPSession.CPSessionOwnerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.hotrestart.BackupTaskState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.memory.MemoryUnit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.nio.serialization.FieldType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.query.QueryConstants
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.ringbuffer.OverflowPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.spi.discovery.DiscoveryStrategyFactory.DiscoveryStrategyLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.spi.discovery.integration.DiscoveryMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.splitbrainprotection.SplitBrainProtectionOn
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.sql.SqlColumnType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.topic.TopicOverloadPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.wan.WanEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.wan.WanPublisherState
Returns the enum constant of this type with the specified name.
ValueReader - Interface in com.hazelcast.query.extractor
Enables reading the value of the attribute specified by the path
ValueReadingException - Exception in com.hazelcast.query.extractor
Exception thrown if there is any checked or unchecked exception caught in the value reading in ValueReader
ValueReadingException(String, Throwable) - Constructor for exception com.hazelcast.query.extractor.ValueReadingException
 
values() - Static method in enum com.hazelcast.auditlog.Level
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.cache.CacheEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.client.config.ClientConnectionStrategyConfig.ReconnectMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.cluster.ClusterState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.AbstractXmlConfigBuilder.ConfigType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.BitmapIndexOptions.UniqueKeyTransformation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.CacheDeserializedValues
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.ConsistencyCheckStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.EvictionPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.HotRestartClusterDataRecoveryPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.IndexType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.InMemoryFormat
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.InstanceTrackingConfig.InstanceMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.InstanceTrackingConfig.InstanceProductName
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.InstanceTrackingConfig.InstanceTrackingProperties
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.MapStoreConfig.InitialLoadMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.MaxSizePolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.MetadataPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.MultiMapConfig.ValueCollectionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.NativeMemoryConfig.MemoryAllocatorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.NearCacheConfig.LocalUpdatePolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.OnJoinPermissionOperationName
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.PartitionGroupConfig.MemberGroupType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.PermissionConfig.PermissionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.PersistentMemoryMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.properties.PropertyTypeConverter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.RestEndpointGroup
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.ScheduledExecutorConfig.CapacityPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.security.LdapRoleMappingMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.security.LdapSearchScope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.security.TokenEncoding
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.UserCodeDeploymentConfig.ClassCacheMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.UserCodeDeploymentConfig.ProviderMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.WanAcknowledgeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.WanQueueFullBehavior
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.core.DistributedObjectEvent.EventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.core.EntryEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.core.ItemEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.core.LifecycleEvent.LifecycleState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.cp.CPGroup.CPGroupStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.cp.event.CPMembershipEvent.EventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.cp.session.CPSession.CPSessionOwnerType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.hotrestart.BackupTaskState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface com.hazelcast.map.BaseMap
Returns a collection clone of the values contained in this map.
values(Predicate<K, V>) - Method in interface com.hazelcast.map.BaseMap
Queries the map based on the specified predicate and returns the values of matching entries.
values() - Method in interface com.hazelcast.map.IMap
Returns an immutable collection clone of the values contained in this map.
values(Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
Queries the map based on the specified predicate and returns an immutable collection of the values of matching entries.
values() - Method in interface com.hazelcast.map.QueryCache
 
values(Predicate<K, V>) - Method in interface com.hazelcast.map.QueryCache
 
values() - Static method in enum com.hazelcast.memory.MemoryUnit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface com.hazelcast.multimap.MultiMap
Returns the collection of values in the multimap.
values() - Static method in enum com.hazelcast.nio.serialization.FieldType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.query.QueryConstants
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Returns a lazy Collection view of the values contained in this map.
A LazyCollection is optimized for querying speed (preventing eager deserialization and hashing on HashSet insertion) and does NOT provide all operations.
values(Comparator<V>) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Returns an eagerly populated Collection view of the values contained in this map.
values() - Static method in enum com.hazelcast.ringbuffer.OverflowPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.spi.discovery.DiscoveryStrategyFactory.DiscoveryStrategyLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.spi.discovery.integration.DiscoveryMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.splitbrainprotection.SplitBrainProtectionOn
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.sql.SqlColumnType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.topic.TopicOverloadPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.values().
values(Predicate<K, V>) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.values(com.hazelcast.query.Predicate).
values() - Static method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.wan.WanEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.wan.WanPublisherState
Returns an array containing the constants of this enum type, in the order they are declared.
ValueValidator<T extends Comparable<T>> - Interface in com.hazelcast.config.properties
This interface defines a certain validation logic implementation to test if a given value is expected to be correct or not.
VaultSecureStoreConfig - Class in com.hazelcast.config
HashiCorp Vault Secure Store configuration.
VaultSecureStoreConfig(String, String, String) - Constructor for class com.hazelcast.config.VaultSecureStoreConfig
Creates a new Vault Secure Store configuration.
verify() - Method in class com.hazelcast.config.JoinConfig
Verifies this JoinConfig is valid.
version() - Method in interface com.hazelcast.cp.session.CPSession
Returns version of the session.
Version - Class in com.hazelcast.version
A generic version to be used with VersionAware classes.
Version() - Constructor for class com.hazelcast.version.Version
 
VersionAware - Interface in com.hazelcast.nio
An instance which supports versioning.
VersionedPortable - Interface in com.hazelcast.nio.serialization
An extension to Portable to support per-object version instead of a global serialization version.

W

WAIT_SECONDS_BEFORE_JOIN - Static variable in class com.hazelcast.spi.properties.ClusterProperty
The time that a newly-appointed master node waits before forming a cluster.
WAN_ADD_CONFIG - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
Event type ID: WAN add config.
WAN_CONSUMER_ACK_DELAY_BACKOFF_INIT_MS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Defines the initial backoff delay for the Enterprise WAN implementation's consumer.
WAN_CONSUMER_ACK_DELAY_BACKOFF_MAX_MS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Defines the maximum backoff delay for the Enterprise WAN implementation's consumer.
WAN_CONSUMER_ACK_DELAY_BACKOFF_MULTIPLIER - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Defines the multiplier (the speed of the function) for the backoff delay for the Enterprise WAN implementation's consumer.
WAN_CONSUMER_INVOCATION_THRESHOLD - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Defines the pending invocation threshold for the Enterprise WAN replication implementation.
WAN_SYNC - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
Event type ID: WAN sync.
WanAcknowledgeType - Enum in com.hazelcast.config
Determines acknowledge waiting type of wan replication operation invocation.
WanBatchPublisherConfig - Class in com.hazelcast.config
Configuration object for the built-in WAN publisher (available in Hazelcast Enterprise).
WanBatchPublisherConfig() - Constructor for class com.hazelcast.config.WanBatchPublisherConfig
 
WanConsumer - Interface in com.hazelcast.wan
Interface to be implemented by custom WAN event consumers.
WanConsumerConfig - Class in com.hazelcast.config
Config for processing WAN events received from a target cluster.
WanConsumerConfig() - Constructor for class com.hazelcast.config.WanConsumerConfig
 
WanCustomPublisherConfig - Class in com.hazelcast.config
Configuration object for a custom WAN publisher.
WanCustomPublisherConfig() - Constructor for class com.hazelcast.config.WanCustomPublisherConfig
 
WanEvent<T> - Interface in com.hazelcast.wan
Interface for all WAN replication messages
WanEventCounters - Class in com.hazelcast.wan
Counters for WAN events for a single distributed object type (map or cache).
WanEventCounters() - Constructor for class com.hazelcast.wan.WanEventCounters
 
WanEventCounters.DistributedObjectWanEventCounters - Class in com.hazelcast.wan
Counters for WAN events for a single map or cache.
WanEventType - Enum in com.hazelcast.wan
The type of the WAN event, signifies the type of the mutation that occurred that caused the WAN event.
WanMigrationAwarePublisher<T> - Interface in com.hazelcast.wan
Interface for WAN publisher migration related events.
WanProtocolVersionAware - Interface in com.hazelcast.nio
An instance which is used in WAN and supports versioning.
WanPublisher<T> - Interface in com.hazelcast.wan
This interface offers the implementation of different kinds of replication techniques like TCP, UDP or maybe even an JMS based service.
WanPublisherState - Enum in com.hazelcast.wan
Defines the state in which a WAN publisher can be in if it is not shutting down.
WanQueueFullBehavior - Enum in com.hazelcast.config
Determines the behavior of WAN replication impl.
WanQueueFullException - Exception in com.hazelcast.wan
A HazelcastException that is thrown when the wan replication queues are full This exception is only thrown when WAN is configured with WanQueueFullBehavior.THROW_EXCEPTION
WanQueueFullException(String) - Constructor for exception com.hazelcast.wan.WanQueueFullException
 
WanReplicationConfig - Class in com.hazelcast.config
Configuration for WAN replication.
WanReplicationConfig() - Constructor for class com.hazelcast.config.WanReplicationConfig
 
WanReplicationRef - Class in com.hazelcast.config
Configuration for a WAN target replication reference.
WanReplicationRef() - Constructor for class com.hazelcast.config.WanReplicationRef
 
WanReplicationRef(WanReplicationRef) - Constructor for class com.hazelcast.config.WanReplicationRef
 
WanReplicationRef(String, String, List<String>, boolean) - Constructor for class com.hazelcast.config.WanReplicationRef
 
WanSyncConfig - Class in com.hazelcast.config
Configuration object for the WAN sync mechanism.
WanSyncConfig() - Constructor for class com.hazelcast.config.WanSyncConfig
 
warning(String) - Method in class com.hazelcast.logging.AbstractLogger
 
warning(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
warning(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
warning(String) - Method in interface com.hazelcast.logging.ILogger
Logs a message at the Level.WARNING level.
warning(Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a throwable at the Level.WARNING level.
warning(String, Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a message with an associated throwable at the Level.WARNING level.
wholeItem() - Static method in class com.hazelcast.function.Functions
Synonym for FunctionEx.identity(), to be used as a projection function (e.g., key extractor).
WildcardConfigPatternMatcher - Class in com.hazelcast.config.matcher
This ConfigPatternMatcher supports a simplified wildcard matching.
WildcardConfigPatternMatcher() - Constructor for class com.hazelcast.config.matcher.WildcardConfigPatternMatcher
 
withAcceptableHeartbeatPauseMillis(long) - Method in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
Duration in milliseconds corresponding to number of potentially lost/delayed heartbeats that will be accepted before considering it to be an anomaly.
withHeartbeatIntervalMillis(long) - Method in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
Bootstrap the stats with heartbeats that corresponds to this duration in milliseconds, with a rather high standard deviation (since environment is unknown in the beginning).
withMaxSampleSize(int) - Method in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
Number of samples to use for calculation of mean and standard deviation of inter-arrival times.
withMinStdDeviationMillis(long) - Method in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
Minimum standard deviation (in milliseconds) to use for the normal distribution used when calculating phi.
withSplitBrainProtectionSize(int) - Method in class com.hazelcast.config.SplitBrainProtectionConfigBuilder
 
withSuspicionThreshold(double) - Method in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
Threshold for suspicion (φ) level.
wrap() - Method in exception com.hazelcast.client.UndefinedErrorCodeException
 
wrap() - Method in exception com.hazelcast.cp.exception.CannotReplicateException
 
wrap() - Method in exception com.hazelcast.cp.exception.CPGroupDestroyedException
 
wrap() - Method in exception com.hazelcast.cp.exception.CPSubsystemException
 
wrap() - Method in exception com.hazelcast.cp.exception.LeaderDemotedException
 
wrap() - Method in exception com.hazelcast.cp.exception.NotLeaderException
 
wrap() - Method in exception com.hazelcast.cp.exception.StaleAppendRequestException
 
wrap() - Method in exception com.hazelcast.ringbuffer.StaleSequenceException
 
write(T) - Method in interface com.hazelcast.nio.serialization.ByteArraySerializer
Converts given object to byte array
write(ObjectDataOutput, T) - Method in interface com.hazelcast.nio.serialization.StreamSerializer
This method writes object to ObjectDataOutput
writeBoolean(String, boolean) - Method in interface com.hazelcast.nio.serialization.GenericRecord.Builder
It is legal to overwrite the field once only when Builder is created with GenericRecord.cloneWithBuilder().
writeBoolean(String, boolean) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive boolean.
writeBooleanArray(boolean[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeBooleanArray(String, boolean[]) - Method in interface com.hazelcast.nio.serialization.GenericRecord.Builder
It is illegal to write to the same field twice.
writeBooleanArray(String, boolean[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive boolean-array.
writeByte(String, byte) - Method in interface com.hazelcast.nio.serialization.GenericRecord.Builder
It is illegal to write to the same field twice.
writeByte(String, byte) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive byte.
writeByteArray(byte[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeByteArray(String, byte[]) - Method in interface com.hazelcast.nio.serialization.GenericRecord.Builder
It is illegal to write to the same field twice.
writeByteArray(String, byte[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive byte-array.
writeChar(String, char) - Method in interface com.hazelcast.nio.serialization.GenericRecord.Builder
It is illegal to write to the same field twice.
writeChar(String, int) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive char.
writeCharArray(char[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeCharArray(String, char[]) - Method in interface com.hazelcast.nio.serialization.GenericRecord.Builder
It is illegal to write to the same field twice.
writeCharArray(String, char[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive char-array.
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cluster.Address
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.AttributeConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.BitmapIndexOptions
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CollectionConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.DiscoveryConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.DurableExecutorConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.EntryListenerConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.EventJournalConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.EvictionConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ExecutorConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.HotRestartConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.IndexConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ItemListenerConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ListenerConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MapConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MapStoreConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MergePolicyConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MerkleTreeConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MultiMapConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.NearCacheConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.PermissionConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.PNCounterConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.PredicateConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.QueryCacheConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.QueueConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.QueueStoreConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ReliableTopicConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ReplicatedMapConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.RingbufferConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.TopicConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanBatchPublisherConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanConsumerConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanReplicationConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanReplicationRef
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanSyncConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.console.Echo
 
writeData(ObjectDataOutput) - Method in interface com.hazelcast.nio.serialization.DataSerializable
Writes object fields to output stream
writeData(ObjectDataOutput) - Method in class com.hazelcast.partition.PartitionAwareKey
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.security.SimpleTokenCredentials
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.transaction.TransactionOptions
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.version.MemberVersion
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.version.Version
 
writeDouble(String, double) - Method in interface com.hazelcast.nio.serialization.GenericRecord.Builder
It is illegal to write to the same field twice.
writeDouble(String, double) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive double.
writeDoubleArray(double[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeDoubleArray(String, double[]) - Method in interface com.hazelcast.nio.serialization.GenericRecord.Builder
It is illegal to write to the same field twice.
writeDoubleArray(String, double[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive double array.
writeFactories(ObjectDataOutput) - Method in class com.hazelcast.config.CacheConfig
 
writeFloat(String, float) - Method in interface com.hazelcast.nio.serialization.GenericRecord.Builder
It is illegal to write to the same field twice.
writeFloat(String, float) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive float.
writeFloatArray(float[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeFloatArray(String, float[]) - Method in interface com.hazelcast.nio.serialization.GenericRecord.Builder
It is illegal to write to the same field twice.
writeFloatArray(String, float[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive float array.
writeGenericRecord(String, GenericRecord) - Method in interface com.hazelcast.nio.serialization.GenericRecord.Builder
It is illegal to write to the same field twice.
writeGenericRecordArray(String, GenericRecord[]) - Method in interface com.hazelcast.nio.serialization.GenericRecord.Builder
It is illegal to write to the same field twice.
writeInt(String, int) - Method in interface com.hazelcast.nio.serialization.GenericRecord.Builder
It is illegal to write to the same field twice.
writeInt(String, int) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive int.
writeIntArray(int[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeIntArray(String, int[]) - Method in interface com.hazelcast.nio.serialization.GenericRecord.Builder
It is illegal to write to the same field twice.
writeIntArray(String, int[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive int-array.
writeKeyValueTypes(ObjectDataOutput) - Method in class com.hazelcast.config.CacheConfig
 
writeListenerConfigurations(ObjectDataOutput) - Method in class com.hazelcast.config.CacheConfig
 
writeLong(String, long) - Method in interface com.hazelcast.nio.serialization.GenericRecord.Builder
It is illegal to write to the same field twice.
writeLong(String, long) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive long.
writeLongArray(long[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeLongArray(String, long[]) - Method in interface com.hazelcast.nio.serialization.GenericRecord.Builder
It is illegal to write to the same field twice.
writeLongArray(String, long[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive long-array.
writeNullPortable(String, int, int) - Method in interface com.hazelcast.nio.serialization.PortableWriter
To write a null portable value, user needs to provide class and factoryIds of related class.
writeObject(Object) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writePortable(PortableWriter) - Method in interface com.hazelcast.nio.serialization.Portable
Serialize this portable object using PortableWriter
writePortable(String, Portable) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a Portable.
writePortableArray(String, Portable[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a an array of Portables.
writeShort(String, short) - Method in interface com.hazelcast.nio.serialization.GenericRecord.Builder
It is illegal to write to the same field twice.
writeShort(String, short) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive short.
writeShortArray(short[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeShortArray(String, short[]) - Method in interface com.hazelcast.nio.serialization.GenericRecord.Builder
It is illegal to write to the same field twice.
writeShortArray(String, short[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive short-array.
writeTenant(ObjectDataOutput) - Method in class com.hazelcast.config.CacheConfig
 
writeUTF(String, String) - Method in interface com.hazelcast.nio.serialization.GenericRecord.Builder
It is illegal to write to the same field twice.
writeUTF(String, String) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes an UTF string.
writeUTFArray(String[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeUTFArray(String, String[]) - Method in interface com.hazelcast.nio.serialization.GenericRecord.Builder
It is illegal to write to the same field twice.
writeUTFArray(String, String[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a String-array.
WrongTargetException - Exception in com.hazelcast.spi.exception
A RetryableHazelcastException indicating that an operation is executed on a wrong member.
WrongTargetException(Member, Member, int, int, String) - Constructor for exception com.hazelcast.spi.exception.WrongTargetException
 
WrongTargetException(Member, Member, int, int, String, String) - Constructor for exception com.hazelcast.spi.exception.WrongTargetException
 
WrongTargetException(String) - Constructor for exception com.hazelcast.spi.exception.WrongTargetException
 

X

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

Y

YamlClientConfigBuilder - Class in com.hazelcast.client.config
Loads the ClientConfig using YAML.
YamlClientConfigBuilder(String) - Constructor for class com.hazelcast.client.config.YamlClientConfigBuilder
 
YamlClientConfigBuilder(File) - Constructor for class com.hazelcast.client.config.YamlClientConfigBuilder
 
YamlClientConfigBuilder(URL) - Constructor for class com.hazelcast.client.config.YamlClientConfigBuilder
 
YamlClientConfigBuilder(InputStream) - Constructor for class com.hazelcast.client.config.YamlClientConfigBuilder
 
YamlClientConfigBuilder() - Constructor for class com.hazelcast.client.config.YamlClientConfigBuilder
Loads the client config using the following resolution mechanism: first it checks if a system property 'hazelcast.client.config' is set.
YamlClientConfigBuilder(YamlClientConfigLocator) - Constructor for class com.hazelcast.client.config.YamlClientConfigBuilder
Constructs a YamlClientConfigBuilder that loads the configuration with the provided YamlClientConfigLocator.
YamlClientFailoverConfigBuilder - Class in com.hazelcast.client.config
Loads the ClientFailoverConfig using YAML.
YamlClientFailoverConfigBuilder(String) - Constructor for class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
 
YamlClientFailoverConfigBuilder(File) - Constructor for class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
 
YamlClientFailoverConfigBuilder(URL) - Constructor for class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
 
YamlClientFailoverConfigBuilder(InputStream) - Constructor for class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
 
YamlClientFailoverConfigBuilder() - Constructor for class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
Loads the client failover config using the following resolution mechanism: first it checks if a system property 'hazelcast.client.failover.config' is set.
YamlClientFailoverConfigBuilder(YamlClientFailoverConfigLocator) - Constructor for class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
Constructs a YamlClientFailoverConfigBuilder that loads the configuration with the provided YamlClientFailoverConfigLocator.
YamlConfigBuilder - Class in com.hazelcast.config
A YAML ConfigBuilder implementation.
YamlConfigBuilder(String) - Constructor for class com.hazelcast.config.YamlConfigBuilder
Constructs a YamlConfigBuilder that reads from the provided YAML file.
YamlConfigBuilder(InputStream) - Constructor for class com.hazelcast.config.YamlConfigBuilder
Constructs a YAMLConfigBuilder that reads from the given InputStream.
YamlConfigBuilder(URL) - Constructor for class com.hazelcast.config.YamlConfigBuilder
Constructs a YamlConfigBuilder that reads from the given URL.
YamlConfigBuilder() - Constructor for class com.hazelcast.config.YamlConfigBuilder
Constructs a YamlConfigBuilder that tries to find a usable YAML configuration file.
YamlConfigBuilder(YamlConfigLocator) - Constructor for class com.hazelcast.config.YamlConfigBuilder
Constructs a YamlConfigBuilder that loads the configuration with the provided YamlConfigLocator.
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 
Skip navigation links

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