Index

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 Z 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

A

abbreviation() - Method in enum class com.hazelcast.memory.MemoryUnit
 
AbstractBaseFactoryWithPropertiesConfig<T extends AbstractBaseFactoryWithPropertiesConfig<T>> - Class in com.hazelcast.config
Configuration base for config types with a factory class and its properties.
AbstractBaseFactoryWithPropertiesConfig() - Constructor for class com.hazelcast.config.AbstractBaseFactoryWithPropertiesConfig
 
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
Common configuration shared by authentication modules provided out-of-the box in Hazelcast.
AbstractClusterLoginConfig() - Constructor for class com.hazelcast.config.security.AbstractClusterLoginConfig
 
AbstractConfigBuilder - Class in com.hazelcast.config
 
AbstractConfigBuilder() - Constructor for class com.hazelcast.config.AbstractConfigBuilder
 
AbstractDiscoveryStrategy - Class in com.hazelcast.spi.discovery
A 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.
AbstractLoadBalancer - Class in com.hazelcast.client.util
An abstract LoadBalancer implementation.
AbstractLoadBalancer() - Constructor for class com.hazelcast.client.util.AbstractLoadBalancer
 
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
 
AbstractProcessor - Class in com.hazelcast.jet.core
Base class to implement custom processors.
AbstractProcessor() - Constructor for class com.hazelcast.jet.core.AbstractProcessor
 
AbstractProcessor.FlatMapper<T,R> - Class in com.hazelcast.jet.core
A helper that simplifies the implementation of tryProcess(ordinal, item) for emitting collections.
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 Class 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(ClientContext) - Method in class com.hazelcast.cp.CPSubsystemStubImpl
 
accept(T) - Method in interface com.hazelcast.function.ConsumerEx
 
accept(T) - Method in class com.hazelcast.jet.core.ResettableSingletonTraverser
Resets this traverser so that the following next() call will return the item supplied here.
accept(T, U) - Method in interface com.hazelcast.function.BiConsumerEx
 
acceptEx(T) - Method in interface com.hazelcast.function.ConsumerEx
Exception-declaring version of Consumer.accept(T)
acceptEx(T, U) - Method in interface com.hazelcast.function.BiConsumerEx
Exception-declaring version of BiConsumer.accept(T, U).
AccessControlService - Interface in com.hazelcast.access
Service for pluggable authentication and authorization.
AccessControlServiceConfig - Class in com.hazelcast.config.security
AccessControlService configuration.
AccessControlServiceConfig() - Constructor for class com.hazelcast.config.security.AccessControlServiceConfig
 
AccessControlServiceFactory - Interface in com.hazelcast.access
Interface implemented by AccessControlService factory classes.
ACCESSED - Enum constant in enum class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
Expiry policy type for the AccessedExpiryPolicy.
accumulate(double) - Method in class com.hazelcast.jet.accumulator.DoubleAccumulator
Adds the value to this objects' value.
accumulate(long, long) - Method in class com.hazelcast.jet.accumulator.LinTrendAccumulator
Accumulates a new sample.
accumulate(I) - Method in interface com.hazelcast.aggregation.Aggregator
Accumulates the given entries.
accumulate(T) - Method in class com.hazelcast.jet.accumulator.PickAnyAccumulator
Accumulates an item.
accumulateByFrameP(List<FunctionEx<?, ? extends K>>, List<ToLongFunctionEx<?>>, TimestampKind, SlidingWindowPolicy, AggregateOperation<A, ?>) - Static method in class com.hazelcast.jet.core.processor.Processors
Returns a supplier of processors for the first-stage vertex in a two-stage sliding window aggregation setup (see the class Javadoc for an explanation of aggregation stages).
accumulateByFrameP(List<FunctionEx<?, ? extends K>>, List<ToLongFunctionEx<?>>, TimestampKind, SlidingWindowPolicy, AggregateOperation<A, ?>, byte) - Static method in class com.hazelcast.jet.core.processor.Processors
Returns a supplier of processors for the first-stage vertex in a two-stage sliding window aggregation setup (see the class Javadoc for an explanation of aggregation stages).
accumulateByKeyP(List<FunctionEx<?, ? extends K>>, AggregateOperation<A, ?>) - Static method in class com.hazelcast.jet.core.processor.Processors
Returns a supplier of processors for the first-stage vertex in a two-stage group-and-aggregate setup.
accumulateFn() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation1
A primitive that updates the accumulator state to account for a new item.
accumulateFn(int) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
A primitive that updates the accumulator state to account for a new item.
accumulateFn(Tag<T>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
A primitive that updates the accumulator state to account for a new item.
accumulateFn0() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation2
A primitive that updates the accumulator state to account for a new item coming from stream-0.
accumulateFn0() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation3
A primitive that updates the accumulator state to account for a new item coming from stream-0.
accumulateFn1() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation2
A primitive that updates the accumulator state to account for a new item coming from stream-1.
accumulateFn1() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation3
A primitive that updates the accumulator state to account for a new item coming from stream-1.
accumulateFn2() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation3
A primitive that updates the accumulator state to account for a new item coming from stream-2.
accumulateP(AggregateOperation<A, R>) - Static method in class com.hazelcast.jet.core.processor.Processors
Returns a supplier of processors for a vertex that performs the accumulation step of the provided aggregate operation on all the items it receives.
ACK_ON_OPERATION_COMPLETE - Enum constant in enum class com.hazelcast.config.WanAcknowledgeType
Wait till the operation is complete on target cluster.
ACK_ON_RECEIPT - Enum constant in enum class com.hazelcast.config.WanAcknowledgeType
ACK after WAN operation is received by the target cluster (without waiting the result of actual operation invocation).
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_ADD_RESOURCES - 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_CANCEL - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_CREATE - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_CREATE_DATACONNECTION - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_CREATE_TYPE - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_CREATE_VIEW - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_DESTROY - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_DROP_DATACONNECTION - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_DROP_TYPE - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_DROP_VIEW - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_EXPORT_SNAPSHOT - 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_OPTIMIZE - 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_RESTART - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_SUBMIT - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_USE - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_USER_CODE_DEPLOY - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_VIEW_DATACONNECTION - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_VIEW_MAPPING - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_WRITE - 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
 
ACTIVE - Enum constant in enum class com.hazelcast.cluster.ClusterState
In ACTIVE state, cluster will continue to operate without any restriction.
ACTIVE - Enum constant in enum class com.hazelcast.cp.CPGroup.CPGroupStatus
A CP group is active after it is initialized with the first request sent to it, and before its destroy process is initialized.
add(long) - Method in class com.hazelcast.jet.accumulator.LongAccumulator
Adds the supplied value to this accumulator, throwing an exception in the case of integer overflow.
add(UserCodeNamespaceConfig, ResourceDefinitionHolder) - Static method in class com.hazelcast.config.ConfigAccessor
 
add(ResourceDefinition) - Method in class com.hazelcast.config.UserCodeNamespaceConfig
 
add(LongAccumulator) - Method in class com.hazelcast.jet.accumulator.LongAccumulator
Adds the value of the supplied accumulator to this accumulator, throwing an exception in the case of integer overflow.
add(AggregateOperation1<? super T, ?, R>) - Method in class com.hazelcast.jet.aggregate.AllOfAggregationBuilder
Adds the supplied aggregate operation to the composite.
add(Tag<T>, AggregateOperation1<? super T, ?, ? extends R>) - Method in class com.hazelcast.jet.aggregate.CoAggregateOperationBuilder
Registers the given aggregate operation with the tag corresponding to an input to the co-aggregating operation being built.
add(BatchStage<T>) - Method in class com.hazelcast.jet.pipeline.AggregateBuilder1
Adds another stage that will contribute its data to the aggregate operation to be performed.
add(BatchStage<T>, AggregateOperation1<? super T, ?, ? extends R>) - Method in class com.hazelcast.jet.pipeline.AggregateBuilder
Adds another stage that will contribute its data to the aggregate operation to be performed.
add(BatchStage<T1_IN>, JoinClause<K, T0, T1_IN, T1>) - Method in class com.hazelcast.jet.pipeline.GeneralHashJoinBuilder
Adds another contributing pipeline stage to the hash-join operation.
add(BatchStageWithKey<T, K>) - Method in class com.hazelcast.jet.pipeline.GroupAggregateBuilder1
Adds another stage that will contribute its data to the aggregate operation to be performed.
add(BatchStageWithKey<T, K>, AggregateOperation1<? super T, ?, ? extends R>) - Method in class com.hazelcast.jet.pipeline.GroupAggregateBuilder
Adds another stage that will contribute its data to the aggregate operation to be performed.
add(StreamStage<E>) - Method in class com.hazelcast.jet.pipeline.WindowAggregateBuilder1
Adds another stage that will contribute its data to the aggregate operation to be performed.
add(StreamStage<T>, AggregateOperation1<? super T, ?, ? extends R>) - Method in class com.hazelcast.jet.pipeline.WindowAggregateBuilder
Adds another stage that will contribute its data to the aggregate operation to be performed.
add(StreamStageWithKey<T, K>) - Method in class com.hazelcast.jet.pipeline.WindowGroupAggregateBuilder1
Adds another stage that will contribute its data to the windowed group-and-aggregate stage being constructed.
add(StreamStageWithKey<T, K>, AggregateOperation1<? super T, ?, ? extends R>) - Method in class com.hazelcast.jet.pipeline.WindowGroupAggregateBuilder
Adds another stage that will contribute its data to the windowed group-and-aggregate stage being constructed.
add(E) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
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.
add(Object) - Method in interface com.hazelcast.cardinality.CardinalityEstimator
Add a new object in the estimation set.
add(Object) - Method in class com.hazelcast.jet.core.test.TestInbox
Convenience for inbox.queue().add(o)
add(Object) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Adds an item to the tail of the ringbuffer.
add(String, Schema) - Method in class org.apache.calcite.jdbc.HazelcastRootCalciteSchema
 
add(Permission) - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
add(Permission) - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
 
add(Permission) - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
 
add(PermissionCollection) - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
 
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(T) - Method in interface com.hazelcast.jet.pipeline.SourceBuilder.SourceBuffer
Adds an item to the buffer.
add(T) - Method in interface com.hazelcast.jet.pipeline.SourceBuilder.TimestampedSourceBuffer
Adds an item to the buffer, assigning System.currentTimeMillis() to it as the timestamp.
add(T, long) - Method in interface com.hazelcast.jet.pipeline.SourceBuilder.TimestampedSourceBuffer
Adds an item to the buffer, assigning a timestamp to it.
ADD - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_ALL - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_CACHE_CONFIG - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_CARDINALITY_ESTIMATOR_CONFIG - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_DATA_CONNECTION_CONFIG - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_DISTRIBUTED_OBJECT_LISTENER - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_DURABLE_EXECUTOR_CONFIG - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_ENTRY_LISTENER - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_EXECUTOR_CONFIG - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_FLAKE_ID_GENERATOR_CONFIG - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_INDEX - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_INTERCEPTOR - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_ITEM_LISTENER - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_LIST_CONFIG - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_MAP_CONFIG - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_MESSAGE_LISTENER - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_MULTIMAP_CONFIG - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_NAMESPACE_CONFIG - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_NEAR_CACHE_INVALIDATION_LISTENER - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_OR_UPDATE - Enum constant in enum class com.hazelcast.wan.WanEventType
Add/update event (can be caused by either adding or creating some data)
ADD_PARTITION_LOST_LISTENER - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_PN_COUNTER_CONFIG - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_QUEUE_CONFIG - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_RELIABLE_TOPIC_CONFIG - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_REPLICATED_MAP_CONFIG - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_RINGBUFFER_CONFIG - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_SCHEDULED_EXECUTOR_CONFIG - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_SET_CONFIG - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_TOPIC_CONFIG - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
ADD_VECTOR_COLLECTION_CONFIG - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
add1(long) - Method in class com.hazelcast.jet.accumulator.LongLongAccumulator
Adds the supplied amount to the first value.
add2(long) - Method in class com.hazelcast.jet.accumulator.LongLongAccumulator
Adds the supplied amount to the second value.
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
addAll(Collection<?>) - Method in class com.hazelcast.jet.core.test.TestInbox
Convenience for inbox.queue().addAll(collection)
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.
addAllowingOverflow(long) - Method in class com.hazelcast.jet.accumulator.LongAccumulator
Adds the supplied value to this accumulator, allowing integer overflow.
addAllowingOverflow(LongAccumulator) - Method in class com.hazelcast.jet.accumulator.LongAccumulator
Adds the value of the supplied accumulator to this accumulator, allowing integer overflow.
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(E, OverflowPolicy) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Asynchronously writes an item with a configurable OverflowPolicy.
addAsync(Object) - Method in interface com.hazelcast.cardinality.CardinalityEstimator
Add a new object in the estimation set.
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
Deprecated.
 
addBooleanField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
 
addByteArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
 
addByteField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
 
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
Deprecated.
 
addCharField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
 
addClass(Class<?>) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
Deprecated.
 
addClass(Class<?>...) - Method in class com.hazelcast.config.UserCodeNamespaceConfig
 
addClass(Class<?>...) - Method in class com.hazelcast.jet.config.JobConfig
Adds the given classes and recursively all their nested (inner & anonymous) classes to the Jet job's classpath.
addClass(Class<T>) - Method in class com.hazelcast.config.CompactSerializationConfig
Registers the class to be serialized with Compact serialization.
addClass(String) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
Deprecated.
 
addClass(URL, String) - Method in class com.hazelcast.config.UserCodeNamespaceConfig
 
addClassDefinition(ClassDefinition) - Method in class com.hazelcast.config.SerializationConfig
Deprecated, for removal: This API element is subject to removal in a future version.
Portable Serialization has been deprecated. We recommend you use Compact Serialization as Portable Serialization will be removed as of version 7.0.
addClasses(String...) - Method in class com.hazelcast.config.ClassFilter
 
addClasspathResource(File) - Method in class com.hazelcast.jet.config.JobConfig
Adds a file that will be available as a resource on the Jet job's classpath.
addClasspathResource(File, String) - Method in class com.hazelcast.jet.config.JobConfig
Adds a file that will be available as a resource on the Jet job's classpath.
addClasspathResource(String) - Method in class com.hazelcast.jet.config.JobConfig
Adds a file that will be available as a resource on the Jet job's classpath.
addClasspathResource(String, String) - Method in class com.hazelcast.jet.config.JobConfig
Adds a file that will be available as a resource on the Jet job's classpath.
addClasspathResource(URL) - Method in class com.hazelcast.jet.config.JobConfig
Adds a resource that will be available on the Jet job's classpath.
addClasspathResource(URL, String) - Method in class com.hazelcast.jet.config.JobConfig
Adds a resource that will be available on the Jet job's classpath.
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
 
addCPMapConfig(CPMapConfig) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Adds the CPMapConfig configuration.
addCustomClasspath(String, String) - Method in class com.hazelcast.jet.config.JobConfig
Adds custom classpath element to a stage with the given name.
addCustomClasspaths(String, List<String>) - Method in class com.hazelcast.jet.config.JobConfig
Adds custom classpath elements to a stage with the given name.
addCustomPublisherConfig(WanCustomPublisherConfig) - Method in class com.hazelcast.config.WanReplicationConfig
Adds a custom WAN publisher implementation configuration to this WAN replication.
addDataConnectionConfig(DataConnectionConfig) - Method in class com.hazelcast.config.Config
Adds a data connection configuration.
addDataSerializableFactory(int, DataSerializableFactory) - Method in class com.hazelcast.config.SerializationConfig
 
addDataSerializableFactoryClass(int, Class<? extends DataSerializableFactory>) - Method in class com.hazelcast.config.SerializationConfig
 
addDataSerializableFactoryClass(int, String) - Method in class com.hazelcast.config.SerializationConfig
 
addDateArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
Adds an array of Date's to the class definition
addDateField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
Adds a date field consisting of year, month of the year and day of the month to the class definition
addDecimalArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
Adds an array of Decimal's to the class definition
addDecimalField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
Adds a decimal which is arbitrary precision and scale floating-point number to the class definition
addDeviceConfig(DeviceConfig) - Method in class com.hazelcast.config.Config
Adds the device configuration.
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
Deprecated.
 
addDoubleField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
 
addDurableExecutorConfig(DurableExecutorConfig) - Method in class com.hazelcast.config.Config
Adds the durable executor configuration.
ADDED - Enum constant in enum class com.hazelcast.core.EntryEventType
Fired if an entry is added.
ADDED - Enum constant in enum class com.hazelcast.core.ItemEventType
Fired when an item is added.
ADDED - Enum constant in enum class com.hazelcast.cp.event.CPMembershipEvent.EventType
Event type fired when a new CP member is added to the CP Subsystem.
addEndpoint(String) - Method in class com.hazelcast.config.PermissionConfig
 
addEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Adds an entry listener for this map.
addEntryListener(EntryListener<K, V>, boolean) - Method in interface com.hazelcast.multimap.MultiMap
Adds an entry listener for this multimap.
addEntryListener(EntryListener<K, V>, Predicate<K, V>) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Adds a continuous entry listener for this map.
addEntryListener(EntryListener<K, V>, Predicate<K, V>, K) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Adds a continuous 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>, K, boolean) - Method in interface com.hazelcast.multimap.MultiMap
Adds the specified entry listener for the specified key.
addEntryListener(MapListener, 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, Predicate<K, V>, 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.QueryCache
 
addEntryListener(MapListener, Predicate<K, V>, K, 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.QueryCache
 
addEntryListener(MapListener, K, boolean) - Method in interface com.hazelcast.map.IMap
Adds a MapListener for this map.
addEntryListener(MapListener, K, boolean) - Method in interface com.hazelcast.map.QueryCache
 
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
Deprecated.
 
addFile(String, File) - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
Add an attached file or folder.
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
Deprecated.
 
addFloatField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
 
addGroupAvailabilityListener(CPGroupAvailabilityListener) - Method in interface com.hazelcast.cp.CPSubsystem
Registers a new CPGroupAvailabilityListener to listen CP group availability changes.
addGroupAvailabilityListener(CPGroupAvailabilityListener) - Method in class com.hazelcast.cp.CPSubsystemStubImpl
 
addImplicitFuncNamesToBuilder(ImmutableSortedSet.Builder<String>) - Method in class org.apache.calcite.jdbc.HazelcastRootCalciteSchema
 
addImplicitFunctionsToBuilder(ImmutableList.Builder<Function>, String, boolean) - Method in class org.apache.calcite.jdbc.HazelcastRootCalciteSchema
 
addImplicitSubSchemaToBuilder(ImmutableSortedMap.Builder<String, CalciteSchema>) - Method in class org.apache.calcite.jdbc.HazelcastRootCalciteSchema
 
addImplicitTablesBasedOnNullaryFunctionsToBuilder(ImmutableSortedMap.Builder<String, Table>) - Method in class org.apache.calcite.jdbc.HazelcastRootCalciteSchema
 
addImplicitTableToBuilder(ImmutableSortedSet.Builder<String>) - Method in class org.apache.calcite.jdbc.HazelcastRootCalciteSchema
 
addImplicitTypeNamesToBuilder(ImmutableSortedSet.Builder<String>) - Method in class org.apache.calcite.jdbc.HazelcastRootCalciteSchema
 
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(IndexConfig) - Method in interface com.hazelcast.map.QueryCache
 
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(IndexType, String...) - 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
 
addInner(BatchStage<T1_IN>, JoinClause<K, T0, T1_IN, T1>) - Method in class com.hazelcast.jet.pipeline.GeneralHashJoinBuilder
Adds another contributing pipeline stage to the hash-join operation.
addIntArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
 
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
Deprecated.
 
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(File) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
Deprecated.
 
addJar(File) - Method in class com.hazelcast.jet.config.JobConfig
Adds a JAR whose contents will be accessible to all the code attached to the underlying pipeline or DAG, but not to any other code.
addJar(String) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
Deprecated.
String jarPath is searched in following order: 1.
addJar(String) - Method in class com.hazelcast.jet.config.JobConfig
Adds a JAR whose contents will be accessible to all the code attached to the underlying pipeline or DAG, but not to any other code.
addJar(URL) - Method in class com.hazelcast.jet.config.JobConfig
Adds a JAR whose contents will be accessible to all the code attached to the underlying pipeline or DAG, but not to any other code.
addJar(URL, String) - Method in class com.hazelcast.config.UserCodeNamespaceConfig
 
addJarsInZip(File) - Method in class com.hazelcast.jet.config.JobConfig
Adds a ZIP file with JARs whose contents will be accessible to all the code attached to the underlying pipeline or DAG, but not to any other code.
addJarsInZip(String) - Method in class com.hazelcast.jet.config.JobConfig
Adds a ZIP file with JARs whose contents will be accessible to all the code attached to the underlying pipeline or DAG, but not to any other code.
addJarsInZip(URL) - Method in class com.hazelcast.jet.config.JobConfig
Adds a ZIP file with JARs whose contents will be accessible to all the code attached to the underlying pipeline or DAG, but not to any other code.
addJarsInZip(URL, String) - Method in class com.hazelcast.config.UserCodeNamespaceConfig
 
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(EntryListener<K, V>) - Method in interface com.hazelcast.multimap.MultiMap
Adds a local entry listener for this multimap.
addLocalEntryListener(EntryListener<K, V>, boolean) - Method in interface com.hazelcast.multimap.MultiMap
MultiMap.addLocalEntryListener(EntryListener) Adds a local entry listener with ability to configure if event should contain the value for this multimap.
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.
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
Deprecated.
 
addLongField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
 
addMapConfig(MapConfig) - Method in class com.hazelcast.config.Config
Adds the map configuration.
addMapPartitionLostListenerConfig(MapPartitionLostListenerConfig) - Method in class com.hazelcast.config.MapConfig
 
addMember(Member) - Method in interface com.hazelcast.spi.partitiongroup.MemberGroup
 
addMember(String) - Method in class com.hazelcast.config.TcpIpConfig
Adds a 'well known' member.
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.
addMembershipListener(CPMembershipListener) - Method in class com.hazelcast.cp.CPSubsystemStubImpl
 
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.
addNamespaceConfig(UserCodeNamespaceConfig) - Method in class com.hazelcast.config.UserCodeNamespacesConfig
Adds the specified namespaceConfig, replacing any existing UserCodeNamespaceConfig with the same name.
addNamespaceConfigLocally(UserCodeNamespaceConfig) - Method in class com.hazelcast.config.UserCodeNamespacesConfig
Adds the specified namespaceConfig, replacing any existing UserCodeNamespaceConfig with the same name.
addNamespaceConfigLocally(UserCodeNamespacesConfig, UserCodeNamespaceConfig) - Static method in class com.hazelcast.config.ConfigAccessor
Adds Namespace directly to namespaces configuration without Broadcasting to cluster members.
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
addObserver(Observer<T>) - Method in interface com.hazelcast.jet.Observable
Registers an Observer to this Observable.
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
Deprecated.
 
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
Deprecated.
 
addPackage(String...) - Method in class com.hazelcast.jet.config.JobConfig
Adds recursively all the classes and resources in given packages to the Jet job's classpath.
addPackages(String...) - Method in class com.hazelcast.config.ClassFilter
 
addParameter(Object) - Method in class com.hazelcast.sql.SqlStatement
Adds a single parameter value to the end of the parameter values list.
addParameter(String, Object) - Method in interface com.hazelcast.auditlog.EventBuilder
Adds single event parameter to the parameters Map.
addPartitionInitialOffset(int, long) - Method in class com.hazelcast.jet.kafka.TopicsConfig.TopicConfig
Adds the initial offset for given partition to the configuration.
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.
addPartitions(int) - Method in class com.hazelcast.jet.core.EventTimeMapper
Adds addedCount partitions.
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
Deprecated.
 
addPortableFactory(int, PortableFactory) - Method in class com.hazelcast.config.SerializationConfig
Deprecated, for removal: This API element is subject to removal in a future version.
Portable Serialization has been deprecated. We recommend you use Compact Serialization as Portable Serialization will be removed as of version 7.0.
addPortableFactoryClass(int, Class<? extends PortableFactory>) - Method in class com.hazelcast.config.SerializationConfig
Deprecated, for removal: This API element is subject to removal in a future version.
Portable Serialization has been deprecated. We recommend you use Compact Serialization as Portable Serialization will be removed as of version 7.0.
addPortableFactoryClass(int, String) - Method in class com.hazelcast.config.SerializationConfig
Deprecated, for removal: This API element is subject to removal in a future version.
Portable Serialization has been deprecated. We recommend you use Compact Serialization as Portable Serialization will be removed as of version 7.0.
addPortableField(String, ClassDefinition) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
 
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(QueryCacheConfig) - Method in class com.hazelcast.config.MapConfig
Adds a new QueryCacheConfig to this MapConfig.
addQueryCacheConfig(String, QueryCacheConfig) - Method in class com.hazelcast.client.config.ClientConfig
 
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(Address) - Constructor for class com.hazelcast.cluster.Address
 
Address(String, int) - Constructor for class com.hazelcast.cluster.Address
 
Address(String, InetAddress, 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 - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
Network address of the cluster member sourcing the metric.
AddressHelper - Class in com.hazelcast.client.util
This is a client side utility class for working with addresses and cluster connections
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.
addSerializer(CompactSerializer<T>) - Method in class com.hazelcast.config.CompactSerializationConfig
Registers the given Compact serializer.
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
Deprecated.
 
addShortField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
 
addSplitBrainProtectionConfig(SplitBrainProtectionConfig) - Method in class com.hazelcast.config.Config
Adds the split-brain protection configuration.
addStatusListener(JobStatusListener) - Method in interface com.hazelcast.jet.Job
Associates the given listener to this job.
addStringArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
 
addStringField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
 
addTimeArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
Adds an array of Time's to the class definition
addTimeField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
Adds a time field consisting of hour, minute, seconds and nanos parts to the class definition
addTimestampArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
Adds an array of Timestamp's to the class definition
addTimestampField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
Adds a timestamp field consisting of year, month of the year, day of the month, hour, minute, seconds, nanos parts to the class definition
addTimestamps(ToLongFunctionEx<? super T>, long) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
Adds a timestamp to each item in the stream using the supplied function and specifies the allowed amount of disorder between them.
addTimestampWithTimezoneArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
Adds an array of TimestampWithTimezone's to the class definition
addTimestampWithTimezoneField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
Adds a timestamp with timezone field consisting of year, month of the year, day of the month, offset seconds, hour, minute, seconds, nanos parts to the class definition
addTopic(String) - Method in class com.hazelcast.jet.kafka.TopicsConfig
Creates empty topic configuration and saves it in the map under the topic name.
addTopicConfig(TopicConfig) - Method in class com.hazelcast.config.Config
Adds the topic configuration.
addTopicConfig(TopicsConfig.TopicConfig) - Method in class com.hazelcast.jet.kafka.TopicsConfig
addTopics(List<String>) - Method in class com.hazelcast.jet.kafka.TopicsConfig
Creates new topic configurations for every provided topic from the list and saves them in the map.
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.
addUser(String, SimpleAuthenticationConfig.UserDto) - Method in class com.hazelcast.config.security.SimpleAuthenticationConfig
Adds one user to the configuration.
addUser(String, String, String...) - Method in class com.hazelcast.config.security.SimpleAuthenticationConfig
Adds one user to the configuration.
addUTFArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
for the sake of better naming. Use ClassDefinitionBuilder.addStringArrayField(String) instead.
addUTFField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
for the sake of better naming. Use ClassDefinitionBuilder.addStringField(String) instead.
addVectorCollectionConfig(VectorCollectionConfig) - Method in class com.hazelcast.config.Config
Add vector collection config.
addVectorIndexConfig(VectorIndexConfig) - Method in class com.hazelcast.config.vector.VectorCollectionConfig
Adds a vector index configuration to this vector collection configuration.
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
aggregate(AggregateOperation1<? super T, ?, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
Attaches a stage that performs the given aggregate operation over all the items it receives.
aggregate(AggregateOperation1<? super T, ?, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
Attaches a stage that performs the given group-and-aggregate operation.
aggregate(AggregateOperation1<? super T, ?, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StageWithKeyAndWindow
Attaches a stage that performs the given group-and-aggregate operation.
aggregate(AggregateOperation1<? super T, ?, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StageWithWindow
Attaches a stage that performs the given aggregate operation over all the items that belong to a given window.
AGGREGATE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
AGGREGATE_COMBINING_ACCUMULATE - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
 
AGGREGATE_WITH_PREDICATE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
aggregate2(AggregateOperation1<? super T, ?, ? extends R0>, BatchStage<T1>, AggregateOperation1<? super T1, ?, ? extends R1>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
Attaches a stage that co-aggregates the data from this and the supplied stage by performing a separate aggregate operation on each and emits a single Tuple2 with their results.
aggregate2(AggregateOperation1<? super T, ?, ? extends R0>, BatchStageWithKey<? extends T1, ? extends K>, AggregateOperation1<? super T1, ?, ? extends R1>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
Attaches a stage that performs the given cogroup-and-aggregate transformation of the items from both this stage and stage1 you supply.
aggregate2(AggregateOperation1<? super T, ?, ? extends R0>, StreamStage<T1>, AggregateOperation1<? super T1, ?, ? extends R1>) - Method in interface com.hazelcast.jet.pipeline.StageWithWindow
Attaches a stage that performs the given co-aggregate operations over the items from this stage and stage1 you supply.
aggregate2(AggregateOperation1<? super T, ?, ? extends R0>, StreamStageWithKey<T1, ? extends K>, AggregateOperation1<? super T1, ?, ? extends R1>) - Method in interface com.hazelcast.jet.pipeline.StageWithKeyAndWindow
Attaches a stage that performs the given cogroup-and-aggregate operation over the items from both this stage and stage1 you supply.
aggregate2(BatchStage<T1>, AggregateOperation2<? super T, ? super T1, ?, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
Attaches a stage that performs the given aggregate operation over all the items it receives from both this stage and stage1 you supply.
aggregate2(BatchStageWithKey<T1, ? extends K>, AggregateOperation2<? super T, ? super T1, ?, R>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
Attaches a stage that performs the given cogroup-and-aggregate operation over the items from both this stage and stage1 you supply.
aggregate2(StreamStage<T1>, AggregateOperation2<? super T, ? super T1, ?, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StageWithWindow
Attaches a stage that performs the given aggregate operation over all the items that belong to the same window.
aggregate2(StreamStageWithKey<T1, ? extends K>, AggregateOperation2<? super T, ? super T1, ?, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StageWithKeyAndWindow
Attaches a stage that performs the given cogroup-and-aggregate operation over the items from both this stage and stage1 you supply.
aggregate3(AggregateOperation1<? super T, ?, ? extends R0>, BatchStage<T1>, AggregateOperation1<? super T1, ?, ? extends R1>, BatchStage<T2>, AggregateOperation1<? super T2, ?, ? extends R2>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
Attaches a stage that co-aggregates the data from this and the two supplied stages by performing a separate aggregate operation on each and emits a single Tuple3 with their results.
aggregate3(AggregateOperation1<? super T, ?, ? extends R0>, BatchStageWithKey<T1, ? extends K>, AggregateOperation1<? super T1, ?, ? extends R1>, BatchStageWithKey<T2, ? extends K>, AggregateOperation1<? super T2, ?, ? extends R2>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
Attaches a stage that performs the given cogroup-and-aggregate transformation of the items from this stage as well as stage1 and stage2 you supply.
aggregate3(AggregateOperation1<? super T, ?, ? extends R0>, StreamStage<T1>, AggregateOperation1<? super T1, ?, ? extends R1>, StreamStage<T2>, AggregateOperation1<? super T2, ?, ? extends R2>) - Method in interface com.hazelcast.jet.pipeline.StageWithWindow
Attaches a stage that performs the given aggregate operation over all the items that belong to the same window.
aggregate3(AggregateOperation1<? super T, ?, ? extends R0>, StreamStageWithKey<T1, ? extends K>, AggregateOperation1<? super T1, ?, ? extends R1>, StreamStageWithKey<T2, ? extends K>, AggregateOperation1<? super T2, ?, ? extends R2>) - Method in interface com.hazelcast.jet.pipeline.StageWithKeyAndWindow
Attaches a stage that performs the given cogroup-and-aggregate operation over the items from both this stage and stage1 you supply.
aggregate3(BatchStage<T1>, BatchStage<T2>, AggregateOperation3<? super T, ? super T1, ? super T2, ?, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
Attaches a stage that performs the given aggregate operation over all the items it receives from this stage as well as stage1 and stage2 you supply.
aggregate3(BatchStageWithKey<T1, ? extends K>, BatchStageWithKey<T2, ? extends K>, AggregateOperation3<? super T, ? super T1, ? super T2, ?, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
Attaches a stage that performs the given cogroup-and-aggregate operation over the items from this stage as well as stage1 and stage2 you supply.
aggregate3(StreamStage<T1>, StreamStage<T2>, AggregateOperation3<? super T, ? super T1, ? super T2, ?, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StageWithWindow
Attaches a stage that performs the given aggregate operation over the items it receives from this stage as well as stage1 and stage2 you supply.
aggregate3(StreamStageWithKey<T1, ? extends K>, StreamStageWithKey<T2, ? extends K>, AggregateOperation3<? super T, ? super T1, ? super T2, ?, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StageWithKeyAndWindow
Attaches a stage that performs the given cogroup-and-aggregate operation over the items from this stage as well as stage1 and stage2 you supply.
aggregateBuilder() - Method in interface com.hazelcast.jet.pipeline.BatchStage
Offers a step-by-step API to build a pipeline stage that co-aggregates the data from several input stages.
aggregateBuilder() - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
Offers a step-by-step API to build a pipeline stage that co-aggregates the data from several input stages.
aggregateBuilder() - Method in interface com.hazelcast.jet.pipeline.StageWithKeyAndWindow
Offers a step-by-step API to build a pipeline stage that co-aggregates the data from several input stages.
aggregateBuilder() - Method in interface com.hazelcast.jet.pipeline.StageWithWindow
Offers a step-by-step API to build a pipeline stage that co-aggregates the data from several input stages.
aggregateBuilder(AggregateOperation1<? super T, ?, ? extends R0>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
Offers a step-by-step API to build a pipeline stage that co-aggregates the data from several input stages.
aggregateBuilder(AggregateOperation1<? super T, ?, ? extends R0>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
Offers a step-by-step API to build a pipeline stage that co-aggregates the data from several input stages.
aggregateBuilder(AggregateOperation1<? super T, ?, ? extends R0>) - Method in interface com.hazelcast.jet.pipeline.StageWithKeyAndWindow
Offers a step-by-step API to build a pipeline stage that co-aggregates the data from several input stages.
aggregateBuilder(AggregateOperation1<? super T, ?, ? extends R0>) - Method in interface com.hazelcast.jet.pipeline.StageWithWindow
Offers a step-by-step API to build a pipeline stage that co-aggregates the data from several input stages.
AggregateBuilder<R0> - Class in com.hazelcast.jet.pipeline
Offers a step-by-step API to build a pipeline stage that co-aggregates the data from several input stages.
AggregateBuilder1<T0> - Class in com.hazelcast.jet.pipeline
Offers a step-by-step API to build a pipeline stage that co-aggregates the data from several input stages.
aggregateByKeyP(List<FunctionEx<?, ? extends K>>, AggregateOperation<A, R>, BiFunctionEx<? super K, ? super R, OUT>) - Static method in class com.hazelcast.jet.core.processor.Processors
Returns a supplier of processors for a vertex that groups items by key and performs the provided aggregate operation on each group.
AggregateOperation<A,R> - Interface in com.hazelcast.jet.aggregate
Contains primitives needed to compute an aggregated result of data processing.
AggregateOperation1<T,A,R> - Interface in com.hazelcast.jet.aggregate
Specialization of AggregateOperation (refer to its extensive documentation) to the "arity-1" case with a single data stream being aggregated over.
aggregateOperation2(AggregateOperation1<? super T0, A0, ? extends R0>, AggregateOperation1<? super T1, A1, ? extends R1>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Convenience for aggregateOperation2(aggrOp0, aggrOp1, finishFn) that outputs a Tuple2(result0, result1).
aggregateOperation2(AggregateOperation1<? super T0, A0, ? extends R0>, AggregateOperation1<? super T1, A1, ? extends R1>, BiFunctionEx<? super R0, ? super R1, ? extends R>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that is a composite of two independent aggregate operations, each one accepting its own input.
AggregateOperation2<T0,T1,A,R> - Interface in com.hazelcast.jet.aggregate
Specialization of AggregateOperation (refer to its extensive documentation) to the "arity-2" case with two data streams being aggregated over.
aggregateOperation3(AggregateOperation1<? super T0, A0, ? extends R0>, AggregateOperation1<? super T1, A1, ? extends R1>, AggregateOperation1<? super T2, A2, ? extends R2>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Convenience for aggregateOperation3(aggrOp0, aggrOp1, aggrOp2, finishFn) that outputs a Tuple3(result0, result1, result2).
aggregateOperation3(AggregateOperation1<? super T0, A0, ? extends R0>, AggregateOperation1<? super T1, A1, ? extends R1>, AggregateOperation1<? super T2, A2, ? extends R2>, TriFunction<? super R0, ? super R1, ? super R2, ? extends R>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that is a composite of three independent aggregate operations, each one accepting its own input.
AggregateOperation3<T0,T1,T2,A,R> - Interface in com.hazelcast.jet.aggregate
Specialization of AggregateOperation (refer to its extensive documentation) to the "arity-3" case with three data streams being aggregated over.
AggregateOperationBuilder<A> - Class in com.hazelcast.jet.aggregate
A builder object that can be used to construct the definition of an aggregate operation in a step-by-step manner.
AggregateOperationBuilder.Arity1<T0,A,R> - Class in com.hazelcast.jet.aggregate
The arity-1 variant of the aggregate operation builder.
AggregateOperationBuilder.Arity2<T0,T1,A,R> - Class in com.hazelcast.jet.aggregate
The arity-2 variant of the aggregate operation builder.
AggregateOperationBuilder.Arity3<T0,T1,T2,A,R> - Class in com.hazelcast.jet.aggregate
The arity-3 variant of the aggregate operation builder.
AggregateOperationBuilder.VarArity<A,R> - Class in com.hazelcast.jet.aggregate
The variable-arity variant of the aggregate operation builder.
AggregateOperations - Class in com.hazelcast.jet.aggregate
Utility class with factory methods for several useful aggregate operations.
aggregateP(AggregateOperation<A, R>) - Static method in class com.hazelcast.jet.core.processor.Processors
Returns a supplier of processors for a vertex that performs the provided aggregate operation on all the items it receives.
aggregateToSessionWindowP(long, long, List<ToLongFunctionEx<?>>, List<FunctionEx<?, ? extends K>>, AggregateOperation<A, ? extends R>, KeyedWindowResultFunction<? super K, ? super R, ? extends OUT>) - Static method in class com.hazelcast.jet.core.processor.Processors
Returns a supplier of processors for a vertex that aggregates events into session windows.
aggregateToSlidingWindowP(List<FunctionEx<?, ? extends K>>, List<ToLongFunctionEx<?>>, TimestampKind, SlidingWindowPolicy, long, AggregateOperation<A, ? extends R>, KeyedWindowResultFunction<? super K, ? super R, ? extends OUT>) - Static method in class com.hazelcast.jet.core.processor.Processors
Returns a supplier of processors for a vertex that aggregates events into a sliding window in a single stage (see the class Javadoc for an explanation of aggregation stages).
aggregateToSlidingWindowP(List<FunctionEx<?, ? extends K>>, List<ToLongFunctionEx<?>>, TimestampKind, SlidingWindowPolicy, long, AggregateOperation<A, ? extends R>, KeyedWindowResultFunction<? super K, ? super R, ? extends OUT>, byte) - Static method in class com.hazelcast.jet.core.processor.Processors
Returns a supplier of processors for a vertex that aggregates events into a sliding window in a single stage (see the class Javadoc for an explanation of aggregation stages).
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(AliasedDiscoveryConfig) - Constructor for class com.hazelcast.config.AliasedDiscoveryConfig
 
AliasedDiscoveryConfig(String) - Constructor for class com.hazelcast.config.AliasedDiscoveryConfig
 
AliasedDiscoveryConfig(String, boolean, boolean, Map<String, String>) - Constructor for class com.hazelcast.config.AliasedDiscoveryConfig
 
ALL - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
Type backed by AllPermissions, which implies all checked permissions.
ALL_LITE_MEMBERS - Static variable in interface com.hazelcast.jet.JetMemberSelector
Selects all lite members on the cluster.
allOf(AggregateOperation1<? super T, A0, ? extends R0>, AggregateOperation1<? super T, A1, ? extends R1>, BiFunctionEx<? super R0, ? super R1, ? extends R>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that is a composite of two aggregate operations.
allOf(AggregateOperation1<? super T, A0, ? extends R0>, AggregateOperation1<? super T, A1, ? extends R1>, AggregateOperation1<? super T, A2, ? extends R2>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
allOf(AggregateOperation1<? super T, A0, ? extends R0>, AggregateOperation1<? super T, A1, ? extends R1>, AggregateOperation1<? super T, A2, ? extends R2>, TriFunction<? super R0, ? super R1, ? super R2, ? extends R>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that is a composite of three aggregate operations.
allOf(AggregateOperation1<? super T, A0, R0>, AggregateOperation1<? super T, A1, R1>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
AllOfAggregationBuilder<T> - Class in com.hazelcast.jet.aggregate
Offers a step-by-step API to create a composite of multiple aggregate operations.
allOfBuilder() - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns a builder object that helps you create a composite of multiple aggregate operations.
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
allToOne() - Method in class com.hazelcast.jet.core.Edge
Activates a special-cased PARTITIONED routing policy where all items will be routed to the same partition ID.
allToOne(Object) - Method in class com.hazelcast.jet.core.Edge
Activates a special-cased PARTITIONED routing policy where all items will be routed to the same partition ID, determined from the given key.
alter(IFunction<E, E>) - Method in interface com.hazelcast.cp.IAtomicReference
Alters the currently stored reference by applying a function on it.
alter(IFunction<Long, Long>) - Method in interface com.hazelcast.cp.IAtomicLong
Alters the currently stored value by applying a function on it.
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.
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.
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.
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.
alterAsync(IFunction<E, E>) - Method in interface com.hazelcast.cp.IAtomicReference
Alters the currently stored reference by applying a function on it.
alterAsync(IFunction<Long, Long>) - Method in interface com.hazelcast.cp.IAtomicLong
Alters the currently stored value by applying a function on it.
ALWAYS - Enum constant in enum class com.hazelcast.config.CacheDeserializedValues
Always cache de-serialized values
ALWAYS - Enum constant in enum class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.PostgresSnapshotMode
Always perform a snapshot when starting.
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(TriPredicate<? super T, ? super U, ? super V>) - Method in interface com.hazelcast.jet.function.TriPredicate
Returns a composite predicate which evaluates the equivalent of this.test(t, u, v) && other.test(t, u, v).
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.
andAccumulate(BiConsumerEx<? super A, ? super T>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder
Registers the AggregateOperation1.accumulateFn() accumulate} primitive.
andAccumulate(Tag<T>, BiConsumerEx<? super A, ? super T>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder
Registers the accumulate primitive for the stream tagged with the supplied tag.
andAccumulate(Tag<T>, BiConsumerEx<? super A, T>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.VarArity
Registers the accumulate primitive for the stream tagged with the supplied tag.
andAccumulate0(BiConsumerEx<? super A, ? super T0>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder
Registers the accumulate primitive for stream-0.
andAccumulate1(BiConsumerEx<? super A, ? super T1>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity1
Registers the AggregateOperation2.accumulateFn1() accumulate} primitive for stream-1, returning the arity-2 variant of the builder.
andAccumulate2(BiConsumerEx<? super A, ? super T2>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity2
Registers the accumulate primitive for stream-2, returning the arity-3 variant of the builder.
andCombine(BiConsumerEx<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity1
Registers the combine primitive.
andCombine(BiConsumerEx<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity2
Registers the combine primitive.
andCombine(BiConsumerEx<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity3
Registers the combine primitive.
andCombine(BiConsumerEx<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.VarArity
Registers the combine primitive.
andDeduct(BiConsumerEx<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity1
Registers the deduct primitive.
andDeduct(BiConsumerEx<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity2
Registers the deduct primitive.
andDeduct(BiConsumerEx<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity3
Registers the deduct primitive.
andDeduct(BiConsumerEx<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.VarArity
Registers the deduct primitive.
andExport(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity1
Registers the export primitive.
andExport(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity2
Registers the export primitive.
andExport(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity3
Registers the export primitive.
andExport(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.VarArity
Registers the export primitive.
andExportFinish(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity1
Registers the supplied function as both the export and finish primitive.
andExportFinish(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity2
Registers the supplied function as both the export and finish primitive.
andExportFinish(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity3
Registers the supplied function as both the export and finish primitive.
andExportFinish(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.VarArity
Registers the supplied function as both the export and finish primitive.
andFinish(FunctionEx<? super A, ? extends R>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity1
Registers the finish primitive.
andFinish(FunctionEx<? super A, ? extends R>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity2
Registers the finish primitive.
andFinish(FunctionEx<? super A, ? extends R>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity3
Registers the finish primitive.
andFinish(FunctionEx<? super A, ? extends R>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.VarArity
Registers the finish primitive.
andThen(BiConsumerEx<? super T, ? super U>) - Method in interface com.hazelcast.function.BiConsumerEx
andThen(ConsumerEx<? super T>) - Method in interface com.hazelcast.function.ConsumerEx
andThen(FunctionEx<? super R, ? extends R_NEW>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
Returns a copy of this aggregate operation, but with the export and finish primitives composed with the supplied thenFn.
andThen(FunctionEx<? super R, ? extends R_NEW>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation1
 
andThen(FunctionEx<? super R, ? extends R_NEW>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation2
 
andThen(FunctionEx<? super R, ? extends R_NEW>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation3
 
andThen(FunctionEx<? super R, ? extends V>) - Method in interface com.hazelcast.function.BiFunctionEx
andThen(FunctionEx<? super R, ? extends V>) - Method in interface com.hazelcast.function.FunctionEx
andThen(FunctionEx<? super T, ? extends V>) - Method in interface com.hazelcast.function.SupplierEx
ANY - Enum constant in enum class com.hazelcast.sql.SqlExpectedResultType
The statement may produce either rows or an update count.
anyFrom(String) - Static method in class com.hazelcast.jet.json.JsonUtil
Converts a JSON string to an Object.
append(T) - Method in class com.hazelcast.jet.core.AppendableTraverser
Returns a traverser that will return all the items of this traverser, plus an additional item once this one returns null.
append(T) - Method in interface com.hazelcast.jet.Traverser
Returns a traverser that will return all the items of this traverser, plus an additional item once this one returns null.
AppendableTraverser<T> - Class in com.hazelcast.jet.core
A traverser with an internal ArrayDeque.
AppendableTraverser(int) - Constructor for class com.hazelcast.jet.core.AppendableTraverser
Creates an appendable traverser.
appendLabels(Set<String>) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
appendProperties(Map<String, ? extends Comparable>) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
appendProperties(Properties) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
appendToken(StringBuilder, StringBuilder) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
apply(long, long, K, R, boolean) - Method in interface com.hazelcast.jet.core.function.KeyedWindowResultFunction
Applies the function to the given arguments
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(IFunction<Long, R>) - Method in interface com.hazelcast.cp.IAtomicLong
Applies a function on the value, the actual stored value will not change.
apply(FunctionEx<? super BatchStage<T>, ? extends BatchStage<R>>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
Transforms this stage using the provided transformFn and returns the transformed stage.
apply(FunctionEx<? super StreamStage<T>, ? extends StreamStage<R>>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
Transforms this stage using the provided transformFn and returns the transformed stage.
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.
apply(Map.Entry<K, V>) - Method in interface com.hazelcast.query.Predicate
Applies this predicate to the given map entry.
apply(T) - Method in interface com.hazelcast.core.IFunction
 
apply(T) - Method in interface com.hazelcast.function.FunctionEx
 
apply(T0, T1, T2) - Method in interface com.hazelcast.jet.function.TriFunction
Applies this function to the given arguments.
apply(T0, T1, T2, T3) - Method in interface com.hazelcast.jet.function.QuadFunction
Applies this function to the given arguments.
apply(T0, T1, T2, T3, T4) - Method in interface com.hazelcast.jet.function.PentaFunction
Applies this function to the given arguments.
apply(T, long) - Method in interface com.hazelcast.jet.core.function.ObjLongBiFunction
Applies this function to the given arguments.
apply(T, T) - Method in interface com.hazelcast.function.BinaryOperatorEx
 
apply(T, U) - Method in interface com.hazelcast.function.BiFunctionEx
 
APPLY_FN_ENTRY_PROCESSOR - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
 
APPLY_VALUE_ENTRY_PROCESSOR - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
 
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<E, R>) - Method in interface com.hazelcast.cp.IAtomicReference
Applies a function on the value, the actual stored value will not change.
applyAsync(IFunction<Long, R>) - Method in interface com.hazelcast.cp.IAtomicLong
Applies a function on the value, the actual stored value will not change.
applyEx(T) - Method in interface com.hazelcast.function.FunctionEx
Exception-declaring version of Function.apply(T).
applyEx(T0, T1, T2) - Method in interface com.hazelcast.jet.function.TriFunction
Exception-declaring variant of TriFunction.apply(T0, T1, T2).
applyEx(T0, T1, T2, T3) - Method in interface com.hazelcast.jet.function.QuadFunction
Exception-declaring variant of QuadFunction.apply(T0, T1, T2, T3).
applyEx(T0, T1, T2, T3, T4) - Method in interface com.hazelcast.jet.function.PentaFunction
Exception-declaring variant of PentaFunction.apply(T0, T1, T2, T3, T4).
applyEx(T, long) - Method in interface com.hazelcast.jet.core.function.ObjLongBiFunction
Exception-declaring version of ObjLongBiFunction.apply(T, long).
applyEx(T, T) - Method in interface com.hazelcast.function.BinaryOperatorEx
Exception-declaring version of BiFunction.apply(T, U).
applyEx(T, U) - Method in interface com.hazelcast.function.BiFunctionEx
Exception-declaring version of BiFunction.apply(T, U).
applyTo(JobConfig) - Method in class com.hazelcast.jet.config.DeltaJobConfig
Applies the changes represented by this instance to the specified configuration.
ArchUnitRules - Class in com.hazelcast.test.archunit
 
ArchUnitTestSupport - Class in com.hazelcast.test.archunit
 
ArchUnitTestSupport() - Constructor for class com.hazelcast.test.archunit.ArchUnitTestSupport
 
args(Resources.Inst) - Static method in class org.apache.calcite.runtime.ResourceUtil
 
arity() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
Returns the number of contributing streams this operation is set up to handle.
ARRAY_OF_BOOLEAN - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
 
ARRAY_OF_CHAR - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
Deprecated.
Portable Serialization has been deprecated. We recommend you use Compact Serialization as Portable Serialization will be removed as of version 7.0.
ARRAY_OF_COMPACT - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
Supported only for Compact.
ARRAY_OF_DATE - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
 
ARRAY_OF_DECIMAL - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
 
ARRAY_OF_FLOAT32 - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
 
ARRAY_OF_FLOAT64 - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
 
ARRAY_OF_INT16 - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
 
ARRAY_OF_INT32 - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
 
ARRAY_OF_INT64 - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
 
ARRAY_OF_INT8 - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
 
ARRAY_OF_NULLABLE_BOOLEAN - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
Supported only for Compact.
ARRAY_OF_NULLABLE_FLOAT32 - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
Supported only for Compact.
ARRAY_OF_NULLABLE_FLOAT64 - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
Supported only for Compact.
ARRAY_OF_NULLABLE_INT16 - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
Supported only for Compact.
ARRAY_OF_NULLABLE_INT32 - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
Supported only for Compact.
ARRAY_OF_NULLABLE_INT64 - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
Supported only for Compact.
ARRAY_OF_NULLABLE_INT8 - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
Supported only for Compact.
ARRAY_OF_PORTABLE - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
Deprecated, for removal: This API element is subject to removal in a future version.
Portable Serialization has been deprecated. We recommend you use Compact Serialization as Portable Serialization will be removed as of version 7.0.
ARRAY_OF_STRING - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
 
ARRAY_OF_TIME - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
 
ARRAY_OF_TIMESTAMP - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
 
ARRAY_OF_TIMESTAMP_WITH_TIMEZONE - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
 
asCredentialsFactory() - Method in class com.hazelcast.config.security.RealmConfig
 
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(ClassLoader) - Method in class com.hazelcast.config.security.TokenIdentityConfig
 
asCredentialsFactory(ClassLoader) - Method in class com.hazelcast.config.security.UsernamePasswordIdentityConfig
 
asLightJob() - Method in interface com.hazelcast.jet.JetService.JobBuilder
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.SimpleAuthenticationConfig
 
asLoginModuleConfigs() - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
 
assertAnyOrder(String, Collection<? extends T>) - Static method in class com.hazelcast.jet.pipeline.test.Assertions
Asserts that the previous stage emitted the expected items in any order, but nothing else.
assertAnyOrder(String, Collection<? extends T>) - Static method in class com.hazelcast.jet.pipeline.test.AssertionSinks
Asserts that the previous stage emitted the expected items in any order, but nothing else.
assertAnyOrder(Collection<? extends T>) - Static method in class com.hazelcast.jet.pipeline.test.Assertions
Asserts that the previous stage emitted the expected items in any order, but nothing else.
assertAnyOrder(Collection<? extends T>) - Static method in class com.hazelcast.jet.pipeline.test.AssertionSinks
Asserts that the previous stage emitted the expected items in any order, but nothing else.
assertCollected(ConsumerEx<? super List<T>>) - Static method in class com.hazelcast.jet.pipeline.test.Assertions
Collects all the received items in a list and once the upstream stage is completed, it executes the assertion supplied by assertFn.
assertCollected(ConsumerEx<? super List<T>>) - Static method in class com.hazelcast.jet.pipeline.test.AssertionSinks
Collects all the received items in a list and once the upstream stage is completed it executes the assertion supplied by assertFn.
assertCollectedEventually(int, ConsumerEx<? super List<T>>) - Static method in class com.hazelcast.jet.pipeline.test.Assertions
Collects all the received items into a list and runs the assertFn every time a new item is received.
assertCollectedEventually(int, ConsumerEx<? super List<T>>) - Static method in class com.hazelcast.jet.pipeline.test.AssertionSinks
Collects all the received items into a list and runs the assertFn every time a new item is received.
assertContains(String, Collection<? extends T>) - Static method in class com.hazelcast.jet.pipeline.test.Assertions
Asserts that the previous stage emitted all of the given items in any order.
assertContains(String, Collection<? extends T>) - Static method in class com.hazelcast.jet.pipeline.test.AssertionSinks
Asserts that the previous stage emitted all the given items in any order.
assertContains(Collection<? extends T>) - Static method in class com.hazelcast.jet.pipeline.test.Assertions
Asserts that the previous stage emitted all of the given items in any order.
assertEquals(String, Object, Object) - Static method in class com.hazelcast.jet.core.test.JetAssert
Asserts that the two given objects are equal, when compared using Object.equals(Object).
assertFalse(String, boolean) - Static method in class com.hazelcast.jet.core.test.JetAssert
Asserts that the given condition is false.
AssertionCompletedException - Exception in com.hazelcast.jet.pipeline.test
An exception which indicates that an assertion passed successfully.
AssertionCompletedException() - Constructor for exception com.hazelcast.jet.pipeline.test.AssertionCompletedException
Creates the exception
AssertionCompletedException(String) - Constructor for exception com.hazelcast.jet.pipeline.test.AssertionCompletedException
Creates the exception with the given message
AssertionCompletedException(String, Throwable) - Constructor for exception com.hazelcast.jet.pipeline.test.AssertionCompletedException
Creates the exception with the given message and cause
Assertions - Class in com.hazelcast.jet.pipeline.test
Various assertions which can be used to assert items passing through the pipeline for correctness.
assertionSink(String, SupplierEx<? extends S>) - Static method in class com.hazelcast.jet.pipeline.test.AssertionSinkBuilder
Returns a builder object that offers a step-by-step fluent API to build an assertion Sink for the Pipeline API.
AssertionSinkBuilder<S,T> - Class in com.hazelcast.jet.pipeline.test
AssertionSinks - Class in com.hazelcast.jet.pipeline.test
Various assertions which can be used to assert items on the output of a pipeline.
assertOrdered(String, Collection<? extends T>) - Static method in class com.hazelcast.jet.pipeline.test.Assertions
Asserts that the previous stage emitted the exact sequence of expected items and nothing else.
assertOrdered(String, Collection<? extends T>) - Static method in class com.hazelcast.jet.pipeline.test.AssertionSinks
Asserts that the previous stage emitted the exact sequence of expected items and nothing else.
assertOrdered(Collection<? extends T>) - Static method in class com.hazelcast.jet.pipeline.test.Assertions
Asserts that the previous stage emitted the exact sequence of expected items and nothing else.
assertOrdered(Collection<? extends T>) - Static method in class com.hazelcast.jet.pipeline.test.AssertionSinks
Asserts that the previous stage emitted the exact sequence of expected items and nothing else.
assertOutput(int, BiConsumer<TestSupport.TestMode, List<List<Object>>>) - Method in class com.hazelcast.jet.core.test.TestSupport
Runs the test with the specified custom assertion.
assertSame(String, Object, Object) - Static method in class com.hazelcast.jet.core.test.JetAssert
Asserts that the two given objects are the same, when compared using the == operator and if not, an AssertionError is thrown with the given message.
assertTrue(String, boolean) - Static method in class com.hazelcast.jet.core.test.JetAssert
Asserts that the given condition is true.
asVersion() - Method in class com.hazelcast.version.MemberVersion
 
ASYNC - Enum constant in enum class com.hazelcast.client.config.ClientConnectionStrategyConfig.ReconnectMode
Reconnect to cluster without blocking invocations.
ASYNC_JOIN_STRATEGY_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
AT_LEAST_ONCE - Enum constant in enum class com.hazelcast.jet.config.ProcessingGuarantee
Enables at-least-once processing semantics.
ATOMIC_LONG - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
Atomic long
ATOMIC_LONG - Static variable in interface com.hazelcast.cp.CPSubsystem
Constant identifying service for IAtomicLong, to be used with CPSubsystem.getObjectInfos(CPGroupId, String)
ATOMIC_REFERENCE - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
Atomic long
ATOMIC_REFERENCE - Static variable in interface com.hazelcast.cp.CPSubsystem
Constant identifying service for IAtomicReference, to be used with CPSubsystem.getObjectInfos(CPGroupId, String)
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
 
attachAll(Map<String, File>) - Method in class com.hazelcast.jet.config.JobConfig
Attaches all the files/directories in the supplied map, as if by calling attachDirectory(dir, id) for every entry that resolves to a directory and attachFile(file, id) for every entry that resolves to a regular file.
attachDirectory(File) - Method in class com.hazelcast.jet.config.JobConfig
Adds the supplied directory to the list of files that will be available to the job while it's executing in the Jet cluster.
attachDirectory(File, String) - Method in class com.hazelcast.jet.config.JobConfig
Adds the supplied directory to the list of files that will be available to the job while it's executing in the Jet cluster.
attachDirectory(String) - Method in class com.hazelcast.jet.config.JobConfig
Adds the directory identified by the supplied pathname to the list of files that will be available to the job while it's executing in the Jet cluster.
attachDirectory(String, String) - Method in class com.hazelcast.jet.config.JobConfig
Adds the directory identified by the supplied pathname to the list of files that will be available to the job while it's executing in the Jet cluster.
attachDirectory(URL) - Method in class com.hazelcast.jet.config.JobConfig
Adds the directory identified by the supplied URL to the list of directories that will be available to the job while it's executing in the Jet cluster.
attachDirectory(URL, String) - Method in class com.hazelcast.jet.config.JobConfig
Adds the directory identified by the supplied URL to the list of directories that will be available to the job while it's executing in the Jet cluster.
attachedDirectory(String) - Method in interface com.hazelcast.jet.core.ProcessorSupplier.Context
Uses the supplied ID to look up a directory you attached to the current Jet job.
attachedDirectory(String) - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
 
attachedFile(String) - Method in interface com.hazelcast.jet.core.ProcessorSupplier.Context
Uses the supplied ID to look up a file you attached to the current Jet job.
attachedFile(String) - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
 
attachedFiles() - Method in class com.hazelcast.jet.pipeline.ServiceFactory
Returns the files and directories attached to this service factory.
attachFile(File) - Method in class com.hazelcast.jet.config.JobConfig
Adds the supplied file to the list of resources that will be available to the job while it's executing in the Jet cluster.
attachFile(File, String) - Method in class com.hazelcast.jet.config.JobConfig
Adds the supplied file to the list of files that will be available to the job while it's executing in the Jet cluster.
attachFile(String) - Method in class com.hazelcast.jet.config.JobConfig
Adds the file identified by the supplied pathname to the list of files that will be available to the job while it's executing in the Jet cluster.
attachFile(String, String) - Method in class com.hazelcast.jet.config.JobConfig
Adds the file identified by the supplied pathname to the list of files that will be available to the job while it's executing in the Jet cluster.
attachFile(URL) - Method in class com.hazelcast.jet.config.JobConfig
Adds the file identified by the supplied URL as a resource that will be available to the job while it's executing in the Jet cluster.
attachFile(URL, String) - Method in class com.hazelcast.jet.config.JobConfig
Adds the file identified by the supplied URL to the list of resources that will be available to the job while it's executing in the Jet cluster.
ATTRIBUTE - Enum constant in enum class com.hazelcast.config.security.LdapRoleMappingMode
Role name in user object attribute.
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(AttributeConfig) - Constructor for class com.hazelcast.config.AttributeConfig
 
AttributeConfig(String, String) - Constructor for class com.hazelcast.config.AttributeConfig
Creates a AttributeConfig with the given attribute and ordered setting.
AttributePartitioningStrategy - Class in com.hazelcast.partition.strategy
 
AttributePartitioningStrategy(String...) - Constructor for class com.hazelcast.partition.strategy.AttributePartitioningStrategy
 
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.
AUTH_DB_PROPERTY - Static variable in class com.hazelcast.jet.mongodb.dataconnection.MongoDataConnection
Name of the property holding the name of the database in which user is created.
authenticate(AuthenticationContext) - Method in interface com.hazelcast.access.AccessControlService
Authenticates user described by given AuthenticationContext and returns role names assigned.
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.
AuthenticationContext - Interface in com.hazelcast.access
Interface for authentication context objects used by AccessControlService implementations.
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.
AuthorizationContext - Interface in com.hazelcast.access
Interface for authorization context objects, It's used by AccessControlService implementations.
AUTO_COMMIT - Static variable in class com.hazelcast.jet.pipeline.JdbcPropertyKeys
Property key to be passed to specify auto commit mode of the JDBC connection For usage example see Sources.jdbc(String, String, Properties, FunctionEx) method
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.
averagingDouble(ToDoubleFunctionEx<? super T>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that finds the arithmetic mean (aka.
averagingLong(ToLongFunctionEx<? super T>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that finds the arithmetic mean (aka.
avro() - Static method in interface com.hazelcast.jet.pipeline.file.FileFormat
Returns a file format for Avro files.
avro(Class<T>) - Static method in interface com.hazelcast.jet.pipeline.file.FileFormat
Returns a file format for Avro files that specifies to use reflection to deserialize the data into instances of the provided Java class.
AvroFileFormat<T> - Class in com.hazelcast.jet.pipeline.file
FileFormat for avro files.
AvroProcessors - Class in com.hazelcast.jet.avro
Static utility class with factories of Apache Avro source and sink processors.
AvroSinks - Class in com.hazelcast.jet.avro
Contains factory methods for Apache Avro sinks.
AvroSourceBuilder<D> - Class in com.hazelcast.jet.avro
Builder for an Avro file source that reads records from Avro files in a directory (but not its subdirectories) and emits objects returned by mapOutputFn.
AvroSources - Class in com.hazelcast.jet.avro
Contains factory methods for Apache Avro sources.
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.
awaitConnected() - Method in class com.hazelcast.client.util.ClientStateListener
Waits until the client is connected to cluster.
awaitConnected(long, TimeUnit) - Method in class com.hazelcast.client.util.ClientStateListener
Waits until the client is connected to cluster or the timeout expires.
awaitDisconnected() - Method in class com.hazelcast.client.util.ClientStateListener
Waits until the client is disconnected from the cluster.
awaitDisconnected(long, TimeUnit) - Method in class com.hazelcast.client.util.ClientStateListener
Waits until the client is disconnected from the cluster or the timeout expires.
awaitSuccessfulInit() - Method in class com.hazelcast.mapstore.GenericMapLoader
Awaits successful initialization; if the initialization fails, throws an exception.
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
 
AwsConfig(String, boolean, boolean, Map<String, String>) - Constructor for class com.hazelcast.config.AwsConfig
 
AwsDiscoveryStrategy - Class in com.hazelcast.aws
AWS implementation of DiscoveryStrategy.
AwsDiscoveryStrategyFactory - Class in com.hazelcast.aws
Factory class which returns AwsDiscoveryStrategy to Discovery SPI
AwsDiscoveryStrategyFactory() - Constructor for class com.hazelcast.aws.AwsDiscoveryStrategyFactory
 
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
 
AzureConfig(String, boolean, boolean, Map<String, String>) - Constructor for class com.hazelcast.config.AzureConfig
 
AzureDiscoveryStrategy - Class in com.hazelcast.azure
Azure implementation of DiscoveryStrategy
AzureDiscoveryStrategyFactory - Class in com.hazelcast.azure
Factory class which returns AzureDiscoveryStrategy to Discovery SPI
AzureDiscoveryStrategyFactory() - Constructor for class com.hazelcast.azure.AzureDiscoveryStrategyFactory
 

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.persistence.PersistenceService
Attempts to perform a cluster-wide data backup.
backup(long) - Method in interface com.hazelcast.persistence.PersistenceService
Attempts to perform a cluster-wide data backup.
BACKUP_DIR_PREFIX - Static variable in interface com.hazelcast.persistence.PersistenceService
The prefix for each persistence 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 Class in com.hazelcast.persistence
The state of the persistence backup task
BackupTaskStatus - Class in com.hazelcast.persistence
The status of the persistence backup task, including progress and state.
BackupTaskStatus(BackupTaskState, int, int) - Constructor for class com.hazelcast.persistence.BackupTaskStatus
 
BASE64 - Enum constant in enum class com.hazelcast.config.security.TokenEncoding
Base64 token encoding.
baseDir() - Method in class com.hazelcast.jet.python.PythonServiceConfig
Returns the Python base directory.
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.
batch(SupplierEx<? extends MongoClient>) - Static method in class com.hazelcast.jet.mongodb.MongoSourceBuilder
Returns a builder object that offers a step-by-step fluent API to build a custom MongoDB BatchSource for the Pipeline API.
batch(SupplierEx<? extends MongoClient>) - Static method in class com.hazelcast.jet.mongodb.MongoSources
Creates as builder for new batch mongo source.
batch(DataConnectionRef) - Static method in class com.hazelcast.jet.mongodb.MongoSourceBuilder
Returns a builder object that offers a step-by-step fluent API to build a custom MongoDB BatchSource for the Pipeline API.
batch(DataConnectionRef) - Static method in class com.hazelcast.jet.mongodb.MongoSources
Creates as builder for new batch mongo source.
batch(DataConnectionRef, String, String, Bson, Bson) - Static method in class com.hazelcast.jet.mongodb.MongoSources
Returns a MongoDB batch source which queries the collection using given filter and applies the given projection on the documents.
batch(String, FunctionEx<? super Processor.Context, ? extends C>) - Static method in class com.hazelcast.jet.pipeline.SourceBuilder
Returns a fluent-API builder with which you can create a batch source for a Jet pipeline.
batch(String, SupplierEx<? extends MongoClient>) - Static method in class com.hazelcast.jet.mongodb.MongoSourceBuilder
Returns a builder object that offers a step-by-step fluent API to build a custom MongoDB BatchSource for the Pipeline API.
batch(String, DataConnectionRef) - Static method in class com.hazelcast.jet.mongodb.MongoSourceBuilder
Returns a builder object that offers a step-by-step fluent API to build a custom MongoDB BatchSource for the Pipeline API.
batch(String, String, String, Bson, Bson) - Static method in class com.hazelcast.jet.mongodb.MongoSources
Returns a MongoDB batch source which queries the collection using given filter and applies the given projection on the documents.
BATCH_SIZE_METRIC - Static variable in class com.hazelcast.jet.kinesis.KinesisSinks
One of the metrics exposed by the sink used to monitor the current sending batch size.
batchFromProcessor(String, ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.pipeline.Sources
Returns a bounded (batch) source constructed directly from the given Core API processor meta-supplier.
batchLimit(int) - Method in class com.hazelcast.jet.pipeline.JdbcSinkBuilder
Sets the batch size limit for the sink.
BatchSource<T> - Interface in com.hazelcast.jet.pipeline
A finite source of data for a Jet pipeline.
BatchStage<T> - Interface in com.hazelcast.jet.pipeline
A stage in a distributed computation pipeline that will observe a finite amount of data (a batch).
BatchStageWithKey<T,K> - Interface in com.hazelcast.jet.pipeline
An intermediate step while constructing a group-and-aggregate batch pipeline stage.
bean(Class<T>) - Static method in class com.hazelcast.spring.jet.JetSpringServiceFactories
Returns a Spring Bean ServiceFactory.
bean(String) - Static method in class com.hazelcast.spring.jet.JetSpringServiceFactories
Returns a Spring Bean ServiceFactory.
bean(String, Class<T>) - Static method in class com.hazelcast.spring.jet.JetSpringServiceFactories
Returns a Spring Bean ServiceFactory.
beanFrom(String, Class<T>) - Static method in class com.hazelcast.jet.json.JsonUtil
Converts a JSON string to an object of the given type.
beanName() - Element in annotation interface com.hazelcast.spring.context.SpringAware
 
beanSequenceFrom(Reader, Class<T>) - Static method in class com.hazelcast.jet.json.JsonUtil
Returns an Iterator over the sequence of JSON objects parsed from given reader.
beanSequenceFrom(Path, Class<T>) - Static method in class com.hazelcast.jet.json.JsonUtil
Parses the file and returns a stream of objects with the given type.
before(Credentials, String, String, String, Parameters) - Method in interface com.hazelcast.security.SecurityInterceptor
 
beforeClass() - Static method in class com.hazelcast.test.archunit.ArchUnitTestSupport
 
BEGIN_TRANSACTION - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
beginTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
Begins a transaction.
Beta - Annotation Interface in com.hazelcast.spi.annotation
An element annotated with this annotation is considered beta status.
between(Vertex, Vertex) - Static method in class com.hazelcast.jet.core.Edge
Returns an edge between two vertices.
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.
bidirectionalStreamingService(SupplierEx<? extends ManagedChannelBuilder<?>>, FunctionEx<? super ManagedChannel, ? extends FunctionEx<StreamObserver<R>, StreamObserver<T>>>) - Static method in class com.hazelcast.jet.grpc.GrpcServices
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
 
BIGINT - Enum constant in enum class com.hazelcast.sql.SqlColumnType
BIGINT type, represented by Long
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
 
BINARY - Enum constant in enum class com.hazelcast.config.InMemoryFormat
As Binary
BinaryOperatorEx<T> - Interface in com.hazelcast.function
Serializable variant of java.util.function.BinaryOperator which declares checked exception.
bindFn(BiConsumerEx<PreparedStatement, T>) - Method in class com.hazelcast.jet.pipeline.JdbcSinkBuilder
Set the function to bind values to a PreparedStatement created with the query set with JdbcSinkBuilder.updateQuery(String).
BiPredicateEx<T,U> - Interface in com.hazelcast.function
Serializable variant of java.util.function.BiPredicate which declares checked exception.
BITMAP - Enum constant in enum class com.hazelcast.config.IndexType
Bitmap index.
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 Class in com.hazelcast.config
Defines an assortment of transformations which can be applied to unique key values.
block() - Method in class com.hazelcast.jet.core.test.TestOutbox
 
BLOCK - Enum constant in enum class com.hazelcast.topic.TopicOverloadPolicy
The caller will wait till there space in the ringbuffer.
BOOLEAN - Enum constant in enum class com.hazelcast.config.properties.PropertyTypeConverter
TypeConverter to convert an input string to an output boolean
BOOLEAN - Enum constant in enum class com.hazelcast.jet.core.metrics.Unit
0 or 1
BOOLEAN - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
 
BOOLEAN - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
 
BOOLEAN - Enum constant in enum class com.hazelcast.sql.SqlColumnType
BOOLEAN type, represented by Boolean
BOOLEAN_ARRAY - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
 
bootstrappedInstance() - Static method in class com.hazelcast.core.Hazelcast
Returns either a local Hazelcast instance or a "bootstrapped" Hazelcast client for a remote Hazelcast cluster, depending on the context.
bootstrappedInstance() - Static method in class com.hazelcast.jet.Jet
Deprecated.
since 5.0 Please use Hazelcast.bootstrappedInstance() and then get JetService from the created HazelcastInstance by using HazelcastInstance.getJet()}.
bottomN(int, ComparatorEx<? super T>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that finds the bottom n items according to the given comparator.
broadcast() - Method in class com.hazelcast.jet.core.Edge
Activates the BROADCAST routing policy.
BROADCAST - Enum constant in enum class com.hazelcast.jet.core.Edge.RoutingPolicy
This policy sends each item to all candidate processors.
broadcastKey(K) - Static method in class com.hazelcast.jet.core.BroadcastKey
Returns a given key as a broadcast key.
BroadcastKey<K> - Class in com.hazelcast.jet.core
Marks a key in the snapshot state to indicate that the corresponding entry should be broadcast to all processors when restoring the snapshot.
BTreeIndexConfig - Class in com.hazelcast.config
Configuration options specific for B-Tree indexes.
BTreeIndexConfig() - Constructor for class com.hazelcast.config.BTreeIndexConfig
 
BTreeIndexConfig(BTreeIndexConfig) - Constructor for class com.hazelcast.config.BTreeIndexConfig
 
bucketCount() - Method in interface com.hazelcast.jet.core.Outbox
Returns the number of buckets in this outbox.
bucketCount() - Method in class com.hazelcast.jet.core.test.TestOutbox
 
build() - Method in interface com.hazelcast.auditlog.EventBuilder
Builds the AuditableEvent instance.
build() - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
 
build() - Method in class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
 
build() - 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.jet.aggregate.AllOfAggregationBuilder
Builds and returns the composite AggregateOperation1.
build() - Method in class com.hazelcast.jet.aggregate.CoAggregateOperationBuilder
Builds and returns the AggregateOperation.
build() - Method in class com.hazelcast.jet.avro.AvroSourceBuilder
build() - Method in class com.hazelcast.jet.cdc.DebeziumCdcSources.Builder
Returns the CDC source based on the properties set.
build() - Method in class com.hazelcast.jet.cdc.mysql.MySqlCdcSources.Builder
Returns the source based on the properties set so far.
build() - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
Returns the source based on the properties set so far.
build() - Method in class com.hazelcast.jet.elastic.ElasticSinkBuilder
Create a sink that writes data into Elasticsearch based on this builder configuration
build() - Method in class com.hazelcast.jet.elastic.ElasticSourceBuilder
Build Elasticsearch BatchSource with supplied parameters
build() - Method in class com.hazelcast.jet.kafka.KafkaSinks.Builder
Builds the Sink object that you pass to the GeneralStage.writeTo(Sink) method.
build() - Method in class com.hazelcast.jet.kinesis.KinesisSinks.Builder
Construct the sink based on the options provided so far.
build() - Method in class com.hazelcast.jet.kinesis.KinesisSources.Builder
Constructs the source based on the options provided so far.
build() - Method in class com.hazelcast.jet.mongodb.MongoSinkBuilder
Creates and returns the MongoDB Sink with the components you supplied to this builder.
build() - Method in class com.hazelcast.jet.mongodb.MongoSourceBuilder.Batch
Creates and returns the MongoDB BatchSource.
build() - Method in class com.hazelcast.jet.mongodb.MongoSourceBuilder.Stream
Creates and returns the MongoDB StreamSource which watches the given collection.
build() - Method in class com.hazelcast.jet.pipeline.AggregateBuilder
Creates and returns a pipeline stage that performs the co-aggregation of the stages registered with this builder object.
build() - Method in class com.hazelcast.jet.pipeline.file.FileSourceBuilder
Builds a BatchSource based on the current state of the builder.
build() - Method in class com.hazelcast.jet.pipeline.FileSinkBuilder
Creates and returns the file Sink with the supplied components.
build() - Method in class com.hazelcast.jet.pipeline.FileSourceBuilder
Deprecated.
Use FileSources.files(java.lang.String). Will be removed in Jet 5.0.
build() - Method in class com.hazelcast.jet.pipeline.GroupAggregateBuilder
Creates and returns a pipeline stage that performs the co-aggregation of the stages registered with this builder object and emits a Map.Entry(key, resultsByTag) for each distinct key.
build() - Method in class com.hazelcast.jet.pipeline.JdbcSinkBuilder
Creates and returns the JDBC Sink with the supplied components.
build() - Method in class com.hazelcast.jet.pipeline.JmsSinkBuilder
Creates and returns the JMS Sink with the supplied components.
build() - Method in class com.hazelcast.jet.pipeline.JmsSourceBuilder
build() - Method in class com.hazelcast.jet.pipeline.MapSinkBuilder
Build the sink.
build() - Method in class com.hazelcast.jet.pipeline.MapSinkEntryProcessorBuilder
 
build() - Method in class com.hazelcast.jet.pipeline.RemoteMapSourceBuilder
Build the source using the parameters set in this builder.
build() - Method in class com.hazelcast.jet.pipeline.SinkBuilder
Creates and returns the Sink with the components you supplied to this builder.
build() - Method in class com.hazelcast.jet.pipeline.SourceBuilder.Batch
Builds and returns the batch source.
build() - Method in class com.hazelcast.jet.pipeline.SourceBuilder.Stream
Builds and returns the unbounded stream source.
build() - Method in class com.hazelcast.jet.pipeline.SourceBuilder.TimestampedStream
Builds and returns the timestamped stream source.
build() - Method in class com.hazelcast.jet.pipeline.test.AssertionSinkBuilder
Creates and returns the Sink with the components you supplied to this builder.
build() - Method in class com.hazelcast.jet.pipeline.WindowAggregateBuilder
Creates and returns a pipeline stage that performs a windowed co-aggregation of the stages registered with this builder object.
build() - Method in class com.hazelcast.jet.pipeline.WindowGroupAggregateBuilder
Creates and returns a pipeline stage that performs a windowed cogroup-and-aggregate operation on the stages registered with this builder object.
build() - Method in class com.hazelcast.jet.retry.RetryStrategies.Builder
Constructs the actual strategy based on the properties set previously.
build() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
 
build() - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
 
build() - Method in class com.hazelcast.vector.SearchOptionsBuilder
build(ClientFailoverConfig) - Method in class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
 
build(BiFunctionEx<String, ? super D, T>) - Method in class com.hazelcast.jet.avro.AvroSourceBuilder
Builds a custom Avro file BatchSource with supplied components and the output function mapOutputFn.
build(BiFunctionEx<String, String, ? extends T>) - Method in class com.hazelcast.jet.pipeline.FileSourceBuilder
Deprecated.
Use FileSources.files(java.lang.String). Will be removed in Jet 5.0.
build(BiFunctionEx<T0, ItemsByTag, R>) - Method in class com.hazelcast.jet.pipeline.HashJoinBuilder
Builds a new pipeline stage that performs the hash-join operation.
build(BiFunctionEx<T0, ItemsByTag, R>) - Method in class com.hazelcast.jet.pipeline.StreamHashJoinBuilder
Builds a new pipeline stage that performs the hash-join operation.
build(FunctionEx<? super ItemsByTag, ? extends R>) - Method in class com.hazelcast.jet.aggregate.CoAggregateOperationBuilder
Builds and returns the multi-input AggregateOperation.
build(FunctionEx<? super ItemsByTag, ? extends R>) - Method in class com.hazelcast.jet.pipeline.AggregateBuilder
Creates and returns a pipeline stage that performs the co-aggregation of the stages registered with this builder object.
build(FunctionEx<? super Message, ? extends T>) - Method in class com.hazelcast.jet.pipeline.JmsSourceBuilder
Creates and returns the JMS StreamSource with the supplied components and the projection function projectionFn.
build(FunctionEx<? super Path, ? extends Stream<T>>) - Method in class com.hazelcast.jet.pipeline.FileSourceBuilder
Deprecated.
Use FileSources.files(java.lang.String). Will be removed in Jet 5.0.
build(FunctionEx<ItemsByTag, R>) - Method in class com.hazelcast.jet.aggregate.AllOfAggregationBuilder
Builds and returns the composite AggregateOperation1.
build(AggregateOperation<?, ? extends R>) - Method in class com.hazelcast.jet.pipeline.WindowGroupAggregateBuilder1
Creates and returns a pipeline stage that performs a windowed cogroup-and-aggregate of the pipeline stages registered with this builder object.
build(AggregateOperation<?, R>) - Method in class com.hazelcast.jet.pipeline.AggregateBuilder1
Creates and returns a pipeline stage that performs the co-aggregation of pipeline stages registered with this builder object.
build(AggregateOperation<?, R>) - Method in class com.hazelcast.jet.pipeline.GroupAggregateBuilder1
Creates and returns a pipeline stage that performs the co-grouping and aggregation of pipeline stages registered with this builder object.
build(AggregateOperation<?, R>, BiFunctionEx<? super K, ? super R, OUT>) - Method in class com.hazelcast.jet.pipeline.GroupAggregateBuilder1
Deprecated.
This is a leftover from an earlier development cycle of the Pipeline API. Use GroupAggregateBuilder1.build(AggregateOperation) instead and add a separate mapping stage with mapToOutputFn.
build(AggregateOperation<A, R>) - Method in class com.hazelcast.jet.pipeline.WindowAggregateBuilder1
Creates and returns a pipeline stage that performs a windowed co-aggregation of the pipeline stages registered with this builder object.
build(ClassLoader) - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
 
build(ClassLoader) - Method in class com.hazelcast.client.config.YamlClientConfigBuilder
 
builder() - Static method in class com.hazelcast.jet.elastic.ElasticSinks
Returns new instance of ElasticSinkBuilder
builder() - Static method in class com.hazelcast.jet.elastic.ElasticSources
Returns new instance of ElasticSourceBuilder
builder() - Static method in interface com.hazelcast.vector.SearchOptions
 
builder(Class<T>, SupplierEx<MongoClient>) - Static method in class com.hazelcast.jet.mongodb.MongoSinks
Returns a builder object that offers a step-by-step fluent API to build a custom MongoDB Sink for the Pipeline API.
builder(Class<T>, DataConnectionRef) - Static method in class com.hazelcast.jet.mongodb.MongoSinks
Returns a builder object that offers a step-by-step fluent API to build a custom MongoDB Sink for the Pipeline API.
buildMetaSupplier() - Method in class com.hazelcast.jet.pipeline.file.FileSourceBuilder
Builds a ProcessorMetaSupplier based on the current state of the builder.
buildWatcher() - Method in class com.hazelcast.jet.pipeline.FileSourceBuilder
buildWatcher(BiFunctionEx<String, String, ? extends T>) - Method in class com.hazelcast.jet.pipeline.FileSourceBuilder
Builds a source that emits a stream of lines of text coming from files in the watched directory (but not its subdirectories).
bulkRequestFn(SupplierEx<BulkRequest>) - Method in class com.hazelcast.jet.elastic.ElasticSinkBuilder
Set the supplier function for BulkRequest, defaults to new BulkRequest()
BYTE - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
 
BYTE_ARRAY - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
 
ByteArraySerializer<T> - Interface in com.hazelcast.nio.serialization
For sample usage custom serialization and other way of custom serialization see StreamSerializer.
bytes() - Static method in interface com.hazelcast.jet.pipeline.file.FileFormat
Returns a file format for binary files.
bytes() - Method in class com.hazelcast.memory.Capacity
Returns value of the capacity in bytes.
BYTES - Enum constant in enum class com.hazelcast.jet.core.metrics.Unit
Size, counter, represented in bytes
BYTES - Enum constant in enum class com.hazelcast.memory.MemoryUnit
MemoryUnit in bytes

C

cache(String) - Static method in class com.hazelcast.jet.pipeline.Sinks
Returns a sink that puts Map.Entrys it receives into a Hazelcast ICache with the specified name.
cache(String) - Static method in class com.hazelcast.jet.pipeline.Sources
Returns a source that fetches entries from a Hazelcast ICache with the given name and emits them as Map.Entry.
CACHE - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
JCache/ICache
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_ON_UPDATE - Enum constant in enum class com.hazelcast.config.NearCacheConfig.LocalUpdatePolicy
While local remove immediately invalidates Near Cache, local put adds new value to it.
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(CacheSimpleConfig) - 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
 
CacheConfigAccessor - Class in com.hazelcast.config
Accessor for package-private methods of CacheConfig.
CacheConfiguration<K,V> - Interface in com.hazelcast.config
Mutable extension to CompleteConfiguration
CacheDeserializedValues - Enum Class in com.hazelcast.config
Control caching of de-serialized values.
CacheEntryView<K,V> - Interface in com.hazelcast.cache
Entry info for cache record.
cacheEventNewValue() - Static method in class com.hazelcast.jet.Util
Returns a projection that extracts the new value from an EventJournalCacheEvent.
cacheEventToEntry() - Static method in class com.hazelcast.jet.Util
Returns a projection that converts the EventJournalCacheEvent to a Map.Entry using the event's new value as a value.
CacheEventType - Enum Class 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.
cacheJournal(String, JournalInitialPosition) - Static method in class com.hazelcast.jet.pipeline.Sources
Convenience for Sources.cacheJournal(String, JournalInitialPosition, FunctionEx, PredicateEx) which will pass only CREATED and UPDATED events and will project the event's key and new value into a Map.Entry.
cacheJournal(String, JournalInitialPosition, FunctionEx<? super EventJournalCacheEvent<K, V>, ? extends T>, PredicateEx<? super EventJournalCacheEvent<K, V>>) - Static method in class com.hazelcast.jet.pipeline.Sources
Returns a source that will stream the EventJournalCacheEvent events of a Hazelcast ICache with the specified name.
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(CachePartitionLostListener) - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfig
 
CachePartitionLostListenerConfig(CachePartitionLostListenerConfig) - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfig
 
CachePartitionLostListenerConfig(String) - 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
 
cachePutEvents() - Static method in class com.hazelcast.jet.Util
cachePutPermission(String, String) - Static method in class com.hazelcast.security.PermissionsUtil
 
CacheSimpleConfig - Class in com.hazelcast.config
Simple configuration to hold parsed XML configuration.
CacheSimpleConfig() - Constructor for class com.hazelcast.config.CacheSimpleConfig
 
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.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 Class in com.hazelcast.config
Represents type of the "TimedExpiryPolicyFactoryConfig".
CacheSimpleEntryListenerConfig - Class in com.hazelcast.config
Simple configuration to hold parsed listener config.
CacheSimpleEntryListenerConfig() - Constructor for class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
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
 
call(T) - Method in interface com.hazelcast.jet.grpc.GrpcService
Calls the requested service and returns a future which will be completed with the result once a response is received.
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() - Method in interface com.hazelcast.jet.Job
Makes a request to cancel this job and returns.
cancel(boolean) - Method in interface com.hazelcast.scheduledexecutor.IScheduledFuture
Attempts to cancel further scheduling of this task.
CANCEL - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
cancelAndExportSnapshot(String) - Method in interface com.hazelcast.jet.Job
Exports and saves a state snapshot with the given name, and then cancels the job without processing any more data after the barrier (graceful cancellation).
canGetNextDataMember() - Method in interface com.hazelcast.client.LoadBalancer
Deprecated.
Since 5.0, the method is unused
canGetNextDataMember() - Method in class com.hazelcast.client.util.RandomLB
 
canGetNextDataMember() - Method in class com.hazelcast.client.util.RoundRobinLB
 
canGetNextDataMember() - Method in class com.hazelcast.client.util.StaticLB
 
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.HazelcastLicenseResourceTransformer
 
canTransformResource(String) - Method in class com.hazelcast.buildutils.HazelcastManifestTransformer
 
capacity() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Returns the capacity of this Ringbuffer.
Capacity - Class in com.hazelcast.memory
Capacity represents a memory capacity with given value and MemoryUnit.
Capacity(long) - Constructor for class com.hazelcast.memory.Capacity
 
Capacity(long, MemoryUnit) - Constructor for class com.hazelcast.memory.Capacity
 
CAPACITY - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
CARDINALITY_ESTIMATOR - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
Cardinality Estimator
CARDINALITY_ESTIMATOR_SERVICE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
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(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
 
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).
CdcSinks - Class in com.hazelcast.jet.cdc
Contains factory methods for change data capture specific pipeline sinks.
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.
ChangeRecord - Interface in com.hazelcast.jet.cdc
Information pertaining to a single data change event (insert, delete or update), affecting a single database record.
CHANNEL_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Number of parallel connection between members.
channelFn() - Method in class com.hazelcast.jet.python.PythonServiceConfig
CHAR - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
Deprecated.
Portable Serialization has been deprecated. We recommend you use Compact Serialization as Portable Serialization will be removed as of version 7.0.
CHAR - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
 
CHAR_ARRAY - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
 
charset() - Method in class com.hazelcast.jet.pipeline.file.LinesTextFileFormat
Returns the configured character encoding.
charset() - Method in class com.hazelcast.jet.pipeline.file.TextFileFormat
Returns the configured character encoding.
charset(Charset) - Method in class com.hazelcast.jet.pipeline.FileSinkBuilder
Sets the character set used to encode the files.
charset(Charset) - Method in class com.hazelcast.jet.pipeline.FileSourceBuilder
Sets the character set used to encode the files.
check(JavaClass, ConditionEvents) - Method in class com.hazelcast.test.archunit.CompletableFutureUsageCondition
 
check(JavaClass, ConditionEvents) - Method in class com.hazelcast.test.archunit.MatchersUsageCondition
 
check(JavaClass, ConditionEvents) - Method in class com.hazelcast.test.archunit.MixTestAnnotationsCondition
 
check(JavaClass, ConditionEvents) - Method in class com.hazelcast.test.archunit.SerialVersionUidFieldCondition
 
check(JavaClass, ConditionEvents) - Method in class com.hazelcast.test.archunit.TestsHaveRunnersCondition
 
checkLocalParallelism(int) - Static method in class com.hazelcast.jet.core.Vertex
Says whether the given integer is valid as the value of localParallelism.
checkPermission(SecuredFunction, ProcessorMetaSupplier.Context) - Static method in class com.hazelcast.security.PermissionsUtil
 
checkPermission(Permission) - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
Check if the current Subject has the given permission granted (or implied).
checkPermission(Permission) - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
 
checkPermission(Subject, Permission) - Method in interface com.hazelcast.security.SecurityContext
Checks whether current Subject has been granted specified permission or not.
checkResourceExistence(ResourceChecks) - Method in class com.hazelcast.jet.mongodb.MongoSinkBuilder
If ResourceChecks.NEVER, the database and collection will be automatically created on the first usage.
checkResourceExistence(ResourceChecks) - Method in class com.hazelcast.jet.mongodb.MongoSourceBuilder.Stream
If ResourceChecks.NEVER, the database and collection will be automatically created on the first usage.
CLASS - Enum constant in enum class com.hazelcast.jet.config.ResourceType
Represents a class that will be on the classpath of the Jet job.
ClassDefinition - Interface in com.hazelcast.nio.serialization
Deprecated, for removal: This API element is subject to removal in a future version.
Portable Serialization has been deprecated. We recommend you use Compact Serialization as Portable Serialization will be removed as of version 7.0.
ClassDefinitionBuilder - Class in com.hazelcast.nio.serialization
Deprecated, for removal: This API element is subject to removal in a future version.
Portable Serialization has been deprecated. We recommend you use Compact Serialization as Portable Serialization will be removed as of version 7.0.
ClassDefinitionBuilder(int, int) - Constructor for class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
IMPORTANT: It uses a default portableVersion (0) for non-versioned classes.
ClassDefinitionBuilder(int, int, int) - Constructor for class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
IMPORTANT: Make sure that the version matches the portableVersion in the SerializationService
ClassDefinitionBuilder(PortableId) - Constructor for class com.hazelcast.nio.serialization.ClassDefinitionBuilder
Deprecated.
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
classLoader() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
Processor classloader configured via JobConfig.addCustomClasspath(String, String)
classLoader() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
 
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 class name.
CLASSPATH_RESOURCE - Enum constant in enum class com.hazelcast.jet.config.ResourceType
Represents a classpath resource that will be on the classpath of the Jet job.
ClasspathXmlConfig - Class in com.hazelcast.config
A Config which is initialized by loading an XML configuration file from the classpath.
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.
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.
ClasspathYamlConfig - Class in com.hazelcast.config
A Config which is initialized by loading a YAML configuration file from the classpath.
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.
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.
clazz() - Method in interface com.hazelcast.dataconnection.DataConnectionRegistration
 
clazz() - Method in class com.hazelcast.jet.pipeline.file.CsvFileFormat
Returns the class Jet will deserialize data into.
clazz() - Method in class com.hazelcast.jet.pipeline.file.JsonFileFormat
Returns the class Jet will deserialize data into.
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.jet.core.Inbox
Removes all items from the inbox.
clear() - Method in class com.hazelcast.jet.core.test.TestInbox
Convenience for inbox.queue().clear()
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
 
CLEAR - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
CLEAR_ALL - Enum constant in enum class com.hazelcast.core.EntryEventType
Fired if all entries are cleared.
CLEAR_REMOTE_TRANSACTION - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
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 parameter values.
clearThreadContext() - Method in interface com.hazelcast.spi.tenantcontrol.TenantControl
Cleans up all of the thread context to avoid potential class loader leaks This method should clear all potential context items, not just the ones set up in TenantControl.setTenant() This acts as a catch-all for any potential class loader and thread-local leaks.
client() - Static method in class com.hazelcast.jet.elastic.ElasticClients
Create Elastic client for an instance running on localhost on default port (9200)
client(String) - Static method in class com.hazelcast.jet.elastic.ElasticClients
Convenience method to create RestClientBuilder with given string, it must contain host, and optionally the scheme and a port.
client(String, int) - Static method in class com.hazelcast.jet.elastic.ElasticClients
Convenience method to create RestClientBuilder with given hostname and port
client(String, String, String, int) - Static method in class com.hazelcast.jet.elastic.ElasticClients
Convenience method to create RestClientBuilder with basic authentication and given hostname and port
client(String, String, String, int, String) - Static method in class com.hazelcast.jet.elastic.ElasticClients
Convenience method to create RestClientBuilder with basic authentication and given hostname, port and scheme.
Client - Enum constant in enum class com.hazelcast.spi.discovery.integration.DiscoveryMode
The current runtime environment is a Hazelcast client
Client - Interface in com.hazelcast.client
The Client interface allows to get information about a connected client's socket address, type and UUID.
CLIENT - Enum constant in enum class com.hazelcast.config.AbstractXmlConfigBuilder.ConfigType
 
CLIENT - Enum constant in enum class com.hazelcast.config.InstanceTrackingConfig.InstanceMode
This instance is a Hazelcast client instance.
CLIENT - Enum constant in enum class com.hazelcast.cp.session.CPSession.CPSessionOwnerType
Represents a Hazelcast client
CLIENT_CACHING_PROVIDER - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
Class name of the client-side Caching Provider
CLIENT_CHANGED_CLUSTER - Enum constant in enum class com.hazelcast.core.LifecycleEvent.LifecycleState
Fired when a client is connected to a new cluster.
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_CONNECTED - Enum constant in enum class com.hazelcast.core.LifecycleEvent.LifecycleState
Fired when a client is connected to the cluster.
CLIENT_CONNECTIVITY_LOGGING_DELAY_SECONDS - Static variable in class com.hazelcast.client.properties.ClientProperty
Sets the client connectivity logging delay in seconds.
CLIENT_DISCONNECTED - Enum constant in enum class com.hazelcast.core.LifecycleEvent.LifecycleState
Fired when a client is disconnected from 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_FAILOVER - Enum constant in enum class com.hazelcast.config.AbstractXmlConfigBuilder.ConfigType
 
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.
CLIENT_XML - Static variable in class com.hazelcast.dataconnection.HazelcastDataConnection
The constant to be used as property key for XML string for connecting to remote cluster
CLIENT_XML_PATH - Static variable in class com.hazelcast.dataconnection.HazelcastDataConnection
The constant to be used as property key for XML file path for connecting to remote cluster
CLIENT_YML - Static variable in class com.hazelcast.dataconnection.HazelcastDataConnection
The constant to be used as property key for YAML string for connecting to remote cluster
CLIENT_YML_PATH - Static variable in class com.hazelcast.dataconnection.HazelcastDataConnection
The constant to be used as property key for YAML file path for connecting to remote cluster
ClientClasspathXmlConfig - Class in com.hazelcast.client.config
A ClientConfig which is initialized by loading an XML configuration file from the classpath.
ClientClasspathXmlConfig(ClassLoader, String, Properties) - Constructor for class com.hazelcast.client.config.ClientClasspathXmlConfig
Creates a config which is loaded from a classpath resource.
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.
ClientClasspathYamlConfig - Class in com.hazelcast.client.config
A ClientConfig which is initialized by loading an YAML configuration file from the classpath.
ClientClasspathYamlConfig(ClassLoader, String, Properties) - Constructor for class com.hazelcast.client.config.ClientClasspathYamlConfig
Creates a config which is loaded from a classpath resource.
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.
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(ClientConfig) - Method in class com.hazelcast.jet.pipeline.MapSinkBuilder
Sets the ClientConfig with configuration for a Hazelcast client to use for remote Map sink.
clientConfig(ClientConfig) - Method in class com.hazelcast.jet.pipeline.MapSinkEntryProcessorBuilder
 
clientConfig(ClientConfig) - Method in class com.hazelcast.jet.pipeline.RemoteMapSourceBuilder
Set the client configuration to use to connect to the remote cluster.
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 Class in com.hazelcast.client.config
Reconnect options.
ClientConnectivityLogger - Class in com.hazelcast.client.util
Logs the connectivity of the client to the cluster.
ClientConnectivityLogger(LoggingService, TaskScheduler, HazelcastProperties) - Constructor for class com.hazelcast.client.util.ClientConnectivityLogger
Constructs a new ClientConnectivityLogger.
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(ClassLoader, String, Properties) - Constructor for class com.hazelcast.client.config.ClientFailoverClasspathXmlConfig
Creates a config which is loaded from a classpath resource.
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.
ClientFailoverClasspathYamlConfig - Class in com.hazelcast.client.config
A ClientFailoverConfig which is initialized by loading a YAML configuration file from the classpath.
ClientFailoverClasspathYamlConfig(ClassLoader, String, Properties) - Constructor for class com.hazelcast.client.config.ClientFailoverClasspathYamlConfig
Creates a config which is loaded from a classpath resource.
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.
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(ClientFlakeIdGeneratorConfig) - Constructor for class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
Copy-constructor
ClientFlakeIdGeneratorConfig(String) - Constructor for class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
 
clientFn(SupplierEx<RestClientBuilder>) - Method in class com.hazelcast.jet.elastic.ElasticSinkBuilder
Set the client supplier function
clientFn(SupplierEx<RestClientBuilder>) - Method in class com.hazelcast.jet.elastic.ElasticSourceBuilder
Set the client supplier function
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(ClientReliableTopicConfig) - Constructor for class com.hazelcast.client.config.ClientReliableTopicConfig
Create a clone of given reliable topic
ClientReliableTopicConfig(String) - Constructor for class com.hazelcast.client.config.ClientReliableTopicConfig
Creates a new ReliableTopicConfig with default settings.
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.
ClientSqlConfig - Class in com.hazelcast.client.config
Contains the SQL configuration for the client.
ClientSqlConfig() - Constructor for class com.hazelcast.client.config.ClientSqlConfig
 
ClientSqlConfig(ClientSqlConfig) - Constructor for class com.hazelcast.client.config.ClientSqlConfig
 
ClientSqlResubmissionMode - Enum Class in com.hazelcast.client.config
The configuration when to retry query that fails with reasons: SqlErrorCode.CONNECTION_PROBLEM SqlErrorCode.PARTITION_DISTRIBUTION SqlErrorCode.TOPOLOGY_CHANGE SqlErrorCode.RESTARTABLE_ERROR
ClientStateListener - Class in com.hazelcast.client.util
Helper class for the user to track the lifecycle state of the client.
ClientStateListener(ClientConfig) - Constructor for class com.hazelcast.client.util.ClientStateListener
Registers this instance with the provided client configuration
ClientStateListener(ClientFailoverConfig) - Constructor for class com.hazelcast.client.util.ClientStateListener
Registers this instance with the provided client configuration
ClientTpcConfig - Class in com.hazelcast.client.config
Contains client configurations for TPC.
ClientTpcConfig() - Constructor for class com.hazelcast.client.config.ClientTpcConfig
 
ClientTpcConfig(ClientTpcConfig) - Constructor for class com.hazelcast.client.config.ClientTpcConfig
 
ClientUserCodeDeploymentConfig - Class in com.hazelcast.client.config
Deprecated, for removal: This API element is subject to removal in a future version.
since 5.4, "User Code Deployment" is replaced by the "User Code Namespaces" feature
ClientUserCodeDeploymentConfig() - Constructor for class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
Deprecated.
 
ClientUserCodeDeploymentConfig(ClientUserCodeDeploymentConfig) - Constructor for class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
Deprecated.
 
clone() - Method in class com.hazelcast.jet.pipeline.ServiceFactory
 
close() - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
close() - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
 
close() - 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.jet.core.Processor
Called as the last method in the processor lifecycle.
close() - Method in interface com.hazelcast.jet.pipeline.SourceBuilder.SourceBuffer
Closes the buffer, signaling that all items have been emitted.
close() - Method in interface com.hazelcast.spi.tenantcontrol.TenantControl.Closeable
Same as Java's close() except no exception is thrown
close() - Method in interface com.hazelcast.sql.SqlResult
Release the resources associated with the query result.
close(ClassLoader) - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
close(ClassLoader) - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
 
close(ClassLoader) - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
 
close(Throwable) - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
Called on coordinator member after execution has finished on all members, successfully or not.
close(Throwable) - Method in interface com.hazelcast.jet.core.ProcessorSupplier
Called after the execution has finished on this member - successfully or not.
close(URI, ClassLoader) - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
close(URI, ClassLoader) - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
 
close(URI, ClassLoader) - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
 
closeIsCooperative() - Method in interface com.hazelcast.jet.core.Processor
Returns true if the Processor.close() method of this processor is cooperative.
closeIsCooperative() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
Returns true if the ProcessorMetaSupplier.close(Throwable) method of this instance is cooperative.
closeIsCooperative() - Method in class com.hazelcast.jet.core.ProcessorMetaSupplier.RandomMemberPms
 
closeIsCooperative() - Method in class com.hazelcast.jet.core.ProcessorMetaSupplier.SpecificMemberPms
 
closeIsCooperative() - Method in interface com.hazelcast.jet.core.ProcessorSupplier
Returns true if the ProcessorSupplier.close(Throwable) method of this instance is cooperative.
CLOUD_VM - Enum constant in enum class com.hazelcast.spi.discovery.DiscoveryStrategyFactory.DiscoveryStrategyLevel
VM Machine level, for example, hazelcast-aws or hazelcast-azure.
Cluster - Interface in com.hazelcast.cluster
Hazelcast cluster interface.
CLUSTER_DEMOTE_MEMBER - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
Event type ID: Data member demoted.
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_READ - Enum constant in enum class com.hazelcast.config.RestEndpointGroup
Deprecated.
Group of operations for retrieving cluster state and its version.
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.
CLUSTER_WRITE - Enum constant in enum class com.hazelcast.config.RestEndpointGroup
Deprecated.
Operations which changes cluster or node state or their configurations.
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.
ClusterRoutingConfig - Class in com.hazelcast.client.config
Config for client routing and associated options.
ClusterRoutingConfig() - Constructor for class com.hazelcast.client.config.ClusterRoutingConfig
 
ClusterRoutingConfig(ClusterRoutingConfig) - Constructor for class com.hazelcast.client.config.ClusterRoutingConfig
 
ClusterState - Enum Class 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.
coAggregateOperationBuilder() - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns a builder object that offers a step-by-step fluent API to create an aggregate operation that accepts multiple inputs.
CoAggregateOperationBuilder - Class in com.hazelcast.jet.aggregate
Offers a step-by-step API to create an aggregate operation that accepts multiple inputs.
COALESCED_WM - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
Tracks the highest watermark observed on all the input queues of a particular incoming Edge of a certain Vertex.
code() - Method in enum class com.hazelcast.jet.cdc.Operation
Returns the Debezium operation code as String.
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.
collection(String) - Method in class com.hazelcast.jet.mongodb.MongoSourceBuilder.Batch
Specifies from which collection connector will read documents.
collection(String) - Method in class com.hazelcast.jet.mongodb.MongoSourceBuilder.Stream
Specifies from which collection connector will read documents.
collection(String, Class<T_NEW>) - Method in class com.hazelcast.jet.mongodb.MongoSourceBuilder.Batch
Specifies from which collection connector will read documents.
collection(String, Class<T_NEW>) - Method in class com.hazelcast.jet.mongodb.MongoSourceBuilder.Stream
Specifies from which collection connector will read documents.
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.
columnMetadataList - Variable in class com.hazelcast.mapstore.GenericMapLoader
 
COLUMNS_PROPERTY - Static variable in class com.hazelcast.mapstore.GenericMapLoader
Property key to define column names in database
com.hazelcast.access - package com.hazelcast.access
Contains interfaces for Hazelcast pluggable access control.
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.aws - package com.hazelcast.aws
Provides interfaces/classes for Hazelcast AWS.
com.hazelcast.azure - package com.hazelcast.azure
Provides interfaces/classes for Hazelcast Azure Discovery Provider
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.client.util - package com.hazelcast.client.util
This package contains some utility classes and the base implementations of the loadbalancer implementations
com.hazelcast.cluster - package com.hazelcast.cluster
This package contains the cluster functionality.
com.hazelcast.cluster.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.commandline - package com.hazelcast.commandline
This package contains the classes related to base `hz` command
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.rest - package com.hazelcast.config.rest
This package contains the REST API configuration classes.
com.hazelcast.config.security - package com.hazelcast.config.security
Provides classes for configuring security realms in Hazelcast.
com.hazelcast.config.tpc - package com.hazelcast.config.tpc
This package contains configuration classes for TPC.
com.hazelcast.config.vector - package com.hazelcast.config.vector
This package contains configuration classes for vector collection.
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.dataconnection - package com.hazelcast.dataconnection
This package contains code handling data connections.
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.gcp - package com.hazelcast.gcp
Provides interfaces/classes for Hazelcast GCP.
com.hazelcast.hotrestart - package com.hazelcast.hotrestart
 
com.hazelcast.jet - package com.hazelcast.jet
Hazelcast Jet is a distributed computation engine running on top of Hazelcast IMDG technology.
com.hazelcast.jet.accumulator - package com.hazelcast.jet.accumulator
Classes intended to be used for accumulator objects in an AggregateOperation.
com.hazelcast.jet.aggregate - package com.hazelcast.jet.aggregate
Contains AggregateOperation and its several variants, as well as a builder object for the aggregate operations.
com.hazelcast.jet.annotation - package com.hazelcast.jet.annotation
Annotations used for describing public API stability.
com.hazelcast.jet.avro - package com.hazelcast.jet.avro
Apache Avro file read/write support for Hazelcast Jet.
com.hazelcast.jet.cdc - package com.hazelcast.jet.cdc
Contains source/sink connectors that deal with Change Data Capture (CDC) events from various databases as well as a generic connector for Debezium CDC sources.
com.hazelcast.jet.cdc.mysql - package com.hazelcast.jet.cdc.mysql
Contains connectors for change data capture events from MySQL databases.
com.hazelcast.jet.cdc.postgres - package com.hazelcast.jet.cdc.postgres
Contains connectors for change data capture events from PostgreSQL databases.
com.hazelcast.jet.config - package com.hazelcast.jet.config
Jet's configuration data objects.
com.hazelcast.jet.core - package com.hazelcast.jet.core
Jet's Core API.
com.hazelcast.jet.core.function - package com.hazelcast.jet.core.function
Functional interfaces used by Jet Core API
com.hazelcast.jet.core.metrics - package com.hazelcast.jet.core.metrics
Jet's Job Metric API.
com.hazelcast.jet.core.processor - package com.hazelcast.jet.core.processor
Contains static utility classes with factories of Jet processors.
com.hazelcast.jet.core.test - package com.hazelcast.jet.core.test
Utilities for writing tests of Core API Processors.
com.hazelcast.jet.datamodel - package com.hazelcast.jet.datamodel
Generic data containers used by the Pipeline API.
com.hazelcast.jet.elastic - package com.hazelcast.jet.elastic
Contains sources and sinks for Elasticsearch 7
com.hazelcast.jet.function - package com.hazelcast.jet.function
Serializable and exception-declaring variants of functional interfaces from java.util.function.
com.hazelcast.jet.grpc - package com.hazelcast.jet.grpc
Contributes gRPC service factories that can be to apply transformations to a pipeline which for each input item calls to a gRPC service.
com.hazelcast.jet.hadoop - package com.hazelcast.jet.hadoop
Apache Hadoop read/write support for Hazelcast Jet.
com.hazelcast.jet.json - package com.hazelcast.jet.json
Utility classes for JSON parsing and serialization.
com.hazelcast.jet.kafka - package com.hazelcast.jet.kafka
Apache Kafka reader/writer support for Hazelcast Jet.
com.hazelcast.jet.kafka.connect - package com.hazelcast.jet.kafka.connect
Contains a generic Kafka Connect source provides ability to plug any Kafka Connect source for data ingestion to Jet pipelines.
com.hazelcast.jet.kinesis - package com.hazelcast.jet.kinesis
Amazon Kinesis Data Streams producer/consumer support for Hazelcast Jet.
com.hazelcast.jet.mongodb - package com.hazelcast.jet.mongodb
Contains sources and sinks for MongoDB.
com.hazelcast.jet.mongodb.compact - package com.hazelcast.jet.mongodb.compact
Contains helpful serializers for the usage with the connector.
com.hazelcast.jet.mongodb.dataconnection - package com.hazelcast.jet.mongodb.dataconnection
Contains classes related to Mongo DB Data Connection.
com.hazelcast.jet.pipeline - package com.hazelcast.jet.pipeline
The Pipeline API is Jet's high-level API to build and execute distributed computation jobs.
com.hazelcast.jet.pipeline.file - package com.hazelcast.jet.pipeline.file
This package offers the FileSourceBuilder which allows you to construct various kinds of Pipeline sources that read from local or distributed files.
com.hazelcast.jet.pipeline.test - package com.hazelcast.jet.pipeline.test
This package contains various mock sources to help with pipeline testing and development.
com.hazelcast.jet.protobuf - package com.hazelcast.jet.protobuf
Protocol Buffers v3 support for Hazelcast Jet.
com.hazelcast.jet.python - package com.hazelcast.jet.python
Contributes a PythonTransforms.mapUsingPython(com.hazelcast.jet.python.PythonServiceConfig) transform that allows you to transform Jet pipeline data using a Python function.
com.hazelcast.jet.retry - package com.hazelcast.jet.retry
Interfaces and utility classes for defining and tracking various types of retry behaviour.
com.hazelcast.jet.s3 - package com.hazelcast.jet.s3
AWS S3 read/write support for Hazelcast Jet.
com.hazelcast.kubernetes - package com.hazelcast.kubernetes
Provides interfaces/classes for Hazelcast Kubernetes Discovery Plugin
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.mapstore - package com.hazelcast.mapstore
Implementation of MapStore interface based on Hazelcast SQL engine
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.nio.serialization.compact - package com.hazelcast.nio.serialization.compact
This package contains APIs for the Compact Serialization.
com.hazelcast.nio.serialization.genericrecord - package com.hazelcast.nio.serialization.genericrecord
This package contains APIs for the GenericRecords.
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.persistence - package com.hazelcast.persistence
This package contains Persistence classes needed for open source Hazelcast code
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.spi.utils - package com.hazelcast.spi.utils
Contains utils classes for Hazelcast SPI.
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.config - package com.hazelcast.spring.config
Contains config factory classes.
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.jet - package com.hazelcast.spring.jet
Provides Jet related Spring interfaces/classes for Hazelcast.
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.test.archunit - package com.hazelcast.test.archunit
ArchUnit rules for Hazelcast code
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.vector - package com.hazelcast.vector
Provides interfaces for Hazelcast vector database.
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.
combine(DoubleAccumulator) - Method in class com.hazelcast.jet.accumulator.DoubleAccumulator
Adds the value of the supplied accumulator to this one.
combine(LinTrendAccumulator) - Method in class com.hazelcast.jet.accumulator.LinTrendAccumulator
Combines this accumulator with the supplied one.
combine(PickAnyAccumulator<T>) - Method in class com.hazelcast.jet.accumulator.PickAnyAccumulator
Combines another accumulator with this one.
combineByKeyP(AggregateOperation<A, R>, BiFunctionEx<? super K, ? super R, OUT>) - Static method in class com.hazelcast.jet.core.processor.Processors
Returns a supplier of processors for the second-stage vertex in a two-stage group-and-aggregate setup.
combineFn() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
A primitive that accepts two accumulators and updates the state of the left-hand one by combining it with the state of the right-hand one.
combineP(AggregateOperation<A, R>) - Static method in class com.hazelcast.jet.core.processor.Processors
Returns a supplier of processors for a vertex that performs the combining and finishing steps of the provided aggregate operation.
combineToSlidingWindowP(SlidingWindowPolicy, AggregateOperation<A, ? extends R>, KeyedWindowResultFunction<? super K, ? super R, ? extends OUT>) - Static method in class com.hazelcast.jet.core.processor.Processors
Returns a supplier of processors for the second-stage vertex in a two-stage sliding window aggregation setup (see the class Javadoc for an explanation of aggregation stages).
combineToSlidingWindowP(SlidingWindowPolicy, AggregateOperation<A, ? extends R>, KeyedWindowResultFunction<? super K, ? super R, ? extends OUT>, byte) - Static method in class com.hazelcast.jet.core.processor.Processors
Returns a supplier of processors for the second-stage vertex in a two-stage sliding window aggregation setup (see the class Javadoc for an explanation of aggregation stages) with specified windowWatermarkKey.
COMMIT - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
COMMIT_TRANSACTION - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
commitRetryStrategy(RetryStrategy) - Method in class com.hazelcast.jet.mongodb.MongoSinkBuilder
Sets the retry strategy in case of commit failure.
commitTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
Commits a transaction.
compact() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
 
compact(String) - Static method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
/** Creates a Builder that will build a GenericRecord in Compact format with the given type name and schema:
COMPACT - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
Supported only for Compact.
CompactReader - Interface in com.hazelcast.nio.serialization.compact
Provides means of reading Compact serialized fields from the binary data.
CompactSerializationConfig - Class in com.hazelcast.config
In 5.0, this feature is disabled by default and has to be enabled via configuration
CompactSerializationConfig() - Constructor for class com.hazelcast.config.CompactSerializationConfig
 
CompactSerializationConfig(CompactSerializationConfig) - Constructor for class com.hazelcast.config.CompactSerializationConfig
 
CompactSerializationConfigAccessor - Class in com.hazelcast.config
An accessor for the package-private fields of the CompactSerializationConfig.
CompactSerializer<T> - Interface in com.hazelcast.nio.serialization.compact
Defines the contract of the serializers used for Compact serialization.
CompactWriter - Interface in com.hazelcast.nio.serialization.compact
Provides means of writing compact serialized fields to the binary data.
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(EntryView<K, V>, EntryView<K, V>) - Method in interface com.hazelcast.map.MapEvictionPolicyComparator
Compares the given EntryView instances and returns the result.
compare(T, T) - Method in interface com.hazelcast.function.ComparatorEx
 
COMPARE_AND_SET - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
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.
compareAndSet(K, V, V) - Method in interface com.hazelcast.cp.CPMap
Atomically sets key to newValue if the current value for key is equal-to expectedValue.
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(HazelcastJsonValue) - Method in class com.hazelcast.core.HazelcastJsonValue
 
compareTo(Tag<?>) - Method in class com.hazelcast.jet.datamodel.Tag
 
compareTo(MemberVersion) - Method in class com.hazelcast.version.MemberVersion
 
compareTo(Version) - Method in class com.hazelcast.version.Version
 
comparing(FunctionEx<? super T, ? extends 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(Function<? super T, ? extends U>, Comparator<? super U>) - Static method in interface com.hazelcast.function.ComparatorEx
comparingDouble(ToDoubleFunctionEx<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
comparingDouble(ToDoubleFunction<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
comparingInt(ToIntFunctionEx<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
comparingInt(ToIntFunction<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
comparingLong(ToLongFunctionEx<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
comparingLong(ToLongFunction<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
COMPLETABLE_FUTURE_USED_ONLY_WITH_EXPLICIT_EXECUTOR - Static variable in class com.hazelcast.test.archunit.ArchUnitRules
ArchUnit rule checking that only CompletableFuture async methods version with explicitly defined executor service is used.
CompletableFutureUsageCondition - Class in com.hazelcast.test.archunit
Hazelcast internal callbacks shouldn't use the ForkJoinPool#commonPool, due to the risk of blocking Hazelcast progress by other misbehaving applications/libraries.
complete() - Method in interface com.hazelcast.jet.core.Processor
Called after all the inbound edges' streams are exhausted.
complete() - Method in class com.hazelcast.jet.pipeline.test.LongStreamSourceP
 
complete() - Method in class com.hazelcast.jet.pipeline.test.ParallelBatchP
 
complete() - Method in class com.hazelcast.jet.pipeline.test.ParallelStreamP
 
COMPLETED - Enum constant in enum class com.hazelcast.cache.CacheEventType
An event type indicating that the cache operation has completed.
COMPLETED - Enum constant in enum class com.hazelcast.jet.core.JobStatus
The job has completed successfully.
completeEdge(int) - Method in interface com.hazelcast.jet.core.Processor
Called after the edge input with the supplied ordinal is exhausted.
completeFn(ConsumerEx<? super S>) - Method in class com.hazelcast.jet.pipeline.test.AssertionSinkBuilder
Sets the function that will be called after all the upstream stages have completed and all the items were received.
COMPLETING - Enum constant in enum class com.hazelcast.jet.core.JobStatus
The job is currently being completed.
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
concatenating() - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that takes string items and concatenates them into a single string.
concatenating(CharSequence) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that takes string items and concatenates them, separated by the given delimiter, into a single string.
concatenating(CharSequence, CharSequence, CharSequence) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that takes string items and concatenates them, separated by the given delimiter, into a single string.
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
 
CONFIG - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
Configuration permission
ConfigAccessor - Class in com.hazelcast.config
Private API for accessing configuration at runtime
configBuilder - Variable in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
ConfigBuilder - Interface in com.hazelcast.config
Interface for all config builders.
ConfigFactory - Class in com.hazelcast.spring.config
Provides factory methods for Config and ClientConfig.
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(Config, Properties) - Method in interface com.hazelcast.security.IPermissionPolicy
Configures IPermissionPolicy.
configure(Map<String, ?>, boolean) - Method in class com.hazelcast.jet.kafka.HazelcastKafkaAvroDeserializer
 
configure(Map<String, ?>, boolean) - Method in class com.hazelcast.jet.kafka.HazelcastKafkaAvroSerializer
 
configure(CallbackHandler) - Method in class com.hazelcast.config.security.StaticCredentialsFactory
 
configure(CallbackHandler) - Method in interface com.hazelcast.security.ICredentialsFactory
configureCapacity(int) - Method in interface com.hazelcast.jet.Observable
Set the capacity of the underlying Ringbuffer, which defaults to 10000.
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(Properties) - Static method in class com.hazelcast.jet.kafka.connect.KafkaConnectSources
A generic Kafka Connect source provides ability to plug any Kafka Connect source for data ingestion to Jet pipelines.
connect(Properties, FunctionEx<SourceRecord, T>) - Static method in class com.hazelcast.jet.kafka.connect.KafkaConnectSources
A generic Kafka Connect source provides ability to plug any Kafka Connect source for data ingestion to Jet pipelines.
connect(Properties, FunctionEx<SourceRecord, T>, RetryStrategy) - Static method in class com.hazelcast.jet.kafka.connect.KafkaConnectSources
A generic Kafka Connect source provides ability to plug any Kafka Connect source for data ingestion to Jet pipelines.
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.
CONNECTION_POOL_MAX - Static variable in class com.hazelcast.jet.mongodb.dataconnection.MongoDataConnection
Name of the property holding the maximum size of Mongo Client connection pool.
CONNECTION_POOL_MIN - Static variable in class com.hazelcast.jet.mongodb.dataconnection.MongoDataConnection
Name of the property holding the minimum size of Mongo Client connection pool.
CONNECTION_STRING_PROPERTY - Static variable in class com.hazelcast.jet.mongodb.dataconnection.MongoDataConnection
Name of a property which holds connection string to the mongodb instance.
connectionFn(FunctionEx<? super ConnectionFactory, ? extends Connection>) - Method in class com.hazelcast.jet.pipeline.JmsSourceBuilder
Sets the function which creates the connection using the connection factory.
connectionFn(FunctionEx<ConnectionFactory, Connection>) - Method in class com.hazelcast.jet.pipeline.JmsSinkBuilder
Sets the function which creates a connection given a connection factory.
connectionParams(String, String) - Method in class com.hazelcast.jet.pipeline.JmsSinkBuilder
Sets the connection parameters.
connectionParams(String, String) - Method in class com.hazelcast.jet.pipeline.JmsSourceBuilder
Sets the connection parameters.
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
 
CONNECTOR - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
Jet Connector permission
ConnectorPermission - Class in com.hazelcast.security.permission
 
ConnectorPermission(String, String...) - Constructor for class com.hazelcast.security.permission.ConnectorPermission
 
ConsistencyCheckStrategy - Enum Class 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
 
constant(long) - Static method in interface com.hazelcast.jet.retry.IntervalFunction
Creates an IntervalFunction which returns a fixed interval in milliseconds.
ConsumerEx<T> - Interface in com.hazelcast.function
Serializable variant of java.util.function.Consumer which declares checked exception.
consumerFn(FunctionEx<? super Session, ? extends MessageConsumer>) - Method in class com.hazelcast.jet.pipeline.JmsSourceBuilder
Sets the function which creates the message consumer from session.
contains(E) - Method in interface com.hazelcast.cp.IAtomicReference
Checks if the reference contains the value.
CONTAINS - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
CONTAINS_ALL - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
CONTAINS_ENTRY - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
CONTAINS_KEY - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
CONTAINS_VALUE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
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(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.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(Object) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.containsKey(Object).
containsKey(K) - Method in interface com.hazelcast.multimap.MultiMap
Returns whether the multimap contains an entry with the key.
containsTag(String) - Method in class com.hazelcast.jet.core.metrics.JobMetrics
Returns true if there is any Measurement that has the specified tag.
containsTag(String) - Static method in class com.hazelcast.jet.core.metrics.MeasurementPredicates
Matches a Measurement which contain the specified tag.
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.
convenientSourceP(FunctionEx<? super Processor.Context, ? extends C>, BiConsumerEx<? super C, ? super SourceBuilder.SourceBuffer<T>>, FunctionEx<? super C, ? extends S>, BiConsumerEx<? super C, ? super List<S>>, ConsumerEx<? super C>, int, boolean, Permission) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
Returns a supplier of processors for a source that the user can create using the SourceBuilder.
convenientTimestampedSourceP(FunctionEx<? super Processor.Context, ? extends C>, BiConsumerEx<? super C, ? super SourceBuilder.TimestampedSourceBuffer<T>>, EventTimePolicy<? super T>, FunctionEx<? super C, ? extends S>, BiConsumerEx<? super C, ? super List<S>>, ConsumerEx<? super C>, int) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
Returns a supplier of processors for a source that the user can create using the SourceBuilder.
convert(long, MemoryUnit) - Method in enum class com.hazelcast.memory.MemoryUnit
 
convert(Comparable) - Method in interface com.hazelcast.core.TypeConverter
Compares a Comparable-typed value to another.
convertToEventType(CacheEventType) - Static method in enum class com.hazelcast.cache.CacheEventType
Converts a CacheEventType into EventType.
COOPERATIVE_DEFAULT - Static variable in class com.hazelcast.jet.pipeline.ServiceFactory
Default value for ServiceFactory.isCooperative.
COOPERATIVE_WORKER - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
Index of the cooperative worker in a fixed worker pool sourcing the metric.
cooperativeTimeout(long) - Method in class com.hazelcast.jet.core.test.TestSupport
If timeout > 0, the test will fail if any call to processing method in a cooperative processor exceeds this timeout.
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
copy(T, boolean) - Method in class com.hazelcast.config.CacheConfig
Copy this CacheConfig to given target object whose type extends CacheConfig.
COPY_ON_READ - Static variable in class com.hazelcast.jet.hadoop.HadoopSources
With the new HDFS API, some of the RecordReaders return the same key/value instances for each record, for example LineRecordReader.
copyWithInitializedDefaultMaxSizeForOnHeapMaps(NearCacheConfig) - Static method in class com.hazelcast.config.NearCacheConfigAccessor
 
COSINE - Enum constant in enum class com.hazelcast.config.vector.Metric
Cosine distance
count() - Static method in class com.hazelcast.aggregation.Aggregators
 
count(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
COUNT - Enum constant in enum class com.hazelcast.jet.core.metrics.Unit
Number of items: size, counter...
COUNT_DOWN_LATCH - Static variable in interface com.hazelcast.cp.CPSubsystem
Constant identifying service for ICountDownLatch, to be used with CPSubsystem.getObjectInfos(CPGroupId, String)
countDown() - Method in interface com.hazelcast.cp.ICountDownLatch
Decrements the count of the latch, releasing all waiting threads if the count reaches zero.
COUNTDOWN_LATCH - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
Countdown Latch
CountDownLatchPermission - Class in com.hazelcast.security.permission
 
CountDownLatchPermission(String, String...) - Constructor for class com.hazelcast.security.permission.CountDownLatchPermission
 
counting() - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that counts the items it observes.
CP - Enum constant in enum class com.hazelcast.config.RestEndpointGroup
Deprecated.
Groups of HTTP REST APIs for CP subsystem interaction
CP_BASE_DIR_DEFAULT - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
The default directory name for storing CP data.
CP_MAP - Static variable in interface com.hazelcast.cp.CPSubsystem
Constant identifying service for CPMap, to be used with CPSubsystem.getObjectInfos(CPGroupId, String)
CP_SUBSYSTEM_IS_NOT_AVAILABLE_IN_OS - Static variable in class com.hazelcast.cp.CPSubsystemStubImpl
Message to inform that CP subsystem is not available in Hazelcast OS
CPGroup - Interface in com.hazelcast.cp
Contains information about a CP group.
CPGroup.CPGroupStatus - Enum Class 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.
CPGroupsSnapshot - Class in com.hazelcast.cp
Represents an immutable snapshot of the current CP groups view from 1 member of the Hazelcast cluster.
CPGroupsSnapshot(Map<CPGroupId, CPGroupsSnapshot.GroupInfo>) - Constructor for class com.hazelcast.cp.CPGroupsSnapshot
Create a new CPGroupsSnapshot without any CP to AP UUID mapping.
CPGroupsSnapshot(Map<CPGroupId, CPGroupsSnapshot.GroupInfo>, Map<UUID, UUID>) - Constructor for class com.hazelcast.cp.CPGroupsSnapshot
Create a new CPGroupsSnapshot with included CP to AP UUID mapping.
CPGroupsSnapshot.GroupInfo - Record Class in com.hazelcast.cp
 
CPMap<K,V> - Interface in com.hazelcast.cp
CPMap is a key-value store within CP.
CPMAP - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
CP Map permissions
CPMapConfig - Class in com.hazelcast.config.cp
Configuration for CPMap.
CPMapConfig() - Constructor for class com.hazelcast.config.cp.CPMapConfig
Deprecated.
exists only for DOM processing.
CPMapConfig(CPMapConfig) - Constructor for class com.hazelcast.config.cp.CPMapConfig
Copy constructor.
CPMapConfig(String) - Constructor for class com.hazelcast.config.cp.CPMapConfig
Creates a configuration for a CPMap with the given name and the default map capacity of CPMapConfig.DEFAULT_MAX_SIZE_MB.
CPMapConfig(String, int) - Constructor for class com.hazelcast.config.cp.CPMapConfig
Creates a configuration for a CPMap with the given name and maximum capacity in MB as specified by maxSizeMb.
CPMapPermission - Class in com.hazelcast.security.permission
 
CPMapPermission(String, String...) - Constructor for class com.hazelcast.security.permission.CPMapPermission
 
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 Class 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.
CPObjectInfo - Interface in com.hazelcast.cp
Info (name, serviceName, group) about a CP object
CPSession - Interface in com.hazelcast.cp.session
Represents a CP session.
CPSession.CPSessionOwnerType - Enum Class 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(String, Throwable, UUID) - Constructor for exception com.hazelcast.cp.exception.CPSubsystemException
 
CPSubsystemException(String, UUID) - Constructor for exception com.hazelcast.cp.exception.CPSubsystemException
 
CPSubsystemException(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.
CPSubsystemStubImpl - Class in com.hazelcast.cp
 
CPSubsystemStubImpl() - Constructor for class com.hazelcast.cp.CPSubsystemStubImpl
 
CRDTReplicationConfig - Class in com.hazelcast.config
Configures the replication mechanism for all CRDT implementations.
CRDTReplicationConfig() - Constructor for class com.hazelcast.config.CRDTReplicationConfig
 
create() - Static method in class com.hazelcast.console.ConsoleApp
 
create() - Static method in interface com.hazelcast.jet.pipeline.Pipeline
Creates a new, empty pipeline.
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
Deprecated.
Creates a Portable instance using the given class ID
create(String) - Static method in class com.hazelcast.spi.utils.RestClient
 
create(String, int) - Static method in class com.hazelcast.spi.utils.RestClient
 
create(RelOptPlanner, RexBuilder, SqlSecurityContext) - Static method in class org.apache.calcite.plan.HazelcastRelOptCluster
 
CREATE - Static variable in class com.hazelcast.security.permission.InstancePermission
 
CREATE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
CREATE_CONFIG - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
CREATE_ON_UPDATE - Enum constant in enum class com.hazelcast.config.MetadataPolicy
Hazelcast processes supported objects at the time of creation and updates.
CREATE_PROXIES - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
createAccessControlService() - Method in interface com.hazelcast.access.AccessControlServiceFactory
Creates the configured AccessControlService instance.
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
 
createContextFn() - Method in class com.hazelcast.jet.pipeline.ServiceFactory
Returns the function that creates the shared context object.
CREATED - Enum constant in enum class com.hazelcast.cache.CacheEventType
An event type indicating that the cache entry was created.
CREATED - Enum constant in enum class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
Expiry policy type for the CreatedExpiryPolicy.
CREATED - Enum constant in enum class com.hazelcast.core.DistributedObjectEvent.EventType
Event if a DistributedObjectEvent is created.
createFactory() - Method in class com.hazelcast.jet.config.JetConfigDataSerializerHook
 
createFactory() - Method in class com.hazelcast.jet.core.JetDataSerializerHook
 
createFactory() - Method in class com.hazelcast.jet.core.metrics.MetricsDataSerializerHook
 
createFn() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
A primitive that returns a new accumulator.
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
 
createLoginConfigurationForRealm(String) - Method in interface com.hazelcast.security.SecurityContext
Creates JAAS login Configuration from given Security Realm configuration.
createLoginContext(Configuration, String, Credentials, InetAddress) - Method in interface com.hazelcast.security.SecurityContext
Creates LoginContext from given JAAS Configuration.
createMemberLoginContext(String, Credentials, Connection) - Method in interface com.hazelcast.security.SecurityContext
Creates member LoginContext.
createResultSet(Connection, int, int) - Method in interface com.hazelcast.jet.function.ToResultSetFunction
Creates a result set which returns a part of the rows pertaining to the given processor.
createSecureCallable(Subject, Runnable) - Method in interface com.hazelcast.security.SecurityContext
Creates secure callable that runs in a sandbox.
createSecureCallable(Subject, Callable<V>) - Method in interface com.hazelcast.security.SecurityContext
Creates secure callable that runs in a sandbox.
createSerializer() - Method in class com.hazelcast.jet.protobuf.ProtobufSerializerHook
 
createSerializer() - Method in interface com.hazelcast.nio.serialization.SerializerHook
Creates a new serializer for the serialization type
createSerializer(SerializationService) - Method in interface com.hazelcast.nio.serialization.SerializerHook
Creates a new serializer for the serialization type
createServiceFn() - Method in class com.hazelcast.jet.pipeline.ServiceFactory
Returns the function that creates the service object.
createSnapshot(SchemaVersion) - Method in class org.apache.calcite.jdbc.HazelcastRootCalciteSchema
 
createSnapshotFn(FunctionEx<? super C, ? extends S>) - Method in class com.hazelcast.jet.pipeline.SourceBuilder.Stream
 
createSnapshotFn(FunctionEx<? super C, ? extends S>) - Method in class com.hazelcast.jet.pipeline.SourceBuilder.TimestampedStream
 
createSqlContext(Subject) - Method in interface com.hazelcast.security.SecurityContext
 
createUnresolvedAddress(String, int) - Static method in class com.hazelcast.cluster.Address
Creates an unresolved address.
createWithSSL(String, String) - Static method in class com.hazelcast.spi.utils.RestClient
 
createWithSSL(String, String, int) - Static method in class com.hazelcast.spi.utils.RestClient
 
creationTime() - Method in interface com.hazelcast.cp.session.CPSession
Returns the timestamp of when the session was created
creationTime() - Method in class com.hazelcast.jet.JobStateSnapshot
Returns the time the snapshot 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
 
csv(Class<T>) - Static method in interface com.hazelcast.jet.pipeline.file.FileFormat
Returns a file format for CSV files which specifies to deserialize each line into an instance of the given class.
csv(List<String>) - Static method in interface com.hazelcast.jet.pipeline.file.FileFormat
Returns a file format for CSV files which specifies to deserialize each line into String[].
CsvFileFormat<T> - Class in com.hazelcast.jet.pipeline.file
FileFormat for CSV files.
custom() - Static method in class com.hazelcast.jet.retry.RetryStrategies
Create a builder which can be used for setting up an arbitrarily complex strategy.
CUSTOM - Enum constant in enum class com.hazelcast.config.PartitionGroupConfig.MemberGroupType
Custom.
CUSTOM - Enum constant in enum class com.hazelcast.spi.discovery.DiscoveryStrategyFactory.DiscoveryStrategyLevel
Custom strategy level, highest priority.
customTransform(String, SupplierEx<Processor>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
 
customTransform(String, SupplierEx<Processor>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
 
customTransform(String, SupplierEx<Processor>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
Attaches a stage with a custom transform based on the provided supplier of Core API Processors.
customTransform(String, SupplierEx<Processor>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
Attaches a stage with a custom transform based on the provided supplier of Core API Processors.
customTransform(String, SupplierEx<Processor>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
 
customTransform(String, SupplierEx<Processor>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
 
customTransform(String, ProcessorMetaSupplier) - Method in interface com.hazelcast.jet.pipeline.BatchStage
 
customTransform(String, ProcessorMetaSupplier) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
 
customTransform(String, ProcessorMetaSupplier) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
Attaches a stage with a custom transform based on the provided supplier of Core API Processors.
customTransform(String, ProcessorMetaSupplier) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
Attaches a stage with a custom transform based on the provided supplier of Core API Processors.
customTransform(String, ProcessorMetaSupplier) - Method in interface com.hazelcast.jet.pipeline.StreamStage
 
customTransform(String, ProcessorMetaSupplier) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
 
customTransform(String, ProcessorSupplier) - Method in interface com.hazelcast.jet.pipeline.BatchStage
 
customTransform(String, ProcessorSupplier) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
 
customTransform(String, ProcessorSupplier) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
Attaches a stage with a custom transform based on the provided supplier of Core API Processors.
customTransform(String, ProcessorSupplier) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
Attaches a stage with a custom transform based on the provided supplier of Core API Processors.
customTransform(String, ProcessorSupplier) - Method in interface com.hazelcast.jet.pipeline.StreamStage
 
customTransform(String, ProcessorSupplier) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
 

D

DAG - Class in com.hazelcast.jet.core
Describes a computation to be performed by the Jet computation engine.
DAG - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
 
DAG() - Constructor for class com.hazelcast.jet.core.DAG
 
dagJsonString() - Method in class com.hazelcast.jet.JobStateSnapshot
Returns the JSON representation of the DAG of the job this snapshot was created from.
DATA - Enum constant in enum class com.hazelcast.config.RestEndpointGroup
Deprecated.
Group of HTTP REST APIs for data manipulation in the cluster (e.g.
DATA_CONNECTION_REF_PROPERTY - Static variable in class com.hazelcast.mapstore.GenericMapLoader
Property key to define data connection
DATA_MEMBER_SELECTOR - Static variable in class com.hazelcast.cluster.memberselector.MemberSelectors
A MemberSelector instance that selects only data members that own a partition
database() - Method in interface com.hazelcast.jet.cdc.ChangeRecord
Returns the name of the database containing the record's table.
database(String) - Method in class com.hazelcast.jet.mongodb.MongoSourceBuilder.Stream
 
DATABASE_PROPERTY - Static variable in class com.hazelcast.jet.mongodb.dataconnection.MongoDataConnection
Name of a property with a database name hint.
DataConnection - Interface in com.hazelcast.dataconnection
DataConnection is a reference to a single external system.
DataConnectionBase - Class in com.hazelcast.dataconnection
Base class for DataConnection implementations.
DataConnectionBase(DataConnectionConfig) - Constructor for class com.hazelcast.dataconnection.DataConnectionBase
 
DataConnectionConfig - Class in com.hazelcast.config
A configuration of a data connection that can be used: to create a source or sink in a Jet Pipeline, as a data connection for MapStore and MapLoader, to create an SQL mapping.
DataConnectionConfig() - Constructor for class com.hazelcast.config.DataConnectionConfig
 
DataConnectionConfig(DataConnectionConfig) - Constructor for class com.hazelcast.config.DataConnectionConfig
 
DataConnectionConfig(String) - Constructor for class com.hazelcast.config.DataConnectionConfig
 
DataConnectionConfigValidator - Class in com.hazelcast.config
Validates an instance of DataConnectionConfig.
dataConnectionName(DataConnectionRef) - Method in class com.hazelcast.jet.pipeline.MapSinkEntryProcessorBuilder
 
dataConnectionRef(DataConnectionRef) - Method in class com.hazelcast.jet.pipeline.JdbcSinkBuilder
Sets the reference to the configured data connection of DataConnectionRef from which the instance of the DataSource will be retrieved.
dataConnectionRef(DataConnectionRef) - Method in class com.hazelcast.jet.pipeline.MapSinkBuilder
Sets the DataConnectionRef reference to a HazelcastDataConnection to use for remote Map sink.
dataConnectionRef(DataConnectionRef) - Method in class com.hazelcast.jet.pipeline.RemoteMapSourceBuilder
Set the data connection name to use to connect to the remote cluster.
dataConnectionRef(String) - Static method in class com.hazelcast.jet.pipeline.DataConnectionRef
Creates a reference to the configured data connection
DataConnectionRef - Class in com.hazelcast.jet.pipeline
Represents a reference to the data connection, used with Sources.jdbc(DataConnectionRef, ToResultSetFunction, FunctionEx).
DataConnectionRef(String) - Constructor for class com.hazelcast.jet.pipeline.DataConnectionRef
 
DataConnectionRegistration - Interface in com.hazelcast.dataconnection
Registration for a DataConnection.
DataConnectionResource - Class in com.hazelcast.dataconnection
DataConnection Resource is an object for which a mapping can be created.
DataConnectionResource(String, String) - Constructor for class com.hazelcast.dataconnection.DataConnectionResource
Create a Resource with given type and name
DataConnectionResource(String, String...) - Constructor for class com.hazelcast.dataconnection.DataConnectionResource
Create a Resource with given type and name
dataConnectionService() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
A service to access DataConnections in processors.
dataConnectionService() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
 
DataConnectionService - Interface in com.hazelcast.dataconnection
The interface provides access to DataConnections for Jet processors.
dataPersistenceConfig - Variable in class com.hazelcast.config.AbstractCacheConfig
 
DataPersistenceConfig - Class in com.hazelcast.config
Configures the Persistence per Hazelcast data structure.
DataPersistenceConfig() - Constructor for class com.hazelcast.config.DataPersistenceConfig
 
DataPersistenceConfig(DataPersistenceConfig) - Constructor for class com.hazelcast.config.DataPersistenceConfig
 
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.
dataSourceSupplier(SupplierEx<? extends CommonDataSource>) - Method in class com.hazelcast.jet.pipeline.JdbcSinkBuilder
Sets the supplier of DataSource or XADataSource.
DATE - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
 
DATE - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
 
DATE - Enum constant in enum class com.hazelcast.sql.SqlColumnType
DATE type, represented by LocalDate
DATE_ARRAY - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
 
debezium(String, Class<?>) - Static method in class com.hazelcast.jet.cdc.DebeziumCdcSources
Creates a CDC source that streams change data from a Debezium-supported database to a Hazelcast Jet pipeline.
debezium(String, String) - Static method in class com.hazelcast.jet.cdc.DebeziumCdcSources
Creates a CDC source that streams change data from a Debezium-supported database to a Hazelcast Jet pipeline.
DebeziumCdcSources - Class in com.hazelcast.jet.cdc
Contains factory methods for creating Change Data Capture (CDC) sources.
DebeziumCdcSources.Builder<T> - Class in com.hazelcast.jet.cdc
A builder to configure a CDC source that streams the change data from a Debezium-supported database to Hazelcast Jet.
debeziumJson(String, Class<?>) - Static method in class com.hazelcast.jet.cdc.DebeziumCdcSources
Creates a CDC source that streams change data from a Debezium-supported database to a Hazelcast Jet pipeline.
debeziumJson(String, String) - Static method in class com.hazelcast.jet.cdc.DebeziumCdcSources
Creates a CDC source that streams change data from a Debezium-supported database to a Hazelcast Jet pipeline.
DEBUG - Enum constant in enum class com.hazelcast.auditlog.Level
Debug level.
DECIMAL - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
 
DECIMAL - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
 
DECIMAL - Enum constant in enum class com.hazelcast.sql.SqlColumnType
DECIMAL type, represented by BigDecimal
DECIMAL_ARRAY - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
 
decode(String) - Method in enum class com.hazelcast.config.security.TokenEncoding
 
decrement() - Method in interface com.hazelcast.jet.core.metrics.Metric
Decrements the current value by 1.
decrement(long) - Method in interface com.hazelcast.jet.core.metrics.Metric
Decrements the current value by the specified amount.
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.
deduct(DoubleAccumulator) - Method in class com.hazelcast.jet.accumulator.DoubleAccumulator
Subtracts the value of the supplied accumulator from this one.
deduct(LinTrendAccumulator) - Method in class com.hazelcast.jet.accumulator.LinTrendAccumulator
Deducts the supplied accumulator from this one.
deductFn() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
A primitive that accepts two accumulators and updates the state of the left-hand one by deducting the state of the right-hand one from it.
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.DynamicConfigurationConfig
Default number of backup declarative configuration files to keep.
DEFAULT_BACKUP_COUNT - Static variable in class com.hazelcast.config.MapConfig
The default number of backups
DEFAULT_BACKUP_COUNT - Static variable in class com.hazelcast.jet.config.InstanceConfig
Deprecated.
The default value of the backup-count
DEFAULT_BACKUP_COUNT - Static variable in class com.hazelcast.jet.config.JetConfig
The default value of the backup-count
DEFAULT_BACKUP_DIR - Static variable in class com.hazelcast.config.DynamicConfigurationConfig
Default name of the folder where backups will be kept.
DEFAULT_BATCH_LIMIT - Static variable in class com.hazelcast.jet.pipeline.JdbcSinkBuilder
The default batch size limit to use for the sink if batching is supported.
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_BLOCK_SIZE_IN_BYTES - Static variable in class com.hazelcast.config.LocalDeviceConfig
Default block/sector size in bytes.
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.LocalDeviceConfig
Default device capacity.
DEFAULT_CAPACITY - Static variable in class com.hazelcast.config.MemoryTierConfig
Default capacity.
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_CONNECT_TIMEOUT_MILLIS - Static variable in class com.hazelcast.client.config.ConnectionRetryConfig
Default value for the cluster connection timeout.
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_COMMIT_RETRY_STRATEGY - Static variable in class com.hazelcast.jet.mongodb.MongoSinkBuilder
Default retry strategy used by the processors.
DEFAULT_CONNECT_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.utils.RestClient
Default value of -1 results in connection timeout not being explicitly defined
DEFAULT_CP_MAP_LIMIT - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
The default limit number of CPMap that can be created.
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
Deprecated.
Default load timeout
DEFAULT_DATA_LOAD_TIMEOUT - Static variable in class com.hazelcast.config.PersistenceConfig
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_DEVICE_BASE_DIR - Static variable in class com.hazelcast.config.LocalDeviceConfig
Default base directory for the device.
DEFAULT_DEVICE_NAME - Static variable in class com.hazelcast.config.LocalDeviceConfig
Default device name.
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_ENABLED - Static variable in class com.hazelcast.config.TieredStoreConfig
Default value for if tiered-store is enabled.
DEFAULT_ENTRY_STATS_ENABLED - Static variable in class com.hazelcast.config.MapConfig
Default value of whether per entry statistics are enabled or not
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_EXACTLY_ONCE - Static variable in class com.hazelcast.jet.pipeline.JdbcSinkBuilder
The default setting for whether exactly-once is allowed for the sink.
DEFAULT_FILE - Static variable in class com.hazelcast.config.InstanceTrackingConfig
Default file to which the instance metadata will be written.
DEFAULT_FLOW_CONTROL_PERIOD_MS - Static variable in class com.hazelcast.jet.config.InstanceConfig
Deprecated.
The default value of the flow-control period.
DEFAULT_FLOW_CONTROL_PERIOD_MS - Static variable in class com.hazelcast.jet.config.JetConfig
The default value of the flow-control period.
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_IDLE_TIMEOUT - Static variable in class com.hazelcast.jet.core.EventTimePolicy
The default idle timeout in milliseconds.
DEFAULT_IN_MEMORY_FORMAT - Static variable in class com.hazelcast.config.CacheSimpleConfig
Default InMemory Format.
DEFAULT_IN_MEMORY_FORMAT - Static variable in class com.hazelcast.config.MapConfig
Default In-Memory format is binary.
DEFAULT_IN_MEMORY_FORMAT - Static variable in class com.hazelcast.config.QueryCacheConfig
By default, hold values of entries in QueryCache as binary.
DEFAULT_IN_MEMORY_FORMAT - Static variable in class com.hazelcast.config.ReplicatedMapConfig
Default value of In-memory format
DEFAULT_IN_MEMORY_FORMAT - Static variable in class com.hazelcast.config.RingbufferConfig
Default value for the 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_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_OPS - Static variable in interface com.hazelcast.jet.pipeline.GeneralStage
Default value for max concurrent operations.
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_MB - Static variable in class com.hazelcast.config.cp.CPMapConfig
The default maximum size in MB that a CPMap can total.
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_NAME - Static variable in class com.hazelcast.config.NearCacheConfig
Default name when it is not set explicitly.
DEFAULT_NAMESPACE - Static variable in interface com.hazelcast.config.UserCodeNamespaceAwareConfig
Defines the default User Code Namespace Name used for all UserCodeNamespaceAwareConfig implementations.
DEFAULT_OFFLOAD - Static variable in class com.hazelcast.config.MapStoreConfig
Default offload behavior
DEFAULT_PACKET_SIZE_LIMIT - Static variable in class com.hazelcast.jet.config.EdgeConfig
The default packet size limit.
DEFAULT_PAGE_SIZE - Static variable in class com.hazelcast.config.BTreeIndexConfig
Default value of page size for B-Trees.
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
Deprecated.
Default level of parallelism in Hot Restart Persistence.
DEFAULT_PARALLELISM - Static variable in class com.hazelcast.config.PersistenceConfig
Default level of parallelism in 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_PRESERVE_ORDER - Static variable in interface com.hazelcast.jet.pipeline.GeneralStage
Default value for preserver order.
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_QUEUE_SIZE - Static variable in class com.hazelcast.jet.config.EdgeConfig
The default size of the concurrent queues connecting processors within a cluster member.
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_READ_IO_THREAD_COUNT - Static variable in class com.hazelcast.config.LocalDeviceConfig
Default read IO thread count.
DEFAULT_REALM - Static variable in class com.hazelcast.config.security.RealmConfig
Default security realm instance.
DEFAULT_REBALANCE_DELAY - Static variable in class com.hazelcast.config.PersistenceConfig
 
DEFAULT_RECEIVE_BUFFER_SIZE_KB - Static variable in class com.hazelcast.config.tpc.TpcSocketConfig
 
DEFAULT_RECEIVE_WINDOW_MULTIPLIER - Static variable in class com.hazelcast.jet.config.EdgeConfig
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_RESUBMISSION_MODE - Static variable in class com.hazelcast.client.config.ClientSqlConfig
The default resubmission mode.
DEFAULT_RING_BUFFER_CAPACITY - Static variable in class com.hazelcast.config.DurableExecutorConfig
Capacity of RingBuffer (per partition).
DEFAULT_ROUTING_MODE - Static variable in class com.hazelcast.client.config.ClusterRoutingConfig
The default RoutingMode to use when one is not explicitly defined
DEFAULT_ROUTING_STRATEGY - Static variable in class com.hazelcast.client.config.ClusterRoutingConfig
The default RoutingStrategy to use when one is not explicitly defined
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_SEND_BUFFER_SIZE_KB - Static variable in class com.hazelcast.config.tpc.TpcSocketConfig
 
DEFAULT_SERIALIZE_KEYS - Static variable in class com.hazelcast.config.NearCacheConfig
Do not serialize by default
DEFAULT_SERIALIZE_KEYS - Static variable in class com.hazelcast.config.QueryCacheConfig
Do not serialize given keys 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_KEEP_COUNT - Static variable in class com.hazelcast.config.EndpointConfig
See jdk.net.ExtendedSocketOptions#TCP_KEEPINTERVAL
DEFAULT_SOCKET_KEEP_IDLE_SECONDS - Static variable in class com.hazelcast.config.EndpointConfig
See jdk.net.ExtendedSocketOptions#TCP_KEEPIDLE
DEFAULT_SOCKET_KEEP_INTERVAL_SECONDS - Static variable in class com.hazelcast.config.EndpointConfig
See jdk.net.ExtendedSocketOptions#TCP_KEEPINTERVAL
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
Deprecated.
Default symmetric encryption algorithm
DEFAULT_SYMMETRIC_PASSWORD - Static variable in class com.hazelcast.config.SymmetricEncryptionConfig
Deprecated.
Default symmetric encryption password used in Hazelcast before version 5.5.
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_TRANSACTION_OPTION - Static variable in class com.hazelcast.jet.mongodb.MongoSinkBuilder
Default transaction options used by the processors.
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
Deprecated.
Default validation timeout
DEFAULT_VALIDATION_TIMEOUT - Static variable in class com.hazelcast.config.PersistenceConfig
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
DEFAULT_WRITE_IO_THREAD_COUNT - Static variable in class com.hazelcast.config.LocalDeviceConfig
Default write IO thread count.
DefaultAuthenticationConfig - Class in com.hazelcast.config.security
Default AuthenticationConfig implementation which just references the DefaultLoginModule.
defaultPartitioner() - Static method in interface com.hazelcast.jet.core.Partitioner
Returns a partitioner which applies the default Hazelcast partitioning.
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
 
DefaultPartitionStrategy - Interface in com.hazelcast.jet.core
A facade that hides the details of Hazelcast partitioning SPI and exposes just the partitioning strategy.
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(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).
delete(K) - Method in interface com.hazelcast.cp.CPMap
Removes key if 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(K) - Method in class com.hazelcast.mapstore.GenericMapStore
 
DELETE - Enum constant in enum class com.hazelcast.jet.cdc.Operation
Record deletion, sourced from the DB changelog.
DELETE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
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.
deleteAll(Collection<K>) - Method in class com.hazelcast.mapstore.GenericMapStore
 
deleteAsync(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 delete operation completion or block waiting for the operation to complete using one of blocking ways to wait on CompletionStage.toCompletableFuture().
DELTA_JOB_CONFIG - Static variable in class com.hazelcast.jet.config.JetConfigDataSerializerHook
Serialization ID of the DeltaJobConfig class.
DeltaJobConfig - Class in com.hazelcast.jet.config
Contains a configuration change for JobConfig.
DeltaJobConfig() - Constructor for class com.hazelcast.jet.config.DeltaJobConfig
 
DEMOTE_MAX_WAIT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Maximum wait in seconds during member demotion to a lite member.
demoteLocalDataMember() - Method in interface com.hazelcast.cluster.Cluster
Demotes the local data member to a lite member.
DenyAllPermissionCollection - Class in com.hazelcast.security.permission
 
DenyAllPermissionCollection() - Constructor for class com.hazelcast.security.permission.DenyAllPermissionCollection
 
DEPLOY_CLASSES - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
DEREGISTER_CACHE_ENTRY_LISTENER - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
deriveTypeImpl(SqlValidatorScope, SqlNode) - Method in class org.apache.calcite.sql.validate.SqlValidatorImplBridge
 
description() - Method in interface com.hazelcast.jet.core.JobSuspensionCause
Describes the job suspension cause in a human-readable form.
deserialize(String, byte[]) - Method in class com.hazelcast.jet.kafka.HazelcastKafkaAvroDeserializer
 
DESTINATION_ADDRESS - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
Destination member address for items sent to a distributed edge.
destinationName(String) - Method in class com.hazelcast.jet.pipeline.JmsSinkBuilder
Sets the name of the destination.
destinationName(String) - Method in class com.hazelcast.jet.pipeline.JmsSourceBuilder
Sets the name of the destination (name of the topic or queue).
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.dataconnection.DataConnection
Called by the member when shutting down.
destroy() - Method in class com.hazelcast.dataconnection.HazelcastDataConnection
 
destroy() - Method in class com.hazelcast.jet.JobStateSnapshot
Destroy the underlying distributed object.
destroy() - Method in class com.hazelcast.jet.kafka.KafkaDataConnection
 
destroy() - Method in class com.hazelcast.jet.mongodb.dataconnection.MongoDataConnection
Closes underlying client.
destroy() - Method in interface com.hazelcast.jet.Observable
Removes all previously registered observers and destroys the backing Ringbuffer.
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 class com.hazelcast.mapstore.GenericMapLoader
 
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() - 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 - Static variable in class com.hazelcast.security.permission.InstancePermission
 
DESTROY - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
DESTROY_CACHE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
DESTROY_TIMEOUT - Static variable in class com.hazelcast.jet.grpc.GrpcProperties
Time to wait for StreamObserver.onCompleted() confirmation when destroying a BidirectionalStreamingService You may want to increase this value when your gRPC calls take longer than 1 s to cleanly shutdown the service.
destroyContextFn() - Method in class com.hazelcast.jet.pipeline.ServiceFactory
Returns the function that destroys the shared context object at the end of the Jet job.
DESTROYED - Enum constant in enum class com.hazelcast.core.DistributedObjectEvent.EventType
Event if a DistributedObjectEvent is destroyed.
DESTROYED - Enum constant in enum class com.hazelcast.cp.CPGroup.CPGroupStatus
A CP group switches to this state after its destroy process is completed.
DestroyEventContext - Interface in com.hazelcast.spi.tenantcontrol
Hook to decouple Hazelcast object from the tenant
destroyFn(ConsumerEx<? super C>) - Method in class com.hazelcast.jet.pipeline.SinkBuilder
Sets the function that will destroy the context object and perform any cleanup.
destroyFn(ConsumerEx<? super C>) - Method in class com.hazelcast.jet.pipeline.SourceBuilder.Batch
 
destroyFn(ConsumerEx<? super C>) - Method in class com.hazelcast.jet.pipeline.SourceBuilder.Stream
 
destroyFn(ConsumerEx<? super C>) - Method in class com.hazelcast.jet.pipeline.SourceBuilder.TimestampedStream
 
DESTROYING - Enum constant in enum class com.hazelcast.cp.CPGroup.CPGroupStatus
A CP group switches to this state after its destroy process is initialized, but not completed yet.
destroyServiceFn() - Method in class com.hazelcast.jet.pipeline.ServiceFactory
Returns the function that destroys the service object at the end of the Jet job.
determineLocalParallelism(int) - Method in class com.hazelcast.jet.core.Vertex
Determines the local parallelism value for the vertex by looking at its local parallelism and meta supplier's preferred local parallelism.
DeviceConfig - Interface in com.hazelcast.config
Device configuration for the Tiered-Store
DiagnosticProcessors - Class in com.hazelcast.jet.core.processor
Static utility class with factories of sinks and wrappers that log the data flowing through the DAG.
DIRECT - Enum constant in enum class com.hazelcast.config.security.LdapRoleMappingMode
User object attribute contains DNs of role objects.
DIRECTORY - Enum constant in enum class com.hazelcast.jet.config.ResourceType
Represents a directory of plain files.
DISABLE_ROLLING - Static variable in class com.hazelcast.jet.pipeline.FileSinkBuilder
A value to pass to FileSinkBuilder.rollByFileSize(long) if you want to disable rolling by file size.
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
Deprecated.
Disables all REST endpoint groups.
disableAllGroups() - Method in class com.hazelcast.config.RestServerEndpointConfig
Deprecated.
Disables all REST endpoint groups.
disableCompleteCall() - Method in class com.hazelcast.jet.core.test.TestSupport
Disables calling complete() method during the test.
DISABLED_TTL_SECONDS - Static variable in class com.hazelcast.config.MapConfig
The number of Time to Live that represents disabling TTL.
disableGroups(RestEndpointGroup...) - Method in class com.hazelcast.config.RestApiConfig
Deprecated.
Disables provided REST endpoint groups.
disableGroups(RestEndpointGroup...) - Method in class com.hazelcast.config.RestServerEndpointConfig
Deprecated.
Disables provided REST endpoint groups.
disableLogging() - Method in class com.hazelcast.jet.core.test.TestSupport
Disables logging of input and output objects.
disableProgressAssertion() - Method in class com.hazelcast.jet.core.test.TestSupport
Disables checking of progress of processing methods (see class javadoc for information on what is "progress").
disableReentrancy() - Method in class com.hazelcast.config.cp.FencedLockConfig
Disable reentrancy.
disableSnapshots() - Method in class com.hazelcast.jet.core.test.TestSupport
Disable snapshot save and restore before first item and after each process() and complete() call.
DISCARD_AFTER_MUTATION - Enum constant in enum class com.hazelcast.config.WanQueueFullBehavior
Instruct WAN replication implementation to drop new events when WAN event queues are full.
DISCARD_NEWEST - Enum constant in enum class com.hazelcast.topic.TopicOverloadPolicy
The message that was to be published is discarded.
DISCARD_OLDEST - Enum constant in enum class com.hazelcast.topic.TopicOverloadPolicy
Using this policy, a message that has not expired can be overwritten.
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
 
disconnect() - Method in class com.hazelcast.spi.utils.RestClient.WatchResponse
 
discoverLocalMetadata() - Method in class com.hazelcast.aws.AwsDiscoveryStrategy
 
discoverLocalMetadata() - Method in class com.hazelcast.azure.AzureDiscoveryStrategy
 
discoverLocalMetadata() - Method in class com.hazelcast.gcp.GcpDiscoveryStrategy
 
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 class com.hazelcast.aws.AwsDiscoveryStrategy
 
discoverNodes() - Method in class com.hazelcast.azure.AzureDiscoveryStrategy
 
discoverNodes() - Method in class com.hazelcast.gcp.GcpDiscoveryStrategy
 
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(DiscoveryConfig) - Constructor for class com.hazelcast.config.DiscoveryConfig
 
DiscoveryConfig(DiscoveryServiceProvider, NodeFilter, String, Collection<DiscoveryStrategyConfig>) - Constructor for class com.hazelcast.config.DiscoveryConfig
 
DiscoveryMode - Enum Class 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(DiscoveryStrategyConfig) - 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(String) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
 
DiscoveryStrategyConfig(String, Map<String, Comparable>) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
 
DiscoveryStrategyFactory - Interface in com.hazelcast.spi.discovery
The DiscoveryStrategyFactory is the entry point for strategy vendors.
DiscoveryStrategyFactory.DiscoveryStrategyLevel - Enum Class in com.hazelcast.spi.discovery
Level of the discovery strategy.
discoveryStrategyLevel() - Method in class com.hazelcast.aws.AwsDiscoveryStrategyFactory
 
discoveryStrategyLevel() - Method in class com.hazelcast.azure.AzureDiscoveryStrategyFactory
 
discoveryStrategyLevel() - Method in class com.hazelcast.gcp.GcpDiscoveryStrategyFactory
 
discoveryStrategyLevel() - Method in class com.hazelcast.kubernetes.HazelcastKubernetesDiscoveryStrategyFactory
 
discoveryStrategyLevel() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategyFactory
Level of the discovery strategy.
DiskTierConfig - Class in com.hazelcast.config
Disk tier configuration of Tiered-Store.
DiskTierConfig() - Constructor for class com.hazelcast.config.DiskTierConfig
 
DiskTierConfig(DiskTierConfig) - Constructor for class com.hazelcast.config.DiskTierConfig
 
dispose() - Method in interface com.hazelcast.scheduledexecutor.IScheduledFuture
Used to destroy the instance of the IScheduledFuture in the scheduled executor.
DISPOSE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
DISPOSE_RESULT - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
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() - Method in interface com.hazelcast.jet.pipeline.BatchStage
Attaches a stage that emits just the items that are distinct according to their definition of equality (equals and hashCode).
distinct() - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
Attaches a stage that emits just the items that are distinct according to the grouping key (no two items which map to the same key will be on the output).
distinct() - Method in interface com.hazelcast.jet.pipeline.StageWithKeyAndWindow
Attaches a stage that passes through just the items that are distinct within their window according to the grouping key (no two items emitted for a window map to the same key).
distinct() - Method in interface com.hazelcast.jet.pipeline.StageWithWindow
Attaches a stage that passes through just the items that are distinct within their window (no two items emitted for a window are equal).
distinct(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
DISTRIBUTE_TO_ALL - Static variable in class com.hazelcast.jet.core.Edge
An address returned by Edge.getDistributedTo() denoting an edge that distributes the items among all members.
distributed() - Method in class com.hazelcast.jet.core.Edge
Declares that the edge is distributed.
distributed(int) - Method in class com.hazelcast.jet.pipeline.SourceBuilder.Batch
 
distributed(int) - Method in class com.hazelcast.jet.pipeline.SourceBuilder.Stream
 
distributed(int) - Method in class com.hazelcast.jet.pipeline.SourceBuilder.TimestampedStream
 
DISTRIBUTED_BYTES_IN - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
Tracks the data volume (bytes) coming in over the network for DISTRIBUTED input Edges of particular Vertex instances running on various Processors.
DISTRIBUTED_BYTES_OUT - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
Tracks the data volume (bytes) going out over the network for DISTRIBUTED output Edges of particular Vertex instances running on various Processors.
DISTRIBUTED_ITEMS_IN - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
Counts data items coming in over the network for DISTRIBUTED input Edges of particular Vertex instances running on various Processors.
DISTRIBUTED_ITEMS_OUT - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
Counts data items going out over the network for DISTRIBUTED output Edges of particular Vertex instances running on various Processors.
distributedObject - Variable in class com.hazelcast.core.DistributedObjectEvent
 
DistributedObject - Interface in com.hazelcast.core
Base interface for all distributed objects.
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 Class 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.
distributeTo(Address) - Method in class com.hazelcast.jet.core.Edge
Declares that all items sent over this edge will be delivered to the specified member.
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
 
DOT - Enum constant in enum class com.hazelcast.config.vector.Metric
Dot product
DOUBLE - Enum constant in enum class com.hazelcast.config.properties.PropertyTypeConverter
TypeConverter to convert an input string to an output double
DOUBLE - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
 
DOUBLE - Enum constant in enum class com.hazelcast.sql.SqlColumnType
DOUBLE type, represented by Double
DOUBLE_ARRAY - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
 
DoubleAccumulator - Class in com.hazelcast.jet.accumulator
Accumulator of a double value.
DoubleAccumulator() - Constructor for class com.hazelcast.jet.accumulator.DoubleAccumulator
Creates a new instance with value == 0.
DoubleAccumulator(double) - Constructor for class com.hazelcast.jet.accumulator.DoubleAccumulator
Creates a new instance with the specified value.
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
 
drain(Consumer<E>) - Method in interface com.hazelcast.jet.core.Inbox
Passes each of this object's items to the supplied consumer until it is empty.
DRAIN_TO - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
drainPermits() - Method in interface com.hazelcast.cp.ISemaphore
Acquires and returns all permits that are available at invocation time.
drainQueueAndReset(int, Collection<T>, boolean) - Method in class com.hazelcast.jet.core.test.TestOutbox
Move all items from the queue to the target collection and make the outbox available to accept more items.
drainQueuesAndReset(List<? extends Collection<T>>, boolean) - Method in class com.hazelcast.jet.core.test.TestOutbox
Move all items from all queues (except the snapshot queue) to the target list of collections.
drainSnapshotQueueAndReset(Collection<? super Map.Entry<K, V>>, boolean) - Method in class com.hazelcast.jet.core.test.TestOutbox
Deserialize and move all items from the snapshot queue to the target collection and make the outbox available to accept more items.
drainTo(Collection<E>) - Method in interface com.hazelcast.jet.core.Inbox
Drains all elements into the provided Collection.
drainTo(Collection<E>, int) - Method in interface com.hazelcast.jet.core.Inbox
Drains at most limit elements into the provided Collection.
drainTo(Collection<M>, int, Function<E, M>) - Method in interface com.hazelcast.jet.core.Inbox
Drains and maps at most limit elements into the provided Collection.
dropWhile(Predicate<? super T>) - Method in interface com.hazelcast.jet.Traverser
Returns a traverser that will emit a suffix of the original traverser, starting from the item for which the predicate fails (inclusive).
dueToError() - Method in interface com.hazelcast.jet.core.JobSuspensionCause
True if Jet suspended the job because it encountered an error during execution.
DuplicateTaskException - Exception in com.hazelcast.scheduledexecutor
An exception thrown when a task's name is already used before for another (or the same, if re-attempted) schedule.
DuplicateTaskException(String) - Constructor for exception com.hazelcast.scheduledexecutor.DuplicateTaskException
 
DURABLE_EXECUTOR_SERVICE - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
Durable Executor Service
DurableExecutorConfig - Class in com.hazelcast.config
Contains the configuration for an DurableExecutorService.
DurableExecutorConfig() - Constructor for class com.hazelcast.config.DurableExecutorConfig
 
DurableExecutorConfig(DurableExecutorConfig) - Constructor for class com.hazelcast.config.DurableExecutorConfig
 
DurableExecutorConfig(String) - Constructor for class com.hazelcast.config.DurableExecutorConfig
 
DurableExecutorConfig(String, int, int, int, boolean, String) - Constructor for class com.hazelcast.config.DurableExecutorConfig
 
DurableExecutorConfig(String, int, int, int, String, boolean, String) - 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
 
DynamicConfigurationConfig - Class in com.hazelcast.config
Dynamic Configuration related configuration options.
DynamicConfigurationConfig() - Constructor for class com.hazelcast.config.DynamicConfigurationConfig
 

E

EAGER - Enum constant in enum class com.hazelcast.config.MapStoreConfig.InitialLoadMode
getMap() method does not return till the map is completely loaded.
earlyResultsPeriod() - Method in class com.hazelcast.jet.pipeline.WindowDefinition
Returns the early results period for this window definition.
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
 
edge(Edge) - Method in class com.hazelcast.jet.core.DAG
Adds an edge to this DAG.
Edge - Class in com.hazelcast.jet.core
Represents an edge between two vertices in a DAG.
Edge() - Constructor for class com.hazelcast.jet.core.Edge
 
Edge(Vertex, int, Vertex, int) - Constructor for class com.hazelcast.jet.core.Edge
 
EDGE - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
 
EDGE_CONFIG - Static variable in class com.hazelcast.jet.config.JetConfigDataSerializerHook
Serialization ID of the EdgeConfig class.
EDGE_KEY_PARTITIONER - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
 
EDGE_SINGLE_PARTITIONER - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
 
Edge.RoutingPolicy - Enum Class in com.hazelcast.jet.core
An edge describes a connection from many upstream processors to many downstream processors.
EdgeConfig - Class in com.hazelcast.jet.config
A configuration object for a DAG Edge that holds fine-tuning parameters that influence its performance characteristics.
EdgeConfig() - Constructor for class com.hazelcast.jet.config.EdgeConfig
 
edgeIterator() - Method in class com.hazelcast.jet.core.DAG
Returns an iterator over the DAG's edges in unspecified order.
elastic() - Static method in class com.hazelcast.jet.elastic.ElasticSources
Creates a source which queries local instance of Elasticsearch for all documents
elastic(FunctionEx<? super SearchHit, T>) - Static method in class com.hazelcast.jet.elastic.ElasticSources
Creates a source which queries local instance of Elasticsearch for all documents.
elastic(FunctionEx<? super T, ? extends DocWriteRequest<?>>) - Static method in class com.hazelcast.jet.elastic.ElasticSinks
Creates an Elasticsearch sink, uses a local instance of Elasticsearch
elastic(SupplierEx<RestClientBuilder>) - Static method in class com.hazelcast.jet.elastic.ElasticSources
Creates a source which queries Elasticsearch using client obtained from RestClientBuilder supplier function.
elastic(SupplierEx<RestClientBuilder>, FunctionEx<? super SearchHit, T>) - Static method in class com.hazelcast.jet.elastic.ElasticSources
Creates a source which queries Elasticsearch using client obtained from RestClientBuilder supplier function.
elastic(SupplierEx<RestClientBuilder>, FunctionEx<? super T, ? extends DocWriteRequest<?>>) - Static method in class com.hazelcast.jet.elastic.ElasticSinks
Creates an Elasticsearch sink, uses a client obtained from clientFn and maps items using given mapToRequestFn
elastic(SupplierEx<RestClientBuilder>, SupplierEx<SearchRequest>, FunctionEx<? super SearchHit, T>) - Static method in class com.hazelcast.jet.elastic.ElasticSources
Creates a source which queries Elasticsearch using client obtained from RestHighLevelClient supplier.
ElasticClients - Class in com.hazelcast.jet.elastic
Collection of convenience factory methods for Elastic's RestClientBuilder
ElasticSinkBuilder<T> - Class in com.hazelcast.jet.elastic
Builder for Elasticsearch Sink
ElasticSinkBuilder() - Constructor for class com.hazelcast.jet.elastic.ElasticSinkBuilder
 
ElasticSinks - Class in com.hazelcast.jet.elastic
Provides factory methods for Elasticsearch sinks.
ElasticSourceBuilder<T> - Class in com.hazelcast.jet.elastic
Builder for Elasticsearch source which reads data from Elasticsearch and converts SearchHits using provided mapToItemFn
ElasticSourceBuilder() - Constructor for class com.hazelcast.jet.elastic.ElasticSourceBuilder
 
ElasticSources - Class in com.hazelcast.jet.elastic
Provides factory methods for Elasticsearch sources.
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
 
EMBEDDED - Enum constant in enum class com.hazelcast.config.InstanceTrackingConfig.InstanceMode
This instance is embedded in another Java program.
emitFromTraverser(int[], Traverser<E>) - Method in class com.hazelcast.jet.core.AbstractProcessor
Obtains items from the traverser and offers them to the outbox's buckets identified in the supplied array.
emitFromTraverser(int, Traverser<E>) - Method in class com.hazelcast.jet.core.AbstractProcessor
Obtains items from the traverser and offers them to the outbox's buckets identified in the supplied array.
emitFromTraverser(Traverser<?>) - Method in class com.hazelcast.jet.core.AbstractProcessor
Convenience for AbstractProcessor.emitFromTraverser(int, Traverser) which emits to all ordinals.
emitFromTraverserToSnapshot(Traverser<T>) - Method in class com.hazelcast.jet.core.AbstractProcessor
Obtains items from the traverser and offers them to the snapshot bucket of the outbox.
EMITTED_COUNT - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
Counts the data items emitted on outgoing Edges of particular Vertex instances running on various Processors.
empty() - Static method in class com.hazelcast.jet.core.metrics.JobMetrics
Returns an empty JobMetrics object.
empty() - Static method in class com.hazelcast.jet.Traversers
Returns a traverser that always returns null.
EMPTY - Static variable in class com.hazelcast.cp.CPGroupsSnapshot
An empty snapshot for use when there is no data to provide
EMPTY_EXECUTOR_NAME - Static variable in class com.hazelcast.security.permission.ExecutorServicePermission
The name of the executor used when no such executor is found for the client invocations.
ENABLE_JMX - Static variable in class com.hazelcast.spi.properties.ClusterProperty
Enable JMX agent.
ENABLE_MANAGEMENT - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
enableAllGroups() - Method in class com.hazelcast.config.RestApiConfig
Deprecated.
Enables all REST endpoint groups.
enableAllGroups() - Method in class com.hazelcast.config.RestServerEndpointConfig
Deprecated.
Enables all REST endpoint groups.
enableCoLocatedReading() - Method in class com.hazelcast.jet.elastic.ElasticSourceBuilder
Enable co-located reading Jet cluster member must run exactly on the same nodes as Elastic cluster.
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
Deprecated.
Enables provided REST endpoint groups.
enableGroups(RestEndpointGroup...) - Method in class com.hazelcast.config.RestServerEndpointConfig
Deprecated.
Enables provided REST endpoint groups.
enableReentrancy() - Method in class com.hazelcast.config.cp.FencedLockConfig
Enables reentrancy.
enableSlicing() - Method in class com.hazelcast.jet.elastic.ElasticSourceBuilder
Enable slicing
encode(byte[]) - Method in enum class com.hazelcast.config.security.TokenEncoding
 
encrypt(String...) - Static method in class com.hazelcast.config.replacer.EncryptionReplacer
 
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).
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
 
end() - Method in class com.hazelcast.jet.datamodel.WindowResult
Returns the ending timestamp of the window.
END_ENTRYVIEW_ITERATION - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
endpoint() - Method in interface com.hazelcast.cp.session.CPSession
Returns the endpoint that has created this session
Endpoint - Interface in com.hazelcast.cluster
Endpoint represents a peer in the cluster.
EndpointConfig - Class in com.hazelcast.config
Endpoint configuration that defines communication/networking properties common to both incoming/outgoing connections e.g.
EndpointConfig() - Constructor for class com.hazelcast.config.EndpointConfig
 
endpointConfigElementName(EndpointConfig) - Static method in class com.hazelcast.config.ConfigXmlGenerator
 
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 Enterprise license key.
entry(K, V) - Static method in class com.hazelcast.jet.Util
Returns a Serializable Map.Entry with nullable key and value.
ENTRY_COUNT - Enum constant in enum class com.hazelcast.config.MaxSizePolicy
Policy based on maximum number of entries stored per data structure (map, cache etc.)
ENTRY_SET - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
 
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 Class 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 size-based-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
Invoked upon expiration-based removal of an entry.
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(EntryListenerConfig) - Constructor for class com.hazelcast.config.EntryListenerConfig
 
EntryListenerConfig(MapListener, boolean, boolean) - Constructor for class com.hazelcast.config.EntryListenerConfig
 
EntryListenerConfig(String, boolean, boolean) - 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() - 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.
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(Predicate<K, V>) - Method in interface com.hazelcast.map.QueryCache
 
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.
ENUM - Enum constant in enum class com.hazelcast.jet.core.metrics.Unit
0..n, ordinal of an enum
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.ClientSqlConfig
 
equals(Object) - Method in class com.hazelcast.client.config.ClientTpcConfig
 
equals(Object) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
Deprecated.
 
equals(Object) - Method in class com.hazelcast.client.config.ClusterRoutingConfig
 
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.AbstractBaseFactoryWithPropertiesConfig
 
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.AdvancedNetworkConfig
 
equals(Object) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
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.AutoDetectionConfig
 
equals(Object) - Method in class com.hazelcast.config.BitmapIndexOptions
 
equals(Object) - Method in class com.hazelcast.config.BTreeIndexConfig
 
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.CompactSerializationConfig
 
equals(Object) - Method in class com.hazelcast.config.cp.CPMapConfig
 
equals(Object) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
 
equals(Object) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
equals(Object) - Method in class com.hazelcast.config.CRDTReplicationConfig
 
equals(Object) - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
equals(Object) - Method in class com.hazelcast.config.DataConnectionConfig
 
equals(Object) - Method in class com.hazelcast.config.DataPersistenceConfig
 
equals(Object) - Method in class com.hazelcast.config.DiscoveryConfig
 
equals(Object) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
equals(Object) - Method in class com.hazelcast.config.DiskTierConfig
 
equals(Object) - Method in class com.hazelcast.config.DurableExecutorConfig
 
equals(Object) - Method in class com.hazelcast.config.DynamicConfigurationConfig
 
equals(Object) - Method in class com.hazelcast.config.EncryptionAtRestConfig
 
equals(Object) - Method in class com.hazelcast.config.EndpointConfig
 
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
Deprecated.
 
equals(Object) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Deprecated.
 
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.JoinConfig
 
equals(Object) - Method in class com.hazelcast.config.ListenerConfig
 
equals(Object) - Method in class com.hazelcast.config.LocalDeviceConfig
 
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.MemberAttributeConfig
 
equals(Object) - Method in class com.hazelcast.config.MemberGroupConfig
 
equals(Object) - Method in class com.hazelcast.config.MemcacheProtocolConfig
 
equals(Object) - Method in class com.hazelcast.config.MemoryTierConfig
 
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.NetworkConfig
 
equals(Object) - Method in class com.hazelcast.config.PartitionGroupConfig
 
equals(Object) - Method in class com.hazelcast.config.PartitioningAttributeConfig
 
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.PersistenceConfig
 
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.RestApiConfig
Deprecated.
 
equals(Object) - Method in class com.hazelcast.config.RestServerEndpointConfig
Deprecated.
 
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.