Index
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 aILogger
instance. - AbstractDiscoveryStrategy(ILogger, Map<String, Comparable>) - Constructor for class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
- AbstractFactoryWithPropertiesConfig<T extends AbstractFactoryWithPropertiesConfig<T>> - Class in com.hazelcast.config
-
Configuration base for config types with a factory class and its properties.
- AbstractFactoryWithPropertiesConfig() - Constructor for class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
- AbstractHazelcastBeanDefinitionParser - Class in com.hazelcast.spring
-
Base class of all Hazelcast BeanDefinitionParser implementations.
- AbstractHazelcastBeanDefinitionParser() - Constructor for class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser
- AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper - Class in com.hazelcast.spring
-
Base Helper class for Spring Xml Builder
- AbstractIMapEvent - Class in com.hazelcast.map
-
The abstract class for a map event
IMapEvent
. - AbstractIMapEvent(Object, Member, int) - Constructor for class com.hazelcast.map.AbstractIMapEvent
-
Constructs a prototypical map Event.
- AbstractLogger - Class in com.hazelcast.logging
-
Abstract
ILogger
implementation that provides implementations for convenience methods like finest, info, warning and severe. - AbstractLogger() - Constructor for class com.hazelcast.logging.AbstractLogger
- AbstractPbeReplacer - Class in com.hazelcast.config.replacer
-
The common parent for
ConfigReplacer
implementations which allow to mask values by encrypting the value. - AbstractPbeReplacer() - Constructor for class com.hazelcast.config.replacer.AbstractPbeReplacer
- 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(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
-
Adds
CacheSimpleEntryListenerConfig
to thisICache
. - 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 thisQueryCacheConfig
. - 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
- 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. as absolute path, 2. as URL, 3. and in classpath.
- 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
-
Adds a
MemberGroupConfig
. - 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 existingUserCodeNamespaceConfig
with the samename
. - addNamespaceConfigLocally(UserCodeNamespaceConfig) - Method in class com.hazelcast.config.UserCodeNamespacesConfig
-
Adds the specified
namespaceConfig
, replacing any existingUserCodeNamespaceConfig
with the samename
. - 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 thisObservable
. - 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 thisMapConfig
. - 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.
- 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
-
Adds the topic configuration.
- 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. source IP address or expression).
- 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
andstage2
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
andstage2
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
andstage2
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
andstage2
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
andstage2
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 aTuple2(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 aTuple3(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
-
Convenience for
AggregateOperations.allOf(AggregateOperation1, AggregateOperation1, AggregateOperation1, TriFunction)
wrapping the three results in aTuple3
. - 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
-
Convenience for
AggregateOperations.allOf(AggregateOperation1, AggregateOperation1, BiFunctionEx)
wrapping the two results in aTuple2
. - 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 givenkey
. - 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
-
Serializable
variant ofjava.util.function.BiPredicate#and(BiPredicate)
. - and(PredicateEx<? super T>) - Method in interface com.hazelcast.function.PredicateEx
-
Serializable
variant ofjava.util.function.Predicate#and(Predicate)
. - 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
- andExportFinish(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity2
- andExportFinish(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity3
- andExportFinish(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.VarArity
- 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
-
Serializable
variant ofjava.util.function.BiConsumer#andThen(BiConsumer)
. - andThen(ConsumerEx<? super T>) - Method in interface com.hazelcast.function.ConsumerEx
-
Serializable
variant ofjava.util.function.Consumer#andThen(Consumer)
. - 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
andfinish
primitives composed with the suppliedthenFn
. - 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
-
Serializable
variant ofjava.util.function.BiFunction#andThen(Function)
. - andThen(FunctionEx<? super R, ? extends V>) - Method in interface com.hazelcast.function.FunctionEx
-
Serializable
variant ofjava.util.function.Function#andThen(Function)
. - andThen(FunctionEx<? super T, ? extends V>) - Method in interface com.hazelcast.function.SupplierEx
-
Serializable
analogue ofjava.util.function.Function#andThen(Function)
. - 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 providedtransformFn
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 providedtransformFn
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
- 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
-
See
JetService.newLightJob(Pipeline, JobConfig)
for details. - 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, anAssertionError
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
-
Controls how
ClusterProperty.WAIT_SECONDS_BEFORE_JOIN
andClusterProperty.MAX_WAIT_SECONDS_BEFORE_JOIN
behave. - 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 withCPSubsystem.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 withCPSubsystem.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 andattachFile(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. credentials from client is not valid. - 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 aAutoDisposableTask
to destroy automatically after execution - autoDisposable(Callable<V>) - Static method in class com.hazelcast.scheduledexecutor.TaskUtils
-
Decorate any
Callable
with aAutoDisposableTask
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.
- 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.
- BACKUP_OPERATIONS_SHOULD_NOTIMPL_MUTATINGOPERATION - Static variable in class com.hazelcast.test.archunit.ArchUnitRules
-
Backup operations should not implement
MutatingOperation
interface, otherwise there may be failures to apply backups. - 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 aCache
. - BackupOperationShouldNotImplementMutatingOperation - Class in com.hazelcast.test.archunit
- 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 givenprojection
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 givenprojection
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 givenreader
. - 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 ofjava.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
-
Creates a
ServiceFactory
that calls out to a bidirectional streaming gRPC service. - BiFunctionEx<T,
U, R> - Interface in com.hazelcast.function -
Serializable
variant ofjava.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 ofjava.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 withJdbcSinkBuilder.updateQuery(String)
. - BiPredicateEx<T,
U> - Interface in com.hazelcast.function -
Serializable
variant ofjava.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 getJetService
from the createdHazelcastInstance
by usingHazelcastInstance.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 givencomparator
. - 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
-
Convenience for
AvroSourceBuilder.build(BiFunctionEx)
. - 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
-
Convenience for
JmsSourceBuilder.build(FunctionEx)
. - 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
-
Creates
SearchOptions
- 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 functionmapOutputFn
. - 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 functionprojectionFn
. - 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 withmapToOutputFn
. - 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
-
Convenience for
FileSourceBuilder.buildWatcher(BiFunctionEx)
. - 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.Entry
s it receives into a HazelcastICache
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 asMap.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 aMap.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 - cacheJournal(String, JournalInitialPosition) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Convenience for
Sources.cacheJournal(String, JournalInitialPosition, FunctionEx, PredicateEx)
which will pass onlyCREATED
andUPDATED
events and will project the event's key and new value into aMap.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 HazelcastICache
with the specified name. - cacheLoaderFactory - Variable in class com.hazelcast.config.AbstractCacheConfig
-
The
Factory
for theCacheLoader
. - 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
-
Returns a predicate for
Sources.cacheJournal(java.lang.String, com.hazelcast.jet.pipeline.JournalInitialPosition, com.hazelcast.function.FunctionEx<? super com.hazelcast.cache.EventJournalCacheEvent<K, V>, ? extends T>, com.hazelcast.function.PredicateEx<? super com.hazelcast.cache.EventJournalCacheEvent<K, V>>)
andSources.remoteCacheJournal(java.lang.String, com.hazelcast.client.config.ClientConfig, com.hazelcast.jet.pipeline.JournalInitialPosition, com.hazelcast.function.FunctionEx<? super com.hazelcast.cache.EventJournalCacheEvent<K, V>, ? extends T>, com.hazelcast.function.PredicateEx<? super com.hazelcast.cache.EventJournalCacheEvent<K, V>>)
that passes onlyCREATED
andUPDATED
events. - 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 theCacheWriter
. - 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
- 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 (seeRaftAlgorithmConfig.getUncommittedEntryCountToRejectNewAppends()
) a membership change is requested before an entry is committed on a term - CannotReplicateException(RaftEndpoint) - Constructor for exception com.hazelcast.cp.exception.CannotReplicateException
- 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.BackupOperationShouldNotImplementMutatingOperation
- check(JavaClass, ConditionEvents) - Method in class com.hazelcast.test.archunit.CompletableFutureUsageCondition
- check(JavaClass, ConditionEvents) - Method in class com.hazelcast.test.archunit.ConfigClassesExposingInternalImplementationCondition
- 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.OperationShouldNotImplementReadonlyAndMutatingOperation
- 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. maximal length of authentication message).
- 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-inConfigRecognizer
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 incustomRecognizers
. - 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.
- 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-inConfigRecognizer
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 incustomRecognizers
. - ClientFlakeIdGeneratorConfig - Class in com.hazelcast.client.config
-
The
ClientFlakeIdGeneratorConfig
contains the configuration for the client regardingFlake 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
Client
s and attach/detachClientListener
s 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
- 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 theProcessor.close()
method of this processor is cooperative. - closeIsCooperative() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Returns
true
if theProcessorMetaSupplier.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 theProcessorSupplier.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
- 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.cache - package com.hazelcast.cache
-
This package contains the public API extension for Hazelcast JCache, the Hazelcast implementation of the JSR-107 commonly referred to as JCache.
- com.hazelcast.cardinality - package com.hazelcast.cardinality
-
This package contains Cardinality Estimator functionality for Hazelcast.
- com.hazelcast.client - package com.hazelcast.client
-
Contains classes/interfaces related to Client
- com.hazelcast.client.cache - package com.hazelcast.client.cache
-
Public API of client-side CachingProvider
- com.hazelcast.client.config - package com.hazelcast.client.config
-
Contains classes related to config for com.hazelcast.client
- com.hazelcast.client.properties - package com.hazelcast.client.properties
-
Contains the Hazelcast client properties implementation.
- com.hazelcast.cluster - package com.hazelcast.cluster
-
This package contains the cluster functionality.
- com.hazelcast.cluster.memberselector - package com.hazelcast.cluster.memberselector
-
This package contains several
MemberSelector
implementations. - com.hazelcast.collection - package com.hazelcast.collection
-
This package contains classes to support the collection API.
- com.hazelcast.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 theExecutorService
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 ofPipeline
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 specifiedwindowWatermarkKey
. - 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
inCompact
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 ofjava.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
tonewValue
if the current value forkey
is equal-toexpectedValue
. - 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
-
Serializable
variant ofjava.util.Comparator#comparing(Function)
. - comparing(FunctionEx<? super T, ? extends U>, ComparatorEx<? super U>) - Static method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#comparing(Function, Comparator)
. - comparing(Function<? super T, ? extends U>) - Static method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#comparing(Function)
. - comparing(Function<? super T, ? extends U>, Comparator<? super U>) - Static method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#comparing(Function, Comparator)
. - comparingDouble(ToDoubleFunctionEx<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#comparingDouble(ToDoubleFunction)
. - comparingDouble(ToDoubleFunction<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#comparingDouble(ToDoubleFunction)
. - comparingInt(ToIntFunctionEx<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#comparingInt(ToIntFunction)
. - comparingInt(ToIntFunction<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#comparingInt(ToIntFunction)
. - comparingLong(ToLongFunctionEx<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#comparingLong(ToLongFunction)
. - comparingLong(ToLongFunction<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#comparingLong(ToLongFunction)
. - 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
-
Serializable
variant ofjava.util.function.Function#compose(Function)
. - 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
- CONFIG_CLASSES_EXPOSING_INTERNAL_IMPLEMENTATION - Static variable in class com.hazelcast.test.archunit.ArchUnitRules
- 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.
- ConfigClassesExposingInternalImplementationCondition - Class in com.hazelcast.test.archunit
-
Asserts that config classes don't expose internal classes (i.e. those in an "impl" package)
- ConfigClassesExposingInternalImplementationCondition() - Constructor for class com.hazelcast.test.archunit.ConfigClassesExposingInternalImplementationCondition
- ConfigFactory - Class in com.hazelcast.spring.config
-
Provides factory methods for
Config
andClientConfig
. - 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 theConfigRecognizer
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
-
Configures
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
- ConnectorNames - Class in com.hazelcast.jet.pipeline
-
Includes builtin connector names for phone home purposes.
- 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 ofjava.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
intoEventType
. - 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
RecordReader
s return the same key/value instances for each record, for exampleLineRecordReader
. - 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 withCPSubsystem.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 withCPSubsystem.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
- CPGroupDestroyedException(String) - 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 givenname
and the default map capacity ofCPMapConfig.DEFAULT_MAX_SIZE_MB
. - CPMapConfig(String, int) - Constructor for class com.hazelcast.config.cp.CPMapConfig
-
Creates a configuration for a
CPMap
with the givenname
and maximum capacity in MB as specified bymaxSizeMb
. - 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 - 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.
- 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
Processor
s. - 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
Processor
s. - 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
Processor
s. - 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
Processor
s. - 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
Processor
s. - 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
Processor
s. - 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
- 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 theDataSource
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
DataConnection
s in processors. - dataConnectionService() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
- DataConnectionService - Interface in com.hazelcast.dataconnection
-
The interface provides access to
DataConnection
s 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
orXADataSource
. - 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 value for
FlakeIdGeneratorConfig.getAllowedFutureMillis()
. - 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.config.vector.VectorCollectionConfig
-
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 value for
FlakeIdGeneratorConfig.getBitsNodeId()
. - DEFAULT_BITS_SEQUENCE - Static variable in class com.hazelcast.config.FlakeIdGeneratorConfig
-
Default value for
FlakeIdGeneratorConfig.getBitsSequence()
. - 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_EF_CONSTRUCTION - Static variable in class com.hazelcast.config.vector.VectorIndexConfig
-
Default efConstruction value
- 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 value for
FlakeIdGeneratorConfig.getEpochStart()
. - 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
. 0 means there is no upper bound for number of reentrant lock acquires. - 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_DEGREE - Static variable in class com.hazelcast.config.vector.VectorIndexConfig
-
Default max degree value
- 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 value for
FlakeIdGeneratorConfig.getPrefetchCount()
. - DEFAULT_PREFETCH_VALIDITY_MILLIS - Static variable in class com.hazelcast.config.FlakeIdGeneratorConfig
-
Default value for
FlakeIdGeneratorConfig.getPrefetchValidityMillis()
. - 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
-
The default
receive window multiplier
. - 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_DEDUPLICATION - Static variable in class com.hazelcast.config.vector.VectorIndexConfig
-
Default value of whether deduplication is enabled
- 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 theDefaultLoginModule
. - 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 implementsPartitionAware
. - 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 onCompletionStage.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
- 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
-
Destroys
ICredentialsFactory
. - destroy() - Method in interface com.hazelcast.security.IPermissionPolicy
-
Destroys
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 aBidirectionalStreamingService
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()
andcomplete()
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 theDiscoveryStrategy
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 buildDiscoveryService
s. - DiscoveryServiceSettings - Class in com.hazelcast.spi.discovery.integration
-
The
DiscoveryServiceSettings
class is used to pass the necessary configuration to create aDiscoveryService
to theDiscoveryServiceProvider
. - 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
andhashCode
). - 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
- DISTRIBUTED_BYTES_OUT - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
- DISTRIBUTED_ITEMS_IN - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
- DISTRIBUTED_ITEMS_OUT - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
- 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 aDistributedObject
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. enforcing invariants).
- 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 providedCollection
. - drainTo(Collection<M>, int, Function<E, M>) - Method in interface com.hazelcast.jet.core.Inbox
-
Drains and maps at most
limit
elements into the providedCollection
. - 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
- 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.
- 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
- 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
- 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<Object, Object>) - 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<Object, Object>) - 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<Object, Object>) - 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<Object, Object>) - 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 itemattribute
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.KerberosIdentityConfig
- equals(Object) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- equals(Object) - Method in class com.hazelcast.config.security.RealmConfig
- equals(Object) - Method in class com.hazelcast.config.security.SimpleAuthenticationConfig
- equals(Object) - Method in class com.hazelcast.config.security.SimpleAuthenticationConfig.UserDto
- equals(Object) - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
- equals(Object) - Method in class com.hazelcast.config.security.TokenIdentityConfig
- equals(Object) - Method in class com.hazelcast.config.security.UsernamePasswordIdentityConfig
- equals(Object) - Method in class com.hazelcast.config.SecurityConfig
- equals(Object) - Method in class com.hazelcast.config.SerializationConfig
- equals(Object) - Method in class com.hazelcast.config.SerializerConfig
- equals(Object) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
- equals(Object) - Method in class com.hazelcast.config.ServiceConfig
- equals(Object) - Method in class com.hazelcast.config.SocketInterceptorConfig
- equals(Object) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
- equals(Object) - Method in class com.hazelcast.config.SqlConfig
- equals(Object) - Method in class com.hazelcast.config.SSLConfig
- equals(Object) - Method in class com.hazelcast.config.TcpIpConfig
- equals(Object) - Method in class com.hazelcast.config.TieredStoreConfig
- equals(Object) - Method in class com.hazelcast.config.TopicConfig
- equals(Object) - Method in class com.hazelcast.config.tpc.TpcConfig
- equals(Object) - Method in class com.hazelcast.config.tpc.TpcSocketConfig
- equals(Object) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Deprecated.
- equals(Object) - Method in class com.hazelcast.config.UserCodeNamespaceConfig
- equals(Object) - Method in class com.hazelcast.config.UserCodeNamespacesConfig
- equals(Object) - Method in class com.hazelcast.config.VaultSecureStoreConfig
- equals(Object) - Method in class com.hazelcast.config.vector.VectorCollectionConfig
- equals(Object) - Method in class com.hazelcast.config.vector.VectorIndexConfig
- equals(Object) - Method in class com.hazelcast.config.WanConsumerConfig
- equals(Object) - Method in class com.hazelcast.config.WanReplicationConfig
- equals(Object) - Method in class com.hazelcast.config.WanReplicationRef
- equals(Object) - Method in class com.hazelcast.config.WanSyncConfig
- equals(Object) - Method in class com.hazelcast.core.HazelcastJsonValue
- equals(Object) - Method in class com.hazelcast.core.LifecycleEvent
- equals(Object) - Method in class com.hazelcast.cp.CPGroupsSnapshot
- equals(Object) - Method in record class com.hazelcast.cp.CPGroupsSnapshot.GroupInfo
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class com.hazelcast.dataconnection.DataConnectionResource
- equals(Object) - Method in class com.hazelcast.jet.accumulator.DoubleAccumulator
- equals(Object) - Method in class com.hazelcast.jet.accumulator.LinTrendAccumulator
- equals(Object) - Method in class com.hazelcast.jet.accumulator.LongAccumulator
- equals(Object) - Method in class com.hazelcast.jet.accumulator.LongDoubleAccumulator
- equals(Object) - Method in class com.hazelcast.jet.accumulator.LongLongAccumulator
- equals(Object) - Method in class com.hazelcast.jet.accumulator.MutableReference
- equals(Object) - Method in class com.hazelcast.jet.accumulator.PickAnyAccumulator
- equals(Object) - Method in class com.hazelcast.jet.config.DeltaJobConfig
- equals(Object) - Method in class com.hazelcast.jet.config.EdgeConfig
- equals(Object) - Method in class com.hazelcast.jet.config.InstanceConfig
-
Deprecated.
- equals(Object) - Method in class com.hazelcast.jet.config.JetConfig
- equals(Object) - Method in class com.hazelcast.jet.config.JobConfig
- equals(Object) - Method in class com.hazelcast.jet.config.ResourceConfig
- equals(Object) - Method in class com.hazelcast.jet.core.BroadcastKey
- equals(Object) - Method in class com.hazelcast.jet.core.Edge
- equals(Object) - Method in class com.hazelcast.jet.core.metrics.JobMetrics
- equals(Object) - Method in class com.hazelcast.jet.core.metrics.Measurement
- equals(Object) - Method in class com.hazelcast.jet.core.Watermark
- equals(Object) - Method in class com.hazelcast.jet.datamodel.ItemsByTag
- equals(Object) - Method in class com.hazelcast.jet.datamodel.KeyedWindowResult
- equals(Object) - Method in class com.hazelcast.jet.datamodel.Tag
- equals(Object) - Method in class com.hazelcast.jet.datamodel.TimestampedItem
- equals(Object) - Method in class com.hazelcast.jet.datamodel.Tuple2
- equals(Object) - Method in class com.hazelcast.jet.datamodel.Tuple3
- equals(Object) - Method in class com.hazelcast.jet.datamodel.Tuple4
- equals(Object) - Method in class com.hazelcast.jet.datamodel.Tuple5
- equals(Object) - Method in class com.hazelcast.jet.datamodel.WindowResult
- equals(Object) - Method in class com.hazelcast.jet.pipeline.file.AvroFileFormat
- equals(Object) - Method in class com.hazelcast.jet.pipeline.file.CsvFileFormat
- equals(Object) - Method in class com.hazelcast.jet.pipeline.file.JsonFileFormat
- equals(Object) - Method in class com.hazelcast.jet.pipeline.file.LinesTextFileFormat
- equals(Object) - Method in class com.hazelcast.jet.pipeline.file.ParquetFileFormat
- equals(Object) - Method in class com.hazelcast.jet.pipeline.file.RawBytesFileFormat
- equals(Object) - Method in class com.hazelcast.jet.pipeline.file.TextFileFormat
- equals(Object) - Method in class com.hazelcast.jet.pipeline.test.SimpleEvent
- equals(Object) - Method in class com.hazelcast.memory.Capacity
- equals(Object) - Method in class com.hazelcast.nio.serialization.PortableId
-
Deprecated.
- equals(Object) - Method in class com.hazelcast.partition.PartitionAwareKey
- equals(Object) - Method in class com.hazelcast.persistence.BackupTaskStatus
- equals(Object) - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
- equals(Object) - Method in class com.hazelcast.security.permission.AllPermissions
- equals(Object) - Method in class com.hazelcast.security.permission.ClusterPermission
- equals(Object) - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
- equals(Object) - Method in class com.hazelcast.security.permission.InstancePermission
- equals(Object) - Method in class com.hazelcast.security.SimpleTokenCredentials
- equals(Object) - Method in class com.hazelcast.security.UsernamePasswordCredentials
- equals(Object) - Method in class com.hazelcast.sql.SqlColumnMetadata
- equals(Object) - Method in class com.hazelcast.sql.SqlRowMetadata
- equals(Object) - Method in class com.hazelcast.sql.SqlStatement
- equals(Object) - Method in record class com.hazelcast.vector.Hint
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class com.hazelcast.version.MemberVersion
- equals(Object) - Method in class com.hazelcast.version.Version
- ERROR - Enum constant in enum class com.hazelcast.auditlog.Level
-
Error level.
- ERROR - Enum constant in enum class com.hazelcast.topic.TopicOverloadPolicy
-
The publish call immediately fails.
- errorCause() - Method in interface com.hazelcast.jet.core.JobSuspensionCause
-
Describes the error that has led to the suspension of the job.
- estimate() - Method in interface com.hazelcast.cardinality.CardinalityEstimator
-
Estimates the cardinality of the aggregation so far.
- ESTIMATE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- estimateAsync() - Method in interface com.hazelcast.cardinality.CardinalityEstimator
-
Estimates the cardinality of the aggregation so far.
- ETERNAL - Enum constant in enum class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
-
Expiry policy type for the
EternalExpiryPolicy
. - ETERNAL - Enum constant in enum class com.hazelcast.config.UserCodeDeploymentConfig.ClassCacheMode
-
Deprecated.Cache indefinitely.
- EUCLIDEAN - Enum constant in enum class com.hazelcast.config.vector.Metric
-
Euclidean distance
- EurekaConfig - Class in com.hazelcast.config
-
Configuration for the Eureka Discovery Strategy.
- EurekaConfig() - Constructor for class com.hazelcast.config.EurekaConfig
- EurekaConfig(EurekaConfig) - Constructor for class com.hazelcast.config.EurekaConfig
- EurekaConfig(String, boolean, boolean, Map<String, String>) - Constructor for class com.hazelcast.config.EurekaConfig
- EVENT - Enum constant in enum class com.hazelcast.jet.core.TimestampKind
-
Denotes the event timestamp kind.
- EVENT_QUEUE_CAPACITY - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Capacity of the executor that handles the incoming event packets.
- EVENT_QUEUE_CAPACITY - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The capacity of the
EventServiceImpl
executor. - EVENT_QUEUE_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The timeout for offering an event to the event executor for processing.
- EVENT_SYNC_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
To prevent overloading of the outbound connections, once in a while an event is made synchronous by wrapping it in a fake operation and waiting for a fake response.
- EVENT_THREAD_COUNT - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Number of the threads to handle the incoming event packets.
- EVENT_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Number of threads for the
EventServiceImpl
executor. - EVENT_TYPE - Static variable in class com.hazelcast.map.EventLostEvent
-
Event type ID.
- eventBuilder(String) - Method in interface com.hazelcast.auditlog.AuditlogService
-
Returns an instance of the
EventBuilder
interface. - EventBuilder<T extends EventBuilder<T>> - Interface in com.hazelcast.auditlog
-
Builder interface for
AuditableEvent
instances. - EventJournalCacheEvent<K,
V> - Interface in com.hazelcast.cache -
The event for the cache event journal.
- eventJournalConfig - Variable in class com.hazelcast.config.AbstractCacheConfig
- EventJournalConfig - Class in com.hazelcast.config
-
Configuration for an event journal.
- EventJournalConfig() - Constructor for class com.hazelcast.config.EventJournalConfig
- EventJournalConfig(EventJournalConfig) - Constructor for class com.hazelcast.config.EventJournalConfig
-
Clones a
EventJournalConfig
. - EventJournalMapEvent<K,
V> - Interface in com.hazelcast.map -
The event for the map event journal.
- eventLost(EventLostEvent) - Method in interface com.hazelcast.map.listener.EventLostListener
-
Invoked upon lost of event or events.
- EventLostEvent - Class in com.hazelcast.map
-
This event is fired in case of an event lost detection.
- EventLostEvent(String, Member, int) - Constructor for class com.hazelcast.map.EventLostEvent
- EventLostListener - Interface in com.hazelcast.map.listener
-
Invoked upon lost of event or events.
- EventTimeMapper<T> - Class in com.hazelcast.jet.core
-
A utility that helps a source emit events according to a given
EventTimePolicy
. - EventTimeMapper(EventTimePolicy<? super T>) - Constructor for class com.hazelcast.jet.core.EventTimeMapper
-
The partition count is initially set to 0, call
EventTimeMapper.addPartitions(int)
to add partitions. - eventTimePolicy(ToLongFunctionEx<? super T>, SupplierEx<? extends WatermarkPolicy>, long, long, long) - Static method in class com.hazelcast.jet.core.EventTimePolicy
-
Creates and returns a new event time policy.
- eventTimePolicy(ToLongFunctionEx<? super T>, ObjLongBiFunction<? super T, ?>, SupplierEx<? extends WatermarkPolicy>, long, long, long) - Static method in class com.hazelcast.jet.core.EventTimePolicy
-
Creates and returns a new event time policy.
- eventTimePolicy(ToLongFunctionEx<? super T>, ObjLongBiFunction<? super T, ?>, SupplierEx<? extends WatermarkPolicy>, long, long, long, byte) - Static method in class com.hazelcast.jet.core.EventTimePolicy
-
Creates and returns a new event time policy.
- EventTimePolicy<T> - Class in com.hazelcast.jet.core
-
A holder of functions and parameters Jet needs to handle event time and the associated watermarks.
- evict(Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
- evict(K) - Method in interface com.hazelcast.map.IMap
-
Evicts the specified key from this map.
- EVICT - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- EVICT_ALL - Enum constant in enum class com.hazelcast.core.EntryEventType
-
Fired if all entries are evicted.
- EVICT_ALL - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- EvictableEntryView<K,
V> - Interface in com.hazelcast.spi.eviction -
Contract point (from the end user perspective) for serving/accessing entries that can be evicted.
- evictAll() - Method in interface com.hazelcast.map.IMap
-
Evicts all keys from this map except the locked ones.
- EVICTED - Enum constant in enum class com.hazelcast.cache.CacheEventType
-
An event type indicating that the cache entry has evicted.
- EVICTED - Enum constant in enum class com.hazelcast.core.EntryEventType
-
Fired if an entry is evicted.
- EvictionConfig - Class in com.hazelcast.config
-
Configuration for eviction.
- EvictionConfig() - Constructor for class com.hazelcast.config.EvictionConfig
- EvictionConfig(EvictionConfig) - Constructor for class com.hazelcast.config.EvictionConfig
- evictionPolicy - Variable in class com.hazelcast.config.EvictionConfig
- EvictionPolicy - Enum Class in com.hazelcast.config
-
Eviction Policy enum.
- EvictionPolicyComparator<K,
V, E extends EvictableEntryView<K, V>> - Interface in com.hazelcast.spi.eviction -
A kind of
Comparator
to be used while comparing entries to be evicted. - EvolvingApi - Annotation Interface in com.hazelcast.jet.annotation
-
Indicates that the annotated class, method or interface has stable implementation but its API may change between minor versions.
- EXACTLY_ONCE - Enum constant in enum class com.hazelcast.jet.config.ProcessingGuarantee
-
Enables exactly-once processing semantics.
- exactlyOnce(boolean) - Method in class com.hazelcast.jet.kafka.KafkaSinks.Builder
-
Enables or disables the exactly-once behavior of the sink using two-phase commit of state snapshots.
- exactlyOnce(boolean) - Method in class com.hazelcast.jet.pipeline.FileSinkBuilder
-
Enables or disables the exactly-once behavior of the sink using two-phase commit of state snapshots.
- exactlyOnce(boolean) - Method in class com.hazelcast.jet.pipeline.JdbcSinkBuilder
-
Sets whether the exactly-once mode is enabled for the sink.
- exactlyOnce(boolean) - Method in class com.hazelcast.jet.pipeline.JmsSinkBuilder
-
Enables or disables the exactly-once behavior of the sink using two-phase commit of state snapshots.
- execute(SqlStatement) - Method in interface com.hazelcast.sql.SqlService
-
Executes an SQL statement.
- execute(TransactionalTaskContext) - Method in interface com.hazelcast.transaction.TransactionalTask
-
Executes the transactional logic.
- execute(Runnable, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
-
Executes a task on a randomly selected member.
- execute(String, Object...) - Method in interface com.hazelcast.sql.SqlService
-
Convenient method to execute a distributed query with the given parameter values.
- EXECUTE_ON_ENTRIES - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- EXECUTE_ON_KEY - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- EXECUTE_ON_KEYS - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- executeBeforeEachRun(Runnable) - Method in class com.hazelcast.jet.core.test.TestSupport
-
Action to execute before each test scenario.
- executeOnAllMembers(Runnable) - Method in interface com.hazelcast.core.IExecutorService
-
Executes a task on all of the known cluster members.
- executeOnEntries(EntryProcessor<K, V, R>) - Method in interface com.hazelcast.map.IMap
-
Applies the user defined
EntryProcessor
to the all entries in the map. - executeOnEntries(EntryProcessor<K, V, R>, Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
-
Applies the user defined
EntryProcessor
to the entries in the map which satisfy provided predicate. - executeOnKey(K, EntryProcessor<K, V, R>) - Method in interface com.hazelcast.map.IMap
-
Applies the user defined
EntryProcessor
to the entry mapped by thekey
. - executeOnKeyOwner(Runnable, Object) - Method in interface com.hazelcast.core.IExecutorService
-
Executes a task on the owner of the specified key.
- executeOnKeyOwner(Runnable, Object) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
-
Executes a task on the owner of the specified key.
- executeOnKeys(Set<K>, EntryProcessor<K, V, R>) - Method in interface com.hazelcast.map.IMap
-
Applies the user defined
EntryProcessor
to the entries mapped by the collection of keys. - executeOnMember(Runnable, Member) - Method in interface com.hazelcast.core.IExecutorService
-
Executes a task on the specified member.
- executeOnMembers(Runnable, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
-
Executes a task on each of the selected members.
- executeOnMembers(Runnable, Collection<Member>) - Method in interface com.hazelcast.core.IExecutorService
-
Executes a task on each of the specified members.
- executeTransaction(TransactionalTask<T>) - Method in interface com.hazelcast.core.HazelcastInstance
-
Executes the given transactional task in current thread using default options and returns the result of the task.
- executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in interface com.hazelcast.core.HazelcastInstance
-
Executes the given transactional task in current thread using given options and returns the result of the task.
- executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in interface com.hazelcast.transaction.TransactionManagerService
- executeUpdate(String, Object...) - Method in interface com.hazelcast.sql.SqlService
-
Convenience method to execute a distributed non-DQL statement (that is a statement that does not return rows) with the given parameter values.
- EXECUTION - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
-
Unique ID of a particular execution of a job (sourcing the metric), example value would be a numerical (long) ID encoded in a human-readable form, like
"2f7f-d88a-4669-6195"
, seeUtil.idToString(long)
for details. - EXECUTION_COMPLETION_TIME - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
-
Tracks the completion time of a given execution of a specific job.
- EXECUTION_START_TIME - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
-
Tracks the start time of a given execution of a specific job.
- ExecutionCallback<V> - Interface in com.hazelcast.core
-
ExecutionCallback allows to asynchronously get notified when the execution is completed, either successfully or with error.
- executionId() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
-
Returns the job execution ID.
- executionId() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
- EXECUTOR_SERVICE - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
-
Executor Service
- ExecutorConfig - Class in com.hazelcast.config
-
Contains the configuration for an
IExecutorService
. - ExecutorConfig() - Constructor for class com.hazelcast.config.ExecutorConfig
- ExecutorConfig(ExecutorConfig) - Constructor for class com.hazelcast.config.ExecutorConfig
- ExecutorConfig(String) - Constructor for class com.hazelcast.config.ExecutorConfig
- ExecutorConfig(String, int) - Constructor for class com.hazelcast.config.ExecutorConfig
- ExecutorServicePermission - Class in com.hazelcast.security.permission
- ExecutorServicePermission(String, String...) - Constructor for class com.hazelcast.security.permission.ExecutorServicePermission
- existenceChecks - Variable in class com.hazelcast.jet.mongodb.MongoSourceBuilder.Stream
- EXPECT_NOTHING_PROCESSOR_SUPPLIER - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
- expectExactOutput(TestSupport.TestEvent...) - Method in class com.hazelcast.jet.core.test.TestSupport
-
Runs the test and expects an exact sequence of input and output items.
- ExpectNothingProcessorSupplier() - Constructor for class com.hazelcast.jet.core.ProcessorMetaSupplier.ExpectNothingProcessorSupplier
- expectOutput(List<?>) - Method in class com.hazelcast.jet.core.test.TestSupport
-
Sets the expected output and runs the test.
- expectOutputs(List<List<?>>) - Method in class com.hazelcast.jet.core.test.TestSupport
-
Specifies the expected outputs and runs the test.
- expectResponseCodes(Integer...) - Method in class com.hazelcast.spi.utils.RestClient
- EXPIRATION_TIME_UPDATED - Enum constant in enum class com.hazelcast.cache.CacheEventType
-
An event type indicating that the expiration time of cache record has been updated
- expirationTime() - Method in interface com.hazelcast.cp.session.CPSession
-
Returns the timestamp of when the session will expire
- ExpirationTimeMergePolicy<V,
T extends MergingValue<V> & MergingExpirationTime> - Class in com.hazelcast.spi.merge -
Merges data structure entries from source to destination data structure if the source entry will expire later than the destination entry.
- ExpirationTimeMergePolicy() - Constructor for class com.hazelcast.spi.merge.ExpirationTimeMergePolicy
- EXPIRED - Enum constant in enum class com.hazelcast.cache.CacheEventType
-
An event type indicating that the cache entry has expired.
- EXPIRED - Enum constant in enum class com.hazelcast.core.EntryEventType
-
Fired if an entry is expired.
- expiryPolicyFactory - Variable in class com.hazelcast.config.AbstractCacheConfig
-
The
Factory
for theExpiryPolicy
. - ExpiryPolicyFactoryConfig() - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
- ExpiryPolicyFactoryConfig(CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
- ExpiryPolicyFactoryConfig(String) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
- exponentialBackoff(long, double) - Static method in interface com.hazelcast.jet.retry.IntervalFunction
-
Creates an
IntervalFunction
which starts from the specified wait interval, on the first attempt, and for each subsequent attempt uses a longer interval, equal to the previous wait duration multiplied by the provided scaling factor (so for example: 1, 2, 4, 8, ...). - exponentialBackoffWithCap(long, double, long) - Static method in interface com.hazelcast.jet.retry.IntervalFunction
-
Creates an
IntervalFunction
which starts from the specified wait interval, on the first attempt, and for each subsequent attempt uses a longer interval, equal to the previous wait duration multiplied by the provided scaling factor (so for example: 1, 2, 4, 8, ...). - export() - Method in class com.hazelcast.jet.accumulator.DoubleAccumulator
-
Returns the current value.
- export() - Method in class com.hazelcast.jet.accumulator.LinTrendAccumulator
-
Computes the linear coefficient of the linear regression of the accumulated samples.
- exportFn() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
-
A primitive that transforms the accumulator into a result of the aggregation.
- exportSnapshot(String) - Method in interface com.hazelcast.jet.Job
-
Exports a state snapshot and saves it under the given name.
- EXPOSE_EXTERNALLY - Static variable in class com.hazelcast.kubernetes.KubernetesProperties
-
Configuration key:
expose-externally
- ExtendedMapEntry<K,
V> - Interface in com.hazelcast.map -
Interface to provide parity with IMap set and put operations.
- EXTERNAL_NAME_PROPERTY - Static variable in class com.hazelcast.mapstore.GenericMapLoader
-
Property key to define external name of the table
- extract(T, A, ValueCollector<Object>) - Method in interface com.hazelcast.query.extractor.ValueExtractor
-
Extracts a value from the given target object.
- extractAdditionalPropertiesFrom(JsonValue) - Method in class com.hazelcast.kubernetes.KubernetesApiEndpointSlicesProvider
- extractKeyFn(FunctionEx<? super E, ?>) - Method in class com.hazelcast.jet.kafka.KafkaSinks.Builder
-
Sets the function to extract the key from the stream items.
- extractNodes(JsonObject, List<String>) - Method in class com.hazelcast.kubernetes.KubernetesApiEndpointSlicesProvider
- extractPort(JsonValue) - Method in class com.hazelcast.kubernetes.KubernetesApiEndpointSlicesProvider
- extractServices(JsonObject, List<String>) - Method in class com.hazelcast.kubernetes.KubernetesApiEndpointSlicesProvider
- extractValueFn(FunctionEx<? super E, ?>) - Method in class com.hazelcast.jet.kafka.KafkaSinks.Builder
-
Sets the function to extract the value from the stream items.
F
- f0() - Method in class com.hazelcast.jet.datamodel.Tuple2
-
Returns the value of the field 0.
- f0() - Method in class com.hazelcast.jet.datamodel.Tuple3
-
Returns the value of the field 0.
- f0() - Method in class com.hazelcast.jet.datamodel.Tuple4
-
Returns the value of the field 0.
- f0() - Method in class com.hazelcast.jet.datamodel.Tuple5
-
Returns the value of the field 0.
- f1() - Method in class com.hazelcast.jet.datamodel.Tuple2
-
Returns the value of the field 1.
- f1() - Method in class com.hazelcast.jet.datamodel.Tuple3
-
Returns the value of the field 1.
- f1() - Method in class com.hazelcast.jet.datamodel.Tuple4
-
Returns the value of the field 1.
- f1() - Method in class com.hazelcast.jet.datamodel.Tuple5
-
Returns the value of the field 1.
- f2() - Method in class com.hazelcast.jet.datamodel.Tuple3
-
Returns the value of the field 2.
- f2() - Method in class com.hazelcast.jet.datamodel.Tuple4
-
Returns the value of the field 2.
- f2() - Method in class com.hazelcast.jet.datamodel.Tuple5
-
Returns the value of the field 2.
- f3() - Method in class com.hazelcast.jet.datamodel.Tuple4
-
Returns the value of the field 3.
- f3() - Method in class com.hazelcast.jet.datamodel.Tuple5
-
Returns the value of the field 3.
- f4() - Method in class com.hazelcast.jet.datamodel.Tuple5
-
Returns the value of the field 4.
- FACTORY_ID - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
-
Factory ID
- factoryClassName - Variable in class com.hazelcast.config.AbstractBaseFactoryWithPropertiesConfig
- factoryWithPropertiesXmlGenerator(ConfigXmlGenerator.XmlGenerator, String, AbstractBaseFactoryWithPropertiesConfig<?>) - Method in class com.hazelcast.config.ConfigXmlGenerator
- fail(String) - Static method in class com.hazelcast.jet.core.test.JetAssert
-
Throws an
AssertionError
with the given message. - FAIL - Enum constant in enum class com.hazelcast.ringbuffer.OverflowPolicy
-
Using this policy the call will fail immediately and the oldest item will not be overwritten before it is old enough to retire.
- FAIL_ON_INDETERMINATE_OPERATION_STATE - Static variable in class com.hazelcast.client.properties.ClientProperty
-
When this configuration is enabled, if an operation has sync backups and acks are not received from backup replicas in time, or the member which owns primary replica of the target partition leaves the cluster, then the invocation fails with
IndeterminateOperationStateException
. - FAIL_ON_INDETERMINATE_OPERATION_STATE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
When this configuration is enabled, if an operation has sync backups and acks are not received from backup replicas in time, or the member which owns primary replica of the target partition leaves the cluster, then the invocation fails with
IndeterminateOperationStateException
. - FAILED - Enum constant in enum class com.hazelcast.jet.core.JobStatus
-
The job has failed with an exception.
- FAILOVER_CLIENT_DEFAULT_CLUSTER_CONNECT_TIMEOUT_MILLIS - Static variable in class com.hazelcast.client.config.ConnectionRetryConfig
-
Timeout used by the failover client to start trying to connect alternative clusters when the cluster connection timeout is equal to
ConnectionRetryConfig.DEFAULT_CLUSTER_CONNECT_TIMEOUT_MILLIS
. - FAILURE - Enum constant in enum class com.hazelcast.persistence.BackupTaskState
-
The backup task has failed
- fanout() - Method in class com.hazelcast.jet.core.Edge
-
Activates the
FANOUT
routing policy. - FANOUT - Enum constant in enum class com.hazelcast.jet.core.Edge.RoutingPolicy
-
This policy sends an item to all members, but only to one processor on each member.
- FencedLock - Interface in com.hazelcast.cp.lock
-
A linearizable & distributed & reentrant implementation of
Lock
. - FencedLockConfig - Class in com.hazelcast.config.cp
-
Contains configuration options for
FencedLock
- FencedLockConfig() - Constructor for class com.hazelcast.config.cp.FencedLockConfig
- FencedLockConfig(String) - Constructor for class com.hazelcast.config.cp.FencedLockConfig
- FencedLockConfig(String, int) - Constructor for class com.hazelcast.config.cp.FencedLockConfig
- FETCH_ENTRY_VIEWS - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- FETCH_NEAR_CACHE_INVALIDATION_METADATA - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- FETCH_SIZE - Static variable in class com.hazelcast.jet.pipeline.JdbcPropertyKeys
-
Property key to be passed to specify fetch size of the JDBC connection For usage example see
Sources.jdbc(String, String, Properties, FunctionEx)
method - FieldDefinition - Interface in com.hazelcast.nio.serialization
-
Defines the name, type and index of a field.
- FieldKind - Enum Class in com.hazelcast.nio.serialization
- fieldNames() - Method in class com.hazelcast.jet.pipeline.file.CsvFileFormat
-
Return the desired list of fields that is used with
String[]
class. - fieldsToString() - Method in class com.hazelcast.config.CollectionConfig
-
Returns field names with values as concatenated String, so it can be used in child classes' toString() methods.
- FieldType - Enum Class in com.hazelcast.nio.serialization
-
Field Type for
Portable
format to be used withClassDefinition.getFieldType(String)
API - file(String, String) - Static method in class com.hazelcast.security.permission.ConnectorPermission
-
converts the
directory
to canonical path if it is not one of the Hadoop prefixes. - FILE - Enum constant in enum class com.hazelcast.jet.config.ResourceType
-
Represents a plain file.
- FILE_PREFIX - Static variable in class com.hazelcast.security.permission.ConnectorPermission
- FILE_WATCHER - Static variable in class com.hazelcast.jet.pipeline.ConnectorNames
- FileFormat<T> - Interface in com.hazelcast.jet.pipeline.file
-
Describes the data format of a file to be used as a Jet data source.
- files(String) - Static method in class com.hazelcast.jet.pipeline.file.FileSources
-
The main entry point to the Unified File Connector.
- files(String) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Convenience for
Sinks.filesBuilder(java.lang.String)
with the UTF-8 charset and with overwriting of existing files. - files(String) - Static method in class com.hazelcast.jet.pipeline.Sources
-
A source to read all files in a directory in a batch way.
- files(String, BiFunctionEx<String, GenericRecord, D>) - Static method in class com.hazelcast.jet.avro.AvroSources
-
Convenience for
AvroSources.filesBuilder(String, SupplierEx)
which reads all the files in the supplied directory as generic records and emits the results of transforming each generic record with the supplied mapping function. - files(String, Class<D>) - Static method in class com.hazelcast.jet.avro.AvroSources
-
Convenience for
AvroSources.filesBuilder(String, Class)
which reads all the files in the supplied directory as specific records using supplieddatumClass
. - files(String, Class<R>, Schema) - Static method in class com.hazelcast.jet.avro.AvroSinks
-
Convenience for
AvroSinks.files(String, Schema, SupplierEx)
which uses eitherSpecificDatumWriter
orReflectDatumWriter
depending on the suppliedrecordClass
. - files(String, Schema) - Static method in class com.hazelcast.jet.avro.AvroSinks
-
Convenience for
AvroSinks.files(String, Schema, SupplierEx)
which usesGenericDatumWriter
. - files(String, Schema, SupplierEx<DatumWriter<R>>) - Static method in class com.hazelcast.jet.avro.AvroSinks
-
Returns a sink that that writes the items it receives to Apache Avro files.
- FILES - Static variable in class com.hazelcast.jet.pipeline.ConnectorNames
- filesBuilder(String) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a builder object that offers a step-by-step fluent API to build a custom file sink for the Pipeline API.
- filesBuilder(String) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Returns a builder object that offers a step-by-step fluent API to build a custom source to read files for the Pipeline API.
- filesBuilder(String, SupplierEx<? extends DatumReader<D>>) - Static method in class com.hazelcast.jet.avro.AvroSources
-
Returns a builder object that offers a step-by-step fluent API to build a custom Avro file source for the Pipeline API.
- filesBuilder(String, Class<D>) - Static method in class com.hazelcast.jet.avro.AvroSources
-
Returns a builder object that offers a step-by-step fluent API to build a custom Avro file source for the Pipeline API.
- FileSinkBuilder<T> - Class in com.hazelcast.jet.pipeline
- FileSourceBuilder<T> - Class in com.hazelcast.jet.pipeline.file
-
A unified builder object for various kinds of file sources.
- FileSourceBuilder - Class in com.hazelcast.jet.pipeline
-
Builder for a file source which reads lines from files in a directory (but not its subdirectories) and emits output object created by
mapOutputFn
- FileSources - Class in com.hazelcast.jet.pipeline.file
-
Contains factory methods for the Unified File Connector.
- FileSystemXmlConfig - Class in com.hazelcast.config
-
A
Config
which includes functionality for loading itself from an XML configuration file. - FileSystemXmlConfig(File) - Constructor for class com.hazelcast.config.FileSystemXmlConfig
-
Creates a Config based on a Hazelcast xml file and uses the System.properties to resolve variables in the XML.
- FileSystemXmlConfig(File, Properties) - Constructor for class com.hazelcast.config.FileSystemXmlConfig
-
Creates a Config based on a Hazelcast XML file.
- FileSystemXmlConfig(String) - Constructor for class com.hazelcast.config.FileSystemXmlConfig
-
Creates a Config based on a Hazelcast xml file and uses the System.properties to resolve variables in the XML.
- FileSystemXmlConfig(String, Properties) - Constructor for class com.hazelcast.config.FileSystemXmlConfig
-
Creates a Config based on a Hazelcast XML file.
- FileSystemYamlConfig - Class in com.hazelcast.config
-
A
Config
which includes functionality for loading itself from a YAML configuration file. - FileSystemYamlConfig(File) - Constructor for class com.hazelcast.config.FileSystemYamlConfig
-
Creates a Config based on a Hazelcast yaml file and uses the System.properties to resolve variables in the YAML.
- FileSystemYamlConfig(File, Properties) - Constructor for class com.hazelcast.config.FileSystemYamlConfig
-
Creates a Config based on a Hazelcast YAML file.
- FileSystemYamlConfig(String) - Constructor for class com.hazelcast.config.FileSystemYamlConfig
-
Creates a Config based on a Hazelcast yaml file and uses the System.properties to resolve variables in the YAML.
- FileSystemYamlConfig(String, Properties) - Constructor for class com.hazelcast.config.FileSystemYamlConfig
-
Creates a Config based on a Hazelcast YAML file.
- fileWatcher(String) - Static method in class com.hazelcast.jet.pipeline.Sources
-
A source to stream lines added to files in a directory.
- fillAttributeValues(Node, BeanDefinitionBuilder, String...) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- fillAttributeValues(Node, BeanDefinitionBuilder, Collection<String>) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- fillBufferFn(BiConsumerEx<? super C, ? super SourceBuilder.SourceBuffer<T_NEW>>) - Method in class com.hazelcast.jet.pipeline.SourceBuilder.Batch
-
Sets the function that Jet will call whenever it needs more data from your source.
- fillBufferFn(BiConsumerEx<? super C, ? super SourceBuilder.SourceBuffer<T_NEW>>) - Method in class com.hazelcast.jet.pipeline.SourceBuilder.Stream
- fillBufferFn(BiConsumerEx<? super C, ? super SourceBuilder.TimestampedSourceBuffer<T_NEW>>) - Method in class com.hazelcast.jet.pipeline.SourceBuilder.TimestampedStream
-
Sets the function that Jet will call whenever it needs more data from your source.
- fillValues(Node, BeanDefinitionBuilder, String...) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- filter(PredicateEx<T>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- filter(PredicateEx<T>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Attaches a filtering stage which applies the provided predicate function to each input item to decide whether to pass the item to the output or to discard it.
- filter(PredicateEx<T>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- filter(String) - Method in interface com.hazelcast.nio.serialization.ClassNameFilter
- filter(String, String) - Method in class com.hazelcast.jet.core.metrics.JobMetrics
-
Convenience method for
JobMetrics.filter(Predicate)
, returns a newJobMetrics
instance containing only thoseMeasurement
s which have the specified tag set to the specified value. - filter(Predicate<? super T>) - Method in interface com.hazelcast.jet.Traverser
-
Returns a traverser that will emit the same items as this traverser, but only those that pass the given predicate.
- filter(Predicate<Measurement>) - Method in class com.hazelcast.jet.core.metrics.JobMetrics
-
Returns a new
JobMetrics
instance containing a subset of theMeasurement
s found in the current one. - filter(Bson) - Method in class com.hazelcast.jet.mongodb.MongoSourceBuilder.Stream
-
Adds filter aggregate to this builder, which allows to filter documents in MongoDB, without the need to download all documents.
- filtering(PredicateEx<? super T>, AggregateOperation1<? super T, A, ? extends R>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Adapts an aggregate operation so that it accumulates only the items passing the
filterFn
and ignores others. - filterP(PredicateEx<? super T>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for a vertex that emits the same items it receives, but only those that pass the given predicate.
- filterStateful(long, SupplierEx<? extends S>, BiPredicateEx<? super S, ? super T>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
-
Attaches a stage that performs a stateful filtering operation.
- filterStateful(SupplierEx<? extends S>, BiPredicateEx<? super S, ? super T>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- filterStateful(SupplierEx<? extends S>, BiPredicateEx<? super S, ? super T>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
- filterStateful(SupplierEx<? extends S>, BiPredicateEx<? super S, ? super T>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Attaches a stage that performs a stateful filtering operation.
- filterStateful(SupplierEx<? extends S>, BiPredicateEx<? super S, ? super T>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
-
Attaches a stage that performs a stateful filtering operation.
- filterStateful(SupplierEx<? extends S>, BiPredicateEx<? super S, ? super T>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- filterStateful(SupplierEx<? extends S>, BiPredicateEx<? super S, ? super T>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
- filterUsingService(ServiceFactory<?, S>, BiPredicateEx<? super S, ? super T>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- filterUsingService(ServiceFactory<?, S>, BiPredicateEx<? super S, ? super T>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Attaches a filtering stage which applies the provided predicate function to each input item to decide whether to pass the item to the output or to discard it.
- filterUsingService(ServiceFactory<?, S>, BiPredicateEx<? super S, ? super T>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- filterUsingService(ServiceFactory<?, S>, TriPredicate<? super S, ? super K, ? super T>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
- filterUsingService(ServiceFactory<?, S>, TriPredicate<? super S, ? super K, ? super T>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
-
Deprecated.Jet now has first-class support for data rebalancing, see
GeneralStage.rebalance()
andGeneralStage.rebalance(FunctionEx)
. - filterUsingService(ServiceFactory<?, S>, TriPredicate<? super S, ? super K, ? super T>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
- filterUsingServiceP(ServiceFactory<C, S>, BiPredicateEx<? super S, ? super T>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for a vertex that emits the same items it receives, but only those that pass the given predicate.
- FINALIZE_REMOTE_TRANSACTION - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- findCacheConfig(String) - Method in class com.hazelcast.config.Config
-
Returns a read-only
CacheSimpleConfig
configuration for the given name. - findCacheConfigOrNull(String) - Method in class com.hazelcast.config.Config
-
Returns the cache config with the given name or
null
if there is none. - findCardinalityEstimatorConfig(String) - Method in class com.hazelcast.config.Config
-
Returns a read-only
CardinalityEstimator
configuration for the given name. - findColumn(String) - Method in class com.hazelcast.sql.SqlRowMetadata
-
Find index of the column with the given name.
- findCPMapConfig(String) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Returns the
CPMapConfig
configuration for the given name. - findDataConnectionConfig(String) - Method in class com.hazelcast.config.Config
-
Returns a read-only
DataConnectionConfig
configuration for the given name. - findDurableExecutorConfig(String) - Method in class com.hazelcast.config.Config
-
Returns a read-only durable executor configuration for the given name.
- findExecutorConfig(String) - Method in class com.hazelcast.config.Config
-
Returns a read-only executor configuration for the given name.
- findFlakeIdGeneratorConfig(String) - Method in class com.hazelcast.client.config.ClientConfig
-
Returns a
ClientFlakeIdGeneratorConfig
configuration for the given flake ID generator name. - findFlakeIdGeneratorConfig(String) - Method in class com.hazelcast.config.Config
-
Returns a
FlakeIdGeneratorConfig
configuration for the given flake ID generator name. - findListConfig(String) - Method in class com.hazelcast.config.Config
-
Returns a read-only
IList
configuration for the given name. - findLockConfig(String) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Returns the
FencedLock
configuration for the given name. - findMapConfig(String) - Method in class com.hazelcast.config.Config
-
Returns a read-only
IMap
configuration for the given name. - findMultiMapConfig(String) - Method in class com.hazelcast.config.Config
-
Returns a read-only
MultiMap
configuration for the given name. - findPNCounterConfig(String) - Method in class com.hazelcast.config.Config
-
Returns a read-only
PNCounterConfig
configuration for the given name. - findQueueConfig(String) - Method in class com.hazelcast.config.Config
-
Returns a read-only
IQueue
configuration for the given name. - findReliableTopicConfig(String) - Method in class com.hazelcast.config.Config
-
Returns a read-only reliable topic configuration for the given name.
- findReplicatedMapConfig(String) - Method in class com.hazelcast.config.Config
-
Returns a read-only
ReplicatedMap
configuration for the given name. - findRingbufferConfig(String) - Method in class com.hazelcast.config.Config
-
Returns a read-only
Ringbuffer
configuration for the given name. - findScheduledExecutorConfig(String) - Method in class com.hazelcast.config.Config
-
Returns a read-only scheduled executor configuration for the given name.
- findSemaphoreConfig(String) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Returns the CP
ISemaphore
configuration for the given name. - findSetConfig(String) - Method in class com.hazelcast.config.Config
-
Returns a read-only
ISet
configuration for the given name. - findSplitBrainProtectionConfig(String) - Method in class com.hazelcast.config.Config
-
Returns a read-only split-brain protection configuration for the given name.
- findTopicConfig(String) - Method in class com.hazelcast.config.Config
-
Returns a read-only
ITopic
configuration for the given name. - fine(String) - Method in class com.hazelcast.logging.AbstractLogger
- fine(String, Object) - Method in interface com.hazelcast.logging.ILogger
-
Logs to
TpcLogger.fine(String)
using a lazily evaluatedtemplate
String
with arguments, formatted usingString.format(String, Object...)
- fine(String, Object, Object) - Method in interface com.hazelcast.logging.ILogger
- fine(String, Object, Object, Object) - Method in interface com.hazelcast.logging.ILogger
- fine(String, Object, Object, Object, Object) - Method in interface com.hazelcast.logging.ILogger
- fine(String, Object, Object, Object, Object, Object) - Method in interface com.hazelcast.logging.ILogger
- fine(String, Object, Object, Object, Object, Object, Object) - Method in interface com.hazelcast.logging.ILogger
- fine(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
- fine(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
- finest(String) - Method in class com.hazelcast.logging.AbstractLogger
- finest(String, Object) - Method in interface com.hazelcast.logging.ILogger
-
Logs to
TpcLogger.finest(String)
using a lazily evaluatedtemplate
String
with arguments, formatted usingString.format(String, Object...)
- finest(String, Object, Object) - Method in interface com.hazelcast.logging.ILogger
- finest(String, Object, Object, Object) - Method in interface com.hazelcast.logging.ILogger
- finest(String, Object, Object, Object, Object) - Method in interface com.hazelcast.logging.ILogger
- finest(String, Object, Object, Object, Object, Object) - Method in interface com.hazelcast.logging.ILogger
- finest(String, Object, Object, Object, Object, Object, Object) - Method in interface com.hazelcast.logging.ILogger
- finest(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
- finest(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
- finishFn() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
-
A primitive that transforms the accumulator into a result of the aggregation.
- finishSnapshotRestore() - Method in interface com.hazelcast.jet.core.Processor
-
Called after a job was restarted from a snapshot and the processor has consumed all the snapshot data in
Processor.restoreFromSnapshot(com.hazelcast.jet.core.Inbox)
. - fixedPointSum() - Static method in class com.hazelcast.aggregation.Aggregators
- fixedPointSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
- FLAKE_ID_GENERATOR - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
-
Flake ID generator
- FlakeIdGenerator - Interface in com.hazelcast.flakeidgen
-
A cluster-wide unique ID generator.
- FlakeIdGeneratorConfig - Class in com.hazelcast.config
-
The
FlakeIdGeneratorConfig
contains the configuration for the member regardingFlake ID Generator
. - FlakeIdGeneratorConfig() - Constructor for class com.hazelcast.config.FlakeIdGeneratorConfig
- FlakeIdGeneratorConfig(FlakeIdGeneratorConfig) - Constructor for class com.hazelcast.config.FlakeIdGeneratorConfig
-
Copy-constructor
- FlakeIdGeneratorConfig(String) - Constructor for class com.hazelcast.config.FlakeIdGeneratorConfig
- FlakeIdGeneratorPermission - Class in com.hazelcast.security.permission
- FlakeIdGeneratorPermission(String, String...) - Constructor for class com.hazelcast.security.permission.FlakeIdGeneratorPermission
- flatMap(FunctionEx<? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- flatMap(FunctionEx<? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Attaches a flat-mapping stage which applies the supplied function to each input item independently and emits all the items from the
Traverser
it returns. - flatMap(FunctionEx<? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- flatMap(Function<? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.Traverser
-
Returns a traverser that will apply the given mapping function to each item retrieved from this traverser and emit all the items from the resulting traversers, which must be null-terminated.
- flatMapEvent(long, T, int, long) - Method in class com.hazelcast.jet.core.EventTimeMapper
-
A lower-level variant of
flatMapEvent(T, int, long)
that accepts an explicit result of aSystem.nanoTime()
call. - flatMapEvent(T, int, long) - Method in class com.hazelcast.jet.core.EventTimeMapper
-
Flat-maps the given
event
by (possibly) prepending it with a watermark. - flatMapIdle() - Method in class com.hazelcast.jet.core.EventTimeMapper
-
Call this method when there is no event to emit.
- flatMapP(FunctionEx<? super T, ? extends Traverser<? extends R>>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for a vertex that applies the provided item-to-traverser mapping function to each received item and emits all the items from the resulting traverser.
- flatMapper(int[], Function<? super T, ? extends Traverser<? extends R>>) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Factory of
AbstractProcessor.FlatMapper
. - flatMapper(int, Function<? super T, ? extends Traverser<? extends R>>) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Factory of
AbstractProcessor.FlatMapper
. - flatMapper(Function<? super T, ? extends Traverser<? extends R>>) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Factory of
AbstractProcessor.FlatMapper
. - flatMapping(FunctionEx<? super T, ? extends Traverser<? extends U>>, AggregateOperation1<? super U, A, ? extends R>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Adapts an aggregate operation that takes items of type
U
to one that takes items of typeT
, by exploding eachT
into a sequence ofU
s and then accumulating all of them. - flatMapStateful(long, SupplierEx<? extends S>, TriFunction<? super S, ? super K, ? super T, ? extends Traverser<R>>, TriFunction<? super S, ? super K, ? super Long, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
-
Attaches a stage that performs a stateful flat-mapping operation.
- flatMapStateful(SupplierEx<? extends S>, BiFunctionEx<? super S, ? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- flatMapStateful(SupplierEx<? extends S>, BiFunctionEx<? super S, ? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Attaches a stage that performs a stateful flat-mapping operation.
- flatMapStateful(SupplierEx<? extends S>, BiFunctionEx<? super S, ? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- flatMapStateful(SupplierEx<? extends S>, TriFunction<? super S, ? super K, ? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
- flatMapStateful(SupplierEx<? extends S>, TriFunction<? super S, ? super K, ? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
-
Attaches a stage that performs a stateful flat-mapping operation.
- flatMapStateful(SupplierEx<? extends S>, TriFunction<? super S, ? super K, ? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
- flatMapStatefulP(long, FunctionEx<? super T, ? extends K>, ToLongFunctionEx<? super T>, Supplier<? extends S>, TriFunction<? super S, ? super K, ? super T, ? extends Traverser<R>>, TriFunction<? super S, ? super K, ? super Long, ? extends Traverser<R>>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for a vertex that performs a stateful flat-mapping of its input.
- flatMapUsingService(ServiceFactory<?, S>, BiFunctionEx<? super S, ? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- flatMapUsingService(ServiceFactory<?, S>, BiFunctionEx<? super S, ? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Attaches a flat-mapping stage which applies the supplied function to each input item independently and emits all items from the
Traverser
it returns as the output items. - flatMapUsingService(ServiceFactory<?, S>, BiFunctionEx<? super S, ? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- flatMapUsingService(ServiceFactory<?, S>, TriFunction<? super S, ? super K, ? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
- flatMapUsingService(ServiceFactory<?, S>, TriFunction<? super S, ? super K, ? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
-
Deprecated.Jet now has first-class support for data rebalancing, see
GeneralStage.rebalance()
andGeneralStage.rebalance(FunctionEx)
. - flatMapUsingService(ServiceFactory<?, S>, TriFunction<? super S, ? super K, ? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
- flatMapUsingServiceP(ServiceFactory<C, S>, BiFunctionEx<? super S, ? super T, ? extends Traverser<R>>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for a vertex that applies the provided item-to-traverser mapping function to each received item and emits all the items from the resulting traverser.
- FLOAT - Enum constant in enum class com.hazelcast.config.properties.PropertyTypeConverter
-
TypeConverter
to convert an input string to an output float - FLOAT - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
- FLOAT_ARRAY - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
- FLOAT32 - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
- FLOAT64 - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
- floatingPointSum() - Static method in class com.hazelcast.aggregation.Aggregators
- floatingPointSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
- floorFrameTs(long) - Method in class com.hazelcast.jet.core.SlidingWindowPolicy
-
Returns the highest frame timestamp less than or equal to the given timestamp.
- flush() - Method in interface com.hazelcast.map.IMap
-
If this map has a MapStore, this method flushes all the local dirty entries.
- FLUSH - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- flushFn(ConsumerEx<? super C>) - Method in class com.hazelcast.jet.pipeline.SinkBuilder
-
Sets the function that implements the sink's flushing behavior.
- followers() - Method in record class com.hazelcast.cp.CPGroupsSnapshot.GroupInfo
-
Returns the value of the
followers
record component. - FORCE_UNLOCK - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- forceCloseSession(String, long) - Method in interface com.hazelcast.cp.session.CPSessionManagementService
-
If a Hazelcast instance that owns a CP session crashes, its CP session is not terminated immediately.
- forceDestroyCPGroup(String) - Method in interface com.hazelcast.cp.CPSubsystemManagementService
-
Unconditionally destroys the given active CP group without using the Raft algorithm mechanics.
- forceLocalMemberToBeSafe(long, TimeUnit) - Method in interface com.hazelcast.partition.PartitionService
-
Force the local member to be safe by checking and syncing partitions owned by the local member with at least one of the backups.
- forceReadTotalParallelismOne - Variable in class com.hazelcast.jet.mongodb.MongoSourceBuilder.Stream
- forceReadTotalParallelismOne(boolean) - Method in class com.hazelcast.jet.mongodb.MongoSourceBuilder.Stream
-
If set to true, reading will be done in only one thread.
- forceTotalParallelismOne(ProcessorSupplier) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Variant of
ProcessorMetaSupplier.forceTotalParallelismOne(ProcessorSupplier, String, Permission)
where the node for the supplier will be chosen randomly and without any required permission. - forceTotalParallelismOne(ProcessorSupplier, Address) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Wraps the provided
ProcessorSupplier
into a meta-supplier that will only use the givenProcessorSupplier
on a node with the givenAddress
. - forceTotalParallelismOne(ProcessorSupplier, String) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Variant of
ProcessorMetaSupplier.forceTotalParallelismOne(ProcessorSupplier, String, Permission)
without any required permission. - forceTotalParallelismOne(ProcessorSupplier, String, Permission) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Wraps the provided
ProcessorSupplier
into a meta-supplier that will only use the givenProcessorSupplier
on a single node. - forceTotalParallelismOne(ProcessorSupplier, Permission) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Variant of
ProcessorMetaSupplier.forceTotalParallelismOne(ProcessorSupplier, String, Permission)
where the node for the supplier will be chosen randomly. - forceUnlock(K) - Method in interface com.hazelcast.map.IMap
-
Releases the lock for the specified key regardless of the lock owner.
- forceUnlock(K) - Method in interface com.hazelcast.multimap.MultiMap
-
Releases the lock for the specified key regardless of the lock owner.
- forEach(BiConsumer<? super K, ? super V>) - Method in interface com.hazelcast.map.IMap
- format() - Method in class com.hazelcast.jet.pipeline.file.AvroFileFormat
- format() - Method in class com.hazelcast.jet.pipeline.file.CsvFileFormat
- format() - Method in interface com.hazelcast.jet.pipeline.file.FileFormat
-
Returns the name of the file format.
- format() - Method in class com.hazelcast.jet.pipeline.file.JsonFileFormat
- format() - Method in class com.hazelcast.jet.pipeline.file.LinesTextFileFormat
- format() - Method in class com.hazelcast.jet.pipeline.file.ParquetFileFormat
- format() - Method in class com.hazelcast.jet.pipeline.file.RawBytesFileFormat
- format() - Method in class com.hazelcast.jet.pipeline.file.TextFileFormat
- format(FileFormat<T_NEW>) - Method in class com.hazelcast.jet.pipeline.file.FileSourceBuilder
-
Set the file format for the source.
- FORMAT_AVRO - Static variable in class com.hazelcast.jet.pipeline.file.AvroFileFormat
-
Format id for Avro.
- FORMAT_BIN - Static variable in class com.hazelcast.jet.pipeline.file.RawBytesFileFormat
-
Format ID for raw binary data.
- FORMAT_CSV - Static variable in class com.hazelcast.jet.pipeline.file.CsvFileFormat
-
Format ID for CSV.
- FORMAT_JSON - Static variable in class com.hazelcast.jet.pipeline.file.JsonFileFormat
-
Format ID for JSON.
- FORMAT_LINES - Static variable in class com.hazelcast.jet.pipeline.file.LinesTextFileFormat
-
Format ID for text file as lines.
- FORMAT_PARQUET - Static variable in class com.hazelcast.jet.pipeline.file.ParquetFileFormat
-
Format ID for Parquet.
- FORMAT_TXT - Static variable in class com.hazelcast.jet.pipeline.file.TextFileFormat
-
Format ID for text files.
- FRAME - Enum constant in enum class com.hazelcast.jet.core.TimestampKind
-
Denotes the frame timestamp kind.
- frameOffset() - Method in class com.hazelcast.jet.core.SlidingWindowPolicy
-
Returns the frame offset.
- frameSize() - Method in class com.hazelcast.jet.core.SlidingWindowPolicy
-
Returns the length of the frame (equal to the sliding step).
- FREE_HEAP_PERCENTAGE - Enum constant in enum class com.hazelcast.config.MaxSizePolicy
-
Policy based on minimum free JVM heap memory percentage per JVM
- FREE_HEAP_SIZE - Enum constant in enum class com.hazelcast.config.MaxSizePolicy
-
Policy based on minimum free JVM heap memory in megabytes per JVM
- FREE_NATIVE_MEMORY_PERCENTAGE - Enum constant in enum class com.hazelcast.config.MaxSizePolicy
-
Policy based on minimum free native memory percentage per Hazelcast instance
- FREE_NATIVE_MEMORY_SIZE - Enum constant in enum class com.hazelcast.config.MaxSizePolicy
-
Policy based on minimum free native memory in megabytes per Hazelcast instance
- from(JsonObject, String) - Static method in class com.hazelcast.kubernetes.RuntimeContext
- from(Vertex) - Static method in class com.hazelcast.jet.core.Edge
-
Returns an edge with the given source vertex and no destination vertex.
- from(Vertex, int) - Static method in class com.hazelcast.jet.core.Edge
-
Returns an edge with the given source vertex at the given ordinal and no destination vertex.
- from(Class<T>, int) - Static method in class com.hazelcast.jet.protobuf.ProtobufSerializer
-
A utility method that creates an anonymous
ProtobufSerializer
. - fromClass(Class<?>...) - Static method in class com.hazelcast.jet.config.ResourceConfig
- fromId(byte) - Static method in enum class com.hazelcast.sql.SqlExpectedResultType
- fromId(int) - Static method in enum class com.hazelcast.config.BitmapIndexOptions.UniqueKeyTransformation
- fromName(String) - Static method in enum class com.hazelcast.config.BitmapIndexOptions.UniqueKeyTransformation
-
Resolves one of the
BitmapIndexOptions.UniqueKeyTransformation
values by its name. - fromProcessor(String, ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink constructed directly from the given Core API processor meta-supplier.
- fromProcessor(String, ProcessorMetaSupplier, FunctionEx<? super T, ?>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink constructed directly from the given Core API processor meta-supplier.
- fromStoreValue(Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
- fromString(String) - Static method in enum class com.hazelcast.jet.mongodb.ResourceChecks
-
Resolves given string value to one of values of this enum.
- FROZEN - Enum constant in enum class com.hazelcast.cluster.ClusterState
-
In
FROZEN
state of the cluster: New members are not allowed to join, except the members left duringFROZEN
orClusterState.PASSIVE
state. - FULL_RECOVERY_ONLY - Enum constant in enum class com.hazelcast.config.HotRestartClusterDataRecoveryPolicy
-
Deprecated.Starts the cluster only when all expected nodes are present and correct.
- FULL_RECOVERY_ONLY - Enum constant in enum class com.hazelcast.config.PersistenceClusterDataRecoveryPolicy
-
Starts the cluster only when all expected nodes are present and correct.
- FunctionEx<T,
R> - Interface in com.hazelcast.function -
Serializable
variant ofjava.util.function.Function
which declares checked exception. - Functions - Class in com.hazelcast.function
-
Factory methods for several common functions.
G
- GcpConfig - Class in com.hazelcast.config
-
Configuration for the GCP Discovery Strategy.
- GcpConfig() - Constructor for class com.hazelcast.config.GcpConfig
- GcpConfig(GcpConfig) - Constructor for class com.hazelcast.config.GcpConfig
- GcpConfig(String, boolean, boolean, Map<String, String>) - Constructor for class com.hazelcast.config.GcpConfig
- GcpDiscoveryStrategy - Class in com.hazelcast.gcp
-
GCP implementation of
DiscoveryStrategy
. - GcpDiscoveryStrategyFactory - Class in com.hazelcast.gcp
-
Factory class which returns
GcpDiscoveryStrategy
to Discovery SPI. - GcpDiscoveryStrategyFactory() - Constructor for class com.hazelcast.gcp.GcpDiscoveryStrategyFactory
- GeneralHashJoinBuilder<T0> - Class in com.hazelcast.jet.pipeline
-
Offers a step-by-step fluent API to build a hash-join pipeline stage.
- GeneralStage<T> - Interface in com.hazelcast.jet.pipeline
- GeneralStageWithKey<T,
K> - Interface in com.hazelcast.jet.pipeline -
An intermediate step when constructing a group-and-aggregate pipeline stage.
- generate(long, long) - Method in interface com.hazelcast.jet.pipeline.test.GeneratorFunction
-
Applies the function to the given timestamp and sequence.
- generate(ClientConfig) - Static method in class com.hazelcast.client.config.ClientConfigXmlGenerator
-
Convenience for
ClientConfigXmlGenerator.generate(ClientConfig, int)
, which generates the xml without any formatting. - generate(ClientConfig, int) - Static method in class com.hazelcast.client.config.ClientConfigXmlGenerator
-
Transforms the given
ClientConfig
to xml string formatting the output with givenindent
, -1 means no formatting. - generate(Config) - Method in class com.hazelcast.config.ConfigXmlGenerator
-
Generates the XML string based on some Config.
- GeneratorFunction<R> - Interface in com.hazelcast.jet.pipeline.test
-
A function which takes a timestamp and a sequence number as the input.
- GENERIC_OPERATION_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The number of generic operation handler threads per member.
- GenericMapLoader<K,
V> - Class in com.hazelcast.mapstore -
GenericMapLoader is an implementation of
MapLoader
built on top of Hazelcast SQL engine. - GenericMapLoader() - Constructor for class com.hazelcast.mapstore.GenericMapLoader
- GenericMapStore<K,
V> - Class in com.hazelcast.mapstore -
GenericMapStore is an implementation of
MapStore
built on top of Hazelcast SQL engine. - GenericMapStore() - Constructor for class com.hazelcast.mapstore.GenericMapStore
- GenericRecord - Interface in com.hazelcast.nio.serialization.genericrecord
- GenericRecordBuilder - Interface in com.hazelcast.nio.serialization.genericrecord
-
Interface for creating
GenericRecord
instances. - get() - Method in interface com.hazelcast.cp.IAtomicLong
-
Gets the current value.
- get() - Method in interface com.hazelcast.cp.IAtomicReference
-
Gets the current value.
- get() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
-
Returns the current value of the counter.
- get() - Method in interface com.hazelcast.function.SupplierEx
- get() - Method in class com.hazelcast.jet.accumulator.LongAccumulator
-
Returns the current value.
- get() - Method in class com.hazelcast.jet.accumulator.MutableReference
-
Returns the current value.
- get() - Method in class com.hazelcast.jet.accumulator.PickAnyAccumulator
-
Returns the picked object.
- get() - Method in class com.hazelcast.spi.utils.RestClient
- get(byte) - Static method in enum class com.hazelcast.nio.serialization.FieldType
- get(int) - Method in class com.hazelcast.jet.core.ProcessorMetaSupplier.ExpectNothingProcessorSupplier
- get(int) - Method in interface com.hazelcast.jet.core.ProcessorSupplier
-
Called after
ProcessorSupplier.init(Context)
to retrieve instances ofProcessor
that will be used during the execution of the Jet job. - get(int) - Static method in enum class com.hazelcast.nio.serialization.FieldKind
- get(int) - Method in interface com.hazelcast.ringbuffer.ReadResultSet
-
Gets the item at the given index.
- get(int) - Method in interface com.hazelcast.security.Parameters
- get(Tag<E>) - Method in class com.hazelcast.jet.datamodel.ItemsByTag
-
Retrieves the value associated with the supplied tag and throws an exception if there is none.
- get(SearchOptions) - Method in record class com.hazelcast.vector.Hint
- get(Object) - Method in interface com.hazelcast.map.BaseMap
-
Returns the value for the specified key, or
null
if this map does not contain this key. - get(Object) - Method in interface com.hazelcast.map.IMap
-
Returns the value for the specified key, or
null
if this map does not contain this key. - get(Object) - Method in interface com.hazelcast.map.QueryCache
- get(Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
- get(Object) - Method in interface com.hazelcast.transaction.TransactionalMap
-
Transactional implementation of
IMap.get(Object)
. - get(Object, Class<T>) - Method in class com.hazelcast.spring.cache.HazelcastCache
- get(Object, Callable<T>) - Method in class com.hazelcast.spring.cache.HazelcastCache
- get(String) - Static method in enum class com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
- get(String) - Static method in enum class com.hazelcast.jet.cdc.Operation
-
Parses the string present in a CDC message into the corresponding
Operation
enum member. - get(String) - Method in class com.hazelcast.jet.core.metrics.JobMetrics
-
Returns all
Measurement
s associated with a given metric name. - get(String) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
- get(String) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
Returns the value for the given key.
- get(List<Address>) - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Called to create a mapping from member
Address
to theProcessorSupplier
that will be sent to that member. - get(List<Address>) - Method in class com.hazelcast.jet.core.ProcessorMetaSupplier.RandomMemberPms
- get(List<Address>) - Method in class com.hazelcast.jet.core.ProcessorMetaSupplier.SpecificMemberPms
- get(K) - Method in interface com.hazelcast.cp.CPMap
-
Gets the value associated with
key
- get(K) - Method in interface com.hazelcast.multimap.BaseMultiMap
-
Returns the collection of values associated with the key.
- get(K) - Method in interface com.hazelcast.multimap.MultiMap
-
Returns the collection of values associated with the key.
- get(K) - Method in interface com.hazelcast.transaction.TransactionalMultiMap
-
Returns the collection of values associated with the key.
- get(K, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Retrieves the mapped value of the given key using a custom
ExpiryPolicy
. - GET - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- GET_ALL - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- GET_ALL_SCHEDULED_FUTURES - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- GET_AND_PUT - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- GET_AND_REMOVE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- GET_AND_REPLACE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- GET_CONFIG - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- GET_CONFIGURED_REPLICA_COUNT - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- GET_DELAY - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- GET_DISTRIBUTED_OBJECTS - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- GET_ENTRY_VIEW - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- GET_FOR_UPDATE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- GET_RESULT - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- GET_STATISTICS - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- get1() - Method in class com.hazelcast.jet.accumulator.LongLongAccumulator
-
Returns the first value.
- get2() - Method in class com.hazelcast.jet.accumulator.LongLongAccumulator
-
Returns the second value.
- getAccessControlServiceConfig() - Method in class com.hazelcast.config.security.RealmConfig
-
Returns configured
AccessControlServiceConfig
. - getAcknowledgeType() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the strategy for when the target cluster should acknowledge that a WAN event batch has been processed.
- getActions() - Method in class com.hazelcast.config.PermissionConfig
- getActions() - Method in class com.hazelcast.security.permission.AllPermissions
- getActions() - Method in class com.hazelcast.security.permission.ConfigPermission
- getActions() - Method in class com.hazelcast.security.permission.InstancePermission
- getActions() - Method in class com.hazelcast.security.permission.ManagementPermission
- getActions() - Method in class com.hazelcast.security.permission.TransactionPermission
- getActiveMemberNetworkConfig(Config) - Static method in class com.hazelcast.config.ConfigAccessor
- getAddress() - Method in interface com.hazelcast.cluster.Member
-
Returns the Address of this Member.
- getAddress() - Method in class com.hazelcast.config.VaultSecureStoreConfig
-
Returns the Vault server address.
- getAddress() - Method in interface com.hazelcast.cp.CPMember
-
Returns the address of this CP member.
- getAddresses() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Returns the list of candidate addresses that client will use to establish initial connection
- getAddressMap() - Method in interface com.hazelcast.cluster.Member
- getAdvancedNetworkConfig() - Method in class com.hazelcast.config.Config
- getAlgorithm() - Method in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
-
Returns the encryption algorithm.
- getAll(Set<? extends K>, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Gets a collection of entries from the cache with custom expiry policy, returning them as
Map
of the values associated with the set of keys requested. - getAll(Set<K>) - Method in interface com.hazelcast.map.IMap
-
Returns an immutable map of entries for the given keys.
- getAll(Set<K>) - Method in interface com.hazelcast.map.QueryCache
- getAllDiscoveryConfigs() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
- getAllEndpointGroups() - Static method in enum class com.hazelcast.config.RestEndpointGroup
-
Deprecated.
- getAllGroupInformation() - Method in class com.hazelcast.cp.CPGroupsSnapshot
- getAllHazelcastClients() - Static method in class com.hazelcast.client.HazelcastClient
-
Gets an immutable collection of all client HazelcastInstances created in this JVM.
- getAllHazelcastInstances() - Static method in class com.hazelcast.core.Hazelcast
-
Returns all active/running HazelcastInstances on this JVM.
- getAllHazelcastInstances() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
-
Gets all active/running
HazelcastOSGiInstance
s on the owner bundle. - getAllocatorType() - Method in class com.hazelcast.config.NativeMemoryConfig
-
Returns the
NativeMemoryConfig.MemoryAllocatorType
to be used while allocating native memory. - getAllowedFutureMillis() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
- getAllScheduledFutures() - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
-
Fetches and returns all scheduled (not disposed yet) futures from all members in the cluster.
- getAllSessions(String) - Method in interface com.hazelcast.cp.session.CPSessionManagementService
-
Returns a non-null collection of CP sessions that are currently active in the given CP group.
- getAnchor() - Method in interface com.hazelcast.query.PagingPredicate
-
Retrieve the anchor object which is the last value object on the previous page.
- getAndAdd(long) - Method in interface com.hazelcast.cp.IAtomicLong
-
Atomically adds the given value to the current value.
- getAndAdd(long) - Method in interface com.hazelcast.crdt.pncounter.PNCounter
-
Adds the given value to the current value.
- getAndAddAsync(long) - Method in interface com.hazelcast.cp.IAtomicLong
-
Atomically adds the given value to the current value.
- getAndAlter(IFunction<E, E>) - Method in interface com.hazelcast.cp.IAtomicReference
-
Alters the currently stored reference by applying a function on it on and gets the old value.
- getAndAlter(IFunction<Long, Long>) - Method in interface com.hazelcast.cp.IAtomicLong
-
Alters the currently stored value by applying a function on it on and gets the old value.
- getAndAlterAsync(IFunction<E, E>) - Method in interface com.hazelcast.cp.IAtomicReference
-
Alters the currently stored reference by applying a function on it on and gets the old value.
- getAndAlterAsync(IFunction<Long, Long>) - Method in interface com.hazelcast.cp.IAtomicLong
-
Alters the currently stored value by applying a function on it on and gets the old value.
- getAndDecrement() - Method in interface com.hazelcast.cp.IAtomicLong
-
Atomically decrements the current value by one.
- getAndDecrement() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
-
Decrements by one the current value.
- getAndDecrementAsync() - Method in interface com.hazelcast.cp.IAtomicLong
-
Atomically decrements the current value by one.
- getAndIncrement() - Method in interface com.hazelcast.cp.IAtomicLong
-
Atomically increments the current value by one.
- getAndIncrement() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
-
Increments by one the current value.
- getAndIncrementAsync() - Method in interface com.hazelcast.cp.IAtomicLong
-
Atomically increments the current value by one.
- getAndPut(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Associates the specified value with the specified key in this cache using a custom
ExpiryPolicy
, returning an existing value if one existed. - getAndPutAsync(K, V) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously associates the specified value with the specified key in this cache, returning an existing value if one existed.
- getAndPutAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously associates the specified value with the specified key in this cache, returning an existing value if one existed using a custom
ExpiryPolicy
. - getAndRemoveAsync(K) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously removes the entry for a key and returns the previously assigned value or null if no value was assigned.
- getAndReplace(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Atomically replaces the assigned value of the given key by the specified value using a custom
ExpiryPolicy
and returns the previously assigned value. - getAndReplaceAsync(K, V) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously replaces the assigned value of the given key by the specified value and returns the previously assigned value.
- getAndReplaceAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously replaces the assigned value of the given key by the specified value using a custom
ExpiryPolicy
and returns the previously assigned value. - getAndRetainDataConnection(String, Class<T>) - Method in interface com.hazelcast.dataconnection.DataConnectionService
-
Returns
DataConnection
with the given name and `retain` it (callsDataConnection.retain()
). - getAndSet(long) - Method in interface com.hazelcast.cp.IAtomicLong
-
Atomically sets the given value and returns the old value.
- getAndSet(E) - Method in interface com.hazelcast.cp.IAtomicReference
-
Gets the old value and sets the new value.
- getAndSetAsync(long) - Method in interface com.hazelcast.cp.IAtomicLong
-
Atomically sets the given value and returns the old value.
- getAndSetAsync(E) - Method in interface com.hazelcast.cp.IAtomicReference
-
Gets the value and sets the new value.
- getAndSubtract(long) - Method in interface com.hazelcast.crdt.pncounter.PNCounter
-
Subtracts the given value from the current value.
- getAppendRequestBackoffTimeoutInMillis() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
- getAppendRequestMaxEntryCount() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
- getApUuid(CPMember) - Method in class com.hazelcast.cp.CPGroupsSnapshot
- getArgument(String) - Method in class com.hazelcast.jet.config.JobConfig
-
Returns the value to which the specified key is mapped, or null if there is no mapping for the key.
- getArrayOfBoolean(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getArrayOfChar(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
-
Supported only for
Portable
. - getArrayOfDate(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getArrayOfDecimal(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getArrayOfFloat32(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getArrayOfFloat64(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getArrayOfGenericRecord(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getArrayOfInt16(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getArrayOfInt32(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getArrayOfInt64(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getArrayOfInt8(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getArrayOfNullableBoolean(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
-
Supported only for
Compact
. - getArrayOfNullableFloat32(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
-
Supported only for
Compact
. - getArrayOfNullableFloat64(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
-
Supported only for
Compact
. - getArrayOfNullableInt16(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
-
Supported only for
Compact
. - getArrayOfNullableInt32(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
-
Supported only for
Compact
. - getArrayOfNullableInt64(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
-
Supported only for
Compact
. - getArrayOfNullableInt8(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
-
Supported only for
Compact
. - getArrayOfString(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getArrayOfTime(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getArrayOfTimestamp(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getArrayOfTimestampWithTimezone(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getAsync() - Method in interface com.hazelcast.cp.IAtomicLong
-
Gets the current value.
- getAsync() - Method in interface com.hazelcast.cp.IAtomicReference
-
Gets the current value.
- getAsync(K) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously retrieves the mapped value of the given key using a custom
ExpiryPolicy
. - getAsync(K) - Method in interface com.hazelcast.map.IMap
-
Asynchronously gets the given key.
- getAsync(K, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously gets an entry from cache using a custom
ExpiryPolicy
. - getAsyncBackupCount() - Method in class com.hazelcast.config.CacheConfig
-
Gets the number of asynchronous backups for this
ICache
. - getAsyncBackupCount() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the number of asynchronous backups for this
ICache
. - getAsyncBackupCount() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
Gets the number of synchronous backups.
- getAsyncBackupCount() - Method in class com.hazelcast.config.CollectionConfig
-
Gets the number of asynchronous backups.
- getAsyncBackupCount() - Method in class com.hazelcast.config.MapConfig
-
Returns the asynchronous backup count for this
IMap
. - getAsyncBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
-
Gets the number of asynchronous backups for this MultiMap.
- getAsyncBackupCount() - Method in class com.hazelcast.config.QueueConfig
-
Get the number of asynchronous backups for this queue.
- getAsyncBackupCount() - Method in class com.hazelcast.config.RingbufferConfig
-
Gets the number of asynchronous backups.
- getAsyncBackupCount() - Method in class com.hazelcast.config.vector.VectorCollectionConfig
-
Returns the asynchronous backup count for this
VectorCollection
. - getAtomicLong(String) - Method in interface com.hazelcast.cp.CPSubsystem
-
Returns a proxy for an
IAtomicLong
instance created on CP Subsystem. - getAtomicLong(String) - Method in class com.hazelcast.cp.CPSubsystemStubImpl
- getAtomicNumber() - Method in class com.hazelcast.console.ConsoleApp
- getAtomicReference(String) - Method in interface com.hazelcast.cp.CPSubsystem
-
Returns a proxy for an
IAtomicReference
instance created on CP Subsystem. - getAtomicReference(String) - Method in class com.hazelcast.cp.CPSubsystemStubImpl
- getAttribute() - Method in interface com.hazelcast.query.PredicateBuilder
- getAttribute(String) - Method in interface com.hazelcast.cluster.Member
-
Returns the value of the specified key for this member or null if value is undefined.
- getAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
- getAttribute(Node, String) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- getAttributeConfigs() - Method in class com.hazelcast.config.MapConfig
- getAttributeName() - Method in class com.hazelcast.config.PartitioningAttributeConfig
-
Returns the name of the attribute.
- getAttributes() - Method in interface com.hazelcast.cluster.Member
-
Returns configured attributes for this member.
This method might not be available on all native clients. - getAttributes() - Method in class com.hazelcast.config.IndexConfig
-
Gets index attributes.
- getAttributes() - Method in class com.hazelcast.config.MemberAttributeConfig
- getAuditlogConfig() - Method in class com.hazelcast.config.Config
- getAutoDetectionConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Returns the configuration of the Auto Detection discovery.
- getAutoDetectionConfig() - Method in class com.hazelcast.config.JoinConfig
- getAverageAge() - Method in interface com.hazelcast.collection.LocalQueueStats
-
Returns the average age of the items in this member.
- getAverageGetTime() - Method in interface com.hazelcast.cache.CacheStatistics
-
The mean time to execute gets.
- getAverageHitLatency() - Method in interface com.hazelcast.query.LocalIndexStats
-
Returns the average hit latency (in nanoseconds) for the index.
- getAverageHitSelectivity() - Method in interface com.hazelcast.query.LocalIndexStats
-
Returns the average selectivity of the hits served by the index.
- getAveragePutTime() - Method in interface com.hazelcast.cache.CacheStatistics
-
The mean time to execute puts.
- getAverageRemoveTime() - Method in interface com.hazelcast.cache.CacheStatistics
-
The mean time to execute removes.
- getAwsConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Returns the current
AwsConfig
. - getAwsConfig() - Method in class com.hazelcast.config.JoinConfig
- getAwsConfig() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the
AwsConfig
used by the discovery mechanism for this WAN publisher. - getAzureConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Returns the current
AzureConfig
. - getAzureConfig() - Method in class com.hazelcast.config.JoinConfig
- getAzureConfig() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the
AzureConfig
used by the discovery mechanism for this WAN publisher. - getBackupCount() - Method in class com.hazelcast.config.CacheConfig
-
Gets the number of synchronous backups for this
ICache
. - getBackupCount() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the number of synchronous backups for this
ICache
. - getBackupCount() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
Gets the number of synchronous backups.
- getBackupCount() - Method in class com.hazelcast.config.CollectionConfig
-
Gets the number of synchronous backups for this collection.
- getBackupCount() - Method in class com.hazelcast.config.DynamicConfigurationConfig
-
Returns backup count.
- getBackupCount() - Method in class com.hazelcast.config.MapConfig
-
Returns the backupCount for this
IMap
- getBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
-
Gets the number of synchronous backups for this MultiMap.
- getBackupCount() - Method in class com.hazelcast.config.QueueConfig
-
Get the number of synchronous backups for this queue.
- getBackupCount() - Method in class com.hazelcast.config.RingbufferConfig
-
Gets the number of synchronous backups.
- getBackupCount() - Method in class com.hazelcast.config.vector.VectorCollectionConfig
-
Returns the backupCount for this
VectorCollection
- getBackupCount() - Method in class com.hazelcast.jet.config.InstanceConfig
-
Deprecated.Returns the
number of backups
used for job metadata and snapshots. - getBackupCount() - Method in class com.hazelcast.jet.config.JetConfig
-
Returns the
number of backups
used for job metadata and snapshots. - getBackupCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the number of backups per entry.
- getBackupDir() - Method in class com.hazelcast.config.DynamicConfigurationConfig
-
Returns backup directory where declarative configuration backups will be kept.
- getBackupDir() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Deprecated.Base directory for hot backups.
- getBackupDir() - Method in class com.hazelcast.config.PersistenceConfig
-
Base directory for persistence backups.
- getBackupDirectory() - Method in interface com.hazelcast.persistence.PersistenceService
-
Returns the persistence backup directory.
- getBackupEntryCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the number of backup entries hold by this member.
- getBackupEntryMemoryCost() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns memory cost (number of bytes) of backup entries in this member.
- getBackupItemCount() - Method in interface com.hazelcast.collection.LocalQueueStats
-
Returns the number of backup items in this member.
- getBackupProcessor() - Method in interface com.hazelcast.map.EntryProcessor
-
Get the entry processor to be applied to backup entries.
- getBackupTaskStatus() - Method in interface com.hazelcast.persistence.PersistenceService
-
Returns the local backup task status (not the cluster backup status).
- getBaseDir() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Returns the base directory for persisting CP data.
- getBaseDir() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Deprecated.Base directory for all Hot Restart stores.
- getBaseDir() - Method in class com.hazelcast.config.LocalDeviceConfig
-
Base directory for this device.
- getBaseDir() - Method in class com.hazelcast.config.PersistenceConfig
-
Base directory for all Persistence stores.
- getBaseName(String) - Static method in class com.hazelcast.partition.strategy.StringPartitioningStrategy
- getBatchMaxDelayMillis() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the maximum amount of time in milliseconds to wait before sending a batch of events to target cluster, if
WanBatchPublisherConfig.getBatchSize()
of events have not arrived within this duration. - getBatchPublisherConfigs() - Method in class com.hazelcast.config.WanReplicationConfig
-
Returns the list of WAN publisher configurations using the built-in batching WAN implementation for this WAN replication.
- getBatchSize() - Method in class com.hazelcast.config.MergePolicyConfig
-
Returns the batch size, which will be used to determine the number of entries to be sent in a merge operation.
- getBatchSize() - Method in class com.hazelcast.config.QueryCacheConfig
-
After reaching this size, node sends buffered events to
QueryCache
. - getBatchSize() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the maximum batch size that can be sent to target cluster.
- getBindAddress() - Method in interface com.hazelcast.spi.MemberAddressProvider
-
What address should Hazelcast bind to.
- getBindAddress(EndpointQualifier) - Method in interface com.hazelcast.spi.MemberAddressProvider
- getBitmapIndexOptions() - Method in class com.hazelcast.config.IndexConfig
-
Provides access to index options specific to bitmap indexes.
- getBitsNodeId() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
- getBitsSequence() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
- getBlacklist() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
- getBlacklistedPrefixes() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Deprecated.Return currently configured blacklist prefixes.
- getBlockSize() - Method in class com.hazelcast.config.LocalDeviceConfig
-
Returns disk block/sector size in bytes.
- getBody() - Method in class com.hazelcast.spi.utils.RestClient.Response
- getBoolean(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
Returns the configured boolean value of a
HazelcastProperty
. - getBoolean(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getBTreeIndexConfig() - Method in class com.hazelcast.config.IndexConfig
-
Provides access to index options specific to B-Tree indexes.
- getBufferSize() - Method in class com.hazelcast.client.config.SocketOptions
-
Gets the SO_SNDBUF and SO_RCVBUF option value
- getBufferSize() - Method in class com.hazelcast.config.QueryCacheConfig
-
Returns the maximum number of events which can be stored in a buffer of partition.
- getById(byte) - Static method in enum class com.hazelcast.config.ConsistencyCheckStrategy
-
Returns the ConsistencyCheckStrategy for the given ID.
- getById(byte) - Static method in enum class com.hazelcast.config.ScheduledExecutorConfig.CapacityPolicy
- getById(int) - Static method in enum class com.hazelcast.cluster.ClusterState
- getById(int) - Static method in enum class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
- getById(int) - Static method in enum class com.hazelcast.config.EvictionPolicy
- getById(int) - Static method in enum class com.hazelcast.config.IndexType
-
Returns the IndexType as an enum.
- getById(int) - Static method in enum class com.hazelcast.config.InMemoryFormat
- getById(int) - Static method in enum class com.hazelcast.config.MaxSizePolicy
- getById(int) - Static method in enum class com.hazelcast.config.MetadataPolicy
-
Returns the MetadataPolicy for the given ID.
- getById(int) - Static method in enum class com.hazelcast.config.vector.Metric
-
Returns the Metric as an enum.
- getById(int) - Static method in enum class com.hazelcast.config.WanAcknowledgeType
-
Returns the
WanAcknowledgeType
for the given ID. - getById(int) - Static method in enum class com.hazelcast.jet.config.ResourceType
-
Returns the ResourceType for the given ID.
- getById(int) - Static method in enum class com.hazelcast.jet.core.JobStatus
- getById(int) - Static method in enum class com.hazelcast.memory.MemoryUnit
- getById(int) - Static method in enum class com.hazelcast.ringbuffer.OverflowPolicy
-
Returns the OverflowPolicy for the given ID.
- getById(int) - Static method in enum class com.hazelcast.sql.SqlColumnType
-
Returns the IndexType as an enum.
- getById(int) - Static method in enum class com.hazelcast.transaction.TransactionOptions.TransactionType
- getByteOrder() - Method in class com.hazelcast.config.SerializationConfig
-
Note that result of useNativeByteOrder is not reflected to return value of this method.
- getByteOrder() - Method in interface com.hazelcast.nio.ObjectDataInput
- getByteOrder() - Method in interface com.hazelcast.nio.ObjectDataOutput
- getByType(byte) - Static method in enum class com.hazelcast.wan.WanPublisherState
-
Returns the WanPublisherState as an enum.
- getByType(int) - Static method in enum class com.hazelcast.cache.CacheEventType
- getByType(int) - Static method in enum class com.hazelcast.config.WanQueueFullBehavior
-
Returns the WANQueueFullBehavior as an enum.
- getByType(int) - Static method in enum class com.hazelcast.core.EntryEventType
- getByType(int) - Static method in enum class com.hazelcast.core.ItemEventType
- getCache(String) - Method in interface com.hazelcast.core.ICacheManager
-
Returns the cache instance with the specified prefixed cache name.
- getCache(String) - Method in interface com.hazelcast.jet.JetCacheManager
-
Deprecated.since 5.0 Use
ICacheManager.getCache(String)
instead. - getCache(String) - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
- getCacheConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the CacheSimpleConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
- getCacheConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of cache configurations, mapped by config name.
- getCacheDeserializedValues() - Method in class com.hazelcast.config.MapConfig
-
Get current value cache settings
- getCacheEntryEventFilterFactory() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
- getCacheEntryListenerConfigurations() - Method in class com.hazelcast.config.AbstractCacheConfig
- getCacheEntryListenerFactory() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
- getCacheEntryListeners() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets a list of
CacheSimpleEntryListenerConfig
from thisICache
. - getCacheEvictions() - Method in interface com.hazelcast.cache.CacheStatistics
-
The total number of evictions from the cache.
- getCacheGets() - Method in interface com.hazelcast.cache.CacheStatistics
-
The total number of requests to the cache.
- getCacheHitPercentage() - Method in interface com.hazelcast.cache.CacheStatistics
-
This is a measure of cache efficiency.
- getCacheHits() - Method in interface com.hazelcast.cache.CacheStatistics
-
The number of get requests that were satisfied by the cache.
- getCacheLoader() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Get classname of a class to be used as
CacheLoader
. - getCacheLoaderFactory() - Method in class com.hazelcast.config.AbstractCacheConfig
- getCacheLoaderFactory() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the factory for the
CacheLoader
. - getCacheManager() - Method in class com.hazelcast.cache.HazelcastCachingProvider
- getCacheManager() - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
- getCacheManager() - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
- getCacheManager() - Method in interface com.hazelcast.core.HazelcastInstance
-
Obtain the
ICacheManager
that provides access to JSR-107 (JCache) caches configured on a Hazelcast cluster. - getCacheManager() - Method in interface com.hazelcast.jet.JetInstance
-
Deprecated.since 5.0 Use
HazelcastInstance.getCacheManager()
instead. - getCacheManager(HazelcastInstance, String, Properties) - Static method in class com.hazelcast.spring.cache.SpringHazelcastCachingProvider
-
Creates a
CacheManager
on an existing HazelcastInstance. - getCacheManager(String, Properties) - Static method in class com.hazelcast.spring.cache.SpringHazelcastCachingProvider
- getCacheManager(URI, ClassLoader) - Method in class com.hazelcast.cache.HazelcastCachingProvider
- getCacheManager(URI, ClassLoader) - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
- getCacheManager(URI, ClassLoader) - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
- getCacheManager(URI, ClassLoader, Properties) - Method in class com.hazelcast.cache.HazelcastCachingProvider
- getCacheManager(URI, ClassLoader, Properties) - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
- getCacheManager(URI, ClassLoader, Properties) - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
- getCacheMisses() - Method in interface com.hazelcast.cache.CacheStatistics
-
A miss is a get request that is not satisfied.
- getCacheMissPercentage() - Method in interface com.hazelcast.cache.CacheStatistics
-
Returns the percentage of cache accesses that did not find a requested entry in the cache.
- getCacheNames() - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
- getCacheNameWithPrefix(String) - Method in interface com.hazelcast.cache.HazelcastCacheManager
-
Gets the cache name by adding the manager prefix.
- getCachePuts() - Method in interface com.hazelcast.cache.CacheStatistics
-
The total number of puts to the cache.
- getCacheRemovals() - Method in interface com.hazelcast.cache.CacheStatistics
-
The total number of removals from the cache.
- getCacheWriter() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Get classname of a class to be used as
CacheWriter
. - getCacheWriterFactory() - Method in class com.hazelcast.config.AbstractCacheConfig
- getCacheWriterFactory() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the factory for the
CacheWriter
. - getCancelledTaskCount() - Method in interface com.hazelcast.executor.LocalExecutorStats
-
Returns the number of cancelled operations on the executor service.
- getCapacity() - Method in interface com.hazelcast.config.DeviceConfig
-
Returns the device capacity.
- getCapacity() - Method in class com.hazelcast.config.DurableExecutorConfig
-
Gets the ring buffer capacity of the executor task.
- getCapacity() - Method in class com.hazelcast.config.EventJournalConfig
-
Gets the capacity of the event journal.
- getCapacity() - Method in class com.hazelcast.config.LocalDeviceConfig
-
Returns the capacity of this device.
- getCapacity() - Method in class com.hazelcast.config.MemoryTierConfig
-
Returns the capacity of this memory tier.
- getCapacity() - Method in class com.hazelcast.config.NativeMemoryConfig
-
Returns size (capacity) of the native memory region.
- getCapacity() - Method in class com.hazelcast.config.RingbufferConfig
-
Gets the capacity of the ringbuffer.
- getCapacity() - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Gets the capacity of the executor
- getCapacity() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
-
Returns the capacity of this ringbuffer.
- getCapacityPolicy() - Method in class com.hazelcast.config.ScheduledExecutorConfig
- getCardinalityEstimator(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Obtain a
CardinalityEstimator
with the given name. - getCardinalityEstimatorConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the CardinalityEstimatorConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
- getCardinalityEstimatorConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of cardinality estimator configurations, mapped by config name.
- getCertificate() - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Return the location of the certificate in PEM format.
- getCertificatePrivateKey() - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Return the location of the private key for the certificate in PEM format.
- getChar(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
-
Supported only for
Portable
. - getCiphers() - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Return the supported SSL ciphers.
- getClassCacheMode() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Deprecated.Return the current ClassCacheMode
- getClassDefinitions() - 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.
- getClasses() - Method in class com.hazelcast.config.ClassFilter
-
Returns unmodifiable set of class names.
- getClassFilterConfig() - Method in class com.hazelcast.config.UserCodeNamespacesConfig
- getClassId() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
- getClassId() - Method in class com.hazelcast.cluster.Address
- getClassId() - Method in class com.hazelcast.config.AttributeConfig
- getClassId() - Method in class com.hazelcast.config.AwsConfig
- getClassId() - Method in class com.hazelcast.config.AzureConfig
- getClassId() - Method in class com.hazelcast.config.BitmapIndexOptions
- getClassId() - Method in class com.hazelcast.config.BTreeIndexConfig
- getClassId() - Method in class com.hazelcast.config.CacheConfig
- getClassId() - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
- getClassId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
- getClassId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
- getClassId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
- getClassId() - Method in class com.hazelcast.config.CacheSimpleConfig
- getClassId() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
- getClassId() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
- getClassId() - Method in class com.hazelcast.config.DataConnectionConfig
- getClassId() - Method in class com.hazelcast.config.DataPersistenceConfig
- getClassId() - Method in class com.hazelcast.config.DiscoveryConfig
- getClassId() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
- getClassId() - Method in class com.hazelcast.config.DiskTierConfig
- getClassId() - Method in class com.hazelcast.config.DurableExecutorConfig
- getClassId() - Method in class com.hazelcast.config.EntryListenerConfig
- getClassId() - Method in class com.hazelcast.config.EurekaConfig
- getClassId() - Method in class com.hazelcast.config.EventJournalConfig
- getClassId() - Method in class com.hazelcast.config.EvictionConfig
- getClassId() - Method in class com.hazelcast.config.ExecutorConfig
- getClassId() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
- getClassId() - Method in class com.hazelcast.config.GcpConfig
- getClassId() - Method in class com.hazelcast.config.HotRestartConfig
-
Deprecated.
- getClassId() - Method in class com.hazelcast.config.IndexConfig
- getClassId() - Method in class com.hazelcast.config.ItemListenerConfig
- getClassId() - Method in class com.hazelcast.config.KubernetesConfig
- getClassId() - Method in class com.hazelcast.config.ListConfig
- getClassId() - Method in class com.hazelcast.config.ListenerConfig
- getClassId() - Method in class com.hazelcast.config.MapConfig
- getClassId() - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
- getClassId() - Method in class com.hazelcast.config.MapStoreConfig
- getClassId() - Method in class com.hazelcast.config.MemoryTierConfig
- getClassId() - Method in class com.hazelcast.config.MergePolicyConfig
- getClassId() - Method in class com.hazelcast.config.MerkleTreeConfig
- getClassId() - Method in class com.hazelcast.config.MultiMapConfig
- getClassId() - Method in class com.hazelcast.config.NearCacheConfig
- getClassId() - Method in class com.hazelcast.config.NearCachePreloaderConfig
- getClassId() - Method in class com.hazelcast.config.PartitioningAttributeConfig
- getClassId() - Method in class com.hazelcast.config.PartitioningStrategyConfig
- getClassId() - Method in class com.hazelcast.config.PermissionConfig
- getClassId() - Method in class com.hazelcast.config.PNCounterConfig
- getClassId() - Method in class com.hazelcast.config.PredicateConfig
- getClassId() - Method in class com.hazelcast.config.QueryCacheConfig
- getClassId() - Method in class com.hazelcast.config.QueueConfig
- getClassId() - Method in class com.hazelcast.config.QueueStoreConfig
- getClassId() - Method in class com.hazelcast.config.ReliableTopicConfig
- getClassId() - Method in class com.hazelcast.config.ReplicatedMapConfig
- getClassId() - Method in class com.hazelcast.config.RingbufferConfig
- getClassId() - Method in class com.hazelcast.config.RingbufferStoreConfig
- getClassId() - Method in class com.hazelcast.config.ScheduledExecutorConfig
- getClassId() - Method in class com.hazelcast.config.SetConfig
- getClassId() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
- getClassId() - Method in class com.hazelcast.config.SplitBrainProtectionListenerConfig
- getClassId() - Method in class com.hazelcast.config.TieredStoreConfig
- getClassId() - Method in class com.hazelcast.config.TopicConfig
- getClassId() - Method in class com.hazelcast.config.UserCodeNamespaceConfig
- getClassId() - Method in class com.hazelcast.config.vector.VectorCollectionConfig
- getClassId() - Method in class com.hazelcast.config.vector.VectorIndexConfig
- getClassId() - Method in class com.hazelcast.config.WanBatchPublisherConfig
- getClassId() - Method in class com.hazelcast.config.WanConsumerConfig
- getClassId() - Method in class com.hazelcast.config.WanCustomPublisherConfig
- getClassId() - Method in class com.hazelcast.config.WanReplicationConfig
- getClassId() - Method in class com.hazelcast.config.WanReplicationRef
- getClassId() - Method in class com.hazelcast.config.WanSyncConfig
- getClassId() - Method in class com.hazelcast.jet.config.DeltaJobConfig
- getClassId() - Method in class com.hazelcast.jet.config.EdgeConfig
- getClassId() - Method in class com.hazelcast.jet.config.JobConfig
- getClassId() - Method in class com.hazelcast.jet.config.ResourceConfig
- getClassId() - Method in class com.hazelcast.jet.core.DAG
- getClassId() - Method in class com.hazelcast.jet.core.Edge
- getClassId() - Method in class com.hazelcast.jet.core.metrics.JobMetrics
- getClassId() - Method in class com.hazelcast.jet.core.metrics.Measurement
- getClassId() - Method in class com.hazelcast.jet.core.ProcessorMetaSupplier.ExpectNothingProcessorSupplier
- getClassId() - Method in class com.hazelcast.jet.core.ProcessorMetaSupplier.RandomMemberPms
- getClassId() - Method in class com.hazelcast.jet.core.ProcessorMetaSupplier.SpecificMemberPms
- getClassId() - Method in class com.hazelcast.jet.core.Vertex
- getClassId() - Method in class com.hazelcast.jet.JobStatusEvent
- getClassId() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Deprecated.Returns the class ID.
- getClassId() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
Deprecated.
- getClassId() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
- getClassId() - Method in interface com.hazelcast.nio.serialization.IdentifiedDataSerializable
-
Returns type identifier for this class.
- getClassId() - Method in interface com.hazelcast.nio.serialization.Portable
-
Deprecated.Returns class identifier for this portable class.
- getClassId() - Method in class com.hazelcast.nio.serialization.PortableId
-
Deprecated.
- getClassId() - Method in class com.hazelcast.security.SimpleTokenCredentials
- getClassId() - Method in class com.hazelcast.security.UsernamePasswordCredentials
- getClassId() - Method in class com.hazelcast.spi.merge.DiscardMergePolicy
- getClassId() - Method in class com.hazelcast.spi.merge.ExpirationTimeMergePolicy
- getClassId() - Method in class com.hazelcast.spi.merge.HigherHitsMergePolicy
- getClassId() - Method in class com.hazelcast.spi.merge.HyperLogLogMergePolicy
- getClassId() - Method in class com.hazelcast.spi.merge.LatestAccessMergePolicy
- getClassId() - Method in class com.hazelcast.spi.merge.LatestUpdateMergePolicy
- getClassId() - Method in class com.hazelcast.spi.merge.PassThroughMergePolicy
- getClassId() - Method in class com.hazelcast.spi.merge.PutIfAbsentMergePolicy
- getClassId() - Method in class com.hazelcast.version.MemberVersion
- getClassId() - Method in class com.hazelcast.version.Version
- getClassLoader() - Method in class com.hazelcast.client.config.ClientConfig
-
Gets the classLoader
- getClassLoader() - Method in class com.hazelcast.config.Config
-
Returns the class-loader that will be used in serialization.
- getClassLoader() - Method in interface com.hazelcast.nio.ObjectDataInput
-
Returns class loader that internally used for objects.
- getClassLoaderFactory() - Method in class com.hazelcast.jet.config.JobConfig
-
Returns the configured
JobClassLoaderFactory
. - getClassName() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
- getClassName() - Method in class com.hazelcast.config.AbstractWanPublisherConfig
-
Returns the name of the class implementing
WanPublisher
. - getClassName() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
- getClassName() - Method in class com.hazelcast.config.CredentialsFactoryConfig
- getClassName() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
- getClassName() - Method in class com.hazelcast.config.GlobalSerializerConfig
- getClassName() - Method in class com.hazelcast.config.ListenerConfig
-
Returns the name of the class of the EventListener.
- getClassName() - Method in class com.hazelcast.config.LoginModuleConfig
- getClassName() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns the name of the MapStore implementation class
- getClassName() - Method in class com.hazelcast.config.MemberAddressProviderConfig
- getClassName() - Method in class com.hazelcast.config.PermissionPolicyConfig
- getClassName() - Method in class com.hazelcast.config.PredicateConfig
-
Returns the name of the class of the Predicate.
- getClassName() - Method in class com.hazelcast.config.QueueStoreConfig
-
Returns the class name of the queue store implementation to be used when instantiating the queue store.
- getClassName() - Method in class com.hazelcast.config.RingbufferStoreConfig
- getClassName() - Method in class com.hazelcast.config.SecurityInterceptorConfig
- getClassName() - Method in class com.hazelcast.config.SerializerConfig
-
Returns the class name of the serializer implementation.
- getClassName() - Method in class com.hazelcast.config.ServiceConfig
- getClassName() - Method in class com.hazelcast.config.SocketInterceptorConfig
-
Returns the name of the
SocketInterceptor
implementation class. - getClassName() - Method in class com.hazelcast.config.WanConsumerConfig
-
Returns the fully qualified class name of the class implementing
WanConsumer
. - getClassNames() - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
-
Deprecated.
- getClassType() - Method in interface com.hazelcast.nio.serialization.TypedDataSerializable
- getClassVersion() - Method in interface com.hazelcast.nio.serialization.VersionedPortable
-
Deprecated.Returns version for this Portable class
- getClient() - Method in class com.hazelcast.dataconnection.HazelcastDataConnection
-
Return a client
HazelcastInstance
based on this data connection configuration. - getClient() - Method in class com.hazelcast.jet.mongodb.dataconnection.MongoDataConnection
-
Returns an instance of
MongoClient
. - getClientAuth() - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Return Whether client authentication is not wanted ("none"), wanted ("want") or needed ("need").
- getClientBlockUnmappedActions() - Method in class com.hazelcast.config.SecurityConfig
- getClientConfigs() - Method in class com.hazelcast.client.config.ClientFailoverConfig
-
Gets the configured list of alternative client configurations.
- getClientIcmpPingConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
ICMP ping is used to detect if machine that a remote hazelcast member runs on alive or not
- getClientPermissionConfigs() - Method in class com.hazelcast.config.SecurityConfig
- getClientPermissionConfigs() - Method in interface com.hazelcast.security.SecurityService
-
Returns latest client permission configuration.
- getClientPolicyConfig() - Method in class com.hazelcast.config.SecurityConfig
- getClientRealm() - Method in class com.hazelcast.config.SecurityConfig
- getClientService() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the client service of this Hazelcast instance.
- getClientType() - Method in interface com.hazelcast.client.Client
-
Type could be a client type from
ConnectionType
or it can be a custom client implementation with a name outside of this @{link ConnectionType} - getCloudConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
- getCluster() - Method in class com.hazelcast.cluster.InitialMembershipEvent
-
Returns the cluster of the event.
- getCluster() - Method in class com.hazelcast.cluster.MembershipEvent
-
Returns the cluster of the event.
- getCluster() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the Cluster that this Hazelcast instance is part of.
- getCluster() - Method in interface com.hazelcast.jet.JetInstance
-
Deprecated.since 5.0 Use
HazelcastInstance.getCluster()
instead. - getClusterConnectTimeoutMillis() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
-
Timeout value in milliseconds for the client to give up to connect to the current cluster Depending on FailoverConfig, a client can shut down or start trying on alternative clusters after reaching the timeout.
- getClusterDataRecoveryPolicy() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Deprecated.Returns the policy to be used when the cluster is started
- getClusterDataRecoveryPolicy() - Method in class com.hazelcast.config.PersistenceConfig
-
Returns the policy to be used when the cluster is started
- getClusterName() - Method in class com.hazelcast.client.config.ClientConfig
-
Returns the configured cluster name.
- getClusterName() - Method in class com.hazelcast.config.Config
-
Returns the cluster name uniquely identifying the hazelcast cluster.
- getClusterName() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the cluster name used as a publisher cluster name for authentication on the target endpoint.
- getClusterRoutingConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
- getClusterState() - Method in interface com.hazelcast.cluster.Cluster
-
Returns the state of the cluster.
- getClusterTime() - Method in interface com.hazelcast.cluster.Cluster
-
Returns the cluster-wide time in milliseconds.
- getClusterVersion() - Method in interface com.hazelcast.cluster.Cluster
-
The cluster version indicates the operating version of the cluster.
- getCode() - Method in enum class com.hazelcast.config.RestEndpointGroup
-
Deprecated.
- getCode() - Method in class com.hazelcast.spi.utils.RestClient.Response
- getCode() - Method in class com.hazelcast.spi.utils.RestClient.WatchResponse
- getCode() - Method in exception com.hazelcast.sql.HazelcastSqlException
-
Gets the internal error code associated with the exception.
- getCollectionFrequencySeconds() - Method in class com.hazelcast.config.BaseMetricsConfig
-
Returns the metrics collection frequency in seconds.
- getColumn(int) - Method in class com.hazelcast.sql.SqlRowMetadata
-
Gets column metadata.
- getColumnCount() - Method in class com.hazelcast.sql.SqlRowMetadata
-
Gets the number of columns in the row.
- getColumns() - Method in class com.hazelcast.sql.SqlRowMetadata
-
Gets columns metadata.
- getCommitIndexAdvanceCountToSnapshot() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
- getCompactClass() - Method in class com.hazelcast.jet.mongodb.compact.ObjectIdCompactSerializer
- getCompactClass() - Method in interface com.hazelcast.nio.serialization.compact.CompactSerializer
- getCompactSerializableClassNames(CompactSerializationConfig) - Static method in class com.hazelcast.config.CompactSerializationConfigAccessor
-
Returns the list of Compact serializable class names.
- getCompactSerializationConfig() - Method in class com.hazelcast.config.SerializationConfig
- getComparator() - Method in class com.hazelcast.config.EvictionConfig
-
Returns the instance of the configured
EvictionPolicyComparator
implementation. - getComparator() - Method in interface com.hazelcast.query.PagingPredicate
-
Returns the comparator used by this predicate (if any).
- getComparatorClassName() - Method in class com.hazelcast.config.EvictionConfig
-
Returns the class name of the configured
EvictionPolicyComparator
implementation. - getCompleted() - Method in class com.hazelcast.persistence.BackupTaskStatus
- getCompletedMigrations() - Method in interface com.hazelcast.partition.MigrationState
-
Returns the number of completed migrations in the migration plan.
- getCompletedTaskCount() - Method in interface com.hazelcast.executor.LocalExecutorStats
-
Returns the number of completed operations on the executor service.
- getConfig() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the configuration of this Hazelcast instance.
- getConfig() - Method in interface com.hazelcast.dataconnection.DataConnection
-
Returns the configuration of this DataConnection.
- getConfig() - Method in class com.hazelcast.dataconnection.DataConnectionBase
- getConfig() - Method in class com.hazelcast.jet.core.Edge
-
Returns the
EdgeConfig
instance associated with this edge. - getConfig() - Method in interface com.hazelcast.jet.JetService
-
Returns the configuration for this Jet member.
- getConfig() - Method in interface com.hazelcast.jet.Job
-
Returns the configuration this job was submitted with.
- getConfig() - Method in class com.hazelcast.spi.properties.HazelcastProperties
- getConfigClassLoader() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
- getConfigObject() - Method in class com.hazelcast.config.ServiceConfig
- getConfigPatternMatcher() - Method in class com.hazelcast.client.config.ClientConfig
-
Returns the pattern matcher which is used to match item names to configuration objects.
- getConfigPatternMatcher() - Method in class com.hazelcast.config.Config
-
Returns the pattern matcher which is used to match item names to configuration objects.
- getConfigRoot() - Method in class com.hazelcast.client.config.YamlClientConfigBuilder
- getConfigRoot() - Method in class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
- getConfigRoot() - Method in class com.hazelcast.config.AbstractYamlConfigBuilder
- getConfigRoot() - Method in class com.hazelcast.config.YamlConfigBuilder
- getConfigType() - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
- getConfigType() - Method in class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
- getConfigType() - Method in class com.hazelcast.config.AbstractXmlConfigBuilder
- getConfigType() - Method in class com.hazelcast.config.AbstractXmlConfigHelper
- getConfigType() - Method in class com.hazelcast.config.XmlConfigBuilder
- getConfigurationFile() - Method in class com.hazelcast.config.Config
- getConfigurationProperties() - Method in class com.hazelcast.aws.AwsDiscoveryStrategyFactory
- getConfigurationProperties() - Method in class com.hazelcast.azure.AzureDiscoveryStrategyFactory
- getConfigurationProperties() - Method in class com.hazelcast.gcp.GcpDiscoveryStrategyFactory
- getConfigurationProperties() - Method in class com.hazelcast.kubernetes.HazelcastKubernetesDiscoveryStrategyFactory
- getConfigurationProperties() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategyFactory
-
Returns a set of the expected configuration properties.
- getConfigurationProperties() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategyFactory
- getConfigurationUrl() - Method in class com.hazelcast.config.Config
- getConfiguredCapacity() - Method in interface com.hazelcast.jet.Observable
-
Returns the configured capacity of the underlying
Ringbuffer
.. - getConnectedClients() - Method in interface com.hazelcast.client.ClientService
-
Returns all connected clients to this member.
- getConnectionCount() - Method in class com.hazelcast.client.config.ClientTpcConfig
-
Gets the connection count.
- getConnectionRetryConfig() - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
-
Connection Retry Config is controls the period among the retries and when should a client gave up retrying.
- getConnectionStrategyConfig() - Method in class com.hazelcast.client.config.ClientConfig
- getConnectionTimeout() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Timeout value in millis for nodes to accept client connection requests.
- getConnectionTimeoutSeconds() - Method in class com.hazelcast.config.TcpIpConfig
-
Returns the connection timeout.
- getConsistencyCheckStrategy() - Method in class com.hazelcast.config.WanSyncConfig
-
Returns the strategy for checking consistency of data between source and target cluster.
- getConstantPartitioningKey() - Method in interface com.hazelcast.jet.core.Partitioner
- getConsumerConfig() - Method in class com.hazelcast.config.WanReplicationConfig
-
Returns the
WAN consumer configuration
for this WAN replication. - getCooperativeThreadCount() - Method in class com.hazelcast.jet.config.InstanceConfig
-
Deprecated.Returns the number of cooperative execution threads.
- getCooperativeThreadCount() - Method in class com.hazelcast.jet.config.JetConfig
-
Returns the number of cooperative execution threads.
- getCost() - Method in interface com.hazelcast.core.EntryView
-
Returns the cost (in bytes) of the entry.
- getCost() - Method in interface com.hazelcast.spi.merge.MergingCosts
-
Returns the memory cost of the merge data.
- getCount() - Method in interface com.hazelcast.cp.ICountDownLatch
-
Returns the current count.
- getCountDownLatch(String) - Method in interface com.hazelcast.cp.CPSubsystem
-
Returns a proxy for an
ICountDownLatch
instance created on CP Subsystem. - getCountDownLatch(String) - Method in class com.hazelcast.cp.CPSubsystemStubImpl
- getCPGroup(String) - Method in interface com.hazelcast.cp.CPSubsystemManagementService
-
Returns the active CP group with the given name.
- getCPGroupIds() - Method in interface com.hazelcast.cp.CPSubsystem
-
Returns all active CP group ids.
- getCPGroupIds() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
-
Returns all active CP group ids.
- getCPGroupIds() - Method in class com.hazelcast.cp.CPSubsystemStubImpl
- getCpMapConfigs() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Returns the map of
CPMap
configurations - getCPMapLimit() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Gets the limit of
CPMap
instances that are permitted to be created. - getCPMemberCount() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Returns the number of CP members that will initialize CP Subsystem.
- getCPMemberPriority() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Returns the CP member priority.
- getCPMembers() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
-
Returns the current list of CP members
- getCPSessionManagementService() - Method in interface com.hazelcast.cp.CPSubsystem
-
Returns the
CPSessionManagementService
of this Hazelcast instance. - getCPSessionManagementService() - Method in class com.hazelcast.cp.CPSubsystemStubImpl
- getCPSubsystem() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the CP subsystem that offers a set of in-memory linearizable data structures
- getCPSubsystemConfig() - Method in class com.hazelcast.config.Config
-
Get current configuration for the CP subsystem
- getCPSubsystemManagementService() - Method in interface com.hazelcast.cp.CPSubsystem
-
Returns the
CPSubsystemManagementService
of this Hazelcast instance. - getCPSubsystemManagementService() - Method in class com.hazelcast.cp.CPSubsystemStubImpl
- getCpToApUuids() - Method in class com.hazelcast.cp.CPGroupsSnapshot
- getCRDTReplicationConfig() - Method in class com.hazelcast.config.Config
- getCreationTime() - Method in interface com.hazelcast.cache.CacheStatistics
-
Gets the cache creation time.
- getCreationTime() - Method in interface com.hazelcast.core.EntryView
-
Returns the creation time of the entry.
- getCreationTime() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the creation time of this map on this member.
- getCreationTime() - Method in interface com.hazelcast.nearcache.NearCacheStats
- getCreationTime() - Method in interface com.hazelcast.spi.eviction.EvictableEntryView
-
Gets the creation time of this
EvictableEntryView
in milliseconds. - getCreationTime() - Method in interface com.hazelcast.spi.merge.MergingCreationTime
-
Returns the creation time of the merge data.
- getCreationTime() - Method in interface com.hazelcast.topic.LocalTopicStats
-
Returns the creation time of this topic on this member
- getCredentials() - Method in class com.hazelcast.config.security.CredentialsIdentityConfig
- getCredentialsFactory() - Method in interface com.hazelcast.security.SecurityContext
-
Returns current
ICredentialsFactory
. - getCredentialsFactoryConfig() - Method in class com.hazelcast.client.config.ClientSecurityConfig
- getCredentialsFactoryConfig() - Method in class com.hazelcast.config.security.RealmConfig
- getCredentialsIdentityConfig() - Method in class com.hazelcast.client.config.ClientSecurityConfig
- getCredentialsIdentityConfig() - Method in class com.hazelcast.config.security.RealmConfig
- getCurrentGroupsSnapshot() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
-
Creates a
CPGroupsSnapshot
based on the internal CP group view tracker's current view of all groups. - getCurrentKeyAlias() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
-
Returns the alias for the current encryption key entry or
null
if no alias is set. - getCurrentMembers() - Method in class com.hazelcast.splitbrainprotection.SplitBrainProtectionEvent
-
Returns the snapshot of member list at the time split brain protection happened
- getCurrentModuleClasses(String) - Static method in class com.hazelcast.test.archunit.ModuleImportOptions
- getCurrentModuleTestClasses(String) - Static method in class com.hazelcast.test.archunit.ModuleImportOptions
- getCurrentReplicas() - Method in class com.hazelcast.kubernetes.RuntimeContext
- getCurrentWatermark() - Method in interface com.hazelcast.jet.core.WatermarkPolicy
-
Called to get the current watermark.
- getCursorBufferSize() - Method in class com.hazelcast.sql.SqlStatement
-
Gets the cursor buffer size (measured in the number of rows).
- getCustomClassPaths() - Method in class com.hazelcast.jet.config.JobConfig
-
Returns configured custom classpath elements, See
JobConfig.addCustomClasspath(String, String)
andJobConfig.addCustomClasspaths(String, List)
- getCustomPublisherConfigs() - Method in class com.hazelcast.config.WanReplicationConfig
-
Returns the list of custom WAN publisher implementations for this WAN replication.
- getDatabaseName() - Method in class com.hazelcast.jet.mongodb.dataconnection.MongoDataConnection
-
Returns the database name hint.
- getDataConnectionConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the data connection configuration for the given name, creating one if necessary and adding it to the collection of known configurations.
- getDataConnectionConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of data connection configurations, mapped by config name.
- getDataLoadTimeoutSeconds() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Returns the timeout duration for CP members to restore their data from stable storage.
- getDataLoadTimeoutSeconds() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Deprecated.Returns configured data load timeout for hot-restart process.
- getDataLoadTimeoutSeconds() - Method in class com.hazelcast.config.PersistenceConfig
-
Returns configured data load timeout for persistence restart process.
- getDataPersistenceConfig() - Method in class com.hazelcast.config.AbstractCacheConfig
-
Gets the
PersistConfig
for thisCacheConfiguration
- getDataPersistenceConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the
DataPersistenceConfig
for thisCacheSimpleConfig
- getDataPersistenceConfig() - Method in class com.hazelcast.config.MapConfig
-
Gets the
DataPersistenceConfig
for thisMapConfig
- getDataSerializableFactories() - Method in class com.hazelcast.config.SerializationConfig
- getDataSerializableFactoryClasses() - Method in class com.hazelcast.config.SerializationConfig
- getDate(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getDecimal(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getDefault() - Static method in class com.hazelcast.transaction.TransactionOptions
-
Creates a new TransactionOptions configured with default settings.
- getDefaultClassLoader() - Method in class com.hazelcast.cache.HazelcastCachingProvider
- getDefaultClassLoader() - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
- getDefaultClassLoader() - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
- getDefaultEdgeConfig() - Method in class com.hazelcast.jet.config.JetConfig
-
Returns the default DAG edge configuration.
- getDefaultHazelcastInstance() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
-
Gets the default
HazelcastOSGiInstance
. - getDefaultProperties() - Method in class com.hazelcast.cache.HazelcastCachingProvider
- getDefaultProperties() - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
- getDefaultProperties() - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
- getDefaultReadTimeout() - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
-
Return default cache value retrieval timeout in milliseconds.
- getDefaultURI() - Method in class com.hazelcast.cache.HazelcastCachingProvider
- getDefaultURI() - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
- getDefaultURI() - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
- getDefaultValue() - Method in class com.hazelcast.spi.properties.HazelcastProperty
-
Returns the default value of the property.
- getDelaySeconds() - Method in class com.hazelcast.config.QueryCacheConfig
-
Returns the minimum number of delay seconds which an event waits in the buffer of node before sending to a
QueryCache
- getDelegatedInstance() - Method in interface com.hazelcast.osgi.HazelcastOSGiInstance
-
Gets the delegated (underlying)
HazelcastInstance
. - getDeprecatedName() - Method in class com.hazelcast.spi.properties.HazelcastProperty
- getDepth() - Method in class com.hazelcast.config.MerkleTreeConfig
-
Returns the depth of the merkle tree.
- getDescription() - Method in class com.hazelcast.jet.JobStatusEvent
-
If the event is generated by the user, indicates the action; if there is a failure, indicates the cause; otherwise, null.
- getDeserializedValue() - Method in interface com.hazelcast.spi.merge.MergingValue
-
Returns the merging value in deserialized form.
- getDestination() - Method in class com.hazelcast.jet.core.Edge
-
Returns this edge's destination vertex.
- getDestination() - Method in interface com.hazelcast.partition.ReplicaMigrationEvent
-
Returns the new owner of the migrating partition replica.
- getDestName() - Method in class com.hazelcast.jet.core.Edge
-
Returns the name of the destination vertex.
- getDestOrdinal() - Method in class com.hazelcast.jet.core.Edge
-
Returns the ordinal of the edge at the destination vertex.
- getDestroyContextForTenant() - Method in interface com.hazelcast.core.DistributedObject
-
Returns a hook which can be used by tenant control implementation to clean up resources once a tenant is destroyed.
- getDeviceConfig(Class<T>, String) - Method in class com.hazelcast.config.Config
-
Returns the device config mapped by the provided device name.
- getDeviceConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the device config mapped by the provided device name.
- getDeviceConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of
LocalDeviceConfig
s mapped by device name. - getDeviceName() - Method in class com.hazelcast.config.DiskTierConfig
-
Returns the device name of this disk tier.
- getDifferentialPartitionReplicationCount() - Method in interface com.hazelcast.partition.LocalReplicationStats
- getDifferentialReplicationRecordCount() - Method in interface com.hazelcast.partition.LocalReplicationStats
- getDimension() - Method in class com.hazelcast.config.vector.VectorIndexConfig
-
Retrieves the dimension of this vector index configuration.
- getDirectory() - Method in class com.hazelcast.config.NearCachePreloaderConfig
- getDirectory() - Method in class com.hazelcast.config.PersistentMemoryDirectoryConfig
-
Returns the directory of this
PersistentMemoryDirectoryConfig
. - getDirectoryConfigs() - Method in class com.hazelcast.config.PersistentMemoryConfig
-
Returns the persistent memory directory configurations to be used to store memory structures allocated by native memory manager.
- getDirtyEntryCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the number of entries that the member owns and are dirty (updated but not persisted yet).
- getDiscoveryConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Returns the configuration of the Hazelcast Discovery SPI and configured discovery providers
- getDiscoveryConfig() - Method in class com.hazelcast.config.JoinConfig
-
Returns the currently defined
DiscoveryConfig
- getDiscoveryConfig() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the currently defined
DiscoveryConfig
used by the discovery mechanism for this WAN publisher. - getDiscoveryConfig() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
- getDiscoveryMode() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
- getDiscoveryNode() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
- getDiscoveryPeriodSeconds() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the period in seconds in which WAN tries to discover new target endpoints and reestablish connections to failed endpoints.
- getDiscoveryServiceProvider() - Method in class com.hazelcast.config.DiscoveryConfig
- getDiscoveryStrategyConfigs() - Method in class com.hazelcast.config.DiscoveryConfig
-
Returns the defined
DiscoveryStrategy
configurations. - getDiscoveryStrategyFactory() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
- getDiscoveryStrategyType() - Method in class com.hazelcast.aws.AwsDiscoveryStrategyFactory
- getDiscoveryStrategyType() - Method in class com.hazelcast.azure.AzureDiscoveryStrategyFactory
- getDiscoveryStrategyType() - Method in class com.hazelcast.gcp.GcpDiscoveryStrategyFactory
- getDiscoveryStrategyType() - Method in class com.hazelcast.kubernetes.HazelcastKubernetesDiscoveryStrategyFactory
- getDiscoveryStrategyType() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategyFactory
-
Returns the type of the
DiscoveryStrategy
itself. - getDiscoveryStrategyType() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategyFactory
- getDiscoveryToken() - Method in class com.hazelcast.client.config.ClientCloudConfig
-
hazelcast.cloud discoveryToken of your cluster
- getDiskTierConfig() - Method in class com.hazelcast.config.TieredStoreConfig
-
Returns the disk tier config of this tiered-store configuration.
- getDistributedObject() - Method in class com.hazelcast.core.DistributedObjectEvent
-
Returns the DistributedObject instance.
- getDistributedObject(String, String) - Method in interface com.hazelcast.core.HazelcastInstance
- getDistributedObjectName(String) - Static method in class com.hazelcast.cache.CacheUtil
-
Convenience method to obtain the name of Hazelcast distributed object corresponding to the cache identified by the given
cacheName
, assumingnull URI
andClassLoader
prefixes. - getDistributedObjectName(String, URI, ClassLoader) - Static method in class com.hazelcast.cache.CacheUtil
-
Convenience method to obtain the name of Hazelcast distributed object corresponding to the cache identified by the given arguments.
- getDistributedObjects() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns all
DistributedObject
s, that is all maps, queues, topics, locks etc. - getDistributedTo() - Method in class com.hazelcast.jet.core.Edge
-
Possible return values: null - route only to local members (after a
Edge.local()
call) "255.255.255.255:0 - route to all members (after aEdge.distributed()
call) else - route to specific member (after aEdge.distributeTo(com.hazelcast.cluster.Address)
call) - getDouble() - Method in class com.hazelcast.jet.accumulator.LongDoubleAccumulator
-
Returns the
double
value. - getDouble(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
Returns the configured double value of a
HazelcastProperty
. - getDroppedCount() - Method in class com.hazelcast.wan.WanEventCounters.DistributedObjectWanEventCounters
-
Returns the number of dropped entry events
- getDurability() - Method in class com.hazelcast.config.DurableExecutorConfig
-
Gets the durability of the executor
- getDurability() - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Gets the durability of the executor
- getDurability() - Method in class com.hazelcast.transaction.TransactionOptions
-
Gets the transaction durability.
- getDurableExecutorConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the DurableExecutorConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
- getDurableExecutorConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of durable executor configurations, mapped by config name.
- getDurableExecutorService(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates or returns the durable executor service for the given name.
- getDurationAmount() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
- getDurationConfig() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
- getDynamicConfigurationConfig() - Method in class com.hazelcast.config.Config
-
Returns the dynamic configuration config.
- getEfConstruction() - Method in class com.hazelcast.config.vector.VectorIndexConfig
-
Retrieves the size of the dynamic list search to use during index time.
- getElapsedTime() - Method in interface com.hazelcast.partition.ReplicaMigrationEvent
-
Returns the elapsed the time of this migration in milliseconds.
- getEmptyPollOperationCount() - Method in interface com.hazelcast.collection.LocalQueueStats
-
Returns number of null returning poll operations.
- getEmptyQueueTtl() - Method in class com.hazelcast.config.QueueConfig
-
Returns the TTL (time to live) for emptying the Queue.
- getEnabled() - Method in class com.hazelcast.config.MerkleTreeConfig
-
Returns if the merkle tree is enabled.
- getEnabledGroups() - Method in class com.hazelcast.config.RestApiConfig
-
Deprecated.Returns a not-
null
set of enabled REST endpoint groups. - getEnabledGroups() - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.Returns a not-
null
set of enabled REST endpoint groups. - getEnabledProtocols() - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Return the enabled SSL protocols.
- getEncoding() - Method in class com.hazelcast.config.security.TokenIdentityConfig
- getEncodingForBytes(byte[]) - Static method in enum class com.hazelcast.config.security.TokenEncoding
- getEncryptionAtRestConfig() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Deprecated.Returns the Hot Restart Encryption at Rest configuration.
- getEncryptionAtRestConfig() - Method in class com.hazelcast.config.PersistenceConfig
-
Returns the Persistence Encryption at Rest configuration.
- getEndpoint() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the WAN endpoint configuration qualifier.
- getEndpointConfigs() - Method in class com.hazelcast.config.AdvancedNetworkConfig
- getEndpoints() - Method in class com.hazelcast.config.PermissionConfig
- getEndpointsByNameUrlString() - Method in class com.hazelcast.kubernetes.KubernetesApiEndpointSlicesProvider
- getEndpointsByServiceLabelUrlString() - Method in class com.hazelcast.kubernetes.KubernetesApiEndpointSlicesProvider
- getEndpointsUrlString() - Method in class com.hazelcast.kubernetes.KubernetesApiEndpointSlicesProvider
- getEntryListenerConfigs() - Method in class com.hazelcast.config.MapConfig
- getEntryListenerConfigs() - Method in class com.hazelcast.config.MultiMapConfig
-
Gets the list of entry listeners (listens for when entries are added or removed) for this MultiMap.
- getEntryListenerConfigs() - Method in class com.hazelcast.config.QueryCacheConfig
- getEntryObject() - Method in interface com.hazelcast.query.PredicateBuilder
- getEntrySetCallsCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the number of
Map#entrySet
calls - getEntryView(K) - Method in interface com.hazelcast.map.IMap
-
Returns the
EntryView
for the specified key. - getEnum(HazelcastProperty, Class<E>) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
Returns the configured enum value of a
ClusterProperty
. - getEpochStart() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
- getEurekaConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Returns the current
EurekaConfig
. - getEurekaConfig() - Method in class com.hazelcast.config.JoinConfig
- getEurekaConfig() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the
EurekaConfig
used by the discovery mechanism for this WAN publisher. - getEventCounterMap() - Method in class com.hazelcast.wan.WanEventCounters
-
Returns a map from distributed object name to
WanEventCounters.DistributedObjectWanEventCounters
. - getEventJournalConfig() - Method in class com.hazelcast.config.AbstractCacheConfig
-
Gets the
EventJournalConfig
for thisCacheConfiguration
- getEventJournalConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the
EventJournalConfig
for thisCacheSimpleConfig
- getEventJournalConfig() - Method in class com.hazelcast.config.MapConfig
-
Gets the
EventJournalConfig
for thisMapConfig
- getEventloopCount() - Method in class com.hazelcast.config.tpc.TpcConfig
-
Gets the number of eventloops.
- getEventObject() - Method in interface com.hazelcast.wan.WanEvent
-
Returns the event object/data.
- getEventOperationCount() - Method in interface com.hazelcast.collection.LocalQueueStats
-
Returns number of event operations
- getEventOperationCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the number of Events Received
- getEventSource() - Method in interface com.hazelcast.partition.PartitionLostEvent
-
Returns the address of the node that dispatches the event
- getEventType() - Method in class com.hazelcast.cluster.MembershipEvent
-
Returns the membership event type; #MEMBER_ADDED #MEMBER_REMOVED
- getEventType() - Method in class com.hazelcast.collection.ItemEvent
-
Returns the event type.
- getEventType() - Method in class com.hazelcast.core.DistributedObjectEvent
-
Returns the type of this event; one of
DistributedObjectEvent.EventType.CREATED
orDistributedObjectEvent.EventType.DESTROYED
. - getEventType() - Method in class com.hazelcast.map.AbstractIMapEvent
-
Returns the event type
EntryEventType
. - getEventType() - Method in class com.hazelcast.map.EventLostEvent
-
Intentionally returns
null
. - getEventType() - Method in interface com.hazelcast.map.IMapEvent
-
Return the event type
- getEventType() - Method in interface com.hazelcast.wan.WanEvent
-
Returns the type of this event.
- getEvictionConfig() - Method in class com.hazelcast.config.CacheConfig
-
Gets the
EvictionConfig
instance of the eviction configuration for thisICache
. - getEvictionConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the eviction configuration for this
ICache
. - getEvictionConfig() - Method in class com.hazelcast.config.MapConfig
-
Gets the
EvictionConfig
instance of the eviction configuration for thisIMap
. - getEvictionConfig() - Method in class com.hazelcast.config.NearCacheConfig
-
Returns the eviction configuration for this Near Cache.
- getEvictionConfig() - Method in class com.hazelcast.config.QueryCacheConfig
-
Returns
EvictionConfig
instance for thisQueryCache
- getEvictionConfig(Node, boolean, boolean) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- getEvictionCount() - Method in interface com.hazelcast.map.LocalMapStats
- getEvictionPolicy() - Method in class com.hazelcast.config.EvictionConfig
-
Returns the
EvictionPolicy
of this eviction configuration. - getEvictions() - Method in interface com.hazelcast.nearcache.NearCacheStats
- getEvictionStrategyType() - Method in class com.hazelcast.config.EvictionConfig
-
Returns the
EvictionStrategyType
of this eviction configuration. - getEx() - Method in interface com.hazelcast.function.SupplierEx
-
Exception-declaring version of
Supplier.get()
. - getExecutor() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
-
Gets the Executor that is going to process the events.
- getExecutor() - Method in class com.hazelcast.config.ReliableTopicConfig
-
Gets the Executor that is going to process the events.
- getExecutorConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the ExecutorConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
- getExecutorConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of executor configurations, mapped by config name.
- getExecutorName() - Method in interface com.hazelcast.core.Offloadable
-
Returns the name of the executor to which the processing unit will be off-loaded.
- getExecutorService(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates or returns the distributed executor service for the given name.
- getExpectedResultType() - Method in class com.hazelcast.sql.SqlStatement
-
Gets the expected result type.
- getExpirationCount() - Method in interface com.hazelcast.map.LocalMapStats
- getExpirations() - Method in interface com.hazelcast.nearcache.NearCacheStats
- getExpirationTime() - Method in interface com.hazelcast.cache.CacheEntryView
-
Gets the expiration time in milliseconds of the cache entry.
- getExpirationTime() - Method in interface com.hazelcast.core.EntryView
-
Returns the expiration time of the entry.
- getExpirationTime() - Method in class com.hazelcast.map.EntryLoader.MetadataAwareValue
-
The expiration date of this entry.
- getExpirationTime() - Method in interface com.hazelcast.spi.merge.MergingExpirationTime
-
Returns the expiration time of the merge data.
- getExpiryForAccess() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
- getExpiryForCreation() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
- getExpiryForUpdate() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
- getExpiryPolicy() - Method in interface com.hazelcast.cache.CacheEntryView
-
Gets the expiry policy associated with this entry if there is one.
- getExpiryPolicyFactory() - Method in class com.hazelcast.config.AbstractCacheConfig
- getExpiryPolicyFactoryConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the factory configuration for the
ExpiryPolicy
. - getExpiryPolicyType() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
- getExtractorClassName() - Method in class com.hazelcast.config.AttributeConfig
-
Gets the full class name of the extractor in a String format, e.g.
- getFactoryClassName() - Method in class com.hazelcast.config.AbstractBaseFactoryWithPropertiesConfig
-
Returns the factory class name.
- getFactoryClassName() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns the name of the MapStoreFactory implementation class
- getFactoryClassName() - Method in class com.hazelcast.config.QueueStoreConfig
-
Returns the factory class name which will be used to instantiate the queue store.
- getFactoryClassName() - Method in class com.hazelcast.config.RingbufferStoreConfig
- getFactoryId() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
- getFactoryId() - Method in class com.hazelcast.cluster.Address
- getFactoryId() - Method in class com.hazelcast.config.AbstractCacheConfig
- getFactoryId() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
- getFactoryId() - Method in class com.hazelcast.config.AttributeConfig
- getFactoryId() - Method in class com.hazelcast.config.BitmapIndexOptions
- getFactoryId() - Method in class com.hazelcast.config.BTreeIndexConfig
- getFactoryId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
- getFactoryId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
- getFactoryId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
- getFactoryId() - Method in class com.hazelcast.config.CacheSimpleConfig
- getFactoryId() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
- getFactoryId() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
- getFactoryId() - Method in class com.hazelcast.config.CollectionConfig
- getFactoryId() - Method in class com.hazelcast.config.DataConnectionConfig
- getFactoryId() - Method in class com.hazelcast.config.DataPersistenceConfig
- getFactoryId() - Method in class com.hazelcast.config.DiscoveryConfig
- getFactoryId() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
- getFactoryId() - Method in class com.hazelcast.config.DiskTierConfig
- getFactoryId() - Method in class com.hazelcast.config.DurableExecutorConfig
- getFactoryId() - Method in class com.hazelcast.config.EventJournalConfig
- getFactoryId() - Method in class com.hazelcast.config.EvictionConfig
- getFactoryId() - Method in class com.hazelcast.config.ExecutorConfig
- getFactoryId() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
- getFactoryId() - Method in class com.hazelcast.config.HotRestartConfig
-
Deprecated.
- getFactoryId() - Method in class com.hazelcast.config.IndexConfig
- getFactoryId() - Method in class com.hazelcast.config.ListenerConfig
- getFactoryId() - Method in class com.hazelcast.config.MapConfig
- getFactoryId() - Method in class com.hazelcast.config.MapStoreConfig
- getFactoryId() - Method in class com.hazelcast.config.MemoryTierConfig
- getFactoryId() - Method in class com.hazelcast.config.MergePolicyConfig
- getFactoryId() - Method in class com.hazelcast.config.MerkleTreeConfig
- getFactoryId() - Method in class com.hazelcast.config.MultiMapConfig
- getFactoryId() - Method in class com.hazelcast.config.NearCacheConfig
- getFactoryId() - Method in class com.hazelcast.config.NearCachePreloaderConfig
- getFactoryId() - Method in class com.hazelcast.config.PartitioningAttributeConfig
- getFactoryId() - Method in class com.hazelcast.config.PartitioningStrategyConfig
- getFactoryId() - Method in class com.hazelcast.config.PermissionConfig
- getFactoryId() - Method in class com.hazelcast.config.PNCounterConfig
- getFactoryId() - Method in class com.hazelcast.config.PredicateConfig
- getFactoryId() - Method in class com.hazelcast.config.QueryCacheConfig
- getFactoryId() - Method in class com.hazelcast.config.QueueConfig
- getFactoryId() - Method in class com.hazelcast.config.QueueStoreConfig
- getFactoryId() - Method in class com.hazelcast.config.ReliableTopicConfig
- getFactoryId() - Method in class com.hazelcast.config.ReplicatedMapConfig
- getFactoryId() - Method in class com.hazelcast.config.RingbufferConfig
- getFactoryId() - Method in class com.hazelcast.config.RingbufferStoreConfig
- getFactoryId() - Method in class com.hazelcast.config.ScheduledExecutorConfig
- getFactoryId() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
- getFactoryId() - Method in class com.hazelcast.config.TieredStoreConfig
- getFactoryId() - Method in class com.hazelcast.config.TopicConfig
- getFactoryId() - Method in class com.hazelcast.config.UserCodeNamespaceConfig
- getFactoryId() - Method in class com.hazelcast.config.vector.VectorCollectionConfig
- getFactoryId() - Method in class com.hazelcast.config.vector.VectorIndexConfig
- getFactoryId() - Method in class com.hazelcast.config.WanBatchPublisherConfig
- getFactoryId() - Method in class com.hazelcast.config.WanConsumerConfig
- getFactoryId() - Method in class com.hazelcast.config.WanCustomPublisherConfig
- getFactoryId() - Method in class com.hazelcast.config.WanReplicationConfig
- getFactoryId() - Method in class com.hazelcast.config.WanReplicationRef
- getFactoryId() - Method in class com.hazelcast.config.WanSyncConfig
- getFactoryId() - Method in class com.hazelcast.jet.config.DeltaJobConfig
- getFactoryId() - Method in class com.hazelcast.jet.config.EdgeConfig
- getFactoryId() - Method in class com.hazelcast.jet.config.JetConfigDataSerializerHook
- getFactoryId() - Method in class com.hazelcast.jet.config.JobConfig
- getFactoryId() - Method in class com.hazelcast.jet.config.ResourceConfig
- getFactoryId() - Method in class com.hazelcast.jet.core.DAG
- getFactoryId() - Method in class com.hazelcast.jet.core.Edge
- getFactoryId() - Method in class com.hazelcast.jet.core.JetDataSerializerHook
- getFactoryId() - Method in class com.hazelcast.jet.core.metrics.JobMetrics
- getFactoryId() - Method in class com.hazelcast.jet.core.metrics.Measurement
- getFactoryId() - Method in class com.hazelcast.jet.core.metrics.MetricsDataSerializerHook
- getFactoryId() - Method in class com.hazelcast.jet.core.ProcessorMetaSupplier.ExpectNothingProcessorSupplier
- getFactoryId() - Method in class com.hazelcast.jet.core.ProcessorMetaSupplier.RandomMemberPms
- getFactoryId() - Method in class com.hazelcast.jet.core.ProcessorMetaSupplier.SpecificMemberPms
- getFactoryId() - Method in class com.hazelcast.jet.core.Vertex
- getFactoryId() - Method in class com.hazelcast.jet.JobStatusEvent
- getFactoryId() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Deprecated.Returns the factory ID.
- getFactoryId() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
Deprecated.
- getFactoryId() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
- getFactoryId() - Method in interface com.hazelcast.nio.serialization.IdentifiedDataSerializable
-
Returns DataSerializableFactory factory ID for this class.
- getFactoryId() - Method in interface com.hazelcast.nio.serialization.Portable
-
Deprecated.Returns PortableFactory ID for this portable class
- getFactoryId() - Method in class com.hazelcast.nio.serialization.PortableId
-
Deprecated.
- getFactoryId() - Method in class com.hazelcast.security.SimpleTokenCredentials
- getFactoryId() - Method in class com.hazelcast.security.UsernamePasswordCredentials
- getFactoryId() - Method in class com.hazelcast.version.MemberVersion
- getFactoryId() - Method in class com.hazelcast.version.Version
- getFactoryImpl() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
- getFactoryImplementation() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns the map store factory implementation object.
- getFactoryImplementation() - Method in class com.hazelcast.config.QueueStoreConfig
-
Returns the queue store factory implementation which will be used to instantiate the queue store.
- getFactoryImplementation() - Method in class com.hazelcast.config.RingbufferStoreConfig
- getFactoryImplementation() - Method in class com.hazelcast.config.SSLConfig
-
Returns the factory implementation object.
- getFence() - Method in interface com.hazelcast.cp.lock.FencedLock
-
Returns the fencing token if the lock is held by the current thread.
- getField(int) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Deprecated.Gets the FieldDefinition for a given fieldIndex.
- getField(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Deprecated.Gets the FieldDefinition for a particular field.
- getFieldClassId(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Deprecated.Gets the class ID of a field.
- getFieldClassId(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- getFieldCount() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Deprecated.Returns the field count.
- getFieldKind(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Returns the kind of the field for the given field name.
- getFieldKind(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
-
Returns the kind of the field for the given field name.
- getFieldNames() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Deprecated.Returns a Set of all field names.
- getFieldNames() - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getFieldNames() - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- getFieldType(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Deprecated.Get the FieldType for a given fieldName.
- getFieldType(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- getFileName() - Method in class com.hazelcast.config.InstanceTrackingConfig
-
Returns the name of the file which will contain the tracking metadata.
- getFilePathOfClasspathResource(String) - Static method in class com.hazelcast.jet.Util
-
Takes the pathname of a classpath resource and returns a
Path
that corresponds to it. - getFilters() - Method in class com.hazelcast.config.WanReplicationRef
-
Returns the list of class names implementing the CacheWanEventFilter or MapWanEventFilter for filtering outbound WAN replication events.
- getFlakeIdGenerator(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates or returns a cluster-wide unique ID generator.
- getFlakeIdGeneratorConfig(String) - Method in class com.hazelcast.client.config.ClientConfig
-
Returns the
ClientFlakeIdGeneratorConfig
for the given name, creating one if necessary and adding it to the collection of known configurations. - getFlakeIdGeneratorConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the
FlakeIdGeneratorConfig
for the given name, creating one if necessary and adding it to the collection of known configurations. - getFlakeIdGeneratorConfigMap() - Method in class com.hazelcast.client.config.ClientConfig
-
Returns the map of
FlakeIdGenerator
configurations, mapped by config name. - getFlakeIdGeneratorConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of
FlakeIdGenerator
configurations, mapped by config name. - getFloat(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
Returns the configured float value of a
HazelcastProperty
. - getFloat32(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getFloat64(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getFlowControlPeriodMs() - Method in class com.hazelcast.jet.config.InstanceConfig
-
Deprecated.Returns the
flow-control period
in milliseconds. - getFlowControlPeriodMs() - Method in class com.hazelcast.jet.config.JetConfig
-
Returns the
flow-control period
in milliseconds. - getFormatPattern() - Method in class com.hazelcast.config.InstanceTrackingConfig
-
Returns the pattern used to render the contents of the instance tracking file.
- getForUpdate(Object) - Method in interface com.hazelcast.transaction.TransactionalMap
-
Locks the key and then gets and returns the value to which the specified key is mapped.
- getFromPort() - Method in class com.hazelcast.spi.utils.PortRange
- getFullPartitionReplicationCount() - Method in interface com.hazelcast.partition.LocalReplicationStats
- getFullReplicationRecordCount() - Method in interface com.hazelcast.partition.LocalReplicationStats
- getFunction() - Method in class com.hazelcast.spi.properties.HazelcastProperty
- getFunctionClassName() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
- getFunctionImplementation() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
- getFuture() - Method in interface com.hazelcast.jet.Job
-
Gets the future associated with the job.
- getGcpConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Returns the current
GcpConfig
. - getGcpConfig() - Method in class com.hazelcast.config.JoinConfig
- getGcpConfig() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the
GcpConfig
used by the discovery mechanism for this WAN publisher. - getGenericRecord(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getGetOperationCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the number of get operations
- getGlobalSerializerConfig() - Method in class com.hazelcast.config.SerializationConfig
- getGroupId() - Method in interface com.hazelcast.cp.event.CPGroupAvailabilityEvent
-
Returns the id of the related CP group.
- getGroupId() - Method in exception com.hazelcast.cp.exception.CPGroupDestroyedException
- getGroupId() - Method in interface com.hazelcast.cp.lock.FencedLock
-
Returns id of the CP group that runs this
FencedLock
instance - getGroupMembers() - Method in interface com.hazelcast.cp.event.CPGroupAvailabilityEvent
-
Returns the current members of the CP group.
- getGroupSize() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Returns the number of CP members to form CP groups.
- getGroupType() - Method in class com.hazelcast.config.PartitionGroupConfig
-
Returns the MemberGroupType configured.
- getHandler() - Method in interface com.hazelcast.scheduledexecutor.IScheduledFuture
-
Returns the scheduled future resource handler.
- getHazelcastClientByName(String) - Static method in class com.hazelcast.client.HazelcastClient
-
Returns an existing HazelcastClient with instanceName.
- getHazelcastInstance() - Method in interface com.hazelcast.cache.HazelcastCacheManager
-
Gets the underlying
HazelcastInstance
implementation. - getHazelcastInstance() - Method in interface com.hazelcast.jet.JetInstance
-
Deprecated.since 5.0 Because we first access to
HazelcastInstance
and thenJetService
from the product's entry point -Hazelcast
-, we don't need to this back reference anymore. This class made sense when the entry point wasJet
. - getHazelcastInstance() - Method in class com.hazelcast.security.HazelcastInstanceCallback
- getHazelcastInstance() - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
- getHazelcastInstanceByName(String) - Static method in class com.hazelcast.core.Hazelcast
-
Returns an existing HazelcastInstance with instanceName.
- getHazelcastInstanceByName(String) - Method in interface com.hazelcast.osgi.HazelcastOSGiService
-
Gets an existing
HazelcastOSGiInstance
with itsinstanceName
. - getHeadSeq() - Method in exception com.hazelcast.ringbuffer.StaleSequenceException
-
Returns the last known head sequence.
- getHeadSequence() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
-
Returns the sequence of the head.
- getHeapCost() - Method in interface com.hazelcast.map.LocalMapStats
-
Cost of map & Near Cache & backup & Merkle trees in bytes
- getHints() - Method in interface com.hazelcast.vector.SearchOptions
- getHitCount() - Method in interface com.hazelcast.query.LocalIndexStats
-
Returns the total number of hits into the index.
- getHits() - Method in interface com.hazelcast.cache.CacheEntryView
-
Gets the number of times this cache entry has been accessed.
- getHits() - Method in interface com.hazelcast.core.EntryView
-
Returns number of hits of the entry.
- getHits() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the number of hits (reads) of locally owned entries, including those which are no longer in the map (for example, may have been evicted).
- getHits() - Method in interface com.hazelcast.nearcache.NearCacheStats
- getHits() - Method in interface com.hazelcast.spi.eviction.EvictableEntryView
-
Gets the access hit count of this
EvictableEntryView
. - getHits() - Method in interface com.hazelcast.spi.merge.MergingHits
-
Returns the access hits of the merge data.
- getHost() - Method in class com.hazelcast.cluster.Address
- getHotRestartConfig() - Method in class com.hazelcast.config.AbstractCacheConfig
-
Gets the
HotRestartConfig
for thisCacheConfiguration
- getHotRestartConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the
HotRestartConfig
for thisCacheSimpleConfig
- getHotRestartConfig() - Method in class com.hazelcast.config.MapConfig
-
Gets the
HotRestartConfig
for thisMapConfig
- getHotRestartPersistenceConfig() - Method in class com.hazelcast.config.Config
-
Returns the Hot Restart configuration for this hazelcast instance
- getHotRestartService() - Method in interface com.hazelcast.cluster.Cluster
-
Deprecated.since 5.0 Use
Cluster.getPersistenceService()
instead.Supported only for members of the cluster, clients will throw a
UnsupportedOperationException
. - getHttpErrorCode() - Method in exception com.hazelcast.spi.exception.RestClientException
- getIcmpFailureDetectorConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig
-
Returns the current
IcmpFailureDetectorConfig
. - getIcmpFailureDetectorConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- getIcmpFailureDetectorConfig() - Method in class com.hazelcast.config.NetworkConfig
-
Returns the current
IcmpFailureDetectorConfig
. - getId() - Method in enum class com.hazelcast.cluster.ClusterState
- getId() - Method in enum class com.hazelcast.config.BitmapIndexOptions.UniqueKeyTransformation
- getId() - Method in enum class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
- getId() - Method in enum class com.hazelcast.config.ConsistencyCheckStrategy
-
Gets the ID for this ConsistencyCheckStrategy.
- getId() - Method in enum class com.hazelcast.config.EvictionPolicy
- getId() - Method in enum class com.hazelcast.config.IndexType
-
Gets the ID for the given
IndexType
. - getId() - Method in enum class com.hazelcast.config.InMemoryFormat
- getId() - Method in enum class com.hazelcast.config.MaxSizePolicy
- getId() - Method in enum class com.hazelcast.config.MetadataPolicy
-
Returns enumeration id of this policy.
- getId() - Method in enum class com.hazelcast.config.ScheduledExecutorConfig.CapacityPolicy
- getId() - Method in enum class com.hazelcast.config.vector.Metric
-
Gets the ID for the given
Metric
. - getId() - Method in enum class com.hazelcast.config.WanAcknowledgeType
-
Gets the ID for the given
WanAcknowledgeType
. - getId() - Method in enum class com.hazelcast.config.WanQueueFullBehavior
-
Gets the ID for the given
WanQueueFullBehavior
. - getId() - Method in interface com.hazelcast.cp.CPGroupId
-
Returns unique id of the CP group.
- getId() - Method in class com.hazelcast.jet.config.ResourceConfig
-
Returns the ID of the resource that will be used to form the
IMap
key under which it will be stored in the Jet cluster. - getId() - Method in enum class com.hazelcast.jet.config.ResourceType
- getId() - Method in enum class com.hazelcast.jet.core.JobStatus
- getId() - Method in interface com.hazelcast.jet.Job
-
Returns the ID of this job.
- getId() - Method in enum class com.hazelcast.memory.MemoryUnit
- getId() - Method in enum class com.hazelcast.nio.serialization.FieldKind
- getId() - Method in enum class com.hazelcast.nio.serialization.FieldType
- getId() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
-
Gets the ID of service.
- getId() - Method in enum class com.hazelcast.ringbuffer.OverflowPolicy
-
Gets the ID for the given OverflowPolicy.
- getId() - Method in enum class com.hazelcast.sql.SqlColumnType
-
Gets the ID for the given
SqlColumnType
. - getId() - Method in enum class com.hazelcast.sql.SqlExpectedResultType
- getId() - Method in enum class com.hazelcast.wan.WanPublisherState
-
Returns the ID of the WAN publisher state.
- getIdleMaxParkNs() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the maximum duration in nanoseconds that the WAN replication thread will be parked if there are no events to replicate.
- getIdleMinParkNs() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the minimum duration in nanoseconds that the WAN replication thread will be parked if there are no events to replicate.
- getIdString() - Method in interface com.hazelcast.jet.Job
-
Returns the string representation of this job's ID.
- getImplementation() - Method in class com.hazelcast.config.AbstractWanPublisherConfig
-
Returns the implementation of
WanPublisher
. - getImplementation() - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
- getImplementation() - Method in class com.hazelcast.config.CredentialsFactoryConfig
- getImplementation() - Method in class com.hazelcast.config.EntryListenerConfig
- getImplementation() - Method in class com.hazelcast.config.GlobalSerializerConfig
- getImplementation() - Method in class com.hazelcast.config.ItemListenerConfig
- getImplementation() - Method in class com.hazelcast.config.ListenerConfig
-
Returns the EventListener implementation.
- getImplementation() - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
- getImplementation() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns the map store implementation object.
- getImplementation() - Method in class com.hazelcast.config.MemberAddressProviderConfig
- getImplementation() - Method in class com.hazelcast.config.PermissionPolicyConfig
- getImplementation() - Method in class com.hazelcast.config.PredicateConfig
-
Returns the Predicate implementation.
- getImplementation() - Method in class com.hazelcast.config.SecurityInterceptorConfig
- getImplementation() - Method in class com.hazelcast.config.SerializerConfig
-
Returns the implementation of the serializer class.
- getImplementation() - Method in class com.hazelcast.config.ServiceConfig
- getImplementation() - Method in class com.hazelcast.config.SocketInterceptorConfig
-
Returns the
SocketInterceptor
implementation object. - getImplementation() - Method in class com.hazelcast.config.SplitBrainProtectionListenerConfig
- getImplementation() - Method in class com.hazelcast.config.WanBatchPublisherConfig
- getImplementation() - Method in class com.hazelcast.config.WanConsumerConfig
-
Returns the implementation implementing
WanConsumer
. - getInboundEdges(String) - Method in class com.hazelcast.jet.core.DAG
-
Returns the inbound edges connected to the vertex with the given name.
- getIndex() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
- getIndexConfigs() - Method in class com.hazelcast.config.MapConfig
- getIndexConfigs() - Method in class com.hazelcast.config.QueryCacheConfig
- getIndexedQueryCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the total number of indexed queries performed on the map.
- getIndexStats() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the per-index statistics map keyed by the index name.
- getInetAddress() - Method in class com.hazelcast.cluster.Address
- getInetSocketAddress() - Method in class com.hazelcast.cluster.Address
- getInitialBackoffMillis() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
-
how long to wait after the first failure before retrying
- getInitialLoadMode() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns the initial load mode.
- getInitialOffsetFor(String, int) - Method in class com.hazelcast.jet.kafka.TopicsConfig
-
Returns initial offset value for the given topic and partition combination.
- getInitialPermits() - Method in class com.hazelcast.config.cp.SemaphoreConfig
-
Returns initial permit count of the Semaphore
- getInitialPublisherState() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the initial WAN publisher state.
- getInitialSnapshotName() - Method in class com.hazelcast.jet.config.JobConfig
-
Returns the configured initial snapshot name or
null
if no initial snapshot is configured. - getInMemoryFormat() - Method in class com.hazelcast.config.CacheConfig
-
Gets the data type that will be used to store records.
- getInMemoryFormat() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the InMemory Format for this
ICache
. - getInMemoryFormat() - Method in class com.hazelcast.config.MapConfig
-
Returns the data type that will be used for storing records.
- getInMemoryFormat() - Method in class com.hazelcast.config.NearCacheConfig
-
Returns the data type used to store entries.
- getInMemoryFormat() - Method in class com.hazelcast.config.QueryCacheConfig
-
Returns memory format of values of entries in
QueryCache
. - getInMemoryFormat() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
Data type used to store entries.
- getInMemoryFormat() - Method in class com.hazelcast.config.RingbufferConfig
-
Returns the in-memory format.
- getInputStream() - Method in class com.hazelcast.config.XmlConfigBuilder
- getInsertCount() - Method in interface com.hazelcast.query.LocalIndexStats
-
Returns the number of insert operations performed on the index.
- getInstanceConfig() - Method in class com.hazelcast.jet.config.JetConfig
-
Deprecated.The fields from
InstanceConfig
class were moved toJetConfig
class. Get the fields directly fromJetConfig
. - getInstanceName() - Method in class com.hazelcast.client.config.ClientConfig
- getInstanceName() - Method in class com.hazelcast.config.Config
-
Returns the instance name uniquely identifying the hazelcast instance created by this configuration.
- getInstanceTrackingConfig() - Method in class com.hazelcast.client.config.ClientConfig
-
Returns the configuration for tracking use of this Hazelcast instance.
- getInstanceTrackingConfig() - Method in class com.hazelcast.config.Config
-
Returns the configuration for tracking use of this Hazelcast instance.
- getInt16(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getInt32(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getInt64(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getInt8(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getInteger(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
Returns the configured int value of a
HazelcastProperty
. - getIntegrityCheckerConfig() - Method in class com.hazelcast.config.Config
-
Returns the IntegrityChecker config
- getInterfaces() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- getInterfaces() - Method in class com.hazelcast.config.EndpointConfig
- getInterfaces() - Method in class com.hazelcast.config.InterfacesConfig
- getInterfaces() - Method in class com.hazelcast.config.MemberGroupConfig
-
Gets an unmodifiable collection containing all interfaces.
- getInterfaces() - Method in class com.hazelcast.config.NetworkConfig
- getIntervalFunction() - Method in interface com.hazelcast.jet.retry.RetryStrategy
-
Function specifying how much time to wait before each retry attempt.
- getIntervalMilliseconds() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
- getIntervalMilliseconds() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
- getInvalidationRequests() - Method in interface com.hazelcast.nearcache.NearCacheStats
- getInvalidations() - Method in interface com.hazelcast.nearcache.NearCacheStats
- getItem() - Method in class com.hazelcast.collection.ItemEvent
-
Returns the item related to the event.
- getItemListenerConfigs() - Method in class com.hazelcast.config.CollectionConfig
-
Gets the list of ItemListenerConfigs.
- getItemListenerConfigs() - Method in class com.hazelcast.config.QueueConfig
-
Get the list of item listener configurations for this queue.
- getItems() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
-
Returns the array representing this ringbuffer.
- getIterationCount() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-
Deprecated.
- getJaasAuthenticationConfig() - Method in class com.hazelcast.config.security.RealmConfig
- getJarPaths() - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
-
Deprecated.
- getJavaReflectionFilterConfig() - Method in class com.hazelcast.config.SqlConfig
- getJavaSerializationFilterConfig() - Method in class com.hazelcast.config.SerializationConfig
- getJet() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns a Jet service to execute distributed batch and streaming jobs.
- getJetConfig() - Method in class com.hazelcast.config.Config
-
Returns the Jet config
- getJitter() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
-
by how much to randomize backoffs.
- getJmxConfig() - Method in class com.hazelcast.config.BaseMetricsConfig
- getJob(long) - Method in interface com.hazelcast.jet.JetService
-
Returns the job with the given id or
null
if no such job could be found. - getJob(String) - Method in interface com.hazelcast.jet.JetService
-
Returns the active or last submitted job with the given name or
null
if no such job could be found. - getJobClassLoader() - Method in interface com.hazelcast.jet.config.JobClassLoaderFactory
-
Return the class loader instance.
- getJobId() - Method in class com.hazelcast.jet.JobStatusEvent
- getJobs() - Method in interface com.hazelcast.jet.JetService
-
Returns all submitted jobs.
- getJobs(String) - Method in interface com.hazelcast.jet.JetService
-
Returns all jobs submitted with the given name, ordered in descending order by submission time.
- getJobStateSnapshot(String) - Method in interface com.hazelcast.jet.JetService
-
Returns the
JobStateSnapshot
object representing an exported snapshot with the given name. - getJobStateSnapshots() - Method in interface com.hazelcast.jet.JetService
-
Returns the collection of exported job state snapshots stored in the cluster.
- getJoin() - Method in class com.hazelcast.config.AdvancedNetworkConfig
-
Returns the
JoinConfig
. - getJoin() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- getJoin() - Method in class com.hazelcast.config.NetworkConfig
-
Returns the
JoinConfig
. - getKerberosAuthenticationConfig() - Method in class com.hazelcast.config.security.RealmConfig
- getKerberosIdentityConfig() - Method in class com.hazelcast.client.config.ClientSecurityConfig
- getKerberosIdentityConfig() - Method in class com.hazelcast.config.security.RealmConfig
- getKey() - Method in interface com.hazelcast.cache.CacheEntryView
-
Gets the key of the cache entry.
- getKey() - Method in interface com.hazelcast.cache.EventJournalCacheEvent
-
Returns the key for the event entry.
- getKey() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-
Deprecated.
- getKey() - Method in class com.hazelcast.core.EntryEvent
-
Returns the key of the entry event.
- getKey() - Method in interface com.hazelcast.core.EntryView
-
Returns the key of the entry.
- getKey() - Method in class com.hazelcast.jet.datamodel.KeyedWindowResult
-
Alias for
KeyedWindowResult.key
, implementsMap.Entry
. - getKey() - Method in class com.hazelcast.jet.datamodel.Tuple2
- getKey() - Method in interface com.hazelcast.map.EventJournalMapEvent
-
Returns the key for the event entry.
- getKey() - Method in class com.hazelcast.partition.PartitionAwareKey
-
Gets the key (not the partitionKey).
- getKey() - Method in interface com.hazelcast.spi.eviction.EvictableEntryView
-
Gets the key of the entry.
- getKey() - Method in interface com.hazelcast.spi.merge.MergingEntry
-
Returns the deserialized merging key.
- getKey() - Method in interface com.hazelcast.vector.SearchResult
- getKeyAlias() - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Return the alias that identifies the key in the key store.
- getKeyClassName() - Method in class com.hazelcast.config.AbstractCacheConfig
- getKeyPassword() - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Return the password used to access the key in the key store.
- getKeySize() - Method in class com.hazelcast.config.EncryptionAtRestConfig
-
Returns the size (in bits) of the Hot Restart Store-level encryption key.
- getKeyStore() - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Return the path to the key store that holds the SSL certificate (typically a jks file).
- getKeyStorePassword() - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Return the password used to access the key store.
- getKeyStoreProvider() - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Return the provider for the key store.
- getKeyStoreType() - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Return the type of the key store.
- getKeytabFile() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
- getKeytabFile() - Method in class com.hazelcast.config.security.KerberosIdentityConfig
- getKeyType() - Method in class com.hazelcast.config.AbstractCacheConfig
- getKeyType() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the key type for this
ICache
. - getKubernetesConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Returns the current
KubernetesConfig
. - getKubernetesConfig() - Method in class com.hazelcast.config.JoinConfig
- getKubernetesConfig() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the
KubernetesConfig
used by the discovery mechanism for this WAN publisher. - getLabels() - Method in interface com.hazelcast.client.Client
- getLabels() - Method in class com.hazelcast.client.config.ClientConfig
- getLargestSequence() - Method in interface com.hazelcast.ringbuffer.RingbufferStore
-
Return the largest sequence seen by the data store.
- getLastAccessTime() - Method in interface com.hazelcast.cache.CacheEntryView
-
Gets the last access time in milliseconds of the cache entry.
- getLastAccessTime() - Method in interface com.hazelcast.cache.CacheStatistics
-
Gets the last access time to cache.
- getLastAccessTime() - Method in interface com.hazelcast.collection.LocalCollectionStats
-
Returns the last access (read) time of the list.
- getLastAccessTime() - Method in interface com.hazelcast.core.EntryView
-
Returns the last access time for the entry.
- getLastAccessTime() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the last access (read) time of the locally owned entries.
- getLastAccessTime() - Method in interface com.hazelcast.spi.eviction.EvictableEntryView
-
Gets the latest access time difference of this
EvictableEntryView
in milliseconds. - getLastAccessTime() - Method in interface com.hazelcast.spi.merge.MergingLastAccessTime
-
Returns the last access time of the merge data.
- getLastIdleTime(TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.ScheduledTaskStatistics
-
Returns the last period of time the task was idle, waiting to get scheduled
- getLastPersistenceDuration() - Method in interface com.hazelcast.nearcache.NearCacheStats
- getLastPersistenceFailure() - Method in interface com.hazelcast.nearcache.NearCacheStats
- getLastPersistenceKeyCount() - Method in interface com.hazelcast.nearcache.NearCacheStats
- getLastPersistenceTime() - Method in interface com.hazelcast.nearcache.NearCacheStats
- getLastPersistenceWrittenBytes() - Method in interface com.hazelcast.nearcache.NearCacheStats
- getLastRunDuration(TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.ScheduledTaskStatistics
-
Returns the duration of the task's last execution.
- getLastStoredTime() - Method in interface com.hazelcast.core.EntryView
-
Returns the last time the value was flushed to its store (e.g.
- getLastStoredTime() - Method in interface com.hazelcast.spi.merge.MergingLastStoredTime
-
Returns the last stored time of the merge data.
- getLastUpdateTime() - Method in interface com.hazelcast.cache.CacheStatistics
-
Gets the last update time to cache.
- getLastUpdateTime() - Method in interface com.hazelcast.collection.LocalCollectionStats
-
Returns the last update time of the list.
- getLastUpdateTime() - Method in interface com.hazelcast.core.EntryView
-
Returns the last time the value was updated.
- getLastUpdateTime() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the last update time of the locally owned entries.
- getLastUpdateTime() - Method in interface com.hazelcast.spi.merge.MergingLastUpdateTime
-
Returns the last update time of the merge data.
- getLdapAuthenticationConfig() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
- getLdapAuthenticationConfig() - Method in class com.hazelcast.config.security.RealmConfig
- getLeader(CPGroupId) - Method in class com.hazelcast.cp.CPGroupsSnapshot
- getLeaderElectionTimeoutInMillis() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
- getLeaderHeartbeatPeriodInMillis() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
- getLeaderUuid() - Method in exception com.hazelcast.cp.exception.CPSubsystemException
-
Returns the leader endpoint of related CP group, if known/available by the time this exception is thrown.
- getLevel() - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
- getLicenseKey() - Method in class com.hazelcast.config.Config
-
Returns the license key for this hazelcast instance.
- getLifecycleService() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the lifecycle service for this instance.
- getLimit() - Method in interface com.hazelcast.vector.SearchOptions
- getLingerSeconds() - Method in class com.hazelcast.client.config.SocketOptions
-
Gets SO_LINGER with the specified linger time in seconds
- getList() - Method in class com.hazelcast.console.ConsoleApp
- getList(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates or returns the distributed list instance with the specified name.
- getList(String) - Method in interface com.hazelcast.jet.JetInstance
-
Deprecated.since 5.0 Use
HazelcastInstance.getList(String)
instead. - getList(String) - Method in class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
- getList(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
-
Returns the transactional list instance with the specified name.
- getListConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the ListConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
- getListConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of
IList
configurations, mapped by config name. - getListenerConfigs() - Method in class com.hazelcast.client.config.ClientConfig
-
Gets list of all configured
ListenerConfig
's - getListenerConfigs() - Method in class com.hazelcast.config.Config
-
Returns the list of
EventListener
configurations. - getListenerConfigs() - Method in class com.hazelcast.config.ReplicatedMapConfig
- getListenerConfigs() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
- getListenerConfigurations() - Method in class com.hazelcast.config.AbstractCacheConfig
- getLoadBalancer() - Method in class com.hazelcast.client.config.ClientConfig
-
Gets LoadBalancer
- getLoadBalancerClassName() - Method in class com.hazelcast.client.config.ClientConfig
-
Gets load balancer class name
- getLocalCacheStatistics() - Method in interface com.hazelcast.cache.ICache
-
Directly access local Cache Statistics.
- getLocalCPMember() - Method in interface com.hazelcast.cp.CPSubsystem
-
Returns the local CP member if this Hazelcast member is part of CP Subsystem, returns null otherwise.
- getLocalCPMember() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
-
Returns the local CP member if this Hazelcast member is part of CP Subsystem, returns null otherwise.
- getLocalCPMember() - Method in class com.hazelcast.cp.CPSubsystemStubImpl
- getLocalEndpoint() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the local Endpoint which this HazelcastInstance belongs to.
- getLocalExecutorStats() - Method in interface com.hazelcast.core.IExecutorService
-
Returns local statistics related to this executor service.
- getLocalListStats() - Method in interface com.hazelcast.collection.IList
-
Returns
LocalListStats
for this collection. - getLocalMapStats() - Method in interface com.hazelcast.map.IMap
-
Returns LocalMapStats for this map.
- getLocalMember() - Method in interface com.hazelcast.cluster.Cluster
-
Returns this Hazelcast instance member.
- getLocalMultiMapStats() - Method in interface com.hazelcast.multimap.MultiMap
-
Returns
LocalMultiMapStats
for this map. - getLocalParallelism() - Method in class com.hazelcast.jet.core.Vertex
-
Returns the number of processors corresponding to this vertex that will be created on each member.
- getLocalQueueStats() - Method in interface com.hazelcast.collection.IQueue
-
Returns LocalQueueStats for this queue.
- getLocalSetStats() - Method in interface com.hazelcast.collection.ISet
-
Returns
LocalSetStats
for this collection. - getLocalTopicStats() - Method in interface com.hazelcast.topic.ITopic
-
Returns statistics about this topic, like total number of publishes/receives.
- getLocalUpdatePolicy() - Method in class com.hazelcast.config.NearCacheConfig
-
Returns the
NearCacheConfig.LocalUpdatePolicy
of this Near Cache. - getLock(String) - Method in interface com.hazelcast.cp.CPSubsystem
-
Returns a proxy for an
FencedLock
instance created on CP Subsystem. - getLock(String) - Method in class com.hazelcast.cp.CPSubsystemStubImpl
- getLockAcquireLimit() - Method in class com.hazelcast.config.cp.FencedLockConfig
-
Returns the maximum number of lock acquires a lock holder can perform. 0 means no upper-bound on the number of reentrant lock acquires. 1 means the lock is non-reentrant.
- getLockConfigs() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Returns the map of
FencedLock
configurations - getLockCount() - Method in interface com.hazelcast.cp.lock.FencedLock
-
Returns the reentrant lock count if the lock is held by any thread in the cluster.
- getLockedEntryCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the number of currently locked keys.
- getLogger() - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Returns the logger associated with this processor instance.
- getLogger() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
-
Returns a
ILogger
instance bound to the current class. - getLogger() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
- getLogger(Class<?>) - Static method in class com.hazelcast.logging.Logger
-
Obtains a
logger
for the givenclazz
. - getLogger(Class<?>) - Method in interface com.hazelcast.logging.LoggingService
- getLogger(String) - Static method in class com.hazelcast.logging.Logger
-
Obtains a
logger
of the givenname
. - getLogger(String) - Method in interface com.hazelcast.logging.LoggerFactory
- getLogger(String) - Method in class com.hazelcast.logging.LoggerFactorySupport
- getLogger(String) - Method in interface com.hazelcast.logging.LoggingService
- getLogger(String) - Method in class com.hazelcast.logging.NoLogFactory
- getLoggingService() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the logging service of this Hazelcast instance.
- getLoggingService() - Method in class com.hazelcast.security.LoggingServiceCallback
- getLoginModuleConfigs() - Method in class com.hazelcast.config.security.JaasAuthenticationConfig
- getLogRecord() - Method in class com.hazelcast.logging.LogEvent
- getLong() - Method in class com.hazelcast.jet.accumulator.LongDoubleAccumulator
-
Returns the
long
value. - getLong(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
Returns the configured long value of a
HazelcastProperty
. - getLoopbackModeEnabled() - Method in class com.hazelcast.config.MulticastConfig
-
Returns if explicit loopback mode configuration was requested (by
MulticastConfig.setLoopbackModeEnabled(Boolean)
). - getLostBackupCount() - Method in interface com.hazelcast.partition.PartitionLostEvent
- getMajor() - Method in class com.hazelcast.version.MemberVersion
- getMajor() - Method in class com.hazelcast.version.Version
- getMajority() - Method in interface com.hazelcast.cp.event.CPGroupAvailabilityEvent
-
Returns the majority member count of the CP group.
- getManagedContext() - Method in class com.hazelcast.client.config.ClientConfig
-
Gets
ManagedContext
- getManagedContext() - Method in class com.hazelcast.config.Config
-
Returns the external managed context.
- getManagementCenterConfig() - Method in class com.hazelcast.config.Config
-
Returns the management center configuration for this hazelcast instance.
- getManagementCenterConfig() - Method in class com.hazelcast.config.MetricsConfig
- getManagerPrefix() - Method in class com.hazelcast.config.CacheConfig
-
Gets the manager prefix of the
ICache
, such as "hz://". - getMap() - Method in class com.hazelcast.console.ConsoleApp
- getMap(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates or returns the distributed map instance with the specified name.
- getMap(String) - Method in interface com.hazelcast.cp.CPSubsystem
-
Returns a proxy for a
CPMap
. - getMap(String) - Method in class com.hazelcast.cp.CPSubsystemStubImpl
- getMap(String) - Method in interface com.hazelcast.jet.JetInstance
-
Deprecated.since 5.0 Use
HazelcastInstance.getMap(String)
instead. - getMap(String) - Method in class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
- getMap(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
-
Returns the transactional distributed map instance with the specified name.
- getMapConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the MapConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
- getMapConfigOrNull(String) - Method in class com.hazelcast.config.Config
-
Returns the map config with the given name or
null
if there is none. - getMapConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of
IMap
configurations, mapped by config name. - getMapStoreConfig() - Method in class com.hazelcast.config.MapConfig
-
Returns the map store configuration
- getMaxAge() - Method in interface com.hazelcast.collection.LocalQueueStats
-
Returns the maximum age of the items in this member.
- getMaxAttempts() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
- getMaxAttempts() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
- getMaxAttempts() - Method in interface com.hazelcast.jet.retry.RetryStrategy
-
Maximum number of retry attempt that should be made before giving up.
- getMaxBackoffMillis() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
-
When backoff reaches this upper bound, it does not increase anymore.
- getMaxConcurrentInvocations() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the maximum number of WAN event batches being sent to the target cluster concurrently.
- getMaxConcurrentReplicationTargets() - Method in class com.hazelcast.config.CRDTReplicationConfig
-
Returns the maximum number of target members that we replicate the CRDT states to in one period.
- getMaxDegree() - Method in class com.hazelcast.config.vector.VectorIndexConfig
-
Retrieves the maximum number of connections a node can have.
- getMaxGetLatency() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the maximum latency of get operations.
- getMaxIdle() - Method in interface com.hazelcast.core.EntryView
-
Returns the last set max idle time in milliseconds.
- getMaxIdle() - Method in interface com.hazelcast.spi.merge.MergingMaxIdle
-
Returns the MaxIdle of the merge data.
- getMaxIdleSeconds() - Method in class com.hazelcast.config.MapConfig
-
Returns the maximum number of seconds for each entry to stay idle in the map.
- getMaxIdleSeconds() - Method in class com.hazelcast.config.NearCacheConfig
-
Returns the maximum number of seconds each entry can stay in the Near Cache as untouched (not-read).
- getMaxMissedLeaderHeartbeatCount() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
- getMaxProcessorAccumulatedRecords() - Method in class com.hazelcast.jet.config.InstanceConfig
-
Deprecated.Returns the maximum number of records that can be accumulated by any single
Processor
instance. - getMaxProcessorAccumulatedRecords() - Method in class com.hazelcast.jet.config.JetConfig
-
Returns the maximum number of records that can be accumulated by any single
Processor
instance. - getMaxProcessorAccumulatedRecords() - Method in class com.hazelcast.jet.config.JobConfig
-
Returns the maximum number of records that can be accumulated by any single
Processor
instance in the context of the job. - getMaxPutLatency() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the maximum latency of put operations.
- getMaxRemoveLatency() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the maximum latency of remove operations.
- getMaxSetLatency() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the maximum latency of set operations.
- getMaxSize() - Method in class com.hazelcast.config.CollectionConfig
-
Gets the maximum size for the Configuration.
- getMaxSize() - Method in class com.hazelcast.config.QueueConfig
-
Returns the maximum size of the Queue.
- getMaxSizeMb() - Method in class com.hazelcast.config.cp.CPMapConfig
-
Gets the maximum capacity in MB.
- getMaxSizePolicy() - Method in class com.hazelcast.config.EvictionConfig
-
Returns the
MaxSizePolicy
of this eviction configuration. - getMaxTargetEndpoints() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the maximum number of endpoints that WAN will connect to when using a discovery mechanism to define endpoints.
- getMember() - Method in class com.hazelcast.cluster.MembershipEvent
-
Returns the removed or added member.
- getMember() - Method in class com.hazelcast.collection.ItemEvent
-
Returns the member that fired this event.
- getMember() - Method in exception com.hazelcast.core.MemberLeftException
-
Returns the member that left the cluster
- getMember() - Method in interface com.hazelcast.cp.event.CPMembershipEvent
-
Returns the CPMember that is added to or removed from CP Subsystem.
- getMember() - Method in class com.hazelcast.logging.LogEvent
- getMember() - Method in class com.hazelcast.map.AbstractIMapEvent
-
Returns the member that fired this event.
- getMember() - Method in class com.hazelcast.map.EventLostEvent
- getMember() - Method in interface com.hazelcast.map.IMapEvent
-
Returns the member that fired this event.
- getMemberAddressProviderConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig
- getMemberAddressProviderConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- getMemberAddressProviderConfig() - Method in class com.hazelcast.config.NetworkConfig
- getMemberAttributeConfig() - Method in class com.hazelcast.config.Config
-
Returns the member attribute configuration.
- getMemberGroupConfigs() - Method in class com.hazelcast.config.PartitionGroupConfig
-
Returns an unmodifiable collection containing all
MemberGroupConfig
elements. - getMemberGroups() - Method in interface com.hazelcast.spi.partitiongroup.PartitionGroupStrategy
- getMemberRealm() - Method in class com.hazelcast.config.SecurityConfig
- getMembers() - Method in interface com.hazelcast.cluster.Cluster
-
Set of the current members in the cluster.
- getMembers() - Method in class com.hazelcast.cluster.InitialMembershipEvent
-
Returns an immutable set of ordered members at the moment this
InitialMembershipListener
is registered. - getMembers() - Method in class com.hazelcast.cluster.MembershipEvent
-
Returns a consistent view of the the members immediately after this MembershipEvent has been processed.
- getMembers() - Method in class com.hazelcast.config.TcpIpConfig
-
Gets a list of all the well known members.
- getMemcacheProtocolConfig() - Method in class com.hazelcast.config.NetworkConfig
- getMemoryCost() - Method in interface com.hazelcast.query.LocalIndexStats
-
Returns the memory cost of the index in bytes.
- getMemoryTierConfig() - Method in class com.hazelcast.config.BTreeIndexConfig
-
Returns memory tier configuration for this index.
- getMemoryTierConfig() - Method in class com.hazelcast.config.TieredStoreConfig
-
Returns the memory tier config of this tiered-store configuration.
- getMergePolicy(String) - Method in class com.hazelcast.spi.merge.SplitBrainMergePolicyProvider
-
Resolves the
SplitBrainMergePolicy
class by its classname. - getMergePolicyClassName() - Method in class com.hazelcast.config.WanReplicationRef
-
Returns the merge policy sent to the WAN replication target to merge replicated entries with existing target entries.
- getMergePolicyConfig() - Method in class com.hazelcast.config.CacheConfig
-
Gets the
MergePolicyConfig
for this map. - getMergePolicyConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the
MergePolicyConfig
for this map. - getMergePolicyConfig() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
Gets the
MergePolicyConfig
for the cardinality estimator. - getMergePolicyConfig() - Method in class com.hazelcast.config.CollectionConfig
-
Gets the
MergePolicyConfig
for the collection. - getMergePolicyConfig() - Method in class com.hazelcast.config.MapConfig
-
Gets the
MergePolicyConfig
for this map. - getMergePolicyConfig() - Method in class com.hazelcast.config.MultiMapConfig
-
Gets the
MergePolicyConfig
for this MultiMap. - getMergePolicyConfig() - Method in class com.hazelcast.config.QueueConfig
-
Gets the
MergePolicyConfig
for this queue. - getMergePolicyConfig() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
Gets the
MergePolicyConfig
for this replicated map. - getMergePolicyConfig() - Method in class com.hazelcast.config.RingbufferConfig
-
Gets the
MergePolicyConfig
for this ringbuffer. - getMergePolicyConfig() - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Gets the
MergePolicyConfig
for the scheduler. - getMergePolicyConfig() - Method in interface com.hazelcast.config.SplitBrainPolicyAwareConfig
-
Gets the
MergePolicyConfig
for the data structure. - getMergePolicyConfig() - Method in class com.hazelcast.config.vector.VectorCollectionConfig
-
Gets the
MergePolicyConfig
for the data structure. - getMergingValue() - Method in class com.hazelcast.core.EntryEvent
-
Returns the incoming merging value of the entry event.
- getMerkleTreeConfig() - Method in class com.hazelcast.config.CacheConfig
-
Gets the
MerkleTreeConfig
for thisCacheConfig
- getMerkleTreeConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the
MerkleTreeConfig
for thisCacheSimpleConfig
- getMerkleTreeConfig() - Method in class com.hazelcast.config.MapConfig
-
Gets the
MerkleTreeConfig
for thisMapConfig
- getMerkleTreesCost() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the heap cost of the Merkle trees
- getMessageListenerConfigs() - Method in class com.hazelcast.config.ReliableTopicConfig
-
Gets the list of message listeners (listens for when messages are added or removed) for this reliable topic.
- getMessageListenerConfigs() - Method in class com.hazelcast.config.TopicConfig
-
Gets the list of message listeners (listens for when messages are added or removed) for this topic.
- getMessageObject() - Method in class com.hazelcast.topic.Message
-
Returns the published message
- getMetadata() - Method in interface com.hazelcast.sql.SqlRow
-
Gets row metadata.
- getMetadataPolicy() - Method in class com.hazelcast.config.MapConfig
-
Returns
MetadataPolicy
for this map. - getMetadataSpacePercentage() - Method in class com.hazelcast.config.NativeMemoryConfig
-
Returns the percentage of native memory space to be used to store metadata and internal memory structures by the native memory manager.
- getMetaSupplier() - Method in class com.hazelcast.jet.core.Vertex
-
Returns this vertex's meta-supplier of processors.
- getMetric() - Method in class com.hazelcast.config.vector.VectorIndexConfig
-
Retrieves the metric of this vector index configuration.
- getMetrics() - Method in interface com.hazelcast.jet.Job
-
Returns a snapshot of the current values of all job-specific metrics.
- getMetricsConfig() - Method in class com.hazelcast.client.config.ClientConfig
-
Returns the metrics collection config.
- getMetricsConfig() - Method in class com.hazelcast.config.Config
-
Returns the metrics collection config.
- getMigrationState() - Method in interface com.hazelcast.partition.ReplicaMigrationEvent
-
Returns the progress information of the overall migration.
- getMillis(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
Returns the configured value of a
HazelcastProperty
converted to milliseconds. - getMinAge() - Method in interface com.hazelcast.collection.LocalQueueStats
-
Returns the minimum age of the items in this member.
- getMinBlockSize() - Method in class com.hazelcast.config.NativeMemoryConfig
-
Returns the minimum memory block size, in bytes, to be served by native memory manager.
- getMinimumClusterSize() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
- getMinor() - Method in class com.hazelcast.version.MemberVersion
- getMinor() - Method in class com.hazelcast.version.Version
- getMisses() - Method in interface com.hazelcast.nearcache.NearCacheStats
- getMissingCPMemberAutoRemovalSeconds() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Returns the duration to wait before automatically removing a missing CP member from CP Subsystem
- getMode() - Method in class com.hazelcast.config.PersistentMemoryConfig
-
Returns the mode in which the persistent memory should be used.
- getModeName() - Method in enum class com.hazelcast.config.InstanceTrackingConfig.InstanceMode
-
Returns the string representation of the instance mode name.
- getMulticastConfig() - Method in class com.hazelcast.config.JoinConfig
- getMulticastGroup() - Method in class com.hazelcast.config.MulticastConfig
-
Gets the multicast group.
- getMulticastPort() - Method in class com.hazelcast.config.MulticastConfig
-
Gets the multicast port.
- getMulticastTimeoutSeconds() - Method in class com.hazelcast.config.MulticastConfig
-
Gets the multicast timeout in seconds.
- getMulticastTimeToLive() - Method in class com.hazelcast.config.MulticastConfig
-
Gets the time to live for the multicast package.
- getMultiMap() - Method in class com.hazelcast.console.ConsoleApp
- getMultiMap(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates or returns the distributed multimap instance with the specified name.
- getMultiMap(String) - Method in class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
- getMultiMap(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
-
Returns the transactional multimap instance with the specified name.
- getMultiMapConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the MultiMapConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
- getMultiMapConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of
MultiMap
configurations, mapped by config name. - getMultiplier() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
-
factor with which to multiply backoff after a failed retry
- getName() - Method in interface com.hazelcast.client.Client
-
This method may return null depending on the client version and the client type Java client provides client name starting with 3.12
- getName() - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
-
Returns the configuration name.
- getName() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
-
Gets the name of the reliable topic.
- getName() - Method in interface com.hazelcast.collection.ICollection
-
Returns the name of this collection.
- getName() - Method in class com.hazelcast.config.AttributeConfig
-
Gets the name of the attribute extracted by the extractor.
- getName() - Method in class com.hazelcast.config.CacheConfig
-
Gets the name of this
ICache
. - getName() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the name of this
ICache
. - getName() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
Gets the name of the cardinality estimator.
- getName() - Method in class com.hazelcast.config.CollectionConfig
-
Gets the name of this collection.
- getName() - Method in class com.hazelcast.config.cp.CPMapConfig
-
Gets the name of the configuration.
- getName() - Method in class com.hazelcast.config.cp.FencedLockConfig
-
Returns the name of FencedLock
- getName() - Method in class com.hazelcast.config.cp.SemaphoreConfig
-
Returns the name of CP ISemaphore
- getName() - Method in class com.hazelcast.config.DataConnectionConfig
-
Returns the name of this data connection.
- getName() - Method in class com.hazelcast.config.DurableExecutorConfig
-
Gets the name of the executor task.
- getName() - Method in class com.hazelcast.config.EndpointConfig
- getName() - Method in class com.hazelcast.config.ExecutorConfig
-
Gets the name of the executor task.
- getName() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
Returns the configuration name.
- getName() - Method in class com.hazelcast.config.IndexConfig
-
Gets name of the index.
- getName() - Method in class com.hazelcast.config.LocalDeviceConfig
-
Returns the device name.
- getName() - Method in class com.hazelcast.config.MapConfig
-
Returns the name of this
IMap
- getName() - Method in class com.hazelcast.config.MultiMapConfig
-
Gets the name of this MultiMap.
- getName() - Method in interface com.hazelcast.config.NamedConfig
- getName() - Method in class com.hazelcast.config.NearCacheConfig
-
Returns the name of the Near Cache.
- getName() - Method in class com.hazelcast.config.PermissionConfig
- getName() - Method in class com.hazelcast.config.PNCounterConfig
-
Gets the name of the PN counter.
- getName() - Method in class com.hazelcast.config.QueryCacheConfig
-
Returns the name of
QueryCache
. - getName() - Method in class com.hazelcast.config.QueueConfig
- getName() - Method in class com.hazelcast.config.ReliableTopicConfig
-
Gets the name of the reliable topic.
- getName() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
Returns the name of this
ReplicatedMap
. - getName() - Method in class com.hazelcast.config.RingbufferConfig
-
Returns the name of the ringbuffer.
- getName() - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Gets the name of the executor task.
- getName() - Method in class com.hazelcast.config.ServiceConfig
- getName() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
- getName() - Method in class com.hazelcast.config.TopicConfig
-
Gets the name of the topic, null if nothing is set.
- getName() - Method in class com.hazelcast.config.UserCodeNamespaceConfig
- getName() - Method in class com.hazelcast.config.vector.VectorCollectionConfig
-
Returns the name of this VectorCollection
- getName() - Method in class com.hazelcast.config.vector.VectorIndexConfig
-
Returns the name of this vector index
- getName() - Method in class com.hazelcast.config.WanReplicationConfig
- getName() - Method in class com.hazelcast.config.WanReplicationRef
-
Returns the WAN replication reference name.
- getName() - Method in interface com.hazelcast.core.DistributedObject
-
Returns the unique name for this DistributedObject.
- getName() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the name of this Hazelcast instance.
- getName() - Method in interface com.hazelcast.cp.CPGroupId
-
Returns name of the CP group.
- getName() - Method in interface com.hazelcast.cp.IAtomicLong
-
Returns the name of this IAtomicLong instance.
- getName() - Method in interface com.hazelcast.cp.ISemaphore
-
Returns the name of this ISemaphore instance.
- getName() - Method in interface com.hazelcast.dataconnection.DataConnection
-
Returns the name of this data connection as specified in the
DataConnectionConfig
or theCREATE DATA CONNECTION
command. - getName() - Method in class com.hazelcast.dataconnection.DataConnectionBase
- getName() - Method in class com.hazelcast.jet.config.JobConfig
-
Returns the name of the job or
null
if no name was given. - getName() - Method in class com.hazelcast.jet.core.Vertex
-
Returns the name of this vertex.
- getName() - Method in interface com.hazelcast.jet.JetInstance
-
Deprecated.since 5.0 Use
HazelcastInstance.getName()
instead. - getName() - Method in interface com.hazelcast.jet.Job
-
Returns the name of this job or
null
if no name was supplied. - getName() - Method in class com.hazelcast.jet.pipeline.DataConnectionRef
- getName() - Method in class com.hazelcast.map.AbstractIMapEvent
-
Returns the name of the map for this event.
- getName() - Method in class com.hazelcast.map.EventLostEvent
- getName() - Method in interface com.hazelcast.map.IMapEvent
-
Returns the name of the map for this event.
- getName() - Method in interface com.hazelcast.map.QueryCache
-
Returns the name of this
QueryCache
. - getName() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
- getName() - Method in interface com.hazelcast.scheduledexecutor.NamedTask
-
Returns the name of the task.
- getName() - Method in interface com.hazelcast.security.Credentials
- getName() - Method in class com.hazelcast.security.SimpleTokenCredentials
-
Simple implementation which returns
"<empty>"
fornull
tokens and"<token>"
for all other tokens. - getName() - Method in class com.hazelcast.security.UsernamePasswordCredentials
- getName() - Method in class com.hazelcast.spi.properties.HazelcastProperty
-
Returns the property name.
- getName() - Method in class com.hazelcast.spring.cache.HazelcastCache
- getName() - Method in class com.hazelcast.sql.SqlColumnMetadata
-
Get column name.
- getName() - Method in interface com.hazelcast.topic.ITopic
-
Returns the name of this ITopic instance.
- getName(DistributedObject) - Static method in class com.hazelcast.core.DistributedObjectUtil
-
Gets the name of the given distributed object.
- getNamespaceConfigs(UserCodeNamespacesConfig) - Static method in class com.hazelcast.config.ConfigAccessor
- getNamespacesConfig() - Method in class com.hazelcast.config.Config
- getNamespaceType() - Method in class com.hazelcast.config.AbstractXmlConfigHelper
- getNameWithPrefix() - Method in class com.hazelcast.config.CacheConfig
-
Gets the full name of the
ICache
, including the manager scope prefix. - getNanos(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
Returns the configured value of a
HazelcastProperty
converted to nanoseconds. - getNativeCache() - Method in class com.hazelcast.spring.cache.HazelcastCache
- getNativeMemoryConfig() - Method in class com.hazelcast.client.config.ClientConfig
- getNativeMemoryConfig() - Method in class com.hazelcast.config.Config
-
Returns the native memory configuration for this hazelcast instance.
- getNearCacheConfig() - Method in class com.hazelcast.config.MapConfig
-
Returns the Near Cache configuration
- getNearCacheConfig(String) - Method in class com.hazelcast.client.config.ClientConfig
-
Gets the
NearCacheConfig
configured for the map / cache with name - getNearCacheConfigMap() - Method in class com.hazelcast.client.config.ClientConfig
-
Map of all configured NearCacheConfig's with the name key and configuration as the value
- getNearCacheStatistics() - Method in interface com.hazelcast.cache.CacheStatistics
-
Gets the Near Cache statistics.
- getNearCacheStats() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns statistics related to the Near Cache.
- getNetworkConfig() - Method in class com.hazelcast.client.config.ClientConfig
-
Gets
ClientNetworkConfig
- getNetworkConfig() - Method in class com.hazelcast.config.Config
-
Returns the network configuration for this hazelcast instance.
- getNewStatus() - Method in class com.hazelcast.jet.JobStatusEvent
- getNewValue() - Method in interface com.hazelcast.cache.EventJournalCacheEvent
-
Returns the new value for the event entry.
- getNewValue() - Method in interface com.hazelcast.map.EventJournalMapEvent
-
Returns the new value for the event entry.
- getNextSequenceToReadFrom() - Method in interface com.hazelcast.ringbuffer.ReadResultSet
-
Returns the sequence of the item following the last read item.
- getNodeEngine() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
- getNodeFilter() - Method in class com.hazelcast.config.DiscoveryConfig
- getNodeFilterClass() - Method in class com.hazelcast.config.DiscoveryConfig
- getNodeIdOffset() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
- getNodeName() - Method in enum class com.hazelcast.config.PermissionConfig.PermissionType
- getNullableBoolean(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
-
Supported only for
Compact
. - getNullableFloat32(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
-
Supported only for
Compact
. - getNullableFloat64(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
-
Supported only for
Compact
. - getNullableInt16(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
-
Supported only for
Compact
. - getNullableInt32(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
-
Supported only for
Compact
. - getNullableInt64(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
-
Supported only for
Compact
. - getNullableInt8(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
-
Supported only for
Compact
. - getNumaNode() - Method in class com.hazelcast.config.PersistentMemoryDirectoryConfig
-
Returns the NUMA node the persistent memory mounted to the given directory is attached to.
- getNumberOfEntriesAffected() - Method in class com.hazelcast.map.MapEvent
-
Returns the number of entries affected by this event.
- getObject(int) - Method in interface com.hazelcast.sql.SqlRow
-
Gets the value of the column by index.
- getObject(String) - Method in interface com.hazelcast.sql.SqlRow
-
Gets the value of the column by column name.
- getObjectInfos(CPGroupId, String) - Method in interface com.hazelcast.cp.CPSubsystem
-
Returns info about all objects of given type within the given group
- getObjectInfos(CPGroupId, String) - Method in class com.hazelcast.cp.CPSubsystemStubImpl
- getObjectName() - Method in class com.hazelcast.core.DistributedObjectEvent
-
Returns the name of related DistributedObject.
- getObjectName() - Method in interface com.hazelcast.wan.WanEvent
-
Returns the name of the distributed object (map or cache) on which this event occurred.
- getObservable(String) - Method in interface com.hazelcast.jet.JetService
-
Returns an
Observable
instance with the specified name. - getObservables() - Method in interface com.hazelcast.jet.JetService
-
Returns a list of all the
Observables
that are active. - getOfferOperationCount() - Method in interface com.hazelcast.collection.LocalQueueStats
-
Returns the number of offer/put/add operations.
- getOldValue() - Method in interface com.hazelcast.cache.EventJournalCacheEvent
-
Returns the old value for the event entry.
- getOldValue() - Method in class com.hazelcast.core.EntryEvent
-
Returns the old value of the entry event.
- getOldValue() - Method in interface com.hazelcast.map.EventJournalMapEvent
-
Returns the old value for the event entry.
- getOnJoinPermissionOperation() - Method in class com.hazelcast.config.SecurityConfig
- getOrCreateHazelcastClient() - Static method in class com.hazelcast.client.HazelcastClient
-
Gets or creates a new HazelcastInstance (a new client in a cluster) with the default XML configuration looked up in: System property: Hazelcast will first check if "hazelcast.client.config" system property is set to a file or a
classpath:...
path. - getOrCreateHazelcastClient(ClientConfig) - Static method in class com.hazelcast.client.HazelcastClient
-
Gets or creates a new HazelcastInstance (a new client in a cluster) with a certain name.
- getOrCreateHazelcastInstance() - Static method in class com.hazelcast.core.Hazelcast
-
Gets or creates a HazelcastInstance with the default XML configuration looked up in: System property: Hazelcast will first check if "hazelcast.config" system property is set to a file or a
classpath:...
path. - getOrCreateHazelcastInstance(Config) - Static method in class com.hazelcast.core.Hazelcast
-
Gets or creates the HazelcastInstance with a certain name.
- getOrCreateQueryCacheConfig(String, String) - Method in class com.hazelcast.client.config.ClientConfig
- getOrDefault(PropertyDefinition, T) - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
-
Returns the value of the requested
PropertyDefinition
if available in the declarative or programmatic configuration (XML or Config API), otherwise it will return the givendefaultValue
. - getOrDefault(String, PropertyDefinition, T) - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
-
Returns the value of the requested
PropertyDefinition
if available in the declarative or programmatic configuration (XML or Config API), can be found in the system's environment, or passed as a JVM property. otherwise it will return the givendefaultValue
. - getOrderComparator() - Method in class com.hazelcast.jet.core.Edge
-
Returns the comparator defined on this edge using
Edge.ordered(ComparatorEx)
. - getOriginatingMemberId() - Method in exception com.hazelcast.sql.HazelcastSqlException
-
Gets ID of the member that caused or initiated an error condition.
- getOriginClassName() - Method in exception com.hazelcast.client.UndefinedErrorCodeException
- getOrNull(PropertyDefinition) - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
-
Returns the value of the requested
PropertyDefinition
if available in the declarative or programmatic configuration (XML or Config API), otherwise it will returnnull
. - getOrNull(String, PropertyDefinition) - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
-
Returns the value of the requested
PropertyDefinition
if available in the declarative or programmatic configuration (XML or Config API), can be found in the system's environment, or passed as a JVM property. - getOrNullQueryCacheConfig(String, String) - Method in class com.hazelcast.client.config.ClientConfig
- getOtherOperationCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the total number of Other Operations
- getOtherOperationsCount() - Method in interface com.hazelcast.collection.LocalQueueStats
-
Returns number of other operations
- getOutboundEdges(String) - Method in class com.hazelcast.jet.core.DAG
-
Returns the outbound edges connected to the vertex with the given name.
- getOutboundPortDefinitions() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Returns the outbound port definitions.
- getOutboundPortDefinitions() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- getOutboundPortDefinitions() - Method in class com.hazelcast.config.EndpointConfig
- getOutboundPortDefinitions() - Method in class com.hazelcast.config.NetworkConfig
- getOutboundPorts() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Returns the outbound ports.
- getOutboundPorts() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- getOutboundPorts() - Method in class com.hazelcast.config.EndpointConfig
- getOutboundPorts() - Method in class com.hazelcast.config.NetworkConfig
- getOutbox() - Method in class com.hazelcast.jet.core.AbstractProcessor
- getOwnedEntryCount() - Method in interface com.hazelcast.cache.CacheStatistics
-
Returns the owned entry count in the cache.
- getOwnedEntryCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the number of entries owned by this member.
- getOwnedEntryCount() - Method in interface com.hazelcast.nearcache.NearCacheStats
- getOwnedEntryMemoryCost() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns memory cost (number of bytes) of owned entries in this member.
- getOwnedEntryMemoryCost() - Method in interface com.hazelcast.nearcache.NearCacheStats
- getOwnedItemCount() - Method in interface com.hazelcast.collection.LocalQueueStats
-
Returns the number of owned items in this member.
- getOwner() - Method in interface com.hazelcast.partition.Partition
-
Returns the current member that owns this partition.
- getOwnerAddress(ProcessorMetaSupplier.Context, Object) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Since the partition owner may not participate in job execution, always
ProcessorMetaSupplier.Context.partitionAssignment()
should be used to find the "actual" owner. - getOwnerBundle() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
-
Gets the owner
Bundle
of this instance. - getOwnerService() - Method in interface com.hazelcast.osgi.HazelcastOSGiInstance
-
Gets the owner
HazelcastOSGiService
of this instance. - getPackages() - Method in class com.hazelcast.config.ClassFilter
-
Returns unmodifiable set of package names.
- getPacketSizeLimit() - Method in class com.hazelcast.jet.config.EdgeConfig
-
Returns the limit on the
network packet size
, in bytes - getPage() - Method in interface com.hazelcast.query.PagingPredicate
-
Returns the current page value.
- getPageSize() - Method in class com.hazelcast.config.BTreeIndexConfig
-
Returns the page size of B-Tree index.
- getPageSize() - Method in class com.hazelcast.config.NativeMemoryConfig
-
Returns the page size, in bytes, to be allocated by native memory manager as a single block.
- getPageSize() - Method in interface com.hazelcast.query.PagingPredicate
-
Returns the page size.
- getParallelism() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Deprecated.Gets the configured number of Hot Restart store instance to create for one Hazelcast instance.
- getParallelism() - Method in class com.hazelcast.config.PersistenceConfig
-
Gets the configured number of Persistence store instance to create for one Hazelcast instance.
- getParameters() - Method in class com.hazelcast.sql.SqlStatement
-
Gets the statement parameter values.
- getParent() - Method in class com.hazelcast.spi.properties.HazelcastProperty
-
Returns the parent
ClusterProperty
of the property. - getParseDn() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- getPartition(Object) - Method in interface com.hazelcast.jet.core.DefaultPartitionStrategy
-
Returns the Hazelcast partition ID of the given object.
- getPartition(Object) - Method in interface com.hazelcast.partition.PartitionService
-
Returns the partition that the given key belongs to.
- getPartition(Object, int) - Method in class com.hazelcast.jet.core.Partitioner.Default
- getPartition(T, int) - Method in interface com.hazelcast.jet.core.Partitioner
-
Returns the partition ID of the given item.
- getPartitionArgumentIndex() - Method in class com.hazelcast.sql.SqlStatement
-
Get the partition argument index value
- getPartitioner() - Method in class com.hazelcast.jet.core.Edge
-
Returns the instance encapsulating the partitioning strategy in effect on this edge.
- getPartitionGroupConfig() - Method in class com.hazelcast.config.Config
-
Returns the partition group configuration for this hazelcast instance.
- getPartitionGroupStrategy() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
- getPartitionGroupStrategy() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategy
-
Deprecated.- use the above method that takes allMember arguments Returns a custom implementation of a
PartitionGroupStrategy
to override default behavior of zone aware backup strategiesPartitionGroupMetaData
or to provide a specific behavior in case the discovery environment does not provide information about the infrastructure to be used for automatic configuration. - getPartitionGroupStrategy() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategy
- getPartitionGroupStrategy(Collection<? extends Member>) - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
- getPartitionGroupStrategy(Collection<? extends Member>) - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategy
-
Returns a custom implementation of a
PartitionGroupStrategy
to override default behavior of zone aware backup strategiesPartitionGroupMetaData
or to provide a specific behavior in case the discovery environment does not provide information about the infrastructure to be used for automatic configuration. - getPartitionId() - Method in class com.hazelcast.map.EventLostEvent
- getPartitionId() - Method in class com.hazelcast.map.MapPartitionLostEvent
-
Returns the partition ID that has been lost for the given map
- getPartitionId() - Method in interface com.hazelcast.partition.Partition
-
Returns the ID of the partition.
- getPartitionId() - Method in interface com.hazelcast.partition.PartitionEvent
-
Returns the partition ID that the event is dispatched for.
- getPartitionId() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
-
Returns the partition ID the task is associated with.
- getPartitioningAttributeConfigs() - Method in class com.hazelcast.config.MapConfig
-
Get Partition Attribute configs used for creation of
AttributePartitioningStrategy
- getPartitioningAttributes() - Method in class com.hazelcast.partition.strategy.AttributePartitioningStrategy
- getPartitioningStrategy() - Method in class com.hazelcast.config.PartitioningStrategyConfig
- getPartitioningStrategyClass() - Method in class com.hazelcast.config.PartitioningStrategyConfig
- getPartitioningStrategyConfig() - Method in class com.hazelcast.config.MapConfig
- getPartitionInitialOffset(int) - Method in class com.hazelcast.jet.kafka.TopicsConfig.TopicConfig
-
Returns the initial offset for given partition or
null
if it was not defined. - getPartitionKey() - Method in interface com.hazelcast.core.DistributedObject
-
Returns the key of the partition that this DistributedObject is assigned to.
- getPartitionKey() - Method in interface com.hazelcast.partition.PartitionAware
-
The key that will be used by Hazelcast to specify the partition.
- getPartitionKey() - Method in class com.hazelcast.partition.PartitionAwareKey
- getPartitionKey() - Method in interface com.hazelcast.query.PartitionPredicate
-
Returns a random partition key from the collection.
- getPartitionKey(Object) - Method in class com.hazelcast.partition.strategy.AttributePartitioningStrategy
- getPartitionKey(Object) - Method in class com.hazelcast.partition.strategy.DefaultPartitioningStrategy
- getPartitionKey(Object) - Method in class com.hazelcast.partition.strategy.StringAndPartitionAwarePartitioningStrategy
- getPartitionKey(Object) - Method in class com.hazelcast.partition.strategy.StringPartitioningStrategy
- getPartitionKey(String) - Static method in class com.hazelcast.partition.strategy.StringPartitioningStrategy
- getPartitionKey(K) - Method in interface com.hazelcast.partition.PartitioningStrategy
-
Returns the key object that will be used by Hazelcast to specify the partition.
- getPartitionKeys() - Method in interface com.hazelcast.query.PartitionPredicate
- getPartitionLostListenerConfigs() - Method in class com.hazelcast.config.CacheConfig
-
Gets the partition lost listener references added to cache configuration.
- getPartitionLostListenerConfigs() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the partition lost listener references added to cache configuration.
- getPartitionLostListenerConfigs() - Method in class com.hazelcast.config.MapConfig
- getPartitions() - Method in interface com.hazelcast.partition.PartitionService
-
Returns a set containing all the
Partition
s in the cluster. - getPartitionService() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the partition service of this Hazelcast instance.
- getPartitionsInitialOffsets() - Method in class com.hazelcast.jet.kafka.TopicsConfig.TopicConfig
-
Returns partitions initial offsets map.
- getPassword() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
-
Returns the Java KeyStore password.
- getPassword() - Method in class com.hazelcast.config.replacer.AbstractPbeReplacer
-
Provides password for a chosen SecretKeyFactory.
- getPassword() - Method in class com.hazelcast.config.replacer.EncryptionReplacer
- getPassword() - Method in class com.hazelcast.config.security.UsernamePasswordIdentityConfig
- getPassword() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-
Deprecated.
- getPassword() - Method in interface com.hazelcast.security.PasswordCredentials
- getPassword() - Method in class com.hazelcast.security.UsernamePasswordCredentials
-
Gets the password.
- getPassword(String) - Method in class com.hazelcast.config.security.SimpleAuthenticationConfig
-
Return the configured password for given username.
- getPasswordAttribute() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- getPatch() - Method in class com.hazelcast.version.MemberVersion
- getPath() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
-
Returns the Java KeyStore file path.
- getPendingTaskCount() - Method in interface com.hazelcast.executor.LocalExecutorStats
-
Returns the number of pending operations on the executor service.
- getPermission(String, String, String...) - Static method in class com.hazelcast.security.permission.ActionConstants
-
Creates a permission
- getPermissions() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
- getPermissions(Subject, Class<? extends Permission>) - Method in interface com.hazelcast.security.IPermissionPolicy
-
Determines permissions of subject.
- getPersistenceConfig() - Method in class com.hazelcast.config.Config
-
Returns the Persistence configuration for this hazelcast instance
- getPersistenceCount() - Method in interface com.hazelcast.nearcache.NearCacheStats
- getPersistenceService() - Method in interface com.hazelcast.cluster.Cluster
-
Returns the public persistence service for interacting with Persistence
- getPersistentMemoryConfig() - Method in class com.hazelcast.config.NativeMemoryConfig
-
Returns the persistent memory configuration this native memory configuration uses.
- getPersistentMemoryDirectory() - Method in class com.hazelcast.config.NativeMemoryConfig
-
Deprecated.Since 4.1 multiple persistent memory directories are supported. Please use
PersistentMemoryConfig.getDirectoryConfigs()
instead. - getPipeline() - Method in interface com.hazelcast.jet.pipeline.Stage
-
Returns the
Pipeline
this stage belongs to. - getPlannedMigrations() - Method in interface com.hazelcast.partition.MigrationState
-
Returns the number of planned migrations in the migration plan.
- getPNCounter(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates or returns a
PNCounter
with the given name. - getPNCounterConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the
PNCounterConfig
for the given name, creating one if necessary and adding it to the collection of known configurations. - getPNCounterConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of PN counter configurations, mapped by config name.
- getPolicy() - Method in class com.hazelcast.config.MergePolicyConfig
-
Returns the class name of the
SplitBrainMergePolicy
. - getPollingInterval() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
-
Returns the polling interval (in seconds) for checking for changes in the KeyStore.
- getPollingInterval() - Method in class com.hazelcast.config.VaultSecureStoreConfig
-
Returns the Vault polling interval (in seconds).
- getPollOperationCount() - Method in interface com.hazelcast.collection.LocalQueueStats
-
Returns the number of poll/take/remove operations.
- getPoolSize() - Method in class com.hazelcast.config.DurableExecutorConfig
-
Gets the number of executor threads per member for the executor.
- getPoolSize() - Method in class com.hazelcast.config.ExecutorConfig
-
Gets the number of executor threads per member for the executor.
- getPoolSize() - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Gets the number of executor threads per member for the executor.
- getPort() - Method in class com.hazelcast.cluster.Address
- getPort() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- getPort() - Method in class com.hazelcast.config.NetworkConfig
-
Returns the port the Hazelcast member will try to bind on.
- getPort() - Method in class com.hazelcast.config.rest.RestConfig
-
Gets the port of the RestConfig.
- getPort() - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
Returns the port the Hazelcast member will try to bind on.
- getPortableFactories() - Method in class com.hazelcast.config.SerializationConfig
-
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.
- getPortableFactoryClasses() - 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.
- getPortableId() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Deprecated.
- getPortableId() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
Deprecated.
- getPortableId() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
- getPortableVersion() - 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.
- getPortCount() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- getPortCount() - Method in class com.hazelcast.config.NetworkConfig
-
Returns the maximum number of ports allowed to try to bind on.
- getPortCount() - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
Returns the maximum number of ports allowed to try to bind on.
- getPortRange() - Method in class com.hazelcast.config.tpc.TpcSocketConfig
-
Gets the possible port range for TPC sockets to bind.
- getPositiveMillisOrDefault(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
Returns the configured value of a
HazelcastProperty
converted to milliseconds if it is positive, otherwise returns its default value. - getPositiveMillisOrDefault(HazelcastProperty, long) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
Returns the configured value of a
HazelcastProperty
converted to milliseconds if it is positive, otherwise returns the passed default value. - getPredicateConfig() - Method in class com.hazelcast.config.QueryCacheConfig
-
Returns the predicate of
QueryCache
. - getPrefetchCount() - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
- getPrefetchCount() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
- getPrefetchValidityMillis() - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
- getPrefetchValidityMillis() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
- getPrefix() - Method in class com.hazelcast.config.replacer.EncryptionReplacer
- getPrefix() - Method in class com.hazelcast.config.replacer.PropertyReplacer
- getPrefix() - Method in interface com.hazelcast.config.replacer.spi.ConfigReplacer
-
Variable replacer prefix string.
- getPrefix(URI, ClassLoader) - Static method in class com.hazelcast.cache.CacheUtil
-
Gets the prefix of cache name without Hazelcast's
CacheManager
specific prefixHazelcastCacheManager.CACHE_MANAGER_PREFIX
. - getPrefixedCacheName(String, URI, ClassLoader) - Static method in class com.hazelcast.cache.CacheUtil
-
Gets the cache name with prefix but without Hazelcast's
CacheManager
specific prefixHazelcastCacheManager.CACHE_MANAGER_PREFIX
. - getPrefixedName() - Method in interface com.hazelcast.core.PrefixedDistributedObject
-
Returns the unique prefixed name for this DistributedObject.
- getPrefixes() - Method in class com.hazelcast.config.ClassFilter
-
Returns unmodifiable set of class name prefixes.
- getPreloaderConfig() - Method in class com.hazelcast.config.NearCacheConfig
-
Returns the
NearCachePreloaderConfig
of this Near Cache. - getPreloaderConfig(Node) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- getPreviousStatus() - Method in class com.hazelcast.jet.JobStatusEvent
- getPrincipal() - Method in class com.hazelcast.config.PermissionConfig
- getPrincipal() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
- getPrincipal() - Method in class com.hazelcast.config.security.KerberosIdentityConfig
- getPriority() - Method in class com.hazelcast.jet.core.Edge
-
Returns the value of edge's priority, as explained on
Edge.priority(int)
. - getPriority() - Method in enum class com.hazelcast.spi.discovery.DiscoveryStrategyFactory.DiscoveryStrategyLevel
- getPriorityComparatorClassName() - Method in class com.hazelcast.config.QueueConfig
-
Returns the class name that will be used to compare queue items.
- getPrivateAddress() - Method in class com.hazelcast.spi.discovery.DiscoveryNode
-
Returns the private address of the discovered node.
- getPrivateAddress() - Method in class com.hazelcast.spi.discovery.SimpleDiscoveryNode
- getProcessingGuarantee() - Method in class com.hazelcast.jet.config.JobConfig
-
Returns the configured
processing guarantee
. - getProducer(String) - Method in class com.hazelcast.jet.kafka.KafkaDataConnection
-
Returns an instance of
KafkaProducer
based on the DataConnection configuration. - getProducer(String, Properties) - Method in class com.hazelcast.jet.kafka.KafkaDataConnection
-
Returns an instance of
KafkaProducer
based on the DataConnection configuration and given properties. - getProductName() - Method in enum class com.hazelcast.config.InstanceTrackingConfig.InstanceProductName
-
Returns the string representation of the instance product name
- getProgress() - Method in class com.hazelcast.persistence.BackupTaskStatus
- getProperties() - Method in class com.hazelcast.client.config.ClientConfig
-
Gets
Properties
object - getProperties() - Method in class com.hazelcast.config.AbstractBaseFactoryWithPropertiesConfig
-
Gets all properties.
- getProperties() - Method in class com.hazelcast.config.AbstractWanPublisherConfig
-
Returns the WAN publisher properties.
- getProperties() - Method in class com.hazelcast.config.AbstractXmlConfigBuilder
-
Gets the current used properties.
- getProperties() - Method in class com.hazelcast.config.AbstractYamlConfigBuilder
-
Gets the current used properties.
- getProperties() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
-
Returns all properties.
- getProperties() - Method in class com.hazelcast.config.Config
-
Returns the properties set on this config instance.
- getProperties() - Method in class com.hazelcast.config.CredentialsFactoryConfig
- getProperties() - Method in class com.hazelcast.config.DataConnectionConfig
-
Returns all the properties of a data connection
- getProperties() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
- getProperties() - Method in class com.hazelcast.config.LoginModuleConfig
- getProperties() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns all the properties
- getProperties() - Method in class com.hazelcast.config.MemberAddressProviderConfig
- getProperties() - Method in class com.hazelcast.config.PermissionPolicyConfig
- getProperties() - Method in class com.hazelcast.config.QueueStoreConfig
-
Returns the properties to be used when instantiating the queue store.
- getProperties() - Method in class com.hazelcast.config.RingbufferStoreConfig
- getProperties() - Method in class com.hazelcast.config.ServiceConfig
- getProperties() - Method in class com.hazelcast.config.SocketInterceptorConfig
-
Gets all properties.
- getProperties() - Method in class com.hazelcast.config.WanConsumerConfig
-
Returns the properties for the custom WAN consumer.
- getProperties() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
-
Returns an immutable copy of the configuration properties.
- getProperties() - Method in class com.hazelcast.spi.discovery.DiscoveryNode
-
Returns a set of unmodifiable properties that are assigned to the discovered node.
- getProperties() - Method in class com.hazelcast.spi.discovery.SimpleDiscoveryNode
- getProperty(String) - Method in class com.hazelcast.client.config.ClientConfig
-
Gets a named property already set or from system properties if not exists.
- getProperty(String) - Method in class com.hazelcast.config.AbstractBaseFactoryWithPropertiesConfig
-
Gets a property.
- getProperty(String) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
-
Returns property value by the property name.
- getProperty(String) - Method in class com.hazelcast.config.Config
-
Returns the value for a named property.
- getProperty(String) - Method in class com.hazelcast.config.DataConnectionConfig
-
Returns a single property of a data connection
- getProperty(String) - Method in class com.hazelcast.config.MapStoreConfig
-
Returns the given property
- getProperty(String) - Method in class com.hazelcast.config.QueueStoreConfig
-
Returns the property with the given
name
which is used when instantiating and interacting with the queue store. - getProperty(String) - Method in class com.hazelcast.config.RingbufferStoreConfig
- getProperty(String) - Method in class com.hazelcast.config.SocketInterceptorConfig
-
Gets a property.
- getProperty(String, String) - Method in class com.hazelcast.config.DataConnectionConfig
-
Returns a single property of a data connection
- getPropertyName() - Method in enum class com.hazelcast.config.InstanceTrackingConfig.InstanceTrackingProperties
-
Returns the property name which can be used in placeholders to be resolved to an actual property value.
- getProtectOn() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
- getProtocol() - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Return the SSL protocol to use.
- getProtocolType() - Method in class com.hazelcast.config.EndpointConfig
- getProtocolType() - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- getProviderFilter() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Deprecated.Get current filter or
null
when no filter is defined. - getProviderMode() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Deprecated.Return the current ProviderMode
- getProxyFactoryConfigs() - Method in class com.hazelcast.client.config.ClientConfig
-
Gets list of
ProxyFactoryConfig
- getPublicAddress() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- getPublicAddress() - Method in class com.hazelcast.config.NetworkConfig
- getPublicAddress() - Method in class com.hazelcast.config.ServerSocketEndpointConfig
- getPublicAddress() - Method in class com.hazelcast.spi.discovery.DiscoveryNode
-
Returns the public address of the discovered node if available.
- getPublicAddress() - Method in class com.hazelcast.spi.discovery.SimpleDiscoveryNode
- getPublicAddress() - Method in interface com.hazelcast.spi.MemberAddressProvider
-
What address should Hazelcast advertise to other members and clients.
- getPublicAddress(EndpointQualifier) - Method in interface com.hazelcast.spi.MemberAddressProvider
- getPublisherId() - Method in class com.hazelcast.config.AbstractWanPublisherConfig
-
Returns the publisher ID used for identifying the publisher in a
WanReplicationConfig
. - getPublisherId() - Method in class com.hazelcast.config.WanCustomPublisherConfig
- getPublishingMember() - Method in class com.hazelcast.topic.Message
-
Returns the member that published the message.
- getPublishOperationCount() - Method in interface com.hazelcast.topic.LocalTopicStats
-
Returns the total number of published messages of this topic on this member
- getPublishTime() - Method in class com.hazelcast.topic.Message
-
Return the time when the message is published
- getPutOperationCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the number of put operations
- getQualifier() - Method in class com.hazelcast.config.EndpointConfig
- getQualifier() - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- getQueryCache(String) - Method in interface com.hazelcast.map.IMap
-
Returns corresponding
QueryCache
instance for the suppliedname
or null. - getQueryCache(String, MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.map.IMap
-
Creates an always up-to-date snapshot of this
IMap
according to the supplied parameters. - getQueryCache(String, Predicate<K, V>, boolean) - Method in interface com.hazelcast.map.IMap
-
Creates an always up-to-date snapshot of this
IMap
according to the supplied parameters. - getQueryCacheConfigs() - Method in class com.hazelcast.client.config.ClientConfig
- getQueryCacheConfigs() - Method in class com.hazelcast.config.MapConfig
-
Returns all
QueryCacheConfig
instances defined on thisMapConfig
. - getQueryCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the total number of queries performed on the map.
- getQueryCount() - Method in interface com.hazelcast.query.LocalIndexStats
-
Returns the total number of queries served by the index.
- getQueryResultSizeExceededCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Get throw count of
QueryResultSizeExceededException
- getQueue() - Method in class com.hazelcast.console.ConsoleApp
- getQueue(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates or returns the distributed queue instance with the specified name.
- getQueue(String) - Method in class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
- getQueue(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
-
Returns the transactional queue instance with the specified name.
- getQueueCapacity() - Method in class com.hazelcast.config.ExecutorConfig
-
Gets the queue capacity of the executor task. 0 means
Integer.MAX_VALUE
. - getQueueCapacity() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the capacity of the primary and backup queue for WAN replication events.
- getQueueConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the QueueConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
- getQueueConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of
IQueue
configurations, mapped by config name. - getQueueFullBehavior() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the configured behaviour of this WAN publisher when the WAN queue is full.
- getQueueSize() - Method in class com.hazelcast.jet.config.EdgeConfig
-
Returns the size of the SPSC queues used to implement this edge.
- getQueueStoreConfig() - Method in class com.hazelcast.config.QueueConfig
-
Get the QueueStore (load and store queue items from/to a database) configuration.
- getRaftAlgorithmConfig() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Returns configuration options for Hazelcast's Raft consensus algorithm implementation
- getRatio() - Method in interface com.hazelcast.nearcache.NearCacheStats
- getRawDataInput() - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- getRawDataOutput() - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.After writing portable fields one can subsequently write remaining fields in the old-fashioned way.
- getRawKey() - Method in interface com.hazelcast.spi.merge.MergingEntry
-
Returns the merging key in the in-memory format of the backing data structure.
- getRawValue() - Method in interface com.hazelcast.spi.merge.MergingValue
-
Returns the merging value in the in-memory format of the backing data structure.
- getReadBatchSize() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
-
Gets the maximum number of items to read in a batch.
- getReadBatchSize() - Method in class com.hazelcast.config.ReliableTopicConfig
-
Gets the maximum number of items to read in a batch.
- getReadIOThreadCount() - Method in class com.hazelcast.config.LocalDeviceConfig
-
Returns the read IO thread count;
- getReadTimeout() - Method in class com.hazelcast.spring.cache.HazelcastCache
-
Return cache retrieval timeout in milliseconds
- getReadTimeoutMap() - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
-
Return cache-specific value retrieval timeouts.
- getReadyReplicas() - Method in class com.hazelcast.kubernetes.RuntimeContext
- getRealm() - Method in class com.hazelcast.config.security.KerberosIdentityConfig
- getRealmConfig() - Method in class com.hazelcast.security.RealmConfigCallback
- getRealmConfig(String) - Method in class com.hazelcast.client.config.ClientSecurityConfig
- getRealmConfig(String) - Method in class com.hazelcast.config.SecurityConfig
- getRealmConfigs() - Method in class com.hazelcast.client.config.ClientSecurityConfig
- getRealmConfigs() - Method in class com.hazelcast.config.SecurityConfig
- getRealmCredentialsFactory(String) - Method in class com.hazelcast.config.SecurityConfig
- getRealmLoginModuleConfigs(String) - Method in class com.hazelcast.config.SecurityConfig
- getRealmName() - Method in class com.hazelcast.security.RealmConfigCallback
- getRealmName() - Method in class com.hazelcast.security.RealmNameCallback
- getRebalanceDelaySeconds() - Method in class com.hazelcast.config.PersistenceConfig
-
Get the configured rebalance delay in seconds.
- getReceiveBufferSizeKB() - Method in class com.hazelcast.config.tpc.TpcSocketConfig
-
Gets the receive-buffer size of the TPC sockets in kilobytes.
- getReceiveOperationCount() - Method in interface com.hazelcast.topic.LocalTopicStats
-
Returns the total number of received messages of this topic on this member
- getReceiveWindowMultiplier() - Method in class com.hazelcast.jet.config.EdgeConfig
- getReconnectMode() - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
- getRegistrations(CompactSerializationConfig) - Static method in class com.hazelcast.config.CompactSerializationConfigAccessor
-
Returns the map of the type names to programmatic registrations.
- getRejectedOfferOperationCount() - Method in interface com.hazelcast.collection.LocalQueueStats
-
Returns the number of rejected offers.
- getRelaxFlagsCheck() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
- getReleaseVersion() - Method in class com.hazelcast.config.AbstractXmlConfigHelper
- getReliableTopic(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates or returns the reliable topic instance with the specified name.
- getReliableTopic(String) - Method in interface com.hazelcast.jet.JetInstance
-
Deprecated.since 5.0 Use
HazelcastInstance.getReliableTopic(String)
instead. - getReliableTopicConfig(String) - Method in class com.hazelcast.client.config.ClientConfig
-
Gets the ClientReliableTopicConfig for a given reliable topic name.
- getReliableTopicConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the ReliableTopicConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
- getReliableTopicConfigMap() - Method in class com.hazelcast.client.config.ClientConfig
-
Returns the map of reliable topic configurations, mapped by config name.
- getReliableTopicConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of reliable topic configurations, mapped by config name.
- getRemainingMigrations() - Method in interface com.hazelcast.partition.MigrationState
-
Returns the number of remaining migrations in the migration plan.
- getRemoveCount() - Method in interface com.hazelcast.query.LocalIndexStats
-
Returns the number of remove operations performed on the index.
- getRemoveCount() - Method in class com.hazelcast.wan.WanEventCounters.DistributedObjectWanEventCounters
-
Returns the number of entry remove events
- getRemoveOperationCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the number of Remove operations
- getReplacement(String) - Method in class com.hazelcast.config.replacer.AbstractPbeReplacer
- getReplacement(String) - Method in class com.hazelcast.config.replacer.PropertyReplacer
- getReplacement(String) - Method in interface com.hazelcast.config.replacer.spi.ConfigReplacer
-
Provides String which should be used as a variable replacement for given masked value.
- getReplicaCount() - Method in class com.hazelcast.config.PNCounterConfig
-
Returns the number of replicas on which state for this PN counter will be kept.
- getReplicaIndex() - Method in interface com.hazelcast.partition.ReplicaMigrationEvent
-
Returns the index of the partition replica. 0th index is primary replica, 1st index is 1st backup and so on.
- getReplicatedMap(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates or returns the replicated map instance with the specified name.
- getReplicatedMap(String) - Method in interface com.hazelcast.jet.JetInstance
-
Deprecated.since 5.0 Use
HazelcastInstance.getReplicatedMap(String)
instead. - getReplicatedMapConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the ReplicatedMapConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
- getReplicatedMapConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of
ReplicatedMap
configurations, mapped by config name. - getReplicatedMapStats() - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
-
Returns LocalReplicatedMapStats for this replicated map.
- getReplicationPeriodMillis() - Method in class com.hazelcast.config.CRDTReplicationConfig
-
Returns the period between two replications of CRDT states in milliseconds.
- getReplicationStats() - Method in interface com.hazelcast.cache.CacheStatistics
- getReplicationStats() - Method in interface com.hazelcast.map.LocalMapStats
- getRequestTimeoutDuration() - Method in class com.hazelcast.config.rest.RestConfig
-
Return the HTTP request timeout.
- getRequiredMember() - Method in class com.hazelcast.config.TcpIpConfig
-
Gets the required member.
- getRequiredPermission() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Returns the required permission to execute the vertex which has this ProcessorMetaSupplier.
- getResourceConfigs() - Method in class com.hazelcast.jet.config.JobConfig
-
Returns all the registered resource configurations.
- getResourceDefinitions(UserCodeNamespaceConfig) - Static method in class com.hazelcast.config.ConfigAccessor
- getResourceFactory() - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
- getResourceType() - Method in class com.hazelcast.jet.config.ResourceConfig
-
Returns the type of the resource.
- getResourceVersion() - Method in class com.hazelcast.kubernetes.RuntimeContext
- getResponseTimeoutMillis() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the duration in milliseconds for the wait time before retrying to send the events to target cluster again in case the acknowledgement has not arrived.
- getRestApiConfig() - Method in class com.hazelcast.config.NetworkConfig
-
Deprecated, for removal: This API element is subject to removal in a future version.since 5.5, use Config.getRestConfig() instead. Will be removed at 6.0.
- getRestConfig() - Method in class com.hazelcast.config.Config
-
Gets the configuration for the REST API server.
- getRestEndpointConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig
- getRestEndpointGroup(int) - Static method in enum class com.hazelcast.config.RestEndpointGroup
-
Deprecated.
- getResubmissionMode() - Method in class com.hazelcast.client.config.ClientSqlConfig
-
Returns the resubmission mode for failing SQL queries.
- getRetentionSeconds() - Method in class com.hazelcast.config.MetricsManagementCenterConfig
-
Returns the number of seconds the metrics will be retained on the instance.
- getRingbuffer(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates or returns the distributed Ringbuffer instance with the specified name.
- getRingbufferConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the RingbufferConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
- getRingbufferConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of
Ringbuffer
configurations, mapped by config name. - getRingbufferStoreConfig() - Method in class com.hazelcast.config.RingbufferConfig
-
Get the RingbufferStore (load and store ringbuffer items from/to a database) configuration.
- getRoleAttribute() - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
- getRoleContext() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- getRoleFilter() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- getRoleMappingAttribute() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- getRoleMappingMode() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- getRoleMappingMode(String) - Static method in enum class com.hazelcast.config.security.LdapRoleMappingMode
- getRoleNameAttribute() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- getRoleRecursionMaxDepth() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- getRoles(String) - Method in class com.hazelcast.config.security.SimpleAuthenticationConfig
-
Returns role names assigned to the given user.
- getRoleSearchScope() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- getRoleSeparator() - Method in class com.hazelcast.config.security.SimpleAuthenticationConfig
-
Returns the custom role separator (when set).
- getRoutingMode() - Method in class com.hazelcast.client.config.ClusterRoutingConfig
-
Returns the defined
RoutingMode
for this client to use when connecting to cluster members. - getRoutingPolicy() - Method in class com.hazelcast.jet.core.Edge
-
Returns the
Edge.RoutingPolicy
in effect on the edge. - getRoutingStrategy() - Method in class com.hazelcast.client.config.ClusterRoutingConfig
-
Returns the strategy for routing client connections to members when
RoutingMode.MULTI_MEMBER
is configured. - getRowMetadata() - Method in interface com.hazelcast.sql.SqlResult
-
Gets the row metadata.
- getSalt() - Method in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
-
Returns the salt.
- getScaleUpDelayMillis() - Method in class com.hazelcast.jet.config.InstanceConfig
-
Deprecated.Returns the scale-up delay, see
InstanceConfig.setScaleUpDelayMillis(long)
. - getScaleUpDelayMillis() - Method in class com.hazelcast.jet.config.JetConfig
-
Returns the scale-up delay, see
JetConfig.setScaleUpDelayMillis(long)
. - getScheduledExecutorConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the ScheduledExecutorConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
- getScheduledExecutorConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of scheduled executor configurations, mapped by config name.
- getScheduledExecutorService(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates or returns the
IScheduledExecutorService
scheduled executor service for the given name. - getScheduledFuture(ScheduledTaskHandler) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
-
Creates a new
IScheduledFuture
from the given handler. - getSchedulerName() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
-
Return the name of the ScheduledExecutor this tasks is running on.
- getSchema() - Method in class com.hazelcast.sql.SqlStatement
-
Gets the schema name.
- getScopedHost() - Method in class com.hazelcast.cluster.Address
- getScopeId() - Method in class com.hazelcast.cluster.Address
- getScore() - Method in interface com.hazelcast.vector.SearchResult
- getSearchScope(String) - Static method in enum class com.hazelcast.config.security.LdapSearchScope
- getSeconds(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
Returns the configured value of a
HazelcastProperty
converted to seconds. - getSecretPath() - Method in class com.hazelcast.config.VaultSecureStoreConfig
-
Returns the Vault secret path.
- getSecureStoreConfig() - Method in class com.hazelcast.config.EncryptionAtRestConfig
-
Returns the Secure Store configuration.
- getSecurityConfig() - Method in class com.hazelcast.client.config.ClientConfig
-
Gets
ClientSecurityConfig
object which allows client credentials configuration. - getSecurityConfig() - Method in class com.hazelcast.config.Config
-
Returns the security configuration for this hazelcast instance.
- getSecurityContext() - Method in class com.hazelcast.security.SecurityContextCallback
- getSecurityInterceptorConfigs() - Method in class com.hazelcast.config.SecurityConfig
- getSecurityRealm() - Method in class com.hazelcast.config.rest.RestConfig
-
Gets the name of the Rest security realm.
- getSecurityRealm() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
- getSecurityRealm() - Method in class com.hazelcast.config.security.KerberosIdentityConfig
- getSecurityRealm() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- getSemaphore(String) - Method in interface com.hazelcast.cp.CPSubsystem
-
Returns a proxy for an
ISemaphore
instance created on CP Subsystem. - getSemaphore(String) - Method in class com.hazelcast.cp.CPSubsystemStubImpl
- getSemaphoreConfigs() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Returns the map of CP
ISemaphore
configurations - getSendBufferSizeKB() - Method in class com.hazelcast.config.tpc.TpcSocketConfig
-
Gets the send-buffer size of the TPC sockets in kilobytes.
- getSequence(int) - Method in interface com.hazelcast.ringbuffer.ReadResultSet
-
Return the sequence number for the item at the given index.
- getSerializationConfig() - Method in class com.hazelcast.client.config.ClientConfig
-
Gets
SerializationConfig
- getSerializationConfig() - Method in class com.hazelcast.config.Config
-
Returns the serialization configuration for this hazelcast instance.
- getSerializationType() - Method in class com.hazelcast.jet.protobuf.ProtobufSerializerHook
- getSerializationType() - Method in interface com.hazelcast.nio.serialization.SerializerHook
-
Returns the actual class type of the serialized object
- getSerializerClassNames(CompactSerializationConfig) - Static method in class com.hazelcast.config.CompactSerializationConfigAccessor
-
Returns the list of Compact serializer class names.
- getSerializerConfigs() - Method in class com.hazelcast.config.SerializationConfig
- getSerializerConfigs() - Method in class com.hazelcast.jet.config.JobConfig
-
Returns all the registered serializer configurations.
- getService() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
- getServiceName() - Method in interface com.hazelcast.core.DistributedObject
-
Returns the service name for this object.
- getServiceName() - Method in class com.hazelcast.core.DistributedObjectEvent
-
Returns the service name of related DistributedObject.
- getServiceName() - Method in interface com.hazelcast.wan.WanEvent
-
Returns the service name on which this event occurred.
- getServiceNamePrefix() - Method in class com.hazelcast.config.security.KerberosIdentityConfig
- getServicesConfig() - Method in class com.hazelcast.config.Config
-
Returns the configuration for the user services managed by this hazelcast instance.
- getServicesConfig(Config) - Static method in class com.hazelcast.config.ConfigAccessor
- getSessionHeartbeatIntervalSeconds() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Returns the interval for the periodically-committed CP session heartbeats.
- getSessionTimeToLiveSeconds() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Returns the duration for a CP session to be kept alive after its last session heartbeat.
- getSet() - Method in class com.hazelcast.console.ConsoleApp
- getSet(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates or returns the distributed set instance with the specified name.
- getSet(String) - Method in class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
- getSet(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
-
Returns the transactional set instance with the specified name.
- getSetConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the SetConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
- getSetConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of
ISet
configurations, mapped by config name. - getSetOperationCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the number of set operations
- getSimpleAuthenticationConfig() - Method in class com.hazelcast.config.security.RealmConfig
- getSingleType() - Method in enum class com.hazelcast.nio.serialization.FieldType
- getSize() - Method in class com.hazelcast.config.EvictionConfig
-
Returns the size which is used by the
MaxSizePolicy
. - getSize() - Method in class com.hazelcast.config.NativeMemoryConfig
-
Deprecated.Since 5.2, use
NativeMemoryConfig.getCapacity()
instead. - getSkipAuthentication() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- getSkipEndpoint() - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
- getSkipIdentity() - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
- getSkipRole() - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
- getSnapshotIntervalMillis() - Method in class com.hazelcast.jet.config.JobConfig
-
Returns the configured
snapshot interval
. - getSocketAddress() - Method in interface com.hazelcast.client.Client
-
Returns the socket address of this client.
- getSocketAddress() - Method in interface com.hazelcast.cluster.Endpoint
-
Returns the socket address for this endpoint.
- getSocketAddress() - Method in interface com.hazelcast.cluster.Member
-
Returns the socket address of this member for member to member communications or unified depending on config.
- getSocketAddress(EndpointQualifier) - Method in interface com.hazelcast.cluster.Member
-
Returns the socket address of this member.
- getSocketConnectTimeoutSeconds() - Method in class com.hazelcast.config.EndpointConfig
- getSocketFactoryClassName() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- getSocketInterceptorConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
- getSocketInterceptorConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- getSocketInterceptorConfig() - Method in class com.hazelcast.config.EndpointConfig
-
Gets the
SocketInterceptorConfig
. - getSocketInterceptorConfig() - Method in class com.hazelcast.config.NetworkConfig
-
Gets the
SocketInterceptorConfig
. - getSocketKeepCount() - Method in class com.hazelcast.config.EndpointConfig
-
Keep-Alive count: the maximum number of TCP keep-alive probes to send before giving up and closing the connection if no response is obtained from the other side.
- getSocketKeepIdleSeconds() - Method in class com.hazelcast.config.EndpointConfig
-
Keep-Alive idle time: the number of seconds of idle time before keep-alive initiates a probe.
- getSocketKeepIntervalSeconds() - Method in class com.hazelcast.config.EndpointConfig
-
Keep-Alive interval: the number of seconds between keep-alive probes.
- getSocketLingerSeconds() - Method in class com.hazelcast.config.EndpointConfig
- getSocketOptions() - Method in class com.hazelcast.client.config.ClientNetworkConfig
- getSocketRcvBufferSizeKb() - Method in class com.hazelcast.config.EndpointConfig
- getSocketSendBufferSizeKb() - Method in class com.hazelcast.config.EndpointConfig
- getSource() - Method in class com.hazelcast.jet.core.Edge
-
Returns this edge's source vertex.
- getSource() - Method in class com.hazelcast.map.AbstractIMapEvent
-
Returns the object on which the event initially occurred.
- getSource() - Method in interface com.hazelcast.partition.ReplicaMigrationEvent
-
Returns the old owner of the migrating partition replica.
- getSourceName() - Method in class com.hazelcast.jet.core.Edge
-
Returns the name of the source vertex.
- getSourceOrdinal() - Method in class com.hazelcast.jet.core.Edge
-
Returns the ordinal of the edge at the source vertex.
- getSpecifiedReplicaCount() - Method in class com.hazelcast.kubernetes.RuntimeContext
- getSplitBrainProtection(String) - Method in interface com.hazelcast.splitbrainprotection.SplitBrainProtectionService
-
Returns the
SplitBrainProtection
instance for a given split brain protection name. - getSplitBrainProtectionConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the
SplitBrainProtectionConfig
for the given name, creating one if necessary and adding it to the collection of known configurations. - getSplitBrainProtectionConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of split brain protection configurations, mapped by config name.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.CacheConfig
-
Gets the name of the associated split brain protection if any.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the name of the associated split brain protection if any.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
Returns the split brain protection name for operations.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.CollectionConfig
-
Returns the split brain protection name for operations.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.DurableExecutorConfig
-
Returns the split brain protection name for operations.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.ExecutorConfig
-
Returns the split brain protection name for operations.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.MapConfig
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.MultiMapConfig
-
Returns the split brain protection name for operations.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.PNCounterConfig
-
Returns the split brain protection name for operations.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.QueueConfig
-
Returns the split brain protection name for queue operations.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
Returns the split brain protection name for operations.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.RingbufferConfig
-
Returns the split brain protection name for operations.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Returns the split brain protection name for operations.
- getSplitBrainProtectionName() - Method in interface com.hazelcast.config.SplitBrainPolicyAwareConfig
-
Returns the split brain protection name for operations of the data structure.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.vector.VectorCollectionConfig
-
Returns the split brain protection name for operations of the data structure.
- getSplitBrainProtectionService() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the split brain protection service of this Hazelcast instance.
- getSpn() - Method in class com.hazelcast.config.security.KerberosIdentityConfig
- getSql() - Method in class com.hazelcast.config.PredicateConfig
-
Returns sql string for this config.
- getSql() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns a service to execute distributed SQL queries.
- getSql() - Method in interface com.hazelcast.jet.JetInstance
-
Deprecated.since 5.0 Use
HazelcastInstance.getSql()
instead. - getSql() - Method in class com.hazelcast.sql.SqlStatement
-
Gets the SQL string to be executed.
- getSqlConfig() - Method in class com.hazelcast.client.config.ClientConfig
-
Returns the configuration for the SQL feature.
- getSqlConfig() - Method in class com.hazelcast.config.Config
- getSsl() - Method in class com.hazelcast.config.rest.RestConfig
-
Gets the SSL configuration.
- getSSLConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Returns the current
SSLConfig
. - getSSLConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- getSSLConfig() - Method in class com.hazelcast.config.EndpointConfig
-
Returns the current
SSLConfig
. - getSSLConfig() - Method in class com.hazelcast.config.NetworkConfig
-
Returns the current
SSLConfig
. - getSSLConfig() - Method in class com.hazelcast.config.VaultSecureStoreConfig
-
Returns the SSL/TLS configuration.
- getStartedTaskCount() - Method in interface com.hazelcast.executor.LocalExecutorStats
-
Returns the number of started operations on the executor service.
- getStartTime() - Method in interface com.hazelcast.partition.MigrationState
-
Returns the start time of the migration in milliseconds since the epoch.
- getState() - Method in class com.hazelcast.core.LifecycleEvent
- getState() - Method in class com.hazelcast.persistence.BackupTaskStatus
- getStatementTimeoutMillis() - Method in class com.hazelcast.config.SqlConfig
-
Gets the timeout in milliseconds that is applied to statements without an explicit timeout.
- getStats() - Method in interface com.hazelcast.scheduledexecutor.IScheduledFuture
-
Returns the statistics and time measurement info of the execution of this scheduled future in the
IScheduledExecutorService
it was scheduled. - getStatus() - Method in interface com.hazelcast.jet.Job
-
Returns the current status of this job.
- getStoreImplementation() - Method in class com.hazelcast.config.QueueStoreConfig
-
Returns the implementation of the queue store which will be used to store queue items.
- getStoreImplementation() - Method in class com.hazelcast.config.RingbufferStoreConfig
- getStoreInitialDelaySeconds() - Method in class com.hazelcast.config.NearCachePreloaderConfig
- getStoreIntervalSeconds() - Method in class com.hazelcast.config.NearCachePreloaderConfig
- getString(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
Returns the configured value of a
HazelcastProperty
as String. - getString(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getSubmissionTime() - Method in interface com.hazelcast.jet.Job
-
Returns the time when the job was submitted to the cluster.
- getSuggestion() - Method in exception com.hazelcast.sql.HazelcastSqlException
-
Gets the suggested SQL statement to remediate experienced error
- getSuspensionCause() - Method in interface com.hazelcast.jet.Job
-
Return a
description of the cause
that has led to the suspension of the job. - getSymmetricEncryptionConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- getSymmetricEncryptionConfig() - Method in class com.hazelcast.config.EndpointConfig
-
Deprecated.since 4.2
- getSymmetricEncryptionConfig() - Method in class com.hazelcast.config.NetworkConfig
-
Deprecated.since 4.2
- getSyncConfig() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the config for the WAN sync mechanism.
- getSyncCount() - Method in class com.hazelcast.wan.WanEventCounters.DistributedObjectWanEventCounters
-
Returns the number of entry sync events
- getSystemAuthentication() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- getSystemProperty() - Method in class com.hazelcast.spi.properties.HazelcastProperty
-
Gets the system property value of the property.
- getSystemUserDn() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- getSystemUserPassword() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- getTag() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
- getTags() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Returns the metadata on this supplier, a string-to-string map.
- getTailSequence() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
-
Returns the sequence of the tail.
- getTarget() - Method in interface com.hazelcast.query.PartitionPredicate
-
Returns the target
Predicate
. - getTarget() - Method in exception com.hazelcast.spi.exception.WrongTargetException
- getTargetEndpoints() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the comma separated list of target cluster members, e.g.
- getTaskId() - Method in interface com.hazelcast.durableexecutor.DurableExecutorServiceFuture
-
A unique ID for the executing task
- getTaskName() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
-
Returns the name of the task.
- getTcpIpConfig() - Method in class com.hazelcast.config.JoinConfig
- getTenantControl() - Method in interface com.hazelcast.spi.tenantcontrol.Tenantable
-
Retrieves the tenant control relevant for this given object.
- getTestMode() - Method in class com.hazelcast.jet.core.test.TestSupport.TestContext
- getTextContent(Node) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- getThreshold() - Method in class com.hazelcast.splitbrainprotection.SplitBrainProtectionEvent
-
Returns the predefined split brain protection threshold
- getTieredStoreConfig() - Method in class com.hazelcast.config.MapConfig
-
Gets the
TieredStoreConfig
for thisMapConfig
- getTime(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getTimedExpiryPolicyFactoryConfig() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
- getTimeoutMillis() - Method in class com.hazelcast.jet.config.JobConfig
-
Returns maximum execution time for the job in milliseconds.
- getTimeoutMillis() - Method in class com.hazelcast.sql.SqlStatement
-
Gets the execution timeout in milliseconds.
- getTimeoutMillis() - Method in class com.hazelcast.transaction.TransactionOptions
-
Gets the timeout in milliseconds.
- getTimeoutMilliseconds() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
- getTimeoutMilliseconds() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
- getTimestamp() - Method in interface com.hazelcast.auditlog.AuditableEvent
-
Returns event timestamp as milliseconds from the epoch.
- getTimestamp(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getTimestampWithTimezone(String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
- getTimeToLiveSeconds() - Method in class com.hazelcast.config.EventJournalConfig
-
Gets the time to live in seconds.
- getTimeToLiveSeconds() - Method in class com.hazelcast.config.MapConfig
-
Returns the maximum number of seconds for each entry to stay in the map.
- getTimeToLiveSeconds() - Method in class com.hazelcast.config.NearCacheConfig
-
Returns the maximum number of seconds for each entry to stay in the Near Cache (time to live).
- getTimeToLiveSeconds() - Method in class com.hazelcast.config.RingbufferConfig
-
Gets the time to live in seconds.
- getTimeUnit() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
- getTimeUnit() - Method in class com.hazelcast.spi.properties.HazelcastProperty
-
Returns the
TimeUnit
of the property. - getTlsAuthenticationConfig() - Method in class com.hazelcast.config.security.RealmConfig
- getToken() - Method in class com.hazelcast.config.security.TokenIdentityConfig
- getToken() - Method in class com.hazelcast.config.VaultSecureStoreConfig
-
Returns the Vault access token.
- getToken() - Method in class com.hazelcast.security.SimpleTokenCredentials
-
Gets the token.
- getToken() - Method in interface com.hazelcast.security.TokenCredentials
-
Returns the token as a byte array.
- getTokenEncoded() - Method in class com.hazelcast.config.security.TokenIdentityConfig
- getTokenEncoding(String) - Static method in enum class com.hazelcast.config.security.TokenEncoding
- getTokenIdentityConfig() - Method in class com.hazelcast.client.config.ClientSecurityConfig
- getTokenIdentityConfig() - Method in class com.hazelcast.config.security.RealmConfig
- getTokenValidityDuration() - Method in class com.hazelcast.config.rest.RestConfig
-
Gets the token validity duration.
- getTombstoneInfos(CPGroupId, String) - Method in interface com.hazelcast.cp.CPSubsystem
-
Returns info about all tombstones of given type within the given group
- getTombstoneInfos(CPGroupId, String) - Method in class com.hazelcast.cp.CPSubsystemStubImpl
- getTopic() - Method in class com.hazelcast.console.ConsoleApp
- getTopic(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates or returns the distributed topic instance with the specified name.
- getTopicConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the TopicConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
- getTopicConfig(String) - Method in class com.hazelcast.jet.kafka.TopicsConfig
-
Returns the topic configuration for given topic.
- getTopicConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of reliable topic configurations, mapped by config name.
- getTopicConfigs() - Method in class com.hazelcast.jet.kafka.TopicsConfig
-
Returns the map of topic configurations, mapped by topic name.
- getTopicName() - Method in class com.hazelcast.jet.kafka.TopicsConfig.TopicConfig
-
Returns the name of the topic.
- getTopicNames() - Method in class com.hazelcast.jet.kafka.TopicsConfig
-
Returns the set of topic names from topic configurations.
- getTopicOverloadPolicy() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
-
Gets the TopicOverloadPolicy for this reliable topic.
- getTopicOverloadPolicy() - Method in class com.hazelcast.config.ReliableTopicConfig
-
Gets the TopicOverloadPolicy for this reliable topic.
- getToPort() - Method in class com.hazelcast.spi.utils.PortRange
- getTotal() - Method in class com.hazelcast.persistence.BackupTaskStatus
- getTotalBackupCount() - Method in class com.hazelcast.config.CacheConfig
-
Gets the total backup count (
backupCount + asyncBackupCount
) of the cache. - getTotalBackupCount() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
Returns the total number of backups: backupCount plus asyncBackupCount.
- getTotalBackupCount() - Method in class com.hazelcast.config.CollectionConfig
-
Gets the total number of synchronous and asynchronous backups for this collection.
- getTotalBackupCount() - Method in class com.hazelcast.config.MapConfig
-
Returns the total number of backups: backupCount plus asyncBackupCount.
- getTotalBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
-
Gets the total number of backups (synchronous + asynchronous) for this MultiMap.
- getTotalBackupCount() - Method in class com.hazelcast.config.QueueConfig
-
Get the total number of backups: the backup count plus the asynchronous backup count.
- getTotalBackupCount() - Method in class com.hazelcast.config.RingbufferConfig
-
Returns the total number of backups: backupCount plus asyncBackupCount.
- getTotalBackupCount() - Method in class com.hazelcast.config.vector.VectorCollectionConfig
-
Returns the total number of backups: backupCount plus asyncBackupCount.
- getTotalElapsedTime() - Method in interface com.hazelcast.partition.MigrationState
-
Returns the total elapsed time of completed migrations in milliseconds.
- getTotalExecutionLatency() - Method in interface com.hazelcast.executor.LocalExecutorStats
-
Returns the total execution time of operations finished.
- getTotalGetLatency() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the total latency of get operations.
- getTotalIdleTime(TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.ScheduledTaskStatistics
-
Returns the total amount of time the task was idle, waiting to get scheduled in.
- getTotalInsertLatency() - Method in interface com.hazelcast.query.LocalIndexStats
-
Returns the total latency (in nanoseconds) of insert operations performed on the index.
- getTotalPutLatency() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the total latency of put operations.
- getTotalRemoveLatency() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the total latency of remove operations.
- getTotalRemoveLatency() - Method in interface com.hazelcast.query.LocalIndexStats
-
Returns the total latency (in nanoseconds) of remove operations performed on the index.
- getTotalRuns() - Method in interface com.hazelcast.scheduledexecutor.ScheduledTaskStatistics
-
Returns how many times the task was run/called.
- getTotalRunTime(TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.ScheduledTaskStatistics
-
Returns the total amount of time the task spent while scheduled in.
- getTotalSetLatency() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the total latency of set operations.
- getTotalStartLatency() - Method in interface com.hazelcast.executor.LocalExecutorStats
-
Returns the total start latency of operations started.
- getTotalUpdateLatency() - Method in interface com.hazelcast.query.LocalIndexStats
-
Returns the total latency (in nanoseconds) of update operations performed on the index.
- getTpcConfig() - Method in class com.hazelcast.client.config.ClientConfig
-
Returns the ClientTpcConfig
- getTpcConfig() - Method in class com.hazelcast.config.Config
-
Gets the TpcConfig.
- getTpcSocketConfig() - Method in class com.hazelcast.config.EndpointConfig
-
Gets the TpcSocketConfig.
- getTpcSocketConfig() - Method in class com.hazelcast.config.NetworkConfig
-
Gets the TpcSocketConfig.
- getTransactionalObject(String, String) - Method in class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
- getTransactionalObject(String, String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
-
Returns the transactional object instance with the specified name and service name.
- getTransactionContext() - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
-
Returns the transaction context
- getTransactionContext() - Method in interface com.hazelcast.transaction.HazelcastXAResource
-
Returns the TransactionContext associated with the current thread.
- getTransactionContext(HazelcastInstance) - Static method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
-
Returns the transaction context for the given Hazelcast instance bounded to the current thread.
- getTransactionType() - Method in class com.hazelcast.transaction.TransactionOptions
-
Gets the
TransactionOptions.TransactionType
. - getTrustCertificate() - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Return the location of the trust certificate authority chain in PEM format.
- getTrustCertificatePrivateKey() - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Return the location of the private key for the trust certificate in PEM format.
- getTrustedInterfaces() - Method in class com.hazelcast.config.ManagementCenterConfig
-
Gets the trusted interfaces.
- getTrustedInterfaces() - Method in class com.hazelcast.config.MulticastConfig
-
Gets the trusted interfaces.
- getTrustedInterfaces() - Method in interface com.hazelcast.config.TrustedInterfacesConfigurable
-
Gets the trusted interfaces.
- getTrustStore() - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Return the trust store that holds SSL certificates.
- getTrustStorePassword() - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Return the password used to access the trust store.
- getTrustStoreProvider() - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Return the provider for the trust store.
- getTrustStoreType() - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Return the type of the trust store.
- getTryCount() - Method in class com.hazelcast.client.config.ClientFailoverConfig
-
Sets the count that the client iterates over the given list of alternative clusters.
- getTtl() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
- getTtl() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
- getTtl() - Method in interface com.hazelcast.core.EntryView
-
Returns the last set time to live in milliseconds.
- getTtl() - Method in interface com.hazelcast.spi.merge.MergingTTL
-
Returns the TTL of the merge data.
- getTxnId() - Method in interface com.hazelcast.transaction.TransactionContext
-
Gets the ID that uniquely identifies the transaction.
- getType() - Method in enum class com.hazelcast.cache.CacheEventType
- getType() - Method in interface com.hazelcast.cache.EventJournalCacheEvent
-
Returns the event type.
- getType() - Method in class com.hazelcast.config.DataConnectionConfig
-
Returns the type of the
DataConnection
- getType() - Method in class com.hazelcast.config.IndexConfig
-
Gets type of the index.
- getType() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
-
Returns the type of the Java KeyStore.
- getType() - Method in class com.hazelcast.config.PermissionConfig
- getType() - Method in enum class com.hazelcast.core.EntryEventType
- getType() - Method in enum class com.hazelcast.core.ItemEventType
- getType() - Method in interface com.hazelcast.cp.event.CPMembershipEvent
-
Returns the type of membership change.
- getType() - Method in interface com.hazelcast.map.EventJournalMapEvent
-
Returns the event type.
- getType() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
- getType() - Method in class com.hazelcast.sql.SqlColumnMetadata
-
Gets column type.
- getType(String) - Static method in enum class com.hazelcast.config.PermissionConfig.PermissionType
- getTypeByPermissionClassName(String) - Static method in enum class com.hazelcast.config.PermissionConfig.PermissionType
- getTypeClass() - Method in class com.hazelcast.config.SerializerConfig
-
Gets the type of the class that will be serialized via this implementation.
- getTypeClassName() - Method in class com.hazelcast.config.SerializerConfig
-
Gets the name of the class that will be serialized via this implementation.
- getTypeId() - Method in class com.hazelcast.jet.protobuf.ProtobufSerializer
- getTypeId() - Method in interface com.hazelcast.nio.serialization.Serializer
-
Uniquely identifies given serializer.
- getTypeName() - Method in class com.hazelcast.jet.mongodb.compact.ObjectIdCompactSerializer
- getTypeName() - Method in interface com.hazelcast.nio.serialization.compact.CompactSerializer
-
Returns the unique type name for the class
CompactSerializer
. - getTypeSize() - Method in enum class com.hazelcast.nio.serialization.FieldType
- getUnavailableMembers() - Method in interface com.hazelcast.cp.event.CPGroupAvailabilityEvent
-
Returns the unavailable members of the CP group.
- getUncommittedEntryCountToRejectNewAppends() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
- getUnhealthyEndpoints() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategy
-
Fetches a set of
Address
marked as unhealthy by the underlying implementation. - getUnhealthyEndpoints() - Method in interface com.hazelcast.spi.discovery.integration.DiscoveryService
-
Fetches a set of
Address
marked as unhealthy by the underlyingDiscoveryStrategy
. - getUniqueKey() - Method in class com.hazelcast.config.BitmapIndexOptions
-
Returns the unique key attribute configured in this index config.
- getUniqueKeyTransformation() - Method in class com.hazelcast.config.BitmapIndexOptions
-
Returns the unique key transformation configured in this index.
- getUnit() - Method in class com.hazelcast.memory.Capacity
-
Returns unit of the capacity
- getUpdateCount() - Method in interface com.hazelcast.query.LocalIndexStats
-
Returns the number of update operations performed on the index.
- getUpdateCount() - Method in class com.hazelcast.wan.WanEventCounters.DistributedObjectWanEventCounters
-
Returns the number of entry update events
- getUriString() - Method in class com.hazelcast.config.CacheConfig
-
Gets the URI string which is the global identifier for this
ICache
. - getUrl() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- getUrl() - Method in class com.hazelcast.jet.config.ResourceConfig
-
Returns the URL at which the resource is available.
- getUsage() - Method in class com.hazelcast.config.LoginModuleConfig
- getUseCanonicalHostname() - Method in class com.hazelcast.config.security.KerberosIdentityConfig
- getUseNameWithoutRealm() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
- getUserCodeDeploymentConfig() - Method in class com.hazelcast.client.config.ClientConfig
-
Get current configuration of User Code Deployment.
- getUserCodeDeploymentConfig() - Method in class com.hazelcast.config.Config
-
Get current configuration of User Code Deployment.
- getUserCodeNamespace() - Method in class com.hazelcast.config.CacheConfig
-
Retrieve the User Code Deployment Namespace to be used for
ClassLoader
awareness during operations related to the structure associated with this configuration. - getUserCodeNamespace() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Retrieve the User Code Deployment Namespace to be used for
ClassLoader
awareness during operations related to the structure associated with this configuration. - getUserCodeNamespace() - Method in class com.hazelcast.config.CollectionConfig
-
Retrieve the User Code Deployment Namespace to be used for
ClassLoader
awareness during operations related to the structure associated with this configuration. - getUserCodeNamespace() - Method in class com.hazelcast.config.DurableExecutorConfig
-
Retrieve the User Code Deployment Namespace to be used for
ClassLoader
awareness during operations related to the structure associated with this configuration. - getUserCodeNamespace() - Method in class com.hazelcast.config.ExecutorConfig
-
Retrieve the User Code Deployment Namespace to be used for
ClassLoader
awareness during operations related to the structure associated with this configuration. - getUserCodeNamespace() - Method in class com.hazelcast.config.MapConfig
-
Retrieve the User Code Deployment Namespace to be used for
ClassLoader
awareness during operations related to the structure associated with this configuration. - getUserCodeNamespace() - Method in class com.hazelcast.config.MultiMapConfig
-
Retrieve the User Code Deployment Namespace to be used for
ClassLoader
awareness during operations related to the structure associated with this configuration. - getUserCodeNamespace() - Method in class com.hazelcast.config.QueueConfig
-
Retrieve the User Code Deployment Namespace to be used for
ClassLoader
awareness during operations related to the structure associated with this configuration. - getUserCodeNamespace() - Method in class com.hazelcast.config.ReliableTopicConfig
-
Retrieve the User Code Deployment Namespace to be used for
ClassLoader
awareness during operations related to the structure associated with this configuration. - getUserCodeNamespace() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
Retrieve the User Code Deployment Namespace to be used for
ClassLoader
awareness during operations related to the structure associated with this configuration. - getUserCodeNamespace() - Method in class com.hazelcast.config.RingbufferConfig
-
Retrieve the User Code Deployment Namespace to be used for
ClassLoader
awareness during operations related to the structure associated with this configuration. - getUserCodeNamespace() - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Retrieve the User Code Deployment Namespace to be used for
ClassLoader
awareness during operations related to the structure associated with this configuration. - getUserCodeNamespace() - Method in class com.hazelcast.config.TopicConfig
-
Retrieve the User Code Deployment Namespace to be used for
ClassLoader
awareness during operations related to the structure associated with this configuration. - getUserCodeNamespace() - Method in interface com.hazelcast.config.UserCodeNamespaceAwareConfig
-
Retrieve the User Code Deployment Namespace to be used for
ClassLoader
awareness during operations related to the structure associated with this configuration. - getUserCodeNamespace() - Method in class com.hazelcast.jet.config.JobConfig
-
Retrieves the User Code Namespace (UCN) to use with this job, if one has been set by calling
JobConfig.setUserCodeNamespace(String)
. - getUserContext() - Method in class com.hazelcast.client.config.ClientConfig
- getUserContext() - Method in class com.hazelcast.config.Config
-
Returns the user supplied context.
- getUserContext() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- getUserContext() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns a ConcurrentMap that can be used to add user-context to the HazelcastInstance.
- getUserFilter() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- getUsername() - Method in class com.hazelcast.config.security.UsernamePasswordIdentityConfig
- getUserNameAttribute() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- getUsernamePasswordIdentityConfig() - Method in class com.hazelcast.client.config.ClientSecurityConfig
- getUsernamePasswordIdentityConfig() - Method in class com.hazelcast.config.security.RealmConfig
- getUsernames() - Method in class com.hazelcast.config.security.SimpleAuthenticationConfig
-
Returns names of users registered in the configuration.
- getUserSearchScope() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- getUuid() - Method in interface com.hazelcast.client.Client
-
Returns a unique UUID for this client.
- getUuid() - Method in interface com.hazelcast.cluster.Endpoint
-
Returns the UUID of this endpoint
- getUuid() - Method in interface com.hazelcast.cluster.Member
-
Returns the UUID of this member.
- getUuid() - Method in interface com.hazelcast.cp.CPMember
-
Returns the UUID of this CP member.
- getUuid() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
-
Returns the uuid of the member the task is associated with.
- getValidationTimeoutSeconds() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Deprecated.Returns configured validation timeout for hot-restart process.
- getValidationTimeoutSeconds() - Method in class com.hazelcast.config.PersistenceConfig
-
Returns configured validation timeout for restart process.
- getValue() - Method in interface com.hazelcast.cache.CacheEntryView
-
Gets the value of the cache entry.
- getValue() - Method in class com.hazelcast.core.EntryEvent
-
Returns the value of the entry event.
- getValue() - Method in interface com.hazelcast.core.EntryView
-
Returns the value of the entry.
- getValue() - Method in class com.hazelcast.core.HazelcastJsonValue
- getValue() - Method in class com.hazelcast.jet.datamodel.KeyedWindowResult
-
Alias for
WindowResult.result()
, implementsMap.Entry
. - getValue() - Method in class com.hazelcast.jet.datamodel.Tuple2
- getValue() - Method in class com.hazelcast.map.EntryLoader.MetadataAwareValue
-
Returns the value
- getValue() - Method in class com.hazelcast.memory.Capacity
-
Returns value of the capacity in its original unit.
- getValue() - Method in interface com.hazelcast.spi.eviction.EvictableEntryView
-
Gets the value of the entry.
- getValue() - Method in interface com.hazelcast.spi.merge.MergingValue
-
Deprecated.since 5.4 - this method name is too ambiguous and does not convey its functionality well (it deserializes the value) - so it is being replaced by
MergingValue.getDeserializedValue()
. - getValue() - Method in interface com.hazelcast.vector.SearchResult
- getValue() - Method in interface com.hazelcast.vector.VectorDocument
- getValueClass() - Method in enum class com.hazelcast.sql.SqlColumnType
-
Gets the Java class of the value of this SQL type.
- getValueClassName() - Method in class com.hazelcast.config.AbstractCacheConfig
- getValueCollectionType() - Method in class com.hazelcast.config.MultiMapConfig
-
Gets the collection type for the values of this MultiMap.
- getValuesCallsCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the number of
Map#values
calls - getValueType() - Method in class com.hazelcast.config.AbstractCacheConfig
- getValueType() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the value type for this
ICache
. - getVectorCollectionConfigOrNull(String) - Method in class com.hazelcast.config.Config
-
Get vector collection config.
- getVectorCollectionConfigs() - Method in class com.hazelcast.config.Config
-
Retrieve configurations for all vector collections.
- getVectorIndexConfigs() - Method in class com.hazelcast.config.vector.VectorCollectionConfig
-
Retrieves the list of vector index configurations associated with this vector collection configuration.
- getVectors() - Method in interface com.hazelcast.vector.SearchResult
- getVectors() - Method in interface com.hazelcast.vector.VectorDocument
- getVersion() - Method in interface com.hazelcast.cluster.Member
-
Returns the Hazelcast codebase version of this member; this may or may not be different from the version reported by
Cluster.getClusterVersion()
, for example when a node with a different codebase version is added to an existing cluster. - getVersion() - Method in interface com.hazelcast.core.EntryView
-
Returns the version of the entry.
- getVersion() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Deprecated.Returns the version.
- getVersion() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
Deprecated.
- getVersion() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
- getVersion() - Method in class com.hazelcast.nio.serialization.PortableId
-
Deprecated.
- getVersion() - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- getVersion() - Method in interface com.hazelcast.nio.VersionAware
- getVersion() - Method in interface com.hazelcast.spi.merge.MergingVersion
-
Returns the version of the merge data.
- getVertex(String) - Method in class com.hazelcast.jet.core.DAG
-
Returns the vertex with the given name, or
null
if there is no vertex with that name. - getWanProtocolVersion() - Method in interface com.hazelcast.nio.WanProtocolVersionAware
-
Returns the WAN protocol version.
- getWanReplicationConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the WAN replication configuration with the given
name
. - getWanReplicationConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of WAN replication configurations, mapped by config name.
- getWanReplicationRef() - Method in class com.hazelcast.config.CacheConfig
- getWanReplicationRef() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the WAN target replication reference.
- getWanReplicationRef() - Method in class com.hazelcast.config.MapConfig
-
Gets the WAN target replication reference.
- getWatermark(int) - Method in class com.hazelcast.jet.core.EventTimeMapper
-
Watermark value to be saved to state snapshot for the given source partition index.
- getWhitelist() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
- getWhitelistedPrefixes() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Deprecated.Return currently configured whitelist prefixes
- getWriteBatchSize() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns the number of operations to be included in each batch processing round.
- getWriteDelaySeconds() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns the number of seconds to delay the store writes.
- getWriteIOThreadCount() - Method in class com.hazelcast.config.LocalDeviceConfig
-
Returns the write IO thread count
- getXAResource() - Method in interface com.hazelcast.core.HazelcastInstance
-
Gets xaResource which will participate in XATransaction.
- gigaBytes() - Method in class com.hazelcast.memory.Capacity
-
Returns value of the capacity in gigabytes.
- GIGABYTES - Enum constant in enum class com.hazelcast.memory.MemoryUnit
-
MemoryUnit in gigabytes
- glob(String) - Method in class com.hazelcast.jet.avro.AvroSourceBuilder
-
Sets the globbing mask, see
getPathMatcher()
. - glob(String) - Method in class com.hazelcast.jet.pipeline.file.FileSourceBuilder
-
Sets a glob pattern to filter the files in the specified directory.
- glob(String) - Method in class com.hazelcast.jet.pipeline.FileSourceBuilder
-
Sets the globbing mask, see
getPathMatcher()
. - GLOBAL_HD_INDEX_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Enables use of the concurrent HD index introduced in 4.1 for the IMDG predicate API (old query engine) and reverts to using the per-partition indexes.
- globalProcessorIndex() - Method in interface com.hazelcast.jet.core.Processor.Context
-
Returns the index of the processor among all the processors created for this vertex on all nodes: it's a unique cluster-wide index.
- globalProcessorIndex() - Method in class com.hazelcast.jet.core.test.TestProcessorContext
- globalProcessorIndex(int) - Method in class com.hazelcast.jet.core.test.TestSupport
-
Sets the globalProcessorIndex for the Processor
- GlobalSerializerConfig - Class in com.hazelcast.config
-
Contains the configuration for global serializer.
- GlobalSerializerConfig() - Constructor for class com.hazelcast.config.GlobalSerializerConfig
- GlobalSerializerConfig(GlobalSerializerConfig) - Constructor for class com.hazelcast.config.GlobalSerializerConfig
- GRACEFUL_SHUTDOWN_MAX_WAIT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Maximum wait in seconds during graceful shutdown.
- greaterEqual(Comparable) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
- greaterEqual(String, Comparable) - Static method in class com.hazelcast.query.Predicates
-
Creates a greater than or equal to predicate that will pass items if the value stored under the given item
attribute
is greater than or equal to the givenvalue
. - greaterThan(Comparable) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
- greaterThan(String, Comparable) - Static method in class com.hazelcast.query.Predicates
-
Creates a greater than predicate that will pass items if the value stored under the given item
attribute
is greater than the givenvalue
. - GROUP - Static variable in class com.hazelcast.spi.discovery.multicast.MulticastProperties
-
Property used to define zones for node filtering.
- GroupAggregateBuilder<K,
R0> - Class in com.hazelcast.jet.pipeline -
Offers a step-by-step API to build a pipeline stage that co-groups and aggregates the data from several input stages.
- GroupAggregateBuilder1<T0,
K> - Class in com.hazelcast.jet.pipeline -
Offers a step-by-step API to build a pipeline stage that co-groups and aggregates the data from several input stages.
- groupId() - Method in interface com.hazelcast.cp.CPObjectInfo
-
Id of the group this object belongs to
- GroupInfo(CPMember, Set<CPMember>, int) - Constructor for record class com.hazelcast.cp.CPGroupsSnapshot.GroupInfo
-
Creates an instance of a
GroupInfo
record class. - groupingBy(FunctionEx<? super T, ? extends K>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that accumulates the items into a
HashMap
where the key is the result of applyingkeyFn
and the value is a list of the items with that key. - groupingBy(FunctionEx<? super T, ? extends K>, SupplierEx<M>, AggregateOperation1<? super T, A, R>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an
AggregateOperation1
that accumulates the items into aMap
(as obtained fromcreateMapFn
) where the key is the result of applyingkeyFn
and the value is the result of applying the downstream aggregate operation to the items with that key. - groupingBy(FunctionEx<? super T, ? extends K>, AggregateOperation1<? super T, A, R>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that accumulates the items into a
HashMap
where the key is the result of applyingkeyFn
and the value is the result of applying the downstream aggregate operation to the items with that key. - groupingKey(FunctionEx<? super T, ? extends K>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
-
Specifies the function that will extract a key from the items in the associated pipeline stage.
- groupingKey(FunctionEx<? super T, ? extends K>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Specifies the function that will extract a key from the items in the associated pipeline stage.
- groupingKey(FunctionEx<? super T, ? extends K>) - Method in interface com.hazelcast.jet.pipeline.StageWithWindow
-
Specifies the function that will extract the grouping key from the items in the associated pipeline stage and moves on to the step in which you'll complete the construction of a windowed group-and-aggregate stage.
- groupingKey(FunctionEx<? super T, ? extends K>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- GrpcProperties - Class in com.hazelcast.jet.grpc
-
Properties of the grpc module
- GrpcService<T,
R> - Interface in com.hazelcast.jet.grpc -
Represents a gRPC service that can be used as part of a
mapUsingServiceAsync
call. - GrpcServices - Class in com.hazelcast.jet.grpc
-
Provides
ServiceFactory
implementations for calling gRPC endpoints.
H
- HadoopProcessors - Class in com.hazelcast.jet.hadoop
-
Static utility class with factories of Apache Hadoop Hadoop source and sink processors.
- HadoopSinks - Class in com.hazelcast.jet.hadoop
-
Factories of Apache Hadoop sinks.
- HadoopSources - Class in com.hazelcast.jet.hadoop
-
Contains factory methods for Apache Hadoop sources.
- handleAddListener(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleAliasedDiscoveryStrategy(Node, BeanDefinitionBuilder, String) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- handleAutoDetection(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- handleClear(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleClient(Node) - Method in class com.hazelcast.spring.HazelcastClientBeanDefinitionParser.SpringXmlBuilder
- handleCommand(String) - Method in class com.hazelcast.console.ConsoleApp
-
Handles a command.
- handleCommonBeanAttributes(Node, BeanDefinitionBuilder, ParserContext) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- handleContains(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleDataSerializableFactories(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- handleDestroy(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleDiscoveryStrategies(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- handleExit() - Method in class com.hazelcast.console.ConsoleApp
- handleIndex(ManagedList<BeanDefinition>, Node) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- handleInstances() - Method in class com.hazelcast.console.ConsoleApp
- handleIterator(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleJavaSerializationFilter(Node, BeanDefinitionBuilder, String) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- handleListAdd(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleListAddMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleListContains(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleListRemove(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleListSet(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleMapDelete(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleMapEntries() - Method in class com.hazelcast.console.ConsoleApp
- handleMapEvict(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleMapGet(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleMapGetAsync(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleMapGetMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleMapGetMapEntry(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleMapKeys() - Method in class com.hazelcast.console.ConsoleApp
- handleMapLocalKeys() - Method in class com.hazelcast.console.ConsoleApp
- handleMapLocalSize() - Method in class com.hazelcast.console.ConsoleApp
- handleMapLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleMapPut(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleMapPutAsync(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleMapPutIfAbsent(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleMapPutMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleMapRemove(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleMapRemoveMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleMapReplace(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleMapTryLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleMapUnlock(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleMapValues() - Method in class com.hazelcast.console.ConsoleApp
- handleMultiMapEntries() - Method in class com.hazelcast.console.ConsoleApp
- handleMultiMapGet(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleMultiMapKeys() - Method in class com.hazelcast.console.ConsoleApp
- handleMultiMapLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleMultiMapPut(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleMultiMapRemove(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleMultiMapTryLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleMultiMapUnlock(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleMultiMapValues() - Method in class com.hazelcast.console.ConsoleApp
- handleNativeMemory(Node) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- handlePartitions() - Method in class com.hazelcast.console.ConsoleApp
- handlePortableFactories(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- handleProperties(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- handleQCapacity() - Method in class com.hazelcast.console.ConsoleApp
- handleQOffer(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleQOfferMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleQPeek() - Method in class com.hazelcast.console.ConsoleApp
- handleQPoll(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleQPollMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleQTake() - Method in class com.hazelcast.console.ConsoleApp
- handleRemoveListener(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handlerFile() - Method in class com.hazelcast.jet.python.PythonServiceConfig
-
Returns the Python handler file.
- handlerFunction() - Method in class com.hazelcast.jet.python.PythonServiceConfig
-
Returns the name of the handler function.
- handlerModule() - Method in class com.hazelcast.jet.python.PythonServiceConfig
-
Returns the handler module name.
- handleSerialization(Node) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- handleSerializers(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- handleSetAdd(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleSetAddMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleSetRemove(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleSetRemoveMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleShutdown() - Method in class com.hazelcast.console.ConsoleApp
- handleSize(String[]) - Method in class com.hazelcast.console.ConsoleApp
- handleSocketInterceptorConfig(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- handleSpringAware() - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- handleTopicPublish(String[]) - Method in class com.hazelcast.console.ConsoleApp
- hasDefiniteSize() - Method in enum class com.hazelcast.nio.serialization.FieldType
- hasField(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Deprecated.Checks if there exists a FieldDefinition with the given fieldName.
- hasField(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- HASH - Enum constant in enum class com.hazelcast.config.IndexType
-
Hash index.
- HASH_CODE - Static variable in interface com.hazelcast.jet.core.Partitioner
-
Partitioner which calls
Object.hashCode()
and coerces it with the modulo operation into the allowed range of partition IDs. - hasHadoopPrefix(String) - Static method in class com.hazelcast.jet.pipeline.file.FileSourceBuilder
-
Checks if the given path starts with one of the defined Hadoop prefixes: "s3a://", // Amazon S3 "hdfs://", // HDFS "wasbs://", // Azure Cloud Storage "adl://", // Azure Data Lake Gen 1 "abfs://", // Azure Data Lake Gen 2 "gs://" // Google Cloud Storage see
FileSourceBuilder.HADOOP_PREFIXES
- hashCode() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
- hashCode() - Method in class com.hazelcast.client.config.ClientCloudConfig
- hashCode() - Method in class com.hazelcast.client.config.ClientConfig
- hashCode() - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
- hashCode() - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
- hashCode() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
- hashCode() - Method in class com.hazelcast.client.config.ClientMetricsConfig
- hashCode() - Method in class com.hazelcast.client.config.ClientNetworkConfig
- hashCode() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
- hashCode() - Method in class com.hazelcast.client.config.ClientSecurityConfig
- hashCode() - Method in class com.hazelcast.client.config.ClientSqlConfig
- hashCode() - Method in class com.hazelcast.client.config.ClientTpcConfig
- hashCode() - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
-
Deprecated.
- hashCode() - Method in class com.hazelcast.client.config.ClusterRoutingConfig
- hashCode() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
- hashCode() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
- hashCode() - Method in class com.hazelcast.client.config.SocketOptions
- hashCode() - Method in class com.hazelcast.cluster.Address
- hashCode() - Method in class com.hazelcast.config.AbstractBaseFactoryWithPropertiesConfig
- hashCode() - Method in class com.hazelcast.config.AbstractCacheConfig
- hashCode() - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
- hashCode() - Method in class com.hazelcast.config.AbstractWanPublisherConfig
- hashCode() - Method in class com.hazelcast.config.AdvancedNetworkConfig
- hashCode() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- hashCode() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
- hashCode() - Method in class com.hazelcast.config.AttributeConfig
- hashCode() - Method in class com.hazelcast.config.AutoDetectionConfig
- hashCode() - Method in class com.hazelcast.config.BitmapIndexOptions
- hashCode() - Method in class com.hazelcast.config.BTreeIndexConfig
- hashCode() - Method in class com.hazelcast.config.CacheConfig
- hashCode() - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
- hashCode() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
- hashCode() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
- hashCode() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
- hashCode() - Method in class com.hazelcast.config.CacheSimpleConfig
- hashCode() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
- hashCode() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
- hashCode() - Method in class com.hazelcast.config.ClassFilter
- hashCode() - Method in class com.hazelcast.config.CollectionConfig
- hashCode() - Method in class com.hazelcast.config.CompactSerializationConfig
- hashCode() - Method in class com.hazelcast.config.cp.CPMapConfig
- hashCode() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
- hashCode() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
- hashCode() - Method in class com.hazelcast.config.CRDTReplicationConfig
- hashCode() - Method in class com.hazelcast.config.CredentialsFactoryConfig
- hashCode() - Method in class com.hazelcast.config.DataConnectionConfig
- hashCode() - Method in class com.hazelcast.config.DataPersistenceConfig
- hashCode() - Method in class com.hazelcast.config.DiscoveryConfig
- hashCode() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
- hashCode() - Method in class com.hazelcast.config.DiskTierConfig
- hashCode() - Method in class com.hazelcast.config.DurableExecutorConfig
- hashCode() - Method in class com.hazelcast.config.DynamicConfigurationConfig
- hashCode() - Method in class com.hazelcast.config.EncryptionAtRestConfig
- hashCode() - Method in class com.hazelcast.config.EndpointConfig
- hashCode() - Method in class com.hazelcast.config.EntryListenerConfig
- hashCode() - Method in class com.hazelcast.config.EventJournalConfig
- hashCode() - Method in class com.hazelcast.config.EvictionConfig
- hashCode() - Method in class com.hazelcast.config.ExecutorConfig
- hashCode() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
- hashCode() - Method in class com.hazelcast.config.GlobalSerializerConfig
- hashCode() - Method in class com.hazelcast.config.HotRestartConfig
-
Deprecated.
- hashCode() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Deprecated.
- hashCode() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
- hashCode() - Method in class com.hazelcast.config.IndexConfig
- hashCode() - Method in class com.hazelcast.config.InstanceTrackingConfig
- hashCode() - Method in class com.hazelcast.config.InterfacesConfig
- hashCode() - Method in class com.hazelcast.config.ItemListenerConfig
- hashCode() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
- hashCode() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
- hashCode() - Method in class com.hazelcast.config.JoinConfig
- hashCode() - Method in class com.hazelcast.config.ListenerConfig
- hashCode() - Method in class com.hazelcast.config.LocalDeviceConfig
- hashCode() - Method in class com.hazelcast.config.LoginModuleConfig
- hashCode() - Method in class com.hazelcast.config.ManagementCenterConfig
- hashCode() - Method in class com.hazelcast.config.MapConfig
- hashCode() - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
- hashCode() - Method in class com.hazelcast.config.MapStoreConfig
- hashCode() - Method in class com.hazelcast.config.matcher.MatchingPointConfigPatternMatcher
- hashCode() - Method in class com.hazelcast.config.matcher.RegexConfigPatternMatcher
- hashCode() - Method in class com.hazelcast.config.matcher.WildcardConfigPatternMatcher
- hashCode() - Method in class com.hazelcast.config.MemberAddressProviderConfig
- hashCode() - Method in class com.hazelcast.config.MemberAttributeConfig
- hashCode() - Method in class com.hazelcast.config.MemberGroupConfig
- hashCode() - Method in class com.hazelcast.config.MemcacheProtocolConfig
- hashCode() - Method in class com.hazelcast.config.MemoryTierConfig
- hashCode() - Method in class com.hazelcast.config.MergePolicyConfig
- hashCode() - Method in class com.hazelcast.config.MerkleTreeConfig
- hashCode() - Method in class com.hazelcast.config.MetricsConfig
- hashCode() - Method in class com.hazelcast.config.MetricsJmxConfig
- hashCode() - Method in class com.hazelcast.config.MetricsManagementCenterConfig
- hashCode() - Method in class com.hazelcast.config.MulticastConfig
- hashCode() - Method in class com.hazelcast.config.MultiMapConfig
- hashCode() - Method in class com.hazelcast.config.NativeMemoryConfig
- hashCode() - Method in class com.hazelcast.config.NearCacheConfig
- hashCode() - Method in class com.hazelcast.config.NearCachePreloaderConfig
- hashCode() - Method in class com.hazelcast.config.NetworkConfig
- hashCode() - Method in class com.hazelcast.config.PartitionGroupConfig
- hashCode() - Method in class com.hazelcast.config.PartitioningAttributeConfig
- hashCode() - Method in class com.hazelcast.config.PartitioningStrategyConfig
- hashCode() - Method in class com.hazelcast.config.PermissionConfig
- hashCode() - Method in class com.hazelcast.config.PermissionPolicyConfig
- hashCode() - Method in class com.hazelcast.config.PersistenceConfig
- hashCode() - Method in class com.hazelcast.config.PersistentMemoryConfig
- hashCode() - Method in class com.hazelcast.config.PersistentMemoryDirectoryConfig
- hashCode() - Method in class com.hazelcast.config.PNCounterConfig
- hashCode() - Method in class com.hazelcast.config.PredicateConfig
- hashCode() - Method in class com.hazelcast.config.QueryCacheConfig
- hashCode() - Method in class com.hazelcast.config.QueueConfig
- hashCode() - Method in class com.hazelcast.config.QueueStoreConfig
- hashCode() - Method in class com.hazelcast.config.ReliableTopicConfig
- hashCode() - Method in class com.hazelcast.config.ReplicatedMapConfig
- hashCode() - Method in class com.hazelcast.config.RestApiConfig
-
Deprecated.
- hashCode() - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- hashCode() - Method in class com.hazelcast.config.RingbufferConfig
- hashCode() - Method in class com.hazelcast.config.RingbufferStoreConfig
- hashCode() - Method in class com.hazelcast.config.ScheduledExecutorConfig
- hashCode() - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
- hashCode() - Method in class com.hazelcast.config.security.CredentialsIdentityConfig
- hashCode() - Method in class com.hazelcast.config.security.JaasAuthenticationConfig
- hashCode() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
- hashCode() - Method in class com.hazelcast.config.security.KerberosIdentityConfig
- hashCode() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- hashCode() - Method in class com.hazelcast.config.security.RealmConfig
- hashCode() - Method in class com.hazelcast.config.security.SimpleAuthenticationConfig
- hashCode() - Method in class com.hazelcast.config.security.SimpleAuthenticationConfig.UserDto
- hashCode() - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
- hashCode() - Method in class com.hazelcast.config.security.TokenIdentityConfig
- hashCode() - Method in class com.hazelcast.config.security.UsernamePasswordIdentityConfig
- hashCode() - Method in class com.hazelcast.config.SecurityConfig
- hashCode() - Method in class com.hazelcast.config.SerializationConfig
- hashCode() - Method in class com.hazelcast.config.SerializerConfig
- hashCode() - Method in class com.hazelcast.config.ServerSocketEndpointConfig
- hashCode() - Method in class com.hazelcast.config.ServiceConfig
- hashCode() - Method in class com.hazelcast.config.SocketInterceptorConfig
- hashCode() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
- hashCode() - Method in class com.hazelcast.config.SqlConfig
- hashCode() - Method in class com.hazelcast.config.SSLConfig
- hashCode() - Method in class com.hazelcast.config.TcpIpConfig
- hashCode() - Method in class com.hazelcast.config.TieredStoreConfig
- hashCode() - Method in class com.hazelcast.config.TopicConfig
- hashCode() - Method in class com.hazelcast.config.tpc.TpcConfig
- hashCode() - Method in class com.hazelcast.config.tpc.TpcSocketConfig
- hashCode() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Deprecated.
- hashCode() - Method in class com.hazelcast.config.UserCodeNamespaceConfig
- hashCode() - Method in class com.hazelcast.config.UserCodeNamespacesConfig
- hashCode() - Method in class com.hazelcast.config.VaultSecureStoreConfig
- hashCode() - Method in class com.hazelcast.config.vector.VectorCollectionConfig
- hashCode() - Method in class com.hazelcast.config.vector.VectorIndexConfig
- hashCode() - Method in class com.hazelcast.config.WanConsumerConfig
- hashCode() - Method in class com.hazelcast.config.WanReplicationConfig
- hashCode() - Method in class com.hazelcast.config.WanReplicationRef
- hashCode() - Method in class com.hazelcast.config.WanSyncConfig
- hashCode() - Method in class com.hazelcast.core.HazelcastJsonValue
- hashCode() - Method in class com.hazelcast.core.LifecycleEvent
- hashCode() - Method in record class com.hazelcast.cp.CPGroupsSnapshot.GroupInfo
-
Returns a hash code value for this object.
- hashCode() - Method in class com.hazelcast.cp.CPGroupsSnapshot
- hashCode() - Method in class com.hazelcast.dataconnection.DataConnectionResource
- hashCode() - Method in class com.hazelcast.jet.accumulator.DoubleAccumulator
- hashCode() - Method in class com.hazelcast.jet.accumulator.LinTrendAccumulator
- hashCode() - Method in class com.hazelcast.jet.accumulator.LongAccumulator
- hashCode() - Method in class com.hazelcast.jet.accumulator.LongDoubleAccumulator
- hashCode() - Method in class com.hazelcast.jet.accumulator.LongLongAccumulator
- hashCode() - Method in class com.hazelcast.jet.accumulator.MutableReference
- hashCode() - Method in class com.hazelcast.jet.accumulator.PickAnyAccumulator
- hashCode() - Method in class com.hazelcast.jet.config.DeltaJobConfig
- hashCode() - Method in class com.hazelcast.jet.config.EdgeConfig
- hashCode() - Method in class com.hazelcast.jet.config.InstanceConfig
-
Deprecated.
- hashCode() - Method in class com.hazelcast.jet.config.JetConfig
- hashCode() - Method in class com.hazelcast.jet.config.JobConfig
- hashCode() - Method in class com.hazelcast.jet.config.ResourceConfig
- hashCode() - Method in class com.hazelcast.jet.core.BroadcastKey
- hashCode() - Method in class com.hazelcast.jet.core.Edge
- hashCode() - Method in class com.hazelcast.jet.core.metrics.JobMetrics
- hashCode() - Method in class com.hazelcast.jet.core.metrics.Measurement
- hashCode() - Method in class com.hazelcast.jet.core.Watermark
- hashCode() - Method in class com.hazelcast.jet.datamodel.ItemsByTag
- hashCode() - Method in class com.hazelcast.jet.datamodel.KeyedWindowResult
- hashCode() - Method in class com.hazelcast.jet.datamodel.Tag
- hashCode() - Method in class com.hazelcast.jet.datamodel.TimestampedItem
- hashCode() - Method in class com.hazelcast.jet.datamodel.Tuple2
- hashCode() - Method in class com.hazelcast.jet.datamodel.Tuple3
- hashCode() - Method in class com.hazelcast.jet.datamodel.Tuple4
- hashCode() - Method in class com.hazelcast.jet.datamodel.Tuple5
- hashCode() - Method in class com.hazelcast.jet.datamodel.WindowResult
- hashCode() - Method in class com.hazelcast.jet.pipeline.file.AvroFileFormat
- hashCode() - Method in class com.hazelcast.jet.pipeline.file.CsvFileFormat
- hashCode() - Method in class com.hazelcast.jet.pipeline.file.JsonFileFormat
- hashCode() - Method in class com.hazelcast.jet.pipeline.file.LinesTextFileFormat
- hashCode() - Method in class com.hazelcast.jet.pipeline.file.ParquetFileFormat
- hashCode() - Method in class com.hazelcast.jet.pipeline.file.RawBytesFileFormat
- hashCode() - Method in class com.hazelcast.jet.pipeline.file.TextFileFormat
- hashCode() - Method in class com.hazelcast.jet.pipeline.test.SimpleEvent
- hashCode() - Method in class com.hazelcast.memory.Capacity
- hashCode() - Method in class com.hazelcast.nio.serialization.PortableId
-
Deprecated.
- hashCode() - Method in class com.hazelcast.partition.PartitionAwareKey
- hashCode() - Method in class com.hazelcast.persistence.BackupTaskStatus
- hashCode() - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
- hashCode() - Method in class com.hazelcast.security.permission.AllPermissions
- hashCode() - Method in class com.hazelcast.security.permission.ClusterPermission
- hashCode() - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
- hashCode() - Method in class com.hazelcast.security.permission.InstancePermission
- hashCode() - Method in class com.hazelcast.security.SimpleTokenCredentials
- hashCode() - Method in class com.hazelcast.security.UsernamePasswordCredentials
- hashCode() - Method in class com.hazelcast.sql.SqlColumnMetadata
- hashCode() - Method in class com.hazelcast.sql.SqlRowMetadata
- hashCode() - Method in class com.hazelcast.sql.SqlStatement
- hashCode() - Method in record class com.hazelcast.vector.Hint
-
Returns a hash code value for this object.
- hashCode() - Method in class com.hazelcast.version.MemberVersion
- hashCode() - Method in class com.hazelcast.version.Version
- hashJoin(BatchStage<T1_IN>, JoinClause<K, ? super T, ? super T1_IN, ? extends T1>, BiFunctionEx<T, T1, R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- hashJoin(BatchStage<T1_IN>, JoinClause<K, ? super T, ? super T1_IN, ? extends T1>, BiFunctionEx<T, T1, R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Attaches to both this and the supplied stage a hash-joining stage and returns it.
- hashJoin(BatchStage<T1_IN>, JoinClause<K, ? super T, ? super T1_IN, ? extends T1>, BiFunctionEx<T, T1, R>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- hashJoin2(BatchStage<T1_IN>, JoinClause<K1, ? super T, ? super T1_IN, ? extends T1>, BatchStage<T2_IN>, JoinClause<K2, ? super T, ? super T2_IN, ? extends T2>, TriFunction<T, T1, T2, R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- hashJoin2(BatchStage<T1_IN>, JoinClause<K1, ? super T, ? super T1_IN, ? extends T1>, BatchStage<T2_IN>, JoinClause<K2, ? super T, ? super T2_IN, ? extends T2>, TriFunction<T, T1, T2, R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Attaches to this and the two supplied stages a hash-joining stage and returns it.
- hashJoin2(BatchStage<T1_IN>, JoinClause<K1, ? super T, ? super T1_IN, ? extends T1>, BatchStage<T2_IN>, JoinClause<K2, ? super T, ? super T2_IN, ? extends T2>, TriFunction<T, T1, T2, R>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- hashJoinBuilder() - Method in interface com.hazelcast.jet.pipeline.BatchStage
- hashJoinBuilder() - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Returns a fluent API builder object to construct a hash join operation with any number of contributing stages.
- hashJoinBuilder() - Method in interface com.hazelcast.jet.pipeline.StreamStage
- HashJoinBuilder<T0> - Class in com.hazelcast.jet.pipeline
-
Offers a step-by-step fluent API to build a hash-join pipeline stage.
- hasIdentityConfig() - Method in class com.hazelcast.client.config.ClientSecurityConfig
- hasListenerConfiguration() - Method in class com.hazelcast.config.AbstractCacheConfig
- hasMember(Member) - Method in interface com.hazelcast.spi.partitiongroup.MemberGroup
- hasMinimumSize() - Method in interface com.hazelcast.splitbrainprotection.SplitBrainProtection
-
Returns true if the minimum cluster size is satisfied, otherwise false.
- hasNext() - Method in class com.hazelcast.spi.merge.RingbufferMergeDataReadOnlyIterator
- hasUnfinishedItem() - Method in interface com.hazelcast.jet.core.Outbox
-
Returns true if this outbox has an unfinished item and the same item must be offered again.
- hasUnfinishedItem() - Method in class com.hazelcast.jet.core.test.TestOutbox
- Hazelcast - Class in com.hazelcast.core
-
Factory for
HazelcastInstance
's, a node in a cluster. - HAZELCAST - Enum constant in enum class com.hazelcast.config.InstanceTrackingConfig.InstanceProductName
-
Hazelcast open-source
- HAZELCAST_CLIENT - Enum constant in enum class com.hazelcast.config.InstanceTrackingConfig.InstanceProductName
-
Hazelcast java open-source client
- HAZELCAST_CLIENT_EE - Enum constant in enum class com.hazelcast.config.InstanceTrackingConfig.InstanceProductName
-
Hazelcast java enterprise client
- HAZELCAST_CLOUD_DISCOVERY_TOKEN - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Token to use when discovering cluster via hazelcast.cloud
- HAZELCAST_CONFIG_LOCATION - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
-
Hazelcast config location property
- HAZELCAST_EE - Enum constant in enum class com.hazelcast.config.InstanceTrackingConfig.InstanceProductName
-
Hazelcast Enterprise
- HAZELCAST_INSTANCE_ITSELF - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
-
Hazelcast instance itself property
- HAZELCAST_INSTANCE_NAME - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
-
Hazelcast instance name property
- HAZELCAST_JET - Enum constant in enum class com.hazelcast.config.InstanceTrackingConfig.InstanceProductName
-
Hazelcast Jet open-source
- HAZELCAST_JET_EE - Enum constant in enum class com.hazelcast.config.InstanceTrackingConfig.InstanceProductName
-
Hazelcast Jet enterprise
- HAZELCAST_OSGI_GROUPING_DISABLED - Static variable in interface com.hazelcast.osgi.HazelcastOSGiService
-
System property for disabling the behaviour that gives different cluster name to each Hazelcast bundle.
- HAZELCAST_OSGI_JSR223_DISABLED - Static variable in interface com.hazelcast.osgi.HazelcastOSGiService
-
System property for disabling the JSR-223 script engine scan by the Hazelcast OSGI service.
- HAZELCAST_OSGI_REGISTER_DISABLED - Static variable in interface com.hazelcast.osgi.HazelcastOSGiService
-
System property for disabling the behaviour that registers created Hazelcast instances as OSGI service.
- HAZELCAST_OSGI_START - Static variable in interface com.hazelcast.osgi.HazelcastOSGiService
-
System property for starting a default Hazelcast instance per Hazelcast OSGI bundle.
- HazelcastCache - Class in com.hazelcast.spring.cache
-
Spring related
Cache
implementation for Hazelcast. - HazelcastCache(IMap<Object, Object>) - Constructor for class com.hazelcast.spring.cache.HazelcastCache
- HazelcastCacheManager - Class in com.hazelcast.spring.cache
-
Spring-related
CacheManager
implementation for Hazelcast. - HazelcastCacheManager - Interface in com.hazelcast.cache
-
Contract point of Hazelcast cache manager implementations (client + server) based on
CacheManager
. - HazelcastCacheManager() - Constructor for class com.hazelcast.spring.cache.HazelcastCacheManager
- HazelcastCacheManager(HazelcastInstance) - Constructor for class com.hazelcast.spring.cache.HazelcastCacheManager
- HazelcastCachingProvider - Class in com.hazelcast.cache
-
Hazelcast implementation of JCache
CachingProvider
. - HazelcastCachingProvider() - Constructor for class com.hazelcast.cache.HazelcastCachingProvider
- HazelcastClient - Class in com.hazelcast.client
-
The HazelcastClient is comparable to the
Hazelcast
class and provides the ability the create and manage Hazelcast clients. - HazelcastClientBeanDefinitionParser - Class in com.hazelcast.spring
-
BeanDefinitionParser for Hazelcast Client Configuration.
- HazelcastClientBeanDefinitionParser() - Constructor for class com.hazelcast.spring.HazelcastClientBeanDefinitionParser
- HazelcastClientBeanDefinitionParser.SpringXmlBuilder - Class in com.hazelcast.spring
-
Client bean definition builder
- HazelcastClientCachingProvider - Class in com.hazelcast.client.cache
-
Client-side
CachingProvider
implementation. - HazelcastClientCachingProvider() - Constructor for class com.hazelcast.client.cache.HazelcastClientCachingProvider
- HazelcastClientNotActiveException - Exception in com.hazelcast.client
-
Thrown when Hazelcast client is not active during an invocation.
- HazelcastClientNotActiveException() - Constructor for exception com.hazelcast.client.HazelcastClientNotActiveException
- HazelcastClientNotActiveException(String) - Constructor for exception com.hazelcast.client.HazelcastClientNotActiveException
- HazelcastClientNotActiveException(String, Throwable) - Constructor for exception com.hazelcast.client.HazelcastClientNotActiveException
- HazelcastClientOfflineException - Exception in com.hazelcast.client
-
Thrown when Hazelcast client is offline during an invocation.
- HazelcastClientOfflineException() - Constructor for exception com.hazelcast.client.HazelcastClientOfflineException
- HazelcastConfigBeanDefinitionParser - Class in com.hazelcast.spring
-
BeanDefinitionParser for Hazelcast Config Configuration.
- HazelcastConfigBeanDefinitionParser() - Constructor for class com.hazelcast.spring.HazelcastConfigBeanDefinitionParser
- HazelcastDataConnection - Class in com.hazelcast.dataconnection
-
Creates a HazelcastInstance that is shared to connect to a remote cluster.
- HazelcastDataConnection(DataConnectionConfig) - Constructor for class com.hazelcast.dataconnection.HazelcastDataConnection
- HazelcastException - Exception in com.hazelcast.core
-
Base Hazelcast exception.
- HazelcastException() - Constructor for exception com.hazelcast.core.HazelcastException
- HazelcastException(String) - Constructor for exception com.hazelcast.core.HazelcastException
- HazelcastException(String, Throwable) - Constructor for exception com.hazelcast.core.HazelcastException
- HazelcastException(Throwable) - Constructor for exception com.hazelcast.core.HazelcastException
- HazelcastExpiryPolicy - Class in com.hazelcast.cache
-
Hazelcast provides overloads of the typical cache operations with a custom
ExpiryPolicy
parameter.
This class provides a custom implementation of anExpiryPolicy
to react on all three types of policies: Create Access Update - HazelcastExpiryPolicy() - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
-
Default constructor to serialize/deserialize
- HazelcastExpiryPolicy(long, long, long) - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
-
Constructs an expiry policy with provided values for creation, access and update in milliseconds.
- HazelcastExpiryPolicy(long, long, long, TimeUnit) - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
-
Constructs an expiry policy with provided values for creation, access and update as well as a
TimeUnit
to convert those values to internally used time unites. - HazelcastExpiryPolicy(Duration, Duration, Duration) - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
-
Constructs an expiry policy with provided values for creation, access and update by providing instances of the
Duration
class. - HazelcastExpiryPolicy(ExpiryPolicy) - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
-
Copy Constructor for an already existing
ExpiryPolicy
. - HazelcastFailoverClientBeanDefinitionParser - Class in com.hazelcast.spring
-
BeanDefinitionParser for Hazelcast Client Configuration.
- HazelcastFailoverClientBeanDefinitionParser() - Constructor for class com.hazelcast.spring.HazelcastFailoverClientBeanDefinitionParser
- hazelcastInstance() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
-
Returns the current Hazelcast instance.
- hazelcastInstance() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
- hazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.jet.core.test.TestSupport
-
Use the given instance for
ProcessorMetaSupplier.Context.hazelcastInstance()
- HazelcastInstance - Interface in com.hazelcast.core
-
Hazelcast instance.
- HazelcastInstanceAware - Interface in com.hazelcast.core
-
Used to get HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService.
- HazelcastInstanceCallback - Class in com.hazelcast.security
-
This JAAS
Callback
is used to retrieve the currentHazelcastInstance
. - HazelcastInstanceCallback() - Constructor for class com.hazelcast.security.HazelcastInstanceCallback
- HazelcastInstanceDefinitionParser - Class in com.hazelcast.spring
-
BeanDefinitionParser for Hazelcast Instance Configuration.
- HazelcastInstanceDefinitionParser() - Constructor for class com.hazelcast.spring.HazelcastInstanceDefinitionParser
- HazelcastInstanceNotActiveException - Exception in com.hazelcast.core
-
Thrown when HazelcastInstance is not active during an invocation.
- HazelcastInstanceNotActiveException() - Constructor for exception com.hazelcast.core.HazelcastInstanceNotActiveException
- HazelcastInstanceNotActiveException(String) - Constructor for exception com.hazelcast.core.HazelcastInstanceNotActiveException
- hazelcastJsonValue(Object) - Static method in class com.hazelcast.jet.json.JsonUtil
-
Creates a
HazelcastJsonValue
by converting given the object to string usingObject.toString()
. - HazelcastJsonValue - Class in com.hazelcast.core
-
HazelcastJsonValue is a wrapper for JSON formatted strings.
- HazelcastJsonValue(String) - Constructor for class com.hazelcast.core.HazelcastJsonValue
-
Creates a HazelcastJsonValue from the given string.
- HazelcastKafkaAvroDeserializer - Class in com.hazelcast.jet.kafka
-
An Avro deserializer for Kafka.
- HazelcastKafkaAvroDeserializer() - Constructor for class com.hazelcast.jet.kafka.HazelcastKafkaAvroDeserializer
-
Constructor used by Kafka consumer.
- HazelcastKafkaAvroSerializer - Class in com.hazelcast.jet.kafka
-
An Avro serializer for Kafka.
- HazelcastKafkaAvroSerializer() - Constructor for class com.hazelcast.jet.kafka.HazelcastKafkaAvroSerializer
-
Constructor used by Kafka producer.
- HazelcastKubernetesDiscoveryStrategyFactory - Class in com.hazelcast.kubernetes
-
Just the factory to create the Kubernetes Discovery Strategy
- HazelcastKubernetesDiscoveryStrategyFactory() - Constructor for class com.hazelcast.kubernetes.HazelcastKubernetesDiscoveryStrategyFactory
- HazelcastMemberCachingProvider - Class in com.hazelcast.cache
-
Member-side
CachingProvider
implementation. - HazelcastMemberCachingProvider() - Constructor for class com.hazelcast.cache.HazelcastMemberCachingProvider
- HazelcastNamespaceHandler - Class in com.hazelcast.spring
-
Hazelcast Custom Namespace Definitions.
- HazelcastNamespaceHandler() - Constructor for class com.hazelcast.spring.HazelcastNamespaceHandler
- HazelcastOSGiInstance - Interface in com.hazelcast.osgi
-
Contract point for
HazelcastInstance
implementations based on OSGi service. - HazelcastOSGiService - Interface in com.hazelcast.osgi
-
Contract point for Hazelcast services on top of OSGI.
- HazelcastOverloadException - Exception in com.hazelcast.core
-
A
HazelcastException
that is thrown when the system won't handle more load due to an overload. - HazelcastOverloadException(String) - Constructor for exception com.hazelcast.core.HazelcastOverloadException
- HazelcastOverloadException(String, Throwable) - Constructor for exception com.hazelcast.core.HazelcastOverloadException
- HazelcastProperties - Class in com.hazelcast.spi.properties
-
Container for configured Hazelcast properties (see
HazelcastProperty
). - HazelcastProperties(Config) - Constructor for class com.hazelcast.spi.properties.HazelcastProperties
-
Creates a container with configured Hazelcast properties.
- HazelcastProperties(Properties) - Constructor for class com.hazelcast.spi.properties.HazelcastProperties
-
Creates a container with configured Hazelcast properties.
- HazelcastProperty - Class in com.hazelcast.spi.properties
-
Interface for Hazelcast Member and Client properties.
- HazelcastProperty(String) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
- HazelcastProperty(String, boolean) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
- HazelcastProperty(String, HazelcastProperty) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
- HazelcastProperty(String, Byte) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
- HazelcastProperty(String, Double) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
- HazelcastProperty(String, Enum<?>) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
- HazelcastProperty(String, Float) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
- HazelcastProperty(String, Integer) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
- HazelcastProperty(String, Integer, TimeUnit) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
- HazelcastProperty(String, Long) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
- HazelcastProperty(String, Long, TimeUnit) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
- HazelcastProperty(String, String) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
- HazelcastProperty(String, String, TimeUnit) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
- HazelcastProperty(String, String, TimeUnit, HazelcastProperty) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
- HazelcastProperty(String, Function<HazelcastProperties, ?>) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
- HazelcastRuntimePermission - Class in com.hazelcast.security.jsm
-
Class which holds named Hazelcast permissions for Security Manager checks.
- HazelcastRuntimePermission(String) - Constructor for class com.hazelcast.security.jsm.HazelcastRuntimePermission
-
Creates permission with given name.
- HazelcastRuntimePermission(String, String) - Constructor for class com.hazelcast.security.jsm.HazelcastRuntimePermission
-
Creates permission with given name.
- HazelcastSerializationException - Exception in com.hazelcast.nio.serialization
-
An exception thrown when a problem occurs while serializing/deserializing objects.
- HazelcastSerializationException(String) - Constructor for exception com.hazelcast.nio.serialization.HazelcastSerializationException
- HazelcastSerializationException(String, Throwable) - Constructor for exception com.hazelcast.nio.serialization.HazelcastSerializationException
- HazelcastSerializationException(Throwable) - Constructor for exception com.hazelcast.nio.serialization.HazelcastSerializationException
- HazelcastServerCommandLine - Class in com.hazelcast.commandline
-
Main command class for Hazelcast operations
- HazelcastServerCommandLine() - Constructor for class com.hazelcast.commandline.HazelcastServerCommandLine
- HazelcastSqlException - Exception in com.hazelcast.sql
-
An exception occurred during SQL query execution.
- HazelcastSqlException(String, Throwable) - Constructor for exception com.hazelcast.sql.HazelcastSqlException
- HazelcastSqlException(UUID, int, String, Throwable, String) - Constructor for exception com.hazelcast.sql.HazelcastSqlException
- HazelcastTransactionManager - Class in com.hazelcast.spring.transaction
-
PlatformTransactionManager
implementation for a singleHazelcastInstance
. - HazelcastTransactionManager(HazelcastInstance) - Constructor for class com.hazelcast.spring.transaction.HazelcastTransactionManager
- HazelcastTypeBeanDefinitionParser - Class in com.hazelcast.spring
-
BeanDefinitionParser for Type Configuration of Hazelcast Types like map, queue, topic etc.
- HazelcastTypeBeanDefinitionParser(String) - Constructor for class com.hazelcast.spring.HazelcastTypeBeanDefinitionParser
- HazelcastXAResource - Interface in com.hazelcast.transaction
-
Interface for providing Hazelcast as an XAResource
- HEAD_SEQUENCE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- headSequence() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
-
Returns the sequence of the head.
- HEALTH_CHECK - Enum constant in enum class com.hazelcast.config.RestEndpointGroup
-
Deprecated.Group of endpoints for HTTP health checking.
- HEALTH_MONITORING_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Health monitoring logging interval in seconds.
- HEALTH_MONITORING_LEVEL - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Health monitoring log level.
- HEALTH_MONITORING_THRESHOLD_CPU_PERCENTAGE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
When the health monitoring level is SILENT, logs are printed only when the CPU usage exceeds this threshold.
- HEALTH_MONITORING_THRESHOLD_MEMORY_PERCENTAGE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
When the health monitoring level is SILENT, logs are printed only when the memory usage exceeds this threshold.
- HEARTBEAT_FAILURE_DETECTOR_TYPE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Heartbeat failure detector type.
- HEARTBEAT_INTERVAL - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Time interval between the heartbeats sent by the client to the nodes.
- HEARTBEAT_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The interval at which member heartbeat messages are sent
- HEARTBEAT_TIMEOUT - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Client sends heartbeat messages to the members and this is the timeout for this sending operations.
- HeartbeatAware - Interface in com.hazelcast.splitbrainprotection
-
SplitBrainProtectionFunction
s which implement this interface will be notified of member heartbeats. - higherFrameTs(long) - Method in class com.hazelcast.jet.core.SlidingWindowPolicy
-
Returns the lowest frame timestamp greater than the given timestamp.
- HigherHitsMergePolicy<V,
T extends MergingValue<V> & MergingHits> - Class in com.hazelcast.spi.merge -
Merges data structure entries from source to destination data structure if the source entry has more hits than the destination one.
- HigherHitsMergePolicy() - Constructor for class com.hazelcast.spi.merge.HigherHitsMergePolicy
- hint(Hint<T>, T) - Method in class com.hazelcast.vector.SearchOptionsBuilder
-
Adds search hint.
- hint(String, T) - Method in class com.hazelcast.vector.SearchOptionsBuilder
-
Adds search hint.
- Hint<T> - Record Class in com.hazelcast.vector
-
SearchOptions
hint definition - Hint(String, Function<String, T>) - Constructor for record class com.hazelcast.vector.Hint
-
Creates an instance of a
Hint
record class. - hints(Map<String, String>) - Method in class com.hazelcast.vector.SearchOptionsBuilder
-
Sets search hints.
- HOST_AWARE - Enum constant in enum class com.hazelcast.config.PartitionGroupConfig.MemberGroupType
-
Host aware.
- HOST_PROPERTY - Static variable in class com.hazelcast.jet.mongodb.dataconnection.MongoDataConnection
-
Name of a property which holds host:port address of the mongodb instance.
- HOT_RESTART - Enum constant in enum class com.hazelcast.config.RestEndpointGroup
-
Deprecated.since 5.0 Please use
RestEndpointGroup.PERSISTENCE
instead. If this deprecated endpoint group is tried to be activated, we apply this change as it's made to RestEndpointGroup#PERSISTENCE. - HOT_RESTART_BASE_DIR_DEFAULT - Static variable in class com.hazelcast.config.HotRestartPersistenceConfig
-
Deprecated.Default directory name for the Hot Restart store's home
- HotRestartClusterDataRecoveryPolicy - Enum Class in com.hazelcast.config
-
Deprecated.since 5.0 use
PersistenceClusterDataRecoveryPolicy
- hotRestartConfig - Variable in class com.hazelcast.config.AbstractCacheConfig
- HotRestartConfig - Class in com.hazelcast.config
-
Deprecated.since 5.0 use
DataPersistenceConfig
- HotRestartConfig() - Constructor for class com.hazelcast.config.HotRestartConfig
-
Deprecated.
- HotRestartConfig(HotRestartConfig) - Constructor for class com.hazelcast.config.HotRestartConfig
-
Deprecated.
- HotRestartPersistenceConfig - Class in com.hazelcast.config
-
Deprecated.since 5.0 use
PersistenceConfig
- HotRestartPersistenceConfig() - Constructor for class com.hazelcast.config.HotRestartPersistenceConfig
-
Deprecated.
- HotRestartService - Interface in com.hazelcast.hotrestart
-
Deprecated.since 5.0 because of renaming purposes. Please use
PersistenceService
instead. - HTTP_NOT_FOUND - Static variable in class com.hazelcast.spi.utils.RestClient
- HTTP_OK - Static variable in class com.hazelcast.spi.utils.RestClient
- HyperLogLogMergePolicy - Class in com.hazelcast.spi.merge
-
Only available for HyperLogLog backed
CardinalityEstimator
. - HyperLogLogMergePolicy() - Constructor for class com.hazelcast.spi.merge.HyperLogLogMergePolicy
I
- IAtomicLong - Interface in com.hazelcast.cp
-
IAtomicLong is a redundant and highly available distributed alternative to the
AtomicLong
. - IAtomicReference<E> - Interface in com.hazelcast.cp
-
IAtomicReference is a redundant and highly available distributed alternative to the
AtomicReference
. - ICache<K,
V> - Interface in com.hazelcast.cache -
This
ICache
interface is theCache
extension offered by Hazelcast JCache.
In addition to the standard set of JCache methods defined in the JSR 107 specification, Hazelcast provides additional operations to support a broader range of programing styles. - ICACHE_SERVICE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- ICacheManager - Interface in com.hazelcast.core
-
ICacheManager
is the entry point to access JSR-107 (JCache) caches viaHazelcastInstance
interface. - IcmpFailureDetectorConfig - Class in com.hazelcast.config
-
This Failure Detector may be configured in addition to one of Deadline and Phi Accrual Failure Detectors.
It operates at Layer 3 of the OSI protocol, and provides much quicker and more deterministic detection of hardware
and other lower level events. - IcmpFailureDetectorConfig() - Constructor for class com.hazelcast.config.IcmpFailureDetectorConfig
- ICollection<E> - Interface in com.hazelcast.collection
-
Concurrent, distributed, partitioned, listenable collection.
- ICountDownLatch - Interface in com.hazelcast.cp
-
ICountDownLatch is a backed-up distributed alternative to the
java.util.concurrent.CountDownLatch
. - ICredentialsFactory - Interface in com.hazelcast.security
-
ICredentialsFactory is used to create
Credentials
objects to be used during node authentication before connection is accepted by the master node. - id() - Method in interface com.hazelcast.cp.CPGroup
-
Returns unique id of the CP group
- id() - Method in enum class com.hazelcast.cp.event.CPMembershipEvent.EventType
- id() - Method in interface com.hazelcast.cp.session.CPSession
-
Returns id of the session
- id() - Method in enum class com.hazelcast.transaction.TransactionOptions.TransactionType
- ID_COLUMN_PROPERTY - Static variable in class com.hazelcast.mapstore.GenericMapLoader
-
Property key to define id column name in database
- IdentifiedDataSerializable - Interface in com.hazelcast.nio.serialization
-
IdentifiedDataSerializable is an extension to
DataSerializable
to avoid reflection during de-serialization. - identifyDocumentBy(String, FunctionEx<T, Object>) - Method in class com.hazelcast.jet.mongodb.MongoSinkBuilder
-
Sets the filter that decides which document in the collection is equal to processed document.
- identity() - Static method in interface com.hazelcast.function.FunctionEx
-
Serializable
variant ofjava.util.function.Function#identity()
. - identity() - Static method in class com.hazelcast.projection.Projections
-
Returns a projection that does no transformation.
- IdentityConfig - Interface in com.hazelcast.config.security
-
This interface represents identity configuration in security realms or client security configurations.
- idFromString(String) - Static method in class com.hazelcast.jet.Util
-
Parses the jobId formatted with
Util.idToString(long)
. - idleTimeoutMillis() - Method in class com.hazelcast.jet.core.EventTimePolicy
-
Returns the amount of time allowed to pass without receiving any events from a partition before marking it as "idle".
- idToString(long) - Static method in class com.hazelcast.jet.Util
-
Converts a
long
job or execution ID to a string representation. - IExecutorService - Interface in com.hazelcast.core
-
Distributed implementation of
ExecutorService
. - IFunction<T,
R> - Interface in com.hazelcast.core -
Represents a function that accepts one argument and produces a result.
- IGNORE_FILE_NOT_FOUND - Static variable in class com.hazelcast.jet.hadoop.HadoopSources
- ignoreFileNotFound(boolean) - Method in class com.hazelcast.jet.pipeline.file.FileSourceBuilder
-
Set to true to ignore no matching files in the directory specified by
path
. - ilike(String, String) - Static method in class com.hazelcast.query.Predicates
-
Creates a case-insensitive like predicate that will pass items if the given
pattern
matches the value stored under the given itemattribute
in a case-insensitive manner. - IList<E> - Interface in com.hazelcast.collection
-
Concurrent, distributed implementation of
List
. - ILogger - Interface in com.hazelcast.logging
-
The Hazelcast logging interface.
- IMap<K,
V> - Interface in com.hazelcast.map -
Concurrent, distributed, observable and queryable map.
- IMAP_SERVICE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- IMapEvent - Interface in com.hazelcast.map
-
Map events common contract.
- iMapService(String) - Static method in class com.hazelcast.jet.pipeline.ServiceFactories
-
Returns a factory that provides an
IMap
as the service. - implementation - Variable in class com.hazelcast.config.AbstractWanPublisherConfig
- implementation - Variable in class com.hazelcast.config.ListenerConfig
- implementation - Variable in class com.hazelcast.config.PredicateConfig
- implementation - Variable in class com.hazelcast.config.SecurityInterceptorConfig
- implies(Permission) - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
- implies(Permission) - Method in class com.hazelcast.security.permission.AllPermissions
- implies(Permission) - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
- implies(Permission) - Method in class com.hazelcast.security.permission.ConfigPermission
- implies(Permission) - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
- implies(Permission) - Method in class com.hazelcast.security.permission.InstancePermission
- implies(Permission) - Method in class com.hazelcast.security.permission.ManagementPermission
- implies(Permission) - Method in class com.hazelcast.security.permission.TransactionPermission
- importDocuments(YamlNode) - Method in class com.hazelcast.config.AbstractYamlConfigBuilder
-
Imports external YAML documents into the provided main YAML document.
- in(int, Object) - Static method in class com.hazelcast.jet.core.test.TestSupport
-
Create a test event with an input item on the given ordinal.
- in(Comparable...) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
- in(Object) - Static method in class com.hazelcast.jet.core.test.TestSupport
-
Create a test event with an input item.
- in(String, Comparable...) - Static method in class com.hazelcast.query.Predicates
-
Creates a in predicate that will pass items if the value stored under the given item
attribute
is a member of the givenvalues
set. - IN_PROGRESS - Enum constant in enum class com.hazelcast.persistence.BackupTaskState
-
The backup task is currently in progress
- IN_TRANSITION - Enum constant in enum class com.hazelcast.cluster.ClusterState
-
Shows that ClusterState is in transition.
- Inbox - Interface in com.hazelcast.jet.core
-
A subset of
Queue<Object>
API restricted to the consumer side, with additional support for bulk draining operations. - inboxLimit() - Method in class com.hazelcast.jet.core.test.TestSupport.TestMode
-
Size limit of the inbox.
- includeValue() - Method in class com.hazelcast.vector.SearchOptionsBuilder
-
Includes the user-supplied value in search results.
- includeVectors() - Method in class com.hazelcast.vector.SearchOptionsBuilder
-
Includes the vectors associated with each search result in search results.
- increasePermits(int) - Method in interface com.hazelcast.cp.ISemaphore
-
Increases the number of available permits by the indicated amount.
- increment() - Method in interface com.hazelcast.jet.core.metrics.Metric
-
Increments the current value by 1.
- increment(long) - Method in interface com.hazelcast.jet.core.metrics.Metric
-
Increments the current value by the specified amount.
- incrementAndGet() - Method in interface com.hazelcast.cp.IAtomicLong
-
Atomically increments the current value by one.
- incrementAndGet() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
-
Increments by one the current value.
- incrementAndGetAsync() - Method in interface com.hazelcast.cp.IAtomicLong
-
Atomically increments the current value by one.
- incrementDropped(String) - Method in class com.hazelcast.wan.WanEventCounters
-
Increment the number of dropped events for the
distributedObjectName
. - incrementEntrySetCallCount() - Method in interface com.hazelcast.replicatedmap.LocalReplicatedMapStats
-
Increments the number of
ReplicatedMap.entrySet()
calls. - incrementQueryResultSizeExceededCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Increments throw count of
QueryResultSizeExceededException
- incrementRemove(String) - Method in class com.hazelcast.wan.WanEventCounters
-
Increment the number of remove events for the
distributedObjectName
. - incrementSync(String) - Method in class com.hazelcast.wan.WanEventCounters
-
Increment the number of sync events for the
distributedObjectName
. - incrementSync(String, int) - Method in class com.hazelcast.wan.WanEventCounters
-
Increment the number of sync events for the
distributedObjectName
bycount
. - incrementUpdate(String) - Method in class com.hazelcast.wan.WanEventCounters
-
Increment the number of update events for the
distributedObjectName
. - incrementValuesCallCount() - Method in interface com.hazelcast.replicatedmap.LocalReplicatedMapStats
-
Increments the number of
ReplicatedMap.values()
calls. - indefinitely(long) - Static method in class com.hazelcast.jet.retry.RetryStrategies
-
Create a strategy which will retry failed actions indefinitely and will wait for a fixed amount of time between any two subsequent attempts.
- IndeterminateOperationState - Interface in com.hazelcast.core
-
A marker interface for exceptions to denote that execution status of an invocation is not known
- IndeterminateOperationStateException - Exception in com.hazelcast.core
-
IndeterminateOperationStateException is thrown when result of an invocation becomes indecisive.
- IndeterminateOperationStateException() - Constructor for exception com.hazelcast.core.IndeterminateOperationStateException
- IndeterminateOperationStateException(String) - Constructor for exception com.hazelcast.core.IndeterminateOperationStateException
- IndeterminateOperationStateException(String, Throwable) - Constructor for exception com.hazelcast.core.IndeterminateOperationStateException
- index() - Method in class com.hazelcast.jet.datamodel.Tag
-
Returns the index associated with this tag.
- INDEX_COPY_BEHAVIOR - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Type of Query Index result copying behavior.
- INDEX_OF - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- INDEX_ONLY - Enum constant in enum class com.hazelcast.config.CacheDeserializedValues
-
Cache values only when using search indexes
- IndexConfig - Class in com.hazelcast.config
-
Configuration of an index.
- IndexConfig() - Constructor for class com.hazelcast.config.IndexConfig
- IndexConfig(IndexConfig) - Constructor for class com.hazelcast.config.IndexConfig
- IndexConfig(IndexType) - Constructor for class com.hazelcast.config.IndexConfig
-
Creates an index configuration of the given type.
- IndexConfig(IndexType, String...) - Constructor for class com.hazelcast.config.IndexConfig
-
Creates an index configuration of the given type with provided attributes.
- indexNameToVector() - Method in interface com.hazelcast.vector.VectorValues.MultiIndexVectorValues
- IndexType - Enum Class in com.hazelcast.config
-
Type of the index.
- info(String) - Method in class com.hazelcast.logging.AbstractLogger
- info(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
- info(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
- INFO - Enum constant in enum class com.hazelcast.auditlog.Level
-
Info level.
- init() - Method in class com.hazelcast.spring.HazelcastNamespaceHandler
- init(int) - Method in interface com.hazelcast.cp.ISemaphore
-
Tries to initialize this ISemaphore instance with the given permit count
- init(Cluster, ClientConfig) - Method in interface com.hazelcast.client.LoadBalancer
-
Initializes the LoadBalancer.
- init(InitialMembershipEvent) - Method in interface com.hazelcast.cluster.InitialMembershipListener
-
Called when this listener is registered.
- init(WanReplicationConfig, AbstractWanPublisherConfig) - Method in interface com.hazelcast.wan.WanPublisher
-
Initializes the publisher.
- init(HazelcastInstance, Properties, String) - Method in interface com.hazelcast.map.MapLoaderLifecycleSupport
-
Initializes this MapLoader implementation.
- init(HazelcastInstance, Properties, String) - Method in class com.hazelcast.mapstore.GenericMapLoader
- init(DefaultPartitionStrategy) - Method in class com.hazelcast.jet.core.Partitioner.Default
- init(DefaultPartitionStrategy) - Method in interface com.hazelcast.jet.core.Partitioner
-
Callback that injects the Hazelcast's default partitioning strategy into this partitioner, so it can be consulted by the
Partitioner.getPartition(Object, int)
method. - init(Outbox, Processor.Context) - Method in class com.hazelcast.jet.core.AbstractProcessor
- init(Outbox, Processor.Context) - Method in interface com.hazelcast.jet.core.Processor
-
Initializes this processor with the outbox that the processing methods must use to deposit their output items.
- init(Processor.Context) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Method that can be overridden to perform any necessary initialization for the processor.
- init(Processor.Context) - Method in class com.hazelcast.jet.pipeline.test.LongStreamSourceP
- init(Processor.Context) - Method in class com.hazelcast.jet.pipeline.test.ParallelBatchP
- init(Processor.Context) - Method in class com.hazelcast.jet.pipeline.test.ParallelStreamP
- init(ProcessorMetaSupplier.Context) - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Called on the cluster member that receives the job request.
- init(ProcessorMetaSupplier.Context) - Method in class com.hazelcast.jet.core.ProcessorMetaSupplier.RandomMemberPms
- init(ProcessorMetaSupplier.Context) - Method in class com.hazelcast.jet.core.ProcessorMetaSupplier.SpecificMemberPms
- init(ProcessorSupplier.Context) - Method in interface com.hazelcast.jet.core.ProcessorSupplier
-
Called on each cluster member after deserialization.
- init(String, WanConsumerConfig) - Method in interface com.hazelcast.wan.WanConsumer
-
Initialize the WAN consumer.
- init(Properties) - Method in class com.hazelcast.config.replacer.AbstractPbeReplacer
- init(Properties) - Method in class com.hazelcast.config.replacer.EncryptionReplacer
- init(Properties) - Method in class com.hazelcast.config.replacer.PropertyReplacer
- init(Properties) - Method in interface com.hazelcast.config.replacer.spi.ConfigReplacer
-
Initialization method called before first usage of the config replacer.
- init(Properties) - Method in interface com.hazelcast.nio.SocketInterceptor
-
Initializes socket interceptor with properties which is set by
Config.setProperty(String, String)
- init(Properties) - Method in interface com.hazelcast.security.ICredentialsFactory
-
This method is (only) called if the factory instance is newly created from a class name provided in
CredentialsFactoryConfig
. - init(CallbackHandler, Properties) - Method in interface com.hazelcast.access.AccessControlServiceFactory
-
Initializes this class with given properties.
- init(CallbackHandler, Properties) - Method in interface com.hazelcast.auditlog.AuditlogServiceFactory
-
Initializes this class with given properties.
- INIT_CLUSTER_VERSION - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Override cluster version to use while node is not yet member of a cluster.
- INITIAL - Enum constant in enum class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.PostgresSnapshotMode
-
Perform a snapshot only upon initial startup of a connector.
- INITIAL_MEMORY_SIZE - Static variable in class com.hazelcast.config.NativeMemoryConfig
-
Initial memory size in megabytes
- INITIAL_MIN_CLUSTER_SIZE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Initial expected cluster size to wait before member to start completely.
- INITIAL_ONLY - Enum constant in enum class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.PostgresSnapshotMode
-
Perform a snapshot and then stop before attempting to receive any logical changes.
- INITIAL_WAIT_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Initial time in seconds to wait before member to start completely.
- initialize(Object) - Method in interface com.hazelcast.core.ManagedContext
-
Initialize the given object instance.
- initialize(Object) - Method in class com.hazelcast.spring.context.SpringManagedContext
- InitialMembershipEvent - Class in com.hazelcast.cluster
-
An event that is sent when a
InitialMembershipListener
registers itself on aCluster
. - InitialMembershipEvent(Cluster, Set<Member>) - Constructor for class com.hazelcast.cluster.InitialMembershipEvent
- InitialMembershipListener - Interface in com.hazelcast.cluster
-
The InitialMembershipListener is a
MembershipListener
that first receives anInitialMembershipEvent
when it is registered so it immediately knows which members are available. - initIsCooperative() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Returns
true
if both theProcessorMetaSupplier.init(Context)
andProcessorMetaSupplier.get(List)
methods of this instance are cooperative. - initIsCooperative() - Method in class com.hazelcast.jet.core.ProcessorMetaSupplier.RandomMemberPms
- initIsCooperative() - Method in class com.hazelcast.jet.core.ProcessorMetaSupplier.SpecificMemberPms
- initIsCooperative() - Method in interface com.hazelcast.jet.core.ProcessorSupplier
-
Returns
true
if theProcessorSupplier.init(Context)
method of this instance is cooperative. - initLoginModuleProperties() - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
- initLoginModuleProperties() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
- initLoginModuleProperties() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- initLoginModuleProperties() - Method in class com.hazelcast.config.security.SimpleAuthenticationConfig
- initLoginModuleProperties() - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
- initMask(String[]) - Method in class com.hazelcast.security.permission.AtomicLongPermission
- initMask(String[]) - Method in class com.hazelcast.security.permission.AtomicReferencePermission
- initMask(String[]) - Method in class com.hazelcast.security.permission.CachePermission
- initMask(String[]) - Method in class com.hazelcast.security.permission.CardinalityEstimatorPermission
- initMask(String[]) - Method in class com.hazelcast.security.permission.ConnectorPermission
- initMask(String[]) - Method in class com.hazelcast.security.permission.CountDownLatchPermission
- initMask(String[]) - Method in class com.hazelcast.security.permission.CPMapPermission
- initMask(String[]) - Method in class com.hazelcast.security.permission.DurableExecutorServicePermission
- initMask(String[]) - Method in class com.hazelcast.security.permission.ExecutorServicePermission
- initMask(String[]) - Method in class com.hazelcast.security.permission.FlakeIdGeneratorPermission
- initMask(String[]) - Method in class com.hazelcast.security.permission.InstancePermission
-
init mask
- initMask(String[]) - Method in class com.hazelcast.security.permission.JobPermission
- initMask(String[]) - Method in class com.hazelcast.security.permission.ListPermission
- initMask(String[]) - Method in class com.hazelcast.security.permission.LockPermission
- initMask(String[]) - Method in class com.hazelcast.security.permission.MapPermission
- initMask(String[]) - Method in class com.hazelcast.security.permission.PNCounterPermission
- initMask(String[]) - Method in class com.hazelcast.security.permission.QueuePermission
- initMask(String[]) - Method in class com.hazelcast.security.permission.ReliableTopicPermission
- initMask(String[]) - Method in class com.hazelcast.security.permission.ReplicatedMapPermission
- initMask(String[]) - Method in class com.hazelcast.security.permission.RingBufferPermission
- initMask(String[]) - Method in class com.hazelcast.security.permission.ScheduledExecutorPermission
- initMask(String[]) - Method in class com.hazelcast.security.permission.SemaphorePermission
- initMask(String[]) - Method in class com.hazelcast.security.permission.SqlPermission
- initMask(String[]) - Method in class com.hazelcast.security.permission.TopicPermission
- initMask(String[]) - Method in class com.hazelcast.security.permission.UserCodeDeploymentPermission
-
Deprecated.
- initMask(String[]) - Method in class com.hazelcast.security.permission.UserCodeNamespacePermission
- initMask(String[]) - Method in class com.hazelcast.security.permission.VectorCollectionPermission
- InMemoryFormat - Enum Class in com.hazelcast.config
-
Storage format type of values stored in cluster
- InMemoryXmlConfig - Class in com.hazelcast.config
-
Creates a
Config
loaded from an in-memory Hazelcast XML String. - InMemoryXmlConfig(String) - Constructor for class com.hazelcast.config.InMemoryXmlConfig
-
Creates a Config from the provided XML string and uses the System.properties to resolve variables in the XML.
- InMemoryXmlConfig(String, Properties) - Constructor for class com.hazelcast.config.InMemoryXmlConfig
-
Creates a Config from the provided XML string and properties to resolve the variables in the XML.
- InMemoryYamlConfig - Class in com.hazelcast.config
-
Creates a
Config
loaded from an in-memory Hazelcast YAML String. - InMemoryYamlConfig(String) - Constructor for class com.hazelcast.config.InMemoryYamlConfig
-
Creates a Config from the provided YAML string and uses the System.properties to resolve variables in the YAML.
- InMemoryYamlConfig(String, Properties) - Constructor for class com.hazelcast.config.InMemoryYamlConfig
-
Creates a Config from the provided YAML string and properties to resolve the variables in the YAML.
- innerHashJoin(BatchStage<T1_IN>, JoinClause<K, ? super T, ? super T1_IN, ? extends T1>, BiFunctionEx<T, T1, R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- innerHashJoin(BatchStage<T1_IN>, JoinClause<K, ? super T, ? super T1_IN, ? extends T1>, BiFunctionEx<T, T1, R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Attaches to both this and the supplied stage an inner hash-joining stage and returns it.
- innerHashJoin(BatchStage<T1_IN>, JoinClause<K, ? super T, ? super T1_IN, ? extends T1>, BiFunctionEx<T, T1, R>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- innerHashJoin2(BatchStage<T1_IN>, JoinClause<K1, ? super T, ? super T1_IN, ? extends T1>, BatchStage<T2_IN>, JoinClause<K2, ? super T, ? super T2_IN, ? extends T2>, TriFunction<T, T1, T2, R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- innerHashJoin2(BatchStage<T1_IN>, JoinClause<K1, ? super T, ? super T1_IN, ? extends T1>, BatchStage<T2_IN>, JoinClause<K2, ? super T, ? super T2_IN, ? extends T2>, TriFunction<T, T1, T2, R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Attaches to this and the two supplied stages an inner hash-joining stage and returns it.
- innerHashJoin2(BatchStage<T1_IN>, JoinClause<K1, ? super T, ? super T1_IN, ? extends T1>, BatchStage<T2_IN>, JoinClause<K2, ? super T, ? super T2_IN, ? extends T2>, TriFunction<T, T1, T2, R>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- inProgress() - Method in enum class com.hazelcast.persistence.BackupTaskState
-
Returns if the backup task is in progress.
- input(List<?>) - Method in class com.hazelcast.jet.core.test.TestSupport
-
Sets the input objects for processor.
- inputFormat(ConsumerEx<Configuration>, BiFunctionEx<K, V, E>) - Static method in class com.hazelcast.jet.hadoop.HadoopSources
-
Returns a source that reads records from Apache Hadoop HDFS and emits the results of transforming each record (a key-value pair) with the supplied projection function.
- inputFormat(Configuration) - Static method in class com.hazelcast.jet.hadoop.HadoopSources
-
Convenience for
HadoopSources.inputFormat(Configuration, BiFunctionEx)
withMap.Entry
as its output type. - inputFormat(Configuration, BiFunctionEx<K, V, E>) - Static method in class com.hazelcast.jet.hadoop.HadoopSources
-
Returns a source that reads records from Apache Hadoop HDFS and emits the results of transforming each record (a key-value pair) with the supplied projection function.
- inputs(List<List<?>>) - Method in class com.hazelcast.jet.core.test.TestSupport
-
Sets the input objects for the processor on multiple input ordinals.
- inputs(List<List<?>>, int[]) - Method in class com.hazelcast.jet.core.test.TestSupport
-
Sets the input objects for the processor on multiple input ordinals.
- INSERT - Enum constant in enum class com.hazelcast.jet.cdc.Operation
-
Record insertion, sourced from the DB changelog.
- INSERT_ONLY - Enum constant in enum class com.hazelcast.jet.mongodb.WriteMode
-
Items will be inserted to MongoDB; in case of ID clash, error will be thrown.
- insertWatermarksP(FunctionEx<ProcessorSupplier.Context, EventTimePolicy<? super T>>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for a vertex that inserts
watermark items
into the stream. - insertWatermarksP(EventTimePolicy<? super T>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for a vertex that inserts
watermark items
into the stream. - INSTANCE - Static variable in class com.hazelcast.config.security.DefaultAuthenticationConfig
-
Singleton instance.
- INSTANCE - Static variable in class com.hazelcast.partition.strategy.StringAndPartitionAwarePartitioningStrategy
- INSTANCE - Static variable in class com.hazelcast.partition.strategy.StringPartitioningStrategy
- InstanceConfig - Class in com.hazelcast.jet.config
-
Deprecated.since 5.0, use
JetConfig
instead. - InstanceConfig() - Constructor for class com.hazelcast.jet.config.InstanceConfig
-
Deprecated.
- instanceOf(Class<?>) - Static method in class com.hazelcast.query.Predicates
-
Creates an instance of predicate that will pass entries for which the value class is an
instanceof
the givenklass
. - InstancePermission - Class in com.hazelcast.security.permission
-
TODO: Object Permission
- InstancePermission(String, String...) - Constructor for class com.hazelcast.security.permission.InstancePermission
- InstanceTrackingConfig - Class in com.hazelcast.config
-
Configures tracking of a running Hazelcast instance.
- InstanceTrackingConfig() - Constructor for class com.hazelcast.config.InstanceTrackingConfig
- InstanceTrackingConfig(InstanceTrackingConfig) - Constructor for class com.hazelcast.config.InstanceTrackingConfig
- InstanceTrackingConfig.InstanceMode - Enum Class in com.hazelcast.config
-
The mode in which this instance is running.
- InstanceTrackingConfig.InstanceProductName - Enum Class in com.hazelcast.config
-
Product name for the Hazelcast instance
- InstanceTrackingConfig.InstanceTrackingProperties - Enum Class in com.hazelcast.config
-
Enumeration of instance properties provided to the format pattern for output.
- INT - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
- INT_ARRAY - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
- INT16 - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
- INT32 - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
- INT64 - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
- INT8 - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
- INTEGER - Enum constant in enum class com.hazelcast.config.properties.PropertyTypeConverter
-
TypeConverter
to convert an input string to an output int - INTEGER - Enum constant in enum class com.hazelcast.sql.SqlColumnType
-
INTEGER type, represented by
Integer
- integerAvg() - Static method in class com.hazelcast.aggregation.Aggregators
- integerAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
- integerMax() - Static method in class com.hazelcast.aggregation.Aggregators
- integerMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
- integerMin() - Static method in class com.hazelcast.aggregation.Aggregators
- integerMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
- integerSum() - Static method in class com.hazelcast.aggregation.Aggregators
- integerSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
- IntegrityCheckerConfig - Class in com.hazelcast.config
-
Configures Module Integrity Checker.
- IntegrityCheckerConfig() - Constructor for class com.hazelcast.config.IntegrityCheckerConfig
- interceptAfter(Credentials, String, String, String) - Method in interface com.hazelcast.security.SecurityContext
-
intercepts a request after process if any
SecurityInterceptor
configured Any exception thrown during interception will be ignored - interceptBefore(Credentials, String, String, String, Object[]) - Method in interface com.hazelcast.security.SecurityContext
-
intercepts a request before process if any
SecurityInterceptor
configured - interceptGet(Object) - Method in interface com.hazelcast.map.MapInterceptor
-
Intercepts the get operation before returning value.
- interceptPut(Object, Object) - Method in interface com.hazelcast.map.MapInterceptor
-
Intercepts the put operation before modifying the map data.
- interceptRemove(Object) - Method in interface com.hazelcast.map.MapInterceptor
-
Intercepts the remove operation before removing the data.
- interfaces - Variable in class com.hazelcast.config.EndpointConfig
- InterfacesConfig - Class in com.hazelcast.config
-
Contains the configuration for Interfaces.
- InterfacesConfig() - Constructor for class com.hazelcast.config.InterfacesConfig
- interruptBackupTask() - Method in interface com.hazelcast.persistence.PersistenceService
-
Interrupts the backup tasks on each cluster member if one is currently running.
- interruptLocalBackupTask() - Method in interface com.hazelcast.persistence.PersistenceService
-
Interrupts the local backup task if one is currently running.
- intervalFunction(IntervalFunction) - Method in class com.hazelcast.jet.retry.RetryStrategies.Builder
-
Set a function to modify the waiting interval after a failure.
- IntervalFunction - Interface in com.hazelcast.jet.retry
-
Function that computes the wait time necessary for each subsequent retry attempt.
- into(FunctionEx<T, String>, FunctionEx<T, String>) - Method in class com.hazelcast.jet.mongodb.MongoSinkBuilder
- into(String, String) - Method in class com.hazelcast.jet.mongodb.MongoSinkBuilder
- INVALID_FENCE - Static variable in interface com.hazelcast.cp.lock.FencedLock
-
Representation of a failed lock attempt where the caller thread has not acquired the lock
- INVALIDATE - Enum constant in enum class com.hazelcast.config.NearCacheConfig.LocalUpdatePolicy
-
Local put and local remove immediately invalidate Near Cache.
- INVALIDATED - Enum constant in enum class com.hazelcast.cache.CacheEventType
-
An event type indicating that the cache entry has invalidated for Near Cache invalidation.
- INVALIDATION - Enum constant in enum class com.hazelcast.core.EntryEventType
-
Fired if an entry is invalidated.
- InvalidConfigurationException - Exception in com.hazelcast.config
-
A InvalidConfigurationException is thrown when Hazelcast faces an invalid configuration.
- InvalidConfigurationException(String) - Constructor for exception com.hazelcast.config.InvalidConfigurationException
-
Creates a InvalidConfigurationException with the given message.
- InvalidConfigurationException(String, Throwable) - Constructor for exception com.hazelcast.config.InvalidConfigurationException
-
Constructs a new runtime exception with the specified detail message and cause.
- INVOCATION_MAX_RETRY_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Maximum number of retries for an invocation.
- INVOCATION_RETRY_PAUSE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Pause time between each retry cycle of an invocation in milliseconds.
- INVOCATION_RETRY_PAUSE_MILLIS - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Pause time between each retry cycle of an invocation in milliseconds.
- INVOCATION_TIMEOUT_SECONDS - Static variable in class com.hazelcast.client.properties.ClientProperty
-
When an invocation gets an exception because: - Member throws an exception
- INVOKE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- IO_BALANCER_INTERVAL_SECONDS - Static variable in class com.hazelcast.client.properties.ClientProperty
-
The interval in seconds between
IOBalancer
executions. - IO_BALANCER_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The interval in seconds between
IOBalancer
executions. - IO_INPUT_THREAD_COUNT - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Controls the number of IO input threads.
- IO_INPUT_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Controls the number of socket input threads.
- IO_OUTPUT_THREAD_COUNT - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Controls the number of IO output threads.
- IO_OUTPUT_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Controls the number of socket output threads.
- IO_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The number of threads doing socket input and the number of threads doing socket output.
- IO_WRITE_THROUGH_ENABLED - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Optimization that allows sending of packets over the network to be done on the calling thread if the conditions are right.
- IO_WRITE_THROUGH_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Optimization that allows sending of packets over the network to be done on the calling thread if the conditions are right.
- IPermissionPolicy - Interface in com.hazelcast.security
-
IPermissionPolicy is used to determine any
Subject
's permissions to perform a security sensitive Hazelcast operation. - IQueue<E> - Interface in com.hazelcast.collection
-
Concurrent, blocking, distributed, observable queue.
- is(String) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
- IS_CANCELLED - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- IS_DONE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- IS_EMPTY - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- IS_LOCKED - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- IS_SHUTDOWN - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- IS_USER_CANCELLED - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
-
Indicates whether the job was cancelled by the user.
- isAccessGranted(AuthorizationContext, String...) - Method in interface com.hazelcast.access.AccessControlService
-
Returns
true
when access to resource described in theAuthorizationContext
should be granted to assigned roles. - isAllowOverrideDefaultSerializers() - Method in class com.hazelcast.config.SerializationConfig
- isAllowUnsafe() - Method in class com.hazelcast.config.SerializationConfig
-
Unsafe, it is not public api of java.
- isArrayType() - Method in enum class com.hazelcast.nio.serialization.FieldType
- isAssignedToMember() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
- isAssignedToPartition() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
- isAsyncFillup() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
True if the replicated map is available for reads before the initial replication is completed, false otherwise.
- isAsyncStart() - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
-
Client instance creation won't block on
HazelcastClient.newHazelcastClient()
if this value is true - isAuthenticationConfigured() - Method in class com.hazelcast.config.security.RealmConfig
- isAutoDetectionApplicable() - Method in class com.hazelcast.aws.AwsDiscoveryStrategyFactory
-
Checks if Hazelcast is running on an AWS EC2 instance.
- isAutoDetectionApplicable() - Method in class com.hazelcast.azure.AzureDiscoveryStrategyFactory
-
Checks if Hazelcast is running on Azure.
- isAutoDetectionApplicable() - Method in class com.hazelcast.gcp.GcpDiscoveryStrategyFactory
-
Checks if Hazelcast is running on GCP.
- isAutoDetectionApplicable() - Method in class com.hazelcast.kubernetes.HazelcastKubernetesDiscoveryStrategyFactory
-
In all Kubernetes environments the file "/var/run/secrets/kubernetes.io/serviceaccount/token" is injected into the container.
- isAutoDetectionApplicable() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategyFactory
-
Checks whether the given discovery strategy may be applied with no additional config to the environment in which Hazelcast is currently running.
- isAutoDetectionEnabled() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Any other connect configuration takes precedence over auto-discovery, so auto-discovery is enabled only when no other strategy is enabled.
- isAutoDetectionEnabled() - Method in class com.hazelcast.config.JoinConfig
-
Any other join configuration takes precedence over auto-discovery, so auto-discovery is enabled only when no other join strategy is enabled.
- isAutoDetectionEnabled() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
- isAutoRemoveStaleData() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Deprecated.Returns whether automatic removal of stale Hot Restart data is enabled.
- isAutoRemoveStaleData() - Method in class com.hazelcast.config.PersistenceConfig
-
Returns whether automatic removal of stale Persistence restart data is enabled.
- isAutoScaling() - Method in class com.hazelcast.jet.config.JobConfig
-
Returns whether auto-scaling is enabled, see
JobConfig.setAutoScaling(boolean)
. - isAvailable(Tenantable) - Method in interface com.hazelcast.spi.tenantcontrol.TenantControl
-
Checks if the tenant app is loaded and classes are available for the given
Tenantable
object. - isBackupAckToClientEnabled() - Method in class com.hazelcast.client.config.ClientConfig
-
Note that backup acks to client can be enabled only for all members routing client.
- isBackupEnabled() - Method in interface com.hazelcast.persistence.PersistenceService
-
Returns if backup is enabled.
- isBetween(Version, Version) - Method in class com.hazelcast.version.Version
-
Checks if the version is between specified version (both ends inclusive)
- isBinary() - Method in class com.hazelcast.config.MultiMapConfig
-
Checks if the MultiMap is in binary (serialized) form.
- isCacheLocalEntries() - Method in class com.hazelcast.config.NearCacheConfig
-
Checks if local entries are also cached in the Near Cache.
- isCatalogPersistenceEnabled() - Method in class com.hazelcast.config.SqlConfig
-
Returns
true
if persistence is enabled for SQL Catalog. - isCheckClassDefErrors() - Method in class com.hazelcast.config.SerializationConfig
-
Default value is
true
(enabled). - IScheduledExecutorService - Interface in com.hazelcast.scheduledexecutor
-
Distributed & durable implementation similar to, but not directly inherited
ScheduledExecutorService
. - IScheduledFuture<V> - Interface in com.hazelcast.scheduledexecutor
-
A delayed result-bearing action that can be cancelled.
- isClassArchive() - Method in enum class com.hazelcast.jet.config.ResourceType
-
Returns whether this resource type represents an archive containing classes.
- isClassesAlwaysAvailable() - Method in interface com.hazelcast.spi.tenantcontrol.TenantControlFactory
-
If the method returns false (classes are not always available), all objects, e.g.
- isClusterSafe() - Method in interface com.hazelcast.partition.PartitionService
-
Checks whether the cluster is in a safe state.
- isCoalesce() - Method in class com.hazelcast.config.QueryCacheConfig
-
Returns
true
if coalescing is enabled, otherwise returnsfalse
. - isConsoleEnabled() - Method in class com.hazelcast.config.ManagementCenterConfig
-
Returns if executing console commands is allowed (
true
) or disallowed (false
). - isCooperative() - Method in interface com.hazelcast.jet.core.Processor
-
Tells whether this processor is able to participate in cooperative multithreading.
- isCooperative() - Method in class com.hazelcast.jet.pipeline.ServiceFactory
-
Returns the
isCooperative
flag, seeServiceFactory.toNonCooperative()
. - isCPDirectToLeaderRoutingEnabled() - Method in class com.hazelcast.client.config.ClientConfig
-
Returns whether CP direct-to-leader operation sending is enabled for this client.
- isDataAccessEnabled() - Method in class com.hazelcast.config.ManagementCenterConfig
-
Returns if Management Center is allowed to access contents of Hazelcast data structures (for instance map entries) (
true
) or disallowed (false
). - isDefaultsDisabled() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
- isDeny() - Method in class com.hazelcast.config.PermissionConfig
-
Returns
true
when the permission should be subtracted (denied) instead of added (granted). - isDestroyed() - Method in interface com.hazelcast.cache.ICache
-
Determines whether this Cache instance has been destroyed.
- isDisablePerEntryInvalidationEvents() - Method in class com.hazelcast.config.CacheConfig
-
Returns invalidation events disabled status for per entry.
- isDisablePerEntryInvalidationEvents() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Returns invalidation events disabled status for per entry.
- isDiscoveryCompleted() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
-
Returns whether the CP discovery process is completed or not.
- isDistributed() - Method in class com.hazelcast.jet.core.Edge
-
Says whether this edge distributes items among all members, as requested by the
Edge.distributed()
method. - isDone() - Method in enum class com.hazelcast.persistence.BackupTaskState
-
Returns true if the backup task completed (successfully or with failure)
- isEarly() - Method in class com.hazelcast.jet.datamodel.WindowResult
-
Returns whether this is an early window result, to be followed by the final one.
- isEchoFailFastOnStartup() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
- ISemaphore - Interface in com.hazelcast.cp
-
ISemaphore is a fault-tolerant distributed alternative to the
Semaphore
. - isEmpty() - Method in class com.hazelcast.config.ClassFilter
- isEmpty() - Method in class com.hazelcast.jet.core.AppendableTraverser
- isEmpty() - Method in interface com.hazelcast.jet.core.Inbox
-
Returns
true
if this inbox contains no elements,false
otherwise. - isEmpty() - Method in class com.hazelcast.jet.core.test.TestInbox
- isEmpty() - Method in interface com.hazelcast.jet.pipeline.Pipeline
-
Returns
true
if there are no stages in the pipeline. - isEmpty() - Method in interface com.hazelcast.map.BaseMap
-
Returns
true
if this map contains no entries. - isEmpty() - Method in interface com.hazelcast.map.QueryCache
- isEmpty() - Method in interface com.hazelcast.transaction.TransactionalMap
-
Transactional implementation of
Map.isEmpty()
. - isEnableCompression() - Method in class com.hazelcast.config.SerializationConfig
-
Enables compression when default java serialization is used.
- isEnabled() - Method in class com.hazelcast.client.config.ClientCloudConfig
- isEnabled() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
- isEnabled() - Method in class com.hazelcast.client.config.ClientTpcConfig
-
Returns if the TPC-aware mode is enabled.
- isEnabled() - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
-
Deprecated.
- isEnabled() - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
-
Returns if this configuration is enabled.
- isEnabled() - Method in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
-
Returns if this configuration is enabled.
- isEnabled() - Method in class com.hazelcast.config.AdvancedNetworkConfig
- isEnabled() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
-
Checks whether the given join mechanism is enabled.
- isEnabled() - Method in class com.hazelcast.config.AutoDetectionConfig
-
Checks whether the auto-detection mechanism is enabled.
- isEnabled() - Method in class com.hazelcast.config.BaseMetricsConfig
-
Returns if metrics collection is enabled.
- isEnabled() - Method in class com.hazelcast.config.DataPersistenceConfig
-
Returns whether persistence enabled on related data structure.
- isEnabled() - Method in class com.hazelcast.config.DiscoveryConfig
- isEnabled() - Method in class com.hazelcast.config.DiskTierConfig
-
Returns whether disk tier is enabled on the related tiered-store.
- isEnabled() - Method in class com.hazelcast.config.EventJournalConfig
-
Returns if the event journal is enabled.
- isEnabled() - Method in class com.hazelcast.config.HotRestartConfig
-
Deprecated.Returns whether hot restart enabled on related data structure.
- isEnabled() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Deprecated.Returns whether hot restart enabled on this member.
- isEnabled() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
- isEnabled() - Method in class com.hazelcast.config.InstanceTrackingConfig
-
Returns
true
if instance tracking is enabled. - isEnabled() - Method in class com.hazelcast.config.IntegrityCheckerConfig
-
Returns {true} if the integrity checker is enabled.
- isEnabled() - Method in class com.hazelcast.config.InterfacesConfig
- isEnabled() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns if this configuration is enabled
- isEnabled() - Method in class com.hazelcast.config.MemberAddressProviderConfig
- isEnabled() - Method in class com.hazelcast.config.MemcacheProtocolConfig
-
Returns if MEMCACHE protocol support is enabled.
- isEnabled() - Method in class com.hazelcast.config.MerkleTreeConfig
-
Deprecated.use
MerkleTreeConfig.getEnabled()
instead. - isEnabled() - Method in class com.hazelcast.config.MetricsJmxConfig
-
Returns whether metrics will be exposed through JMX MBeans.
- isEnabled() - Method in class com.hazelcast.config.MetricsManagementCenterConfig
-
Returns whether metrics will be exposed to Hazelcast Management Center.
- isEnabled() - Method in class com.hazelcast.config.MulticastConfig
-
Check if the multicast discovery mechanism has been enabled.
- isEnabled() - Method in class com.hazelcast.config.NativeMemoryConfig
-
Returns
true
if native memory allocation is enabled,false
otherwise. - isEnabled() - Method in class com.hazelcast.config.NearCachePreloaderConfig
- isEnabled() - Method in class com.hazelcast.config.PartitionGroupConfig
-
Checks if this PartitionGroupConfig is enabled.
- isEnabled() - Method in class com.hazelcast.config.PersistenceConfig
-
Returns whether persistence enabled on this member.
- isEnabled() - Method in class com.hazelcast.config.PersistentMemoryConfig
-
Returns if the persistent memory is enabled.
- isEnabled() - Method in class com.hazelcast.config.QueueStoreConfig
-
Returns
true
if the queue store is enabled,false
otherwise. - isEnabled() - Method in class com.hazelcast.config.rest.RestConfig
-
Checks if the RestConfig is enabled.
- isEnabled() - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Return whether to enable SSL support.
- isEnabled() - Method in class com.hazelcast.config.RestApiConfig
-
Deprecated.Checks if REST API access is enabled.
- isEnabled() - Method in class com.hazelcast.config.RingbufferStoreConfig
- isEnabled() - Method in class com.hazelcast.config.SecurityConfig
- isEnabled() - Method in class com.hazelcast.config.ServiceConfig
- isEnabled() - Method in class com.hazelcast.config.SocketInterceptorConfig
-
Returns if this configuration is enabled.
- isEnabled() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
- isEnabled() - Method in class com.hazelcast.config.TcpIpConfig
-
Checks if the Tcp/Ip join mechanism is enabled.
- isEnabled() - Method in class com.hazelcast.config.TieredStoreConfig
-
Returns whether tiered-store is enabled on the related data structure.
- isEnabled() - Method in class com.hazelcast.config.tpc.TpcConfig
-
Gets the enabled flag which defines TPC is enabled or not.
- isEnabled() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Deprecated.Returns true if User Code Deployment is enabled
- isEnabled() - Method in class com.hazelcast.config.UserCodeNamespacesConfig
- isEnabled() - Method in class com.hazelcast.jet.config.JetConfig
-
Returns if Jet is enabled
- isEnabledAndNotEmpty() - Method in class com.hazelcast.config.RestApiConfig
-
Deprecated.Return true if the REST API is enabled and at least one REST endpoint group is allowed.
- isEnabledAndNotEmpty() - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.Return true if the REST API is enabled and at least one REST endpoint group is allowed.
- isEnabledByDefault() - Method in enum class com.hazelcast.config.RestEndpointGroup
-
Deprecated.Returns if this group is enabled by default.
- isEnabledSet() - Method in class com.hazelcast.config.MerkleTreeConfig
-
Method introduced for client protocol compatibility.
- isEnableSharedObject() - Method in class com.hazelcast.config.SerializationConfig
-
Enables shared object when default java serialization is used.
- isEnqueueNewEvents() - Method in enum class com.hazelcast.wan.WanPublisherState
-
Returns
true
if this state allows enqueueing new events,false
otherwise. - isEqual(Object) - Static method in interface com.hazelcast.function.PredicateEx
-
Serializable
variant of - isEqualTo(Version) - Method in class com.hazelcast.version.Version
- ISet<E> - Interface in com.hazelcast.collection
-
Concurrent, distributed implementation of
Set
- isEverPerformed() - Method in enum class com.hazelcast.jet.mongodb.ResourceChecks
- isExistingTransaction(Object) - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
- isExpired(long) - Method in interface com.hazelcast.cp.session.CPSession
-
Returns true if the session expires before the given timestamp.
- isFailFastOnStartup() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
- isFailOnIndeterminateOperationState() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Returns the value to determine if CP Subsystem API calls will fail when result of an API call becomes indeterminate.
- isFineEnabled() - Method in class com.hazelcast.logging.AbstractLogger
- isFinestEnabled() - Method in class com.hazelcast.logging.AbstractLogger
- isFsync() - Method in class com.hazelcast.config.DataPersistenceConfig
-
Returns whether disk write should be followed by an
fsync()
system call. - isFsync() - Method in class com.hazelcast.config.HotRestartConfig
-
Deprecated.Returns whether disk write should be followed by an
fsync()
system call. - isGlobalOrderingEnabled() - Method in class com.hazelcast.config.TopicConfig
-
Checks if global ordering is enabled (all nodes listening to the same topic get their messages in the same order), or disabled (nodes get the messages in the order that the messages are published).
- isGreaterOrEqual(Version) - Method in class com.hazelcast.version.Version
- isGreaterThan(Version) - Method in class com.hazelcast.version.Version
- isGroupEnabled(RestEndpointGroup) - Method in class com.hazelcast.config.RestApiConfig
-
Deprecated.Checks if given REST endpoint group is enabled.
- isGroupEnabled(RestEndpointGroup) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.Checks if given REST endpoint group is enabled.
- isHotBackupEnabled() - Method in interface com.hazelcast.hotrestart.HotRestartService
-
Deprecated.since 5.0 Use
PersistenceService.isBackupEnabled()
instead. - isIdentityConfigured() - Method in class com.hazelcast.config.security.RealmConfig
- isIncludeValue() - Method in class com.hazelcast.config.EntryListenerConfig
- isIncludeValue() - Method in class com.hazelcast.config.ItemListenerConfig
- isIncludeValue() - Method in class com.hazelcast.config.ListenerConfig
- isIncludeValue() - Method in class com.hazelcast.config.QueryCacheConfig
-
Returns
true
if value caching enabled, otherwise returnsfalse
. - isIncludeValue() - Method in class com.hazelcast.config.SplitBrainProtectionListenerConfig
- isIncludeValue() - Method in interface com.hazelcast.vector.SearchOptions
- isIncludeVectors() - Method in interface com.hazelcast.vector.SearchOptions
- isInfoEnabled() - Method in class com.hazelcast.logging.AbstractLogger
- isInstanceTrackingEnabledSet(Config) - Static method in class com.hazelcast.config.ConfigAccessor
- isInvalidateOnChange() - Method in class com.hazelcast.config.NearCacheConfig
-
Checks if Near Cache entries are invalidated when the entries in the backing data structure are changed (updated or removed).
- isIPv4() - Method in class com.hazelcast.cluster.Address
- isIPv6() - Method in class com.hazelcast.cluster.Address
- isJDKCompatible() - Method in class com.hazelcast.config.cp.SemaphoreConfig
-
Returns true if CP ISemaphore is compatible with its JDK counterpart
- isJoinAllowed() - Method in enum class com.hazelcast.cluster.ClusterState
-
Returns
true
, if joining of a new member is allowed in this state. - isKeepAlive() - Method in class com.hazelcast.client.config.SocketOptions
-
SO_KEEPALIVE socket option
- isLessOrEqual(Version) - Method in class com.hazelcast.version.Version
- isLessThan(Version) - Method in class com.hazelcast.version.Version
- isLightJob() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
-
Returns if this job runs as a light job, see
JetService.newLightJob(Pipeline)
. - isLightJob() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
- isLightJob() - Method in interface com.hazelcast.jet.Job
-
Returns
true
if this instance represents a light job. - isListed(String) - Method in class com.hazelcast.config.ClassFilter
- isLiteMember() - Method in interface com.hazelcast.cluster.Member
-
Returns true if this member is a lite member.
- isLiteMember() - Method in class com.hazelcast.config.Config
-
Returns
true
if this member is a lite member. - isLocal() - Method in interface com.hazelcast.config.DeviceConfig
-
Returns
true
if the device configuration is for a local device, otherwise, returnsfalse
if this configuration is for a remote device. - isLocal() - Method in class com.hazelcast.config.EntryListenerConfig
- isLocal() - Method in class com.hazelcast.config.ListenerConfig
- isLocal() - Method in class com.hazelcast.config.LocalDeviceConfig
-
Returns
true
sincethis
is a configuration for a local device. - isLocal() - Method in class com.hazelcast.config.SplitBrainProtectionListenerConfig
- isLocal() - Method in class com.hazelcast.jet.core.Edge
-
Returning if the edge is local.
- isLocalMemberSafe() - Method in interface com.hazelcast.partition.PartitionService
-
Checks whether local member is in safe state.
- isLocked() - Method in interface com.hazelcast.cp.lock.FencedLock
-
Returns whether this lock is locked or not.
- isLocked() - Method in interface com.hazelcast.map.LockAware
- isLocked(K) - Method in interface com.hazelcast.map.IMap
-
Checks the lock for the specified key.
- isLocked(K) - Method in interface com.hazelcast.multimap.MultiMap
-
Checks the lock for the specified key.
- isLockedByCurrentThread() - Method in interface com.hazelcast.cp.lock.FencedLock
-
Returns whether the lock is held by the current thread or not.
- isLoggable(Level) - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
- isLoopbackModeEnabled() - Method in class com.hazelcast.config.MulticastConfig
-
Deprecated.
- isLosslessRestartEnabled() - Method in class com.hazelcast.jet.config.InstanceConfig
-
Deprecated.Returns if lossless restart is enabled, see
InstanceConfig.setLosslessRestartEnabled(boolean)
. - isLosslessRestartEnabled() - Method in class com.hazelcast.jet.config.JetConfig
-
Returns if lossless restart is enabled, see
JetConfig.setLosslessRestartEnabled(boolean)
. - isLossTolerant() - Method in interface com.hazelcast.topic.ReliableMessageListener
-
Checks if this ReliableMessageListener is able to deal with message loss.
- isMajorityAvailable() - Method in interface com.hazelcast.cp.event.CPGroupAvailabilityEvent
-
Returns whether this group has the majority of its members available or not.
- isManagementEnabled - Variable in class com.hazelcast.config.AbstractCacheConfig
-
Whether management is enabled
- isManagementEnabled() - Method in class com.hazelcast.config.AbstractCacheConfig
- isManagementEnabled() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Checks if management is enabled for this
ICache
. - isMemberSafe(Member) - Method in interface com.hazelcast.partition.PartitionService
-
Checks whether the given member is in safe state.
- isMetadataGroup() - Method in interface com.hazelcast.cp.event.CPGroupAvailabilityEvent
-
Returns whether this is the METADATA CP group or not.
- isMetricsEnabled() - Method in class com.hazelcast.jet.config.JobConfig
-
Returns if metrics collection is enabled for the job.
- isMigrationAllowed() - Method in enum class com.hazelcast.cluster.ClusterState
-
Returns
true
, if migrations and replications are allowed in this state. - isMultiline() - Method in class com.hazelcast.jet.pipeline.file.JsonFileFormat
-
Specifies if the Json parser should accept json records spanning multiple lines.
- isMultiThreadingEnabled() - Method in class com.hazelcast.config.TopicConfig
-
Checks if multithreaded processing of incoming messages is enabled or not.
- isNearCacheEnabled() - Method in class com.hazelcast.config.MapConfig
-
Checks if Near Cache is enabled.
- isNot(String) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
- isNotNull() - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
- isNull() - Method in interface com.hazelcast.cp.IAtomicReference
-
Checks if the stored reference is
null
. - isNull() - Method in class com.hazelcast.jet.accumulator.MutableReference
-
Tells whether the current value is
null
. - isNull() - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
- isNullable() - Method in class com.hazelcast.sql.SqlColumnMetadata
-
Gets column nullability.
- isNullAsync() - Method in interface com.hazelcast.cp.IAtomicReference
-
Checks if the stored reference is
null
. - isNumaNodeSet() - Method in class com.hazelcast.config.PersistentMemoryDirectoryConfig
-
Returns if the NUMA node for the given persistent memory directory is set.
- isOffload() - Method in class com.hazelcast.config.MapStoreConfig
-
Default value is true.
- isolated() - Method in class com.hazelcast.jet.core.Edge
-
Activates the
ISOLATED
routing policy which establishes isolated paths from upstream to downstream processors. - ISOLATED - Enum constant in enum class com.hazelcast.jet.core.Edge.RoutingPolicy
-
This policy sets up isolated parallel data paths between two vertices as much as it can, given the level of mismatch between the local parallelism (LP) of the upstream vs. the downstream vertices.
- isOldValueRequired() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
If old value is required, previously assigned values for the affected keys will be sent to this cache entry listener implementation.
- isOverrideJavaSerialization() - Method in class com.hazelcast.config.GlobalSerializerConfig
- isOverwritable() - Method in class com.hazelcast.jet.protobuf.ProtobufSerializerHook
- isOverwritable() - Method in interface com.hazelcast.nio.serialization.SerializerHook
-
Indicates if this serializer can be overridden by defining a custom serializer in the configurations (via code or configuration file)
- isParallelMode() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
- isParseDn() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
Deprecated.
- isPartitionPromotionAllowed() - Method in enum class com.hazelcast.cluster.ClusterState
-
Returns
true
, if partition promotions are allowed in this state. - isPerEntryStatsEnabled() - Method in class com.hazelcast.config.MapConfig
-
Checks if entry level statistics are enabled for this map.
- isPermissionPriorityGrant() - Method in class com.hazelcast.config.SecurityConfig
-
Returns
true
when grant permissions should take precedence over deny ones. - isPersistenceEnabled() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Returns whether CP Subsystem Persistence enabled on this member.
- isPersistenceEnabled() - Method in class com.hazelcast.config.DynamicConfigurationConfig
-
Returns whether Dynamic Configuration Persistence is enabled on this member.
- isPersistWanReplicatedData() - Method in class com.hazelcast.config.WanConsumerConfig
- isPopulate() - Method in class com.hazelcast.config.QueryCacheConfig
-
Returns
true
if initial population ofQueryCache
is enabled, otherwise returnsfalse
. - isPortAutoIncrement() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- isPortAutoIncrement() - Method in class com.hazelcast.config.NetworkConfig
-
Checks if a Hazelcast member is allowed find a free port by incrementing the port number when it encounters an occupied port.
- isPortAutoIncrement() - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
Checks if a Hazelcast member is allowed find a free port by incrementing the port number when it encounters an occupied port.
- isPresent() - Method in class com.hazelcast.splitbrainprotection.SplitBrainProtectionEvent
-
Returns the presence of the split brain protection
- isPresent(SearchOptions) - Method in record class com.hazelcast.vector.Hint
- isPreserveOrder() - Method in interface com.hazelcast.jet.pipeline.Pipeline
-
Returns the preserve order property of this pipeline
- isPriorityQueue() - Method in class com.hazelcast.config.QueueConfig
-
Check if underlying implementation is a
PriorityQueue
. - isReadBackupData() - Method in class com.hazelcast.config.MapConfig
-
Checks if read-backup-data (reading local backup entries) is enabled for this map.
- isReadThrough - Variable in class com.hazelcast.config.AbstractCacheConfig
-
A flag indicating if "read-through" mode is required.
- isReadThrough() - Method in class com.hazelcast.config.AbstractCacheConfig
- isReadThrough() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Checks if this
ICache
is read-through: a read loads the entry from the data store if it is not already in the cache. - isRealm(String) - Method in class com.hazelcast.config.SecurityConfig
-
Returns if the given name is a valid realm name.
- isRecognized(ConfigStream) - Method in interface com.hazelcast.config.ConfigRecognizer
-
Recognizes the configuration given in the
configStream
argument. - isRedoOperation() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
See
ClientNetworkConfig.setRedoOperation(boolean)
for details - isReplicateEnqueuedEvents() - Method in enum class com.hazelcast.wan.WanPublisherState
-
Returns
true
if this state allows dequeueing and replicating events,false
otherwise. - isRepublishingEnabled() - Method in class com.hazelcast.config.WanReplicationRef
-
Returns
true
if incoming WAN events to this member should be republished (forwarded) to this WAN replication reference. - isResourceUploadEnabled() - Method in class com.hazelcast.jet.config.JetConfig
-
Returns if uploading resources when submitting the job enabled
- isReusable() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Returns
true
if the same instance can be reused in different job executions or in different vertices. - isReusable() - Method in class com.hazelcast.jet.core.ProcessorMetaSupplier.RandomMemberPms
- isReusable() - Method in class com.hazelcast.jet.core.ProcessorMetaSupplier.SpecificMemberPms
- isReuseAddress() - Method in class com.hazelcast.client.config.SocketOptions
-
SO_REUSEADDR socket option.
- isReuseAddress() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- isReuseAddress() - Method in class com.hazelcast.config.NetworkConfig
- isReuseAddress() - Method in class com.hazelcast.config.ServerSocketEndpointConfig
- isRowSet() - Method in interface com.hazelcast.sql.SqlResult
-
Return whether this result has rows to iterate using the
SqlResult.iterator()
method. - isRunning() - Method in class com.hazelcast.console.ConsoleApp
- isRunning() - Method in interface com.hazelcast.core.LifecycleService
-
Checks whether the instance is running.
- isScriptingEnabled() - Method in class com.hazelcast.config.ManagementCenterConfig
-
Returns if scripting is allowed (
true
) or disallowed (false
). - isSerializeKeys() - Method in class com.hazelcast.config.NearCacheConfig
-
Checks if the Near Cache key is stored in serialized format or by-reference.
- isSerializeKeys() - Method in class com.hazelcast.config.QueryCacheConfig
-
Checks if the
QueryCache
key is stored in serialized format or by-reference. - isSevereEnabled() - Method in class com.hazelcast.logging.AbstractLogger
- isShared() - Method in class com.hazelcast.config.DataConnectionConfig
-
true
if an instance of the data connection will be reused. - isSmartRouting() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Deprecated.since 5.5, this option is superseded by
ClusterRoutingConfig.getRoutingMode()
- isSnapshotEnabled() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns
true
if key-based coalescing is configured for this WAN publisher. - isSnapshotsEnabled() - Method in class com.hazelcast.jet.core.test.TestSupport.TestMode
-
Are snapshots enabled.
- isSocketBufferDirect() - Method in class com.hazelcast.config.EndpointConfig
- isSocketKeepAlive() - Method in class com.hazelcast.config.EndpointConfig
- isSocketTcpNoDelay() - Method in class com.hazelcast.config.EndpointConfig
- isSplitBrainProtectionEnabled() - Method in class com.hazelcast.jet.config.JobConfig
-
Tells whether
split brain protection
is enabled. - isStatisticsEnabled - Variable in class com.hazelcast.config.AbstractCacheConfig
-
A flag indicating if statistics gathering is enabled.
- isStatisticsEnabled() - Method in class com.hazelcast.config.AbstractCacheConfig
- isStatisticsEnabled() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Checks if statistics are enabled for this
ICache
. - isStatisticsEnabled() - Method in class com.hazelcast.config.CollectionConfig
-
Checks if collection statistics are enabled.
- isStatisticsEnabled() - Method in class com.hazelcast.config.DurableExecutorConfig
- isStatisticsEnabled() - Method in class com.hazelcast.config.ExecutorConfig
- isStatisticsEnabled() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
- isStatisticsEnabled() - Method in class com.hazelcast.config.MapConfig
-
Checks if statistics are enabled for this map.
- isStatisticsEnabled() - Method in class com.hazelcast.config.MultiMapConfig
-
Checks to see if statistics are enabled for this MultiMap.
- isStatisticsEnabled() - Method in class com.hazelcast.config.PNCounterConfig
-
Checks if statistics are enabled for this PN counter
- isStatisticsEnabled() - Method in class com.hazelcast.config.QueueConfig
-
Check if statistics are enabled for this queue.
- isStatisticsEnabled() - Method in class com.hazelcast.config.ReliableTopicConfig
-
Checks if statistics are enabled for this reliable topic.
- isStatisticsEnabled() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
Checks if statistics are enabled for this replicated map.
- isStatisticsEnabled() - Method in class com.hazelcast.config.ScheduledExecutorConfig
- isStatisticsEnabled() - Method in class com.hazelcast.config.TopicConfig
-
Checks if statistics are enabled for this topic.
- isStoreByValue - Variable in class com.hazelcast.config.AbstractCacheConfig
-
A flag indicating if the cache will be store-by-value or store-by-reference.
- isStoreByValue() - Method in class com.hazelcast.config.AbstractCacheConfig
- isStoreMetricsAfterJobCompletion() - Method in class com.hazelcast.jet.config.JobConfig
-
Returns whether metrics should be stored in the cluster after the job completes successfully.
- isSuccess() - Method in interface com.hazelcast.partition.ReplicaMigrationEvent
-
Returns the result of the migration: completed or failed.
- isSupported(OptionalFeature) - Method in class com.hazelcast.cache.HazelcastCachingProvider
- isSupported(OptionalFeature) - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
- isSupported(OptionalFeature) - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
- isSuspendOnFailure() - Method in class com.hazelcast.jet.config.JobConfig
-
Returns whether the job will be suspended on failure, see
JobConfig.setSuspendOnFailure(boolean)
. - isSynchronous() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
If
true
, this cache entry listener implementation will be called in a synchronous manner. - isTcpNoDelay() - Method in class com.hazelcast.client.config.SocketOptions
-
TCP_NODELAY socket option
- isTerminal() - Method in enum class com.hazelcast.jet.core.JobStatus
-
Returns
true
if this state is terminal - a job in this state will never have any other state and will never execute again. - isTerminal(Throwable) - Method in interface com.hazelcast.topic.ReliableMessageListener
-
Checks if the ReliableMessageListener should be terminated based on an exception thrown while calling
MessageListener.onMessage(Message)
. - isTumbling() - Method in class com.hazelcast.jet.core.SlidingWindowPolicy
-
Tells whether this definition describes a tumbling window.
- isUnknown() - Method in class com.hazelcast.version.MemberVersion
- isUnknown() - Method in class com.hazelcast.version.Version
- isUnknownOrGreaterOrEqual(Version) - Method in class com.hazelcast.version.Version
- isUnknownOrGreaterThan(Version) - Method in class com.hazelcast.version.Version
- isUnknownOrLessOrEqual(Version) - Method in class com.hazelcast.version.Version
- isUnknownOrLessThan(Version) - Method in class com.hazelcast.version.Version
- isUseDeduplication() - Method in class com.hazelcast.config.vector.VectorIndexConfig
-
Checks if deduplication is enabled.
- isUseEndpointPrivateAddress() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns whether the WAN connection manager should connect to the endpoint on the private address returned by the discovery SPI.
- isUseNativeByteOrder() - Method in class com.hazelcast.config.SerializationConfig
- isUsePublicIp() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
-
Checks whether the public or private IP should be used to connect to Hazelcast members.
- isUserCancelled() - Method in interface com.hazelcast.jet.Job
-
Returns true, if the job is user-cancelled.
- isUserRequested() - Method in class com.hazelcast.jet.JobStatusEvent
-
Indicates whether the event is generated by the user via
Job.suspend()
,Job.resume()
,Job.restart()
,Job.cancel()
,Job.exportSnapshot(String)
, orJob.cancelAndExportSnapshot(String)
. - isWarningEnabled() - Method in class com.hazelcast.logging.AbstractLogger
- isWriteCoalescing() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns
true
if write-coalescing is enabled. - isWriteThrough - Variable in class com.hazelcast.config.AbstractCacheConfig
-
A flag indicating if "write-through" mode is required.
- isWriteThrough() - Method in class com.hazelcast.config.AbstractCacheConfig
- isWriteThrough() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Checks if the
ICache
is write-through: a write to the queue also loads the entry into the data store. - item - Variable in class com.hazelcast.collection.ItemEvent
- item() - Method in class com.hazelcast.jet.datamodel.TimestampedItem
-
Returns the item.
- itemAdded(ItemEvent) - Method in class com.hazelcast.console.ConsoleApp
- itemAdded(ItemEvent<E>) - Method in interface com.hazelcast.collection.ItemListener
-
Invoked when an item is added.
- ItemEvent<E> - Class in com.hazelcast.collection
-
Event for a collection item.
- ItemEvent(String, ItemEventType, E, Member) - Constructor for class com.hazelcast.collection.ItemEvent
- ItemEventType - Enum Class in com.hazelcast.core
-
Type of item events.
- ItemListener<E> - Interface in com.hazelcast.collection
- ItemListenerConfig - Class in com.hazelcast.config
-
Contains the configuration for an Item Listener.
- ItemListenerConfig() - Constructor for class com.hazelcast.config.ItemListenerConfig
- ItemListenerConfig(ItemListener, boolean) - Constructor for class com.hazelcast.config.ItemListenerConfig
- ItemListenerConfig(ItemListenerConfig) - Constructor for class com.hazelcast.config.ItemListenerConfig
- ItemListenerConfig(String, boolean) - Constructor for class com.hazelcast.config.ItemListenerConfig
- itemRemoved(ItemEvent) - Method in class com.hazelcast.console.ConsoleApp
- itemRemoved(ItemEvent<E>) - Method in interface com.hazelcast.collection.ItemListener
-
Invoked when an item is removed.
- items(Iterable<? extends T>) - Static method in class com.hazelcast.jet.pipeline.test.TestSources
-
Returns a batch source which iterates through the supplied iterable and then terminates.
- items(T...) - Static method in class com.hazelcast.jet.pipeline.test.TestSources
-
Returns a batch source which iterates through the supplied items and then terminates.
- itemsByTag(Object...) - Static method in class com.hazelcast.jet.datamodel.ItemsByTag
-
Accepts an argument list of alternating tags and values, interprets them as a list of tag-value pairs, and returns an
ItemsByTag
populated with these pairs. - ItemsByTag - Class in com.hazelcast.jet.datamodel
-
A heterogeneous map from
Tag<E>
toE
, whereE
can be different for each tag. - ItemsByTag() - Constructor for class com.hazelcast.jet.datamodel.ItemsByTag
- itemsDistributed(Iterable<? extends T>) - Static method in class com.hazelcast.jet.pipeline.test.TestSources
-
Returns a batch source which iterates through the supplied iterable and then terminates.
- itemsDistributed(T...) - Static method in class com.hazelcast.jet.pipeline.test.TestSources
-
Returns a batch source which iterates through the supplied items and then terminates.
- itemStream(int) - Static method in class com.hazelcast.jet.pipeline.test.TestSources
-
Returns a streaming source that generates events of type
SimpleEvent
at the specified rate. - itemStream(int, GeneratorFunction<? extends T>) - Static method in class com.hazelcast.jet.pipeline.test.TestSources
-
Returns a streaming source that generates events created by the
generatorFn
at the specified rate. - iterator() - Method in class com.hazelcast.jet.core.DAG
-
Validates the DAG and returns an iterator over the DAG's vertices in topological order.
- iterator() - Method in interface com.hazelcast.jet.core.Inbox
-
Returns an iterator over the items in the inbox in the order they would be returned by the
Inbox.poll()
method. - iterator() - Method in class com.hazelcast.jet.core.metrics.JobMetrics
-
Returns an iterator over the metrics.
- iterator() - Method in class com.hazelcast.jet.core.test.TestInbox
- iterator() - Method in interface com.hazelcast.jet.Observable
-
Returns an iterator over the sequence of events produced by this
Observable
. - iterator() - Method in interface com.hazelcast.map.IMap
-
Returns an iterator over the entries of the map.
- iterator() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
-
Returns a read-only iterator.
- iterator() - Method in interface com.hazelcast.spi.partitiongroup.MemberGroup
- iterator() - Method in interface com.hazelcast.sql.SqlResult
-
Returns the iterator over the result rows.
- iterator(int) - Method in interface com.hazelcast.cache.ICache
-
Creates and returns a cluster wide iterator to iterate on all entries owned by this cache.
- iterator(int) - Method in interface com.hazelcast.map.IMap
-
Returns an iterator over the entries of the map.
- ITERATOR - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- ITERATOR_FETCH_ENTRIES - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- ITERATOR_FETCH_KEYS - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- ITERATOR_FETCH_WITH_QUERY - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- ITopic<E> - Interface in com.hazelcast.topic
-
Hazelcast provides distribution mechanism for publishing messages that are delivered to multiple subscribers, which is also known as a publish/subscribe (pub/sub) messaging model.
J
- JaasAuthenticationConfig - Class in com.hazelcast.config.security
-
This
AuthenticationConfig
implementation is a imple holder for login module configurations. - JaasAuthenticationConfig() - Constructor for class com.hazelcast.config.security.JaasAuthenticationConfig
- JAR - Enum constant in enum class com.hazelcast.jet.config.ResourceType
-
Represents a JAR file whose classes will be on the classpath of the Jet job.
- JAR_UPLOAD_DIR_PATH - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The directory path to be used for jar uploading.
- JARS_IN_ZIP - Enum constant in enum class com.hazelcast.jet.config.ResourceType
-
Represents a ZIP file that contains JAR files, all of whose classes will be on the classpath of the Jet job.
- JavaKeyStoreSecureStoreConfig - Class in com.hazelcast.config
-
Java KeyStore Secure Store configuration.
- JavaKeyStoreSecureStoreConfig() - Constructor for class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
-
Creates a new Java KeyStore Secure Store configuration.
- JavaKeyStoreSecureStoreConfig(File) - Constructor for class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
-
Creates a new Java KeyStore Secure Store configuration.
- JavaSerializationFilterConfig - Class in com.hazelcast.config
-
Configuration for Serialization Filters and Reflection Filters.
- JavaSerializationFilterConfig() - Constructor for class com.hazelcast.config.JavaSerializationFilterConfig
- JavaSerializationFilterConfig(JavaSerializationFilterConfig) - Constructor for class com.hazelcast.config.JavaSerializationFilterConfig
- JCACHE_PROVIDER_TYPE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Forces the JCache provider, which can have values client or server, to force the provider type.
- jdbc(SupplierEx<? extends Connection>, ToResultSetFunction, FunctionEx<? super ResultSet, ? extends T>) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Returns a source which connects to the specified database using the given
newConnectionFn
, queries the database and creates a result set using the givenresultSetFn
. - jdbc(DataConnectionRef, ToResultSetFunction, FunctionEx<? super ResultSet, ? extends T>) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Returns a source which connects to the specified database using the given
dataConnectionRef
, queries the database and creates a result set using the givenresultSetFn
. - jdbc(String, SupplierEx<? extends CommonDataSource>, BiConsumerEx<PreparedStatement, T>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
A shortcut for:
- jdbc(String, DataConnectionRef, BiConsumerEx<PreparedStatement, T>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
A shortcut for:
- jdbc(String, String, BiConsumerEx<PreparedStatement, T>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
A shortcut for:
- jdbc(String, String, FunctionEx<? super ResultSet, ? extends T>) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Convenience for
Sources.jdbc(SupplierEx, ToResultSetFunction, FunctionEx)
. - jdbc(String, String, Properties, FunctionEx<? super ResultSet, ? extends T>) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Same as @{link
Sources.jdbc(String, String, FunctionEx)
} - jdbcBuilder() - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a builder to build a sink that connects to a JDBC database, prepares an SQL statement and executes it for each item.
- JdbcPropertyKeys - Class in com.hazelcast.jet.pipeline
-
This class defines property keys that can be passed to JDBC connector.
- JdbcSinkBuilder<T> - Class in com.hazelcast.jet.pipeline
-
See
Sinks.jdbcBuilder()
. - jdbcUrl(String) - Method in class com.hazelcast.jet.pipeline.JdbcSinkBuilder
-
Sets the connection URL for the target database.
- Jet - Class in com.hazelcast.jet
-
Deprecated.After 5.0 Jet was merged into core Hazelcast product. Use the
Hazelcast
class as the entry point. - JET - Enum constant in enum class com.hazelcast.config.AbstractXmlConfigBuilder.ConfigType
- JET_IDLE_COOPERATIVE_MAX_MICROSECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The maximum time in microseconds the cooperative worker threads will sleep if none of the tasklets made any progress.
- JET_IDLE_COOPERATIVE_MIN_MICROSECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The minimum time in microseconds the cooperative worker threads will sleep if none of the tasklets made any progress.
- JET_IDLE_NONCOOPERATIVE_MAX_MICROSECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The maximum time in microseconds the non-cooperative worker threads will sleep if none of the tasklets made any progress.
- JET_IDLE_NONCOOPERATIVE_MIN_MICROSECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The minimum time in microseconds the non-cooperative worker threads will sleep if none of the tasklets made any progress.
- JET_SQL_ROW - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
- JetAssert - Class in com.hazelcast.jet.core.test
-
Assert methods that throw exceptions similar to those thrown by JUnit.
- JetBeanDefinitionParser - Class in com.hazelcast.spring.jet
-
Bean definition parser for
JetService
. - JetBeanDefinitionParser() - Constructor for class com.hazelcast.spring.jet.JetBeanDefinitionParser
- JetCacheManager - Interface in com.hazelcast.jet
-
Deprecated.since 5.0 Use
ICacheManager
instead. - JetConfig - Class in com.hazelcast.jet.config
-
Configuration object for a Jet instance.
- JetConfig() - Constructor for class com.hazelcast.jet.config.JetConfig
-
Creates a new, empty
JetConfig
with the default configuration. - JetConfigDataSerializerHook - Class in com.hazelcast.jet.config
-
Hazelcast serializer hooks for the classes in the
com.hazelcast.jet.config
package. - JetConfigDataSerializerHook() - Constructor for class com.hazelcast.jet.config.JetConfigDataSerializerHook
- JetDataSerializerHook - Class in com.hazelcast.jet.core
-
A Java Service Provider hook for Hazelcast's Identified Data Serializable mechanism.
- JetDataSerializerHook() - Constructor for class com.hazelcast.jet.core.JetDataSerializerHook
- JetException - Exception in com.hazelcast.jet
-
Base Jet exception.
- JetException() - Constructor for exception com.hazelcast.jet.JetException
- JetException(String) - Constructor for exception com.hazelcast.jet.JetException
- JetException(String, Throwable) - Constructor for exception com.hazelcast.jet.JetException
- JetException(Throwable) - Constructor for exception com.hazelcast.jet.JetException
- jetInstance() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
-
Deprecated.Use
hazelcastInstance().getJet()
instead. - jetInstance() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
-
Deprecated.
- JetInstance - Interface in com.hazelcast.jet
-
Deprecated.After 5.0 Jet was merged into core Hazelcast product. Jet became a service of Hazelcast instead of being an instance of its own that encapsulates
HazelcastInstance
. Please useJetService
instead. - JetMemberSelector - Interface in com.hazelcast.jet
-
Selects the members on which a specific job will run.
- JetService - Interface in com.hazelcast.jet
-
Jet is a component of Hazelcast to execute streaming or batch computations.
- JetService.JobBuilder - Interface in com.hazelcast.jet
- JetSpringServiceFactories - Class in com.hazelcast.spring.jet
-
Utility class with methods that create several useful Spring Bean
service factories
and transform functions. - jmsQueue(SupplierEx<? extends ConnectionFactory>, String) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Deprecated.
- jmsQueue(String, SupplierEx<? extends ConnectionFactory>) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Shortcut equivalent to:
- jmsQueue(String, SupplierEx<ConnectionFactory>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Convenience for
Sinks.jmsQueueBuilder(SupplierEx)
. - jmsQueueBuilder(SupplierEx<? extends ConnectionFactory>) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Returns a builder object that offers a step-by-step fluent API to build a custom JMS
StreamSource
for the Pipeline API. - jmsQueueBuilder(SupplierEx<ConnectionFactory>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a builder object that offers a step-by-step fluent API to build a custom JMS queue sink for the Pipeline API.
- JmsSinkBuilder<T> - Class in com.hazelcast.jet.pipeline
- JmsSourceBuilder - Class in com.hazelcast.jet.pipeline
- jmsTopic(SupplierEx<? extends ConnectionFactory>, String) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Deprecated.
- jmsTopic(String, SupplierEx<? extends ConnectionFactory>) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Shortcut equivalent to:
- jmsTopic(String, SupplierEx<ConnectionFactory>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Shortcut for:
- jmsTopicBuilder(SupplierEx<? extends ConnectionFactory>) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Returns a builder object that offers a step-by-step fluent API to build a custom JMS
StreamSource
for the Pipeline API. - jmsTopicBuilder(SupplierEx<ConnectionFactory>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a builder object that offers a step-by-step fluent API to build a custom JMS topic sink for the Pipeline API.
- JMX_UPDATE_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Some JMX MBeans are cached (e.g. map, multimap, queue and replicated map) to reduce the overhead of calculating statistics.
- jmxConfig - Variable in class com.hazelcast.config.BaseMetricsConfig
- Job - Interface in com.hazelcast.jet
- JOB - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
-
Jet Job permission
- JOB - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
-
Unique ID of the job (sourcing the metric), example value would be a numerical (long) ID encoded in a human-readable form, like
"2f7f-d88a-4669-6195"
, seeUtil.idToString(long)
)} for details. - JOB_CONFIG - Static variable in class com.hazelcast.jet.config.JetConfigDataSerializerHook
-
Serialization ID of the
JobConfig
class. - JOB_EXECUTIONS_COMPLETED - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
-
Number of job executions finished on the Jet cluster.
- JOB_EXECUTIONS_STARTED - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
-
Number of job executions started on the Jet cluster.
- JOB_METRICS - Static variable in class com.hazelcast.jet.core.metrics.MetricsDataSerializerHook
-
Serialization ID of the
JobMetrics
class. - JOB_NAME - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
-
Job name, or job ID if no name is specified.
- JOB_RESULTS_MAX_SIZE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Maximum number of job results to keep in the cluster, the oldest results will be automatically deleted after this size is reached.
- JOB_RESULTS_TTL_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Maximum number of time in seconds the job results will be kept in the cluster.
- JOB_SCAN_PERIOD - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Jet will periodically check for new jobs to start and perform cleanup of unused resources.
- JOB_STATUS - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
-
Numerical ID of the job's status.
- JOB_UPLOAD_PART_SIZE - Static variable in class com.hazelcast.client.properties.ClientProperty
-
The default size of multipart job upload
- JobAlreadyExistsException - Exception in com.hazelcast.jet
-
Thrown when a named job is submitted while there is an active job with the same name.
- JobAlreadyExistsException() - Constructor for exception com.hazelcast.jet.JobAlreadyExistsException
-
Creates the exception
- JobAlreadyExistsException(String) - Constructor for exception com.hazelcast.jet.JobAlreadyExistsException
-
Creates the exception with a message.
- JobAlreadyExistsException(String, Throwable) - Constructor for exception com.hazelcast.jet.JobAlreadyExistsException
-
Creates the exception with a message and a cause.
- JobClassLoaderFactory - Interface in com.hazelcast.jet.config
-
An interface that can be implemented to provide custom class loader for Jet job.
- jobConfig() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
-
Returns the
JobConfig
. - jobConfig() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
- jobConfig(JobConfig) - Method in class com.hazelcast.jet.core.test.TestSupport
-
Use the given instance for
ProcessorMetaSupplier.Context.jobConfig()
- JobConfig - Class in com.hazelcast.jet.config
-
Contains the configuration specific to one Hazelcast Jet job.
- JobConfig() - Constructor for class com.hazelcast.jet.config.JobConfig
- JobConfigArguments - Class in com.hazelcast.jet.config
-
Some constants for the
JobConfig.getArgument(String)
method. - jobId() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
-
Returns the job ID.
- jobId() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
- jobId() - Method in class com.hazelcast.jet.JobStateSnapshot
-
Returns the job ID of the job the snapshot was originally exported from.
- JobMetrics - Class in com.hazelcast.jet.core.metrics
-
An immutable collection of job-specific metrics, pairs of metric names and sets of associated
Measurement
s. - jobName() - Method in class com.hazelcast.jet.JobStateSnapshot
-
Returns the job name of the job the snapshot was originally exported from.
- JobNotFoundException - Exception in com.hazelcast.jet.core
-
Thrown when a job could not be found on the master node
- JobNotFoundException(long) - Constructor for exception com.hazelcast.jet.core.JobNotFoundException
- JobNotFoundException(String) - Constructor for exception com.hazelcast.jet.core.JobNotFoundException
- JobNotFoundException(String, Throwable) - Constructor for exception com.hazelcast.jet.core.JobNotFoundException
- JobPermission - Class in com.hazelcast.security.permission
- JobPermission(String...) - Constructor for class com.hazelcast.security.permission.JobPermission
- JOBS_COMPLETED_SUCCESSFULLY - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
-
Number of jobs successfully completed by the Jet cluster.
- JOBS_COMPLETED_WITH_FAILURE - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
-
Number of jobs that have failed on the Jet cluster.
- JOBS_SUBMITTED - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
-
Number of jobs submitted to the Jet cluster.
- JobStateSnapshot - Class in com.hazelcast.jet
-
A handle to an exported state snapshot created using
Job.exportSnapshot(String)
. - JobStateSnapshot(HazelcastInstance, String, SnapshotValidationRecord) - Constructor for class com.hazelcast.jet.JobStateSnapshot
-
This constructor is a private API, use
JetService.getJobStateSnapshot(String)
instead. - JobStatus - Enum Class in com.hazelcast.jet.core
-
Represents current status of the job from the perspective of the job coordinator.
- jobStatusChanged(JobStatusEvent) - Method in interface com.hazelcast.jet.JobStatusListener
-
Invoked upon job status change.
- JobStatusEvent - Class in com.hazelcast.jet
-
Holds information about a job's state (status) transition, reason for the transition, and whether it is user-initiated.
- JobStatusEvent() - Constructor for class com.hazelcast.jet.JobStatusEvent
- JobStatusEvent(long, JobStatus, JobStatus, String, boolean) - Constructor for class com.hazelcast.jet.JobStatusEvent
- JobStatusListener - Interface in com.hazelcast.jet
-
Invoked upon job status change.
- JobSuspensionCause - Interface in com.hazelcast.jet.core
-
Description of the cause that has led to the job being suspended.
- join() - Method in interface com.hazelcast.jet.Job
-
Waits for the job to complete and throws an exception if the job completes with an error.
- JoinClause<K,
T0, T1, T1_OUT> - Class in com.hazelcast.jet.pipeline -
Specifies how to join an enriching stream to the primary stream in a
hash-join
operation. - JoinConfig - Class in com.hazelcast.config
-
Contains the multiple different join configuration.
- JoinConfig() - Constructor for class com.hazelcast.config.JoinConfig
- joinMapEntries(FunctionEx<? super T0, ? extends K>) - Static method in class com.hazelcast.jet.pipeline.JoinClause
-
A shorthand factory for the common case of hash-joining with a stream of map entries.
- JournalInitialPosition - Enum Class in com.hazelcast.jet.pipeline
-
When passed to an IMap/ICache Event Journal source, specifies which event to start from.
- json() - Static method in interface com.hazelcast.jet.pipeline.file.FileFormat
-
Returns a file format for JSON Lines files.
- json(Class<T>) - Static method in interface com.hazelcast.jet.pipeline.file.FileFormat
-
Returns a file format for JSON Lines files, where each line of text is one JSON object.
- json(String) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Convenience for
Sinks.filesBuilder(java.lang.String)
with the UTF-8 charset and with overwriting of existing files. - json(String) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Convenience for
Sources.json(String, Class)
which converts each JSON string to aMap
. - json(String, Class<T>) - Static method in class com.hazelcast.jet.pipeline.Sources
-
A source to read all files in a directory in a batch way.
- JSON - Enum constant in enum class com.hazelcast.sql.SqlColumnType
-
JSON type, represented by
HazelcastJsonValue
- JsonFileFormat<T> - Class in com.hazelcast.jet.pipeline.file
-
FileFormat
for the JSON Lines files. - JsonUtil - Class in com.hazelcast.jet.json
-
Util class to parse JSON formatted input to various object types or convert objects to JSON strings.
- jsonWatcher(String) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Convenience for
Sources.jsonWatcher(String, Class)
which converts each line appended to theMap
representation of the JSON string. - jsonWatcher(String, Class<T>) - Static method in class com.hazelcast.jet.pipeline.Sources
-
A source to stream lines added to files in a directory.
K
- kafka(DataConnectionRef) - Static method in class com.hazelcast.jet.kafka.KafkaSinks
-
Returns a builder object that you can use to create an Apache Kafka pipeline sink.
- kafka(DataConnectionRef, FunctionEx<? super E, ProducerRecord<K, V>>) - Static method in class com.hazelcast.jet.kafka.KafkaSinks
-
Returns a sink that publishes messages to Apache Kafka topic(s).
- kafka(DataConnectionRef, FunctionEx<ConsumerRecord<K, V>, T>, String...) - Static method in class com.hazelcast.jet.kafka.KafkaSources
-
Returns a source that consumes one or more Apache Kafka topics and emits items from them as
Map.Entry
instances. - kafka(DataConnectionRef, String) - Static method in class com.hazelcast.jet.kafka.KafkaSinks
-
Convenience for
KafkaSinks.kafka(DataConnectionRef, String, FunctionEx, FunctionEx)
which expectsMap.Entry<K, V>
as input and extracts its key and value parts to be published to Kafka. - kafka(DataConnectionRef, String...) - Static method in class com.hazelcast.jet.kafka.KafkaSources
-
Convenience for
KafkaSources.kafka(DataConnectionRef, FunctionEx, String...)
wrapping the output inMap.Entry
. - kafka(DataConnectionRef, String, FunctionEx<? super E, K>, FunctionEx<? super E, V>) - Static method in class com.hazelcast.jet.kafka.KafkaSinks
-
Convenience for
KafkaSinks.kafka(Properties, FunctionEx)
which creates aProducerRecord
using the given topic and the given key and value mapping functions - kafka(DataConnectionRef, Properties, String, FunctionEx<? super E, K>, FunctionEx<? super E, V>) - Static method in class com.hazelcast.jet.kafka.KafkaSinks
-
Convenience for
KafkaSinks.kafka(Properties, FunctionEx)
which creates aProducerRecord
using the given topic and the given key and value mapping functions with additional properties available - kafka(Properties) - Static method in class com.hazelcast.jet.kafka.KafkaSinks
-
Returns a builder object that you can use to create an Apache Kafka pipeline sink.
- kafka(Properties, FunctionEx<? super E, ProducerRecord<K, V>>) - Static method in class com.hazelcast.jet.kafka.KafkaSinks
-
Returns a sink that publishes messages to Apache Kafka topic(s).
- kafka(Properties, FunctionEx<ConsumerRecord<K, V>, T>, TopicsConfig) - Static method in class com.hazelcast.jet.kafka.KafkaSources
-
Returns a source that consumes one or more Apache Kafka topics and emits items from them as
Map.Entry
instances. - kafka(Properties, FunctionEx<ConsumerRecord<K, V>, T>, String...) - Static method in class com.hazelcast.jet.kafka.KafkaSources
-
Returns a source that consumes one or more Apache Kafka topics and emits items from them as
Map.Entry
instances. - kafka(Properties, String) - Static method in class com.hazelcast.jet.kafka.KafkaSinks
-
Convenience for
KafkaSinks.kafka(Properties, String, FunctionEx, FunctionEx)
which expectsMap.Entry<K, V>
as input and extracts its key and value parts to be published to Kafka. - kafka(Properties, String...) - Static method in class com.hazelcast.jet.kafka.KafkaSources
-
Convenience for
KafkaSources.kafka(Properties, FunctionEx, String...)
wrapping the output inMap.Entry
. - kafka(Properties, String, FunctionEx<? super E, K>, FunctionEx<? super E, V>) - Static method in class com.hazelcast.jet.kafka.KafkaSinks
-
Convenience for
KafkaSinks.kafka(Properties, FunctionEx)
which creates aProducerRecord
using the given topic and the given key and value mapping functions - KafkaConnectSources - Class in com.hazelcast.jet.kafka.connect
-
Contains factory methods to create a Kafka Connect source.
- KafkaDataConnection - Class in com.hazelcast.jet.kafka
-
DataConnection
implementation for Kafka. - KafkaDataConnection(DataConnectionConfig) - Constructor for class com.hazelcast.jet.kafka.KafkaDataConnection
-
Create
KafkaDataConnection
based on given config - KafkaProcessors - Class in com.hazelcast.jet.kafka
-
Static utility class with factories of Apache Kafka source and sink processors.
- KafkaSinks - Class in com.hazelcast.jet.kafka
-
Contains factory methods for Apache Kafka sinks.
- KafkaSinks.Builder<E> - Class in com.hazelcast.jet.kafka
-
A builder for Kafka sink.
- KafkaSources - Class in com.hazelcast.jet.kafka
-
Contains factory methods for Apache Kafka sources.
- KerberosAuthenticationConfig - Class in com.hazelcast.config.security
-
Typed authentication configuration for Kerberos tickets verification.
- KerberosAuthenticationConfig() - Constructor for class com.hazelcast.config.security.KerberosAuthenticationConfig
- KerberosIdentityConfig - Class in com.hazelcast.config.security
-
This class configures the Kerberos identity.
- KerberosIdentityConfig() - Constructor for class com.hazelcast.config.security.KerberosIdentityConfig
- key - Variable in class com.hazelcast.core.EntryEvent
- key() - Method in interface com.hazelcast.config.properties.PropertyDefinition
-
Returns the key (the name) of this property inside the configuration.
- key() - Method in class com.hazelcast.config.properties.SimplePropertyDefinition
- key() - Method in interface com.hazelcast.jet.cdc.ChangeRecord
-
Returns the key part of the CDC event.
- key() - Method in class com.hazelcast.jet.core.BroadcastKey
-
Returns the underlying key
- key() - Method in class com.hazelcast.jet.core.Watermark
-
Returns the key of this watermark item.
- key() - Method in class com.hazelcast.jet.datamodel.KeyedWindowResult
-
Returns the grouping key.
- key() - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
- KEY_ATTRIBUTE_NAME - Enum constant in enum class com.hazelcast.query.QueryConstants
-
Attribute name of the key.
- KEY_JOB_IS_SUSPENDABLE - Static variable in class com.hazelcast.jet.config.JobConfigArguments
-
The key under which caller marks analyzed job.
- KEY_REQUIRED_PARTITIONS - Static variable in class com.hazelcast.jet.config.JobConfigArguments
-
The key under which the SQL engine stores detected partitions to apply member pruning technique.
- KEY_SET - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- KEY_SQL_QUERY_TEXT - Static variable in class com.hazelcast.jet.config.JobConfigArguments
-
The key under which the SQL engine stores the SQL query text in
JobConfig.getArgument(String)
. - KEY_SQL_UNBOUNDED - Static variable in class com.hazelcast.jet.config.JobConfigArguments
-
The key under which the SQL engine stores whether the job backing an SQL query is bounded or unbounded (returning infinite rows).
- KEY_USER_CODE_NAMESPACE - Static variable in class com.hazelcast.jet.config.JobConfigArguments
-
The key under which the associated User Code Namespace for this job is stored.
- keyedWatermarkCheck(Watermark) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Throws
UnsupportedOperationException
if watermark has non-zero key. - KeyedWindowResult<K,
R> - Class in com.hazelcast.jet.datamodel -
Holds the result of a group-and-aggregate operation performed over a time window.
- KeyedWindowResult(long, long, K, R) - Constructor for class com.hazelcast.jet.datamodel.KeyedWindowResult
-
Constructs a keyed window result that is not early.
- KeyedWindowResult(long, long, K, R, boolean) - Constructor for class com.hazelcast.jet.datamodel.KeyedWindowResult
- KeyedWindowResultFunction<K,
R, OUT> - Interface in com.hazelcast.jet.core.function -
Represents the function you pass to windowing processors such as
aggregateToSlidingWindowP()
andaggregateToSessionWindowP()
asmapToOutputFn
. - keyFn() - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
-
Returns the function that extracts the key from stream items.
- keyFn() - Method in interface com.hazelcast.jet.pipeline.StageWithKeyAndWindow
-
Returns the function that extracts the grouping key from stream items.
- keySet() - Method in interface com.hazelcast.map.BaseMap
-
Returns a set clone of the keys contained in this map.
- keySet() - Method in interface com.hazelcast.map.IMap
-
Returns an immutable set clone of the keys contained in this map.
- keySet() - Method in interface com.hazelcast.map.QueryCache
- keySet() - Method in interface com.hazelcast.multimap.MultiMap
-
Returns the set of keys in the multimap.
- keySet() - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
-
Returns a lazy
Set
view of the key contained in this map.
A LazySet is optimized for querying speed (preventing eager deserialization and hashing on HashSet insertion) and does NOT provide all operations. - keySet() - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
Returns an immutable set of all keys in this HazelcastProperties.
- keySet() - Method in interface com.hazelcast.transaction.TransactionalMap
-
Transactional implementation of
IMap.keySet()
. - keySet(Predicate<K, V>) - Method in interface com.hazelcast.map.BaseMap
-
Queries the map based on the specified predicate and returns the keys of matching entries.
- keySet(Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
-
Queries the map based on the specified predicate and returns an immutable
Set
clone of the keys of matching entries. - keySet(Predicate<K, V>) - Method in interface com.hazelcast.map.QueryCache
- keySet(Predicate<K, V>) - Method in interface com.hazelcast.transaction.TransactionalMap
-
Transactional implementation of
IMap.keySet(com.hazelcast.query.Predicate)
. - keyValueTypesEqual(AbstractCacheConfig) - Method in class com.hazelcast.config.AbstractCacheConfig
- KILO_BYTE - Static variable in class com.hazelcast.client.config.SocketOptions
-
constant for kilobyte
- kiloBytes() - Method in class com.hazelcast.memory.Capacity
-
Returns value of the capacity in kilobytes.
- KILOBYTES - Enum constant in enum class com.hazelcast.memory.MemoryUnit
-
MemoryUnit in kilobytes
- kinesis(String) - Static method in class com.hazelcast.jet.kinesis.KinesisSinks
-
Convenience method for a specific type of sink, one that ingests items of type
Map.Entry<String, byte[]>
and assumes that the entries key is the partition key and the entries value is the record data blob. - kinesis(String) - Static method in class com.hazelcast.jet.kinesis.KinesisSources
-
Initiates the building of a streaming source that consumes a Kinesis data stream and emits
Map.Entry<String, byte[]>
items. - kinesis(String, FunctionEx<T, String>, FunctionEx<T, byte[]>) - Static method in class com.hazelcast.jet.kinesis.KinesisSinks
-
Initiates the building of a sink that publishes messages into Amazon Kinesis Data Streams (KDS).
- KinesisSinks - Class in com.hazelcast.jet.kinesis
-
Contains factory methods for creating Amazon Kinesis Data Streams (KDS) sinks.
- KinesisSinks.Builder<T> - Class in com.hazelcast.jet.kinesis
-
Fluent builder for constructing the Kinesis sink and setting its configuration parameters.
- KinesisSources - Class in com.hazelcast.jet.kinesis
-
Contains factory methods for creating Amazon Kinesis Data Streams (KDS) sources.
- KinesisSources.Builder<T> - Class in com.hazelcast.jet.kinesis
-
Fluent builder for constructing the Kinesis source and setting its configuration parameters.
- KUBERNETES_API_RETIRES - Static variable in class com.hazelcast.kubernetes.KubernetesProperties
-
Configuration key:
kubernetes-api-retries
- KUBERNETES_API_TOKEN - Static variable in class com.hazelcast.kubernetes.KubernetesProperties
-
Configuration key:
api-token
- KUBERNETES_CA_CERTIFICATE - Static variable in class com.hazelcast.kubernetes.KubernetesProperties
-
Configuration key:
ca-certificate
CA Authority certificate from Kubernetes Master, defaults to reading the certificate from the auto-injected file at:/var/run/secrets/kubernetes.io/serviceaccount/ca.crt
- KUBERNETES_MASTER_URL - Static variable in class com.hazelcast.kubernetes.KubernetesProperties
-
Configuration key:
kubernetes-master
- KUBERNETES_SYSTEM_PREFIX - Static variable in class com.hazelcast.kubernetes.KubernetesProperties
-
Configuration System Environment Prefix:
hazelcast.kubernetes.
- KubernetesApiEndpointSlicesProvider - Class in com.hazelcast.kubernetes
- KubernetesApiEndpointSlicesProvider() - Constructor for class com.hazelcast.kubernetes.KubernetesApiEndpointSlicesProvider
- KubernetesConfig - Class in com.hazelcast.config
-
Configuration for the Kubernetes Discovery Strategy.
- KubernetesConfig() - Constructor for class com.hazelcast.config.KubernetesConfig
- KubernetesConfig(KubernetesConfig) - Constructor for class com.hazelcast.config.KubernetesConfig
- KubernetesConfig(String, boolean, boolean, Map<String, String>) - Constructor for class com.hazelcast.config.KubernetesConfig
- KubernetesProperties - Class in com.hazelcast.kubernetes
-
Configuration class of the Hazelcast Discovery Plugin for Kubernetes.
L
- LAST_FORWARDED_WM - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
- LAST_FORWARDED_WM_LATENCY - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
- LAST_INDEX_OF - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- lastForwardedWm(byte) - Method in class com.hazelcast.jet.core.test.TestOutbox
- LatestAccessMergePolicy<V,
T extends MergingValue<V> & MergingLastAccessTime> - Class in com.hazelcast.spi.merge -
Merges data structure entries from source to destination data structure if the source entry has been accessed more recently than the destination entry.
- LatestAccessMergePolicy() - Constructor for class com.hazelcast.spi.merge.LatestAccessMergePolicy
- LatestUpdateMergePolicy<V,
T extends MergingValue<V> & MergingLastUpdateTime> - Class in com.hazelcast.spi.merge -
Merges data structure entries from source to destination data structure if the source entry was updated more frequently than the destination entry.
- LatestUpdateMergePolicy() - Constructor for class com.hazelcast.spi.merge.LatestUpdateMergePolicy
- lazy(Supplier<Traverser<T>>) - Static method in class com.hazelcast.jet.Traversers
-
Flattens a supplier of traverser into a lazy-initialized traverser.
- LAZY - Enum constant in enum class com.hazelcast.config.MapStoreConfig.InitialLoadMode
-
Each partition is loaded when it is first touched.
- LdapAuthenticationConfig - Class in com.hazelcast.config.security
-
Typed authentication configuration for
BasicLdapLoginModule
andLdapLoginModule
. - LdapAuthenticationConfig() - Constructor for class com.hazelcast.config.security.LdapAuthenticationConfig
- LdapRoleMappingMode - Enum Class in com.hazelcast.config.security
-
Enum for LDAP role mapping modes.
- LdapSearchScope - Enum Class in com.hazelcast.config.security
-
Search scope types for LDAP queries.
- leader() - Method in record class com.hazelcast.cp.CPGroupsSnapshot.GroupInfo
-
Returns the value of the
leader
record component. - LeaderDemotedException - Exception in com.hazelcast.cp.exception
-
A
CPSubsystemException
which is thrown when an appended but not-committed entry is truncated by the new leader. - LeaderDemotedException(RaftEndpoint, RaftEndpoint) - Constructor for exception com.hazelcast.cp.exception.LeaderDemotedException
- leftKeyFn() - Method in class com.hazelcast.jet.pipeline.JoinClause
-
Returns the left-hand key extractor function.
- length() - Method in interface com.hazelcast.security.Parameters
- lessEqual(Comparable) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
- lessEqual(String, Comparable) - Static method in class com.hazelcast.query.Predicates
-
Creates a less than or equal to predicate that will pass items if the value stored under the given item
attribute
is less than or equal to the givenvalue
. - lessThan(Comparable) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
- lessThan(String, Comparable) - Static method in class com.hazelcast.query.Predicates
-
Creates a less than predicate that will pass items if the value stored under the given item
attribute
is less than the givenvalue
. - level() - Method in interface com.hazelcast.auditlog.AuditableEvent
- level(Level) - Method in interface com.hazelcast.auditlog.EventBuilder
-
Sets the event
Level
. - Level - Enum Class in com.hazelcast.auditlog
-
Event importance levels.
- LFU - Enum constant in enum class com.hazelcast.config.EvictionPolicy
-
Least Frequently Used
- LICENSED - Enum constant in enum class com.hazelcast.config.InstanceTrackingConfig.InstanceTrackingProperties
-
If this instance is using a license or not.
- LifecycleEvent - Class in com.hazelcast.core
-
Lifecycle events are fired when the HazelcastInstance state changes.
- LifecycleEvent(LifecycleEvent.LifecycleState) - Constructor for class com.hazelcast.core.LifecycleEvent
- LifecycleEvent.LifecycleState - Enum Class in com.hazelcast.core
-
Lifecycle states
- LifecycleListener - Interface in com.hazelcast.core
-
Listener object for listening to lifecycle events of the Hazelcast instance
- LifecycleService - Interface in com.hazelcast.core
-
LifecycleService allows you to shut down, terminate, and listen to
LifecycleEvent
s on HazelcastInstance. - like(String, String) - Static method in class com.hazelcast.query.Predicates
-
Creates a like predicate that will pass items if the given
pattern
matches the value stored under the given itemattribute
. - limit(int) - Method in class com.hazelcast.vector.SearchOptionsBuilder
-
Sets the number of search results to return.
- limitingLag(long) - Static method in interface com.hazelcast.jet.core.WatermarkPolicy
-
Maintains a watermark that lags behind the top observed timestamp by the given amount.
- limitingRealTimeLag(long) - Static method in interface com.hazelcast.jet.core.WatermarkPolicy
-
Maintains a watermark that lags behind the real time by the given amount.
- linearTrend(ToLongFunctionEx<T>, ToLongFunctionEx<T>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that computes a linear trend over the items.
- LineReader - Interface in com.hazelcast.console
-
Reads a line of input.
- lines() - Static method in interface com.hazelcast.jet.pipeline.file.FileFormat
-
Returns a file format for text files where each line is a
String
data item. - lines(Charset) - Static method in interface com.hazelcast.jet.pipeline.file.FileFormat
-
Returns a file format for text files where each line is a
String
data item. - LinesTextFileFormat - Class in com.hazelcast.jet.pipeline.file
-
FileFormat
for text files where each line is aString
data item. - LinTrendAccumulator - Class in com.hazelcast.jet.accumulator
-
Maintains the components needed to compute the linear regression on a set of
(long, long)
pairs. - LinTrendAccumulator() - Constructor for class com.hazelcast.jet.accumulator.LinTrendAccumulator
-
Constructs a new accumulator with all components at zero.
- LinTrendAccumulator(long, BigInteger, BigInteger, BigInteger, BigInteger) - Constructor for class com.hazelcast.jet.accumulator.LinTrendAccumulator
-
Creates a new accumulator with the given components.
- list(IList<? extends T>) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Returns a source that emits items retrieved from a Hazelcast
IList
. - list(IList<? super T>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink that adds the items it receives to the specified Hazelcast
IList
. - list(String) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink that adds the items it receives to a Hazelcast
IList
with the specified name. - list(String) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Returns a source that emits items retrieved from a Hazelcast
IList
. - LIST - Enum constant in enum class com.hazelcast.config.MultiMapConfig.ValueCollectionType
-
Store value collection as list
- LIST - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
-
List
- LIST_ITERATOR - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- listAddPermission(String, String) - Static method in class com.hazelcast.security.PermissionsUtil
- ListConfig - Class in com.hazelcast.config
-
Contains the configuration for an
IList
. - ListConfig() - Constructor for class com.hazelcast.config.ListConfig
- ListConfig(ListConfig) - Constructor for class com.hazelcast.config.ListConfig
- ListConfig(String) - Constructor for class com.hazelcast.config.ListConfig
- LISTENER_INSTANCE - Static variable in class com.hazelcast.security.permission.ActionConstants
- LISTENER_MEMBER - Static variable in class com.hazelcast.security.permission.ActionConstants
- LISTENER_MIGRATION - Static variable in class com.hazelcast.security.permission.ActionConstants
- ListenerConfig - Class in com.hazelcast.config
-
Contains the configuration for an
EventListener
. - ListenerConfig() - Constructor for class com.hazelcast.config.ListenerConfig
-
Creates a ListenerConfig without className/implementation.
- ListenerConfig(ListenerConfig) - Constructor for class com.hazelcast.config.ListenerConfig
- ListenerConfig(String) - Constructor for class com.hazelcast.config.ListenerConfig
-
Creates a ListenerConfig with the given className.
- ListenerConfig(EventListener) - Constructor for class com.hazelcast.config.ListenerConfig
-
Creates a ListenerConfig with the given implementation.
- listenerConfigurations - Variable in class com.hazelcast.config.AbstractCacheConfig
-
The
CacheEntryListenerConfiguration
s for theConfiguration
. - listFrom(String) - Static method in class com.hazelcast.jet.json.JsonUtil
-
Converts a JSON string to a
List
. - listFrom(String, Class<T>) - Static method in class com.hazelcast.jet.json.JsonUtil
-
Converts a JSON string to a
List
of given type. - ListPermission - Class in com.hazelcast.security.permission
- ListPermission(String, String...) - Constructor for class com.hazelcast.security.permission.ListPermission
- listReadPermission(String, String) - Static method in class com.hazelcast.security.PermissionsUtil
- listResources() - Method in interface com.hazelcast.dataconnection.DataConnection
-
Returns list of
DataConnectionResource
s accessible via this DataConnection. - listResources() - Method in class com.hazelcast.dataconnection.HazelcastDataConnection
- listResources() - Method in class com.hazelcast.jet.kafka.KafkaDataConnection
- listResources() - Method in class com.hazelcast.jet.mongodb.dataconnection.MongoDataConnection
-
Lists all MongoDB collections in all databases.
- LITE_MEMBER_SELECTOR - Static variable in class com.hazelcast.cluster.memberselector.MemberSelectors
-
A
MemberSelector
instance that selects only lite members that own no partition - load() - Static method in class com.hazelcast.client.config.ClientConfig
-
Populates Hazelcast
ClientConfig
object from an external configuration file. - load() - Static method in class com.hazelcast.client.config.ClientFailoverConfig
-
Populates Hazelcast
ClientFailoverConfig
object from an external configuration file. - load() - Static method in class com.hazelcast.config.Config
-
Populates Hazelcast
Config
object from an external configuration file. - load(long) - Method in interface com.hazelcast.ringbuffer.RingbufferStore
-
Loads the value of a given sequence.
- load(Long) - Method in interface com.hazelcast.collection.QueueStore
-
Loads the value of a given key.
- load(Map<K, V>) - Method in interface com.hazelcast.scheduledexecutor.StatefulTask
-
Task callback to initialize its inner state, after a replica promotion, from the given map.
- load(K) - Method in interface com.hazelcast.map.MapLoader
-
Loads the value of a given key.
- load(K) - Method in class com.hazelcast.map.MapStoreAdapter
-
Loads the value of a given key.
- load(K) - Method in class com.hazelcast.mapstore.GenericMapLoader
- LOAD_ALL - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- LOAD_ALL_KEYS_PROPERTY - Static variable in class com.hazelcast.mapstore.GenericMapLoader
-
Property key to control loading of all keys when IMap is first created
- loadAll(boolean) - Method in interface com.hazelcast.map.IMap
-
Loads all keys into the store.
- loadAll(Collection<Long>) - Method in interface com.hazelcast.collection.QueueStore
-
Loads the given keys.
- loadAll(Collection<K>) - Method in interface com.hazelcast.map.MapLoader
-
Loads given keys.
- loadAll(Collection<K>) - Method in class com.hazelcast.map.MapStoreAdapter
-
Loads given keys.
- loadAll(Collection<K>) - Method in class com.hazelcast.mapstore.GenericMapLoader
-
Size of the
keys
collection is limited byClusterProperty.MAP_LOAD_CHUNK_SIZE
- loadAll(Set<K>, boolean) - Method in interface com.hazelcast.map.IMap
-
Loads the given keys.
- loadAllKeys() - Method in interface com.hazelcast.collection.QueueStore
-
Loads all the keys from the store.
- loadAllKeys() - Method in interface com.hazelcast.map.MapLoader
-
Loads all the keys from the store.
- loadAllKeys() - Method in class com.hazelcast.map.MapStoreAdapter
-
Loads all the keys from the store.
- loadAllKeys() - Method in class com.hazelcast.mapstore.GenericMapLoader
- LoadBalancer - Interface in com.hazelcast.client
-
LoadBalancer
allows you to send operations to one of a number of endpoints (members). - loadDefault() - Static method in class com.hazelcast.config.Config
-
Same as
load()
, i.e., loads Config using the default lookup mechanism - loadDefault(Properties) - Static method in class com.hazelcast.config.Config
-
Loads Config using the default
lookup mechanism
to locate the configuration file and applies variable resolution from the provided properties. - LOADED - Enum constant in enum class com.hazelcast.core.EntryEventType
-
Fired if an entry is loaded.
- loadFromClasspath(ClassLoader, String) - Static method in class com.hazelcast.config.Config
-
Creates a Config which is loaded from a classpath resource.
- loadFromClasspath(ClassLoader, String, Properties) - Static method in class com.hazelcast.config.Config
-
Creates a Config which is loaded from a classpath resource.
- loadFromFile(File) - Static method in class com.hazelcast.config.Config
-
Creates a Config based on a the provided configuration file (XML or YAML) and uses the System.properties to resolve variables in the file.
- loadFromFile(File, Properties) - Static method in class com.hazelcast.config.Config
-
Creates a Config based on a the provided configuration file (XML or YAML) and uses the System.properties to resolve variables in the file.
- loadFromStream(InputStream) - Static method in class com.hazelcast.config.Config
-
Creates a Config from the provided stream (XML or YAML content) and uses the System.properties for variable resolution.
- loadFromStream(InputStream, Properties) - Static method in class com.hazelcast.config.Config
-
Creates a Config from the provided stream (XML or YAML content).
- loadFromString(String) - Static method in class com.hazelcast.config.Config
-
Creates a Config from the provided string (XML or YAML content) and uses the System.properties for variable resolution.
- loadFromString(String, Properties) - Static method in class com.hazelcast.config.Config
-
Creates a Config from the provided string (XML or YAML content).
- loadSchemaFile(String) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
- local() - Method in class com.hazelcast.jet.core.Edge
-
Declares that the edge is local.
- LOCAL_AND_CACHED_CLASSES - Enum constant in enum class com.hazelcast.config.UserCodeDeploymentConfig.ProviderMode
-
Deprecated.Serve classes loaded from both local classpath and from other members.
- LOCAL_CACHE_READER_FUNCTION - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
- LOCAL_CLASSES_ONLY - Enum constant in enum class com.hazelcast.config.UserCodeDeploymentConfig.ProviderMode
-
Deprecated.Serve classes from local classpath only.
- LOCAL_MAP_QUERY_READER_FUNCTION - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
- LOCAL_MAP_READER_FUNCTION - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
- LOCAL_MEMBER_SELECTOR - Static variable in class com.hazelcast.cluster.memberselector.MemberSelectors
-
A
MemberSelector
instance that selects only local members - LOCAL_PARALLELISM_USE_DEFAULT - Static variable in class com.hazelcast.jet.core.Vertex
-
The value of
Vertex.localParallelism(int)
with the meaning "use the default local parallelism". - LocalCollectionStats - Interface in com.hazelcast.collection
-
Local collections statistics to be used by
MemberState
implementations. - LocalDeviceConfig - Class in com.hazelcast.config
-
Local Device configuration for the Tiered-Store.
- LocalDeviceConfig() - Constructor for class com.hazelcast.config.LocalDeviceConfig
- LocalDeviceConfig(LocalDeviceConfig) - Constructor for class com.hazelcast.config.LocalDeviceConfig
- LocalExecutorStats - Interface in com.hazelcast.executor
-
Local executor service statistics.
- LocalIndexStats - Interface in com.hazelcast.query
-
Provides local statistics for an index to be used by
MemberState
implementations. - localKeySet() - Method in interface com.hazelcast.map.IMap
-
Returns the locally owned immutable set of keys.
- localKeySet() - Method in interface com.hazelcast.multimap.MultiMap
-
Returns the locally owned set of keys.
- localKeySet(Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
-
Returns an immutable set of the keys of matching locally owned entries.
- LocalListStats - Interface in com.hazelcast.collection
-
Local List statistics to be used by
MemberState
implementations. - LocalMapStats - Interface in com.hazelcast.map
-
Local map statistics to be used by
MemberState
implementations. - localMember() - Method in interface com.hazelcast.cluster.Member
-
Returns true if this member is the local member.
- LocalMemberResetException - Exception in com.hazelcast.core
-
An exception provided to
MemberLeftException
as a cause when the local member is resetting itself - LocalMemberResetException(String) - Constructor for exception com.hazelcast.core.LocalMemberResetException
- LocalMultiMapStats - Interface in com.hazelcast.multimap
-
Local multimap statistics to be used by
MemberState
implementations. - localParallelism() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
-
Returns the number of processors that each
ProcessorSupplier
will be asked to create once deserialized on each member. - localParallelism() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
- localParallelism(int) - Method in class com.hazelcast.jet.core.test.TestSupport
-
Sets the localParallelism for the Processor
- localParallelism(int) - Method in class com.hazelcast.jet.core.Vertex
-
Sets the number of processors corresponding to this vertex that will be created on each member.
- localProcessorIndex() - Method in interface com.hazelcast.jet.core.Processor.Context
-
Returns the index of the processor among all the processors created for this vertex on a single node: it's a unique node-wide index.
- localProcessorIndex() - Method in class com.hazelcast.jet.core.test.TestProcessorContext
- localProcessorIndex(int) - Method in class com.hazelcast.jet.core.test.TestSupport
-
Sets the localProcessorIndex for the Processor
- LocalQueueStats - Interface in com.hazelcast.collection
-
Local queue statistics to be used by
MemberState
implementations. - LocalReplicatedMapStats - Interface in com.hazelcast.replicatedmap
-
Local replicated map statistics to be used by
MemberState
implementations. - LocalReplicationStats - Interface in com.hazelcast.partition
-
Local statistics related to partition data replication.
- LocalSetStats - Interface in com.hazelcast.collection
-
Local Set statistics to be used by
MemberState
implementations. - LocalTopicStats - Interface in com.hazelcast.topic
-
Local topic statistics to be used by
MemberState
implementations. - localValues() - Method in interface com.hazelcast.map.IMap
-
Returns an immutable collection locally owned values contained in this map.
- localValues(Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
-
Queries the map of locally owned keys based on the specified predicate and returns an immutable collection of the values of matching entries.
- lock() - Method in interface com.hazelcast.cp.lock.FencedLock
-
Acquires the lock.
- lock() - Method in class com.hazelcast.jet.config.JobConfig
-
Used to prevent further mutations the config after submitting it with a job execution.
- lock() - Method in class com.hazelcast.jet.core.DAG
-
Used to prevent further mutations to the DAG after submitting it for execution.
- lock(K) - Method in interface com.hazelcast.map.IMap
-
Acquires the lock for the specified key.
- lock(K) - Method in interface com.hazelcast.multimap.MultiMap
-
Acquires a lock for the specified key.
- lock(K, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Acquires the lock for the specified key for the specified lease time.
- lock(K, long, TimeUnit) - Method in interface com.hazelcast.multimap.MultiMap
-
Acquires the lock for the specified key for the specified lease time.
- LOCK - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
-
Lock
- LOCK - Static variable in interface com.hazelcast.cp.CPSubsystem
-
Constant identifying service for
FencedLock
, to be used withCPSubsystem.getObjectInfos(CPGroupId, String)
- LOCK - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- LOCK_MAX_LEASE_TIME_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
All locks which are acquired without an explicit lease time use this value (in seconds) as the lease time.
- LockAcquireLimitReachedException - Exception in com.hazelcast.cp.lock.exception
-
Thrown when the current lock holder could not acquire the lock reentrantly because the configured lock acquire limit is reached.
- LockAcquireLimitReachedException() - Constructor for exception com.hazelcast.cp.lock.exception.LockAcquireLimitReachedException
- LockAcquireLimitReachedException(String) - Constructor for exception com.hazelcast.cp.lock.exception.LockAcquireLimitReachedException
- lockAndGetFence() - Method in interface com.hazelcast.cp.lock.FencedLock
-
Acquires the lock and returns the fencing token assigned to the current thread for this lock acquire.
- LockAware - Interface in com.hazelcast.map
-
Determines if the object implementing this interface is locked or not.
- lockInterruptibly() - Method in interface com.hazelcast.cp.lock.FencedLock
-
Acquires the lock unless the current thread is interrupted.
- LockOwnershipLostException - Exception in com.hazelcast.cp.lock.exception
-
Thrown when an endpoint (either a Hazelcast server or a client) interacts with a
FencedLock
instance after its CP session is closed in the underlying CP group and its lock ownership is cancelled. - LockOwnershipLostException() - Constructor for exception com.hazelcast.cp.lock.exception.LockOwnershipLostException
- LockOwnershipLostException(String) - Constructor for exception com.hazelcast.cp.lock.exception.LockOwnershipLostException
- LockPermission - Class in com.hazelcast.security.permission
- LockPermission(String, String...) - Constructor for class com.hazelcast.security.permission.LockPermission
- log() - Method in interface com.hazelcast.auditlog.EventBuilder
-
Builds the event and logs it to the service which provided this builder (if any).
- log(AuditableEvent) - Method in interface com.hazelcast.auditlog.AuditlogService
-
Logs given event.
- log(LogEvent) - Method in interface com.hazelcast.logging.ILogger
-
Deprecated.Since 5.1, the method is unused
- log(LogEvent) - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
- log(LogEvent) - Method in interface com.hazelcast.logging.LogListener
- log(String, Level, String) - Method in interface com.hazelcast.auditlog.AuditlogService
-
Creates and logs a simple parameterless message at the given level.
- log(String, Level, String, Throwable) - Method in interface com.hazelcast.auditlog.AuditlogService
-
Creates and logs a simple parameterless message with an associated throwable at the given level.
- log(Level, String) - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
- log(Level, String, Throwable) - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
- LOG_EMOJI_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Controls whether cluster emojis can be used in log messages.
- Log4j2Factory - Class in com.hazelcast.logging
-
Logging to Log4j 2.x.
- Log4j2Factory() - Constructor for class com.hazelcast.logging.Log4j2Factory
- Log4j2Factory.Log4j2Logger - Class in com.hazelcast.logging
- Log4j2Logger(ExtendedLogger) - Constructor for class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
- Log4jFactory - Class in com.hazelcast.logging
- Log4jFactory() - Constructor for class com.hazelcast.logging.Log4jFactory
- LogEvent - Class in com.hazelcast.logging
- LogEvent(LogRecord, Member) - Constructor for class com.hazelcast.logging.LogEvent
- logger - Variable in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
- logger() - Method in interface com.hazelcast.jet.core.Processor.Context
-
Return a logger for the processor
- logger() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
-
Returns a logger for the associated
ProcessorMetaSupplier
. - logger() - Method in interface com.hazelcast.jet.core.ProcessorSupplier.Context
-
Returns a logger for the associated
ProcessorSupplier
. - logger() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
- logger() - Static method in class com.hazelcast.jet.pipeline.Sinks
- logger(FunctionEx<? super T, String>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink that logs all the data items it receives, at the INFO level to the log category
WriteLoggerP
. - Logger - Class in com.hazelcast.logging
-
Provides static utilities to access the global shared logging machinery.
- LoggerFactory - Interface in com.hazelcast.logging
- LoggerFactorySupport - Class in com.hazelcast.logging
- LoggerFactorySupport() - Constructor for class com.hazelcast.logging.LoggerFactorySupport
- loggerName() - Method in class com.hazelcast.jet.core.test.TestProcessorContext
- loggerName() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
- loggerName() - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
- LOGGING_ENABLE_DETAILS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Controls whether cluster name, ip and version should be included in all log messages.
- LOGGING_SHUTDOWN - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Controls whether Hazelcast will explicitly shut down the logging implementation as part of Hazelcast graceful shutdown procedure.
- LOGGING_TYPE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Name of logging framework type to send logging events.
- LoggingService - Interface in com.hazelcast.logging
- LoggingServiceCallback - Class in com.hazelcast.security
-
This JAAS
Callback
is used to retrieve aLoggingService
from the current member. - LoggingServiceCallback() - Constructor for class com.hazelcast.security.LoggingServiceCallback
- LoginModuleConfig - Class in com.hazelcast.config
-
Configuration for Login Module
- LoginModuleConfig() - Constructor for class com.hazelcast.config.LoginModuleConfig
- LoginModuleConfig(String, LoginModuleConfig.LoginModuleUsage) - Constructor for class com.hazelcast.config.LoginModuleConfig
- LoginModuleConfig.LoginModuleUsage - Enum Class in com.hazelcast.config
-
Usage of Login Module
- LogListener - Interface in com.hazelcast.logging
- LONG - Enum constant in enum class com.hazelcast.config.BitmapIndexOptions.UniqueKeyTransformation
-
Extracted unique key value is interpreted as a whole integer value of byte, short, int or long type.
- LONG - Enum constant in enum class com.hazelcast.config.properties.PropertyTypeConverter
-
TypeConverter
to convert an input string to an output long - LONG - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
- LONG_ARRAY - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
- LongAccumulator - Class in com.hazelcast.jet.accumulator
-
Mutable container of a
long
value. - LongAccumulator() - Constructor for class com.hazelcast.jet.accumulator.LongAccumulator
-
Creates a new instance with
value == 0
. - LongAccumulator(long) - Constructor for class com.hazelcast.jet.accumulator.LongAccumulator
-
Creates a new instance with the specified value.
- longAvg() - Static method in class com.hazelcast.aggregation.Aggregators
- longAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
- LongDoubleAccumulator - Class in com.hazelcast.jet.accumulator
-
Mutable container of a
long
and adouble
value. - LongDoubleAccumulator() - Constructor for class com.hazelcast.jet.accumulator.LongDoubleAccumulator
-
Creates a new instance with values equal to 0.
- LongDoubleAccumulator(long, double) - Constructor for class com.hazelcast.jet.accumulator.LongDoubleAccumulator
-
Creates a new instance with the specified values.
- LongLongAccumulator - Class in com.hazelcast.jet.accumulator
-
Mutable container of two
long
values. - LongLongAccumulator() - Constructor for class com.hazelcast.jet.accumulator.LongLongAccumulator
-
Creates a new instance with values equal to 0.
- LongLongAccumulator(long, long) - Constructor for class com.hazelcast.jet.accumulator.LongLongAccumulator
-
Creates a new instance with the specified values.
- longMax() - Static method in class com.hazelcast.aggregation.Aggregators
- longMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
- longMin() - Static method in class com.hazelcast.aggregation.Aggregators
- longMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
- longStream(long, long) - Static method in class com.hazelcast.jet.pipeline.test.TestSources
-
Returns a
StreamSource
that emits an ever-increasing sequence ofLong
numbers with native timestamps that are exactly the same amount of time apart, as specified by the suppliedeventsPerSecond
parameter. - LongStreamSourceP - Class in com.hazelcast.jet.pipeline.test
-
Implements the
TestSources.longStream(long, long)
source. - longSum() - Static method in class com.hazelcast.aggregation.Aggregators
- longSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
- LRU - Enum constant in enum class com.hazelcast.config.EvictionPolicy
-
Least Recently Used
M
- main(String[]) - Static method in class com.hazelcast.commandline.HazelcastServerCommandLine
- main(String...) - Static method in class com.hazelcast.config.replacer.EncryptionReplacer
- main(String[]) - Static method in class com.hazelcast.console.ConsoleApp
-
Starts the test application.
- MAJOR_MINOR_VERSION_COMPARATOR - Static variable in class com.hazelcast.version.MemberVersion
-
Version comparator that takes into account only major & minor version, disregarding patch version number.
- majorityLost(CPGroupAvailabilityEvent) - Method in interface com.hazelcast.cp.event.CPGroupAvailabilityListener
-
Called when a CP group has lost its majority.
- managedContext() - Method in interface com.hazelcast.jet.core.ProcessorSupplier.Context
-
Returns
ManagedContext
associated with this job. - managedContext() - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
- ManagedContext - Interface in com.hazelcast.core
-
Container managed context, such as Spring, Guice etc.
- ManagedTransactionalTaskContext - Class in com.hazelcast.spring.transaction
-
TransactionalTaskContext
proxying implementation to make the one created byHazelcastTransactionManager
available to actual business logic. - ManagedTransactionalTaskContext(HazelcastTransactionManager) - Constructor for class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
- MANAGEMENT - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
-
Cluster Management
- ManagementCenterConfig - Class in com.hazelcast.config
-
Contains the configuration for Hazelcast Management Center.
- ManagementCenterConfig() - Constructor for class com.hazelcast.config.ManagementCenterConfig
- ManagementPermission - Class in com.hazelcast.security.permission
-
Hazelcast Permission type used in client protocol actions intended for Management Center operations.
- ManagementPermission(String) - Constructor for class com.hazelcast.security.permission.ManagementPermission
- map(FunctionEx<? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- map(FunctionEx<? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Attaches a mapping stage which applies the given function to each input item independently and emits the function's result as the output item.
- map(FunctionEx<? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- map(IMap<? extends K, ? extends V>) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Returns a source that fetches entries from the given Hazelcast
IMap
and emits them asMap.Entry
. - map(IMap<? extends K, ? extends V>, Predicate<K, V>, Projection<? super Map.Entry<K, V>, ? extends T>) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Returns a source that fetches entries from the given Hazelcast
IMap
. - map(IMap<? super K, ? super V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink that puts
Map.Entry
s it receives into the given HazelcastIMap
. - map(IMap<? super K, ? super V>, FunctionEx<? super ChangeRecord, ? extends K>, FunctionEx<? super ChangeRecord, ? extends V>) - Static method in class com.hazelcast.jet.cdc.CdcSinks
-
Returns a sink that applies the changes described by a Change Data Capture (CDC) stream to an
IMap
. - map(IMap<? super K, ? super V>, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink that uses the supplied functions to extract the key and value with which to put to given Hazelcast
IMap
. - map(String) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink that puts
Map.Entry
s it receives into a HazelcastIMap
with the specified name. - map(String) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Returns a source that fetches entries from a local Hazelcast
IMap
with the specified name and emits them asMap.Entry
. - map(String, FunctionEx<? super ChangeRecord, ? extends K>, FunctionEx<? super ChangeRecord, ? extends V>) - Static method in class com.hazelcast.jet.cdc.CdcSinks
-
Returns a sink that applies the changes described by a Change Data Capture (CDC) stream to an
IMap
. - map(String, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink that uses the supplied functions to extract the key and value with which to put to a Hazelcast
IMap
with the specified name. - map(String, Predicate<K, V>, Projection<? super Map.Entry<K, V>, ? extends T>) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Returns a source that fetches entries from a local Hazelcast
IMap
with the specified name. - map(Function<? super T, ? extends R>) - Method in interface com.hazelcast.jet.Traverser
-
Returns a traverser that will emit the results of applying
mapFn
to this traverser's items. - MAP - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
-
Map
- MAP_EVICTION_BATCH_SIZE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Maximum number of IMap entries Hazelcast will evict during a single eviction cycle.
- MAP_EXPIRY_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
You can use MAP_EXPIRY_DELAY_SECONDS to deal with some possible edge cases, such as using EntryProcessor.
- MAP_INVALIDATION_MESSAGE_BATCH_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Defines Near Cache invalidation event batch sending is enabled or not.
- MAP_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Defines the Near Cache invalidation event batch sending frequency in seconds.
- MAP_INVALIDATION_MESSAGE_BATCH_SIZE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Defines the maximum number of Near Cache invalidation events to be drained and sent to the event Near Cache in a batch.
- MAP_LOAD_CHUNK_SIZE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The maximum size of the key batch sent to the partition owners for value loading and the maximum size of a key batch for which values are loaded in a single partition.
- MAP_REPLICA_SCHEDULED_TASK_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Scheduler delay for map tasks those are executed on backup members.
- MAP_WRITE_BEHIND_QUEUE_CAPACITY - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Setting this capacity is valid if you set
writeCoalescing
tofalse
(seeMapStoreConfig.setWriteCoalescing(boolean)
). - mapBuilder(String) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a builder object that offers a step-by-step fluent API to build a custom file sink for the Pipeline API.
- mapCleared(MapEvent) - Method in class com.hazelcast.console.ConsoleApp
- mapCleared(MapEvent) - Method in class com.hazelcast.core.EntryAdapter
- mapCleared(MapEvent) - Method in interface com.hazelcast.map.listener.MapClearedListener
-
Invoked when all entries are removed by
IMap.clear()
. - MapClearedListener - Interface in com.hazelcast.map.listener
-
Invoked after all entries are removed by
IMap.clear()
. - MapConfig - Class in com.hazelcast.config
-
Contains the configuration for an
IMap
. - MapConfig() - Constructor for class com.hazelcast.config.MapConfig
- MapConfig(MapConfig) - Constructor for class com.hazelcast.config.MapConfig
- MapConfig(String) - Constructor for class com.hazelcast.config.MapConfig
- mapEntryProcessorBuilder(String) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a builder object that offers a step-by-step fluent API to build a custom file sink for the Pipeline API.
- MapEvent - Class in com.hazelcast.map
-
Used for map-wide events like
EntryEventType.EVICT_ALL
andEntryEventType.CLEAR_ALL
. - MapEvent(Object, Member, int, int) - Constructor for class com.hazelcast.map.MapEvent
- mapEventNewValue() - Static method in class com.hazelcast.jet.Util
-
Returns a projection that extracts the new value from an
EventJournalMapEvent
. - mapEventToEntry() - Static method in class com.hazelcast.jet.Util
-
Returns a projection that converts the
EventJournalMapEvent
to aMap.Entry
using the event's new value as a value. - mapEvicted(MapEvent) - Method in class com.hazelcast.console.ConsoleApp
- mapEvicted(MapEvent) - Method in class com.hazelcast.core.EntryAdapter
- mapEvicted(MapEvent) - Method in interface com.hazelcast.map.listener.MapEvictedListener
-
Invoked when all entries are evicted by
IMap.evictAll()
. - MapEvictedListener - Interface in com.hazelcast.map.listener
-
Invoked after all entries are evicted by
IMap.evictAll()
. - MapEvictionPolicyComparator<K,
V> - Interface in com.hazelcast.map - mapFn(BiFunctionEx<ChangeStreamDocument<Document>, Long, T_NEW>) - Method in class com.hazelcast.jet.mongodb.MongoSourceBuilder.Stream
- mapFn(FunctionEx<Document, T_NEW>) - Method in class com.hazelcast.jet.mongodb.MongoSourceBuilder.Batch
- mapFrom(Object) - Static method in class com.hazelcast.jet.json.JsonUtil
-
Converts a JSON string to a
Map
. - MapInterceptor - Interface in com.hazelcast.map
-
MapInterceptor is used to intercept changes to the map, allowing access to the values before and after adding them to the map.
- mapJournal(IMap<? extends K, ? extends V>, JournalInitialPosition) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Convenience for
Sources.mapJournal(IMap, JournalInitialPosition, FunctionEx, PredicateEx)
which will pass onlyADDED
andUPDATED
events and will project the event's key and new value into aMap.Entry
. - mapJournal(IMap<? extends K, ? extends V>, JournalInitialPosition, FunctionEx<? super EventJournalMapEvent<K, V>, ? extends T>, PredicateEx<? super EventJournalMapEvent<K, V>>) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Returns a source that will stream
EventJournalMapEvent
s of the given HazelcastIMap
. - mapJournal(String, JournalInitialPosition) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Convenience for
Sources.mapJournal(String, JournalInitialPosition, FunctionEx, PredicateEx)
which will pass onlyADDED
andUPDATED
events and will project the event's key and new value into aMap.Entry
. - mapJournal(String, JournalInitialPosition, FunctionEx<? super EventJournalMapEvent<K, V>, ? extends T>, PredicateEx<? super EventJournalMapEvent<K, V>>) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Returns a source that will stream
EventJournalMapEvent
s of the HazelcastIMap
with the specified name. - MapListener - Interface in com.hazelcast.map.listener
-
A marker interface which is used to get notified upon a map or an entry event.
- MapLoader<K,
V> - Interface in com.hazelcast.map -
Hazelcast distributed map implementation is an in-memory data store, but it can be backed by any type of data store such as RDBMS, OODBMS, or simply a file-based data store.
- MapLoaderLifecycleSupport - Interface in com.hazelcast.map
-
Provides Lifecycle support for the implementing MapLoader class.
- mapP(FunctionEx<? super T, ? extends R>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for a vertex which, for each received item, emits the result of applying the given mapping function to it.
- MapPartitionLostEvent - Class in com.hazelcast.map
-
Used for providing information about the lost partition for a map
- MapPartitionLostEvent(Object, Member, int, int) - Constructor for class com.hazelcast.map.MapPartitionLostEvent
- MapPartitionLostListener - Interface in com.hazelcast.map.listener
-
Invoked when owner and all backups of a partition is lost for a specific map.
- MapPartitionLostListenerConfig - Class in com.hazelcast.config
-
Configuration for MapPartitionLostListener
- MapPartitionLostListenerConfig() - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfig
- MapPartitionLostListenerConfig(MapPartitionLostListenerConfig) - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfig
- MapPartitionLostListenerConfig(MapPartitionLostListener) - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfig
- MapPartitionLostListenerConfig(String) - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfig
- MapPermission - Class in com.hazelcast.security.permission
- MapPermission(String, String...) - Constructor for class com.hazelcast.security.permission.MapPermission
- mapping(FunctionEx<? super T, ? extends U>, AggregateOperation1<? super U, A, ? extends R>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Adapts an aggregate operation that takes items of type
U
to one that takes items of typeT
, by applying the given mapping function to each item. - mapPutEvents() - Static method in class com.hazelcast.jet.Util
-
Returns a predicate for
Sources.mapJournal(java.lang.String, com.hazelcast.jet.pipeline.JournalInitialPosition, com.hazelcast.function.FunctionEx<? super com.hazelcast.map.EventJournalMapEvent<K, V>, ? extends T>, com.hazelcast.function.PredicateEx<? super com.hazelcast.map.EventJournalMapEvent<K, V>>)
andSources.remoteMapJournal(java.lang.String, com.hazelcast.client.config.ClientConfig, com.hazelcast.jet.pipeline.JournalInitialPosition, com.hazelcast.function.FunctionEx<? super com.hazelcast.map.EventJournalMapEvent<K, V>, ? extends T>, com.hazelcast.function.PredicateEx<? super com.hazelcast.map.EventJournalMapEvent<K, V>>)
that passes onlyADDED
andUPDATED
events. - mapPutPermission(boolean, String) - Static method in class com.hazelcast.security.PermissionsUtil
- mapPutPermission(String) - Static method in class com.hazelcast.security.PermissionsUtil
- mapSequenceFrom(Reader) - Static method in class com.hazelcast.jet.json.JsonUtil
-
Returns an
Iterator
over the sequence of JSON objects parsed from givenreader
. - mapSequenceFrom(Path) - Static method in class com.hazelcast.jet.json.JsonUtil
-
Parses the file and returns a stream of
Map
. - MapSinkBuilder<T,
K, V> - Class in com.hazelcast.jet.pipeline -
Builder for a map that is used as sink.
- MapSinkBuilder(String) - Constructor for class com.hazelcast.jet.pipeline.MapSinkBuilder
-
Creates
MapSinkBuilder
to build a local or remote Map sink - MapSinkEntryProcessorBuilder<E,
K, V, R> - Class in com.hazelcast.jet.pipeline -
Parameters for using a map as a sink with an EntryProcessor
- MapSinkEntryProcessorBuilder(String) - Constructor for class com.hazelcast.jet.pipeline.MapSinkEntryProcessorBuilder
- mapStateful(long, SupplierEx<? extends S>, TriFunction<? super S, ? super K, ? super T, ? extends R>, TriFunction<? super S, ? super K, ? super Long, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
-
Attaches a stage that performs a stateful mapping operation.
- mapStateful(SupplierEx<? extends S>, BiFunctionEx<? super S, ? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- mapStateful(SupplierEx<? extends S>, BiFunctionEx<? super S, ? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Attaches a stage that performs a stateful mapping operation.
- mapStateful(SupplierEx<? extends S>, BiFunctionEx<? super S, ? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- mapStateful(SupplierEx<? extends S>, TriFunction<? super S, ? super K, ? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
- mapStateful(SupplierEx<? extends S>, TriFunction<? super S, ? super K, ? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
-
Attaches a stage that performs a stateful mapping operation.
- mapStateful(SupplierEx<? extends S>, TriFunction<? super S, ? super K, ? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
- mapStatefulP(long, FunctionEx<? super T, ? extends K>, ToLongFunctionEx<? super T>, Supplier<? extends S>, TriFunction<? super S, ? super K, ? super T, ? extends R>, TriFunction<? super S, ? super K, ? super Long, ? extends R>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for a vertex that performs a stateful mapping of its input.
- MapStore<K,
V> - Interface in com.hazelcast.map -
Hazelcast distributed map implementation is an in-memory data store, but it can be backed by any type of data store such as RDBMS, OODBMS, NOSQL, or simply a file-based data store.
- MAPSTORE_INIT_TIMEOUT - Static variable in class com.hazelcast.mapstore.GenericMapLoader
-
Timeout for initialization of GenericMapLoader
- MapStoreAdapter<K,
V> - Class in com.hazelcast.map -
Adapter for MapStore.
- MapStoreAdapter() - Constructor for class com.hazelcast.map.MapStoreAdapter
- MapStoreConfig - Class in com.hazelcast.config
-
Contains the configuration for a Map Store.
- MapStoreConfig() - Constructor for class com.hazelcast.config.MapStoreConfig
- MapStoreConfig(MapStoreConfig) - Constructor for class com.hazelcast.config.MapStoreConfig
- MapStoreConfig.InitialLoadMode - Enum Class in com.hazelcast.config
-
Initial load module
- MapStoreFactory<K,
V> - Interface in com.hazelcast.map -
Factory for MapLoader or MapStore instances, specifiable in MapStoreConfig.
- mapToItemFn(FunctionEx<? super SearchHit, T_NEW>) - Method in class com.hazelcast.jet.elastic.ElasticSourceBuilder
-
Set the function to map SearchHit to a pipeline item
- mapToRequestFn(FunctionEx<? super T_NEW, ? extends DocWriteRequest<?>>) - Method in class com.hazelcast.jet.elastic.ElasticSinkBuilder
-
Set the function mapping the item from a pipeline item to an index request
- mapUpdatePermission(boolean, String) - Static method in class com.hazelcast.security.PermissionsUtil
- mapUpdatePermission(String) - Static method in class com.hazelcast.security.PermissionsUtil
- mapUpdatePermission(String, String) - Static method in class com.hazelcast.security.PermissionsUtil
- mapUsingIMap(IMap<K, V>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
- mapUsingIMap(IMap<K, V>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
-
Attaches a mapping stage where for each item a lookup in the supplied
IMap
using the grouping key is performed and the result of the lookup is merged with the item and emitted. - mapUsingIMap(IMap<K, V>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
- mapUsingIMap(IMap<K, V>, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- mapUsingIMap(IMap<K, V>, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Attaches a mapping stage where for each item a lookup in the supplied
IMap
is performed and the result of the lookup is merged with the item and emitted. - mapUsingIMap(IMap<K, V>, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- mapUsingIMap(String, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
- mapUsingIMap(String, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
-
Attaches a mapping stage where for each item a lookup in the
IMap
with the supplied name using the grouping key is performed and the result of the lookup is merged with the item and emitted. - mapUsingIMap(String, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
- mapUsingIMap(String, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- mapUsingIMap(String, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Attaches a mapping stage where for each item a lookup in the
IMap
with the supplied name is performed and the result of the lookup is merged with the item and emitted. - mapUsingIMap(String, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- mapUsingPython(FunctionEx<? super String, ? extends K>, PythonServiceConfig) - Static method in class com.hazelcast.jet.python.PythonTransforms
-
Deprecated.Jet now has first-class support for data rebalancing, see
GeneralStage.rebalance()
andGeneralStage.rebalance(FunctionEx)
. - mapUsingPython(PythonServiceConfig) - Static method in class com.hazelcast.jet.python.PythonTransforms
-
A stage-transforming method that adds a "map using Python" pipeline stage.
- mapUsingPython(PythonServiceConfig, int) - Static method in class com.hazelcast.jet.python.PythonTransforms
-
A stage-transforming method that adds a "map using Python" pipeline stage.
- mapUsingPythonBatch(FunctionEx<? super String, ? extends K>, PythonServiceConfig) - Static method in class com.hazelcast.jet.python.PythonTransforms
-
Deprecated.Jet now has first-class support for data rebalancing, see
GeneralStage.rebalance()
andGeneralStage.rebalance(FunctionEx)
. - mapUsingPythonBatch(PythonServiceConfig) - Static method in class com.hazelcast.jet.python.PythonTransforms
-
A stage-transforming method that adds a "map using Python" pipeline stage.
- mapUsingPythonBatch(PythonServiceConfig, int) - Static method in class com.hazelcast.jet.python.PythonTransforms
-
A stage-transforming method that adds a "map using Python" pipeline stage.
- mapUsingReplicatedMap(ReplicatedMap<K, V>, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- mapUsingReplicatedMap(ReplicatedMap<K, V>, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Attaches a mapping stage where for each item a lookup in the supplied
ReplicatedMap
is performed and the result of the lookup is merged with the item and emitted. - mapUsingReplicatedMap(ReplicatedMap<K, V>, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- mapUsingReplicatedMap(String, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- mapUsingReplicatedMap(String, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Attaches a mapping stage where for each item a lookup in the
ReplicatedMap
with the supplied name is performed and the result of the lookup is merged with the item and emitted. - mapUsingReplicatedMap(String, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- mapUsingService(ServiceFactory<?, S>, BiFunctionEx<? super S, ? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- mapUsingService(ServiceFactory<?, S>, BiFunctionEx<? super S, ? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Attaches a mapping stage which applies the supplied function to each input item independently and emits the function's result as the output item.
- mapUsingService(ServiceFactory<?, S>, BiFunctionEx<? super S, ? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- mapUsingService(ServiceFactory<?, S>, TriFunction<? super S, ? super K, ? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
- mapUsingService(ServiceFactory<?, S>, TriFunction<? super S, ? super K, ? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
-
Deprecated.Jet now has first-class support for data rebalancing, see
GeneralStage.rebalance()
andGeneralStage.rebalance(FunctionEx)
. - mapUsingService(ServiceFactory<?, S>, TriFunction<? super S, ? super K, ? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
- mapUsingServiceAsync(ServiceFactory<?, S>, int, boolean, BiFunctionEx<? super S, ? super T, ? extends CompletableFuture<R>>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- mapUsingServiceAsync(ServiceFactory<?, S>, int, boolean, BiFunctionEx<? super S, ? super T, ? extends CompletableFuture<R>>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Asynchronous version of
GeneralStage.mapUsingService(com.hazelcast.jet.pipeline.ServiceFactory<?, S>, com.hazelcast.function.BiFunctionEx<? super S, ? super T, ? extends R>)
: themapAsyncFn
returns aCompletableFuture<R>
instead of justR
. - mapUsingServiceAsync(ServiceFactory<?, S>, int, boolean, BiFunctionEx<? super S, ? super T, ? extends CompletableFuture<R>>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- mapUsingServiceAsync(ServiceFactory<?, S>, int, boolean, TriFunction<? super S, ? super K, ? super T, CompletableFuture<R>>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
- mapUsingServiceAsync(ServiceFactory<?, S>, int, boolean, TriFunction<? super S, ? super K, ? super T, CompletableFuture<R>>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
-
Deprecated.Jet now has first-class support for data rebalancing, see
GeneralStage.rebalance()
andGeneralStage.rebalance(FunctionEx)
. - mapUsingServiceAsync(ServiceFactory<?, S>, int, boolean, TriFunction<? super S, ? super K, ? super T, CompletableFuture<R>>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
- mapUsingServiceAsync(ServiceFactory<?, S>, BiFunctionEx<? super S, ? super T, ? extends CompletableFuture<R>>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- mapUsingServiceAsync(ServiceFactory<?, S>, BiFunctionEx<? super S, ? super T, ? extends CompletableFuture<R>>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Asynchronous version of
GeneralStage.mapUsingService(com.hazelcast.jet.pipeline.ServiceFactory<?, S>, com.hazelcast.function.BiFunctionEx<? super S, ? super T, ? extends R>)
: themapAsyncFn
returns aCompletableFuture<R>
instead of justR
. - mapUsingServiceAsync(ServiceFactory<?, S>, BiFunctionEx<? super S, ? super T, ? extends CompletableFuture<R>>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- mapUsingServiceAsync(ServiceFactory<?, S>, TriFunction<? super S, ? super K, ? super T, CompletableFuture<R>>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
- mapUsingServiceAsync(ServiceFactory<?, S>, TriFunction<? super S, ? super K, ? super T, CompletableFuture<R>>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
-
Deprecated.Jet now has first-class support for data rebalancing, see
GeneralStage.rebalance()
andGeneralStage.rebalance(FunctionEx)
. - mapUsingServiceAsync(ServiceFactory<?, S>, TriFunction<? super S, ? super K, ? super T, CompletableFuture<R>>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
- mapUsingServiceAsyncBatched(ServiceFactory<?, S>, int, BiFunctionEx<? super S, ? super List<T>, ? extends CompletableFuture<List<R>>>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- mapUsingServiceAsyncBatched(ServiceFactory<?, S>, int, BiFunctionEx<? super S, ? super List<T>, ? extends CompletableFuture<List<R>>>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
- mapUsingServiceAsyncBatched(ServiceFactory<?, S>, int, BiFunctionEx<? super S, ? super List<T>, ? extends CompletableFuture<List<R>>>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Batched version of
GeneralStage.mapUsingServiceAsync(com.hazelcast.jet.pipeline.ServiceFactory<?, S>, com.hazelcast.function.BiFunctionEx<? super S, ? super T, ? extends java.util.concurrent.CompletableFuture<R>>)
:mapAsyncFn
takes a list of input items and returns aCompletableFuture<List<R>>
. - mapUsingServiceAsyncBatched(ServiceFactory<?, S>, int, BiFunctionEx<? super S, ? super List<T>, ? extends CompletableFuture<List<R>>>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
-
Deprecated.Jet now has first-class support for data rebalancing, see
GeneralStage.rebalance()
andGeneralStage.rebalance(FunctionEx)
. - mapUsingServiceAsyncBatched(ServiceFactory<?, S>, int, BiFunctionEx<? super S, ? super List<T>, ? extends CompletableFuture<List<R>>>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- mapUsingServiceAsyncBatched(ServiceFactory<?, S>, int, BiFunctionEx<? super S, ? super List<T>, ? extends CompletableFuture<List<R>>>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
- mapUsingServiceAsyncBatched(ServiceFactory<?, S>, int, TriFunction<? super S, ? super List<K>, ? super List<T>, ? extends CompletableFuture<List<R>>>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
- mapUsingServiceAsyncBatched(ServiceFactory<?, S>, int, TriFunction<? super S, ? super List<K>, ? super List<T>, ? extends CompletableFuture<List<R>>>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
-
Deprecated.Jet now has first-class support for data rebalancing, see
GeneralStage.rebalance()
andGeneralStage.rebalance(FunctionEx)
. - mapUsingServiceAsyncBatched(ServiceFactory<?, S>, int, TriFunction<? super S, ? super List<K>, ? super List<T>, ? extends CompletableFuture<List<R>>>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
- mapUsingServiceAsyncP(ServiceFactory<C, S>, int, boolean, FunctionEx<T, K>, BiFunctionEx<? super S, ? super T, CompletableFuture<R>>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Asynchronous version of
Processors.mapUsingServiceP(com.hazelcast.jet.pipeline.ServiceFactory<C, S>, com.hazelcast.function.BiFunctionEx<? super S, ? super T, ? extends R>)
: themapAsyncFn
returns aCompletableFuture<R>
instead of justR
. - mapUsingServiceP(ServiceFactory<C, S>, BiFunctionEx<? super S, ? super T, ? extends R>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for a vertex which, for each received item, emits the result of applying the given mapping function to it.
- mapWithEntryProcessor(int, String, FunctionEx<? super E, ? extends K>, FunctionEx<? super E, ? extends EntryProcessor<K, V, R>>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink that uses the items it receives to create
EntryProcessor
s it submits to a HazelcastIMap
with the specified name. - mapWithEntryProcessor(IMap<? super K, ? super V>, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends EntryProcessor<K, V, R>>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink that uses the items it receives to create
EntryProcessor
s it submits to a HazelcastIMap
with the specified name. - mapWithEntryProcessor(String, FunctionEx<? super E, ? extends K>, FunctionEx<? super E, ? extends EntryProcessor<K, V, R>>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Convenience for
Sinks.mapWithEntryProcessor(int, String, FunctionEx, FunctionEx)
when the maximum number of async operations is not specified. - mapWithMerging(IMap<? super K, ? super V>, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends V>, BinaryOperatorEx<V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink that uses the supplied functions to extract the key and value with which to update a Hazelcast
IMap
. - mapWithMerging(IMap<? super K, V>, BinaryOperatorEx<V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Convenience for
Sinks.mapWithMerging(IMap, FunctionEx, FunctionEx, BinaryOperatorEx)
withMap.Entry
as input item. - mapWithMerging(String, BinaryOperatorEx<V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Convenience for
Sinks.mapWithMerging(String, FunctionEx, FunctionEx, BinaryOperatorEx)
withMap.Entry
as input item. - mapWithMerging(String, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends V>, BinaryOperatorEx<V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink that uses the supplied functions to extract the key and value with which to update a Hazelcast
IMap
. - mapWithUpdating(IMap<? super K, ? super V>, BiFunctionEx<? super V, ? super E, ? extends V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Convenience for
Sinks.mapWithUpdating(IMap, FunctionEx, BiFunctionEx)
withMap.Entry
as the input item. - mapWithUpdating(IMap<? super K, ? super V>, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super V, ? super T, ? extends V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink that uses the supplied key-extracting and value-updating functions to update a Hazelcast
IMap
. - mapWithUpdating(String, BiFunctionEx<? super V, ? super E, ? extends V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Convenience for
Sinks.mapWithUpdating(String, FunctionEx, BiFunctionEx)
withMap.Entry
as the input item. - mapWithUpdating(String, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super V, ? super T, ? extends V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink that uses the supplied key-extracting and value-updating functions to update a Hazelcast
IMap
. - mark(int) - Method in class com.hazelcast.config.ConfigStream
- markEndpointAsUnhealthy(Address) - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategy
-
Marks the passed
Address
as unhealthy, which prevents it from being offered as a viable endpoint in someDiscoveryStrategy
implementations, usually prompting this endpoint to be periodically probed for liveliness. - markEndpointAsUnhealthy(Address) - Method in interface com.hazelcast.spi.discovery.integration.DiscoveryService
-
Marks the passed
Address
as unhealthy, which prevents it from being offered as a viable endpoint in someDiscoveryStrategy
implementations, usually prompting this endpoint to be periodically probed for liveliness. - markSupported() - Method in class com.hazelcast.config.ConfigStream
- mask - Variable in class com.hazelcast.security.permission.InstancePermission
- MASK_FOR_SENSITIVE_DATA - Static variable in class com.hazelcast.config.ConfigXmlGenerator
-
Mask to hide the sensitive values in configuration.
- MASTERSHIP_CLAIM_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The timeout which defines when master candidate gives up waiting for response to its mastership claim.
- MATCHERS_USAGE - Static variable in class com.hazelcast.test.archunit.ArchUnitRules
-
ArchUnit rule checking that Hamcrest matchers are not mixed with AssertJ.
- MatchersUsageCondition - Class in com.hazelcast.test.archunit
-
Hamcrest is great, but AssertJ is even better.
- MatchersUsageCondition() - Constructor for class com.hazelcast.test.archunit.MatchersUsageCondition
- matches(Iterable<String>, String) - Method in interface com.hazelcast.config.ConfigPatternMatcher
-
Returns the best match for an item name out of a list of configuration patterns.
- matches(Iterable<String>, String) - Method in class com.hazelcast.config.matcher.MatchingPointConfigPatternMatcher
- matches(Iterable<String>, String) - Method in class com.hazelcast.config.matcher.RegexConfigPatternMatcher
- matches(Iterable<String>, String) - Method in class com.hazelcast.config.matcher.WildcardConfigPatternMatcher
- matches(String, String) - Method in class com.hazelcast.config.matcher.WildcardConfigPatternMatcher
-
This method is public to be accessible by
InstancePermission
. - MatchingPointConfigPatternMatcher - Class in com.hazelcast.config.matcher
-
This
ConfigPatternMatcher
supports a simplified wildcard matching. - MatchingPointConfigPatternMatcher() - Constructor for class com.hazelcast.config.matcher.MatchingPointConfigPatternMatcher
- MAX_BACKUP_COUNT - Static variable in class com.hazelcast.config.CacheSimpleConfig
-
The maximum number of backups.
- MAX_BACKUP_COUNT - Static variable in class com.hazelcast.config.MapConfig
-
The maximum number of backups
- MAX_BACKUP_COUNT - Static variable in class com.hazelcast.config.vector.VectorCollectionConfig
-
The maximum number of backups
- MAX_CONCURRENT_INVOCATIONS - Static variable in class com.hazelcast.client.properties.ClientProperty
-
The maximum number of concurrent invocations allowed.
- MAX_GROUP_SIZE - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
-
The maximum number of CP members that can form a CP group.
- MAX_JOIN_MERGE_TARGET_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Split-brain merge timeout for a specific target.
- MAX_JOIN_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Join timeout, maximum time to try to join before giving up.
- MAX_NO_HEARTBEAT_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The timeout which defines when a cluster member is removed because it has not sent any heartbeats.
- MAX_RECORD_SIZE - Static variable in class com.hazelcast.jet.kinesis.KinesisSinks
-
The length of a record's data blob (byte array length), plus the record's key size (no. of Unicode characters in the key), must not be larger than 1MiB.
- MAX_WAIT_SECONDS_BEFORE_JOIN - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The maximum time that a newly-appointed master node waits before forming a cluster.
- maxAttempts(int) - Method in class com.hazelcast.jet.retry.RetryStrategies.Builder
-
Sets the maximum number of retry attempts.
- maxBy(ComparatorEx<? super T>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that computes the greatest item according to the given
comparator
. - maxBy(String) - Static method in class com.hazelcast.aggregation.Aggregators
- maxBy(Comparator<? super T>) - Static method in interface com.hazelcast.function.BinaryOperatorEx
-
Serializable
variant ofjava.util.function.BinaryOperator#maxBy(Comparator)
. - maxGuarantee(ProcessingGuarantee) - Method in class com.hazelcast.jet.pipeline.JmsSourceBuilder
-
Sets the maximum processing guarantee for the source.
- MAXIMUM_KEY_LENGTH - Static variable in class com.hazelcast.jet.kinesis.KinesisSinks
-
Kinesis partition keys are Unicode strings, with a maximum length limit of 256 characters for each key.
- MAXIMUM_PREFETCH_COUNT - Static variable in class com.hazelcast.config.FlakeIdGeneratorConfig
-
Maximum value for prefetch count.
- maxParallelAsyncOps(int) - Method in class com.hazelcast.jet.pipeline.MapSinkEntryProcessorBuilder
- maxProcessorAccumulatedRecords() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
-
Returns the maximum number of records that can be accumulated by any single
Processor
. - maxProcessorAccumulatedRecords() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
- maxSizePolicy - Variable in class com.hazelcast.config.EvictionConfig
- MaxSizePolicy - Enum Class in com.hazelcast.config
-
Maximum Size Policy
- MC_EXECUTOR_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The number of threads that the Management Center service has available for processing operations sent from connected Management Center instance.
- MC_MAX_VISIBLE_SLOW_OPERATION_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Management Center maximum visible slow operations count.
- Measurement - Class in com.hazelcast.jet.core.metrics
-
Immutable data class containing information about one metric measurement, consisting of: metric value metric timestamp, generated when the metric was gathered metric descriptor (set of tag name-value pairs)
- MEASUREMENT - Static variable in class com.hazelcast.jet.core.metrics.MetricsDataSerializerHook
-
Serialization ID of the
Measurement
class. - MeasurementPredicates - Class in com.hazelcast.jet.core.metrics
-
Static utility class for creating various
Measurement
filtering predicates. - megaBytes() - Method in class com.hazelcast.memory.Capacity
-
Returns value of the capacity in megabytes.
- MEGABYTES - Enum constant in enum class com.hazelcast.memory.MemoryUnit
-
MemoryUnit in megabytes
- member - Variable in class com.hazelcast.cluster.MembershipEvent
- Member - Enum constant in enum class com.hazelcast.spi.discovery.integration.DiscoveryMode
-
The current runtime environment is a Hazelcast member node
- Member - Interface in com.hazelcast.cluster
-
Cluster member interface.
- MEMBER - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
-
Unique ID of the cluster member sourcing the metric.
- MEMBER_ADDED - Static variable in class com.hazelcast.cluster.MembershipEvent
-
This event type is fired when a new member joins the cluster.
- MEMBER_ADDED - Static variable in interface com.hazelcast.cp.event.CPMembershipEvent
-
Member ADDED event ID.
- MEMBER_CACHING_PROVIDER - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
-
Class name of the member-side Caching Provider
- MEMBER_LIST_PUBLISH_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The interval at which the master sends the member lists are sent to other non-master members.
- MEMBER_LOGGING_LEVEL_RESET - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
-
Event type ID: Member logging level reset.
- MEMBER_LOGGING_LEVEL_SET - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
-
Event type ID: Member logging level set.
- MEMBER_REMOVED - Static variable in class com.hazelcast.cluster.MembershipEvent
-
This event type is fired if a member left the cluster or was decided to be unresponsive by other members for a extended time.
- MEMBER_REMOVED - Static variable in interface com.hazelcast.cp.event.CPMembershipEvent
-
Member REMOVED event ID.
- MEMBER_TEXT_SPLIT_PATTERN - Static variable in class com.hazelcast.config.TcpIpConfig
-
A pattern for splitting member texts defined in tcp-ip configuration by comma(,) semicolon(;) space( ).
- memberAdded(MembershipEvent) - Method in class com.hazelcast.cluster.MembershipAdapter
- memberAdded(MembershipEvent) - Method in interface com.hazelcast.cluster.MembershipListener
-
Invoked when a new member is added to the cluster.
- memberAdded(CPMembershipEvent) - Method in interface com.hazelcast.cp.event.CPMembershipListener
-
Called when a new CP member is added to the CP Subsystem.
- memberAddress - Variable in class com.hazelcast.jet.core.ProcessorMetaSupplier.SpecificMemberPms
- MemberAddressProvider - Interface in com.hazelcast.spi
-
IMPORTANT This interface is not intended to provide addresses of other cluster members with which the hazelcast instance will form a cluster.
- MemberAddressProviderConfig - Class in com.hazelcast.config
-
Configuration for a custom
MemberAddressProvider
strategy. - MemberAddressProviderConfig() - Constructor for class com.hazelcast.config.MemberAddressProviderConfig
- MemberAttributeConfig - Class in com.hazelcast.config
-
Contains configuration for attribute of member.
- MemberAttributeConfig() - Constructor for class com.hazelcast.config.MemberAttributeConfig
- MemberAttributeConfig(MemberAttributeConfig) - Constructor for class com.hazelcast.config.MemberAttributeConfig
- MemberConfigRecognizer - Class in com.hazelcast.config
-
ConfigRecognizer
implementation that recognizes Hazelcast member declarative configurations based on an extensible set of built-inConfigRecognizer
implementations. - MemberConfigRecognizer() - Constructor for class com.hazelcast.config.MemberConfigRecognizer
-
Constructs an instance with the built-in set of
ConfigRecognizer
implementations only. - MemberConfigRecognizer(ConfigRecognizer...) - Constructor for class com.hazelcast.config.MemberConfigRecognizer
-
Constructs an instance with the built-in set of
ConfigRecognizer
implementations extended with ones provided incustomRecognizers
. - memberCount() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
-
Returns the number of members running this job.
- memberCount() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
- MemberGroup - Interface in com.hazelcast.spi.partitiongroup
-
A collection of members to which a single partition replica can be assigned.
- MemberGroupConfig - Class in com.hazelcast.config
-
Contains the configuration for a single member group.
- MemberGroupConfig() - Constructor for class com.hazelcast.config.MemberGroupConfig
- memberIndex() - Method in interface com.hazelcast.jet.core.ProcessorSupplier.Context
-
Returns the index of the member among all the members that run this job: it's a unique cluster-wide index.
- memberIndex() - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
- MemberLeftException - Exception in com.hazelcast.core
-
A
ExecutionException
thrown when a member left during an invocation or execution. - MemberLeftException() - Constructor for exception com.hazelcast.core.MemberLeftException
- MemberLeftException(Member) - Constructor for exception com.hazelcast.core.MemberLeftException
- MemberLeftException(String) - Constructor for exception com.hazelcast.core.MemberLeftException
- MemberLeftException(Throwable) - Constructor for exception com.hazelcast.core.MemberLeftException
- memberPartitions() - Method in interface com.hazelcast.jet.core.ProcessorSupplier.Context
-
Returns the partitions from
ProcessorMetaSupplier.Context.partitionAssignment()
pertaining to this member. - memberRemoved(MembershipEvent) - Method in class com.hazelcast.cluster.MembershipAdapter
- memberRemoved(MembershipEvent) - Method in interface com.hazelcast.cluster.MembershipListener
-
Invoked when an existing member leaves the cluster.
- memberRemoved(CPMembershipEvent) - Method in interface com.hazelcast.cp.event.CPMembershipListener
-
Called when a CP member is removed from the CP Subsystem.
- members - Variable in class com.hazelcast.cluster.MembershipEvent
- members() - Method in interface com.hazelcast.cp.CPGroup
-
Returns current members of the CP group
- memberSelector() - Method in class com.hazelcast.jet.core.DAG
- MemberSelector - Interface in com.hazelcast.cluster
-
Implementations of this interface select members that are capable of executing a special kind of task.
TheMemberSelector.select(Member)
method is called for every available member in the cluster and it is up to the implementation to decide if the member is going to be used or not. - MemberSelectors - Class in com.hazelcast.cluster.memberselector
-
A utility class to get
MemberSelector
instances. - MembershipAdapter - Class in com.hazelcast.cluster
-
Adapter for MembershipListener.
- MembershipAdapter() - Constructor for class com.hazelcast.cluster.MembershipAdapter
- MembershipEvent - Class in com.hazelcast.cluster
-
Membership event fired when a new member is added to the cluster and/or when a member leaves the cluster and similar methods.
- MembershipEvent(Cluster, Member, int, Set<Member>) - Constructor for class com.hazelcast.cluster.MembershipEvent
- MembershipListener - Interface in com.hazelcast.cluster
-
Cluster membership listener.
- MemberSocketInterceptor - Interface in com.hazelcast.nio
-
Member Socket Interceptor can be registered via see
SocketInterceptorConfig
Warning: a MemberSocketInterceptor provides access to the socket and will bypass any TLS encryption. - MemberVersion - Class in com.hazelcast.version
-
Determines the Hazelcast codebase version in terms of major.minor.patch version.
- MemberVersion() - Constructor for class com.hazelcast.version.MemberVersion
- MemberVersion(int, int, int) - Constructor for class com.hazelcast.version.MemberVersion
- MemberVersion(String) - Constructor for class com.hazelcast.version.MemberVersion
- MemcacheProtocolConfig - Class in com.hazelcast.config
-
This class allows to enable MEMCACHE text protocol support in Hazelcast.
- MemcacheProtocolConfig() - Constructor for class com.hazelcast.config.MemcacheProtocolConfig
- MemorySize - Class in com.hazelcast.memory
-
Deprecated.Since 5.1,
Capacity
should be used instead. - MemorySize(long) - Constructor for class com.hazelcast.memory.MemorySize
-
Deprecated.
- MemorySize(long, MemoryUnit) - Constructor for class com.hazelcast.memory.MemorySize
-
Deprecated.
- MemoryTierConfig - Class in com.hazelcast.config
-
Memory tier configuration of Tiered-Store.
- MemoryTierConfig() - Constructor for class com.hazelcast.config.MemoryTierConfig
- MemoryTierConfig(MemoryTierConfig) - Constructor for class com.hazelcast.config.MemoryTierConfig
- MemoryUnit - Enum Class in com.hazelcast.memory
-
MemoryUnit represents memory size at a given unit of granularity and provides utility methods to convert across units.
- merge(BatchStage<? extends T>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
-
Attaches a stage that emits all the items from this stage as well as all the items from the supplied stage.
- merge(StreamStage<? extends T>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
-
Attaches a stage that emits all the items from this stage as well as all the items from the supplied stage.
- merge(SplitBrainMergeTypes.CardinalityEstimatorMergeTypes, SplitBrainMergeTypes.CardinalityEstimatorMergeTypes) - Method in class com.hazelcast.spi.merge.HyperLogLogMergePolicy
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in interface com.hazelcast.map.IMap
- merge(T, T) - Method in class com.hazelcast.spi.merge.DiscardMergePolicy
- merge(T, T) - Method in class com.hazelcast.spi.merge.ExpirationTimeMergePolicy
- merge(T, T) - Method in class com.hazelcast.spi.merge.HigherHitsMergePolicy
- merge(T, T) - Method in class com.hazelcast.spi.merge.LatestAccessMergePolicy
- merge(T, T) - Method in class com.hazelcast.spi.merge.LatestUpdateMergePolicy
- merge(T, T) - Method in class com.hazelcast.spi.merge.PassThroughMergePolicy
- merge(T, T) - Method in class com.hazelcast.spi.merge.PutIfAbsentMergePolicy
- merge(T, T) - Method in interface com.hazelcast.spi.merge.SplitBrainMergePolicy
-
Selects the value of either the merging or the existing
MergingValue
which should be merged. - MERGE_FAILED - Enum constant in enum class com.hazelcast.core.LifecycleEvent.LifecycleState
-
Fired when the merge process failed for some reason.
- MERGE_FIRST_RUN_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The delay until the first run of the split-brain handler.
- MERGE_NEXT_RUN_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The interval between invocations of the split-brain handler.
- MERGED - Enum constant in enum class com.hazelcast.core.EntryEventType
-
Fired if an entry is merged after a network partition.
- MERGED - Enum constant in enum class com.hazelcast.core.LifecycleEvent.LifecycleState
-
Fired when the merge process was successful and all data has been merged.
- mergeFn(BinaryOperatorEx<V>) - Method in class com.hazelcast.jet.pipeline.MapSinkBuilder
-
Set the function to merge the existing value with new value.
- mergeMapP(String, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends V>, BinaryOperatorEx<V>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for
Sinks.mapWithMerging(String, FunctionEx, FunctionEx, BinaryOperatorEx)
. - MergePolicyConfig - Class in com.hazelcast.config
-
Configuration for
SplitBrainMergePolicy
. - MergePolicyConfig() - Constructor for class com.hazelcast.config.MergePolicyConfig
- MergePolicyConfig(MergePolicyConfig) - Constructor for class com.hazelcast.config.MergePolicyConfig
- MergePolicyConfig(String, int) - Constructor for class com.hazelcast.config.MergePolicyConfig
- mergeRemoteMapP(String, ClientConfig, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends V>, BinaryOperatorEx<V>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for
Sinks.remoteMapWithMerging(String, ClientConfig, FunctionEx, FunctionEx, BinaryOperatorEx)
. - MERGING - Enum constant in enum class com.hazelcast.core.LifecycleEvent.LifecycleState
-
Fired on each cluster member just before the start of a merge process into another cluster.
- MergingCosts - Interface in com.hazelcast.spi.merge
-
Represents a read-only view of memory costs for the merging process after a split-brain.
- MergingCreationTime - Interface in com.hazelcast.spi.merge
-
Represents a read-only view of a creation time for the merging process after a split-brain.
- MergingEntry<K,
V> - Interface in com.hazelcast.spi.merge -
Represents a read-only view of a data structure key/value-pair for the merging process after a split-brain.
- MergingExpirationTime - Interface in com.hazelcast.spi.merge
-
Represents a read-only view of an expiration time for the merging process after a split-brain.
- MergingHits - Interface in com.hazelcast.spi.merge
-
Represents a read-only view access hits for the merging process after a split-brain.
- MergingLastAccessTime - Interface in com.hazelcast.spi.merge
-
Represents a read-only view of a last access time for the merging process after a split-brain.
- MergingLastStoredTime - Interface in com.hazelcast.spi.merge
-
Represents a read-only view of a last stored time for the merging process after a split-brain.
- MergingLastUpdateTime - Interface in com.hazelcast.spi.merge
-
Represents a read-only view of a last update time for the merging process after a split-brain.
- MergingMaxIdle - Interface in com.hazelcast.spi.merge
-
Represents a read-only view of a MaxIdle for the merging process after a split-brain.
- MergingTTL - Interface in com.hazelcast.spi.merge
-
Represents a read-only view of a TTL for the merging process after a split-brain.
- mergingValue - Variable in class com.hazelcast.core.EntryEvent
- MergingValue<V> - Interface in com.hazelcast.spi.merge
-
Represents a read-only view of a data structure value for the merging process after a split-brain.
- MergingVersion - Interface in com.hazelcast.spi.merge
-
Represents a read-only view of a version for the merging process after a split-brain.
- MergingView - Interface in com.hazelcast.spi.merge
-
Marker interface representing a read-only view of a data structure for the merging process after a split-brain.
- MERKLE_TREES - Enum constant in enum class com.hazelcast.config.ConsistencyCheckStrategy
-
Uses merkle trees (if configured) for consistency checks.
- MerkleTreeConfig - Class in com.hazelcast.config
-
Configuration for a merkle tree.
- MerkleTreeConfig() - Constructor for class com.hazelcast.config.MerkleTreeConfig
- MerkleTreeConfig(MerkleTreeConfig) - Constructor for class com.hazelcast.config.MerkleTreeConfig
-
Clones a
MerkleTreeConfig
. - message() - Method in interface com.hazelcast.auditlog.AuditableEvent
-
Return a text description of the event.
- message(String) - Method in interface com.hazelcast.auditlog.EventBuilder
- Message<E> - Class in com.hazelcast.topic
-
Message for
ITopic
. - Message(String, E, long, Member) - Constructor for class com.hazelcast.topic.Message
- messageFn(BiFunctionEx<Session, T, Message>) - Method in class com.hazelcast.jet.pipeline.JmsSinkBuilder
-
Sets the function which creates the message from the item.
- messageIdFn(FunctionEx<? super Message, ?>) - Method in class com.hazelcast.jet.pipeline.JmsSourceBuilder
-
Configures the function to extract IDs from the messages, if exactly-once guarantee is used.
- MessageListener<E> - Interface in com.hazelcast.topic
-
Message listener for
ITopic
. - messageObject - Variable in class com.hazelcast.topic.Message
- METADATA_CP_GROUP_NAME - Static variable in interface com.hazelcast.cp.CPGroup
-
Name of the internal CP group that is used for maintaining CP groups and CP members
- MetadataAwareValue(V) - Constructor for class com.hazelcast.map.EntryLoader.MetadataAwareValue
-
Creates a value without attaching an expiration time
- MetadataAwareValue(V, long) - Constructor for class com.hazelcast.map.EntryLoader.MetadataAwareValue
-
Creates a value and attaches an expiration time to it.
- MetadataPolicy - Enum Class in com.hazelcast.config
-
Hazelcast may process objects of supported types ahead of time to create additional metadata about them.
- metric() - Method in class com.hazelcast.jet.core.metrics.Measurement
-
Returns the name of the metric.
- metric(String) - Static method in class com.hazelcast.jet.core.metrics.Metrics
-
Returns a non-thread-safe handler for manipulating the metric with the specified name.
- metric(String, Unit) - Static method in class com.hazelcast.jet.core.metrics.Metrics
-
Same as
Metrics.metric(String)
, but allows us to also specify the measurementUnit
of the metric. - Metric - Enum Class in com.hazelcast.config.vector
-
Vector similarity metrics: These are utilized in search algorithms to retrieve the top K most similar vectors to a target vector.
- Metric - Interface in com.hazelcast.jet.core.metrics
-
Handler for manipulating one user-defined metric.
- MetricNames - Class in com.hazelcast.jet.core.metrics
-
Each metric provided by Jet has a specific name which conceptually identifies what it's being used to measure.
- metrics() - Method in class com.hazelcast.jet.core.metrics.JobMetrics
-
Returns all metrics present.
- Metrics - Class in com.hazelcast.jet.core.metrics
-
Utility class for obtaining handlers to user-defined metrics.
- METRICS_COLLECTION_FREQUENCY - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Sets the metrics collection frequency in seconds.
- METRICS_COLLECTION_FREQUENCY - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Sets the metrics collection frequency in seconds.
- METRICS_DATASTRUCTURES - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Enables/disables collecting metrics from the distributed data structures.
- METRICS_DEBUG - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Enables collecting debug metrics.
- METRICS_DEBUG - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Enables collecting debug metrics.
- METRICS_ENABLED - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Enables/disables metrics collection altogether.
- METRICS_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Enables/disables metrics collection altogether.
- METRICS_JMX_ENABLED - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Enables/disables exposing metrics on JMX.
- METRICS_JMX_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Enables/disables exposing metrics on JMX.
- METRICS_MC_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Enables/disables collecting metrics for Management Center.
- METRICS_MC_RETENTION - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Sets the duration in seconds for which the collected metrics are retained and Management Center can consume them.
- METRICS_USER_CODE_NAMESPACES - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Enables/disables collecting metrics from user code namespaces.
- MetricsConfig - Class in com.hazelcast.config
-
Member-side metrics collection configuration.
- MetricsConfig() - Constructor for class com.hazelcast.config.MetricsConfig
- MetricsConfig(MetricsConfig) - Constructor for class com.hazelcast.config.MetricsConfig
- MetricsDataSerializerHook - Class in com.hazelcast.jet.core.metrics
-
A Java Service Provider hook for Hazelcast's Identified Data Serializable mechanism.
- MetricsDataSerializerHook() - Constructor for class com.hazelcast.jet.core.metrics.MetricsDataSerializerHook
- MetricsJmxConfig - Class in com.hazelcast.config
-
JMX related metrics configuration.
- MetricsJmxConfig() - Constructor for class com.hazelcast.config.MetricsJmxConfig
- MetricsJmxConfig(MetricsJmxConfig) - Constructor for class com.hazelcast.config.MetricsJmxConfig
- MetricsManagementCenterConfig - Class in com.hazelcast.config
-
Management Center related metrics configuration.
- MetricsManagementCenterConfig() - Constructor for class com.hazelcast.config.MetricsManagementCenterConfig
- MetricsManagementCenterConfig(MetricsManagementCenterConfig) - Constructor for class com.hazelcast.config.MetricsManagementCenterConfig
- MetricTags - Class in com.hazelcast.jet.core.metrics
-
Metric descriptors are formed from a comma separated list of
tag_name=tag_value
pairs. - migrationFinished(MigrationState) - Method in interface com.hazelcast.partition.MigrationListener
-
Called when the migration process finishes.
- MigrationListener - Interface in com.hazelcast.partition
-
MigrationListener provides the ability to listen to partition migration process and events.
- migrationStarted(MigrationState) - Method in interface com.hazelcast.partition.MigrationListener
-
Called when the migration process starts.
- MigrationState - Interface in com.hazelcast.partition
-
MigrationState shows statistical information about the migration, such as; migration start time, number of planned replica migrations, number of completed replica migrations, total elapsed migration time etc.
- MILLIS_BEHIND_LATEST_METRIC - Static variable in class com.hazelcast.jet.kinesis.KinesisSources
-
Name of the metric exposed by the source, used to monitor if reading a specific shard is delayed or not.
- MIN_BACKUP_COUNT - Static variable in class com.hazelcast.config.CacheSimpleConfig
-
The minimum number of backups.
- MIN_BACKUP_COUNT - Static variable in class com.hazelcast.config.MapConfig
-
The minimum number of backups
- MIN_BACKUP_COUNT - Static variable in class com.hazelcast.config.vector.VectorCollectionConfig
-
The minimum number of backups
- MIN_GROUP_SIZE - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
-
The minimum number of CP members that can form a CP group.
- MIN_INITIAL_MEMORY_SIZE - Static variable in class com.hazelcast.config.NativeMemoryConfig
-
Minimum initial memory size in megabytes
- minBy(ComparatorEx<? super T>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that computes the least item according to the given
comparator
. - minBy(String) - Static method in class com.hazelcast.aggregation.Aggregators
- minBy(Comparator<? super T>) - Static method in interface com.hazelcast.function.BinaryOperatorEx
-
Serializable
variant ofjava.util.function.BinaryOperator#minBy(Comparator)
. - minimumClusterSize - Variable in class com.hazelcast.config.SplitBrainProtectionConfigBuilder
-
The minimum cluster size: expected number of live members in cluster not to be considered it split
- MixTestAnnotationsCondition - Class in com.hazelcast.test.archunit
- MixTestAnnotationsCondition() - Constructor for class com.hazelcast.test.archunit.MixTestAnnotationsCondition
- MOBY_NAMING_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Defines whether Moby Names should be used for instance name generating when it is not provided by user.
- MODE - Enum constant in enum class com.hazelcast.config.InstanceTrackingConfig.InstanceTrackingProperties
-
The instance mode, e.g.
- MODIFIED - Enum constant in enum class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
-
Expiry policy type for the
ModifiedExpiryPolicy
. - MODULE - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
-
Source system or module, value is always
"jet"
. - ModuleImportOptions - Class in com.hazelcast.test.archunit
- MongoDataConnection - Class in com.hazelcast.jet.mongodb.dataconnection
-
Creates a MongoDB DataConnection.
- MongoDataConnection(DataConnectionConfig) - Constructor for class com.hazelcast.jet.mongodb.dataconnection.MongoDataConnection
-
Creates a new data connection based on given config.
- mongoDataConnectionConf(String, String) - Static method in class com.hazelcast.jet.mongodb.dataconnection.MongoDataConnection
-
Helper method to create new
MongoDataConnection
with given name and connection string. - mongodb(DataConnectionRef, String, String) - Static method in class com.hazelcast.jet.mongodb.MongoSinks
- mongodb(String, String, String) - Static method in class com.hazelcast.jet.mongodb.MongoSinks
- MongoSinkBuilder<T> - Class in com.hazelcast.jet.mongodb
- MongoSinks - Class in com.hazelcast.jet.mongodb
-
Contains factory methods for MongoDB sinks.
- MongoSourceBuilder - Class in com.hazelcast.jet.mongodb
-
Top-level class for MongoDB custom source builders.
- MongoSourceBuilder.Batch<T> - Class in com.hazelcast.jet.mongodb
- MongoSourceBuilder.Stream<T> - Class in com.hazelcast.jet.mongodb
- MongoSources - Class in com.hazelcast.jet.mongodb
-
Contains factory methods for MongoDB sources.
- MOUNTED - Enum constant in enum class com.hazelcast.config.PersistentMemoryMode
-
The persistent memory is mounted into the file system (aka FS DAX mode).
- MS - Enum constant in enum class com.hazelcast.jet.core.metrics.Unit
-
Timestamp or duration represented in ms
- multiAttribute(String...) - Static method in class com.hazelcast.projection.Projections
-
Returns a projection that extracts the value of the given
attributePaths
. - MULTICAST_GROUP - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
IP address of a multicast group.
- MULTICAST_SOCKET_SET_INTERFACE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Allows explicitly control if the
MulticastSocket.setInterface(java.net.InetAddress)
method is called in the Hazelcast multicast discovery service. - MulticastConfig - Class in com.hazelcast.config
-
Contains the configuration for the multicast discovery mechanism.
- MulticastConfig() - Constructor for class com.hazelcast.config.MulticastConfig
- MulticastDiscoveryStrategy - Class in com.hazelcast.spi.discovery.multicast
-
The multicast
DiscoveryStrategy
. - MulticastDiscoveryStrategy(DiscoveryNode, ILogger, Map<String, Comparable>) - Constructor for class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategy
- MulticastDiscoveryStrategyFactory - Class in com.hazelcast.spi.discovery.multicast
-
Factory class which returns
MulticastDiscoveryStrategy
to Discovery SPI - MulticastDiscoveryStrategyFactory() - Constructor for class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategyFactory
- MulticastProperties - Class in com.hazelcast.spi.discovery.multicast
-
Defines the name and default value for the Multicast Discovery Strategy.
- MultiExecutionCallback - Interface in com.hazelcast.core
-
MultiExecutionCallback provides notification for when an execution is completed on each member that a task is submitted to.
- multiline(boolean) - Method in class com.hazelcast.jet.pipeline.file.JsonFileFormat
-
Specifies if the Json parser should accept json records spanning multiple lines.
- MultiMap<K,
V> - Interface in com.hazelcast.multimap -
A specialized map whose keys can be associated with multiple values.
- MULTIMAP - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
-
MultiMap
- MultiMapConfig - Class in com.hazelcast.config
-
Configuration for MultiMap.
- MultiMapConfig() - Constructor for class com.hazelcast.config.MultiMapConfig
- MultiMapConfig(MultiMapConfig) - Constructor for class com.hazelcast.config.MultiMapConfig
- MultiMapConfig(String) - Constructor for class com.hazelcast.config.MultiMapConfig
- MultiMapConfig.ValueCollectionType - Enum Class in com.hazelcast.config
-
Type of value collection
- MultiMapPermission - Class in com.hazelcast.security.permission
- MultiMapPermission(String, String...) - Constructor for class com.hazelcast.security.permission.MultiMapPermission
- multiPartitionPredicate(Set<? extends Object>, Predicate<K, V>) - Static method in class com.hazelcast.query.Predicates
-
Creates a new partition predicate that restricts the execution of the target predicate to a subset of partitions.
- MutableReference<T> - Class in com.hazelcast.jet.accumulator
-
Mutable container of an object reference.
- MutableReference() - Constructor for class com.hazelcast.jet.accumulator.MutableReference
-
Creates a new instance with a
null
value. - MutableReference(T) - Constructor for class com.hazelcast.jet.accumulator.MutableReference
-
Creates a new instance with the specified value.
- MutationDisallowedException - Exception in com.hazelcast.crdt
-
Exception that indicates that the state found on this replica disallows mutation.
- MutationDisallowedException(String) - Constructor for exception com.hazelcast.crdt.MutationDisallowedException
- mysql(String) - Static method in class com.hazelcast.jet.cdc.mysql.MySqlCdcSources
-
Creates a CDC source that streams change data from a MySQL database to Hazelcast Jet.
- MySqlCdcSources - Class in com.hazelcast.jet.cdc.mysql
-
Contains factory methods for creating change data capture sources based on MySQL databases.
- MySqlCdcSources.Builder - Class in com.hazelcast.jet.cdc.mysql
-
Builder for configuring a CDC source that streams change data from a MySQL database to Hazelcast Jet.
N
- name - Variable in class com.hazelcast.config.EndpointConfig
- name - Variable in class com.hazelcast.jet.mongodb.MongoSourceBuilder.Stream
- name - Variable in class com.hazelcast.map.AbstractIMapEvent
- name() - Method in interface com.hazelcast.cp.CPObjectInfo
-
Name of the object
- name() - Method in class com.hazelcast.dataconnection.DataConnectionResource
-
Name of the resource, e.g. name of the JDBC table, including any namespace prefix such as schema.
- name() - Method in interface com.hazelcast.jet.core.metrics.Metric
-
Returns the name of the associated metric.
- name() - Method in class com.hazelcast.jet.JobStateSnapshot
-
Returns the snapshot name.
- name() - Method in interface com.hazelcast.jet.Observable
-
Name of this instance.
- name() - Method in interface com.hazelcast.jet.pipeline.BatchSource
-
Returns a descriptive name of this source.
- name() - Method in interface com.hazelcast.jet.pipeline.Sink
-
Returns a descriptive name for this sink.
- name() - Method in interface com.hazelcast.jet.pipeline.Stage
-
Returns the name of this stage.
- name() - Method in interface com.hazelcast.jet.pipeline.StreamSource
-
Returns a descriptive name of this source.
- name() - Method in record class com.hazelcast.vector.Hint
-
Returns the value of the
name
record component. - named(String, Runnable) - Static method in class com.hazelcast.scheduledexecutor.TaskUtils
- named(String, Callable<V>) - Static method in class com.hazelcast.scheduledexecutor.TaskUtils
- NamedConfig - Interface in com.hazelcast.config
-
Interface for hazelcast data structures with name
- NamedTask - Interface in com.hazelcast.scheduledexecutor
-
The
NamedTask
interface should be implemented by any task that needs to have an identification and enhanced atomicity upon scheduling the task. - NAMESPACE - Static variable in class com.hazelcast.kubernetes.KubernetesProperties
-
Configuration key:
namespace
- namespaceConfigurations(ConfigXmlGenerator.XmlGenerator, Config) - Static method in class com.hazelcast.config.ConfigXmlGenerator
- namespacesConfiguration(ConfigXmlGenerator.XmlGenerator, Config) - Static method in class com.hazelcast.config.ConfigXmlGenerator
- NamespacesSupported - Annotation Interface in com.hazelcast.spi.annotation
-
Marker for interfaces that can be implemented by users and executed on clusters via User Code Deployment.
- NATIVE - Enum constant in enum class com.hazelcast.config.InMemoryFormat
-
As native storage
- NativeMemoryConfig - Class in com.hazelcast.config
-
Configures native memory region.
- NativeMemoryConfig() - Constructor for class com.hazelcast.config.NativeMemoryConfig
- NativeMemoryConfig(NativeMemoryConfig) - Constructor for class com.hazelcast.config.NativeMemoryConfig
- NativeMemoryConfig.MemoryAllocatorType - Enum Class in com.hazelcast.config
-
Type of memory allocator: STANDARD: allocate/free memory using default OS memory manager POOLED: manage memory blocks in pool
- NativeOutOfMemoryError - Error in com.hazelcast.memory
-
Thrown when Hazelcast cannot allocate required native memory.
- NativeOutOfMemoryError() - Constructor for error com.hazelcast.memory.NativeOutOfMemoryError
- NativeOutOfMemoryError(String) - Constructor for error com.hazelcast.memory.NativeOutOfMemoryError
- NativeOutOfMemoryError(String, Throwable) - Constructor for error com.hazelcast.memory.NativeOutOfMemoryError
- naturalOrder() - Static method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#naturalOrder()
. - NearCacheConfig - Class in com.hazelcast.config
-
Contains the configuration for a Near Cache.
- NearCacheConfig() - Constructor for class com.hazelcast.config.NearCacheConfig
- NearCacheConfig(NearCacheConfig) - Constructor for class com.hazelcast.config.NearCacheConfig
- NearCacheConfig(String) - Constructor for class com.hazelcast.config.NearCacheConfig
- NearCacheConfig.LocalUpdatePolicy - Enum Class in com.hazelcast.config
-
Defines how to reflect local updates to the Near Cache.
- NearCacheConfigAccessor - Class in com.hazelcast.config
-
Accessor for the
EvictionConfig
of aNearCacheConfig
to initialize the old default max size, if no size was configured by the user. - NearCachePreloaderConfig - Class in com.hazelcast.config
-
Configuration for storing and preloading Near Cache keys.
- NearCachePreloaderConfig() - Constructor for class com.hazelcast.config.NearCachePreloaderConfig
- NearCachePreloaderConfig(boolean, String) - Constructor for class com.hazelcast.config.NearCachePreloaderConfig
- NearCachePreloaderConfig(NearCachePreloaderConfig) - Constructor for class com.hazelcast.config.NearCachePreloaderConfig
- NearCachePreloaderConfig(String) - Constructor for class com.hazelcast.config.NearCachePreloaderConfig
- NearCacheStats - Interface in com.hazelcast.nearcache
-
Near Cache statistics to be used by
MemberState
implementations. - NEED - Enum constant in enum class com.hazelcast.config.rest.RestConfig.Ssl.ClientAuth
-
Client authentication is needed and mandatory.
- negate() - Method in interface com.hazelcast.function.BiPredicateEx
-
Serializable
variant ofjava.util.function.BiPredicate#negate()
. - negate() - Method in interface com.hazelcast.function.PredicateEx
-
Serializable
variant ofPredicate.negate()
. - negate() - Method in interface com.hazelcast.jet.function.TriPredicate
-
Returns a composite predicate which evaluates the equivalent of
!this.test(t, u, v)
. - NETWORK_CONNECT - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
-
Event type ID: Connection accepted.
- NETWORK_DISCONNECT - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
-
Event type ID: Connection closed.
- NETWORK_SELECT_PROTOCOL - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
-
Event type ID: Protocol selected.
- NETWORK_STATS_REFRESH_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The interval at which network stats (bytes sent and received) are re-calculated and published.
- NetworkConfig - Class in com.hazelcast.config
-
Contains configuration for Network.
- NetworkConfig() - Constructor for class com.hazelcast.config.NetworkConfig
- never() - Static method in class com.hazelcast.jet.retry.RetryStrategies
-
Create a strategy which will not retry a failed action.
- NEVER - Enum constant in enum class com.hazelcast.client.config.ClientSqlResubmissionMode
-
If a query fails, the failure is immediately forwarded to the caller.
- NEVER - Enum constant in enum class com.hazelcast.config.CacheDeserializedValues
-
Never cache de-serialized value
- NEVER - Enum constant in enum class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.PostgresSnapshotMode
-
Never perform a snapshot and only receive logical changes.
- NEVER - Enum constant in enum class com.hazelcast.jet.mongodb.ResourceChecks
-
Check won't be ever done, meaning that the database and collection will be created automatically by Mongo when it's accessed for the first time.
- newAliasedDiscoveryConfig(String, Map<String, String>) - Static method in class com.hazelcast.spring.config.ConfigFactory
- newBuilder() - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
-
Creates a
GenericRecordBuilder
allows to create a new object. - newBuilderWithClone() - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecord
-
Returned
GenericRecordBuilder
can be used to have exact copy and also just to update a couple of fields. - newClientConfig() - Static method in class com.hazelcast.spring.config.ConfigFactory
- newClientFailoverConfig() - Static method in class com.hazelcast.spring.config.ConfigFactory
- newClientTransactionContext(TransactionOptions, UUID) - Method in interface com.hazelcast.transaction.TransactionManagerService
- newCompactSerializationConfig(List<String>, List<String>) - Static method in class com.hazelcast.spring.config.ConfigFactory
- newCondition() - Method in interface com.hazelcast.cp.lock.FencedLock
-
NOT IMPLEMENTED.
- newConfig() - Static method in class com.hazelcast.spring.config.ConfigFactory
- newConsumer() - Method in class com.hazelcast.jet.kafka.KafkaDataConnection
-
Creates new instance of
KafkaConsumer
based on the DataConnection configuration. - newConsumer(Properties) - Method in class com.hazelcast.jet.kafka.KafkaDataConnection
-
Creates new instance of
KafkaConsumer
based on the DataConnection configuration and given properties parameter. - newCredentials() - Method in class com.hazelcast.config.security.StaticCredentialsFactory
- newCredentials() - Method in interface com.hazelcast.security.ICredentialsFactory
-
Creates new
Credentials
object. - newCredentials(Address) - Method in interface com.hazelcast.security.ICredentialsFactory
-
Creates new
Credentials
object for given targetAddress
. - newDiscoveryService(DiscoveryServiceSettings) - Method in interface com.hazelcast.spi.discovery.integration.DiscoveryServiceProvider
-
Instantiates a new instance of the
DiscoveryService
. - newDiscoveryStrategy(DiscoveryNode, ILogger, Map<String, Comparable>) - Method in class com.hazelcast.aws.AwsDiscoveryStrategyFactory
- newDiscoveryStrategy(DiscoveryNode, ILogger, Map<String, Comparable>) - Method in class com.hazelcast.azure.AzureDiscoveryStrategyFactory
- newDiscoveryStrategy(DiscoveryNode, ILogger, Map<String, Comparable>) - Method in class com.hazelcast.gcp.GcpDiscoveryStrategyFactory
- newDiscoveryStrategy(DiscoveryNode, ILogger, Map<String, Comparable>) - Method in class com.hazelcast.kubernetes.HazelcastKubernetesDiscoveryStrategyFactory
- newDiscoveryStrategy(DiscoveryNode, ILogger, Map<String, Comparable>) - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategyFactory
-
Instantiates a new instance of the
DiscoveryStrategy
with the given configuration properties. - newDiscoveryStrategy(DiscoveryNode, ILogger, Map<String, Comparable>) - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategyFactory
- newEvictionConfig(Integer, MaxSizePolicy, EvictionPolicy, boolean, boolean, String, EvictionPolicyComparator<?, ?, ?>) - Static method in class com.hazelcast.spring.config.ConfigFactory
- newHazelcastClient() - Static method in class com.hazelcast.client.HazelcastClient
-
Creates a new HazelcastInstance (a new client in a cluster).
- newHazelcastClient(ClientConfig) - Static method in class com.hazelcast.client.HazelcastClient
-
Creates a new HazelcastInstance (a new client in a cluster).
- newHazelcastFailoverClient() - Static method in class com.hazelcast.client.HazelcastClient
-
Creates a client with cluster switch capability.
- newHazelcastFailoverClient(ClientFailoverConfig) - Static method in class com.hazelcast.client.HazelcastClient
-
Creates a client with cluster switch capability.
- newHazelcastInstance() - Static method in class com.hazelcast.core.Hazelcast
-
Creates a new HazelcastInstance (a new node in a cluster).
- newHazelcastInstance() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
-
Creates a new
HazelcastOSGiInstance
on the owner bundle with default configuration. - newHazelcastInstance(Config) - Static method in class com.hazelcast.core.Hazelcast
-
Creates a new HazelcastInstance (a new node in a cluster).
- newHazelcastInstance(Config) - Method in interface com.hazelcast.osgi.HazelcastOSGiService
-
Creates a new
HazelcastOSGiInstance
on the owner bundle with specified configuration. - newId() - Method in interface com.hazelcast.flakeidgen.FlakeIdGenerator
-
Generates and returns a cluster-wide unique ID.
- newJetClient() - Static method in class com.hazelcast.jet.Jet
-
Deprecated.since 5.0 Use
HazelcastClient.newHazelcastClient()
and then getJetService
from the createdHazelcastInstance
client by usingHazelcastInstance.getJet()
}. - newJetClient(ClientConfig) - Static method in class com.hazelcast.jet.Jet
-
Deprecated.since 5.0 Use
HazelcastClient.newHazelcastClient(ClientConfig)
and then getJetService
from the createdHazelcastInstance
client by usingHazelcastInstance.getJet()
}. - newJetFailoverClient() - Static method in class com.hazelcast.jet.Jet
-
Deprecated.since 5.0 Use
HazelcastClient.newHazelcastFailoverClient()
and then getJetService
from the createdHazelcastInstance
client by usingHazelcastInstance.getJet()
}. - newJetFailoverClient(ClientFailoverConfig) - Static method in class com.hazelcast.jet.Jet
-
Deprecated.since 5.0 Use
HazelcastClient.newHazelcastFailoverClient(ClientFailoverConfig)
and then getJetService
from the createdHazelcastInstance
client by usingHazelcastInstance.getJet()
}. - newJetInstance() - Static method in class com.hazelcast.jet.Jet
-
Deprecated.since 5.0 Please use
Hazelcast.newHazelcastInstance()
and then getJetService
from the createdHazelcastInstance
by usingHazelcastInstance.getJet()
}. - newJetInstance(JetConfig) - Static method in class com.hazelcast.jet.Jet
-
Deprecated.since 5.0 Use
Hazelcast.newHazelcastInstance(Config)
and then getJetService
from the createdHazelcastInstance
by usingHazelcastInstance.getJet()
}. - newJob(DAG) - Method in interface com.hazelcast.jet.JetService
-
Creates and returns a Jet job based on the supplied DAG.
- newJob(DAG, JobConfig) - Method in interface com.hazelcast.jet.JetService
-
Creates and returns a Jet job based on the supplied DAG and job configuration.
- newJob(Pipeline) - Method in interface com.hazelcast.jet.JetService
-
Creates and returns an executable job based on the supplied pipeline.
- newJob(Pipeline, JobConfig) - Method in interface com.hazelcast.jet.JetService
-
Creates and returns a Jet job based on the supplied pipeline and job configuration.
- newJobBuilder(DAG) - Method in interface com.hazelcast.jet.JetService
-
Creates a
JobBuilder
for a new Jet job withDAG
definition. - newJobBuilder(Pipeline) - Method in interface com.hazelcast.jet.JetService
-
Creates a
JobBuilder
for a new Jet job withPipeline
definition. - newJobIfAbsent(DAG, JobConfig) - Method in interface com.hazelcast.jet.JetService
-
Creates and returns a Jet job based on the supplied DAG and job configuration.
- newJobIfAbsent(Pipeline, JobConfig) - Method in interface com.hazelcast.jet.JetService
-
Creates and returns a Jet job based on the supplied pipeline and job configuration.
- newLightJob(DAG) - Method in interface com.hazelcast.jet.JetService
-
Submits a job defined in the Core API with a default config.
- newLightJob(DAG, JobConfig) - Method in interface com.hazelcast.jet.JetService
-
Submits a job defined in the Core API.
- newLightJob(Pipeline) - Method in interface com.hazelcast.jet.JetService
-
Submits a new light job with a default config.
- newLightJob(Pipeline, JobConfig) - Method in interface com.hazelcast.jet.JetService
-
Submits a light job for execution.
- newLoggerFactory(String) - Static method in class com.hazelcast.logging.Logger
-
Creates a
logger factory
instance of the given preferred type. - newMapStore(String, Properties) - Method in interface com.hazelcast.map.MapStoreFactory
-
Produces a MapLoader or a MapStore for the given map name and properties.
- newObservable() - Method in interface com.hazelcast.jet.JetService
-
Returns a new observable with a randomly generated name
- newPermissionCollection() - Method in class com.hazelcast.security.permission.AllPermissions
- newPermissionCollection() - Method in class com.hazelcast.security.permission.ClusterPermission
- newPredicateBuilder() - Static method in class com.hazelcast.query.Predicates
-
Creates a new instance of
PredicateBuilder
. - newProbabilisticSplitBrainProtectionConfigBuilder(String, int) - Static method in class com.hazelcast.config.SplitBrainProtectionConfig
-
Returns a builder for
SplitBrainProtectionConfig
with the givenname
using a probabilistic split brain protection function, for the given split brain protectionsize
that is enabled by default. - newQueueStore(String, Properties) - Method in interface com.hazelcast.collection.QueueStoreFactory
- newRecentlyActiveSplitBrainProtectionConfigBuilder(String, int, int) - Static method in class com.hazelcast.config.SplitBrainProtectionConfig
-
Returns a builder for a
SplitBrainProtectionConfig
with the givenname
using a recently-active split brain protection function for the given split brain protectionsize
that is enabled by default. - newRingbufferStore(String, Properties) - Method in interface com.hazelcast.ringbuffer.RingbufferStoreFactory
- newTransactionContext() - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates a new TransactionContext associated with the current thread using default options.
- newTransactionContext(TransactionOptions) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates a new TransactionContext associated with the current thread with given options.
- newTransactionContext(TransactionOptions) - Method in interface com.hazelcast.transaction.TransactionManagerService
- newUniqueVertex(String, SupplierEx<? extends Processor>) - Method in class com.hazelcast.jet.core.DAG
-
Creates a vertex from a
Supplier<Processor>
and adds it to this DAG. - newUniqueVertex(String, ProcessorMetaSupplier) - Method in class com.hazelcast.jet.core.DAG
-
Creates a vertex from a
ProcessorMetaSupplier
and adds it to this DAG. - newUniqueVertex(String, ProcessorSupplier) - Method in class com.hazelcast.jet.core.DAG
-
Creates a vertex from a
ProcessorSupplier
and adds it to this DAG. - newValue() - Method in interface com.hazelcast.jet.cdc.ChangeRecord
-
Returns the new value of the record.
- newVertex(String, SupplierEx<? extends Processor>) - Method in class com.hazelcast.jet.core.DAG
-
Creates a vertex from a
Supplier<Processor>
and adds it to this DAG. - newVertex(String, ProcessorMetaSupplier) - Method in class com.hazelcast.jet.core.DAG
-
Creates a vertex from a
ProcessorMetaSupplier
and adds it to this DAG. - newVertex(String, ProcessorSupplier) - Method in class com.hazelcast.jet.core.DAG
-
Creates a vertex from a
ProcessorSupplier
and adds it to this DAG. - newWmPolicyFn() - Method in class com.hazelcast.jet.core.EventTimePolicy
-
Returns the factory of the watermark policy objects.
- next() - Method in interface com.hazelcast.client.LoadBalancer
-
Returns the next member to route to.
- next() - Method in class com.hazelcast.jet.core.AppendableTraverser
- next() - Method in class com.hazelcast.jet.core.ResettableSingletonTraverser
- next() - Method in interface com.hazelcast.jet.Traverser
-
Returns the next item, removing it from this traverser.
- next() - Method in class com.hazelcast.spi.merge.RingbufferMergeDataReadOnlyIterator
- nextDataMember() - Method in interface com.hazelcast.client.LoadBalancer
-
Deprecated.Since 5.0, the method is unused
- nextLine() - Method in class com.hazelcast.spi.utils.RestClient.WatchResponse
- nextPage() - Method in interface com.hazelcast.query.PagingPredicate
-
Sets the page value to next page.
- NO_JUNIT_MIXING - Static variable in class com.hazelcast.test.archunit.ArchUnitRules
-
ArchUnit rule checking that JUnit4 and JUnit5 annotations are not mixed within the same tes
- NO_MIGRATION - Enum constant in enum class com.hazelcast.cluster.ClusterState
-
In
NO_MIGRATION
state of the cluster, migrations (partition rebalancing) and backup replications are not allowed. - NO_NATIVE_TIME - Static variable in class com.hazelcast.jet.core.EventTimeMapper
-
Value to use as the
nativeEventTime
argument when callingEventTimeMapper.flatMapEvent(Object, int, long)
when there's no native event time to supply. - NO_OFFLOADING - Static variable in interface com.hazelcast.core.Offloadable
-
Constant meaning that there will be no off-loading if returned from the
Offloadable.getExecutorName()
method. - NO_TASK - Enum constant in enum class com.hazelcast.persistence.BackupTaskState
-
No backup task has yet been run
- NO_TIME_SET - Static variable in class com.hazelcast.map.EntryLoader.MetadataAwareValue
-
Represents no expiration time for a particular value
- noCorrespondingServicesException(Set<String>) - Method in class com.hazelcast.kubernetes.KubernetesApiEndpointSlicesProvider
- NoCredentialsException - Exception in com.hazelcast.spi.exception
-
Exception to indicate that no credentials are possible to retrieve.
- NoCredentialsException() - Constructor for exception com.hazelcast.spi.exception.NoCredentialsException
- NoCredentialsException(String, Throwable) - Constructor for exception com.hazelcast.spi.exception.NoCredentialsException
- NoDataMemberInClusterException - Exception in com.hazelcast.partition
-
Thrown when there is no data member in the cluster to assign partitions.
- NoDataMemberInClusterException(String) - Constructor for exception com.hazelcast.partition.NoDataMemberInClusterException
- node(String, Object, Object...) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
- NODE_AWARE - Enum constant in enum class com.hazelcast.config.PartitionGroupConfig.MemberGroupType
-
Node Aware.
- NodeFilter - Interface in com.hazelcast.spi.discovery
-
The NodeFilter, if supplied, will retrieve all discovered nodes and might apply additional filtering based on vendor provided metadata.
- nodeIfContents(String, Object, Object...) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
- noEventTime() - Static method in class com.hazelcast.jet.core.EventTimePolicy
-
Returns an event time policy that results in no timestamping.
- NoLogFactory - Class in com.hazelcast.logging
- NoLogFactory() - Constructor for class com.hazelcast.logging.NoLogFactory
- noLogger() - Static method in class com.hazelcast.logging.Logger
- NON_LOCAL_MEMBER_SELECTOR - Static variable in class com.hazelcast.cluster.memberselector.MemberSelectors
-
A
MemberSelector
instance that selects only remote members - NONE - Enum constant in enum class com.hazelcast.config.ConsistencyCheckStrategy
-
No consistency checks
- NONE - Enum constant in enum class com.hazelcast.config.EvictionPolicy
-
None
- NONE - Enum constant in enum class com.hazelcast.config.OnJoinPermissionOperationName
-
No-op - neither receives nor sends permissions.
- NONE - Enum constant in enum class com.hazelcast.config.rest.RestConfig.Ssl.ClientAuth
-
Client authentication is not wanted.
- NONE - Enum constant in enum class com.hazelcast.config.security.TokenEncoding
-
No token encoding used (ASCII charset expected).
- NONE - Enum constant in enum class com.hazelcast.jet.config.ProcessingGuarantee
-
No processing guarantees are given and no snapshots are taken during job execution.
- NONE - Static variable in class com.hazelcast.security.permission.InstancePermission
- noNodeNameAssignedException(Set<String>) - Method in class com.hazelcast.kubernetes.KubernetesApiEndpointSlicesProvider
- nonSharedService(FunctionEx<? super Processor.Context, ? extends S>) - Static method in class com.hazelcast.jet.pipeline.ServiceFactories
-
A variant of
nonSharedService(createFn, destroyFn)
with a no-opdestroyFn
. - nonSharedService(FunctionEx<? super Processor.Context, ? extends S>, ConsumerEx<? super S>) - Static method in class com.hazelcast.jet.pipeline.ServiceFactories
-
Returns a
ServiceFactory
which creates a separate service instance for each parallel Jet processor. - noop() - Static method in interface com.hazelcast.function.ConsumerEx
-
Returns a consumer that does nothing.
- noop() - Static method in interface com.hazelcast.jet.function.RunnableEx
- noop() - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink which discards all received items.
- NOOP_TENANT_CONTROL - Static variable in interface com.hazelcast.spi.tenantcontrol.TenantControl
-
Default no-op tenant control
- NOOP_TENANT_CONTROL_FACTORY - Static variable in interface com.hazelcast.spi.tenantcontrol.TenantControlFactory
-
Default tenant control factory.
- noopP() - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of a processor that swallows all its normal input (if any), does nothing with it, forwards the watermarks, produces no output and completes immediately.
- not(Predicate) - Static method in class com.hazelcast.query.Predicates
-
Creates a not predicate that will negate the result of the given
predicate
. - NOT_AVAILABLE - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
-
Represents fields that do not exist.
- NOT_RUNNING - Enum constant in enum class com.hazelcast.jet.core.JobStatus
-
The job is submitted but hasn't started yet.
- NOT_STARTED - Enum constant in enum class com.hazelcast.persistence.BackupTaskState
-
The backup task has been submitted but not yet started.
- notEqual(Comparable) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
- notEqual(String, Comparable) - Static method in class com.hazelcast.query.Predicates
-
Creates a not equal predicate that will pass items if the given
value
and the value stored under the given itemattribute
are not equal. - NotLeaderException - Exception in com.hazelcast.cp.exception
-
A
CPSubsystemException
which is thrown when a leader-only request is received by a non-leader member. - NotLeaderException(CPGroupId, RaftEndpoint, RaftEndpoint) - Constructor for exception com.hazelcast.cp.exception.NotLeaderException
- NotLeaderException(String, Throwable) - Constructor for exception com.hazelcast.cp.exception.NotLeaderException
- notMixJUnit4AndJUnit5Annotations() - Static method in class com.hazelcast.test.archunit.MixTestAnnotationsCondition
- notUseHamcrestMatchers() - Static method in class com.hazelcast.test.archunit.MatchersUsageCondition
- NULL - Enum constant in enum class com.hazelcast.sql.SqlColumnType
-
The type of the generic SQL
NULL
literal. - NULLABLE_BOOLEAN - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
-
Supported only for
Compact
. - NULLABLE_FLOAT32 - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
-
Supported only for
Compact
. - NULLABLE_FLOAT64 - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
-
Supported only for
Compact
. - NULLABLE_INT16 - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
-
Supported only for
Compact
. - NULLABLE_INT32 - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
-
Supported only for
Compact
. - NULLABLE_INT64 - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
-
Supported only for
Compact
. - NULLABLE_INT8 - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
-
Supported only for
Compact
. - nullableDataConnectionRef(String) - Static method in class com.hazelcast.jet.pipeline.DataConnectionRef
-
If the name parameter is null, this method returns null.
- nullsFirst(ComparatorEx<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#nullsFirst(Comparator)
. - nullsFirst(Comparator<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#nullsFirst(Comparator)
. - nullsLast(ComparatorEx<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#nullsLast(Comparator)
. - nullsLast(Comparator<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#nullsLast(Comparator)
. - numberAvg() - Static method in class com.hazelcast.aggregation.Aggregators
- numberAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
O
- OBJECT - Enum constant in enum class com.hazelcast.config.BitmapIndexOptions.UniqueKeyTransformation
-
Extracted unique key value is interpreted as an object value.
- OBJECT - Enum constant in enum class com.hazelcast.config.InMemoryFormat
-
As Object
- OBJECT - Enum constant in enum class com.hazelcast.config.security.LdapSearchScope
-
Only given search context object.
- OBJECT - Enum constant in enum class com.hazelcast.sql.SqlColumnType
-
OBJECT type, could be represented by any Java class.
- OBJECT_TYPE_IMAP_JOURNAL - Static variable in class com.hazelcast.dataconnection.HazelcastDataConnection
-
IMap Journal resource type name
- ObjectDataInput - Interface in com.hazelcast.nio
-
Provides serialization methods for arrays of primitive types.
- ObjectDataOutput - Interface in com.hazelcast.nio
-
Provides serialization methods for arrays by extending DataOutput
- ObjectIdCompactSerializer - Class in com.hazelcast.jet.mongodb.compact
-
Compact serializer for
ObjectId
. - ObjectIdCompactSerializer() - Constructor for class com.hazelcast.jet.mongodb.compact.ObjectIdCompactSerializer
- ObjLongBiFunction<T,
R> - Interface in com.hazelcast.jet.core.function -
Represents a specialization of
BiFunction
where the second argument is along
. - observable(Observable<? super T>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink that publishes to the provided
Observable
. - observable(String) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink that publishes to the
Observable
with the provided name. - Observable<T> - Interface in com.hazelcast.jet
-
Represents a flowing sequence of events produced by observable sinks.
- Observer<T> - Interface in com.hazelcast.jet.function
-
Observes the events produced by an
Observable
. - of(float[]) - Static method in interface com.hazelcast.vector.VectorValues
-
Returns a
VectorValues
object suitable for supplying a single vector to aVectorCollection
configured with one vector index. - of(int, boolean, boolean) - Static method in interface com.hazelcast.vector.SearchOptions
- of(int, int) - Static method in class com.hazelcast.version.Version
- of(int, int, int) - Static method in class com.hazelcast.version.MemberVersion
- of(int, FunctionEx<? super Address, ? extends ProcessorSupplier>) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Factory method that creates a
ProcessorMetaSupplier
from the supplied function that maps a cluster member address to aProcessorSupplier
. - of(int, SupplierEx<? extends Processor>) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Factory method that wraps the given
Supplier<Processor>
and uses it as the supplier of allProcessor
instances. - of(int, ProcessorSupplier) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Variant of
ProcessorMetaSupplier.of(int, Permission, ProcessorSupplier)
where the processor does not require any permission to run. - of(int, Permission, ProcessorSupplier) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Factory method that wraps the given
ProcessorSupplier
and returns the same instance for each givenAddress
. - of(int, Permission, ProcessorSupplier, String) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Factory method that wraps the given
ProcessorSupplier
and returns the same instance for each givenAddress
. - of(long, MemoryUnit) - Static method in class com.hazelcast.memory.Capacity
-
Returns an instance of
Capacity
. - of(ConsumerEx<? super T>) - Static method in interface com.hazelcast.jet.function.Observer
-
Utility method for building an
Observer
only from its data callback, with default behaviour for completion & error. - of(ConsumerEx<? super T>, ConsumerEx<? super Throwable>, RunnableEx) - Static method in interface com.hazelcast.jet.function.Observer
-
Utility method for building an
Observer
from its basic callback components. - of(FunctionEx<? super Address, ? extends ProcessorSupplier>) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Factory method that creates a
ProcessorMetaSupplier
from the supplied function that maps a cluster member address to aProcessorSupplier
. - of(SupplierEx<? extends Processor>) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Factory method that wraps the given
Supplier<Processor>
and uses it as the supplier of allProcessor
instances. - of(SupplierEx<? extends Processor>) - Static method in interface com.hazelcast.jet.core.ProcessorSupplier
-
Returns a
ProcessorSupplier
which will delegate to the givenSupplier<Processor>
to create allProcessor
instances. - of(ProcessorSupplier) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Variant of
ProcessorMetaSupplier.of(Permission, ProcessorSupplier)
where the processor does not require any permission to run. - of(String) - Static method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
-
Reconstructs a
ScheduledTaskHandler
from a URN String. - of(String) - Static method in class com.hazelcast.version.MemberVersion
- of(String) - Static method in class com.hazelcast.version.Version
-
Parse the given string to a
Version
. - of(String, float[]) - Static method in interface com.hazelcast.vector.VectorValues
-
Returns a
VectorValues
object that represents a single named vector. - of(String, float[], String, float[]) - Static method in interface com.hazelcast.vector.VectorValues
-
Returns a
VectorValues
object that represents two mappings of index names to associated vectors. - of(String, long, long, Map<String, String>) - Static method in class com.hazelcast.jet.core.metrics.Measurement
-
Builds a
Measurement
instance based on timestamp, value and the metric descriptor in map form. - of(Permission, ProcessorSupplier) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Wraps the provided
ProcessorSupplier
into a meta-supplier that will always return it. - of(Map<String, float[]>) - Static method in interface com.hazelcast.vector.VectorValues
-
Returns a
VectorValues
object that represents the given mappings of index names to associated vectors. - of(Map<String, List<Measurement>>) - Static method in class com.hazelcast.jet.core.metrics.JobMetrics
-
Builds a
JobMetrics
object based on a map ofMeasurement
s. - of(T, VectorValues) - Static method in interface com.hazelcast.vector.VectorDocument
- OFF - Enum constant in enum class com.hazelcast.client.config.ClientConnectionStrategyConfig.ReconnectMode
-
Prevent reconnect to cluster after a disconnect
- OFF - Enum constant in enum class com.hazelcast.config.MetadataPolicy
-
Turns off metadata creation.
- OFF - Enum constant in enum class com.hazelcast.config.UserCodeDeploymentConfig.ClassCacheMode
-
Deprecated.Never caches loaded classes.
- OFF - Enum constant in enum class com.hazelcast.config.UserCodeDeploymentConfig.ProviderMode
-
Deprecated.Never serve classes to other members.
- offer(int[], Object) - Method in interface com.hazelcast.jet.core.Outbox
-
Offers the item to all supplied edge ordinals.
- offer(int[], Object) - Method in class com.hazelcast.jet.core.test.TestOutbox
- offer(int, Object) - Method in interface com.hazelcast.jet.core.Outbox
-
Offers the supplied item to the bucket with the supplied ordinal.
- offer(int, Object) - Method in class com.hazelcast.jet.core.test.TestOutbox
- offer(E) - Method in interface com.hazelcast.collection.BaseQueue
-
Inserts the specified element into this queue if it is possible to do so immediately without violating capacity restrictions.
- offer(E) - Method in interface com.hazelcast.transaction.TransactionalQueue
-
Inserts the specified element into this queue if it is possible to do so immediately without violating capacity restrictions.
- offer(E, long, TimeUnit) - Method in interface com.hazelcast.collection.BaseQueue
-
Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to become available.
- offer(E, long, TimeUnit) - Method in interface com.hazelcast.transaction.TransactionalQueue
-
Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to become available.
- offer(Object) - Method in interface com.hazelcast.jet.core.Outbox
-
Offers the item to all edges.
- offer(Object) - Method in class com.hazelcast.jet.core.test.TestOutbox
- OFFER - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- offerToSnapshot(Object, Object) - Method in interface com.hazelcast.jet.core.Outbox
-
Offers the given key and value pair to the processor's snapshot storage.
- offerToSnapshot(Object, Object) - Method in class com.hazelcast.jet.core.test.TestOutbox
- Offloadable - Interface in com.hazelcast.core
-
Allows off-loading the processing unit implementing this interface to the specified or default Executor.
- OFFLOADABLE_EXECUTOR - Static variable in interface com.hazelcast.core.Offloadable
-
Constant meaning that processing will be off-loaded to the default OFFLOADABLE_EXECUTOR executor.
- oldValue - Variable in class com.hazelcast.core.EntryEvent
- oldValue() - Method in interface com.hazelcast.jet.cdc.ChangeRecord
-
Returns the old value of the record.
- ON - Enum constant in enum class com.hazelcast.client.config.ClientConnectionStrategyConfig.ReconnectMode
-
Reconnect to cluster by blocking invocations
- ON_EACH_CONNECT - Enum constant in enum class com.hazelcast.jet.mongodb.ResourceChecks
-
Check will be done on every connect action on every processor.
- onAccept(Socket) - Method in interface com.hazelcast.nio.MemberSocketInterceptor
-
This method will be called when a connection to a member node is accepted meaning security requirements and clusters are matching.
- onAccumulationFinished() - Method in interface com.hazelcast.aggregation.Aggregator
-
Called after the last call to combine on a specific instance.
- onCancel() - Method in interface com.hazelcast.topic.ReliableMessageListener
-
Called when the ReliableMessageListener is cancelled.
- ONCE_PER_JOB - Enum constant in enum class com.hazelcast.jet.mongodb.ResourceChecks
-
Check will be done once per each job execution (when job starts from scratch or from snapshot).
- onChange(SplitBrainProtectionEvent) - Method in interface com.hazelcast.splitbrainprotection.SplitBrainProtectionListener
-
Called when the state of the split brain detector is changed.
- onCombinationFinished() - Method in interface com.hazelcast.aggregation.Aggregator
-
Called after the last call to combine on a specific instance.
- onComplete() - Method in interface com.hazelcast.jet.function.Observer
-
Observes the completion event from the
Observable
it is registered with. - onComplete(Map<Member, Object>) - Method in interface com.hazelcast.core.MultiExecutionCallback
-
Called after all executions are completed.
- onConnect(Socket) - Method in interface com.hazelcast.nio.SocketInterceptor
-
Called when a connection is established.
- ONE_LEVEL - Enum constant in enum class com.hazelcast.config.security.LdapSearchScope
-
One level under the search context.
- ONE_PHASE - Enum constant in enum class com.hazelcast.transaction.TransactionOptions.TransactionType
-
The one phase transaction executes a transaction using a single step at the end; committing the changes.
- onEntryEvent(EntryEvent<K, V>) - Method in class com.hazelcast.core.EntryAdapter
-
This method is called when one of the methods of the
EntryListener
is not overridden. - onError(Throwable) - Method in interface com.hazelcast.jet.function.Observer
-
Observes an error event from the
Observable
it is registered with, in the form of an exception that reflects the underlying cause. - onFailure(Throwable) - Method in interface com.hazelcast.core.ExecutionCallback
-
Called when an execution is completed with an error.
- onFirstNull(Runnable) - Method in interface com.hazelcast.jet.Traverser
-
Returns a traverser that will emit the same items as this traverser and additionally run the supplied action the first time this traverser returns
null
. - onHeartbeat(Member, long) - Method in interface com.hazelcast.splitbrainprotection.HeartbeatAware
-
Notifies of a received heartbeat.
- OnJoinPermissionOperationName - Enum Class in com.hazelcast.config
-
Enum of operation names for handling client permissions when the member is joining into the cluster.
- onKeys(FunctionEx<? super T0, ? extends K>, FunctionEx<? super T1, ? extends K>) - Static method in class com.hazelcast.jet.pipeline.JoinClause
-
Constructs and returns a join clause with the supplied left-hand and right-hand key extractor functions, and with an identity right-hand projection function.
- ONLY_INITIAL - Enum constant in enum class com.hazelcast.jet.mongodb.ResourceChecks
-
(SQL-only) check will be done only during initial mapping creation.
- onMapEvent(MapEvent) - Method in class com.hazelcast.core.EntryAdapter
-
This method is called when one of the methods of the
EntryListener
is not overridden. - onMessage(Message) - Method in class com.hazelcast.console.ConsoleApp
- onMessage(Message<E>) - Method in interface com.hazelcast.topic.MessageListener
-
Invoked when a message is received for the topic.
- onMigrationCommit(PartitionMigrationEvent) - Method in interface com.hazelcast.wan.WanMigrationAwarePublisher
-
Indicates that migration is committing for a given partition
- onMigrationRollback(PartitionMigrationEvent) - Method in interface com.hazelcast.wan.WanMigrationAwarePublisher
-
Indicates that migration is rolling back for a given partition
- onMigrationStart(PartitionMigrationEvent) - Method in interface com.hazelcast.wan.WanMigrationAwarePublisher
-
Indicates that migration started for a given partition
- onNext(T) - Method in interface com.hazelcast.jet.function.Observer
-
Observes the next event from the
Observable
it is registered with. - onOutOfMemory(OutOfMemoryError, HazelcastInstance[]) - Method in class com.hazelcast.client.ClientOutOfMemoryHandler
- onOutOfMemory(OutOfMemoryError, HazelcastInstance[]) - Method in class com.hazelcast.core.OutOfMemoryHandler
-
When an
OutOfMemoryError
is caught by Hazelcast threads, this method is called for ALLHazelcastInstance
s knows by current JVM (actually ClassLoader). - onPingLost(Member) - Method in interface com.hazelcast.splitbrainprotection.PingAware
-
Notifies the
SplitBrainProtectionFunction
of ping loss. - onPingRestored(Member) - Method in interface com.hazelcast.splitbrainprotection.PingAware
-
Notifies the
SplitBrainProtectionFunction
of a successful ping after one or more pings to that member were lost. - onResponse(Member, Object) - Method in interface com.hazelcast.core.MultiExecutionCallback
-
Called when an execution is completed on a member.
- onResponse(V) - Method in interface com.hazelcast.core.ExecutionCallback
-
Called when an execution is completed successfully.
- onResult(T) - Method in interface com.hazelcast.query.extractor.ValueCallback
-
Notifies about a value passed as an argument
- open(String, Object...) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
- operation() - Method in interface com.hazelcast.jet.cdc.ChangeRecord
-
Returns the type of change this record describes (insert, delete or update).
- Operation - Enum Class in com.hazelcast.jet.cdc
-
Describes the nature of a CDC event, mainly the type of action performed on a database record: insertion, update and deletion.
- OPERATION_BACKUP_TIMEOUT_MILLIS - Static variable in class com.hazelcast.client.properties.ClientProperty
-
If an operation has backups, this property specifies how long the invocation will wait for acks from the backup replicas.
- OPERATION_BACKUP_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
If an operation has backups, this property specifies how long the invocation will wait for acks from the backup replicas.
- OPERATION_CALL_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Timeout to wait for a response when a remote call is sent, in milliseconds.
- OPERATIONS_SHOULD_NOTIMPL_BOTH_READONLY_AND_MUTATINGOPERATION - Static variable in class com.hazelcast.test.archunit.ArchUnitRules
-
Operations should not implement both
ReadonlyOperation
andMutatingOperation
interfaces, otherwise split brain protection may not work as expected. - OperationShouldNotImplementReadonlyAndMutatingOperation - Class in com.hazelcast.test.archunit
- OperationTimeoutException - Exception in com.hazelcast.core
-
An unchecked version of
TimeoutException
. - OperationTimeoutException() - Constructor for exception com.hazelcast.core.OperationTimeoutException
- OperationTimeoutException(String) - Constructor for exception com.hazelcast.core.OperationTimeoutException
- OperationTimeoutException(String, String) - Constructor for exception com.hazelcast.core.OperationTimeoutException
- OperationTimeoutException(String, Throwable) - Constructor for exception com.hazelcast.core.OperationTimeoutException
- OPTIMIZE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- option(String, String) - Method in class com.hazelcast.jet.pipeline.file.FileSourceBuilder
-
Specifies an arbitrary option for the underlying source.
- optional() - Method in interface com.hazelcast.config.properties.PropertyDefinition
-
Defines if this property is optional or not.
- optional() - Method in class com.hazelcast.config.properties.SimplePropertyDefinition
- OPTIONAL - Enum constant in enum class com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
-
Optimal
- options() - Method in interface com.hazelcast.dataconnection.DataConnection
-
Returns the properties / options this DataConnection was created with.
- optionsFn(FunctionEx<? super ActionRequest, RequestOptions>) - Method in class com.hazelcast.jet.elastic.ElasticSinkBuilder
-
Set the function that provides
RequestOptions
- optionsFn(FunctionEx<? super ActionRequest, RequestOptions>) - Method in class com.hazelcast.jet.elastic.ElasticSourceBuilder
-
Set the function that provides
RequestOptions
- or(MemberSelector...) - Static method in class com.hazelcast.cluster.memberselector.MemberSelectors
-
Selects a member when one of the selectors succeed
- or(BiPredicateEx<? super T, ? super U>) - Method in interface com.hazelcast.function.BiPredicateEx
-
Serializable
variant ofjava.util.function.BiPredicate#or(BiPredicate)
. - or(PredicateEx<? super T>) - Method in interface com.hazelcast.function.PredicateEx
-
Serializable
variant ofjava.util.function.Predicate#or(Predicate)
. - or(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)
. - or(Predicate) - Method in interface com.hazelcast.query.PredicateBuilder
- or(Predicate...) - Static method in class com.hazelcast.query.Predicates
-
Creates an or predicate that will perform the logical or operation on the given
predicates
. - ordered(ComparatorEx<?>) - Method in class com.hazelcast.jet.core.Edge
-
Specifies that the data traveling on this edge is ordered according to the provided comparator.
- ORDINAL - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
-
Index of the vertex input or output edges sourcing the metric.
- out(int, Object) - Static method in class com.hazelcast.jet.core.test.TestSupport
-
Create a test event with an output item on the given ordinal.
- out(Object) - Static method in class com.hazelcast.jet.core.test.TestSupport
-
Create a test event with an output item.
- Outbox - Interface in com.hazelcast.jet.core
-
Data sink for a
Processor
. - OutOfMemoryHandler - Class in com.hazelcast.core
-
Handler for
OutOfMemoryError
. - OutOfMemoryHandler() - Constructor for class com.hazelcast.core.OutOfMemoryHandler
- outputChecker(BiPredicate<? super List<?>, ? super List<?>>) - Method in class com.hazelcast.jet.core.test.TestSupport
-
Predicate to compare expected and actual output.
- outputFormat(Configuration) - Static method in class com.hazelcast.jet.hadoop.HadoopSinks
-
Convenience for
HadoopSinks.outputFormat(Configuration, FunctionEx, FunctionEx)
which expectsMap.Entry<K, V>
as input and extracts its key and value parts to be written to HDFS. - outputFormat(Configuration, FunctionEx<? super E, K>, FunctionEx<? super E, V>) - Static method in class com.hazelcast.jet.hadoop.HadoopSinks
-
Returns a sink that writes to Apache Hadoop HDFS.
- OverflowPolicy - Enum Class in com.hazelcast.ringbuffer
-
Using this policy one can control the behavior what should to be done when an item is about to be added to the ringbuffer, but there is
0
remaining capacity. - OVERWRITE - Enum constant in enum class com.hazelcast.ringbuffer.OverflowPolicy
-
Using this policy the oldest item is overwritten no matter it is not old enough to retire.
P
- pagingPredicate(int) - Static method in class com.hazelcast.query.Predicates
-
Creates a paging predicate with a page size.
- pagingPredicate(Predicate<K, V>, Comparator<Map.Entry<K, V>>, int) - Static method in class com.hazelcast.query.Predicates
-
Creates a paging predicate with an inner predicate, comparator and page size.
- pagingPredicate(Predicate, int) - Static method in class com.hazelcast.query.Predicates
-
Creates a paging predicate with an inner predicate and page size.
- pagingPredicate(Comparator<Map.Entry<K, V>>, int) - Static method in class com.hazelcast.query.Predicates
-
Creates a paging predicate with a comparator and page size.
- PagingPredicate<K,
V> - Interface in com.hazelcast.query -
This interface is a special Predicate which helps to get a page-by-page result of a query.
- ParallelBatchP<T> - Class in com.hazelcast.jet.pipeline.test
-
Implements a mock batch source with parallelism.
- ParallelBatchP(List<? extends Iterable<T>>) - Constructor for class com.hazelcast.jet.pipeline.test.ParallelBatchP
-
Creates a processor that generates items using its assigned iterables.
- ParallelStreamP<T> - Class in com.hazelcast.jet.pipeline.test
-
Implements a mock stream source with parallelism.
- ParallelStreamP(long, EventTimePolicy<? super T>, List<? extends GeneratorFunction<T>>) - Constructor for class com.hazelcast.jet.pipeline.test.ParallelStreamP
-
Creates a processor that generates items using its assigned generator functions.
- parameters() - Method in interface com.hazelcast.auditlog.AuditableEvent
-
Return Map of parameters for given event.
- parameters(Map<String, Object>) - Method in interface com.hazelcast.auditlog.EventBuilder
- Parameters - Interface in com.hazelcast.security
-
This interface is used to pass parameters of a method call to a
SecurityInterceptor
. - params - Variable in class com.hazelcast.jet.mongodb.MongoSourceBuilder.Stream
- parquet() - Static method in interface com.hazelcast.jet.pipeline.file.FileFormat
-
Returns a file format for Parquet files.
- ParquetFileFormat<T> - Class in com.hazelcast.jet.pipeline.file
-
FileFormat
for Parquet files. - parse(InputStream) - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
- parse(InputStream) - Method in class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
- parse(InputStream) - Method in class com.hazelcast.config.AbstractXmlConfigBuilder
-
Reads XML from InputStream and parses.
- parse(InputStream) - Method in class com.hazelcast.config.XmlConfigBuilder
- parse(String) - Static method in class com.hazelcast.memory.Capacity
-
Parses string representation of a capacity.
- parse(String) - Static method in class com.hazelcast.memory.MemorySize
-
Deprecated.since 5.1, use
Capacity.parse(String)
instead. - parse(String, MemoryUnit) - Static method in class com.hazelcast.memory.Capacity
-
Parses string representation of a capacity.
- parse(String, MemoryUnit) - Static method in class com.hazelcast.memory.MemorySize
-
Deprecated.since 5.1, use
Capacity.parse(String, MemoryUnit)
instead - parseEndpoints(JsonValue) - Method in class com.hazelcast.kubernetes.KubernetesApiEndpointSlicesProvider
- parseEndpointsList(JsonObject) - Method in class com.hazelcast.kubernetes.KubernetesApiEndpointSlicesProvider
- parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.CacheManagerBeanDefinitionParser
- parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.HazelcastClientBeanDefinitionParser
- parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.HazelcastConfigBeanDefinitionParser
- parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.HazelcastFailoverClientBeanDefinitionParser
- parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.HazelcastInstanceDefinitionParser
- parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.HazelcastTypeBeanDefinitionParser
- parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.hibernate.RegionFactoryBeanDefinitionParser
- parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.jet.JetBeanDefinitionParser
- parseListeners(Node, Class<?>) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- parseProperties(Node) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- parseProxyFactories(Node, Class<?>) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- parser() - Method in record class com.hazelcast.vector.Hint
-
Returns the value of the
parser
record component. - parseString(String) - Static method in enum class com.hazelcast.config.CacheDeserializedValues
-
Create instance from String
- ParsingException - Exception in com.hazelcast.jet.cdc
-
Exception to indicate that parsing CDC JSON data has failed irrecoverably.
- ParsingException(String) - Constructor for exception com.hazelcast.jet.cdc.ParsingException
-
Constructs a new exception with the specified detail message.
- ParsingException(String, Throwable) - Constructor for exception com.hazelcast.jet.cdc.ParsingException
-
Constructs a new exception with the specified detail message and
Throwable
as cause. - PARTIAL_MEMBER_DISCONNECTION_RESOLUTION_ALGORITHM_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The partial member disconnection resolution mechanism uses a graph algorithm that finds a max-clique in non-polynomial time.
- PARTIAL_MEMBER_DISCONNECTION_RESOLUTION_HEARTBEAT_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The master member, i.e, the first member in the cluster member list administrates the cluster and kicks unreachable members with the heartbeat mechanism.
- PARTIAL_RECOVERY_MOST_COMPLETE - Enum constant in enum class com.hazelcast.config.HotRestartClusterDataRecoveryPolicy
-
Deprecated.Starts the cluster with the largest group of members which have the same partition table version and successfully restored their data.
- PARTIAL_RECOVERY_MOST_COMPLETE - Enum constant in enum class com.hazelcast.config.PersistenceClusterDataRecoveryPolicy
-
Starts the cluster with the largest group of members which have the same partition table version and successfully restored their data.
- PARTIAL_RECOVERY_MOST_RECENT - Enum constant in enum class com.hazelcast.config.HotRestartClusterDataRecoveryPolicy
-
Deprecated.Starts the cluster with the members which have most up-to-date partition table and successfully restored their data.
- PARTIAL_RECOVERY_MOST_RECENT - Enum constant in enum class com.hazelcast.config.PersistenceClusterDataRecoveryPolicy
-
Starts the cluster with the members which have most up-to-date partition table and successfully restored their data.
- Partition - Interface in com.hazelcast.partition
-
In Hazelcast the data is split up in partitions: by default, 271 and configurable through the 'hazelcast.partition.count' ClusterProperty.
- PARTITION_ARGUMENT_CACHE_SIZE - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Parametrized SQL queries touching only a single partition benefit from using the partition owner as the query coordinator, if the partition owner can be determined from one of the query parameters.
- PARTITION_BACKUP_SYNC_INTERVAL - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Interval for syncing backup replicas in seconds.
- PARTITION_CHUNKED_MAX_MIGRATING_DATA_IN_MB - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Total size of all chunks in bytes during a single partition migration.
- PARTITION_CHUNKED_MIGRATION_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Enable to subdivide fragments into chunks.
- PARTITION_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Total number of partitions in the Hazelcast cluster.
- PARTITION_FRAGMENTED_MIGRATION_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
When enabled, which is the default behavior, partitions are migrated/replicated in small fragments instead of one big chunk.
- PARTITION_GROUP_NODE - Static variable in enum class com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
-
Metadata key definition for a node machine that containers/pods run on, in case of container orchestration tools being used.
- PARTITION_GROUP_PLACEMENT - Static variable in enum class com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
-
Metadata key definition for the placement group to which VMs belong if a placement strategy is applied by cloud providers.
- PARTITION_GROUP_ZONE - Static variable in enum class com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
-
Metadata key definition for a low-latency link between (virtual) data centers in the same area
- PARTITION_GROUPS - Enum constant in enum class com.hazelcast.client.config.RoutingStrategy
-
The client will have a limited view of the cluster (1 partition group at a time)
- PARTITION_LOST - Enum constant in enum class com.hazelcast.cache.CacheEventType
-
An event type indicating that partition loss is detected in given cache with name
- PARTITION_MAX_PARALLEL_MIGRATIONS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Maximum number of partition migrations to be executed concurrently on a member.
- PARTITION_MAX_PARALLEL_REPLICATIONS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Maximum number of anti-entropy partition replications to be executed on a member.
- PARTITION_MIGRATION_INTERVAL - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Time in seconds to sleep after a migration task.
- PARTITION_MIGRATION_TIMEOUT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Timeout in seconds for all migration operations.
- PARTITION_OPERATION_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The number of partition operation handler threads per member.
- PARTITION_TABLE_SEND_INTERVAL - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Interval for publishing partition table periodically to all cluster members in seconds.
- partitionAssignment() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
-
Returns the partition assignment used by this job.
- partitionAssignment() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
- PartitionAware<T> - Interface in com.hazelcast.partition
-
PartitionAware means that data will be based in the same member based on the partition key and implementing tasks will be executed on the
PartitionAware.getPartitionKey()
's owner member. - PartitionAwareKey<K,
P> - Class in com.hazelcast.partition -
A
PartitionAware
key. - PartitionAwareKey(K, P) - Constructor for class com.hazelcast.partition.PartitionAwareKey
-
Creates a new PartitionAwareKey.
- partitionCount() - Method in class com.hazelcast.jet.core.EventTimeMapper
-
Returns the current partition count.
- partitioned(FunctionEx<T, ?>) - Method in class com.hazelcast.jet.core.Edge
-
Activates the
PARTITIONED
routing policy and applies thedefault
Hazelcast partitioning strategy. - partitioned(FunctionEx<T, K>, Partitioner<? super K>) - Method in class com.hazelcast.jet.core.Edge
-
Activates the
PARTITIONED
routing policy and applies the provided partitioning strategy. - PARTITIONED - Enum constant in enum class com.hazelcast.jet.core.Edge.RoutingPolicy
-
This policy sends every item to the one processor responsible for the item's partition ID.
- Partitioner<T> - Interface in com.hazelcast.jet.core
-
Encapsulates the logic associated with a
DAG
edge that decides on the partition ID of an item traveling over it. - Partitioner.Default - Class in com.hazelcast.jet.core
-
Partitioner which applies the default Hazelcast partitioning strategy.
- PartitionEvent - Interface in com.hazelcast.partition
-
PartitionEvent is a base interface for partition related events.
- PartitionGroupConfig - Class in com.hazelcast.config
-
With PartitionGroupConfig, you can control how primary and backup partitions are mapped to physical Members.
- PartitionGroupConfig() - Constructor for class com.hazelcast.config.PartitionGroupConfig
- PartitionGroupConfig.MemberGroupType - Enum Class in com.hazelcast.config
-
Type of member groups.
- PartitionGroupMetaData - Enum Class in com.hazelcast.spi.partitiongroup
-
This class contains the definition of known Discovery SPI metadata to support automatic generation of zone aware and node aware backup strategies.
- PartitionGroupStrategy - Interface in com.hazelcast.spi.partitiongroup
-
A
PartitionGroupStrategy
implementation defines a strategy how backup groups are designed. - partitionIdleTimeout() - Method in interface com.hazelcast.jet.pipeline.StreamSource
-
Returns the value set by
StreamSource.setPartitionIdleTimeout(long)
. - PARTITIONING_STRATEGY_CLASS - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Class name implementing
PartitioningStrategy
, which defines key to partition mapping. - PARTITIONING_STRATEGY_CLASS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Class name implementing
PartitioningStrategy
, which defines key to partition mapping. - PartitioningAttributeConfig - Class in com.hazelcast.config
-
Contains the configuration for attributes used to create
AttributePartitioningStrategy
- PartitioningAttributeConfig() - Constructor for class com.hazelcast.config.PartitioningAttributeConfig
- PartitioningAttributeConfig(PartitioningAttributeConfig) - Constructor for class com.hazelcast.config.PartitioningAttributeConfig
- PartitioningAttributeConfig(String) - Constructor for class com.hazelcast.config.PartitioningAttributeConfig
- PartitioningStrategy<K> - Interface in com.hazelcast.partition
-
PartitioningStrategy allows keys to be located on the same member.
- PartitioningStrategyConfig - Class in com.hazelcast.config
-
Contains the configuration for partitioning strategy.
- PartitioningStrategyConfig() - Constructor for class com.hazelcast.config.PartitioningStrategyConfig
- PartitioningStrategyConfig(PartitioningStrategyConfig) - Constructor for class com.hazelcast.config.PartitioningStrategyConfig
- PartitioningStrategyConfig(PartitioningStrategy) - Constructor for class com.hazelcast.config.PartitioningStrategyConfig
- PartitioningStrategyConfig(String) - Constructor for class com.hazelcast.config.PartitioningStrategyConfig
- partitionLost(MapPartitionLostEvent) - Method in interface com.hazelcast.map.listener.MapPartitionLostListener
-
Invoked when owner and all backups of a partition is lost for a specific map.
- partitionLost(PartitionLostEvent) - Method in interface com.hazelcast.partition.PartitionLostListener
-
Invoked when a primary replica of the partition is lost.
- PartitionLostEvent - Interface in com.hazelcast.partition
-
The event is fired when a primary replica of the partition is lost.
- PartitionLostListener - Interface in com.hazelcast.partition
-
PartitionLostListener provides the ability to be notified upon a possible data loss when a partition loses a replica.
- PartitionMigratingException - Exception in com.hazelcast.spi.exception
-
A
RetryableHazelcastException
that is thrown when an operation is executed on a partition, but that partition is currently being moved around. - PartitionMigratingException(Address, int, String, String) - Constructor for exception com.hazelcast.spi.exception.PartitionMigratingException
- PartitionMigratingException(String) - Constructor for exception com.hazelcast.spi.exception.PartitionMigratingException
- partitionPredicate(Object, Predicate<K, V>) - Static method in class com.hazelcast.query.Predicates
-
Creates a new partition predicate that restricts the execution of the target predicate to a single partition.
- PartitionPredicate<K,
V> - Interface in com.hazelcast.query - PartitionService - Interface in com.hazelcast.partition
-
PartitionService allows you to query
Partition
s and attach/detachMigrationListener
s to listen to partition migration events. - PASSIVE - Enum constant in enum class com.hazelcast.cluster.ClusterState
-
In
PASSIVE
state of the cluster: New members are not allowed to join, except the members left duringClusterState.FROZEN
orPASSIVE
state. - PassThroughMergePolicy<V,
T extends MergingValue<V>> - Class in com.hazelcast.spi.merge -
Merges data structure entries from source to destination directly unless the merging entry is
null
. - PassThroughMergePolicy() - Constructor for class com.hazelcast.spi.merge.PassThroughMergePolicy
- PASSWORD_PROPERTY - Static variable in class com.hazelcast.jet.mongodb.dataconnection.MongoDataConnection
-
Name of the property holding user password.
- PasswordCredentials - Interface in com.hazelcast.security
-
Credentials
type for name/password representation. - PAUSED - Enum constant in enum class com.hazelcast.wan.WanPublisherState
-
State where new events are enqueued, but they are not dequeued.
- payloadSize() - Method in class com.hazelcast.jet.JobStateSnapshot
-
Returns the size in bytes of the payload data of the state snapshot.
- peek() - Method in interface com.hazelcast.jet.core.Inbox
-
Retrieves, but does not remove, the head of this inbox, or returns
null
if it is empty. - peek() - Method in class com.hazelcast.jet.core.test.TestInbox
- peek() - Method in interface com.hazelcast.jet.pipeline.BatchStage
- peek() - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Adds a peeking layer to this compute stage which logs its output.
- peek() - Method in interface com.hazelcast.jet.pipeline.StreamStage
- peek() - Method in interface com.hazelcast.transaction.TransactionalQueue
- peek(long, TimeUnit) - Method in interface com.hazelcast.transaction.TransactionalQueue
- peek(FunctionEx<? super T, ? extends CharSequence>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- peek(FunctionEx<? super T, ? extends CharSequence>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Adds a peeking layer to this compute stage which logs its output.
- peek(FunctionEx<? super T, ? extends CharSequence>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- peek(PredicateEx<? super T>, FunctionEx<? super T, ? extends CharSequence>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- peek(PredicateEx<? super T>, FunctionEx<? super T, ? extends CharSequence>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Attaches a peeking stage which logs this stage's output and passes it through without transformation.
- peek(PredicateEx<? super T>, FunctionEx<? super T, ? extends CharSequence>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- peek(Consumer<? super T>) - Method in interface com.hazelcast.jet.Traverser
-
Returns a traverser that will emit the same items as this traverser, additionally passing each (non-null) item to the supplied consumer.
- PEEK - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- PEEK_DEFAULT_TO_STRING - Static variable in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
A function that uses `Object.toString()` for non-arrays, `Arrays.toString()` for arrays of primitive types and `Arrays.deepToString()` for `Object[]`.
- peekInputP(FunctionEx<T, ? extends CharSequence>, PredicateEx<T>, SupplierEx<Processor>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
Same as
peekInput(toStringFn, shouldLogFn, metaSupplier)
, but accepts aSupplierEx
of processors instead of a meta-supplier. - peekInputP(FunctionEx<T, ? extends CharSequence>, PredicateEx<T>, ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
Returns a meta-supplier that wraps the provided one and adds a logging layer to each processor it creates.
- peekInputP(FunctionEx<T, ? extends CharSequence>, PredicateEx<T>, ProcessorSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
Same as
peekInput(toStringFn, shouldLogFn, metaSupplier)
, but accepts aProcessorSupplier
instead of a meta-supplier. - peekInputP(SupplierEx<Processor>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
Convenience for
peekInput(toStringFn, shouldLogFn, metaSupplier)
with a pass-through filter andObject#toString
as the formatting function. - peekInputP(ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
Convenience for
peekInput(toStringFn, shouldLogFn, metaSupplier)
with a pass-through filter andObject#toString
as the formatting function. - peekInputP(ProcessorSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
Convenience for
peekInput(toStringFn, shouldLogFn, metaSupplier)
with a pass-through filter andObject#toString
as the formatting function. - peekOutputP(FunctionEx<? super T, ? extends CharSequence>, PredicateEx<? super T>, SupplierEx<Processor>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
Same as
peekOutput(toStringFn, shouldLogFn, metaSupplier)
, but accepts aSupplierEx
of processors instead of a meta-supplier. - peekOutputP(FunctionEx<? super T, ? extends CharSequence>, PredicateEx<? super T>, ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
Returns a meta-supplier that wraps the provided one and adds a logging layer to each processor it creates.
- peekOutputP(FunctionEx<? super T, ? extends CharSequence>, PredicateEx<? super T>, ProcessorSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
Same as
peekOutput(toStringFn, shouldLogFn, metaSupplier)
, but accepts aProcessorSupplier
instead of a meta-supplier. - peekOutputP(SupplierEx<Processor>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
Convenience for
peekOutput(toStringFn, shouldLogFn, metaSupplier
with a pass-through filter andObject#toString
as the formatting function. - peekOutputP(ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
Convenience for
peekOutput(toStringFn, shouldLogFn, metaSupplier
with a pass-through filter andObject#toString
as the formatting function. - peekOutputP(ProcessorSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
Convenience for
peekOutput(toStringFn, shouldLogFn, metaSupplier
with a pass-through filter andObject#toString
as the formatting function. - peekSnapshotP(FunctionEx<? super Map.Entry<K, V>, ? extends CharSequence>, PredicateEx<? super Map.Entry<K, V>>, SupplierEx<Processor>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
Same as
peekSnapshot(toStringFn, shouldLogFn, metaSupplier)
, but accepts aSupplierEx
of processors instead of a meta-supplier. - peekSnapshotP(FunctionEx<? super Map.Entry<K, V>, ? extends CharSequence>, PredicateEx<? super Map.Entry<K, V>>, ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
Returns a meta-supplier that wraps the provided one and adds a logging layer to each processor it creates.
- peekSnapshotP(FunctionEx<? super Map.Entry<K, V>, ? extends CharSequence>, PredicateEx<? super Map.Entry<K, V>>, ProcessorSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
Same as
peekSnapshot(toStringFn, shouldLogFn, metaSupplier)
, but accepts aProcessorSupplier
instead of a meta-supplier. - peekSnapshotP(SupplierEx<Processor>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
Convenience for
peekSnapshot(toStringFn, shouldLogFn, metaSupplier
with a pass-through filter andObject#toString
as the formatting function. - peekSnapshotP(ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
Convenience for
peekSnapshot(toStringFn, shouldLogFn, metaSupplier
with a pass-through filter andObject#toString
as the formatting function. - peekSnapshotP(ProcessorSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
Convenience for
peekSnapshot(toStringFn, shouldLogFn, metaSupplier
with a pass-through filter andObject#toString
as the formatting function. - PentaFunction<T0,
T1, T2, T3, T4, R> - Interface in com.hazelcast.jet.function -
Represents a penta-arity function that accepts five arguments and produces a result.
- PER_MEMBER - Enum constant in enum class com.hazelcast.config.PartitionGroupConfig.MemberGroupType
-
Per member.
- PER_NODE - Enum constant in enum class com.hazelcast.config.MaxSizePolicy
-
Policy based on maximum number of entries stored per data structure (map, cache etc.) on each Hazelcast instance
- PER_NODE - Enum constant in enum class com.hazelcast.config.ScheduledExecutorConfig.CapacityPolicy
-
Capacity policy that counts tasks per Hazelcast instance node/member, and rejects new ones when
ScheduledExecutorConfig.capacity
value is reached - PER_PARTITION - Enum constant in enum class com.hazelcast.config.MaxSizePolicy
-
Policy based on maximum number of entries stored per data structure (map, cache etc.) on each partition
- PER_PARTITION - Enum constant in enum class com.hazelcast.config.ScheduledExecutorConfig.CapacityPolicy
-
Capacity policy that counts tasks per partition, and rejects new ones when
ScheduledExecutorConfig.capacity
value is reached. - PERCENT - Enum constant in enum class com.hazelcast.jet.core.metrics.Unit
-
An integer in range 0..100
- permission() - Method in class com.hazelcast.jet.pipeline.ServiceFactory
-
Returns the required permission to use this factory.
- permission(Permission) - Method in class com.hazelcast.jet.pipeline.SinkBuilder
-
Sets the permission required to use this sink when the security is enabled.
- permission(Permission) - Method in class com.hazelcast.jet.pipeline.SourceBuilder.Batch
- permission(Permission) - Method in class com.hazelcast.jet.pipeline.SourceBuilder.Stream
- permission(Permission) - Method in class com.hazelcast.jet.pipeline.SourceBuilder.TimestampedStream
- PermissionConfig - Class in com.hazelcast.config
-
Contains the configuration for a permission.
- PermissionConfig() - Constructor for class com.hazelcast.config.PermissionConfig
- PermissionConfig(PermissionConfig) - Constructor for class com.hazelcast.config.PermissionConfig
- PermissionConfig(PermissionConfig.PermissionType, String, String) - Constructor for class com.hazelcast.config.PermissionConfig
- PermissionConfig.PermissionType - Enum Class in com.hazelcast.config
-
Type of permission
- PermissionPolicyConfig - Class in com.hazelcast.config
-
Contains the configuration for policy of permission
- PermissionPolicyConfig() - Constructor for class com.hazelcast.config.PermissionPolicyConfig
- PermissionPolicyConfig(String) - Constructor for class com.hazelcast.config.PermissionPolicyConfig
- PermissionsUtil - Class in com.hazelcast.security
-
Utility class for security permissions.
- PERSISTENCE - Enum constant in enum class com.hazelcast.config.RestEndpointGroup
-
Deprecated.Group of HTTP REST APIs related to Persistence feature.
- PERSISTENCE_AUTO_CLUSTER_STATE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
When
true
, enables monitoring of the runtime environment to detect the intent of shutdown and automate cluster state management decisions. - PERSISTENCE_AUTO_CLUSTER_STATE_STRATEGY - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Select which cluster state to use when dealing with missing members in a managed runtime environment.
- PERSISTENCE_BASE_DIR_DEFAULT - Static variable in class com.hazelcast.config.PersistenceConfig
-
Default directory name for the Persistence store's home
- PersistenceClusterDataRecoveryPolicy - Enum Class in com.hazelcast.config
-
Specifies the policy that will be respected during persistence cluster start
- PersistenceConfig - Class in com.hazelcast.config
-
Configures the Persistence stores.
- PersistenceConfig() - Constructor for class com.hazelcast.config.PersistenceConfig
- PersistenceService - Interface in com.hazelcast.persistence
-
Service for interacting with Persistence.
- PersistentMemoryConfig - Class in com.hazelcast.config
-
Configuration class for persistent memory devices (e.g.
- PersistentMemoryConfig() - Constructor for class com.hazelcast.config.PersistentMemoryConfig
- PersistentMemoryConfig(PersistentMemoryConfig) - Constructor for class com.hazelcast.config.PersistentMemoryConfig
-
Constructs an instance with copying the fields of the provided
PersistentMemoryConfig
. - PersistentMemoryDirectoryConfig - Class in com.hazelcast.config
-
Configuration class for directories that persistent memories are mounted at.
- PersistentMemoryDirectoryConfig(PersistentMemoryDirectoryConfig) - Constructor for class com.hazelcast.config.PersistentMemoryDirectoryConfig
-
Constructs an instance by copying the provided
PersistentMemoryDirectoryConfig
. - PersistentMemoryDirectoryConfig(String) - Constructor for class com.hazelcast.config.PersistentMemoryDirectoryConfig
-
Creates an instance with the
directory
specified. - PersistentMemoryDirectoryConfig(String, int) - Constructor for class com.hazelcast.config.PersistentMemoryDirectoryConfig
-
Creates an instance with the
directory
and NUMA node specified. - PersistentMemoryMode - Enum Class in com.hazelcast.config
-
The enumeration of the supported persistent memory operational modes.
- PHONE_HOME_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Enable or disable the sending of phone home data to Hazelcast’s phone home server.
- pickAny() - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation whose result is an arbitrary item it observed, or
null
if it observed no items. - PickAnyAccumulator<T> - Class in com.hazelcast.jet.accumulator
-
Keeps the state needed to implement the
AggregateOperations.pickAny()
aggregate operation. - PickAnyAccumulator() - Constructor for class com.hazelcast.jet.accumulator.PickAnyAccumulator
-
Constructs an empty
pickAny
accumulator. - PickAnyAccumulator(T) - Constructor for class com.hazelcast.jet.accumulator.PickAnyAccumulator
-
Constructs a
pickAny
accumulator with the full state passed in the parameters. - PID - Enum constant in enum class com.hazelcast.config.InstanceTrackingConfig.InstanceTrackingProperties
-
Attempts to get the process ID value.
- PingAware - Interface in com.hazelcast.splitbrainprotection
-
Split brain protection functions that need access to ICMP ping failure detector should implement this interface; the instance of
PingFailureDetector
used by this member'sClusterHeartbeatManager
will be provided on initialization. - Pipeline - Interface in com.hazelcast.jet.pipeline
-
Models a distributed computation job using an analogy with a system of interconnected water pipes.
- Pipelining<E> - Class in com.hazelcast.core
-
The Pipelining can be used to speed up requests.
- Pipelining(int) - Constructor for class com.hazelcast.core.Pipelining
-
Creates a Pipelining with the given depth.
- PLACEHOLDER_NAMESPACE - Static variable in class com.hazelcast.config.InstanceTrackingConfig
-
Namespace for the placeholders in the file name and format pattern to distinguish between different types of placeholders.
- PLACEMENT_AWARE - Enum constant in enum class com.hazelcast.config.PartitionGroupConfig.MemberGroupType
-
Placement Aware.
- PLATFORM - Enum constant in enum class com.hazelcast.spi.discovery.DiscoveryStrategyFactory.DiscoveryStrategyLevel
-
Platform level, for example, hazelcast-kubernetes.
- PN_COUNTER - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
-
CRDT PN Counter
- PN_COUNTER_SERVICE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- PNCounter - Interface in com.hazelcast.crdt.pncounter
-
PN (Positive-Negative) CRDT counter.
- PNCounterConfig - Class in com.hazelcast.config
-
Configuration for a
PNCounter
- PNCounterConfig() - Constructor for class com.hazelcast.config.PNCounterConfig
- PNCounterConfig(PNCounterConfig) - Constructor for class com.hazelcast.config.PNCounterConfig
- PNCounterConfig(String) - Constructor for class com.hazelcast.config.PNCounterConfig
- PNCounterConfig(String, int, String, boolean) - Constructor for class com.hazelcast.config.PNCounterConfig
- PNCounterPermission - Class in com.hazelcast.security.permission
- PNCounterPermission(String, String...) - Constructor for class com.hazelcast.security.permission.PNCounterPermission
- POD_LABEL_NAME - Static variable in class com.hazelcast.kubernetes.KubernetesProperties
-
Configuration key:
pod-label-name
- POD_LABEL_VALUE - Static variable in class com.hazelcast.kubernetes.KubernetesProperties
-
Configuration key:
pod-label-value
- poll() - Method in interface com.hazelcast.collection.BaseQueue
-
Retrieves and removes the head of this queue, or returns
null
if this queue is empty. - poll() - Method in interface com.hazelcast.collection.IQueue
-
Retrieves and removes the head of this queue, or returns
null
if this queue is empty. - poll() - Method in interface com.hazelcast.jet.core.Inbox
-
Retrieves and removes the head of this inbox, or returns
null
if it is empty. - poll() - Method in class com.hazelcast.jet.core.test.TestInbox
- poll() - Method in interface com.hazelcast.transaction.TransactionalQueue
-
Retrieves and removes the head of this queue, or returns
null
if this queue is empty. - poll(long, TimeUnit) - Method in interface com.hazelcast.collection.BaseQueue
-
Retrieves and removes the head of this queue, waiting up to the specified wait time if necessary for an element to become available.
- poll(long, TimeUnit) - Method in interface com.hazelcast.collection.IQueue
-
Retrieves and removes the head of this queue, waiting up to the specified wait time if necessary for an element to become available.
- poll(long, TimeUnit) - Method in interface com.hazelcast.transaction.TransactionalQueue
-
Retrieves and removes the head of this queue, waiting up to the specified wait time if necessary for an element to become available.
- POLL - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- POOLED - Enum constant in enum class com.hazelcast.config.NativeMemoryConfig.MemoryAllocatorType
-
POOLED memory allocator: manage memory blocks in pool
- PORT - Static variable in class com.hazelcast.spi.discovery.multicast.MulticastProperties
-
Property used to define multicast port.
- PORT_AUTO_INCREMENT - Static variable in class com.hazelcast.config.ServerSocketEndpointConfig
-
Default port auto-increment count.
- portable(ClassDefinition) - Static method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
Creates a Builder that will build a
GenericRecord
inPortable
format with a new class definition: - Portable - 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.
- 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.
- PORTABLE - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
-
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.
- PORTABLE_ARRAY - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
-
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.
- PortableFactory - 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.
- PortableId - 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.
- PortableId() - Constructor for class com.hazelcast.nio.serialization.PortableId
-
Deprecated.
- PortableId(int, int, int) - Constructor for class com.hazelcast.nio.serialization.PortableId
-
Deprecated.
- PortableId(String) - Constructor for class com.hazelcast.nio.serialization.PortableId
-
Deprecated.
- PortableReader - 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.
- PortableWriter - 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.
- PortRange - Class in com.hazelcast.spi.utils
-
Represents the range of IPv4 Ports.
- PortRange(String) - Constructor for class com.hazelcast.spi.utils.PortRange
-
Creates
PortRange
from thespec
String. - post() - Method in class com.hazelcast.spi.utils.RestClient
- postgres(String) - Static method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources
-
Creates a CDC source that streams change data from a PostgreSQL database to Hazelcast Jet.
- PostgresCdcSources - Class in com.hazelcast.jet.cdc.postgres
-
Contains factory methods for creating change data capture sources based on PostgreSQL databases.
- PostgresCdcSources.Builder - Class in com.hazelcast.jet.cdc.postgres
-
Builder for configuring a CDC source that streams change data from a PostgreSQL database to Hazelcast Jet.
- PostgresCdcSources.PostgresSnapshotMode - Enum Class in com.hazelcast.jet.cdc.postgres
-
Possible postgres snapshot modes, that does not require additional mandatory parameters to be set.
- PostProcessingMapStore - Interface in com.hazelcast.map
-
Implement this interface if you modify the value in MapStore.store(K key, V value) method.
- predicate(Predicate<K, V>) - Method in class com.hazelcast.jet.pipeline.RemoteMapSourceBuilder
-
Set the predicate to apply at the source.
- Predicate<K,
V> - Interface in com.hazelcast.query -
Represents a map entry predicate.
- PredicateBuilder - Interface in com.hazelcast.query
-
This interface provides functionality to build a predicate.
- PredicateBuilder.EntryObject - Interface in com.hazelcast.query
-
This interface provides entry-level functionality related to building a predicate.
- PredicateConfig - Class in com.hazelcast.config
-
Contains the configuration for an
Predicate
. - PredicateConfig() - Constructor for class com.hazelcast.config.PredicateConfig
-
Creates a PredicateConfig without className/implementation.
- PredicateConfig(PredicateConfig) - Constructor for class com.hazelcast.config.PredicateConfig
- PredicateConfig(Predicate) - Constructor for class com.hazelcast.config.PredicateConfig
-
Creates a PredicateConfig with the given implementation.
- PredicateConfig(String) - Constructor for class com.hazelcast.config.PredicateConfig
-
Creates a PredicateConfig with the given className.
- PredicateEx<T> - Interface in com.hazelcast.function
-
Serializable
variant ofjava.util.function.Predicate
which declares checked exception. - Predicates - Class in com.hazelcast.query
-
A utility class to create new
PredicateBuilder
andPredicate
instances. - PREFER_IPv4_STACK - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Prefer IPv4 network interface when picking a local address.
- preferLocalParallelismOne(SupplierEx<? extends Processor>) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Variant of
ProcessorMetaSupplier.preferLocalParallelismOne(ProcessorSupplier)
where the suppliedSupplierEx<Processor>
will be wrapped into aProcessorSupplier
. - preferLocalParallelismOne(ProcessorSupplier) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Wraps the provided
ProcessorSupplier
into a meta-supplier that will always return it. - preferLocalParallelismOne(Permission, SupplierEx<? extends Processor>) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Variant of
ProcessorMetaSupplier.preferLocalParallelismOne(SupplierEx)
where the processor requires given permission to run. - preferLocalParallelismOne(Permission, SupplierEx<? extends Processor>, String) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Variant of
ProcessorMetaSupplier.preferLocalParallelismOne(SupplierEx)
where the processor requires given permission to run. - preferLocalParallelismOne(Permission, ProcessorSupplier) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Variant of
ProcessorMetaSupplier.preferLocalParallelismOne(ProcessorSupplier)
where the processor requires given permission to run. - preferredLocalParallelism() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Returns the local parallelism the vertex should be configured with.
- preferredLocalParallelism() - Method in class com.hazelcast.jet.core.ProcessorMetaSupplier.SpecificMemberPms
- preferredLocalParallelism(int) - Method in class com.hazelcast.jet.mongodb.MongoSinkBuilder
- preferredLocalParallelism(int) - Method in class com.hazelcast.jet.pipeline.SinkBuilder
-
Sets the local parallelism of the sink.
- PrefixedDistributedObject - Interface in com.hazelcast.core
-
Contact point for special
DistributedObject
's which has prefixed name. - PREPARE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- prepareEventContainerReplicationData(PartitionReplicationEvent, Collection<ServiceNamespace>) - Method in interface com.hazelcast.wan.WanMigrationAwarePublisher
-
Returns a container containing the WAN events for the given replication
event
andnamespaces
to be replicated. - prepend(T) - Method in interface com.hazelcast.jet.Traverser
-
Returns a traverser which prepends an additional item in front of all the items of this traverser.
- previousPage() - Method in interface com.hazelcast.query.PagingPredicate
-
Sets the page value to previous page.
- print(Object) - Method in class com.hazelcast.console.ConsoleApp
- println(Object) - Method in class com.hazelcast.console.ConsoleApp
- priority(int) - Method in class com.hazelcast.jet.core.Edge
-
Sets the priority of the edge.
- PRIORITY_GENERIC_OPERATION_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The number of priority generic operation handler threads per member.
- PrivateApi - Annotation Interface in com.hazelcast.spi.annotation
-
Marker for private functionality.
- ProbabilisticSplitBrainProtectionConfigBuilder - Class in com.hazelcast.config
-
Builder for a
SplitBrainProtectionConfig
configured withProbabilisticSplitBrainProtectionFunction
that considers members present in the context of a split brain protection using a probabilistic, adaptive split brain protection function. - process(int, Inbox) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Implements the boilerplate of dispatching against the ordinal, taking items from the inbox one by one, and invoking the processing logic on each.
- process(int, Inbox) - Method in interface com.hazelcast.jet.core.Processor
-
Called with a batch of items retrieved from an inbound edge's stream.
- process(Map.Entry<K, V>) - Method in interface com.hazelcast.map.EntryProcessor
-
Process the entry without worrying about concurrency.
- process(Node) - Method in class com.hazelcast.config.AbstractXmlConfigBuilder
- processEventContainerReplicationData(int, T) - Method in interface com.hazelcast.wan.WanMigrationAwarePublisher
-
Processes the WAN event container received through intra-cluster replication or migration.
- processingGuarantee() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
-
Returns the guarantee for current job.
- processingGuarantee() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
- ProcessingGuarantee - Enum Class in com.hazelcast.jet.config
-
Defines what message processing guarantees are given under failure conditions.
- Processor - Interface in com.hazelcast.jet.core
-
When Jet executes a DAG, it creates one or more instances of
Processor
on each cluster member to do the work of a given vertex. - PROCESSOR - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
-
Global index of the
Processor
sourcing the metric. - PROCESSOR_CUSTOM_LIB_DIR - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The directory containing jars, that can be used to specify custom classpath for a stage in a pipeline.
- PROCESSOR_MAP_P_SUPPLIER - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
- PROCESSOR_TYPE - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
-
Class name without package name of the
Processor
sourcing the metric (only for processor-specific metrics). - Processor.Context - Interface in com.hazelcast.jet.core
-
Context passed to the processor in the
init()
call. - processorAssertion(Consumer<T>) - Static method in class com.hazelcast.jet.core.test.TestSupport
-
Create a test event with a processor assertion.
- ProcessorMetaSupplier - Interface in com.hazelcast.jet.core
-
Factory of
ProcessorSupplier
instances. - ProcessorMetaSupplier.Context - Interface in com.hazelcast.jet.core
-
Context passed to the meta-supplier at init time on the member that received a job request from the client.
- ProcessorMetaSupplier.ExpectNothingProcessorSupplier - Class in com.hazelcast.jet.core
- ProcessorMetaSupplier.RandomMemberPms - Class in com.hazelcast.jet.core
- ProcessorMetaSupplier.SpecificMemberPms - Class in com.hazelcast.jet.core
-
A meta-supplier that will only use the given
ProcessorSupplier
on a node with givenAddress
or random member if address is not given. - processorPartitions() - Method in interface com.hazelcast.jet.core.Processor.Context
-
Returns the slice of partitions for this processor.
- Processors - Class in com.hazelcast.jet.core.processor
-
Static utility class with factory methods for Jet processors.
- PROCESSORS_AGGREGATE_P_SUPPLIER - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
- ProcessorSupplier - Interface in com.hazelcast.jet.core
-
Factory of
Processor
instances. - ProcessorSupplier.Context - Interface in com.hazelcast.jet.core
-
Context passed to the supplier in the
init()
call. - PRODUCT - Enum constant in enum class com.hazelcast.config.InstanceTrackingConfig.InstanceTrackingProperties
-
The instance product name, e.g.
- project(Projection<? super Map.Entry<K, V>, R>) - Method in interface com.hazelcast.map.IMap
-
Applies the projection logic on all map entries and returns the result
- project(Projection<? super Map.Entry<K, V>, R>, Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
-
Applies the projection logic on map entries filtered with the Predicated and returns the result
- project(Bson) - Method in class com.hazelcast.jet.mongodb.MongoSourceBuilder.Stream
-
Adds a projection aggregate.
- PROJECT - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- projecting(FunctionEx<? super T1, ? extends T1_NEW_OUT>) - Method in class com.hazelcast.jet.pipeline.JoinClause
-
Returns a copy of this join clause, but with the right-hand projection function replaced with the supplied one.
- projection(Projection<? super Map.Entry<K, V>, ? extends T_NEW>) - Method in class com.hazelcast.jet.pipeline.RemoteMapSourceBuilder
-
Set the projection to apply at the source.
- Projection<I,
O> - Interface in com.hazelcast.projection -
Enables transforming object into other objects.
- Projections - Class in com.hazelcast.projection
-
A utility class to create basic
Projection
instances. - promoteLocalLiteMember() - Method in interface com.hazelcast.cluster.Cluster
-
Promotes the local lite member to a data member.
- promoteToCPMember() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
-
Promotes the local Hazelcast member to the CP role.
- properties - Variable in class com.hazelcast.config.AbstractBaseFactoryWithPropertiesConfig
- properties - Variable in class com.hazelcast.config.AbstractWanPublisherConfig
- propertiesByInstanceItself(HazelcastInstance) - Static method in class com.hazelcast.cache.HazelcastCachingProvider
-
Create the
Properties
with the provided instance itself. - propertiesByInstanceName(String) - Static method in class com.hazelcast.cache.HazelcastCachingProvider
-
Create the
Properties
with the provided instance name. - propertiesByLocation(String) - Static method in class com.hazelcast.cache.HazelcastCachingProvider
-
Create the
Properties
with the provided config file location. - PROPERTY_CIPHER_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
-
Replacer property name to configure
Cipher
algorithm name. - PROPERTY_KEY_LENGTH_BITS - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
-
Replacer property name to configure key length (in bits).
- PROPERTY_PASSWORD_FILE - Static variable in class com.hazelcast.config.replacer.EncryptionReplacer
-
Replacer property name to configure path to a password file which content should be used as part of the encryption password.
- PROPERTY_PASSWORD_NETWORK_INTERFACE - Static variable in class com.hazelcast.config.replacer.EncryptionReplacer
-
Replacer property name to configure network interface name used to retrieve MAC address used as part of the encryption password.
- PROPERTY_PASSWORD_USER_PROPERTIES - Static variable in class com.hazelcast.config.replacer.EncryptionReplacer
-
Replacer property name to configure
true
/false
flag controlling if users properties should be used as part of the encryption password. - PROPERTY_SALT_LENGTH_BYTES - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
-
Replacer property name to configure salt length (in bytes).
- PROPERTY_SECRET_KEY_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
-
Replacer property name to configure
SecretKeySpec
algorithm name. - PROPERTY_SECRET_KEY_FACTORY_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
-
Replacer property name to configure
SecretKeyFactory
algorithm name. - PROPERTY_SECURITY_PROVIDER - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
-
Replacer property name to configure Java Security provider name used for
Cipher
andSecretKeyFactory
selection. - PropertyDefinition - Interface in com.hazelcast.config.properties
-
This interface describes an extended approach of the currently available pure property based configuration inside Hazelcast and helps to implement an automatic and transparent way to verify configuration as well as converting types based on provided validators and converters.
- PropertyReplacer - Class in com.hazelcast.config.replacer
-
ConfigReplacer for replacing property names with property values for properties provided in
PropertyReplacer.init(Properties)
method. - PropertyReplacer() - Constructor for class com.hazelcast.config.replacer.PropertyReplacer
- PropertyTypeConverter - Enum Class in com.hazelcast.config.properties
-
This enum class contains basic
TypeConverter
implementations to convert strings to all common basic Java types. - ProtobufSerializer<T extends com.google.protobuf.GeneratedMessageV3> - Class in com.hazelcast.jet.protobuf
-
Adapts a generated Google Protocol Buffers v3 serializer class to the Hazelcast
StreamSerializer
interface. - ProtobufSerializer(Class<T>, int) - Constructor for class com.hazelcast.jet.protobuf.ProtobufSerializer
-
Called by the subclass to initialize this protobuf serializer.
- ProtobufSerializerHook<T extends com.google.protobuf.GeneratedMessageV3> - Class in com.hazelcast.jet.protobuf
-
Simplifies using the Hazelcast Serializer Hook mechanism to register a Google Protocol Buffers serializer with the Hazelcast Jet cluster.
- ProtobufSerializerHook(Class<T>, int) - Constructor for class com.hazelcast.jet.protobuf.ProtobufSerializerHook
-
Creates Protocol Buffers v3 serializer hook.
- protocolType - Variable in class com.hazelcast.config.EndpointConfig
- ProxyFactoryConfig - Class in com.hazelcast.client.config
-
This class is related to SPI.
- ProxyFactoryConfig() - Constructor for class com.hazelcast.client.config.ProxyFactoryConfig
- ProxyFactoryConfig(ProxyFactoryConfig) - Constructor for class com.hazelcast.client.config.ProxyFactoryConfig
- ProxyFactoryConfig(String, ClientProxyFactory) - Constructor for class com.hazelcast.client.config.ProxyFactoryConfig
- ProxyFactoryConfig(String, String) - Constructor for class com.hazelcast.client.config.ProxyFactoryConfig
- publish(E) - Method in interface com.hazelcast.topic.ITopic
-
Publishes the message to all subscribers of this topic.
- PUBLISH - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- PUBLISH_ALL - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- publishAll(Collection<? extends E>) - Method in interface com.hazelcast.topic.ITopic
-
Publishes all messages to all subscribers of this topic.
- publishAllAsync(Collection<? extends E>) - Method in interface com.hazelcast.topic.ITopic
-
Publishes all messages asynchronously to all subscribers of this topic.
- publishAsync(E) - Method in interface com.hazelcast.topic.ITopic
-
Publishes the message asynchronously to all subscribers of this topic.
- publisherId - Variable in class com.hazelcast.config.AbstractWanPublisherConfig
- publishReplicationEvent(WanEvent<T>) - Method in interface com.hazelcast.wan.WanPublisher
-
Publish the
eventObject
WAN replication event. - publishReplicationEventBackup(WanEvent<T>) - Method in interface com.hazelcast.wan.WanPublisher
-
Publish the
eventObject
WAN replication event backup. - publishRepublishedReplicationEvent(WanEvent<T>) - Method in interface com.hazelcast.wan.WanPublisher
-
Republishes the
eventObject
WAN replication event. - publishRepublishedReplicationEventBackup(WanEvent<T>) - Method in interface com.hazelcast.wan.WanPublisher
-
Republishes the
eventObject
WAN replication backup event. - put() - Method in class com.hazelcast.spi.utils.RestClient
- put(Tag<E>, E) - Method in class com.hazelcast.jet.datamodel.ItemsByTag
-
Associates the supplied value with the supplied tag.
- put(Object, Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
- put(K, V) - Method in interface com.hazelcast.cp.CPMap
-
Associates
key
withvalue
. - put(K, V) - Method in interface com.hazelcast.map.BaseMap
-
Associates the specified value with the specified key in this map.
- put(K, V) - Method in interface com.hazelcast.map.IMap
-
Associates the specified value with the specified key in this map.
- put(K, V) - Method in interface com.hazelcast.multimap.BaseMultiMap
-
Stores a key-value pair in the multimap.
- put(K, V) - Method in interface com.hazelcast.multimap.MultiMap
-
Stores a key-value pair in the multimap.
- put(K, V) - Method in interface com.hazelcast.transaction.TransactionalMap
-
Transactional implementation of
IMap.put(Object, Object)
. - put(K, V) - Method in interface com.hazelcast.transaction.TransactionalMultiMap
-
Stores a key-value pair in the multimap.
- put(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.BaseMap
-
Associates the specified value with the specified key in this map with a given ttl (time to live) value.
- put(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Puts an entry into this map with a given TTL (time to live) value.
- put(K, V, long, TimeUnit) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
-
Associates a given value to the specified key and replicates it to the cluster.
- put(K, V, long, TimeUnit) - Method in interface com.hazelcast.transaction.TransactionalMap
-
Transactional implementation of
IMap.put(Object, Object, long, TimeUnit)
. - put(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Puts an entry into this map with a given TTL (time to live) value and max idle time value.
- put(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Associates the specified value with the specified key in the cache using a custom
ExpiryPolicy
. - PUT - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- PUT_ALL - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- PUT_ALL_WITH_METADATA - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- PUT_IF_ABSENT - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- PUT_TRANSIENT - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- putAll(Map<? extends K, ? extends V>) - Method in interface com.hazelcast.map.IMap
- putAll(Map<? extends K, ? extends V>, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Copies all of the entries from the given map to the cache using a custom
ExpiryPolicy
. - putAllAsync(Map<? extends K, ? extends V>) - Method in interface com.hazelcast.map.IMap
-
Asynchronously copies all of the mappings from the specified map to this map.
- putAllAsync(Map<? extends K, Collection<? extends V>>) - Method in interface com.hazelcast.multimap.MultiMap
-
Stores the given Map in the MultiMap asynchronously.
- putAllAsync(K, Collection<? extends V>) - Method in interface com.hazelcast.multimap.MultiMap
-
Stores the given Collection in the specified key of a MultiMap asynchronously.
- putAsync(K, V) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously associates the specified value with the specified key in the cache.
- putAsync(K, V) - Method in interface com.hazelcast.map.IMap
-
Asynchronously puts the given key and value.
- putAsync(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Asynchronously puts the given key and value into this map with a given TTL (time to live) value.
- putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Asynchronously puts the given key and value into this map with a given TTL (time to live) value and max idle time value.
- putAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously associates the specified value with the specified key in the cache using a custom
ExpiryPolicy
. - putIfAbsent(Object, Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
- putIfAbsent(K, V) - Method in interface com.hazelcast.cp.CPMap
-
Associates
key
withvalue
only ifkey
is not present. - putIfAbsent(K, V) - Method in interface com.hazelcast.map.BaseMap
-
If the specified key is not already associated with a value, associate it with the given value.
- putIfAbsent(K, V) - Method in interface com.hazelcast.map.IMap
-
If the specified key is not already associated with a value, associate it with the given value.
- putIfAbsent(K, V) - Method in interface com.hazelcast.transaction.TransactionalMap
-
Transactional implementation of
IMap.putIfAbsent(Object, Object)
. - putIfAbsent(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Puts an entry into this map with a given TTL (time to live) value, if the specified key is not already associated with a value.
- putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Puts an entry into this map with a given TTL (time to live) value and max idle time value.
- putIfAbsent(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Associates the specified key with the given value if and only if there is not yet a mapping defined for the specified key.
- putIfAbsentAsync(K, V) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously associates the specified key with the given value if and only if there is not yet a mapping defined for the specified key.
- putIfAbsentAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously associates the specified key with the given value if and only if there is not yet a mapping defined for the specified key.
- PutIfAbsentMergePolicy<V,
T extends MergingValue<V>> - Class in com.hazelcast.spi.merge -
Merges data structure entries from source to destination if they don't exist in the destination data structure.
- PutIfAbsentMergePolicy() - Constructor for class com.hazelcast.spi.merge.PutIfAbsentMergePolicy
- putTransient(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Same as
IMap.put(Object, Object, long, TimeUnit)
except that the map store, if defined, will not be called to load/store/persist the entry. - putTransient(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Same as
IMap.put(Object, Object, long, TimeUnit)
except that the map store, if defined, will not be called to load/store/persist the entry. - PythonServiceConfig - Class in com.hazelcast.jet.python
-
Configuration object for the Python service factory, used in a
mapUsingPython
stage. - PythonServiceConfig() - Constructor for class com.hazelcast.jet.python.PythonServiceConfig
- PythonTransforms - Class in com.hazelcast.jet.python
-
Transforms which allow the user to call Python user-defined functions from inside a Jet pipeline.
Q
- QuadFunction<T0,
T1, T2, T3, R> - Interface in com.hazelcast.jet.function -
Represents a four-arity function that accepts four arguments and produces a result.
- QUERY_MAX_LOCAL_PARTITION_LIMIT_FOR_PRE_CHECK - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Maximum value of local partitions to trigger local pre-check for
Predicates.alwaysTrue()
predicate query operations on maps. - QUERY_OPTIMIZER_TYPE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Type of Query Optimizer.
- QUERY_PREDICATE_PARALLEL_EVALUATION - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Run Query Evaluations for multiple partitions in parallel.
- QUERY_RESULT_SIZE_LIMIT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Result size limit for query operations on maps.
- QueryCache<K,
V> - Interface in com.hazelcast.map -
A concurrent, queryable data structure which is used to cache results of a continuous query executed on an
IMap
. - QueryCacheConfig - Class in com.hazelcast.config
-
Contains configuration for
QueryCache
. - QueryCacheConfig() - Constructor for class com.hazelcast.config.QueryCacheConfig
- QueryCacheConfig(QueryCacheConfig) - Constructor for class com.hazelcast.config.QueryCacheConfig
- QueryCacheConfig(String) - Constructor for class com.hazelcast.config.QueryCacheConfig
- QueryConstants - Enum Class in com.hazelcast.query
-
Contains constants for Query.
- QueryException - Exception in com.hazelcast.query
-
Exception class for the Query.
- QueryException() - Constructor for exception com.hazelcast.query.QueryException
- QueryException(String) - Constructor for exception com.hazelcast.query.QueryException
- QueryException(String, Throwable) - Constructor for exception com.hazelcast.query.QueryException
- QueryException(Throwable) - Constructor for exception com.hazelcast.query.QueryException
- QueryResultSizeExceededException - Exception in com.hazelcast.map
-
This exception is thrown when a query exceeds a configurable result size limit.
- QueryResultSizeExceededException() - Constructor for exception com.hazelcast.map.QueryResultSizeExceededException
- QueryResultSizeExceededException(int, String) - Constructor for exception com.hazelcast.map.QueryResultSizeExceededException
- QueryResultSizeExceededException(String) - Constructor for exception com.hazelcast.map.QueryResultSizeExceededException
- queue() - Method in class com.hazelcast.jet.core.test.TestInbox
-
Retrieves the queue backing the inbox.
- queue(int) - Method in class com.hazelcast.jet.core.test.TestOutbox
-
Exposes individual output queues to the testing code.
- QUEUE - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
-
Queue
- QueueConfig - Class in com.hazelcast.config
-
Contains the configuration for an
IQueue
. - QueueConfig() - Constructor for class com.hazelcast.config.QueueConfig
- QueueConfig(QueueConfig) - Constructor for class com.hazelcast.config.QueueConfig
- QueueConfig(String) - Constructor for class com.hazelcast.config.QueueConfig
- QueuePermission - Class in com.hazelcast.security.permission
- QueuePermission(String, String...) - Constructor for class com.hazelcast.security.permission.QueuePermission
- QUEUES_CAPACITY - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
- QUEUES_SIZE - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
- QueueStore<T> - Interface in com.hazelcast.collection
-
QueueStore makes a queue backed by a central data store; such as database, disk, etc.
- QueueStoreConfig - Class in com.hazelcast.config
-
Configuration for the
QueueStore
. - QueueStoreConfig() - Constructor for class com.hazelcast.config.QueueStoreConfig
- QueueStoreConfig(QueueStoreConfig) - Constructor for class com.hazelcast.config.QueueStoreConfig
- QueueStoreFactory<T> - Interface in com.hazelcast.collection
-
Creates a new
QueueStore
.
R
- RaftAlgorithmConfig - Class in com.hazelcast.config.cp
-
Configuration for Hazelcast's implementation of the Raft consensus algorithm
- RaftAlgorithmConfig() - Constructor for class com.hazelcast.config.cp.RaftAlgorithmConfig
- RaftAlgorithmConfig(RaftAlgorithmConfig) - Constructor for class com.hazelcast.config.cp.RaftAlgorithmConfig
- RANDOM - Enum constant in enum class com.hazelcast.config.EvictionPolicy
-
Randomly
- RANDOM_MEMBER_PROCESSOR_META_SUPPLIER - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
- randomMember(ProcessorSupplier) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Wraps the provided
ProcessorSupplier
into a meta-supplier that will only use the givenProcessorSupplier
on a random node - RAW - Enum constant in enum class com.hazelcast.config.BitmapIndexOptions.UniqueKeyTransformation
-
Extracted unique key value is interpreted as a whole integer value of byte, short, int or long type.
- RawBytesFileFormat - Class in com.hazelcast.jet.pipeline.file
-
FileFormat
for binary files where the whole file is onebyte[]
item. - ReachedMaxSizeException - Exception in com.hazelcast.map
-
Exception thrown when a write-behind
MapStore
rejects to accept a new element. - ReachedMaxSizeException(String) - Constructor for exception com.hazelcast.map.ReachedMaxSizeException
- read() - Method in class com.hazelcast.config.ConfigStream
- read(byte[]) - Method in class com.hazelcast.config.ConfigStream
- read(byte[]) - Method in interface com.hazelcast.nio.serialization.ByteArraySerializer
-
Converts given byte array to object
- read(byte[], int, int) - Method in class com.hazelcast.config.ConfigStream
- read(byte[], Class<?>) - Method in interface com.hazelcast.nio.serialization.TypedByteArrayDeserializer
-
Reads object from objectDataInputStream
- read(long) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
-
Reads one item from the ringbuffer.
- read(ObjectDataInput) - Method in class com.hazelcast.jet.protobuf.ProtobufSerializer
- read(ObjectDataInput) - Method in interface com.hazelcast.nio.serialization.StreamSerializer
-
Reads object from objectDataInputStream
- read(ObjectDataInput, Class) - Method in interface com.hazelcast.nio.serialization.TypedStreamDeserializer
-
Reads object from objectDataInputStream
- read(CompactReader) - Method in class com.hazelcast.jet.mongodb.compact.ObjectIdCompactSerializer
- read(CompactReader) - Method in interface com.hazelcast.nio.serialization.compact.CompactSerializer
- read(String, ValueCallback<T>) - Method in interface com.hazelcast.query.extractor.ValueReader
-
Read the value of the attribute specified by the path and returns the result via the callback.
- read(String, ValueCollector<T>) - Method in interface com.hazelcast.query.extractor.ValueReader
-
Read the value of the attribute specified by the path and returns the result directly to the collector.
- READ - Enum constant in enum class com.hazelcast.splitbrainprotection.SplitBrainProtectionOn
-
Only read operations will participate in a split brain protection.
- READ_FROM_EVENT_JOURNAL - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- READ_MANY - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- READ_MAP_OR_CACHE_P_LOCAL_PROCESSOR_SUPPLIER - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
- READ_METRICS - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- READ_ONE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- READ_WRITE - Enum constant in enum class com.hazelcast.splitbrainprotection.SplitBrainProtectionOn
-
Both read and write operations will participate in a split brain protection.
- readArrayOfBoolean(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads an array of booleans.
- readArrayOfCompact(String, Class<T>) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads an array of compact objects.
- readArrayOfDate(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads an array of dates consisting of year, month, and day.
- readArrayOfDecimal(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads an array of arbitrary precision and scale floating point numbers.
- readArrayOfFloat32(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads an array of 32-bit IEEE 754 floating point numbers.
- readArrayOfFloat64(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads an array of 64-bit IEEE 754 floating point numbers.
- readArrayOfInt16(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads an array of 16-bit two's complement signed integers.
- readArrayOfInt32(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads an array of 32-bit two's complement signed integers.
- readArrayOfInt64(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads an array of 64-bit two's complement signed integers.
- readArrayOfInt8(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads an array of 8-bit two's complement signed integers.
- readArrayOfNullableBoolean(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a nullable array of nullable booleans.
- readArrayOfNullableFloat32(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a nullable array of nullable 32-bit IEEE 754 floating point numbers.
- readArrayOfNullableFloat64(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a nullable array of nullable 64-bit IEEE 754 floating point numbers.
- readArrayOfNullableInt16(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a nullable array of nullable 16-bit two's complement signed integers.
- readArrayOfNullableInt32(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a nullable array of nullable 32-bit two's complement signed integers.
- readArrayOfNullableInt64(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a nullable array of nullable 64-bit two's complement signed integers.
- readArrayOfNullableInt8(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a nullable array of nullable 8-bit two's complement signed integers.
- readArrayOfString(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads an array of UTF-8 encoded strings.
- readArrayOfTime(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads an array of times consisting of hour, minute, second, and nanoseconds
- readArrayOfTimestamp(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads an array of timestamps consisting of date and time.
- readArrayOfTimestampWithTimezone(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads an array of timestamps with timezone consisting of date, time and timezone offset.
- readBoolean(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a boolean.
- readBoolean(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- readBooleanArray() - Method in interface com.hazelcast.nio.ObjectDataInput
- readBooleanArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- readByte(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- readByteArray() - Method in interface com.hazelcast.nio.ObjectDataInput
- readByteArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- readCacheP(String) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
Returns a supplier of processors for
Sources.cache(String)
. - readChar(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- readCharArray() - Method in interface com.hazelcast.nio.ObjectDataInput
- readCharArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- readCompact(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a compact object
- readCount() - Method in interface com.hazelcast.ringbuffer.ReadResultSet
-
Returns the number of items that have been read before filtering.
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
- readData(ObjectDataInput) - Method in class com.hazelcast.cluster.Address
- readData(ObjectDataInput) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.AttributeConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.BitmapIndexOptions
- readData(ObjectDataInput) - Method in class com.hazelcast.config.BTreeIndexConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.CollectionConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.DataConnectionConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.DataPersistenceConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.DiscoveryConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.DiskTierConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.DurableExecutorConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.EntryListenerConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.EventJournalConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.EvictionConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.ExecutorConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.HotRestartConfig
-
Deprecated.
- readData(ObjectDataInput) - Method in class com.hazelcast.config.IndexConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.ItemListenerConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.ListenerConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.MapConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.MapStoreConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.MemoryTierConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.MergePolicyConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.MerkleTreeConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.MultiMapConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.NearCacheConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.NearCachePreloaderConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.PartitioningAttributeConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.PartitioningStrategyConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.PermissionConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.PNCounterConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.PredicateConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.QueryCacheConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.QueueConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.QueueStoreConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.ReliableTopicConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.ReplicatedMapConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.RingbufferConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.RingbufferStoreConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.ScheduledExecutorConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.TieredStoreConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.TopicConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.UserCodeNamespaceConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.vector.VectorCollectionConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.vector.VectorIndexConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.WanBatchPublisherConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.WanConsumerConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.WanReplicationConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.config.WanReplicationRef
- readData(ObjectDataInput) - Method in class com.hazelcast.config.WanSyncConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.console.Echo
- readData(ObjectDataInput) - Method in class com.hazelcast.jet.config.DeltaJobConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.jet.config.EdgeConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.jet.config.JobConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.jet.config.ResourceConfig
- readData(ObjectDataInput) - Method in class com.hazelcast.jet.core.DAG
- readData(ObjectDataInput) - Method in class com.hazelcast.jet.core.Edge
- readData(ObjectDataInput) - Method in class com.hazelcast.jet.core.metrics.JobMetrics
- readData(ObjectDataInput) - Method in class com.hazelcast.jet.core.metrics.Measurement
- readData(ObjectDataInput) - Method in class com.hazelcast.jet.core.ProcessorMetaSupplier.ExpectNothingProcessorSupplier
- readData(ObjectDataInput) - Method in class com.hazelcast.jet.core.ProcessorMetaSupplier.RandomMemberPms
- readData(ObjectDataInput) - Method in class com.hazelcast.jet.core.ProcessorMetaSupplier.SpecificMemberPms
- readData(ObjectDataInput) - Method in class com.hazelcast.jet.core.Vertex
- readData(ObjectDataInput) - Method in class com.hazelcast.jet.JobStatusEvent
- readData(ObjectDataInput) - Method in interface com.hazelcast.nio.serialization.DataSerializable
-
Reads fields from the input stream
- readData(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.PortableId
-
Deprecated.
- readData(ObjectDataInput) - Method in class com.hazelcast.partition.PartitionAwareKey
- readData(ObjectDataInput) - Method in class com.hazelcast.security.SimpleTokenCredentials
- readData(ObjectDataInput) - Method in class com.hazelcast.security.UsernamePasswordCredentials
- readData(ObjectDataInput) - Method in class com.hazelcast.transaction.TransactionOptions
- readData(ObjectDataInput) - Method in class com.hazelcast.version.MemberVersion
- readData(ObjectDataInput) - Method in class com.hazelcast.version.Version
- readDate(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a date consisting of year, month, and day.
- readDate(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.Reads a date field consisting of year, month of the year and day of the month to LocalDate
- readDateArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.Reads an array of Date's to LocalDate[]
- readDecimal(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads an arbitrary precision and scale floating point number.
- readDecimal(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.Reads a decimal which is arbitrary precision and scale floating-point number to BigDecimal
- readDecimalArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.Reads an array of Decimal's to BigDecimal[]
- readDouble(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- readDoubleArray() - Method in interface com.hazelcast.nio.ObjectDataInput
- readDoubleArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- readFactories(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
- readFilesP(String, String, boolean, boolean, FunctionEx<? super Path, ? extends Stream<I>>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
Returns a supplier of processors for
FileSources.files(String)
to read local files. - readFilesP(String, String, boolean, FunctionEx<? super Path, ? extends Stream<I>>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
Returns a supplier of processors for
Sources.filesBuilder(java.lang.String)
. - readFilesP(String, String, boolean, SupplierEx<? extends DatumReader<D>>, BiFunctionEx<String, ? super D, T>) - Static method in class com.hazelcast.jet.avro.AvroProcessors
-
Returns a supplier of processors for
AvroSources.filesBuilder(java.lang.String, java.lang.Class<D>)
. - readFilesP(String, Charset, String, boolean, BiFunctionEx<? super String, ? super String, ? extends R>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
Returns a supplier of processors for
Sources.filesBuilder(java.lang.String)
. - readFloat(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- readFloat32(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a 32-bit IEEE 754 floating point number.
- readFloat64(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a 64-bit IEEE 754 floating point number.
- readFloatArray() - Method in interface com.hazelcast.nio.ObjectDataInput
- readFloatArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- readFrom(BatchSource<? extends T>) - Method in interface com.hazelcast.jet.pipeline.Pipeline
-
Returns a pipeline stage that represents a bounded (batch) data source.
- readFrom(StreamSource<? extends T>) - Method in interface com.hazelcast.jet.pipeline.Pipeline
-
Returns a pipeline stage that represents an unbounded data source (i.e., an event stream).
- readHadoopP(Permission, ConsumerEx<Configuration>, BiFunctionEx<K, V, R>) - Static method in class com.hazelcast.jet.hadoop.HadoopProcessors
-
Returns a supplier of processors for
FileSources.files(String)
. - readHadoopP(Configuration, BiFunctionEx<K, V, R>) - Static method in class com.hazelcast.jet.hadoop.HadoopProcessors
-
Returns a supplier of processors for
HadoopSources.inputFormat(Configuration, BiFunctionEx)
. - readInt(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- readInt16(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a 16-bit two's complement signed integer.
- readInt32(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a 32-bit two's complement signed integer.
- readInt64(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a 64-bit two's complement signed integer.
- readInt8(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads an 8-bit two's complement signed integer.
- readIntArray() - Method in interface com.hazelcast.nio.ObjectDataInput
- readIntArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- readJdbcP(SupplierEx<? extends Connection>, ToResultSetFunction, FunctionEx<? super ResultSet, ? extends T>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
Returns a supplier of processors for
Sources.jdbc(SupplierEx, ToResultSetFunction, FunctionEx)
. - readJdbcP(DataConnectionRef, ToResultSetFunction, FunctionEx<? super ResultSet, ? extends T>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
Returns a supplier of processors for
Sources.jdbc(DataConnectionRef, ToResultSetFunction, FunctionEx)
. - readJdbcP(String, String, FunctionEx<? super ResultSet, ? extends T>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
Returns a supplier of processors for
Sources.jdbc(String, String, FunctionEx)
. - readJdbcP(String, String, Properties, FunctionEx<? super ResultSet, ? extends T>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
- readKeyValueTypes(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
- readLine() - Method in interface com.hazelcast.console.LineReader
- readListenerConfigurations(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
- readListP(String) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
Returns a supplier of processors for
Sources.list(String)
. - readLong(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- readLongArray() - Method in interface com.hazelcast.nio.ObjectDataInput
- readLongArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- readManyAsync(long, int, int, IFunction<E, Boolean>) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
-
Reads a batch of items from the Ringbuffer.
- readMapP(String) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
Returns a supplier of processors for
Sources.map(String)
. - readMapP(String, Predicate<K, V>, Projection<? super Map.Entry<K, V>, ? extends T>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
Returns a supplier of processors for
Sources.map(String, Predicate, Projection)
. - readNullableBoolean(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a nullable boolean.
- readNullableFloat32(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a nullable 32-bit IEEE 754 floating point number.
- readNullableFloat64(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a nullable 64-bit IEEE 754 floating point number.
- readNullableInt16(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a nullable 16-bit two's complement signed integer.
- readNullableInt32(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a nullable 32-bit two's complement signed integer.
- readNullableInt64(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a nullable 64-bit two's complement signed integer.
- readNullableInt8(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a nullable 8-bit two's complement signed integer.
- readObject() - Method in interface com.hazelcast.nio.ObjectDataInput
- readObject(Class) - Method in interface com.hazelcast.nio.ObjectDataInput
- readOne(long) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
-
Reads one item from the Ringbuffer.
- ReadOnly - Interface in com.hazelcast.core
-
Allows notifying Hazelcast that the processing unit implementing this interface will not do any modifications.
- readPortable(PortableReader) - Method in interface com.hazelcast.nio.serialization.Portable
-
Deprecated.Read portable fields using PortableReader
- readPortable(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- readPortableArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- readRemoteCacheP(String, ClientConfig) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
Returns a supplier of processors for
Sources.remoteCache(String, ClientConfig)
. - readRemoteListP(String, ClientConfig) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
Returns a supplier of processors for
Sources.remoteList(String, ClientConfig)
. - ReadResultSet<E> - Interface in com.hazelcast.ringbuffer
-
The result of a
Ringbuffer.readManyAsync(long, int, int, com.hazelcast.core.IFunction)
operation. - readShort(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- readShortArray() - Method in interface com.hazelcast.nio.ObjectDataInput
- readShortArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- readString() - Method in interface com.hazelcast.nio.ObjectDataInput
- readString(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a UTF-8 encoded string.
- readString(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- readStringArray() - Method in interface com.hazelcast.nio.ObjectDataInput
- readStringArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.
- readTenant(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
- readTime(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a time consisting of hour, minute, second, and nanoseconds.
- readTime(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.Reads a time field consisting of hour, minute, seconds and nanos parts to LocalTime
- readTimeArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.Reads an array of Time's to LocalTime[]
- readTimestamp(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a timestamp consisting of date and time.
- readTimestamp(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.Reads a timestamp field consisting of year, month of the year, day of the month, hour, minute, seconds, nanos parts to LocalDateTime
- readTimestampArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.Reads an array of Timestamp's to LocalDateTime[]
- readTimestampWithTimezone(String) - Method in interface com.hazelcast.nio.serialization.compact.CompactReader
-
Reads a timestamp with timezone consisting of date, time and timezone offset.
- readTimestampWithTimezone(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.Reads a timestamp with timezone field consisting of year, month of the year, day of the month, offset seconds, hour, minute, seconds, nanos parts to OffsetDateTime
- readTimestampWithTimezoneArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.Reads an array of TimestampWithTimezone's to OffsetDateTime[]
- readUTF() - Method in interface com.hazelcast.nio.ObjectDataInput
-
Deprecated.for the sake of better naming. Use
ObjectDataInput.readString()
instead - readUTF(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.for the sake of better naming. Use
PortableReader.readString(String)
instead - readUTFArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-
Deprecated.for the sake of better naming. Use
ObjectDataInput.readStringArray()
instead - readUTFArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Deprecated.for the sake of better naming. Use
PortableReader.readStringArray(String)
instead - REAL - Enum constant in enum class com.hazelcast.sql.SqlColumnType
-
REAL type, represented by
Float
- RealmConfig - Class in com.hazelcast.config.security
-
Security realm represents the security configuration for part of the system (e.g. member-to-member communication).
- RealmConfig() - Constructor for class com.hazelcast.config.security.RealmConfig
- RealmConfigCallback - Class in com.hazelcast.security
-
This JAAS
Callback
is used to retrieve aRealmConfig
from client or member configuration. - RealmConfigCallback(String) - Constructor for class com.hazelcast.security.RealmConfigCallback
- RealmNameCallback - Class in com.hazelcast.security
-
This
Callback
allows retrieving the current security realm name. - RealmNameCallback() - Constructor for class com.hazelcast.security.RealmNameCallback
- rebalance() - Method in interface com.hazelcast.jet.pipeline.BatchStage
- rebalance() - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Returns a new stage that applies data rebalancing to the output of this stage.
- rebalance() - Method in interface com.hazelcast.jet.pipeline.StreamStage
- rebalance(FunctionEx<? super T, ? extends K>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- rebalance(FunctionEx<? super T, ? extends K>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Returns a new stage that applies data rebalancing to the output of this stage.
- rebalance(FunctionEx<? super T, ? extends K>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- RECEIVE - Enum constant in enum class com.hazelcast.config.OnJoinPermissionOperationName
-
Operation which replaces locally configured permissions by the ones received from cluster.
- RECEIVED_BATCHES - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
- RECEIVED_COUNT - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
- receiveFn(BiConsumerEx<? super C, ? super T_NEW>) - Method in class com.hazelcast.jet.pipeline.SinkBuilder
-
Sets the function Jet will call upon receiving an item.
- receiveFn(BiConsumerEx<? super S, ? super T_NEW>) - Method in class com.hazelcast.jet.pipeline.test.AssertionSinkBuilder
-
Sets the function Jet will call upon receiving every item.
- RecentlyActiveSplitBrainProtectionConfigBuilder - Class in com.hazelcast.config
-
Builder for a
SplitBrainProtectionConfig
configured withRecentlyActiveSplitBrainProtectionFunction
that considers members present in the context of a split brain protection if the last received heartbeat is within a recent window of time. - RecordPart - Interface in com.hazelcast.jet.cdc
-
Represents the top-level component of a
ChangeRecord
, such as the key or the value. - RECOVER - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- recreateAttachedDirectory(String) - Method in interface com.hazelcast.jet.core.ProcessorSupplier.Context
-
Behaves like
ProcessorSupplier.Context.attachedDirectory(java.lang.String)
, but if the directory already exists, it deletes and recreates all its contents. - recreateAttachedDirectory(String) - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
- recreateAttachedFile(String) - Method in interface com.hazelcast.jet.core.ProcessorSupplier.Context
-
Behaves like
ProcessorSupplier.Context.attachedFile(java.lang.String)
, but if the file already exists, it deletes and recreates it. - recreateAttachedFile(String) - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
- reducePermits(int) - Method in interface com.hazelcast.cp.ISemaphore
-
Reduces the number of available permits by the indicated amount.
- reducing(A, FunctionEx<? super T, ? extends A>, BinaryOperatorEx<A>, BinaryOperatorEx<A>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that constructs the result through the process of immutable reduction: The initial accumulated value is
emptyAccValue
. - reflectClass() - Method in class com.hazelcast.jet.pipeline.file.AvroFileFormat
-
Returns the class Jet will deserialize data into (using reflection).
- refreshClientPermissions(Set<PermissionConfig>) - Method in interface com.hazelcast.security.SecurityService
-
Propagates changes made to client permissions to all members and reinitiates
IPermissionPolicy
with new configuration. - refreshPermissions(Set<PermissionConfig>) - Method in interface com.hazelcast.security.IPermissionPolicy
-
Replaces existing permissions with given set of permissions.
- refreshPermissions(Set<PermissionConfig>) - Method in interface com.hazelcast.security.SecurityContext
- regex(String, String) - Static method in class com.hazelcast.query.Predicates
-
Creates a regex predicate that will pass items if the given
pattern
matches the value stored under the given itemattribute
. - RegexConfigPatternMatcher - Class in com.hazelcast.config.matcher
-
This
ConfigPatternMatcher
uses Java regular expressions for matching. - RegexConfigPatternMatcher() - Constructor for class com.hazelcast.config.matcher.RegexConfigPatternMatcher
- RegexConfigPatternMatcher(int) - Constructor for class com.hazelcast.config.matcher.RegexConfigPatternMatcher
- RegionFactoryBeanDefinitionParser - Class in com.hazelcast.spring.hibernate
-
Parser for RegionFactory.
- RegionFactoryBeanDefinitionParser() - Constructor for class com.hazelcast.spring.hibernate.RegionFactoryBeanDefinitionParser
- REGISTER_CACHE_ENTRY_LISTENER - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- registerClass(CompactSerializationConfig, String) - Static method in class com.hazelcast.config.CompactSerializationConfigAccessor
-
Registers a reflective compact serializer for the given class name.
- registerObject(DestroyEventContext) - Method in interface com.hazelcast.spi.tenantcontrol.TenantControl
-
Registers a hook to decouple any Hazelcast object when the tenant is destroyed, This is used, for example, to delete all associated caches from the application when it gets undeployed, so there are no
ClassCastException
afterwards. - registerSerializer(CompactSerializationConfig, String) - Static method in class com.hazelcast.config.CompactSerializationConfigAccessor
-
Registers an explicit compact serializer for the given class and type name.
- registerSerializer(Class<T>, Class<S>) - Method in class com.hazelcast.jet.config.JobConfig
-
Registers the given serializer for the given class for the scope of the job.
- release() - Method in interface com.hazelcast.cp.ISemaphore
-
Releases a permit and increases the number of available permits by one.
- release() - Method in interface com.hazelcast.dataconnection.DataConnection
-
Release a retained data connection.
- release() - Method in class com.hazelcast.dataconnection.DataConnectionBase
- release(int) - Method in interface com.hazelcast.cp.ISemaphore
-
Releases the given number of permits and increases the number of available permits by that amount.
- RELIABLE_TOPIC - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
-
ReliableTopic
- ReliableMessageListener<E> - Interface in com.hazelcast.topic
-
A
MessageListener
to better integrate with the reliable topic. - reliableTopic(ITopic<Object>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink which publishes the items it receives to the provided distributed reliable topic.
- reliableTopic(String) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink which publishes the items it receives to a distributed reliable topic with the specified name.
- ReliableTopicConfig - Class in com.hazelcast.config
-
Configuration for a reliable
ITopic
. - ReliableTopicConfig() - Constructor for class com.hazelcast.config.ReliableTopicConfig
- ReliableTopicConfig(ReliableTopicConfig) - Constructor for class com.hazelcast.config.ReliableTopicConfig
-
Creates a new ReliableTopicConfig by cloning an existing one.
- ReliableTopicConfig(String) - Constructor for class com.hazelcast.config.ReliableTopicConfig
-
Creates a new ReliableTopicConfig with default settings.
- ReliableTopicPermission - Class in com.hazelcast.security.permission
- ReliableTopicPermission(String, String...) - Constructor for class com.hazelcast.security.permission.ReliableTopicPermission
- REMAINING_CAPACITY - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- remainingCapacity() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
-
Returns the remaining capacity of the ringbuffer.
- REMOTE_CACHE_READER_FUNCTION - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
- REMOTE_MAP_QUERY_READER_FUNCTION - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
- REMOTE_MAP_READER_FUNCTION - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
- remoteCache(String, ClientConfig) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink that puts
Map.Entry
s it receives into a HazelcastICache
with the specified name in a remote cluster identified by the suppliedClientConfig
. - remoteCache(String, ClientConfig) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Returns a source that fetches entries from the Hazelcast
ICache
with the specified name in a remote cluster identified by the suppliedClientConfig
and emits them asMap.Entry
. - remoteCacheJournal(String, ClientConfig, JournalInitialPosition) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Convenience for
Sources.remoteCacheJournal(String, ClientConfig, JournalInitialPosition, FunctionEx, PredicateEx)
which will pass onlyCREATED
andUPDATED
events and will project the event's key and new value into aMap.Entry
. - remoteCacheJournal(String, ClientConfig, 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 the HazelcastICache
with the specified name from a remote cluster. - remoteList(String, ClientConfig) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink that adds the items it receives to a Hazelcast
IList
with the specified name in a remote cluster identified by the suppliedClientConfig
. - remoteList(String, ClientConfig) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Returns a source that emits items retrieved from a Hazelcast
IList
in a remote cluster identified by the suppliedClientConfig
. - remoteMap(String, ClientConfig) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink that puts
Map.Entry
s it receives into a HazelcastIMap
with the specified name in a remote cluster identified by the suppliedClientConfig
. - remoteMap(String, ClientConfig) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Returns a source that fetches entries from the Hazelcast
IMap
with the specified name in a remote cluster identified by the suppliedClientConfig
and emits them asMap.Entry
. - remoteMap(String, ClientConfig, FunctionEx<? super ChangeRecord, ? extends K>, FunctionEx<? super ChangeRecord, ? extends V>) - Static method in class com.hazelcast.jet.cdc.CdcSinks
-
Returns a sink equivalent to
CdcSinks.map(java.lang.String, com.hazelcast.function.FunctionEx<? super com.hazelcast.jet.cdc.ChangeRecord, ? extends K>, com.hazelcast.function.FunctionEx<? super com.hazelcast.jet.cdc.ChangeRecord, ? extends V>)
, but for a map in a remote Hazelcast cluster identified by the suppliedClientConfig
. - remoteMap(String, ClientConfig, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink that uses the supplied functions to extract the key and value with which to put to a Hazelcast
IMap
in a remote cluster identified by the suppliedClientConfig
. - remoteMap(String, ClientConfig, Predicate<K, V>, Projection<? super Map.Entry<K, V>, ? extends T>) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Returns a source that fetches entries from a remote Hazelcast
IMap
with the specified name in a remote cluster identified by the suppliedClientConfig
. - remoteMap(String, DataConnectionRef) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
The same as the
Sinks.remoteMap(String, ClientConfig)
method. - remoteMap(String, DataConnectionRef) - Static method in class com.hazelcast.jet.pipeline.Sources
-
The same as the
Sources.remoteMap(String, ClientConfig, Predicate, Projection)
method. - remoteMap(String, DataConnectionRef, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
The same as the
Sinks.remoteMap(String, ClientConfig, FunctionEx, FunctionEx)
method. - remoteMap(String, DataConnectionRef, Predicate<K, V>, Projection<? super Map.Entry<K, V>, ? extends T>) - Static method in class com.hazelcast.jet.pipeline.Sources
-
The same as the
Sources.remoteMap(String, ClientConfig, Predicate, Projection)
method. - remoteMapBuilder(String) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Returns a builder to build a source that fetches entries from a remote Hazelcast
IMap
with the specified name. - remoteMapJournal(String, ClientConfig, JournalInitialPosition) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Convenience for
Sources.remoteMapJournal(String, ClientConfig, JournalInitialPosition, FunctionEx, PredicateEx)
which will pass onlyADDED
andUPDATED
events and will project the event's key and new value into aMap.Entry
. - remoteMapJournal(String, ClientConfig, JournalInitialPosition, FunctionEx<? super EventJournalMapEvent<K, V>, ? extends T>, PredicateEx<? super EventJournalMapEvent<K, V>>) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Returns a source that will stream the
EventJournalMapEvent
events of the HazelcastIMap
with the specified name from a remote cluster. - remoteMapJournal(String, DataConnectionRef, JournalInitialPosition) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Convenience for
Sources.remoteMapJournal(String, DataConnectionRef, JournalInitialPosition, FunctionEx, PredicateEx)
which will pass onlyADDED
andUPDATED
events and will project the event's key and new value into aMap.Entry
. - remoteMapJournal(String, DataConnectionRef, JournalInitialPosition, FunctionEx<? super EventJournalMapEvent<K, V>, ? extends T>, PredicateEx<? super EventJournalMapEvent<K, V>>) - Static method in class com.hazelcast.jet.pipeline.Sources
-
The same as the
Sources.remoteMapJournal(String, ClientConfig, JournalInitialPosition, FunctionEx, PredicateEx)
method. - RemoteMapSourceBuilder<K,
V, T> - Class in com.hazelcast.jet.pipeline -
Builder providing a fluent API to build a remote map source.
- remoteMapWithEntryProcessor(String, ClientConfig, FunctionEx<? super E, ? extends K>, FunctionEx<? super E, ? extends EntryProcessor<K, V, R>>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink equivalent to
Sinks.mapWithEntryProcessor(java.lang.String, com.hazelcast.function.FunctionEx<? super E, ? extends K>, com.hazelcast.function.FunctionEx<? super E, ? extends com.hazelcast.map.EntryProcessor<K, V, R>>)
, but for a map in a remote Hazelcast cluster identified by the suppliedClientConfig
. - remoteMapWithEntryProcessor(String, DataConnectionRef, FunctionEx<? super E, ? extends K>, FunctionEx<? super E, ? extends EntryProcessor<K, V, R>>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
The same as the
Sinks.remoteMapWithEntryProcessor(String, ClientConfig, FunctionEx, FunctionEx)
method. - remoteMapWithMerging(String, ClientConfig, BinaryOperatorEx<V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Convenience for
Sinks.remoteMapWithMerging(java.lang.String, com.hazelcast.client.config.ClientConfig, com.hazelcast.function.BinaryOperatorEx<V>)
withMap.Entry
as input item. - remoteMapWithMerging(String, ClientConfig, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends V>, BinaryOperatorEx<V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink equivalent to
Sinks.mapWithMerging(String, BinaryOperatorEx)
, but for a map in a remote Hazelcast cluster identified by the suppliedClientConfig
. - remoteMapWithMerging(String, DataConnectionRef, BinaryOperatorEx<V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
The same as the
Sinks.remoteMapWithMerging(String, ClientConfig, BinaryOperatorEx)
method. - remoteMapWithMerging(String, DataConnectionRef, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends V>, BinaryOperatorEx<V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
The same as the
Sinks.remoteMapWithMerging(String, ClientConfig, FunctionEx, FunctionEx, BinaryOperatorEx)
method. - remoteMapWithUpdating(String, ClientConfig, BiFunctionEx<? super V, ? super E, ? extends V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
- remoteMapWithUpdating(String, ClientConfig, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super V, ? super T, ? extends V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink equivalent to
Sinks.mapWithUpdating(java.lang.String, com.hazelcast.function.FunctionEx<? super T, ? extends K>, com.hazelcast.function.BiFunctionEx<? super V, ? super T, ? extends V>)
, but for a map in a remote Hazelcast cluster identified by the suppliedClientConfig
. - remoteMapWithUpdating(String, DataConnectionRef, BiFunctionEx<? super V, ? super E, ? extends V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
The same as the
Sinks.remoteMapWithUpdating(String, ClientConfig, BiFunctionEx)
method. - remoteMapWithUpdating(String, DataConnectionRef, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super V, ? super T, ? extends V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
The same as the
Sinks.remoteMapWithUpdating(String, ClientConfig, BiFunctionEx)
method. - remoteReliableTopic(String, ClientConfig) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink which publishes the items it receives to a distributed reliable topic with the provided name in a remote cluster identified by the supplied
ClientConfig
. - remove() - Method in interface com.hazelcast.jet.core.Inbox
-
Removes the head of this inbox.
- remove() - Method in class com.hazelcast.jet.core.test.TestInbox
- remove() - Method in class com.hazelcast.spi.merge.RingbufferMergeDataReadOnlyIterator
- remove(E) - Method in interface com.hazelcast.transaction.TransactionalList
-
Removes an item from the transactional list.
- remove(E) - Method in interface com.hazelcast.transaction.TransactionalSet
-
Remove item from transactional set.
- remove(Object) - Method in interface com.hazelcast.map.BaseMap
-
Removes the mapping for a key from this map if it is present.
- remove(Object) - Method in interface com.hazelcast.map.IMap
-
Removes the mapping for a key from this map if it is present.
- remove(Object) - Method in interface com.hazelcast.multimap.BaseMultiMap
-
Removes all the entries associated with the given key.
- remove(Object) - Method in interface com.hazelcast.multimap.MultiMap
-
Removes all the entries with the given key.
- remove(Object) - Method in interface com.hazelcast.transaction.TransactionalMap
-
Transactional implementation of
IMap.remove(Object)
. - remove(Object) - Method in interface com.hazelcast.transaction.TransactionalMultiMap
-
Removes all the entries associated with the given key.
- remove(Object, Object) - Method in interface com.hazelcast.map.BaseMap
-
Removes the entry for a key only if currently mapped to a given value.
- remove(Object, Object) - Method in interface com.hazelcast.map.IMap
-
Removes the entry for a key only if currently mapped to a given value.
- remove(Object, Object) - Method in interface com.hazelcast.multimap.BaseMultiMap
-
Removes the given key value pair from the multimap.
- remove(Object, Object) - Method in interface com.hazelcast.multimap.MultiMap
-
Removes the given key value pair from the multimap.
- remove(Object, Object) - Method in interface com.hazelcast.transaction.TransactionalMap
-
Transactional implementation of
IMap.remove(Object, Object)
. - remove(Object, Object) - Method in interface com.hazelcast.transaction.TransactionalMultiMap
-
Removes the given key value pair from the multimap.
- remove(K) - Method in interface com.hazelcast.cp.CPMap
-
Removes
key
if present. - REMOVE - Enum constant in enum class com.hazelcast.wan.WanEventType
-
Remove event (caused by removing data)
- REMOVE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- REMOVE_ALL - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- REMOVE_DISTRIBUTED_OBJECT_LISTENER - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- REMOVE_ENTRY_LISTENER - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- REMOVE_INTERCEPTOR - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- REMOVE_INVALIDATION_LISTENER - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- REMOVE_ITEM_LISTENER - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- REMOVE_MESSAGE_LISTENER - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- REMOVE_PARTITION_LOST_LISTENER - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- removeAll(Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
-
Removes all entries which match with the supplied predicate.
- removeAsync(K) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously removes the mapping for a key from this cache if it is present.
- removeAsync(K) - Method in interface com.hazelcast.map.IMap
-
Asynchronously removes the given key, returning an
CompletionStage
on which the caller can register further computation stages to be invoked upon remove operation completion or block waiting for the operation to complete using one of blocking ways to wait onCompletionStage.toCompletableFuture()
. - removeAsync(K, V) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously removes the mapping for the given key if and only if the currently mapped value equals to the value of
oldValue
. - removeAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
- removeCache(String, boolean) - Method in interface com.hazelcast.cache.HazelcastCacheManager
-
Removes the associated cache with the given cache name.
- removeCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.config.AbstractCacheConfig
-
Remove a configuration for a
CacheEntryListener
. - removeCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in interface com.hazelcast.config.CacheConfiguration
-
Remove a configuration for a
CacheEntryListener
. - removeClientListener(UUID) - Method in interface com.hazelcast.client.ClientService
-
Removes a ClientListener.
- removeCounter(String) - Method in class com.hazelcast.wan.WanEventCounters
-
Removes the counter for the given
dataStructureName
. - removeCPMember(UUID) - Method in interface com.hazelcast.cp.CPSubsystemManagementService
-
Removes the given unreachable CP member from the active CP members list and all CP groups it belongs to.
- REMOVED - Enum constant in enum class com.hazelcast.cache.CacheEventType
-
An event type indicating that the cache entry was removed.
- REMOVED - Enum constant in enum class com.hazelcast.core.EntryEventType
-
Fired if an entry is removed.
- REMOVED - Enum constant in enum class com.hazelcast.core.ItemEventType
-
Fired when an item is removed.
- REMOVED - Enum constant in enum class com.hazelcast.cp.event.CPMembershipEvent.EventType
-
Event type fired when a CP member is removed from the CP Subsystem.
- removeDistributedObjectListener(UUID) - Method in interface com.hazelcast.core.HazelcastInstance
-
Removes the specified Distributed Object listener.
- removeEntryListener(UUID) - Method in interface com.hazelcast.map.IMap
-
Removes the specified entry listener.
- removeEntryListener(UUID) - Method in interface com.hazelcast.map.QueryCache
- removeEntryListener(UUID) - Method in interface com.hazelcast.multimap.MultiMap
-
Removes the specified entry listener.
- removeEntryListener(UUID) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
-
Removes the specified entry listener.
- removeGroupAvailabilityListener(UUID) - Method in interface com.hazelcast.cp.CPSubsystem
-
Removes CPGroupAvailabilityListener registration.
- removeGroupAvailabilityListener(UUID) - Method in class com.hazelcast.cp.CPSubsystemStubImpl
- removeInterceptor(String) - Method in interface com.hazelcast.map.IMap
-
Removes the given interceptor for this map, so it will not intercept operations anymore.
- removeItemListener(UUID) - Method in interface com.hazelcast.collection.ICollection
-
Removes the specified item listener.
- removeLifecycleListener(UUID) - Method in interface com.hazelcast.core.LifecycleService
-
Removes a lifecycle listener.
- removeLogListener(LogListener) - Method in interface com.hazelcast.logging.LoggingService
- removeMember(Member) - Method in interface com.hazelcast.spi.partitiongroup.MemberGroup
- removeMembershipListener(UUID) - Method in interface com.hazelcast.cluster.Cluster
-
Removes the specified MembershipListener.
- removeMembershipListener(UUID) - Method in interface com.hazelcast.cp.CPSubsystem
-
Removes membership listener registration.
- removeMembershipListener(UUID) - Method in class com.hazelcast.cp.CPSubsystemStubImpl
- removeMessageListener(UUID) - Method in interface com.hazelcast.topic.ITopic
-
Stops receiving messages for the given message listener.
- removeMigrationListener(UUID) - Method in interface com.hazelcast.partition.PartitionService
-
Removes a MigrationListener.
- removeNamespaceConfig(String) - Method in class com.hazelcast.config.UserCodeNamespacesConfig
- removeObserver(UUID) - Method in interface com.hazelcast.jet.Observable
-
Removes a previously added
Observer
identified by its assigned registration ID. - removePartition(int) - Method in class com.hazelcast.jet.core.EventTimeMapper
-
Removes a partition that will no longer have events.
- removePartitionLostListener(UUID) - Method in interface com.hazelcast.cache.ICache
-
Removes the specified cache partition lost listener.
- removePartitionLostListener(UUID) - Method in interface com.hazelcast.map.IMap
-
Removes the specified map partition lost listener.
- removePartitionLostListener(UUID) - Method in interface com.hazelcast.partition.PartitionService
-
Removes a PartitionLostListener.
- removeProperty(String) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
- removeStatusListener(UUID) - Method in interface com.hazelcast.jet.Job
-
Stops delivering all events to the listener with the given registration id.
- replace(K, V) - Method in interface com.hazelcast.map.BaseMap
-
Replaces the entry for a key only if it is currently mapped to some value.
- replace(K, V) - Method in interface com.hazelcast.map.IMap
-
Replaces the entry for a key only if it is currently mapped to some value.
- replace(K, V) - Method in interface com.hazelcast.transaction.TransactionalMap
-
Transactional implementation of
IMap.replace(Object, Object)
. - replace(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Atomically replaces the assigned value of the given key by the specified value using a custom
ExpiryPolicy
. - replace(K, V, V) - Method in interface com.hazelcast.map.BaseMap
-
Replaces the entry for a key only if currently mapped to a given value.
- replace(K, V, V) - Method in interface com.hazelcast.map.IMap
-
Replaces the entry for a key only if currently mapped to a given value.
- replace(K, V, V) - Method in interface com.hazelcast.transaction.TransactionalMap
-
Transactional implementation of
IMap.replace(Object, Object, Object)
. - replace(K, V, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Atomically replaces the currently assigned value for the given key with the specified
newValue
if and only if the currently assigned value equals the value ofoldValue
using a customExpiryPolicy
. - REPLACE - Enum constant in enum class com.hazelcast.jet.mongodb.WriteMode
-
Performs replace.
- REPLACE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- REPLACE_ALL - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.hazelcast.map.IMap
- replaceAsync(K, V) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously replaces the assigned value of the given key by the specified value.
- replaceAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously replaces the assigned value of the given key by the specified value using a custom
ExpiryPolicy
. - replaceAsync(K, V, V) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously replaces the currently assigned value for the given key with the specified
newValue
if and only if the currently assigned value equals the value ofoldValue
. - replaceAsync(K, V, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously replaces the currently assigned value for the given key with the specified
newValue
if and only if the currently assigned value equals the value ofoldValue
using a customExpiryPolicy
. - replaceVariables(Node) - Method in class com.hazelcast.config.AbstractYamlConfigBuilder
- replicaMigrationCompleted(ReplicaMigrationEvent) - Method in interface com.hazelcast.partition.MigrationListener
-
Called when a partition replica migration is completed successfully.
- ReplicaMigrationEvent - Interface in com.hazelcast.partition
-
An event fired when a partition replica migration completes or fails.
- replicaMigrationFailed(ReplicaMigrationEvent) - Method in interface com.hazelcast.partition.MigrationListener
-
Called when a partition replica migration is failed.
- ReplicatedMap<K,
V> - Interface in com.hazelcast.replicatedmap -
A ReplicatedMap is a map data structure with weak consistency and has entries stored locally on every node of the cluster.
- REPLICATEDMAP - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
-
ReplicatedMap
- ReplicatedMapCantBeCreatedOnLiteMemberException - Exception in com.hazelcast.replicatedmap
-
Thrown when
HazelcastInstance.getReplicatedMap(String)
is invoked on a lite member. - ReplicatedMapCantBeCreatedOnLiteMemberException(Address) - Constructor for exception com.hazelcast.replicatedmap.ReplicatedMapCantBeCreatedOnLiteMemberException
- ReplicatedMapCantBeCreatedOnLiteMemberException(String) - Constructor for exception com.hazelcast.replicatedmap.ReplicatedMapCantBeCreatedOnLiteMemberException
- ReplicatedMapConfig - Class in com.hazelcast.config
-
Contains the configuration for an
ReplicatedMap
- ReplicatedMapConfig() - Constructor for class com.hazelcast.config.ReplicatedMapConfig
- ReplicatedMapConfig(ReplicatedMapConfig) - Constructor for class com.hazelcast.config.ReplicatedMapConfig
- ReplicatedMapConfig(String) - Constructor for class com.hazelcast.config.ReplicatedMapConfig
-
Creates a ReplicatedMapConfig with the given name.
- ReplicatedMapPermission - Class in com.hazelcast.security.permission
- ReplicatedMapPermission(String, String...) - Constructor for class com.hazelcast.security.permission.ReplicatedMapPermission
- replicatedMapService(String) - Static method in class com.hazelcast.jet.pipeline.ServiceFactories
-
Returns a factory that provides a
ReplicatedMap
as the service object. - REPLICATING - Enum constant in enum class com.hazelcast.wan.WanPublisherState
-
State where both enqueuing new events is allowed, enqueued events are replicated to the target cluster and WAN sync is enabled.
- reportEvent(long) - Method in interface com.hazelcast.jet.core.WatermarkPolicy
-
Called to report the observation of an event with the given timestamp.
- requestedByUser() - Method in interface com.hazelcast.jet.core.JobSuspensionCause
-
True if the user explicitly suspended the job.
- REQUIRED - Enum constant in enum class com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
-
Required
- requiredF0() - Method in class com.hazelcast.jet.datamodel.Tuple2
-
Returns the value of the f0, throwing if it's null.
- requiredF1() - Method in class com.hazelcast.jet.datamodel.Tuple2
-
Returns the value of the f1, throwing if it's null..
- requireNonEmpty(String, String) - Static method in class com.hazelcast.config.security.SimpleAuthenticationConfig
- requiresTenantContext() - Method in interface com.hazelcast.spi.tenantcontrol.Tenantable
- REQUISITE - Enum constant in enum class com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
-
Requisite
- reset() - Method in class com.hazelcast.config.ConfigStream
- reset() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
-
Wipes and resets the whole CP Subsystem state and initializes it as if the Hazelcast cluster is starting up initially.
- reset() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
-
Resets the observed state by this PN counter.
- reset() - Method in class com.hazelcast.jet.core.test.TestOutbox
- reset() - Method in interface com.hazelcast.query.PagingPredicate
-
Resets for reuse.
- reset() - Method in interface com.hazelcast.wan.WanPublisher
-
Resets the publisher (e.g. before split-brain merge).
- resetLevel() - Method in class com.hazelcast.logging.LoggerFactorySupport
- resetLevel() - Method in class com.hazelcast.logging.NoLogFactory
- ResettableSingletonTraverser<T> - Class in com.hazelcast.jet.core
-
Traverses over a single item which can be set from the outside, by using this traverser as a
Consumer<T>
. - ResettableSingletonTraverser() - Constructor for class com.hazelcast.jet.core.ResettableSingletonTraverser
- RESOLVE_NOT_READY_ADDRESSES - Static variable in class com.hazelcast.kubernetes.KubernetesProperties
-
Configuration key:
resolve-not-ready-addresses
- RESOURCE_CONFIG - Static variable in class com.hazelcast.jet.config.JetConfigDataSerializerHook
-
Serialization ID of the
ResourceConfig
class. - ResourceChecks - Enum Class in com.hazelcast.jet.mongodb
-
Defines when and if database and collection existence will be checked.
- ResourceConfig - Class in com.hazelcast.jet.config
-
Describes a single resource to deploy to the Jet cluster.
- ResourceConfig(URL, String, ResourceType) - Constructor for class com.hazelcast.jet.config.ResourceConfig
-
Creates a resource config with the given properties.
- ResourceType - Enum Class in com.hazelcast.jet.config
-
Represents the type of the resource to be uploaded.
- resourceTypes() - Method in interface com.hazelcast.dataconnection.DataConnection
-
Returns the list of possible values for
DataConnectionResource.type()
, that will be returned whenDataConnection.listResources()
is called. - resourceTypes() - Method in class com.hazelcast.dataconnection.HazelcastDataConnection
- resourceTypes() - Method in class com.hazelcast.jet.kafka.KafkaDataConnection
- resourceTypes() - Method in class com.hazelcast.jet.mongodb.dataconnection.MongoDataConnection
- RESPONSE_THREAD_COUNT - Static variable in class com.hazelcast.client.properties.ClientProperty
-
The number of response threads.
- RESPONSE_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The number of threads that process responses.
- RESPONSE_THREAD_DYNAMIC - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Enabled dynamic switching between processing responses on the io threads and offloading the response threads.
- ResponseAlreadySentException - Exception in com.hazelcast.spi.exception
-
A HazelcastException indicating that there is some kind of system error causing a response to be send multiple times for some operation.
- ResponseAlreadySentException() - Constructor for exception com.hazelcast.spi.exception.ResponseAlreadySentException
- ResponseAlreadySentException(String) - Constructor for exception com.hazelcast.spi.exception.ResponseAlreadySentException
- RestApiConfig - Class in com.hazelcast.config
-
Deprecated, for removal: This API element is subject to removal in a future version.since 5.5, use RestConfig instead. Will be removed at 6.0.
- RestApiConfig() - Constructor for class com.hazelcast.config.RestApiConfig
-
Deprecated.
- restart() - Method in interface com.hazelcast.jet.Job
-
Gracefully stops the current execution and schedules a new execution with the current member list of the Jet cluster.
- RestartableException - Exception in com.hazelcast.jet
-
Exception to throw from job-executing methods to indicate a failure that can be resolved by restarting the job.
- RestartableException() - Constructor for exception com.hazelcast.jet.RestartableException
- RestartableException(String) - Constructor for exception com.hazelcast.jet.RestartableException
- RestartableException(String, Throwable) - Constructor for exception com.hazelcast.jet.RestartableException
- RestartableException(Throwable) - Constructor for exception com.hazelcast.jet.RestartableException
- RestClient - Class in com.hazelcast.spi.utils
- RestClient.Response - Class in com.hazelcast.spi.utils
- RestClient.WatchResponse - Class in com.hazelcast.spi.utils
- RestClientException - Exception in com.hazelcast.spi.exception
-
Exception to indicate any issues while executing a REST call.
- RestClientException(String, int) - Constructor for exception com.hazelcast.spi.exception.RestClientException
- RestClientException(String, Throwable) - Constructor for exception com.hazelcast.spi.exception.RestClientException
- RestConfig - Class in com.hazelcast.config.rest
-
This class allows controlling the Hazelcast REST API feature.
- RestConfig() - Constructor for class com.hazelcast.config.rest.RestConfig
-
Default constructor for RestConfig.
- RestConfig.Ssl - Class in com.hazelcast.config.rest
- RestConfig.Ssl.ClientAuth - Enum Class in com.hazelcast.config.rest
-
Client authentication types.
- RestEndpointGroup - Enum Class in com.hazelcast.config
-
Deprecated, for removal: This API element is subject to removal in a future version.since 5.5, use RestConfig instead. Will be removed at 6.0.
- restoreFromSnapshot(Inbox) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Implements the boilerplate of polling the inbox, casting the items to
Map.Entry
, and extracting the key and value. - restoreFromSnapshot(Inbox) - Method in interface com.hazelcast.jet.core.Processor
-
Called when a batch of items is received during the "restore from snapshot" operation.
- restoreFromSnapshot(Object, Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Called to restore one key-value pair from the snapshot to processor's internal state.
- restoreSnapshotFn(BiConsumerEx<? super C, ? super List<S>>) - Method in class com.hazelcast.jet.pipeline.SourceBuilder.FaultTolerant
-
Sets the function that restores the source's state from a snapshot.
- restoreWatermark(int, long) - Method in class com.hazelcast.jet.core.EventTimeMapper
-
Restore watermark value from state snapshot.
- RestServerEndpointConfig - Class in com.hazelcast.config
-
Deprecated, for removal: This API element is subject to removal in a future version.since 5.5, use RestConfig instead. Will be removed at 6.0.
- RestServerEndpointConfig() - Constructor for class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- result() - Method in class com.hazelcast.jet.datamodel.WindowResult
-
Returns the aggregated result.
- results() - Method in class com.hazelcast.core.Pipelining
-
Returns the results.
- resume() - Method in interface com.hazelcast.jet.Job
-
Resumes a suspended job.
- retain() - Method in interface com.hazelcast.dataconnection.DataConnection
-
Prevents the data connection from being closed.
- retain() - Method in class com.hazelcast.dataconnection.DataConnectionBase
- RETAIN_ALL - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- retries(int) - Method in class com.hazelcast.jet.elastic.ElasticSinkBuilder
-
Number of retries the connector will do in addition to Elastic client retries
- retries(int) - Method in class com.hazelcast.jet.elastic.ElasticSourceBuilder
-
Number of retries the connector will do in addition to Elastic client retries
- RETRIEVE_AND_DISPOSE_RESULT - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- RETRIEVE_RESULT - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- retrieveAndDisposeResult(long) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
-
Retrieves and disposes the result with the given taskId
- retrieveInitialSequence() - Method in interface com.hazelcast.topic.ReliableMessageListener
-
Retrieves the initial sequence from which this ReliableMessageListener should start.
- retrieveResult(long) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
-
Retrieves the result with the given taskId
- retry(Callable<T>, int) - Static method in class com.hazelcast.spi.utils.RetryUtils
-
Calls
callable.call()
until it does not throw an exception (but no more thanretries
times). - retry(Callable<T>, int, List<String>) - Static method in class com.hazelcast.spi.utils.RetryUtils
-
Calls
callable.call()
until it does not throw an exception (but no more thanretries
times). - RETRY_ALL - Enum constant in enum class com.hazelcast.client.config.ClientSqlResubmissionMode
-
All queries will be retried after a failure.
- RETRY_SELECTS - Enum constant in enum class com.hazelcast.client.config.ClientSqlResubmissionMode
-
The query will be retried if: no rows were received yet the SQL text starts with `SELECT` (case-insensitive, ignoring white space)
- RETRY_SELECTS_ALLOW_DUPLICATES - Enum constant in enum class com.hazelcast.client.config.ClientSqlResubmissionMode
-
The query will be retried if the SQL text starts with `SELECT` (case-insensitive, ignoring white space).
- RetryableException - Interface in com.hazelcast.spi.exception
-
Marker interface for exceptions to indicate that an operation can be retried.
- RetryableHazelcastException - Exception in com.hazelcast.spi.exception
-
A 'marker' exception that indicates that an operation can be retried.
- RetryableHazelcastException() - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
- RetryableHazelcastException(String) - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
- RetryableHazelcastException(String, Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
- RetryableHazelcastException(Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
- RetryableIOException - Exception in com.hazelcast.spi.exception
-
A
IOException
indicating that there was a IO failure, but it can be retried. - RetryableIOException() - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
- RetryableIOException(String) - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
- RetryableIOException(String, Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
- RetryableIOException(Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
- RetryStrategies - Class in com.hazelcast.jet.retry
-
Collection of factory methods for creating the most frequently used
RetryStrategies
. - RetryStrategies.Builder - Class in com.hazelcast.jet.retry
-
Builder for custom retry strategies.
- RetryStrategy - Interface in com.hazelcast.jet.retry
-
Description of a strategy to take when an action fails, like when connecting to a server.
- RetryUtils - Class in com.hazelcast.spi.utils
-
Static utility class to retry operations.
- REVERSE - Enum constant in enum class com.hazelcast.config.security.LdapRoleMappingMode
-
Role object attribute contains DN of user objects.
- reversed() - Method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#reversed()
- reverseOrder() - Static method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#reverseOrder()
. - rightKeyFn() - Method in class com.hazelcast.jet.pipeline.JoinClause
-
Returns the right-hand key extractor function.
- rightProjectFn() - Method in class com.hazelcast.jet.pipeline.JoinClause
-
Returns the right-hand projection function.
- RING_BUFFER - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
-
RingBuffer
- Ringbuffer<E> - Interface in com.hazelcast.ringbuffer
-
A Ringbuffer is a data structure where the content is stored in a ring-like structure.
- RingbufferConfig - Class in com.hazelcast.config
-
Contains the configuration for the
Ringbuffer
. - RingbufferConfig() - Constructor for class com.hazelcast.config.RingbufferConfig
- RingbufferConfig(RingbufferConfig) - Constructor for class com.hazelcast.config.RingbufferConfig
-
Clones a RingbufferConfig
- RingbufferConfig(String) - Constructor for class com.hazelcast.config.RingbufferConfig
-
Creates a RingbufferConfig with the provided name.
- RingbufferConfig(String, RingbufferConfig) - Constructor for class com.hazelcast.config.RingbufferConfig
-
Creates a new RingbufferConfig by cloning an existing config and overriding the name.
- RingbufferMergeData - Class in com.hazelcast.spi.merge
-
A ringbuffer implementation holding data involved in split-brain healing.
- RingbufferMergeData(int) - Constructor for class com.hazelcast.spi.merge.RingbufferMergeData
- RingbufferMergeData(Ringbuffer<Object>) - Constructor for class com.hazelcast.spi.merge.RingbufferMergeData
- RingbufferMergeDataReadOnlyIterator<E> - Class in com.hazelcast.spi.merge
-
Read-only iterator over items in a provided
RingbufferMergeData
. - RingBufferPermission - Class in com.hazelcast.security.permission
- RingBufferPermission(String, String...) - Constructor for class com.hazelcast.security.permission.RingBufferPermission
- RingbufferStore<T> - Interface in com.hazelcast.ringbuffer
-
Ringbuffer store makes a ring buffer backed by a central data store; such as database, disk, etc.
- RingbufferStoreConfig - Class in com.hazelcast.config
-
Configuration for the
RingbufferStore
. - RingbufferStoreConfig() - Constructor for class com.hazelcast.config.RingbufferStoreConfig
- RingbufferStoreConfig(RingbufferStoreConfig) - Constructor for class com.hazelcast.config.RingbufferStoreConfig
- RingbufferStoreFactory<T> - Interface in com.hazelcast.ringbuffer
-
Creates a new
RingbufferStore
. - ROLLBACK - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- ROLLBACK_TRANSACTION - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- rollbackTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
-
Rollback of the current transaction.
- rollByDate(String) - Method in class com.hazelcast.jet.pipeline.FileSinkBuilder
-
Sets a date pattern that will be included in the file name.
- rollByFileSize(long) - Method in class com.hazelcast.jet.pipeline.FileSinkBuilder
-
Enables rolling by file size.
- rollingAggregate(long, AggregateOperation1<? super T, A, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
-
Attaches a rolling aggregation stage.
- rollingAggregate(AggregateOperation1<? super T, A, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- rollingAggregate(AggregateOperation1<? super T, A, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
- rollingAggregate(AggregateOperation1<? super T, A, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Attaches a rolling aggregation stage.
- rollingAggregate(AggregateOperation1<? super T, A, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
-
Attaches a rolling aggregation stage.
- rollingAggregate(AggregateOperation1<? super T, A, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- rollingAggregate(AggregateOperation1<? super T, A, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
- RoutingStrategy - Enum Class in com.hazelcast.client.config
-
Strategy for routing client connections to members.
- ROW - Enum constant in enum class com.hazelcast.sql.SqlColumnType
-
This type and the value representing it is likely to change or be removed in the future release
- ROWS - Enum constant in enum class com.hazelcast.sql.SqlExpectedResultType
-
The statement must produce rows.
- run() - Method in interface com.hazelcast.jet.function.RunnableEx
- runEx() - Method in interface com.hazelcast.jet.function.RunnableEx
- RunnableEx - Interface in com.hazelcast.jet.function
- RUNNING - Enum constant in enum class com.hazelcast.jet.core.JobStatus
-
The job is currently running.
- RuntimeContext - Class in com.hazelcast.kubernetes
- RuntimeContext(int, int, int, String) - Constructor for class com.hazelcast.kubernetes.RuntimeContext
- RuntimeInterruptedException - Exception in com.hazelcast.core
-
An unchecked version of
InterruptedException
. - RuntimeInterruptedException() - Constructor for exception com.hazelcast.core.RuntimeInterruptedException
- RuntimeInterruptedException(String) - Constructor for exception com.hazelcast.core.RuntimeInterruptedException
- runUntilOutputMatches(long, long) - Method in class com.hazelcast.jet.core.test.TestSupport
-
Normally, the
complete()
method is run repeatedly until it returnstrue
.
S
- s3(String, SupplierEx<? extends S3Client>) - Static method in class com.hazelcast.jet.s3.S3Sinks
-
Convenience for
S3Sinks.s3(String, String, Charset, SupplierEx, FunctionEx)
UsesObject.toString()
to convert the items to lines. - s3(String, String, Charset, SupplierEx<? extends S3Client>, FunctionEx<? super T, String>) - Static method in class com.hazelcast.jet.s3.S3Sinks
-
Creates an AWS S3
Sink
which writes items to files into the given bucket. - s3(List<String>, String, SupplierEx<? extends S3Client>) - Static method in class com.hazelcast.jet.s3.S3Sources
-
Convenience for
S3Sources.s3(List, String, Charset, SupplierEx, BiFunctionEx)
. - s3(List<String>, String, SupplierEx<? extends S3Client>, FunctionEx<? super InputStream, ? extends Stream<I>>, BiFunctionEx<String, ? super I, ? extends T>) - Static method in class com.hazelcast.jet.s3.S3Sources
-
Creates an AWS S3
BatchSource
which lists all the objects in the bucket-list using givenprefix
, reads them using providedreadFileFn
, transforms each read item to the desired output object using givenmapFn
and emits them to downstream. - s3(List<String>, String, SupplierEx<? extends S3Client>, TriFunction<? super InputStream, String, String, ? extends Stream<I>>, BiFunctionEx<String, ? super I, ? extends T>) - Static method in class com.hazelcast.jet.s3.S3Sources
-
Creates an AWS S3
BatchSource
which lists all the objects in the bucket-list using givenprefix
, reads them using providedreadFileFn
, transforms each read item to the desired output object using givenmapFn
and emits them to downstream. - s3(List<String>, String, Charset, SupplierEx<? extends S3Client>, BiFunctionEx<String, String, ? extends T>) - Static method in class com.hazelcast.jet.s3.S3Sources
-
Creates an AWS S3
BatchSource
which lists all the objects in the bucket-list using givenprefix
, reads them line by line, transforms each line to the desired output object using givenmapFn
and emits them to downstream. - S3Sinks - Class in com.hazelcast.jet.s3
-
Contains factory methods for creating AWS S3 sinks.
- S3Sources - Class in com.hazelcast.jet.s3
-
Contains factory methods for creating AWS S3 sources.
- SAFE_SERIALIZATION - Static variable in class com.hazelcast.spi.discovery.multicast.MulticastProperties
-
Property which determines if Java Serialization is used (
false
) or rather the safer and portable one (true
). - SAME_ITEMS_ANY_ORDER - Static variable in class com.hazelcast.jet.core.test.TestSupport
-
An output checker that will claim actual and expected object lists as equal if they both contain the same items, in any order.
- save(Map<K, V>) - Method in interface com.hazelcast.scheduledexecutor.StatefulTask
-
Task callback to capture its state on the provided map.
- saveCurrentTenant() - Method in interface com.hazelcast.spi.tenantcontrol.TenantControlFactory
-
To be called from the application's thread to connect a Hazelcast object with a particular tenant, e.g.
- saveToSnapshot() - Method in interface com.hazelcast.jet.core.Processor
-
Stores the processor's state to a state snapshot by adding items to the outbox's snapshot bucket.
- schedule(Runnable, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
-
Creates and executes a one-shot action that becomes enabled after the given delay.
- schedule(Callable<V>, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
-
Creates and executes a one-shot action that becomes enabled after the given delay.
- SCHEDULE_ON_MEMBER - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- SCHEDULE_ON_PARTITION - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
-
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period.
- SCHEDULED_EXECUTOR - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
-
Scheduled executor service
- ScheduledExecutorConfig - Class in com.hazelcast.config
-
Configuration options for the
IScheduledExecutorService
. - ScheduledExecutorConfig() - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
- ScheduledExecutorConfig(ScheduledExecutorConfig) - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
- ScheduledExecutorConfig(String) - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
- ScheduledExecutorConfig(String, int, int, int, boolean, String) - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
- ScheduledExecutorConfig(String, int, int, int, String, MergePolicyConfig, ScheduledExecutorConfig.CapacityPolicy, boolean, String) - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
- ScheduledExecutorConfig.CapacityPolicy - Enum Class in com.hazelcast.config
-
Capacity policy options
- ScheduledExecutorPermission - Class in com.hazelcast.security.permission
- ScheduledExecutorPermission(String, String...) - Constructor for class com.hazelcast.security.permission.ScheduledExecutorPermission
- ScheduledTaskHandler - Class in com.hazelcast.scheduledexecutor
-
Resource handler pointing to a
IScheduledFuture
. - ScheduledTaskHandler() - Constructor for class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
- ScheduledTaskStatistics - Interface in com.hazelcast.scheduledexecutor
-
Statistics and timing info for a
IScheduledFuture
accessible throughIScheduledFuture.getStats()
- scheduleOnAllMembers(Runnable, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
-
Creates and executes a one-shot action that becomes enabled after the given delay on all cluster
Member
s. - scheduleOnAllMembers(Callable<V>, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
-
Creates and executes a one-shot action that becomes enabled after the given delay on all cluster
Member
s. - scheduleOnAllMembersAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
-
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period on all cluster
Member
s. - scheduleOnKeyOwner(Runnable, Object, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
-
Creates and executes a one-shot action that becomes enabled after the given delay on the partition owner of the given key.
- scheduleOnKeyOwner(Callable<V>, Object, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
-
Creates and executes a one-shot action that becomes enabled after the given delay on the partition owner of the given key.
- scheduleOnKeyOwnerAtFixedRate(Runnable, Object, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
-
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period on the partition owner of the given key.
- scheduleOnMember(Runnable, Member, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
-
Creates and executes a one-shot action that becomes enabled after the given delay at the given
Member
. - scheduleOnMember(Callable<V>, Member, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
-
Creates and executes a one-shot action that becomes enabled after the given delay at the given
Member
. - scheduleOnMemberAtFixedRate(Runnable, Member, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
-
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period at the given
Member
. - scheduleOnMembers(Runnable, Collection<Member>, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
-
Creates and executes a one-shot action that becomes enabled after the given delay on all
Member
s given. - scheduleOnMembers(Callable<V>, Collection<Member>, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
-
Creates and executes a one-shot action that becomes enabled after the given delay on all
Member
s given. - scheduleOnMembersAtFixedRate(Runnable, Collection<Member>, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
-
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period on all
Member
s given. - schema() - Method in interface com.hazelcast.jet.cdc.ChangeRecord
-
Returns the name of the schema containing the record's table.
- schemaValidation(Document) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
- scrollKeepAlive(String) - Method in class com.hazelcast.jet.elastic.ElasticSourceBuilder
-
Set the keepAlive for Elastic search scroll
- SEARCH - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- SEARCH_DYNAMIC_CONFIG_FIRST - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
By default, search for data structures config is performed within static configuration first: Exact match in static config Wildcard match in static config Exact match in dynamic config Wildcard match in dynamic config Fallback to default But sometimes it makes sense to perform search within dynamic configs first.
- SearchOptions - Interface in com.hazelcast.vector
-
Vector search options
- SearchOptionsBuilder - Class in com.hazelcast.vector
-
Vector search options builder
- SearchOptionsBuilder() - Constructor for class com.hazelcast.vector.SearchOptionsBuilder
- searchRequestFn(SupplierEx<SearchRequest>) - Method in class com.hazelcast.jet.elastic.ElasticSourceBuilder
-
Set the search request supplier function
- SearchResult<K,
V> - Interface in com.hazelcast.vector -
Single vector search result
- SecureCallable<V> - Interface in com.hazelcast.security
-
A secure callable that runs in a sandbox.
- SecureStoreConfig - Class in com.hazelcast.config
-
Abstract Secure Store configuration class.
- SecureStoreConfig() - Constructor for class com.hazelcast.config.SecureStoreConfig
- SECURITY_RECOMMENDATIONS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
When set to any not-
null
value, security recommendations are logged on INFO level during the node start. - SecurityConfig - Class in com.hazelcast.config
-
Contains configuration for Security
- SecurityConfig() - Constructor for class com.hazelcast.config.SecurityConfig
- SecurityContext - Interface in com.hazelcast.security
-
SecurityContext is responsible for managing lifecycle of security object such as
ICredentialsFactory
,IPermissionPolicy
etc, to creatingLoginContext
es for member and client authentications and checking permissions for client operations. - SecurityContextCallback - Class in com.hazelcast.security
-
This JAAS
Callback
is used to retrieve aSecurityContext
from the current member. - SecurityContextCallback() - Constructor for class com.hazelcast.security.SecurityContextCallback
- SecurityInterceptor - Interface in com.hazelcast.security
-
This interface allows to intercept requests which were produced by an API call like map.put, queue.offer...
- SecurityInterceptorConfig - Class in com.hazelcast.config
-
This class is used to configure
SecurityInterceptor
- SecurityInterceptorConfig() - Constructor for class com.hazelcast.config.SecurityInterceptorConfig
- SecurityInterceptorConfig(SecurityInterceptor) - Constructor for class com.hazelcast.config.SecurityInterceptorConfig
- SecurityInterceptorConfig(String) - Constructor for class com.hazelcast.config.SecurityInterceptorConfig
- SecurityInterceptorConstants - Class in com.hazelcast.security
- securityRealmGenerator(ConfigXmlGenerator.XmlGenerator, String, RealmConfig) - Method in class com.hazelcast.config.ConfigXmlGenerator
- SecurityService - Interface in com.hazelcast.security
-
Provides necessary methods to initiate security related config changes.
- select(Member) - Method in interface com.hazelcast.cluster.MemberSelector
-
Decides if the given member will be part of an operation or not.
- self() - Method in class com.hazelcast.config.AbstractBaseFactoryWithPropertiesConfig
- self() - Method in class com.hazelcast.config.AuditlogConfig
- self() - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
- self() - Method in class com.hazelcast.config.security.AccessControlServiceConfig
- self() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
- self() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- self() - Method in class com.hazelcast.config.security.SimpleAuthenticationConfig
- self() - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
- self() - Method in class com.hazelcast.config.SSLConfig
- SEMAPHORE - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
-
Semaphore
- SEMAPHORE - Static variable in interface com.hazelcast.cp.CPSubsystem
-
Constant identifying service for
ISemaphore
, to be used withCPSubsystem.getObjectInfos(CPGroupId, String)
- SemaphoreConfig - Class in com.hazelcast.config.cp
-
Contains configuration options for CP
ISemaphore
- SemaphoreConfig() - Constructor for class com.hazelcast.config.cp.SemaphoreConfig
- SemaphoreConfig(String) - Constructor for class com.hazelcast.config.cp.SemaphoreConfig
- SemaphoreConfig(String, boolean, int) - Constructor for class com.hazelcast.config.cp.SemaphoreConfig
- SemaphorePermission - Class in com.hazelcast.security.permission
- SemaphorePermission(String, String...) - Constructor for class com.hazelcast.security.permission.SemaphorePermission
- SEND - Enum constant in enum class com.hazelcast.config.OnJoinPermissionOperationName
-
Operation which refreshes cluster permissions with locally specified ones.
- sequence() - Method in class com.hazelcast.jet.pipeline.test.SimpleEvent
-
Sequence number of the event
- SEQUENCE_CACHE_EXPIRATION_SECONDS - Static variable in class com.hazelcast.jet.cdc.CdcSinks
-
Number of seconds for which the sink will remember the last seen sequence number for an input key (used to detect reordering).
- SEQUENCE_UNAVAILABLE - Static variable in interface com.hazelcast.ringbuffer.ReadResultSet
-
Value returned from methods returning a sequence number when the information is not available (e.g. because of rolling upgrade and some members not returning the sequence).
- sequenceSource() - Method in interface com.hazelcast.jet.cdc.ChangeRecord
-
Specifies the source descriptor of the record's sequence.
- sequenceValue() - Method in interface com.hazelcast.jet.cdc.ChangeRecord
-
Specifies the numeric value part of the record's source sequence.
- SERIALIZABLE_SHOULD_HAVE_VALID_SERIAL_VERSION_UID - Static variable in class com.hazelcast.test.archunit.ArchUnitRules
-
ArchUnit rule checking that Serializable classes have a valid serialVersionUID
- SERIALIZATION_VERSION - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Hazelcast serialization version.
- SerializationConfig - Class in com.hazelcast.config
-
Contains the serialization configuration of
HazelcastInstance
. - SerializationConfig() - Constructor for class com.hazelcast.config.SerializationConfig
- SerializationConfig(SerializationConfig) - Constructor for class com.hazelcast.config.SerializationConfig
- serializationService - Variable in class com.hazelcast.config.AbstractCacheConfig
- serializationService() - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
- serialize(String, GenericRecord) - Method in class com.hazelcast.jet.kafka.HazelcastKafkaAvroSerializer
- Serializer - Interface in com.hazelcast.nio.serialization
-
Base interface of custom serialization interfaces
- SerializerConfig - Class in com.hazelcast.config
-
Contains the serialization configuration for a particular class.
- SerializerConfig() - Constructor for class com.hazelcast.config.SerializerConfig
- SerializerConfig(SerializerConfig) - Constructor for class com.hazelcast.config.SerializerConfig
- SerializerHook<T> - Interface in com.hazelcast.nio.serialization
-
This interface is used to automatically register serializers from external Hazelcast or user modules.
- SerialVersionUidFieldCondition - Class in com.hazelcast.test.archunit
- SERVER - Enum constant in enum class com.hazelcast.config.AbstractXmlConfigBuilder.ConfigType
- SERVER - Enum constant in enum class com.hazelcast.config.InstanceTrackingConfig.InstanceMode
-
This instance was started using the
start.sh
orstart.bat
scripts. - SERVER - Enum constant in enum class com.hazelcast.cp.session.CPSession.CPSessionOwnerType
-
Represents a Hazelcast server
- SERVER_CACHING_PROVIDER - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
-
Deprecated.
- ServerSocketEndpointConfig - Class in com.hazelcast.config
-
Endpoint configuration that defines a listening side (server)
- ServerSocketEndpointConfig() - Constructor for class com.hazelcast.config.ServerSocketEndpointConfig
- SERVICE_DNS - Static variable in class com.hazelcast.kubernetes.KubernetesProperties
-
Configuration key:
service-dns
- SERVICE_DNS_TIMEOUT - Static variable in class com.hazelcast.kubernetes.KubernetesProperties
-
Configuration key:
service-dns-timeout
- SERVICE_LABEL_NAME - Static variable in class com.hazelcast.kubernetes.KubernetesProperties
-
Configuration key:
service-label-name
- SERVICE_LABEL_VALUE - Static variable in class com.hazelcast.kubernetes.KubernetesProperties
-
Configuration key:
service-label-value
- SERVICE_NAME - Static variable in class com.hazelcast.kubernetes.KubernetesProperties
-
Configuration key:
service-name
- SERVICE_PER_POD_LABEL_NAME - Static variable in class com.hazelcast.kubernetes.KubernetesProperties
-
Configuration key:
service-per-pod-label-name
- SERVICE_PER_POD_LABEL_VALUE - Static variable in class com.hazelcast.kubernetes.KubernetesProperties
-
Configuration key:
service-per-pod-label-value
- SERVICE_PORT - Static variable in class com.hazelcast.kubernetes.KubernetesProperties
-
Configuration key:
service-port
- ServiceConfig - Class in com.hazelcast.config
-
Configuration for a single service.
- ServiceConfig() - Constructor for class com.hazelcast.config.ServiceConfig
- ServiceFactories - Class in com.hazelcast.jet.pipeline
-
Utility class with methods that create several useful
service factories
. - ServiceFactory<C,
S> - Class in com.hazelcast.jet.pipeline -
A holder of functions needed to create and destroy a service object used in pipeline transforms such as
stage.mapUsingService()
. - serviceName() - Method in interface com.hazelcast.cp.CPObjectInfo
-
The service name for this object.
- ServiceNotFoundException - Exception in com.hazelcast.spi.exception
-
A
HazelcastException
that indicates that a requested service is not exist. - ServiceNotFoundException(String) - Constructor for exception com.hazelcast.spi.exception.ServiceNotFoundException
- session(long) - Static method in class com.hazelcast.jet.pipeline.WindowDefinition
-
Returns a window definition that aggregates events into session windows.
- sessionTimeout() - Method in class com.hazelcast.jet.pipeline.SessionWindowDefinition
-
Returns the session timeout, which is the largest difference in the timestamps of any two consecutive events in the session window.
- SessionWindowDefinition - Class in com.hazelcast.jet.pipeline
-
Represents the definition of a session window.
- set(double) - Method in class com.hazelcast.jet.accumulator.DoubleAccumulator
-
Sets the value as given.
- set(long) - Method in interface com.hazelcast.cp.IAtomicLong
-
Atomically sets the given value.
- set(long) - Method in class com.hazelcast.jet.accumulator.LongAccumulator
-
Sets the value as given.
- set(long) - Method in interface com.hazelcast.jet.core.metrics.Metric
-
Sets the current value.
- set(long, Object) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
-
Sets the item at the given sequence.
- set(E) - Method in interface com.hazelcast.cp.IAtomicReference
-
Atomically sets the given value.
- set(K, V) - Method in interface com.hazelcast.cp.CPMap
-
Associates
key
withvalue
. - set(K, V) - Method in interface com.hazelcast.map.BaseMap
-
Associates the specified value with the specified key in this map.
- set(K, V) - Method in interface com.hazelcast.map.IMap
-
Puts an entry into this map without returning the old value (which is more efficient than
put()
). - set(K, V) - Method in interface com.hazelcast.transaction.TransactionalMap
-
Transactional implementation of
IMap.set(Object, Object)
. - set(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Puts an entry into this map with a given TTL (time to live) value, without returning the old value (which is more efficient than
put()
). - set(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Puts an entry into this map with a given TTL (time to live) value and max idle time value without returning the old value (which is more efficient than
put()
). - set(T) - Method in class com.hazelcast.jet.accumulator.MutableReference
-
Sets the value as given.
- SET - Enum constant in enum class com.hazelcast.config.MultiMapConfig.ValueCollectionType
-
Store value collection as set
- SET - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
-
Set
- SET - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- SET_EXPIRY_POLICY - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- SET_TTL - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- set1(long) - Method in class com.hazelcast.jet.accumulator.LongLongAccumulator
-
Sets the first value.
- set2(long) - Method in class com.hazelcast.jet.accumulator.LongLongAccumulator
-
Sets the second value.
- setAccessControlServiceConfig(AccessControlServiceConfig) - Method in class com.hazelcast.config.security.RealmConfig
-
Sets the access control service configuration.
- setAcknowledgeType(WanAcknowledgeType) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the strategy for when the target cluster should acknowledge that a WAN event batch has been processed.
- setActions(Set<String>) - Method in class com.hazelcast.config.PermissionConfig
- setAddress(String) - Method in class com.hazelcast.config.VaultSecureStoreConfig
-
Sets the Vault server address.
- setAddresses(List<String>) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Sets given addresses as candidate address list that client will use to establish initial connection
- setAdvancedNetworkConfig(AdvancedNetworkConfig) - Method in class com.hazelcast.config.Config
- setAlgorithm(String) - Method in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
-
Sets the encryption algorithm, such as
AES/CBC/PKCS5Padding
. - setAliasedDiscoveryConfigs(List<DiscoveryStrategyConfig>) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
- setAll(Map<? extends K, ? extends V>) - Method in interface com.hazelcast.map.IMap
-
Copies all of the mappings from the specified map to this map without loading non-existing elements from map store (which is more efficient than
putAll()
). - setAllAsync(Map<? extends K, ? extends V>) - Method in interface com.hazelcast.map.IMap
-
Asynchronously copies all of the mappings from the specified map to this map without loading non-existing elements from map store.
- setAllocatorType(NativeMemoryConfig.MemoryAllocatorType) - Method in class com.hazelcast.config.NativeMemoryConfig
-
Sets the
NativeMemoryConfig.MemoryAllocatorType
to be used while allocating native memory. - setAllowedFutureMillis(long) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
Sets how far to the future is the generator allowed to go to generate IDs without blocking.
- setAllowOverrideDefaultSerializers(boolean) - Method in class com.hazelcast.config.SerializationConfig
-
This configuration should be used cautiously.
- setAllowUnsafe(boolean) - Method in class com.hazelcast.config.SerializationConfig
-
Unsafe, it is not public api of java.
- setAppendRequestBackoffTimeoutInMillis(long) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
- setAppendRequestMaxEntryCount(int) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
- setApplicationContext(ApplicationContext) - Method in class com.hazelcast.spring.context.SpringManagedContext
- setArgument(String, Object) - Method in class com.hazelcast.jet.config.JobConfig
-
Associates the specified value with the specified key.
- setArrayOfBoolean(String, boolean[]) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setArrayOfChar(String, char[]) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setArrayOfDate(String, LocalDate[]) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setArrayOfDecimal(String, BigDecimal[]) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setArrayOfFloat32(String, float[]) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setArrayOfFloat64(String, double[]) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setArrayOfGenericRecord(String, GenericRecord[]) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setArrayOfInt16(String, short[]) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setArrayOfInt32(String, int[]) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setArrayOfInt64(String, long[]) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setArrayOfInt8(String, byte[]) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setArrayOfNullableBoolean(String, Boolean[]) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setArrayOfNullableFloat32(String, Float[]) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setArrayOfNullableFloat64(String, Double[]) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setArrayOfNullableInt16(String, Short[]) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setArrayOfNullableInt32(String, Integer[]) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setArrayOfNullableInt64(String, Long[]) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setArrayOfNullableInt8(String, Byte[]) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setArrayOfString(String, String[]) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setArrayOfTime(String, LocalTime[]) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setArrayOfTimestamp(String, LocalDateTime[]) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setArrayOfTimestampWithTimezone(String, OffsetDateTime[]) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setAsync(long) - Method in interface com.hazelcast.cp.IAtomicLong
-
Atomically sets the given value.
- setAsync(E) - Method in interface com.hazelcast.cp.IAtomicReference
-
Atomically sets the given value.
- setAsync(K, V) - Method in interface com.hazelcast.map.IMap
-
Asynchronously puts the given key and value.
- setAsync(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Asynchronously puts an entry into this map with a given TTL (time to live) value, without returning the old value (which is more efficient than
put()
). - setAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Asynchronously puts an entry into this map with a given TTL (time to live) value and max idle time value without returning the old value (which is more efficient than
put()
). - setAsyncBackupCount(int) - Method in class com.hazelcast.config.CacheConfig
-
Sets the number of asynchronous backups for this
ICache
. - setAsyncBackupCount(int) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the number of asynchronous backups for this
ICache
. - setAsyncBackupCount(int) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
Sets the number of synchronous backups.
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.CollectionConfig
-
Sets the number of asynchronous backups.
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.MapConfig
-
Sets the number of asynchronous backups. 0 means no backups.
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfig
-
Sets the number of asynchronous backups. 0 means no backups
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.QueueConfig
-
Sets the number of asynchronous backups. 0 means no backups.
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.RingbufferConfig
-
Sets the number of asynchronous backups. 0 means no backups.
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.vector.VectorCollectionConfig
-
Sets the number of asynchronous backups. 0 means no backups.
- setAsyncFillup(boolean) - Method in class com.hazelcast.config.ReplicatedMapConfig
-
True if the replicated map is available for reads before the initial replication is completed, false otherwise.
- setAsyncStart(boolean) - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
-
Set true for non-blocking
HazelcastClient.newHazelcastClient()
. - setAttribute(String) - Method in interface com.hazelcast.query.PredicateBuilder
- setAttribute(String, String) - Method in class com.hazelcast.config.MemberAttributeConfig
- setAttributeConfigs(List<AttributeConfig>) - Method in class com.hazelcast.config.MapConfig
- setAttributeName(String) - Method in class com.hazelcast.config.PartitioningAttributeConfig
-
Sets the name of the attribute.
- setAttributes(List<String>) - Method in class com.hazelcast.config.IndexConfig
-
Sets index attributes.
- setAttributes(Map<String, String>) - Method in class com.hazelcast.config.MemberAttributeConfig
- setAuditlogConfig(AuditlogConfig) - Method in class com.hazelcast.config.Config
- setAutoDetectionConfig(AutoDetectionConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Defines the Auto Detection configuration.
- setAutoDetectionConfig(AutoDetectionConfig) - Method in class com.hazelcast.config.JoinConfig
- setAutoDetectionEnabled(boolean) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
- setAutoRemoveStaleData(boolean) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Deprecated.Sets whether automatic removal of stale Hot Restart data is enabled.
- setAutoRemoveStaleData(boolean) - Method in class com.hazelcast.config.PersistenceConfig
-
Sets whether automatic removal of stale Persistence restart data is enabled.
- setAutoScaling(boolean) - Method in class com.hazelcast.jet.config.DeltaJobConfig
- setAutoScaling(boolean) - Method in class com.hazelcast.jet.config.JobConfig
-
Sets whether Jet will scale the job up or down when a member is added or removed from the cluster.
- setAwsConfig(AwsConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Sets configuration to connect nodes in AWS environment.
- setAwsConfig(AwsConfig) - Method in class com.hazelcast.config.JoinConfig
- setAwsConfig(AwsConfig) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the
AwsConfig
used by the discovery mechanism for this WAN publisher. - setAzureConfig(AzureConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Sets configuration to connect nodes in Azure environment.
- setAzureConfig(AzureConfig) - Method in class com.hazelcast.config.JoinConfig
- setAzureConfig(AzureConfig) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the
AzureConfig
used by the discovery mechanism for this WAN publisher. - setBackupAckToClientEnabled(boolean) - Method in class com.hazelcast.client.config.ClientConfig
-
This feature reduces number of hops and increases performance for
RoutingMode.ALL_MEMBERS
routing clients. - setBackupCount(int) - Method in class com.hazelcast.config.CacheConfig
-
Sets the number of synchronous backups.
- setBackupCount(int) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the number of synchronous backups for this
ICache
. - setBackupCount(int) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
Sets the number of synchronous backups.
- setBackupCount(int) - Method in class com.hazelcast.config.CollectionConfig
-
Sets the number of synchronous backups for this collection.
- setBackupCount(int) - Method in class com.hazelcast.config.DynamicConfigurationConfig
-
Returns backup count.
- setBackupCount(int) - Method in class com.hazelcast.config.MapConfig
-
Number of synchronous backups.
- setBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfig
-
Sets the number of synchronous backups.
- setBackupCount(int) - Method in class com.hazelcast.config.QueueConfig
-
Sets the number of synchronous backups for this queue.
- setBackupCount(int) - Method in class com.hazelcast.config.RingbufferConfig
-
Sets the number of synchronous backups.
- setBackupCount(int) - Method in class com.hazelcast.config.vector.VectorCollectionConfig
-
Number of synchronous backups.
- setBackupCount(int) - Method in class com.hazelcast.jet.config.InstanceConfig
-
Deprecated.Sets the number of backups that Jet will maintain for the job metadata and snapshots.
- setBackupCount(int) - Method in class com.hazelcast.jet.config.JetConfig
-
Sets the number of backups that Jet will maintain for the job metadata and snapshots.
- setBackupDir(File) - Method in class com.hazelcast.config.DynamicConfigurationConfig
-
Sets backup directory where declarative configuration backups will be kept.
- setBackupDir(File) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Deprecated.Sets base directory for all Hot Restart stores.
- setBackupDir(File) - Method in class com.hazelcast.config.PersistenceConfig
-
Sets base directory for all Hot Restart stores.
- setBaseDir(File) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Sets the base directory for persisting CP data.
- setBaseDir(File) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Deprecated.Sets base directory for all Hot Restart stores.
- setBaseDir(File) - Method in class com.hazelcast.config.LocalDeviceConfig
-
Sets the base directory for this device.
- setBaseDir(File) - Method in class com.hazelcast.config.PersistenceConfig
-
Sets base directory for all Persistence stores.
- setBaseDir(String) - Method in class com.hazelcast.jet.python.PythonServiceConfig
-
Sets the base directory where the Python files reside.
- setBatchMaxDelayMillis(int) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the maximum amount of time in milliseconds to wait before sending a batch of events to target cluster, if
WanBatchPublisherConfig.getBatchSize()
of events have not arrived within this duration. - setBatchPublisherConfigs(List<WanBatchPublisherConfig>) - Method in class com.hazelcast.config.WanReplicationConfig
-
Sets the list of WAN publisher configurations using the built-in batching WAN implementation for this WAN replication.
- setBatchSize(int) - Method in class com.hazelcast.config.MergePolicyConfig
-
Sets the batch size, which will be used to determine the number of entries to be sent in a merge operation.
- setBatchSize(int) - Method in class com.hazelcast.config.QueryCacheConfig
-
Sets the batch size which will be used to determine number of events to be sent in a batch to
QueryCache
- setBatchSize(int) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the maximum batch size that can be sent to target cluster.
- setBinary(boolean) - Method in class com.hazelcast.config.MultiMapConfig
-
Enables or disables binary (serialized) form for this MultiMap.
- setBitmapIndexOptions(BitmapIndexOptions) - Method in class com.hazelcast.config.IndexConfig
-
Sets bitmap index options of this index config to the given ones.
- setBitsNodeId(int) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
Sets the bit-length of node id component.
- setBitsSequence(int) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
Sets the bit-length of the sequence component.
- setBlacklist(ClassFilter) - Method in class com.hazelcast.config.JavaSerializationFilterConfig
- setBlacklistedPrefixes(String) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Deprecated.Comma-separated list of class prefixes which will never be loaded remotely.
- setBlockSize(int) - Method in class com.hazelcast.config.LocalDeviceConfig
-
Sets the disk block/sector size in bytes.
- setBoolean(String, boolean) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setBTreeIndexConfig(BTreeIndexConfig) - Method in class com.hazelcast.config.IndexConfig
-
Sets B-Tree config of this index to the specified configuration.
- setBufferSize(int) - Method in class com.hazelcast.client.config.SocketOptions
-
Sets the SO_SNDBUF and SO_RCVBUF options to the specified value in KB
- setBufferSize(int) - Method in class com.hazelcast.config.QueryCacheConfig
-
Sets the maximum number of events which can be stored in a buffer of partition.
- setByteOrder(ByteOrder) - Method in class com.hazelcast.config.SerializationConfig
-
Note that configuring use native byte order as enabled will override the byte order set by this method.
- setCacheConfigs(Map<String, CacheSimpleConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of cache configurations, mapped by config name.
- setCacheDeserializedValues(CacheDeserializedValues) - Method in class com.hazelcast.config.MapConfig
-
Configure de-serialized value caching.
- setCacheEntryEventFilterFactory(String) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
- setCacheEntryListenerFactory(String) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
- setCacheEntryListeners(List<CacheSimpleEntryListenerConfig>) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets a list of
CacheSimpleEntryListenerConfig
for thisICache
. - setCacheLoader(String) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Set classname of a class to be used as
CacheLoader
. - setCacheLoaderFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the factory for this
CacheLoader
. - setCacheLoaderFactory(Factory<? extends CacheLoader<K, V>>) - Method in class com.hazelcast.config.AbstractCacheConfig
- setCacheLoaderFactory(Factory<? extends CacheLoader<K, V>>) - Method in interface com.hazelcast.config.CacheConfiguration
-
Set the
CacheLoader
factory. - setCacheLocalEntries(boolean) - Method in class com.hazelcast.config.NearCacheConfig
-
Sets if local entries are also cached in the Near Cache.
- setCacheOptions(String) - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
-
Set the cache ead-timeout params
- setCacheWriter(String) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Set classname of a class to be used as
CacheWriter
. - setCacheWriterFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the factory for this
CacheWriter
. - setCacheWriterFactory(Factory<? extends CacheWriter<? super K, ? super V>>) - Method in class com.hazelcast.config.AbstractCacheConfig
- setCacheWriterFactory(Factory<? extends CacheWriter<? super K, ? super V>>) - Method in interface com.hazelcast.config.CacheConfiguration
-
Set the
CacheWriter
factory. - setCapacity(int) - Method in class com.hazelcast.config.DurableExecutorConfig
-
Sets the ring buffer capacity of the executor task.
- setCapacity(int) - Method in class com.hazelcast.config.EventJournalConfig
-
Sets the capacity of the event journal.
- setCapacity(int) - Method in class com.hazelcast.config.RingbufferConfig
-
Sets the capacity of the ringbuffer.
- setCapacity(int) - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Sets the capacity of the executor The capacity represents the maximum number of tasks that a scheduler can have at any given point in time per partition or per node according to the capacity policy.
- setCapacity(Capacity) - Method in class com.hazelcast.config.LocalDeviceConfig
-
Sets the capacity of this device.
- setCapacity(Capacity) - Method in class com.hazelcast.config.MemoryTierConfig
-
Sets the capacity of this memory tier.
- setCapacity(Capacity) - Method in class com.hazelcast.config.NativeMemoryConfig
-
Sets size (capacity) of the native memory region.
- setCapacityPolicy(ScheduledExecutorConfig.CapacityPolicy) - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Set the capacity policy for the configured capacity value
- setCardinalityEstimatorConfigs(Map<String, CardinalityEstimatorConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of cardinality estimator configurations, mapped by config name.
- setCatalogPersistenceEnabled(boolean) - Method in class com.hazelcast.config.SqlConfig
-
Sets whether SQL Catalog persistence is enabled for the node.
- setCertificate(String) - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Set the location of the certificate in PEM format.
- setCertificatePrivateKey(String) - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Set the location of the private key for the certificate in PEM format.
- setChannelFn(BiFunctionEx<String, Integer, ? extends ManagedChannelBuilder<?>>) - Method in class com.hazelcast.jet.python.PythonServiceConfig
-
Sets the channel function.
- setChar(String, char) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setCheckClassDefErrors(boolean) - Method in class com.hazelcast.config.SerializationConfig
-
When enabled, serialization system will check for class definitions error at start and throw a Serialization Exception with error definition.
- setCiphers(String) - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Set the supported SSL ciphers.
- setClass(Class<? extends Serializer>) - Method in class com.hazelcast.config.SerializerConfig
-
Sets the class of the serializer implementation.
- setClassCacheMode(UserCodeDeploymentConfig.ClassCacheMode) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Deprecated.Configure caching of classes loaded from remote members.
- setClassDefinitions(Set<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.
- setClasses(Class<?>...) - Method in class com.hazelcast.config.CompactSerializationConfig
-
Registers multiple classes to be serialized with Compact serialization.
- setClasses(Collection<String>) - Method in class com.hazelcast.config.ClassFilter
- setClassFilterConfig(JavaSerializationFilterConfig) - Method in class com.hazelcast.config.UserCodeNamespacesConfig
- setClassLoader(ClassLoader) - Method in class com.hazelcast.client.config.ClientConfig
-
Sets the classLoader which is used by serialization and listener configuration
- setClassLoader(ClassLoader) - Method in class com.hazelcast.config.AbstractCacheConfig
- setClassLoader(ClassLoader) - Method in class com.hazelcast.config.Config
-
Sets the class-loader to be used during de-serialization and as context class-loader of Hazelcast internal threads.
- setClassLoader(ClassLoader) - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
- setClassLoaderFactory(JobClassLoaderFactory) - Method in class com.hazelcast.jet.config.JobConfig
-
Sets a custom
JobClassLoaderFactory
that will be used to load job classes and resources on Jet members. - setClassName(String) - Method in class com.hazelcast.client.config.ProxyFactoryConfig
-
Sets class name of proxy factory
- setClassName(String) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
-
Sets the name of the class implementing
WanPublisher
. - setClassName(String) - Method in class com.hazelcast.config.CredentialsFactoryConfig
- setClassName(String) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
- setClassName(String) - Method in class com.hazelcast.config.GlobalSerializerConfig
- setClassName(String) - Method in class com.hazelcast.config.ListenerConfig
-
Sets the class name of the EventListener.
- setClassName(String) - Method in class com.hazelcast.config.LoginModuleConfig
- setClassName(String) - Method in class com.hazelcast.config.MapStoreConfig
-
Sets the name for the MapStore implementation class
- setClassName(String) - Method in class com.hazelcast.config.MemberAddressProviderConfig
- setClassName(String) - Method in class com.hazelcast.config.PermissionPolicyConfig
- setClassName(String) - Method in class com.hazelcast.config.PredicateConfig
-
Sets the class name of the Predicate.
- setClassName(String) - Method in class com.hazelcast.config.QueueStoreConfig
-
Sets the class name of the queue store implementation to be used when instantiating the queue store.
- setClassName(String) - Method in class com.hazelcast.config.RingbufferStoreConfig
- setClassName(String) - Method in class com.hazelcast.config.SecurityInterceptorConfig
- setClassName(String) - Method in class com.hazelcast.config.SerializerConfig
-
Sets the class name of the serializer implementation.
- setClassName(String) - Method in class com.hazelcast.config.ServiceConfig
- setClassName(String) - Method in class com.hazelcast.config.SocketInterceptorConfig
-
Sets the name for the
SocketInterceptor
implementation class. - setClassName(String) - Method in class com.hazelcast.config.WanBatchPublisherConfig
- setClassName(String) - Method in class com.hazelcast.config.WanConsumerConfig
-
Sets the fully qualified class name of the class implementing
WanConsumer
. - setClassName(String) - Method in class com.hazelcast.config.WanCustomPublisherConfig
- setClassNames(List<String>) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
-
Deprecated.
- setClientAuth(RestConfig.Ssl.ClientAuth) - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Set whether client authentication is not wanted ("none"), wanted ("want") or needed ("need").
- setClientBlockUnmappedActions(boolean) - Method in class com.hazelcast.config.SecurityConfig
-
Block or allow actions, submitted as tasks in an Executor from clients and have no permission mappings.
- setClientConfigs(List<ClientConfig>) - Method in class com.hazelcast.client.config.ClientFailoverConfig
-
Sets the configured list of alternative client configurations.
- setClientEndpointConfig(ServerSocketEndpointConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
-
Sets the server socket endpoint config for
CLIENT
protocol. - setClientIcmpPingConfig(ClientIcmpPingConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
ICMP ping is used to detect if machine that a remote hazelcast member runs on alive or not
- setClientPermissionConfigs(Set<PermissionConfig>) - Method in class com.hazelcast.config.SecurityConfig
- setClientPolicyConfig(PermissionPolicyConfig) - Method in class com.hazelcast.config.SecurityConfig
- setClientRealm(String) - Method in class com.hazelcast.config.SecurityConfig
- setClientRealmConfig(String, RealmConfig) - Method in class com.hazelcast.config.SecurityConfig
- setCloudConfig(ClientCloudConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
- setClusterConnectTimeoutMillis(long) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
- setClusterDataRecoveryPolicy(HotRestartClusterDataRecoveryPolicy) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Deprecated.Sets the policy to be used when the cluster is started
- setClusterDataRecoveryPolicy(PersistenceClusterDataRecoveryPolicy) - Method in class com.hazelcast.config.PersistenceConfig
-
Sets the policy to be used when the cluster is started
- setClusterName(String) - Method in class com.hazelcast.client.config.ClientConfig
- setClusterName(String) - Method in class com.hazelcast.config.Config
-
Sets the cluster name uniquely identifying the hazelcast cluster.
- setClusterName(String) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the cluster name used as an endpoint group password for authentication on the target endpoint.
- setClusterName(String) - Method in class com.hazelcast.jet.cdc.mysql.MySqlCdcSources.Builder
-
Logical name that identifies and provides a namespace for the particular database server/cluster being monitored.
- setClusterRoutingConfig(ClusterRoutingConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Sets config for managing how the client routes to members of the cluster.
- setCoalesce(boolean) - Method in class com.hazelcast.config.QueryCacheConfig
-
Set
true
to enable coalescing, otherwise setfalse
. - setCollectionFrequencySeconds(int) - Method in class com.hazelcast.config.BaseMetricsConfig
-
Sets the metrics collection frequency in seconds.
- setColumnBlacklist(String...) - Method in class com.hazelcast.jet.cdc.mysql.MySqlCdcSources.Builder
-
Optional regular expressions that match the fully-qualified names of columns that should be excluded from change event message values.
- setColumnBlacklist(String...) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
Optional regular expressions that match the fully-qualified names of columns that should be excluded from change event message values.
- setCommitIndexAdvanceCountToSnapshot(int) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
- setCommitPeriod(long) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
Specifies how often the connector should confirm processed offsets to the Postgres database's replication slot.
- setCompactSerializationConfig(CompactSerializationConfig) - Method in class com.hazelcast.config.SerializationConfig
- setComparator(EvictionPolicyComparator) - Method in class com.hazelcast.config.EvictionConfig
-
Sets the instance of the configured
EvictionPolicyComparator
implementation. - setComparatorClassName(String) - Method in class com.hazelcast.config.EvictionConfig
-
Sets the class name of the configured
EvictionPolicyComparator
implementation. - setConfig(EdgeConfig) - Method in class com.hazelcast.jet.core.Edge
-
Assigns an
EdgeConfig
to this edge. - SetConfig - Class in com.hazelcast.config
-
Contains the configuration for an
ISet
. - SetConfig() - Constructor for class com.hazelcast.config.SetConfig
- SetConfig(SetConfig) - Constructor for class com.hazelcast.config.SetConfig
- SetConfig(String) - Constructor for class com.hazelcast.config.SetConfig
- setConfigClassLoader(ClassLoader) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
- setConfigObject(Object) - Method in class com.hazelcast.config.ServiceConfig
- setConfigPatternMatcher(ConfigPatternMatcher) - Method in class com.hazelcast.client.config.ClientConfig
-
Sets the pattern matcher which is used to match item names to configuration objects.
- setConfigPatternMatcher(ConfigPatternMatcher) - Method in class com.hazelcast.config.Config
-
Sets the pattern matcher which is used to match item names to configuration objects.
- setConfigurationFile(File) - Method in class com.hazelcast.config.Config
-
Sets the
File
from which this configuration has been retrieved and created. - setConfigurationUrl(URL) - Method in class com.hazelcast.config.Config
-
Sets the
URL
from which this configuration has been retrieved and created. - setConnectionCount(int) - Method in class com.hazelcast.client.config.ClientTpcConfig
-
Sets the number of connections to TPC ports offered by a Hazelcast member.
- setConnectionRetryConfig(ConnectionRetryConfig) - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
-
Connection Retry Config is controls the period among the retries and when should a client gave up retrying.
- setConnectionStrategyConfig(ClientConnectionStrategyConfig) - Method in class com.hazelcast.client.config.ClientConfig
- setConnectionTimeout(int) - Method in class com.hazelcast.client.config.ClientNetworkConfig
- setConnectionTimeoutSeconds(int) - Method in class com.hazelcast.config.TcpIpConfig
-
Sets the connection timeout.
- setConsistencyCheckStrategy(ConsistencyCheckStrategy) - Method in class com.hazelcast.config.WanSyncConfig
-
Sets the strategy for checking consistency of data between source and target cluster.
- setConsoleEnabled(boolean) - Method in class com.hazelcast.config.ManagementCenterConfig
-
Enables/disables console commands execution on the member.
- setConsumerConfig(WanConsumerConfig) - Method in class com.hazelcast.config.WanReplicationConfig
-
Sets the
WAN consumer configuration
for this WAN replication. - setCooperative(boolean) - Method in class com.hazelcast.jet.pipeline.ServiceFactory
-
Returns a copy of this
ServiceFactory
with theisCooperative
flag set tocooperative
argument value. - setCooperativeThreadCount(int) - Method in class com.hazelcast.jet.config.InstanceConfig
-
Deprecated.Sets the number of threads each cluster member will use to execute Jet jobs.
- setCooperativeThreadCount(int) - Method in class com.hazelcast.jet.config.JetConfig
-
Sets the number of threads each cluster member will use to execute Jet jobs.
- setCPDirectToLeaderRoutingEnabled(boolean) - Method in class com.hazelcast.client.config.ClientConfig
-
Sets whether CP direct-to-leader operation sending is enabled.
- setCpMapConfigs(Map<String, CPMapConfig>) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
- setCPMapConfigs(Map<String, CPMapConfig>) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Sets the map of
CPMapConfig
configurations, mapped by config name. - setCPMapLimit(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Sets the limit of permitted
CPMap
instances. - setCPMemberCount(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Sets the CP member count to initialize CP Subsystem.
- setCPMemberPriority(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Sets the CP member priority.
- setCPSubsystemConfig(CPSubsystemConfig) - Method in class com.hazelcast.config.Config
-
Set CP subsystem configuration
- setCRDTReplicationConfig(CRDTReplicationConfig) - Method in class com.hazelcast.config.Config
-
Sets the replication configuration for
CRDT
implementations. - setCredentials(Credentials) - Method in class com.hazelcast.client.config.ClientConfig
-
Shortcut for
getSecurityConfig().setCredentials()
- setCredentials(Credentials) - Method in class com.hazelcast.client.config.ClientSecurityConfig
- setCredentials(Credentials) - Method in class com.hazelcast.config.security.RealmConfig
- setCredentialsFactoryConfig(CredentialsFactoryConfig) - Method in class com.hazelcast.client.config.ClientSecurityConfig
- setCredentialsFactoryConfig(CredentialsFactoryConfig) - Method in class com.hazelcast.config.security.RealmConfig
- setCredentialsIdentityConfig(CredentialsIdentityConfig) - Method in class com.hazelcast.client.config.ClientSecurityConfig
- setCredentialsIdentityConfig(CredentialsIdentityConfig) - Method in class com.hazelcast.config.security.RealmConfig
- setCurrentKeyAlias(String) - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
-
Sets the alias for the current encryption key entry.
- setCursorBufferSize(int) - Method in class com.hazelcast.sql.SqlStatement
-
Sets the cursor buffer size (measured in the number of rows).
- setCustomProperty(String, String) - Method in class com.hazelcast.jet.cdc.mysql.MySqlCdcSources.Builder
-
Can be used to set any property not explicitly covered by other methods or to override internal properties.
- setCustomProperty(String, String) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
Can be used to set any property not explicitly covered by other methods or to override internal properties.
- setCustomPublisherConfigs(List<WanCustomPublisherConfig>) - Method in class com.hazelcast.config.WanReplicationConfig
-
Sets the list of custom WAN publisher implementations for this WAN replication.
- setCustomSnapshotter(Class<?>) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
Custom snapshotter that will be used by the connector.
- setDataAccessEnabled(boolean) - Method in class com.hazelcast.config.ManagementCenterConfig
-
Enables/disables access to contents of Hazelcast data structures (for instance map entries) for Management Center.
- setDatabaseAddress(String) - Method in class com.hazelcast.jet.cdc.mysql.MySqlCdcSources.Builder
-
IP address or hostname of the database server, has to be specified.
- setDatabaseAddress(String) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
IP address or hostname of the database server, has to be specified.
- setDatabaseBlacklist(String...) - Method in class com.hazelcast.jet.cdc.mysql.MySqlCdcSources.Builder
-
Optional regular expressions that match database names to be excluded from monitoring; any database name not included in the blacklist will be monitored.
- setDatabaseClientId(int) - Method in class com.hazelcast.jet.cdc.mysql.MySqlCdcSources.Builder
-
A numeric ID of this database client, which must be unique across all currently-running database processes in the MySQL cluster.
- setDatabaseName(String) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
The name of the PostgreSQL database from which to stream the changes.
- setDatabasePassword(String) - Method in class com.hazelcast.jet.cdc.mysql.MySqlCdcSources.Builder
-
Database user password for connecting to the database server.
- setDatabasePassword(String) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
Database user password for connecting to the database server.
- setDatabasePort(int) - Method in class com.hazelcast.jet.cdc.mysql.MySqlCdcSources.Builder
-
Optional port number of the database server, if unspecified defaults to the database specific default port (3306).
- setDatabasePort(int) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
Optional port number of the database server, if unspecified defaults to the database specific default port (5432).
- setDatabaseUser(String) - Method in class com.hazelcast.jet.cdc.mysql.MySqlCdcSources.Builder
-
Database user for connecting to the database server.
- setDatabaseUser(String) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
Database user for connecting to the database server.
- setDatabaseWhitelist(String...) - Method in class com.hazelcast.jet.cdc.mysql.MySqlCdcSources.Builder
-
Optional regular expressions that match database names to be monitored; any database name not included in the whitelist will be excluded from monitoring.
- setDataConnectionConfigs(Map<String, DataConnectionConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of data connection configurations, mapped by config name.
- setDataLoadTimeoutSeconds(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Sets the timeout duration for CP members to restore their data from stable storage.
- setDataLoadTimeoutSeconds(int) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Deprecated.Sets data load timeout for hot-restart process, all members in the cluster should complete restoring their local data before this timeout.
- setDataLoadTimeoutSeconds(int) - Method in class com.hazelcast.config.PersistenceConfig
-
Sets data load timeout for persistence restart process, all members in the cluster should complete restoring their local data before this timeout.
- setDataPersistenceConfig(DataPersistenceConfig) - Method in class com.hazelcast.config.AbstractCacheConfig
-
Sets the
DataPersistenceConfig
for thisCacheConfiguration
- setDataPersistenceConfig(DataPersistenceConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the
DataPersistenceConfig
for thisCacheSimpleConfig
- setDataPersistenceConfig(DataPersistenceConfig) - Method in class com.hazelcast.config.MapConfig
-
Sets the
DataPersistenceConfig
for thisMapConfig
- setDataSerializableFactories(Map<Integer, DataSerializableFactory>) - Method in class com.hazelcast.config.SerializationConfig
- setDataSerializableFactoryClasses(Map<Integer, String>) - Method in class com.hazelcast.config.SerializationConfig
- setDate(String, LocalDate) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
Sets a date field consisting of year, month of the year, and day of the month.
- setDecimal(String, BigDecimal) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
Sets a decimal which is arbitrary precision and scale floating-point number.
- setDefaultEdgeConfig(EdgeConfig) - Method in class com.hazelcast.jet.config.JetConfig
-
Sets the configuration object that specifies the defaults to use for a DAG edge configuration.
- setDefaultReadTimeout(long) - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
-
Set default cache value retrieval timeout.
- setDefaultsDisabled(boolean) - Method in class com.hazelcast.config.JavaSerializationFilterConfig
- setDelaySeconds(int) - Method in class com.hazelcast.config.QueryCacheConfig
-
Sets the minimum number of delay seconds which an event waits in the buffer of node before sending to a
QueryCache
- setDeny(boolean) - Method in class com.hazelcast.config.PermissionConfig
-
Configures if this permission config is for a grant (
false
, default) permission or deny (true
) - setDeprecatedName(String) - Method in class com.hazelcast.spi.properties.HazelcastProperty
-
Sets the deprecated name of this property.
- setDepth(int) - Method in class com.hazelcast.config.MerkleTreeConfig
-
Sets the depth of the merkle tree.
- setDeviceConfigs(Map<String, DeviceConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of
DeviceConfig
s mapped by device name. - setDeviceName(String) - Method in class com.hazelcast.config.DiskTierConfig
-
Sets the device name for this disk tier.
- setDimension(int) - Method in class com.hazelcast.config.vector.VectorIndexConfig
-
Sets the dimension of this vector index configuration.
- setDirectory(String) - Method in class com.hazelcast.config.NearCachePreloaderConfig
- setDirectory(String) - Method in class com.hazelcast.config.PersistentMemoryDirectoryConfig
-
Returns the
directory
of thisPersistentMemoryDirectoryConfig
. - setDirectoryConfigs(List<PersistentMemoryDirectoryConfig>) - Method in class com.hazelcast.config.PersistentMemoryConfig
-
Sets the persistent memory directory configuration to the set of directories provided in the
directoryConfigs
argument. - setDisablePerEntryInvalidationEvents(boolean) - Method in class com.hazelcast.config.CacheConfig
-
Sets invalidation events disabled status for per entry.
- setDisablePerEntryInvalidationEvents(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets invalidation events disabled status for per entry.
- setDiscoveryConfig(DiscoveryConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Defines the Discovery Provider SPI configuration
- setDiscoveryConfig(DiscoveryConfig) - Method in class com.hazelcast.config.JoinConfig
-
Sets a custom defined
DiscoveryConfig
- setDiscoveryConfig(DiscoveryConfig) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the
DiscoveryConfig
used by the discovery mechanism for this WAN publisher. - setDiscoveryConfig(DiscoveryConfig) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
- setDiscoveryMode(DiscoveryMode) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
- setDiscoveryNode(DiscoveryNode) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
- setDiscoveryPeriodSeconds(int) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the period in seconds in which WAN tries to discover new target endpoints and reestablish connections to failed endpoints.
- setDiscoveryServiceProvider(DiscoveryServiceProvider) - Method in class com.hazelcast.config.DiscoveryConfig
- setDiscoveryStrategyConfigs(List<DiscoveryStrategyConfig>) - Method in class com.hazelcast.config.DiscoveryConfig
-
Sets the strategy configurations for this discovery config.
- setDiscoveryStrategyFactory(DiscoveryStrategyFactory) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
- setDiscoveryToken(String) - Method in class com.hazelcast.client.config.ClientCloudConfig
- setDiskTierConfig(DiskTierConfig) - Method in class com.hazelcast.config.TieredStoreConfig
-
Sets the disk tier config of this tiered-store configuration.
- setDouble(double) - Method in class com.hazelcast.jet.accumulator.LongDoubleAccumulator
-
Sets the
double
value. - setDurability(int) - Method in class com.hazelcast.config.DurableExecutorConfig
-
Sets the durability of the executor
- setDurability(int) - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Sets the durability of the executor The durability represents the number of replicas that exist in a cluster for any given partition-owned task.
- setDurability(int) - Method in class com.hazelcast.transaction.TransactionOptions
-
Sets the transaction durability.
- setDurableExecutorConfigs(Map<String, DurableExecutorConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of durable executor configurations, mapped by config name.
- setDynamicConfigurationConfig(DynamicConfigurationConfig) - Method in class com.hazelcast.config.Config
-
Sets the dynamic configuration config.
- setEarlyResultsPeriod(long) - Method in class com.hazelcast.jet.pipeline.SessionWindowDefinition
- setEarlyResultsPeriod(long) - Method in class com.hazelcast.jet.pipeline.SlidingWindowDefinition
- setEarlyResultsPeriod(long) - Method in class com.hazelcast.jet.pipeline.WindowDefinition
-
Sets the period in milliseconds at which the windowed aggregation stage will emit partial results of all the windows that contain some data, but the watermark hasn't yet advanced enough to close them and emit the final results.
- setEchoFailFastOnStartup(boolean) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
- setEfConstruction(int) - Method in class com.hazelcast.config.vector.VectorIndexConfig
-
Sets the size of the dynamic list search to use during index time.
- setEmptyQueueTtl(int) - Method in class com.hazelcast.config.QueueConfig
-
Sets the TTL (time to live) for emptying the Queue.
- setEnableCompression(boolean) - Method in class com.hazelcast.config.SerializationConfig
-
Enables compression when default java serialization is used.
- setEnabled(boolean) - Method in class com.hazelcast.client.config.ClientCloudConfig
- setEnabled(boolean) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
- setEnabled(boolean) - Method in class com.hazelcast.client.config.ClientTpcConfig
-
Enables or disables the TPC-aware mode.
- setEnabled(boolean) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
-
Deprecated.
- setEnabled(boolean) - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
-
Enables and disables this configuration.
- setEnabled(boolean) - Method in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
-
Enables and disables this configuration.
- setEnabled(boolean) - Method in class com.hazelcast.config.AdvancedNetworkConfig
- setEnabled(boolean) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
-
Enables or disables the join mechanism based on the given discovery config.
- setEnabled(boolean) - Method in class com.hazelcast.config.AutoDetectionConfig
-
Enables or disables the auto detection join mechanism.
- setEnabled(boolean) - Method in class com.hazelcast.config.BaseMetricsConfig
-
Sets whether metrics collection should be enabled for the node.
- setEnabled(boolean) - Method in class com.hazelcast.config.DataPersistenceConfig
-
Sets whether hot restart is enabled on related data structure.
- setEnabled(boolean) - Method in class com.hazelcast.config.DiskTierConfig
-
Sets whether disk tier is enabled on the related tiered-store.
- setEnabled(boolean) - Method in class com.hazelcast.config.EventJournalConfig
-
Enables or disables the event journal.
- setEnabled(boolean) - Method in class com.hazelcast.config.HotRestartConfig
-
Deprecated.Sets whether hot restart is enabled on related data structure.
- setEnabled(boolean) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Deprecated.Sets whether hot restart is enabled on this member.
- setEnabled(boolean) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
-
Set whether the ICMP failure detector should be enabled or not.
- setEnabled(boolean) - Method in class com.hazelcast.config.InstanceTrackingConfig
-
Enables or disables instance tracking.
- setEnabled(boolean) - Method in class com.hazelcast.config.IntegrityCheckerConfig
-
Sets the flag to enable or disable integrity checker.
- setEnabled(boolean) - Method in class com.hazelcast.config.InterfacesConfig
- setEnabled(boolean) - Method in class com.hazelcast.config.MapStoreConfig
-
Enables and disables this configuration
- setEnabled(boolean) - Method in class com.hazelcast.config.MemberAddressProviderConfig
- setEnabled(boolean) - Method in class com.hazelcast.config.MemcacheProtocolConfig
-
Enables or disables the MEMCACHE protocol on the member.
- setEnabled(boolean) - Method in class com.hazelcast.config.MerkleTreeConfig
-
Enables or disables the merkle tree.
- setEnabled(boolean) - Method in class com.hazelcast.config.MetricsJmxConfig
-
Enables metrics exposure through JMX.
- setEnabled(boolean) - Method in class com.hazelcast.config.MetricsManagementCenterConfig
-
Enables exposing metrics to Hazelcast Management Center.
- setEnabled(boolean) - Method in class com.hazelcast.config.MulticastConfig
-
Enables or disables the multicast discovery mechanism
- setEnabled(boolean) - Method in class com.hazelcast.config.NativeMemoryConfig
-
Enables or disables native memory allocation.
- setEnabled(boolean) - Method in class com.hazelcast.config.NearCachePreloaderConfig
- setEnabled(boolean) - Method in class com.hazelcast.config.PartitionGroupConfig
-
Enables or disables this PartitionGroupConfig.
- setEnabled(boolean) - Method in class com.hazelcast.config.PersistenceConfig
-
Sets whether persistence is enabled on this member.
- setEnabled(boolean) - Method in class com.hazelcast.config.PersistentMemoryConfig
-
Enables or disables persistent memory.
- setEnabled(boolean) - Method in class com.hazelcast.config.QueueStoreConfig
-
Enables or disables the queue store.
- setEnabled(boolean) - Method in class com.hazelcast.config.rest.RestConfig
-
Sets the enabled status of the RestConfig.
- setEnabled(boolean) - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Set whether to enable SSL support.
- setEnabled(boolean) - Method in class com.hazelcast.config.RestApiConfig
-
Deprecated.Enables or disables the REST API on the member.
- setEnabled(boolean) - Method in class com.hazelcast.config.RingbufferStoreConfig
- setEnabled(boolean) - Method in class com.hazelcast.config.SecurityConfig
- setEnabled(boolean) - Method in class com.hazelcast.config.ServiceConfig
- setEnabled(boolean) - Method in class com.hazelcast.config.SocketInterceptorConfig
-
Enables and disables this configuration.
- setEnabled(boolean) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
- setEnabled(boolean) - Method in class com.hazelcast.config.TcpIpConfig
-
Enables or disables the Tcp/Ip join mechanism.
- setEnabled(boolean) - Method in class com.hazelcast.config.TieredStoreConfig
-
Sets whether tiered-store is enabled on the related data structure.
- setEnabled(boolean) - Method in class com.hazelcast.config.tpc.TpcConfig
-
Sets the enabled flag which defines TPC is enabled or not.
- setEnabled(boolean) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Deprecated.Enable or disable User Code Deployment.
- setEnabled(boolean) - Method in class com.hazelcast.config.UserCodeNamespacesConfig
- setEnabled(boolean) - Method in class com.hazelcast.jet.config.JetConfig
-
Sets if Jet is enabled
- setEnabledGroups(Collection<RestEndpointGroup>) - Method in class com.hazelcast.config.RestApiConfig
-
Deprecated.
- setEnabledGroups(Collection<RestEndpointGroup>) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- setEnabledProtocols(String) - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Set the enabled SSL protocols.
- setEnableSharedObject(boolean) - Method in class com.hazelcast.config.SerializationConfig
-
Enables shared object when default java serialization is used.
- setEncryptionAtRestConfig(EncryptionAtRestConfig) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Deprecated.Sets the Hot Restart Encryption at Rest configuration.
- setEncryptionAtRestConfig(EncryptionAtRestConfig) - Method in class com.hazelcast.config.PersistenceConfig
-
Sets the Persistence Encryption at Rest configuration.
- setEndpoint(String) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the WAN endpoint configuration qualifier.
- setEndpointConfigs(Map<EndpointQualifier, EndpointConfig>) - Method in class com.hazelcast.config.AdvancedNetworkConfig
- setEndpoints(Set<String>) - Method in class com.hazelcast.config.PermissionConfig
- setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.config.MapConfig
- setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.config.MultiMapConfig
-
Sets the list of entry listeners (listens for when entries are added or removed) for this MultiMap.
- setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.config.QueryCacheConfig
- setEpochStart(long) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
Sets the offset of timestamp component in milliseconds.
- setEurekaConfig(EurekaConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Sets configuration to connect nodes in Eureka environment.
- setEurekaConfig(EurekaConfig) - Method in class com.hazelcast.config.JoinConfig
- setEurekaConfig(EurekaConfig) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the
EurekaConfig
used by the discovery mechanism for this WAN publisher. - setEventJournalConfig(EventJournalConfig) - Method in class com.hazelcast.config.AbstractCacheConfig
-
Sets the
EventJournalConfig
for thisCacheConfiguration
- setEventJournalConfig(EventJournalConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the
EventJournalConfig
for thisCacheSimpleConfig
- setEventJournalConfig(EventJournalConfig) - Method in class com.hazelcast.config.MapConfig
-
Sets the
EventJournalConfig
for thisMapConfig
- setEventloopCount(int) - Method in class com.hazelcast.config.tpc.TpcConfig
-
In TPC, everything is done in eventloops.
- setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.CacheConfig
-
Sets the
EvictionConfig
instance for eviction configuration for thisICache
. - setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the eviction configuration for this
ICache
. - setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.MapConfig
-
Sets the
EvictionConfig
instance for eviction configuration for thisIMap
. - setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.NearCacheConfig
-
Sets the eviction configuration for this Near Cache.
- setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.QueryCacheConfig
-
Sets the
EvictionConfig
instance for thisQueryCache
- setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.EvictionConfig
-
Sets the
EvictionPolicy
of this eviction configuration. - setExecutionId(long) - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
-
Sets the execution ID.
- setExecutor(Executor) - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
-
Sets the Executor that is going to process the event.
- setExecutor(Executor) - Method in class com.hazelcast.config.ReliableTopicConfig
-
Sets the executor that is going to process the event.
- setExecutorConfigs(Map<String, ExecutorConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of executor configurations, mapped by config name.
- setExpectedResultType(SqlExpectedResultType) - Method in class com.hazelcast.sql.SqlStatement
-
Sets the expected result type.
- setExpiryPolicy(Set<? extends K>, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Associates the specified key with the given
ExpiryPolicy
. - setExpiryPolicy(K, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Associates the specified key with the given
ExpiryPolicy
. - setExpiryPolicyFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the factory for this
ExpiryPolicy
. - setExpiryPolicyFactory(Factory<? extends ExpiryPolicy>) - Method in class com.hazelcast.config.AbstractCacheConfig
- setExpiryPolicyFactory(Factory<? extends ExpiryPolicy>) - Method in interface com.hazelcast.config.CacheConfiguration
-
Set the
Factory
for theExpiryPolicy
. - setExpiryPolicyFactoryConfig(CacheSimpleConfig.ExpiryPolicyFactoryConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the factory configuration for this
ExpiryPolicy
. - setExtractorClassName(String) - Method in class com.hazelcast.config.AttributeConfig
-
Sets the full class name of the extractor in a String format, e.g.
- setFactoryClassName(String) - Method in class com.hazelcast.config.AbstractBaseFactoryWithPropertiesConfig
-
Sets the factory class name.
- setFactoryClassName(String) - Method in class com.hazelcast.config.MapStoreConfig
-
Sets the name for the MapStoreFactory implementation class
- setFactoryClassName(String) - Method in class com.hazelcast.config.QueueStoreConfig
-
Sets the factory class name which will be used to instantiate the queue store.
- setFactoryClassName(String) - Method in class com.hazelcast.config.RingbufferStoreConfig
- setFactoryClassName(String) - Method in class com.hazelcast.config.SSLConfig
-
Sets the name for the implementation class.
- setFactoryImpl(ClientProxyFactory) - Method in class com.hazelcast.client.config.ProxyFactoryConfig
-
Sets factory implementation of proxy factory
- setFactoryImplementation(QueueStoreFactory) - Method in class com.hazelcast.config.QueueStoreConfig
-
Sets the queue store factory implementation which will be used to instantiate the queue store.
- setFactoryImplementation(RingbufferStoreFactory) - Method in class com.hazelcast.config.RingbufferStoreConfig
- setFactoryImplementation(Object) - Method in class com.hazelcast.config.MapStoreConfig
-
Sets the map store factory implementation object.
- setFactoryImplementation(Object) - Method in class com.hazelcast.config.SSLConfig
-
Sets the implementation object.
- setFailFastOnStartup(boolean) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
-
Sets whether the member should fail-fast on startup if ICMP is not allowed by the underlying OS.
- setFailOnIndeterminateOperationState(boolean) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Sets the value to determine if CP Subsystem calls will fail when result of an API call becomes indeterminate.
- setFileName(String) - Method in class com.hazelcast.config.InstanceTrackingConfig
-
Sets the name of the file which will contain the tracking metadata.
- setFilters(List<String>) - Method in class com.hazelcast.config.WanReplicationRef
-
Sets the list of class names implementing the CacheWanEventFilter or MapWanEventFilter for filtering outbound WAN replication events.
- setFlakeIdGeneratorConfigMap(Map<String, ClientFlakeIdGeneratorConfig>) - Method in class com.hazelcast.client.config.ClientConfig
-
Sets the map of
FlakeIdGenerator
configurations, mapped by config name. - setFlakeIdGeneratorConfigs(Map<String, FlakeIdGeneratorConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of
FlakeIdGenerator
configurations, mapped by config name. - setFloat32(String, float) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setFloat64(String, double) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setFlowControlPeriodMs(int) - Method in class com.hazelcast.jet.config.InstanceConfig
-
Deprecated.While executing a Jet job there is the issue of regulating the rate at which one member of the cluster sends data to another member.
- setFlowControlPeriodMs(int) - Method in class com.hazelcast.jet.config.JetConfig
-
While executing a Jet job there is the issue of regulating the rate at which one member of the cluster sends data to another member.
- setFormatPattern(String) - Method in class com.hazelcast.config.InstanceTrackingConfig
-
Sets the pattern used to render the contents of the instance tracking file.
- setFsync(boolean) - Method in class com.hazelcast.config.DataPersistenceConfig
-
Sets whether disk write should be followed by an
fsync()
system call. - setFsync(boolean) - Method in class com.hazelcast.config.HotRestartConfig
-
Deprecated.Sets whether disk write should be followed by an
fsync()
system call. - setFunctionClassName(String) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
- setFunctionImplementation(SplitBrainProtectionFunction) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
- setGcpConfig(GcpConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Sets configuration to connect nodes in GCP environment.
- setGcpConfig(GcpConfig) - Method in class com.hazelcast.config.JoinConfig
- setGcpConfig(GcpConfig) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the
GcpConfig
used by the discovery mechanism for this WAN publisher. - setGenericRecord(String, GenericRecord) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setGlobalOrderingEnabled(boolean) - Method in class com.hazelcast.config.TopicConfig
-
Enable global ordering (all nodes listening to the same topic get their messages in the same order), or disable it (nodes get the messages in the order that the messages are published).
- setGlobalProcessorIndex(int) - Method in class com.hazelcast.jet.core.test.TestProcessorContext
-
Set the global processor index
- setGlobalSerializerConfig(GlobalSerializerConfig) - Method in class com.hazelcast.config.SerializationConfig
- setGroupSize(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Sets the number of CP members to form CP groups.
- setGroupType(PartitionGroupConfig.MemberGroupType) - Method in class com.hazelcast.config.PartitionGroupConfig
-
Sets the MemberGroupType.
- setHandlerFile(String) - Method in class com.hazelcast.jet.python.PythonServiceConfig
-
Sets the Python handler file.
- setHandlerFunction(String) - Method in class com.hazelcast.jet.python.PythonServiceConfig
-
Overrides the default name of the Python function that transforms Jet pipeline data.
- setHandlerModule(String) - Method in class com.hazelcast.jet.python.PythonServiceConfig
-
Sets the name of the Python module that has the function that transforms Jet pipeline data.
- setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.console.Echo
- setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.console.SimulateLoadTask
- setHazelcastInstance(HazelcastInstance) - Method in interface com.hazelcast.core.HazelcastInstanceAware
-
Gets the HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService.
- setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.jet.core.test.TestProcessorContext
- setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
-
Sets the Hazelcast instance.
- setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
- setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.security.HazelcastInstanceCallback
- setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
- setHeadSequence(long) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
-
Sets the head sequence.
- setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.AbstractCacheConfig
-
Deprecated.
- setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Deprecated.
- setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.MapConfig
-
Deprecated.
- setHotRestartPersistenceConfig(HotRestartPersistenceConfig) - Method in class com.hazelcast.config.Config
-
Deprecated.since 5.0 use
Config.setPersistenceConfig(PersistenceConfig)
- setIcmpFailureDetectorConfig(IcmpFailureDetectorConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- setIcmpFailureDetectorConfig(IcmpFailureDetectorConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
-
Sets the
IcmpFailureDetectorConfig
. - setIcmpFailureDetectorConfig(IcmpFailureDetectorConfig) - Method in class com.hazelcast.config.NetworkConfig
-
Sets the
IcmpFailureDetectorConfig
. - setIdleMaxParkNs(long) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the maximum duration in nanoseconds that the WAN replication thread will be parked if there are no events to replicate.
- setIdleMinParkNs(long) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the minimum duration in nanoseconds that the WAN replication thread will be parked if there are no events to replicate.
- setIfConfigured(Properties, String, Enum<?>) - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
- setIfConfigured(Properties, String, Object) - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
- setIfConfigured(Properties, String, String) - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
- setImplementation(CachePartitionLostListener) - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
- setImplementation(ItemListener) - Method in class com.hazelcast.config.ItemListenerConfig
- setImplementation(MapListener) - Method in class com.hazelcast.config.EntryListenerConfig
- setImplementation(MapPartitionLostListener) - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
- setImplementation(Serializer) - Method in class com.hazelcast.config.GlobalSerializerConfig
- setImplementation(Serializer) - Method in class com.hazelcast.config.SerializerConfig
-
Sets the serializer implementation instance.
- setImplementation(Predicate) - Method in class com.hazelcast.config.PredicateConfig
-
Sets the Predicate implementation.
- setImplementation(ICredentialsFactory) - Method in class com.hazelcast.config.CredentialsFactoryConfig
- setImplementation(IPermissionPolicy) - Method in class com.hazelcast.config.PermissionPolicyConfig
- setImplementation(SecurityInterceptor) - Method in class com.hazelcast.config.SecurityInterceptorConfig
- setImplementation(MemberAddressProvider) - Method in class com.hazelcast.config.MemberAddressProviderConfig
- setImplementation(SplitBrainProtectionListener) - Method in class com.hazelcast.config.SplitBrainProtectionListenerConfig
- setImplementation(WanConsumer) - Method in class com.hazelcast.config.WanConsumerConfig
-
Sets the implementation for this WAN consumer.
- setImplementation(WanPublisher) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
-
Sets the implementation of
WanPublisher
. - setImplementation(WanPublisher) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
No-op method as the implementation cannot be changed for this publisher.
- setImplementation(WanPublisher) - Method in class com.hazelcast.config.WanCustomPublisherConfig
- setImplementation(Object) - Method in class com.hazelcast.config.MapStoreConfig
-
Sets the map store implementation object
- setImplementation(Object) - Method in class com.hazelcast.config.ServiceConfig
- setImplementation(Object) - Method in class com.hazelcast.config.SocketInterceptorConfig
-
Sets the
SocketInterceptor
implementation object. - setImplementation(EventListener) - Method in class com.hazelcast.config.EntryListenerConfig
- setImplementation(EventListener) - Method in class com.hazelcast.config.ListenerConfig
-
Sets the EventListener implementation.
- setIncludeValue(boolean) - Method in class com.hazelcast.config.EntryListenerConfig
- setIncludeValue(boolean) - Method in class com.hazelcast.config.ItemListenerConfig
- setIncludeValue(boolean) - Method in class com.hazelcast.config.QueryCacheConfig
-
Set
true
to enable value caching, otherwise setfalse
- setIncludeValue(boolean) - Method in class com.hazelcast.vector.SearchOptionsBuilder
-
Includes or excludes the user-supplied value in search results.
- setIncludeVectors(boolean) - Method in class com.hazelcast.vector.SearchOptionsBuilder
-
Includes or excludes the vectors associated with each search result in search results.
- setIndexConfigs(List<IndexConfig>) - Method in class com.hazelcast.config.MapConfig
- setIndexConfigs(List<IndexConfig>) - Method in class com.hazelcast.config.QueryCacheConfig
- setInitialBackoffMillis(int) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
- setInitialLoadMode(MapStoreConfig.InitialLoadMode) - Method in class com.hazelcast.config.MapStoreConfig
-
Sets the initial load mode.
- setInitialPermits(int) - Method in class com.hazelcast.config.cp.SemaphoreConfig
-
Sets initial permit count of the Semaphore
- setInitialPublisherState(WanPublisherState) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the initial publisher state.
- setInitialSnapshotName(String) - Method in class com.hazelcast.jet.config.JobConfig
-
Sets the exported state snapshot name to restore the initial job state from.
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.CacheConfig
-
Data type that will be used to store records in this
ICache
. - setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the InMemory Format for this
ICache
. - setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.MapConfig
-
Binary type that will be used for storing records.
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.NearCacheConfig
-
Sets the data type used to store entries.
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.QueryCacheConfig
-
Sets memory format of values of entries in
QueryCache
. - setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.ReplicatedMapConfig
-
Data type used to store entries.
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.RingbufferConfig
-
Sets the in-memory format.
- setInMemoryFormat(String) - Method in class com.hazelcast.config.NearCacheConfig
- setInstanceConfig(InstanceConfig) - Method in class com.hazelcast.jet.config.JetConfig
-
Deprecated.The fields from
InstanceConfig
class were moved toJetConfig
class. Set the fields directly onJetConfig
. - setInstanceName(String) - Method in class com.hazelcast.client.config.ClientConfig
- setInstanceName(String) - Method in class com.hazelcast.config.Config
-
Sets the instance name uniquely identifying the hazelcast instance created by this configuration.
- setInstanceTrackingConfig(InstanceTrackingConfig) - Method in class com.hazelcast.client.config.ClientConfig
-
Returns the configuration for tracking use of this Hazelcast instance.
- setInstanceTrackingConfig(InstanceTrackingConfig) - Method in class com.hazelcast.config.Config
-
Sets the configuration for tracking use of this Hazelcast instance.
- setInt16(String, short) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setInt32(String, int) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setInt64(String, long) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setInt8(String, byte) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setIntegrityCheckerConfig(IntegrityCheckerConfig) - Method in class com.hazelcast.config.Config
-
Sets the Integrity Checker config
- setInterfaces(InterfacesConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- setInterfaces(InterfacesConfig) - Method in class com.hazelcast.config.EndpointConfig
- setInterfaces(InterfacesConfig) - Method in class com.hazelcast.config.NetworkConfig
- setInterfaces(InterfacesConfig) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- setInterfaces(InterfacesConfig) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
- setInterfaces(Collection<String>) - Method in class com.hazelcast.config.InterfacesConfig
-
Adds a collection of interfaces.
- setInterfaces(Collection<String>) - Method in class com.hazelcast.config.MemberGroupConfig
-
Sets the interfaces that are part of a group.
- setIntervalMilliseconds(int) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
- setIntervalMilliseconds(int) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
-
Sets the time in milliseconds between each ping This value can not be smaller than 1000 milliseconds
- setInvalidateOnChange(boolean) - Method in class com.hazelcast.config.NearCacheConfig
-
Sets if Near Cache entries are invalidated when the entries in the backing data structure are changed (updated or removed).
- setIsLightJob(boolean) - Method in class com.hazelcast.jet.core.test.TestProcessorContext
- setIsLightJob(boolean) - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
-
Sets the isLightJob flag.
- setIsLightJob(boolean) - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
- setItem(T) - Method in class com.hazelcast.jet.datamodel.TimestampedItem
-
Sets the item.
- setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.config.CollectionConfig
-
Sets the list of ItemListenerConfigs.
- setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.config.QueueConfig
-
Set the list of item listener configurations for this queue.
- setIterationCount(int) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-
Deprecated.
- setJaasAuthenticationConfig(JaasAuthenticationConfig) - Method in class com.hazelcast.config.security.RealmConfig
- setJarPaths(List<String>) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
-
Deprecated.String jarPath is searched in following order: 1. as absolute path, 2. as URL, 3. and in classpath.
- setJavaReflectionFilterConfig(JavaSerializationFilterConfig) - Method in class com.hazelcast.config.SqlConfig
-
Allows to configure reflection protection filter.
- setJavaSerializationFilterConfig(JavaSerializationFilterConfig) - Method in class com.hazelcast.config.SerializationConfig
-
Allows to configure deserialization protection filter.
- setJDKCompatible(boolean) - Method in class com.hazelcast.config.cp.SemaphoreConfig
-
Sets JDK compatibility mode of CP ISemaphore
- setJetConfig(JetConfig) - Method in class com.hazelcast.config.Config
-
Sets the Jet config
- setJitter(double) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
-
At each iteration calculated back-off is randomized via following method Random(-jitter * current_backoff, jitter * current_backoff)
- setJmxConfig(MetricsJmxConfig) - Method in class com.hazelcast.config.BaseMetricsConfig
- setJobConfig(JobConfig) - Method in class com.hazelcast.jet.core.test.TestProcessorContext
- setJobConfig(JobConfig) - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
-
Sets the config for the job.
- setJobConfig(JobConfig) - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
- setJobId(long) - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
-
Sets the job ID.
- setJoin(JoinConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- setJoin(JoinConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
- setJoin(JoinConfig) - Method in class com.hazelcast.config.NetworkConfig
- setKeepAlive(boolean) - Method in class com.hazelcast.client.config.SocketOptions
-
Enable/disable SO_KEEPALIVE socket option.
- setKerberosAuthenticationConfig(KerberosAuthenticationConfig) - Method in class com.hazelcast.config.security.RealmConfig
- setKerberosIdentityConfig(KerberosIdentityConfig) - Method in class com.hazelcast.client.config.ClientSecurityConfig
- setKerberosIdentityConfig(KerberosIdentityConfig) - Method in class com.hazelcast.config.security.RealmConfig
- setKey(byte[]) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-
Deprecated.
- setKeyAlias(String) - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Set the alias that identifies the key in the key store.
- setKeyClassName(String) - Method in class com.hazelcast.config.AbstractCacheConfig
- setKeyPassword(String) - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Set the password used to access the key in the key store.
- setKeySize(int) - Method in class com.hazelcast.config.EncryptionAtRestConfig
-
Sets the size (in bits) of the Hot Restart Store-level encryption key (non-positive value implies falling back to the cipher-specific default key length).
- setKeyStore(String) - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Set the path to the key store that holds the SSL certificate (typically a jks file).
- setKeyStorePassword(String) - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Set the password used to access the key store.
- setKeyStoreProvider(String) - Method in class com.hazelcast.config.rest.RestConfig.Ssl
- setKeyStoreType(String) - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Set the type of the key store.
- setKeytabFile(String) - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
-
Allows (together with the
KerberosAuthenticationConfig.setPrincipal(String)
) simplification of security realm configuration. - setKeytabFile(String) - Method in class com.hazelcast.config.security.KerberosIdentityConfig
-
Allows (together with the
KerberosIdentityConfig.setPrincipal(String)
) simplification of security realm configuration. - setKeyType(Class<K>) - Method in class com.hazelcast.config.AbstractCacheConfig
- setKeyType(String) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the key type for this
ICache
. - setKubernetesConfig(KubernetesConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Sets configuration to connect nodes in Kubernetes environment.
- setKubernetesConfig(KubernetesConfig) - Method in class com.hazelcast.config.JoinConfig
- setKubernetesConfig(KubernetesConfig) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the
KubernetesConfig
used by the discovery mechanism for this WAN publisher. - setLabels(Set<String>) - Method in class com.hazelcast.client.config.ClientConfig
-
Set labels for the client.
- setLdapAuthenticationConfig(LdapAuthenticationConfig) - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
-
Allows specifying LDAP authentication configuration which is then used after the Kerberos authentication successfully finishes.
- setLdapAuthenticationConfig(LdapAuthenticationConfig) - Method in class com.hazelcast.config.security.RealmConfig
- setLeaderElectionTimeoutInMillis(long) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
- setLeaderHeartbeatPeriodInMillis(long) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
- setLevel(Level) - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
- setLevel(Level) - Method in class com.hazelcast.logging.LoggerFactorySupport
- setLevel(Level) - Method in class com.hazelcast.logging.NoLogFactory
- setLicenseKey(String) - Method in class com.hazelcast.config.Config
-
Sets the license key for this hazelcast instance.
- setLingerSeconds(int) - Method in class com.hazelcast.client.config.SocketOptions
-
Enable/disable SO_LINGER with the specified linger time in seconds If set to a value of 0 or less then it is disabled.
- setListConfigs(Map<String, ListConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of
IList
configurations, mapped by config name. - setListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.client.config.ClientConfig
-
Sets all
ListenerConfig
's - setListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.Config
-
Sets the list of
EventListener
configurations. - setListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.ReplicatedMapConfig
- setListenerConfigs(List<SplitBrainProtectionListenerConfig>) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
- setListenerConfigurations() - Method in class com.hazelcast.config.AbstractCacheConfig
- setListenerConfigurations(Set<CacheEntryListenerConfiguration<K, V>>) - Method in class com.hazelcast.config.AbstractCacheConfig
- setLiteMember(boolean) - Method in class com.hazelcast.config.Config
-
Sets the flag to indicate if this member is a lite member.
- setLoadBalancer(LoadBalancer) - Method in class com.hazelcast.client.config.ClientConfig
-
Sets the
LoadBalancer
. - setLoadBalancerClassName(String) - Method in class com.hazelcast.client.config.ClientConfig
-
Sets load balancer class name.
- setLocal(boolean) - Method in class com.hazelcast.config.EntryListenerConfig
- setLocalParallelism(int) - Method in class com.hazelcast.jet.core.test.TestProcessorContext
- setLocalParallelism(int) - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
-
Sets local parallelism.
- setLocalParallelism(int) - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
- setLocalParallelism(int) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- setLocalParallelism(int) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
- setLocalParallelism(int) - Method in interface com.hazelcast.jet.pipeline.SinkStage
- setLocalParallelism(int) - Method in interface com.hazelcast.jet.pipeline.Stage
-
Sets the preferred local parallelism (number of processors per Jet cluster member) this stage will configure its DAG vertices with.
- setLocalParallelism(int) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- setLocalProcessorIndex(int) - Method in class com.hazelcast.jet.core.test.TestProcessorContext
-
Set the local processor index
- setLocalUpdatePolicy(NearCacheConfig.LocalUpdatePolicy) - Method in class com.hazelcast.config.NearCacheConfig
-
Sets the
NearCacheConfig.LocalUpdatePolicy
of this Near Cache. - setLockAcquireLimit(int) - Method in class com.hazelcast.config.cp.FencedLockConfig
-
Sets the number of lock acquires a lock holder can perform.
- setLockConfigs(Map<String, FencedLockConfig>) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Sets the map of
FencedLock
configurations, mapped by config name. - setLogger(ILogger) - Method in class com.hazelcast.jet.core.test.TestProcessorContext
- setLogger(ILogger) - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
-
Sets the logger.
- setLogger(ILogger) - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
- setLogger(ILogger) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
- setLoggingService(LoggingService) - Method in class com.hazelcast.security.LoggingServiceCallback
- setLogicalDecodingPlugIn(String) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
The name of the @see Postgres logical decoding plug-in installed on the server.
- setLoginModuleConfigs(List<LoginModuleConfig>) - Method in class com.hazelcast.config.security.JaasAuthenticationConfig
- setLong(long) - Method in class com.hazelcast.jet.accumulator.LongDoubleAccumulator
-
Sets the
long
value. - setLoopbackModeEnabled(Boolean) - Method in class com.hazelcast.config.MulticastConfig
-
Explicitly enables or disables the loopback mode in the multicast discovery mechanism.
- setLosslessRestartEnabled(boolean) - Method in class com.hazelcast.jet.config.InstanceConfig
-
Deprecated.Sets whether lossless job restart is enabled for the node.
- setLosslessRestartEnabled(boolean) - Method in class com.hazelcast.jet.config.JetConfig
-
Sets whether lossless job restart is enabled for the node.
- setManagedContext(ManagedContext) - Method in class com.hazelcast.client.config.ClientConfig
-
Sets
ManagedContext
- setManagedContext(ManagedContext) - Method in class com.hazelcast.config.Config
-
Sets the external managed context.
- setManagedContext(ManagedContext) - Method in class com.hazelcast.jet.core.test.TestProcessorContext
- setManagedContext(ManagedContext) - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
-
Sets the
ManagedContext
- setManagementCenterConfig(ManagementCenterConfig) - Method in class com.hazelcast.config.Config
-
Sets the management center configuration for this hazelcast instance.
- setManagementCenterConfig(MetricsManagementCenterConfig) - Method in class com.hazelcast.config.MetricsConfig
- setManagementEnabled(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
-
Sets whether management is enabled on this cache.
- setManagementEnabled(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
-
Sets whether management is enabled on a cache.
- setManagementEnabled(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets management to enabled or disabled for this
ICache
. - setManagerPrefix(String) - Method in class com.hazelcast.config.CacheConfig
-
Sets the manager prefix of the
ICache
. - setMapConfigs(Map<String, MapConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of
IMap
configurations, mapped by config name. - setMapLimit(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
- setMapStoreConfig(MapStoreConfig) - Method in class com.hazelcast.config.MapConfig
-
Sets the map store configuration
- setMaxAttempts(int) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
- setMaxAttempts(int) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
-
Set the max ping attempts before suspecting a member
- setMaxBackoffMillis(int) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
-
When backoff reaches this upper bound, it does not increase anymore.
- setMaxConcurrentInvocations(int) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the maximum number of WAN event batches being sent to the target cluster concurrently.
- setMaxConcurrentReplicationTargets(int) - Method in class com.hazelcast.config.CRDTReplicationConfig
-
Sets the maximum number of target members that we replicate the CRDT states to in one period.
- setMaxDegree(int) - Method in class com.hazelcast.config.vector.VectorIndexConfig
-
Sets the maximum number of connections allowed per node.
- setMaxIdleSeconds(int) - Method in class com.hazelcast.config.MapConfig
-
Maximum number of seconds for each entry to stay idle in the map.
- setMaxIdleSeconds(int) - Method in class com.hazelcast.config.NearCacheConfig
-
Set the maximum number of seconds each entry can stay in the Near Cache as untouched (not-read).
- setMaxMissedLeaderHeartbeatCount(int) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
- setMaxProcessorAccumulatedRecords(long) - Method in class com.hazelcast.jet.config.DeltaJobConfig
- setMaxProcessorAccumulatedRecords(long) - Method in class com.hazelcast.jet.config.InstanceConfig
-
Deprecated.Sets the maximum number of records that can be accumulated by any single
Processor
instance. - setMaxProcessorAccumulatedRecords(long) - Method in class com.hazelcast.jet.config.JetConfig
-
Sets the maximum number of records that can be accumulated by any single
Processor
instance. - setMaxProcessorAccumulatedRecords(long) - Method in class com.hazelcast.jet.config.JobConfig
-
Sets the maximum number of records that can be accumulated by any single
Processor
instance in the context of the job. - setMaxProcessorAccumulatedRecords(long) - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
- setMaxSize(int) - Method in class com.hazelcast.config.CollectionConfig
-
Sets the maximum size for the collection.
- setMaxSize(int) - Method in class com.hazelcast.config.QueueConfig
-
Sets the maximum size of the Queue.
- setMaxSizeMb(int) - Method in class com.hazelcast.config.cp.CPMapConfig
-
Sets the maximum capacity of the
CPMap
. - setMaxSizePolicy(MaxSizePolicy) - Method in class com.hazelcast.config.EvictionConfig
-
Sets the
MaxSizePolicy
of this eviction configuration. - setMaxTargetEndpoints(int) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the maximum number of endpoints that WAN will connect to when using a discovery mechanism to define endpoints.
- setMemberAddressProviderConfig(MemberAddressProviderConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- setMemberAddressProviderConfig(MemberAddressProviderConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
- setMemberAddressProviderConfig(MemberAddressProviderConfig) - Method in class com.hazelcast.config.NetworkConfig
- setMemberAttributeConfig(MemberAttributeConfig) - Method in class com.hazelcast.config.Config
-
Sets the member attribute configuration.
- setMemberEndpointConfig(ServerSocketEndpointConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
-
Sets the server socket endpoint config for
MEMBER
protocol. - setMemberGroupConfigs(Collection<MemberGroupConfig>) - Method in class com.hazelcast.config.PartitionGroupConfig
-
Adds a MemberGroupConfig.
- setMemberIndex(int) - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
-
Sets the member index
- setMemberRealm(String) - Method in class com.hazelcast.config.SecurityConfig
- setMemberRealmConfig(String, RealmConfig) - Method in class com.hazelcast.config.SecurityConfig
- setMembers(List<String>) - Method in class com.hazelcast.config.TcpIpConfig
-
Sets the well known members.
- setMemberSelector(JetMemberSelector) - Method in class com.hazelcast.jet.core.DAG
- setMemcacheEndpointConfig(ServerSocketEndpointConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
-
Sets the server socket endpoint config for
memcache
protocol. - setMemcacheProtocolConfig(MemcacheProtocolConfig) - Method in class com.hazelcast.config.NetworkConfig
- setMemoryTierConfig(MemoryTierConfig) - Method in class com.hazelcast.config.BTreeIndexConfig
-
Sets memory tier configuration for this index to given configuration.
- setMemoryTierConfig(MemoryTierConfig) - Method in class com.hazelcast.config.TieredStoreConfig
-
Sets the memory tier config of this tiered-store configuration.
- setMergePolicyClassName(String) - Method in class com.hazelcast.config.WanReplicationRef
-
Sets the merge policy sent to the WAN replication target to merge replicated entries with existing target entries.
- setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.CacheConfig
-
Sets the
MergePolicyConfig
for this map. - setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the
MergePolicyConfig
for this map. - setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
Sets the
MergePolicyConfig
for the cardinality estimator. - setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.CollectionConfig
-
Sets the
MergePolicyConfig
for the collection. - setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.MapConfig
-
Sets the
MergePolicyConfig
for this map. - setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.MultiMapConfig
-
Sets the
MergePolicyConfig
for this MultiMap. - setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.QueueConfig
-
Sets the
MergePolicyConfig
for this queue. - setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.ReplicatedMapConfig
-
Sets the
MergePolicyConfig
for this replicated map. - setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.RingbufferConfig
-
Sets the
MergePolicyConfig
for this ringbuffer. - setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Sets the
MergePolicyConfig
for the scheduler. - setMergePolicyConfig(MergePolicyConfig) - Method in interface com.hazelcast.config.SplitBrainPolicyAwareConfig
-
Sets the
MergePolicyConfig
for the data structure. - setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.vector.VectorCollectionConfig
-
Sets the
MergePolicyConfig
for the data structure. - setMerkleTreeConfig(MerkleTreeConfig) - Method in class com.hazelcast.config.CacheConfig
-
Sets the
MerkleTreeConfig
for thisCacheConfig
- setMerkleTreeConfig(MerkleTreeConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the
MerkleTreeConfig
for thisCacheSimpleConfig
- setMerkleTreeConfig(MerkleTreeConfig) - Method in class com.hazelcast.config.MapConfig
-
Sets the
MerkleTreeConfig
for thisMapConfig
- setMessageListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.ReliableTopicConfig
-
Sets the list of message listeners (listens for when messages are added or removed) for this topic.
- setMessageListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.TopicConfig
-
Sets the list of message listeners (listens for when messages are added or removed) for this topic.
- setMetadataPolicy(MetadataPolicy) - Method in class com.hazelcast.config.MapConfig
-
Sets the metadata policy.
- setMetadataSpacePercentage(float) - Method in class com.hazelcast.config.NativeMemoryConfig
-
Sets the percentage of native memory space to be used to store metadata and internal memory structures by the native memory manager.
- setMetric(Metric) - Method in class com.hazelcast.config.vector.VectorIndexConfig
-
Sets the metric of this vector index configuration.
- setMetricsConfig(ClientMetricsConfig) - Method in class com.hazelcast.client.config.ClientConfig
-
Sets the metrics collection config.
- setMetricsConfig(MetricsConfig) - Method in class com.hazelcast.config.Config
-
Sets the metrics collection config.
- setMetricsEnabled(boolean) - Method in class com.hazelcast.jet.config.DeltaJobConfig
- setMetricsEnabled(boolean) - Method in class com.hazelcast.jet.config.JobConfig
-
Sets whether metrics collection should be enabled for the job.
- setMinBlockSize(int) - Method in class com.hazelcast.config.NativeMemoryConfig
-
Sets the minimum memory block size, in bytes, to be served by native memory manager.
- setMinimumClusterSize(int) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
- setMissingCPMemberAutoRemovalSeconds(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Sets the duration to wait before automatically removing a missing CP member from CP Subsystem.
- setMode(PersistentMemoryMode) - Method in class com.hazelcast.config.PersistentMemoryConfig
-
Sets the mode in which the persistent memory should be used.
- setMulticastConfig(MulticastConfig) - Method in class com.hazelcast.config.JoinConfig
- setMulticastGroup(String) - Method in class com.hazelcast.config.MulticastConfig
-
Sets the multicast group.
- setMulticastPort(int) - Method in class com.hazelcast.config.MulticastConfig
-
Sets the multicast port.
- setMulticastTimeoutSeconds(int) - Method in class com.hazelcast.config.MulticastConfig
-
Specifies the time in seconds that a node should wait for a valid multicast response from another node running in the network before declaring itself as master node and creating its own cluster.
- setMulticastTimeToLive(int) - Method in class com.hazelcast.config.MulticastConfig
-
Sets the time to live for the multicast package; a value between 0..255.
- setMultiMapConfigs(Map<String, MultiMapConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of
MultiMap
configurations, mapped by config name. - setMultiplier(double) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
- setMultiThreadingEnabled(boolean) - Method in class com.hazelcast.config.TopicConfig
-
Enable multithreaded message handling.
- setName(String) - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
-
Sets the name or name pattern for this config.
- setName(String) - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
-
Sets the name or name pattern for this config.
- setName(String) - Method in class com.hazelcast.config.AttributeConfig
-
Sets the name of the attribute extracted by the extractor.
- setName(String) - Method in class com.hazelcast.config.CacheConfig
-
Sets the name of this
ICache
. - setName(String) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the name of this
ICache
. - setName(String) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
Sets the name of the cardinality estimator.
- setName(String) - Method in class com.hazelcast.config.CollectionConfig
-
Sets the name of this collection.
- setName(String) - Method in class com.hazelcast.config.cp.CPMapConfig
-
Sets the name of the configuration.
- setName(String) - Method in class com.hazelcast.config.cp.FencedLockConfig
-
Sets the name of FencedLock
- setName(String) - Method in class com.hazelcast.config.cp.SemaphoreConfig
-
Sets the name of CP ISemaphore
- setName(String) - Method in class com.hazelcast.config.DataConnectionConfig
-
Sets the name of this data connection, the name must be unique.
- setName(String) - Method in class com.hazelcast.config.DurableExecutorConfig
-
Sets the name of the executor task.
- setName(String) - Method in class com.hazelcast.config.EndpointConfig
- setName(String) - Method in class com.hazelcast.config.ExecutorConfig
-
Sets the name of the executor task.
- setName(String) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
Sets the name or name pattern for this config.
- setName(String) - Method in class com.hazelcast.config.IndexConfig
-
Sets name of the index.
- setName(String) - Method in class com.hazelcast.config.LocalDeviceConfig
-
Sets the device name.
- setName(String) - Method in class com.hazelcast.config.MapConfig
-
Sets the name of the
IMap
- setName(String) - Method in class com.hazelcast.config.MultiMapConfig
-
Sets the name of this MultiMap.
- setName(String) - Method in interface com.hazelcast.config.NamedConfig
- setName(String) - Method in class com.hazelcast.config.NearCacheConfig
-
Sets the name of the Near Cache.
- setName(String) - Method in class com.hazelcast.config.PermissionConfig
- setName(String) - Method in class com.hazelcast.config.PNCounterConfig
-
Sets the name of the PN counter.
- setName(String) - Method in class com.hazelcast.config.QueryCacheConfig
-
Sets the name of
QueryCache
. - setName(String) - Method in class com.hazelcast.config.QueueConfig
-
Set the name for this queue.
- setName(String) - Method in class com.hazelcast.config.ReliableTopicConfig
-
Sets the name of the reliable topic.
- setName(String) - Method in class com.hazelcast.config.ReplicatedMapConfig
-
Sets the name of this
ReplicatedMap
. - setName(String) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- setName(String) - Method in class com.hazelcast.config.RingbufferConfig
-
Sets the name of the ringbuffer.
- setName(String) - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Sets the name of the executor task.
- setName(String) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
- setName(String) - Method in class com.hazelcast.config.ServiceConfig
- setName(String) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
- setName(String) - Method in class com.hazelcast.config.TopicConfig
-
Sets the name of the topic.
- setName(String) - Method in class com.hazelcast.config.UserCodeNamespaceConfig
- setName(String) - Method in class com.hazelcast.config.vector.VectorCollectionConfig
-
Sets the name of the VectorCollection.
- setName(String) - Method in class com.hazelcast.config.vector.VectorIndexConfig
-
Sets the name of the vector index.
- setName(String) - Method in class com.hazelcast.config.WanReplicationConfig
-
Sets the name of this WAN replication config.
- setName(String) - Method in class com.hazelcast.config.WanReplicationRef
-
Sets the WAN replication reference name.
- setName(String) - Method in class com.hazelcast.jet.config.JobConfig
-
Sets the name of the job.
- setName(String) - Method in interface com.hazelcast.jet.pipeline.BatchStage
- setName(String) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
- setName(String) - Method in interface com.hazelcast.jet.pipeline.SinkStage
- setName(String) - Method in interface com.hazelcast.jet.pipeline.Stage
-
Overrides the default name of the stage with the name you choose and returns the stage.
- setName(String) - Method in interface com.hazelcast.jet.pipeline.StreamStage
- setName(String) - Method in class com.hazelcast.security.UsernamePasswordCredentials
- setNamespacesConfig(UserCodeNamespacesConfig) - Method in class com.hazelcast.config.Config
-
Sets the namespaces configuration.
- setNativeMemoryConfig(NativeMemoryConfig) - Method in class com.hazelcast.client.config.ClientConfig
- setNativeMemoryConfig(NativeMemoryConfig) - Method in class com.hazelcast.config.Config
-
Sets the native memory configuration for this hazelcast instance.
- setNearCacheConfig(NearCacheConfig) - Method in class com.hazelcast.config.MapConfig
-
Sets the Near Cache configuration
- setNearCacheConfigMap(Map<String, NearCacheConfig>) - Method in class com.hazelcast.client.config.ClientConfig
-
Sets all
NearCacheConfig
's with the provided map - setNetworkConfig(ClientNetworkConfig) - Method in class com.hazelcast.client.config.ClientConfig
-
Sets
ClientNetworkConfig
- setNetworkConfig(NetworkConfig) - Method in class com.hazelcast.config.Config
-
Sets the network configuration for this hazelcast instance.
- setNodeFilter(NodeFilter) - Method in class com.hazelcast.config.DiscoveryConfig
- setNodeFilterClass(String) - Method in class com.hazelcast.config.DiscoveryConfig
- setNodeIdOffset(long) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
Sets the offset that will be added to the node ID assigned to cluster member for this generator.
- setNullableBoolean(String, Boolean) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setNullableFloat32(String, Float) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setNullableFloat64(String, Double) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setNullableInt16(String, Short) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setNullableInt32(String, Integer) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setNullableInt64(String, Long) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setNullableInt8(String, Byte) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setNumaNode(int) - Method in class com.hazelcast.config.PersistentMemoryDirectoryConfig
-
Sets the NUMA node the persistent memory mounted to the given directory is attached to.
- setOffload(boolean) - Method in class com.hazelcast.config.MapStoreConfig
-
Default value is true.
- setOldValueRequired(boolean) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
If
true
, previously assigned values for the affected keys will be sent to this cache entry listener implementation. - setOnJoinPermissionOperation(OnJoinPermissionOperationName) - Method in class com.hazelcast.config.SecurityConfig
- setOrClear(String, String) - Method in class com.hazelcast.config.LoginModuleConfig
-
Alternative to the
LoginModuleConfig.setProperty(String, String)
method. - setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Set outbound port definitions
- setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.config.EndpointConfig
- setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.config.NetworkConfig
- setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
- setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Set outbound ports
- setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.config.EndpointConfig
- setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.config.NetworkConfig
- setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
- setOutOfMemoryHandler(OutOfMemoryHandler) - Static method in class com.hazelcast.client.HazelcastClient
-
Sets OutOfMemoryHandler to be used when an OutOfMemoryError is caught by Hazelcast Client threads.
- setOutOfMemoryHandler(OutOfMemoryHandler) - Static method in class com.hazelcast.core.Hazelcast
-
Sets
OutOfMemoryHandler
to be used when anOutOfMemoryError
is caught by Hazelcast threads. - setOverrideJavaSerialization(boolean) - Method in class com.hazelcast.config.GlobalSerializerConfig
- setPackages(Collection<String>) - Method in class com.hazelcast.config.ClassFilter
- setPacketSizeLimit(int) - Method in class com.hazelcast.jet.config.EdgeConfig
-
For a distributed edge, data is sent to a remote member via Hazelcast network packets.
- setPage(int) - Method in interface com.hazelcast.query.PagingPredicate
-
Sets the current page value.
- setPageSize(int) - Method in class com.hazelcast.config.NativeMemoryConfig
-
Sets the page size, in bytes, to be allocated by native memory manager as a single block.
- setPageSize(Capacity) - Method in class com.hazelcast.config.BTreeIndexConfig
-
Sets index page size to given non-negative value.
- setParallelism(int) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Deprecated.Sets the number of Hot Restart store instances to create for one Hazelcast instance.
- setParallelism(int) - Method in class com.hazelcast.config.PersistenceConfig
-
Sets the number of Persistence store instances to create for one Hazelcast instance.
- setParallelMode(boolean) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
-
Set the ICMP detector to run in parallel mode, independent from the other failure detectors.
- setParameters(List<Object>) - Method in class com.hazelcast.sql.SqlStatement
-
Sets the values for statement parameters.
- setParseDn(Boolean) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- setPartitionArgumentIndex(int) - Method in class com.hazelcast.sql.SqlStatement
-
Set the partition argument index.
- setPartitionAssignment(Map<Address, int[]>) - Method in class com.hazelcast.jet.core.test.TestProcessorContext
- setPartitionAssignment(Map<Address, int[]>) - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
-
Sets the partition assignment.
- setPartitionAssignment(Map<Address, int[]>) - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
- setPartitionGroupConfig(PartitionGroupConfig) - Method in class com.hazelcast.config.Config
-
Sets the partition group configuration for this hazelcast instance.
- setPartitionIdleTimeout(long) - Method in interface com.hazelcast.jet.pipeline.StreamSource
-
Sets a timeout after which idle partitions will be excluded from watermark coalescing.
- setPartitioningAttributeConfigs(List<PartitioningAttributeConfig>) - Method in class com.hazelcast.config.MapConfig
- setPartitioningStrategy(PartitioningStrategy) - Method in class com.hazelcast.config.PartitioningStrategyConfig
- setPartitioningStrategyClass(String) - Method in class com.hazelcast.config.PartitioningStrategyConfig
- setPartitioningStrategyConfig(PartitioningStrategyConfig) - Method in class com.hazelcast.config.MapConfig
- setPartitionLostListenerConfigs(List<CachePartitionLostListenerConfig>) - Method in class com.hazelcast.config.CacheConfig
-
Sets the WAN target replication reference.
- setPartitionLostListenerConfigs(List<CachePartitionLostListenerConfig>) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the PartitionLostListenerConfigs.
- setPartitionLostListenerConfigs(List<MapPartitionLostListenerConfig>) - Method in class com.hazelcast.config.MapConfig
- setPassword(String) - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
-
Sets the Java KeyStore password.
- setPassword(String) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-
Deprecated.
- setPassword(String) - Method in class com.hazelcast.security.UsernamePasswordCredentials
- setPasswordAttribute(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- setPath(File) - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
-
Sets the Java KeyStore file path.
- setPerEntryStatsEnabled(boolean) - Method in class com.hazelcast.config.MapConfig
-
Set to enable/disable per entry statistics.
- SetPermission - Class in com.hazelcast.security.permission
- SetPermission(String, String...) - Constructor for class com.hazelcast.security.permission.SetPermission
- setPermissionPriorityGrant(boolean) - Method in class com.hazelcast.config.SecurityConfig
-
Sets if grant permissions should take precedence over deny ones.
- setPersistenceConfig(PersistenceConfig) - Method in class com.hazelcast.config.Config
-
Sets the Persistence configuration.
- setPersistenceEnabled(boolean) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Sets whether CP Subsystem Persistence is enabled on this member.
- setPersistenceEnabled(boolean) - Method in class com.hazelcast.config.DynamicConfigurationConfig
-
Sets whether Dynamic Configuration Persistence is enabled on this member.
- setPersistentMemoryConfig(PersistentMemoryConfig) - Method in class com.hazelcast.config.NativeMemoryConfig
-
Sets the persistent memory configuration this native memory configuration uses.
- setPersistentMemoryDirectory(String) - Method in class com.hazelcast.config.NativeMemoryConfig
-
Deprecated.Since 4.1 multiple persistent memory directories are supported. Please use
NativeMemoryConfig.setPersistentMemoryConfig(PersistentMemoryConfig)
orPersistentMemoryConfig.addDirectoryConfig(PersistentMemoryDirectoryConfig)
instead. - setPersistWanReplicatedData(boolean) - Method in class com.hazelcast.config.WanConsumerConfig
- setPNCounterConfigs(Map<String, PNCounterConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of PN counter configurations, mapped by config name.
- setPolicy(String) - Method in class com.hazelcast.config.MergePolicyConfig
-
Sets the class name of your
SplitBrainMergePolicy
. - setPollingInterval(int) - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
-
Sets the polling interval (in seconds) for checking for changes in the KeyStore.
- setPollingInterval(int) - Method in class com.hazelcast.config.VaultSecureStoreConfig
-
Sets the polling interval (in seconds) for checking for changes in Vault.
- setPoolSize(int) - Method in class com.hazelcast.config.DurableExecutorConfig
-
Sets the number of executor threads per member for the executor.
- setPoolSize(int) - Method in class com.hazelcast.config.ExecutorConfig
-
Sets the number of executor threads per member for the executor.
- setPoolSize(int) - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Sets the number of executor threads per member for the executor.
- setPopulate(boolean) - Method in class com.hazelcast.config.QueryCacheConfig
-
Set
true
to enable initial population, otherwise setfalse
. - setPort(int) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- setPort(int) - Method in class com.hazelcast.config.NetworkConfig
-
Sets the port the Hazelcast member will try to bind on.
- setPort(int) - Method in class com.hazelcast.config.rest.RestConfig
-
Sets the port of the RestConfig.
- setPort(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- setPort(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
Sets the port the Hazelcast member will try to bind on.
- setPortableFactories(Map<Integer, PortableFactory>) - Method in class com.hazelcast.config.SerializationConfig
-
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.
- setPortableFactoryClasses(Map<Integer, 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.
- setPortableVersion(int) - 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.
- setPortAutoIncrement(boolean) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- setPortAutoIncrement(boolean) - Method in class com.hazelcast.config.NetworkConfig
-
Sets if a Hazelcast member is allowed to find a free port by incrementing the port number when it encounters an occupied port.
- setPortAutoIncrement(boolean) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- setPortAutoIncrement(boolean) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
Sets if a Hazelcast member is allowed to find a free port by incrementing the port number when it encounters an occupied port.
- setPortCount(int) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- setPortCount(int) - Method in class com.hazelcast.config.NetworkConfig
-
The maximum number of ports allowed to use.
- setPortCount(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
The maximum number of ports allowed to use.
- setPortRange(String) - Method in class com.hazelcast.config.tpc.TpcSocketConfig
-
Sets the possible port range for TPC sockets to bind.
- setPredicateConfig(PredicateConfig) - Method in class com.hazelcast.config.QueryCacheConfig
-
Sets the predicate of
QueryCache
. - setPrefetchCount(int) - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
-
Sets how many IDs are pre-fetched on the background when one call to
FlakeIdGenerator.newId()
is made. - setPrefetchCount(int) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
Sets how many IDs are pre-fetched on the background when one call to
FlakeIdGenerator.newId()
is made. - setPrefetchValidityMillis(long) - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
-
Sets for how long the pre-fetched IDs can be used.
- setPrefetchValidityMillis(long) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
Sets for how long the pre-fetched IDs can be used.
- setPrefixes(Collection<String>) - Method in class com.hazelcast.config.ClassFilter
- setPreloaderConfig(NearCachePreloaderConfig) - Method in class com.hazelcast.config.NearCacheConfig
-
Sets the
NearCachePreloaderConfig
of this Near Cache. - setPreserveOrder(boolean) - Method in interface com.hazelcast.jet.pipeline.Pipeline
-
Tells Jet whether or not it is allowed to reorder the events for better performance.
- setPrincipal(String) - Method in class com.hazelcast.config.PermissionConfig
- setPrincipal(String) - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
-
Allows (together with the
KerberosAuthenticationConfig.setKeytabFile(String)
) simplification of security realm configuration. - setPrincipal(String) - Method in class com.hazelcast.config.security.KerberosIdentityConfig
-
Allows (together with the
KerberosIdentityConfig.setKeytabFile(String)
) simplification of security realm configuration. - setPriorityComparatorClassName(String) - Method in class com.hazelcast.config.QueueConfig
-
Sets the class name that will be used to compare queue items.
- setProcessingGuarantee(ProcessingGuarantee) - Method in class com.hazelcast.jet.config.JobConfig
-
Set the
processing guarantee
for the job. - setProcessingGuarantee(ProcessingGuarantee) - Method in class com.hazelcast.jet.core.test.TestProcessorContext
- setProcessingGuarantee(ProcessingGuarantee) - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
-
Sets the processing guarantee.
- setProcessingGuarantee(ProcessingGuarantee) - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
- setProperties(Map<String, Comparable>) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
-
Sets the WAN publisher properties.
- setProperties(Map<String, Comparable>) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
- setProperties(Map<String, Comparable>) - Method in class com.hazelcast.config.WanBatchPublisherConfig
- setProperties(Map<String, Comparable>) - Method in class com.hazelcast.config.WanConsumerConfig
-
Sets the properties for the custom WAN consumer.
- setProperties(Map<String, Comparable>) - Method in class com.hazelcast.config.WanCustomPublisherConfig
- setProperties(Properties) - Method in class com.hazelcast.client.config.ClientConfig
-
sets all properties
- setProperties(Properties) - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
- setProperties(Properties) - Method in class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
- setProperties(Properties) - Method in class com.hazelcast.client.config.YamlClientConfigBuilder
- setProperties(Properties) - Method in class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
- setProperties(Properties) - Method in class com.hazelcast.config.AbstractBaseFactoryWithPropertiesConfig
-
Sets the properties.
- setProperties(Properties) - Method in class com.hazelcast.config.Config
-
Sets the properties for this config instance.
- setProperties(Properties) - Method in class com.hazelcast.config.CredentialsFactoryConfig
- setProperties(Properties) - Method in class com.hazelcast.config.DataConnectionConfig
-
Sets the properties of a data connection.
- setProperties(Properties) - Method in class com.hazelcast.config.LoginModuleConfig
- setProperties(Properties) - Method in class com.hazelcast.config.MapStoreConfig
-
Sets the properties
- setProperties(Properties) - Method in class com.hazelcast.config.MemberAddressProviderConfig
- setProperties(Properties) - Method in class com.hazelcast.config.PermissionPolicyConfig
- setProperties(Properties) - Method in class com.hazelcast.config.QueueStoreConfig
-
Sets the properties to be used when instantiating the queue store.
- setProperties(Properties) - Method in class com.hazelcast.config.RingbufferStoreConfig
- setProperties(Properties) - Method in class com.hazelcast.config.ServiceConfig
- setProperties(Properties) - Method in class com.hazelcast.config.SocketInterceptorConfig
-
Sets the properties.
- setProperties(Properties) - Method in class com.hazelcast.config.XmlConfigBuilder
-
Sets the used properties.
- setProperties(Properties) - Method in class com.hazelcast.config.YamlConfigBuilder
- setPropertiesInternal(Properties) - Method in class com.hazelcast.config.AbstractXmlConfigBuilder
-
Sets the used properties.
- setPropertiesInternal(Properties) - Method in class com.hazelcast.config.AbstractYamlConfigBuilder
- setProperty(String, String) - Method in class com.hazelcast.client.config.ClientConfig
-
Sets the value of a named property.
- setProperty(String, String) - Method in class com.hazelcast.config.AbstractBaseFactoryWithPropertiesConfig
-
Sets a single property.
- setProperty(String, String) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
-
Sets the property understood by the given SPI Discovery Strategy.
- setProperty(String, String) - Method in class com.hazelcast.config.Config
-
Sets the value of a named property.
- setProperty(String, String) - Method in class com.hazelcast.config.DataConnectionConfig
-
Sets a single property.
- setProperty(String, String) - Method in class com.hazelcast.config.LoginModuleConfig
- setProperty(String, String) - Method in class com.hazelcast.config.MapStoreConfig
- setProperty(String, String) - Method in class com.hazelcast.config.QueueStoreConfig
-
Sets a property to be used when instantiating the queue store.
- setProperty(String, String) - Method in class com.hazelcast.config.RingbufferStoreConfig
- setProperty(String, String) - Method in class com.hazelcast.config.SocketInterceptorConfig
-
Sets a property.
- setProperty(String, String) - Method in class com.hazelcast.jet.cdc.DebeziumCdcSources.Builder
-
Sets a source property.
- setProtectOn(SplitBrainProtectionOn) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
- setProtocol(String) - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Set the SSL protocol to use.
- setProtocolType(ProtocolType) - Method in class com.hazelcast.config.EndpointConfig
- setProtocolType(ProtocolType) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
- setProviderFilter(String) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Deprecated.Filter to limit members that can be used for classloading request when a user class is not available locally.
- setProviderMode(UserCodeDeploymentConfig.ProviderMode) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Deprecated.Configure behaviour when providing classes to remote members.
- setProxyFactoryConfigs(List<ProxyFactoryConfig>) - Method in class com.hazelcast.client.config.ClientConfig
-
Sets the
ProxyFactoryConfig
- setPublicAddress(String) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- setPublicAddress(String) - Method in class com.hazelcast.config.NetworkConfig
-
Overrides the public address of a member.
- setPublicAddress(String) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- setPublicAddress(String) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
Overrides the public address of a member.
- setPublicationName(String) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
The name of the Postgres publication that will be used for CDC purposes.
- setPublisherId(String) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
-
Sets the publisher ID used for identifying the publisher in a
WanReplicationConfig
. - setPublisherId(String) - Method in class com.hazelcast.config.WanBatchPublisherConfig
- setPublisherId(String) - Method in class com.hazelcast.config.WanCustomPublisherConfig
- setQueryCacheConfigs(List<QueryCacheConfig>) - Method in class com.hazelcast.config.MapConfig
-
Sets
QueryCacheConfig
instances to thisMapConfig
. - setQueryCacheConfigs(Map<String, Map<String, QueryCacheConfig>>) - Method in class com.hazelcast.client.config.ClientConfig
- setQueueCapacity(int) - Method in class com.hazelcast.config.ExecutorConfig
-
Sets the queue capacity of the executor task. 0 means
Integer.MAX_VALUE
. - setQueueCapacity(int) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the capacity of the primary and backup queue for WAN replication events.
- setQueueConfigs(Map<String, QueueConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of
IQueue
configurations, mapped by config name. - setQueueFullBehavior(WanQueueFullBehavior) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the configured behaviour of this WAN publisher when the WAN queue is full.
- setQueueSize(int) - Method in class com.hazelcast.jet.config.EdgeConfig
-
Sets the capacity of processor-to-processor concurrent queues.
- setQueueStoreConfig(QueueStoreConfig) - Method in class com.hazelcast.config.QueueConfig
-
Set the QueueStore (load and store queue items from/to a database) configuration.
- setRaftAlgorithmConfig(RaftAlgorithmConfig) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Sets configuration options for Hazelcast's Raft consensus algorithm implementation
- setReadBackupData(boolean) - Method in class com.hazelcast.config.MapConfig
-
Sets read-backup-data (reading local backup entries) for this map.
- setReadBatchSize(int) - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
-
Sets the read batch size.
- setReadBatchSize(int) - Method in class com.hazelcast.config.ReliableTopicConfig
-
Sets the read batch size.
- setReadIOThreadCount(int) - Method in class com.hazelcast.config.LocalDeviceConfig
-
Sets the read IO thread count.
- setReadThrough(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
- setReadThrough(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
-
Set if read-through caching should be used.
- setReadThrough(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Enables or disables read-through: a read loads the entry from the data store if it is not already in the cache.
- setReadTimeout(long) - Method in class com.hazelcast.spring.cache.HazelcastCache
-
Set cache value retrieval timeout
- setRealm(String) - Method in class com.hazelcast.config.security.KerberosIdentityConfig
-
Defines Kerberos realm name (e.g.
- setRealmConfig(RealmConfig) - Method in class com.hazelcast.security.RealmConfigCallback
- setRealmConfigs(Map<String, RealmConfig>) - Method in class com.hazelcast.client.config.ClientSecurityConfig
- setRealmConfigs(Map<String, RealmConfig>) - Method in class com.hazelcast.config.SecurityConfig
- setRealmName(String) - Method in class com.hazelcast.security.RealmNameCallback
- setRebalanceDelaySeconds(int) - Method in class com.hazelcast.config.PersistenceConfig
-
Set the rebalance delay in seconds.
- setReceiveBufferSizeKB(int) - Method in class com.hazelcast.config.tpc.TpcSocketConfig
-
Sets the receive-buffer size of the TPC sockets in kilobytes.
- setReceiveWindowMultiplier(int) - Method in class com.hazelcast.jet.config.EdgeConfig
-
Sets the scaling factor used by the adaptive receive window sizing function.
- setReconnectBehavior(RetryStrategy) - Method in class com.hazelcast.jet.cdc.mysql.MySqlCdcSources.Builder
-
Specifies how the source should behave when it detects that the backing database has been shut down (read class javadoc for details and special cases).
- setReconnectBehavior(RetryStrategy) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
Specifies how the connector should behave when it detects that the backing database has been shut dow.
- setReconnectMode(ClientConnectionStrategyConfig.ReconnectMode) - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
-
How a client reconnect to cluster after a disconnect can be configured.
- setRedoOperation(boolean) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
If true, client will redo the operations that were executing on the server and client lost the connection.
- setRelaxFlagsCheck(Boolean) - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
-
Allows disabling some of the checks on incoming token (e.g. passes authentication even if the mutual authentication is required by the token).
- setReliableTopicConfigMap(Map<String, ClientReliableTopicConfig>) - Method in class com.hazelcast.client.config.ClientConfig
-
Sets the map of
ClientReliableTopicConfig
, mapped by config name. - setReliableTopicConfigs(Map<String, ReliableTopicConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of reliable topic configurations, mapped by config name.
- setReplicaCount(int) - Method in class com.hazelcast.config.PNCounterConfig
-
Sets the number of replicas on which state for this PN counter will be kept.
- setReplicatedMapConfigs(Map<String, ReplicatedMapConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of
ReplicatedMap
configurations, mapped by config name. - setReplicationPeriodMillis(int) - Method in class com.hazelcast.config.CRDTReplicationConfig
-
Sets the period between two replications of CRDT states in milliseconds.
- setReplicationSlotDropOnStop(boolean) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
Whether to drop the logical replication slot when the connector disconnects cleanly.
- setReplicationSlotName(String) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
The name of the @see Postgres logical decoding slot (also called "replication slot") created for streaming changes from a plug-in and database instance.
- setRepublishingEnabled(boolean) - Method in class com.hazelcast.config.WanReplicationRef
-
Sets if incoming WAN events to this member should be republished (forwarded) to this WAN replication reference.
- setRequestTimeoutDuration(Duration) - Method in class com.hazelcast.config.rest.RestConfig
-
Set the HTTP request timeout.
- setRequiredMember(String) - Method in class com.hazelcast.config.TcpIpConfig
-
Sets the required member.
- setResourceUploadEnabled(boolean) - Method in class com.hazelcast.jet.config.JetConfig
-
Sets if uploading resources when submitting the job enabled
- setResponseTimeoutMillis(int) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the duration in milliseconds for the waiting time before retrying to send the events to target cluster again in case of acknowledgement is not arrived.
- setRestApiConfig(RestApiConfig) - Method in class com.hazelcast.config.NetworkConfig
- setRestConfig(RestConfig) - Method in class com.hazelcast.config.Config
-
Sets the configuration for the REST API server.
- setRestEndpointConfig(RestServerEndpointConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
-
Deprecated, for removal: This API element is subject to removal in a future version.since 5.5, use RestConfig instead. Will be removed at 6.0.
- setResubmissionMode(ClientSqlResubmissionMode) - Method in class com.hazelcast.client.config.ClientSqlConfig
-
Sets the resubmission mode for failing SQL queries.
- setRetentionSeconds(int) - Method in class com.hazelcast.config.MetricsManagementCenterConfig
-
Sets the number of seconds the metrics will be retained on the instance.
- setReuseAddress(boolean) - Method in class com.hazelcast.client.config.SocketOptions
-
Enable/disable the SO_REUSEADDR socket option.
- setReuseAddress(boolean) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- setReuseAddress(boolean) - Method in class com.hazelcast.config.NetworkConfig
-
Sets the reuse address.
- setReuseAddress(boolean) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- setReuseAddress(boolean) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
Sets the reuse address.
- setRingbufferConfigs(Map<String, RingbufferConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of
Ringbuffer
configurations, mapped by config name. - setRingbufferStoreConfig(RingbufferStoreConfig) - Method in class com.hazelcast.config.RingbufferConfig
-
Set the RingbufferStore (load and store ringbuffer items from/to a database) configuration.
- setRoleAttribute(String) - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
- setRoleContext(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- setRoleFilter(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- setRoleMappingAttribute(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- setRoleMappingMode(LdapRoleMappingMode) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- setRoleNameAttribute(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- setRoleRecursionMaxDepth(Integer) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- setRoleSearchScope(LdapSearchScope) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- setRoleSeparator(String) - Method in class com.hazelcast.config.security.SimpleAuthenticationConfig
-
Allows to use a custom role separator in the configuration.
- setRoutingMode(RoutingMode) - Method in class com.hazelcast.client.config.ClusterRoutingConfig
-
Sets the
RoutingMode
for this client to use when connecting to cluster members. - setRoutingStrategy(RoutingStrategy) - Method in class com.hazelcast.client.config.ClusterRoutingConfig
-
Sets the strategy for routing client connections to members when
RoutingMode.MULTI_MEMBER
is configured. - setSalt(String) - Method in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
-
Sets the salt used for encryption.
- setScaleUpDelayMillis(long) - Method in class com.hazelcast.jet.config.InstanceConfig
-
Deprecated.Sets the delay after which auto-scaled jobs will restart if a new member is added to the cluster.
- setScaleUpDelayMillis(long) - Method in class com.hazelcast.jet.config.JetConfig
-
Sets the delay after which auto-scaled jobs will restart if a new member is added to the cluster.
- setScheduledExecutorConfigs(Map<String, ScheduledExecutorConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of scheduled executor configurations, mapped by config name.
- setSchema(String) - Method in class com.hazelcast.sql.SqlStatement
-
Sets the schema name.
- setSchemaBlacklist(String...) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
Optional regular expressions that match schema names to be excluded from monitoring ("schema" is used here to denote logical groups of tables).
- setSchemaWhitelist(String...) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
Optional regular expressions that match schema names to be monitored ("schema" is used here to denote logical groups of tables).
- setScopeId(String) - Method in class com.hazelcast.cluster.Address
- setScriptingEnabled(boolean) - Method in class com.hazelcast.config.ManagementCenterConfig
-
Enables/disables scripting on the member.
- setSecretPath(String) - Method in class com.hazelcast.config.VaultSecureStoreConfig
-
Sets the Vault secret path where the encryption keys is expected to be stored.
- setSecureStoreConfig(SecureStoreConfig) - Method in class com.hazelcast.config.EncryptionAtRestConfig
-
Sets the Secure Store configuration.
- setSecurityConfig(ClientSecurityConfig) - Method in class com.hazelcast.client.config.ClientConfig
-
Sets
ClientSecurityConfig
object - setSecurityConfig(SecurityConfig) - Method in class com.hazelcast.config.Config
-
Sets the security configuration for this hazelcast instance.
- setSecurityContext(SecurityContext) - Method in class com.hazelcast.security.SecurityContextCallback
- setSecurityInterceptorConfigs(List<SecurityInterceptorConfig>) - Method in class com.hazelcast.config.SecurityConfig
- setSecurityRealm(String) - Method in class com.hazelcast.config.rest.RestConfig
-
Sets the name of the Rest security realm.
- setSecurityRealm(String) - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
-
References Security realm name in Hazelcast configuration.
- setSecurityRealm(String) - Method in class com.hazelcast.config.security.KerberosIdentityConfig
-
Configures a reference to Security realm name in Hazelcast configuration.
- setSecurityRealm(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- setSemaphoreConfigs(Map<String, SemaphoreConfig>) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Sets the map of CP
ISemaphore
configurations, mapped by config name. - setSendBufferSizeKB(int) - Method in class com.hazelcast.config.tpc.TpcSocketConfig
-
Sets the send-buffer size of the TPC sockets in kilobytes.
- setSerializationConfig(SerializationConfig) - Method in class com.hazelcast.client.config.ClientConfig
-
Sets
SerializationConfig
- setSerializationConfig(SerializationConfig) - Method in class com.hazelcast.config.Config
-
Sets the serialization configuration for this hazelcast instance.
- setSerializationService(CacheConfig<?, ?>, SerializationService) - Static method in class com.hazelcast.config.CacheConfigAccessor
- setSerializeKeys(boolean) - Method in class com.hazelcast.config.NearCacheConfig
-
Sets if the Near Cache key is stored in serialized format or by-reference.
- setSerializeKeys(boolean) - Method in class com.hazelcast.config.QueryCacheConfig
-
Sets if the
QueryCache
key is stored in serialized format or by-reference. - setSerializerConfigs(Collection<SerializerConfig>) - Method in class com.hazelcast.config.SerializationConfig
- setSerializers(CompactSerializer<?>...) - Method in class com.hazelcast.config.CompactSerializationConfig
-
Registers the given Compact serializers.
- setService(String) - Method in class com.hazelcast.client.config.ProxyFactoryConfig
- setServiceNamePrefix(String) - Method in class com.hazelcast.config.security.KerberosIdentityConfig
-
Defines prefix of the Service Principal name.
- setSessionHeartbeatIntervalSeconds(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Sets the interval for the periodically-committed CP session heartbeats.
- setSessionTimeToLiveSeconds(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Sets the duration for a CP session to be kept alive after its last session heartbeat.
- setSetConfigs(Map<String, SetConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of
ISet
configurations, mapped by config name. - setShared(boolean) - Method in class com.hazelcast.config.DataConnectionConfig
-
true
if an instance of the data connection will be reused. - setShouldStateBeResetOnReconnect(boolean) - Method in class com.hazelcast.jet.cdc.mysql.MySqlCdcSources.Builder
-
Specifies if the source's state should be kept or discarded during reconnect attempts to the database.
- setShouldStateBeResetOnReconnect(boolean) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
Specifies if the source's state should be kept or discarded during reconnect attempts to the database.
- setSimpleAuthenticationConfig(SimpleAuthenticationConfig) - Method in class com.hazelcast.config.security.RealmConfig
- setSize(int) - Method in class com.hazelcast.config.EvictionConfig
-
Sets the size which is used by the
MaxSizePolicy
. - setSize(MemorySize) - Method in class com.hazelcast.config.NativeMemoryConfig
-
Deprecated.Since 5.2, use
NativeMemoryConfig.setCapacity(Capacity)
instead. - setSkipAuthentication(Boolean) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- setSkipEndpoint(Boolean) - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
-
Allows skipping address assignment of authenticated user/service.
- setSkipIdentity(Boolean) - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
-
Allows skipping identity (name) assignment during the authentication.
- setSkipRole(Boolean) - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
-
Allows skipping role assignment during authentication.
- setSmartRouting(boolean) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Deprecated.since 5.5, this option is superseded by
ClusterRoutingConfig.setRoutingMode(RoutingMode)
}. - setSnapshotEnabled(boolean) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets if key-based coalescing is configured for this WAN publisher.
- setSnapshotIntervalMillis(long) - Method in class com.hazelcast.jet.config.DeltaJobConfig
- setSnapshotIntervalMillis(long) - Method in class com.hazelcast.jet.config.JobConfig
-
Sets the snapshot interval in milliseconds — the interval between the completion of the previous snapshot and the start of a new one.
- setSnapshotMode(PostgresCdcSources.PostgresSnapshotMode) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
Snapshot mode that will be used by the connector.
- setSocketBufferDirect(boolean) - Method in class com.hazelcast.config.EndpointConfig
- setSocketBufferDirect(boolean) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- setSocketBufferDirect(boolean) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
- setSocketConnectTimeoutSeconds(int) - Method in class com.hazelcast.config.EndpointConfig
- setSocketConnectTimeoutSeconds(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- setSocketConnectTimeoutSeconds(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
- setSocketFactoryClassName(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
- setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.config.EndpointConfig
-
Sets the
SocketInterceptorConfig
. - setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.config.NetworkConfig
-
Sets the
SocketInterceptorConfig
. - setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
- setSocketKeepAlive(boolean) - Method in class com.hazelcast.config.EndpointConfig
- setSocketKeepAlive(boolean) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- setSocketKeepAlive(boolean) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
- setSocketKeepCount(int) - Method in class com.hazelcast.config.EndpointConfig
-
Set the maximum number of TCP keep-alive probes to send before giving up and closing the connection if no response is obtained from the other side.
- setSocketKeepCount(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- setSocketKeepCount(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
- setSocketKeepIdleSeconds(int) - Method in class com.hazelcast.config.EndpointConfig
-
Set the number of seconds a connection needs to be idle before TCP begins sending out keep-alive probes.
- setSocketKeepIdleSeconds(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- setSocketKeepIdleSeconds(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
- setSocketKeepIntervalSeconds(int) - Method in class com.hazelcast.config.EndpointConfig
-
Set the number of seconds between keep-alive probes.
- setSocketKeepIntervalSeconds(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- setSocketKeepIntervalSeconds(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
- setSocketLingerSeconds(int) - Method in class com.hazelcast.config.EndpointConfig
- setSocketLingerSeconds(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- setSocketLingerSeconds(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
- setSocketOptions(SocketOptions) - Method in class com.hazelcast.client.config.ClientNetworkConfig
- setSocketRcvBufferSizeKb(int) - Method in class com.hazelcast.config.EndpointConfig
- setSocketRcvBufferSizeKb(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- setSocketRcvBufferSizeKb(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
- setSocketSendBufferSizeKb(int) - Method in class com.hazelcast.config.EndpointConfig
- setSocketSendBufferSizeKb(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- setSocketSendBufferSizeKb(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
- setSocketTcpNoDelay(boolean) - Method in class com.hazelcast.config.EndpointConfig
- setSocketTcpNoDelay(boolean) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- setSocketTcpNoDelay(boolean) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
- setSplitBrainProtection(boolean) - Method in class com.hazelcast.jet.config.DeltaJobConfig
- setSplitBrainProtection(boolean) - Method in class com.hazelcast.jet.config.JobConfig
-
Configures the split brain protection feature.
- setSplitBrainProtectionConfigs(Map<String, SplitBrainProtectionConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of split-brain protection configurations, mapped by config name.
- setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.CacheConfig
-
Associates this cache configuration to a split brain protection.
- setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Associates this cache configuration to a split brain protection.
- setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
Sets the split brain protection name for operations.
- setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.CollectionConfig
-
Sets the split brain protection name for operations.
- setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.DurableExecutorConfig
-
Sets the split brain protection name for operations.
- setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.ExecutorConfig
-
Sets the split brain protection name for operations.
- setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.MapConfig
- setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.MultiMapConfig
-
Sets the split brain protection name for operations.
- setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.PNCounterConfig
-
Sets the split brain protection name for operations.
- setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.QueueConfig
-
Sets the split brain protection name for queue operations.
- setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.ReplicatedMapConfig
-
Sets the split brain protection name for operations.
- setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.RingbufferConfig
-
Sets the split brain protection name for operations.
- setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Sets the split brain protection name for operations.
- setSplitBrainProtectionName(String) - Method in interface com.hazelcast.config.SplitBrainPolicyAwareConfig
-
Sets the split brain protection name for operations of the data structure.
- setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.vector.VectorCollectionConfig
-
Sets the split brain protection name for operations of the data structure.
- setSpn(String) - Method in class com.hazelcast.config.security.KerberosIdentityConfig
-
Allows to configure static service principal name (SPN).
- setSql(String) - Method in class com.hazelcast.config.PredicateConfig
-
Sets sql string for this config.
- setSql(String) - Method in class com.hazelcast.sql.SqlStatement
-
Sets the SQL string to be executed.
- setSqlConfig(ClientSqlConfig) - Method in class com.hazelcast.client.config.ClientConfig
-
Sets the configuration for the SQL feature.
- setSqlConfig(SqlConfig) - Method in class com.hazelcast.config.Config
-
Sets SQL config.
- setSsl(RestConfig.Ssl) - Method in class com.hazelcast.config.rest.RestConfig
-
Sets the SSL configuration.
- setSslCertificateFile(String) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
Specifies the (path to the) file containing the SSL Certificate for the database client.
- setSSLConfig(SSLConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Sets the
SSLConfig
. null value indicates that no SSLConfig should be used. - setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.EndpointConfig
-
Sets the
SSLConfig
. null value indicates that no SSLConfig should be used. - setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.NetworkConfig
-
Sets the
SSLConfig
. null value indicates that no SSLConfig should be used. - setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
- setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.VaultSecureStoreConfig
-
Sets the SSL/TLS configuration.
- setSslKeyFile(String) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
Specifies the (path to the) file containing the SSL private key of the database client.
- setSslKeyFilePassword(String) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
Specifies the password to be used to access the SSL key file, if specified.
- setSslKeystoreFile(String) - Method in class com.hazelcast.jet.cdc.mysql.MySqlCdcSources.Builder
-
Specifies the (path to the) Java keystore file containing the database client certificate and private key.
- setSslKeystorePassword(String) - Method in class com.hazelcast.jet.cdc.mysql.MySqlCdcSources.Builder
-
Password to access the private key from any specified keystore files.
- setSslMode(String) - Method in class com.hazelcast.jet.cdc.mysql.MySqlCdcSources.Builder
-
Specifies whether to use an encrypted connection to the database.
- setSslMode(String) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
Specifies whether to use an encrypted connection to the database.
- setSslRootCertificateFile(String) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
Specifies the file containing SSL certificate authority (CA) certificate(s).
- setSslTruststoreFile(String) - Method in class com.hazelcast.jet.cdc.mysql.MySqlCdcSources.Builder
-
Specifies the (path to the) Java truststore file containing the collection of trusted CA certificates.
- setSslTruststorePassword(String) - Method in class com.hazelcast.jet.cdc.mysql.MySqlCdcSources.Builder
-
Password to unlock any specified truststore.
- setStatementTimeoutMillis(long) - Method in class com.hazelcast.config.SqlConfig
-
Sets the timeout in milliseconds that is applied to statements without an explicit timeout.
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
-
Sets whether statistics gathering is enabled on this cache.
- setStatisticsEnabled(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
-
Sets whether statistics gathering is enabled on a cache.
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets statistics to enabled or disabled for this
ICache
. - setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.CollectionConfig
-
Sets collection statistics to enabled or disabled.
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.DurableExecutorConfig
-
Enables or disables statistics gathering on the executor task.
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ExecutorConfig
-
Enables or disables statistics gathering on the executor task.
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
Enables or disables statistics gathering of
LocalFlakeIdGeneratorStats
. - setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.MapConfig
-
Set to enable/disable map level statistics for this map.
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.MultiMapConfig
-
Enables or disables statistics for this MultiMap.
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.PNCounterConfig
-
Enables or disables statistics for this PN counter
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.QueueConfig
-
Enables or disables statistics for this queue.
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ReliableTopicConfig
-
Enables or disables statistics for this reliable topic.
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ReplicatedMapConfig
-
Sets statistics to enabled or disabled for this replicated map.
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Enables or disables statistics gathering on the executor task.
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.TopicConfig
-
Enables or disables statistics for this topic.
- setStoreByValue(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
-
Set if a configured cache should use store-by-value or store-by-reference semantics.
- setStoreByValue(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
-
Set if a configured cache should use store-by-value or store-by-reference semantics.
- setStoreImplementation(QueueStore) - Method in class com.hazelcast.config.QueueStoreConfig
-
Sets the implementation of the queue store which will be used to store queue items.
- setStoreImplementation(RingbufferStore) - Method in class com.hazelcast.config.RingbufferStoreConfig
- setStoreInitialDelaySeconds(int) - Method in class com.hazelcast.config.NearCachePreloaderConfig
- setStoreIntervalSeconds(int) - Method in class com.hazelcast.config.NearCachePreloaderConfig
- setStoreMetricsAfterJobCompletion(boolean) - Method in class com.hazelcast.jet.config.DeltaJobConfig
- setStoreMetricsAfterJobCompletion(boolean) - Method in class com.hazelcast.jet.config.JobConfig
-
Sets whether metrics should be stored in the cluster after the job completes.
- setString(String, String) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
It is legal to set the field again only when Builder is created with
GenericRecord.newBuilderWithClone()
. - setSuspendOnFailure(boolean) - Method in class com.hazelcast.jet.config.DeltaJobConfig
- setSuspendOnFailure(boolean) - Method in class com.hazelcast.jet.config.JobConfig
-
Sets what happens if the job execution fails: If enabled, the job will be suspended.
- setSymmetricEncryptionConfig(SymmetricEncryptionConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- setSymmetricEncryptionConfig(SymmetricEncryptionConfig) - Method in class com.hazelcast.config.EndpointConfig
-
Deprecated.since 4.2
- setSymmetricEncryptionConfig(SymmetricEncryptionConfig) - Method in class com.hazelcast.config.NetworkConfig
-
Deprecated.since 4.2
- setSymmetricEncryptionConfig(SymmetricEncryptionConfig) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- setSymmetricEncryptionConfig(SymmetricEncryptionConfig) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
- setSyncConfig(WanSyncConfig) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the config for the WAN sync mechanism.
- setSynchronous(boolean) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
If
true
, this cache entry listener implementation will be called in a synchronous manner. - setSystemAuthentication(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- setSystemProperty(String) - Method in class com.hazelcast.spi.properties.HazelcastProperty
-
Sets the system property value of the property.
- setSystemUserDn(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- setSystemUserPassword(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- setTableBlacklist(String...) - Method in class com.hazelcast.jet.cdc.mysql.MySqlCdcSources.Builder
-
Optional regular expressions that match fully-qualified table identifiers for tables to be excluded from monitoring; any table not included in the blacklist will be monitored.
- setTableBlacklist(String...) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
Optional regular expressions that match fully-qualified table identifiers for tables to be excluded from monitoring; any table not included in the blacklist will be monitored.
- setTableWhitelist(String...) - Method in class com.hazelcast.jet.cdc.mysql.MySqlCdcSources.Builder
-
Optional regular expressions that match fully-qualified table identifiers for tables to be monitored; any table not included in the whitelist will be excluded from monitoring.
- setTableWhitelist(String...) - Method in class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.Builder
-
Optional regular expressions that match fully-qualified table identifiers for tables to be monitored; any table not included in the whitelist will be excluded from monitoring.
- setTailSequence(long) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
-
Sets the tail sequence.
- setTargetEndpoints(String) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the comma separated list of target cluster members, e.g.
- setTcpIpConfig(TcpIpConfig) - Method in class com.hazelcast.config.JoinConfig
- setTcpNoDelay(boolean) - Method in class com.hazelcast.client.config.SocketOptions
-
Enable/disable TCP_NODELAY socket option.
- setTenant() - Method in interface com.hazelcast.spi.tenantcontrol.TenantControl
-
Establish this tenant's thread-local context.
- setTieredStoreConfig(TieredStoreConfig) - Method in class com.hazelcast.config.MapConfig
-
Sets the
TieredStoreConfig
for thisMapConfig
- setTime(String, LocalTime) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
Sets a time field consisting of hour, minute, seconds, and nanos parts.
- setTimeout(long, TimeUnit) - Method in class com.hazelcast.transaction.TransactionOptions
-
Sets the timeout.
- setTimeoutMillis(long) - Method in class com.hazelcast.jet.config.DeltaJobConfig
- setTimeoutMillis(long) - Method in class com.hazelcast.jet.config.JobConfig
-
Sets the maximum execution time for the job in milliseconds.
- setTimeoutMillis(long) - Method in class com.hazelcast.sql.SqlStatement
-
Sets the execution timeout in milliseconds.
- setTimeoutMilliseconds(int) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
- setTimeoutMilliseconds(int) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
-
Sets the timeout in Milliseconds before declaring a failed ping This cannot be more than the interval value.
- setTimestamp(long) - Method in class com.hazelcast.jet.datamodel.TimestampedItem
-
Sets the timestamp.
- setTimestamp(String, LocalDateTime) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
Sets a timestamp field consisting of year, month of the year, and day of the month, hour, minute, seconds, nanos parts.
- setTimestampWithTimezone(String, OffsetDateTime) - Method in interface com.hazelcast.nio.serialization.genericrecord.GenericRecordBuilder
-
Sets a timestamp with timezone field consisting of year, month of the year and day of the month, offset seconds, hour, minute, seconds, nanos parts.
- setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.EventJournalConfig
-
Sets the time to live in seconds.
- setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.MapConfig
-
The maximum number of seconds for each entry to stay in the map.
- setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.NearCacheConfig
-
Returns the maximum number of seconds for each entry to stay in the Near Cache (time to live).
- setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.RingbufferConfig
-
Sets the time to live in seconds which is the maximum number of seconds for each item to stay in the ringbuffer before being removed.
- setTlsAuthenticationConfig(TlsAuthenticationConfig) - Method in class com.hazelcast.config.security.RealmConfig
- setToken(String) - Method in class com.hazelcast.config.VaultSecureStoreConfig
-
Sets the Vault access token.
- setTokenIdentityConfig(TokenIdentityConfig) - Method in class com.hazelcast.client.config.ClientSecurityConfig
- setTokenIdentityConfig(TokenIdentityConfig) - Method in class com.hazelcast.config.security.RealmConfig
- setTokenValidityDuration(Duration) - Method in class com.hazelcast.config.rest.RestConfig
-
Sets the expiration duration for jwt token.
- setTopicConfigs(Map<String, TopicConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of
ITopic
configurations, mapped by config name. - setTopicOverloadPolicy(TopicOverloadPolicy) - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
-
Sets the TopicOverloadPolicy for this reliable topic.
- setTopicOverloadPolicy(TopicOverloadPolicy) - Method in class com.hazelcast.config.ReliableTopicConfig
-
Sets the TopicOverloadPolicy for this reliable topic.
- setTotalParallelism(int) - Method in class com.hazelcast.jet.core.test.TestProcessorContext
- setTotalParallelism(int) - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
-
Sets the total parallelism.
- setTotalParallelism(int) - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
- setTpcConfig(ClientTpcConfig) - Method in class com.hazelcast.client.config.ClientConfig
-
Sets the TpcConfig
- setTpcConfig(TpcConfig) - Method in class com.hazelcast.config.Config
-
Sets the TpcConfig.
- setTpcSocketConfig(TpcSocketConfig) - Method in class com.hazelcast.config.EndpointConfig
-
Sets the TpcSocketConfig.
- setTpcSocketConfig(TpcSocketConfig) - Method in class com.hazelcast.config.NetworkConfig
-
Sets the TpcSocketConfig
- setTpcSocketConfig(TpcSocketConfig) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- setTpcSocketConfig(TpcSocketConfig) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
- setTransactionType(TransactionOptions.TransactionType) - Method in class com.hazelcast.transaction.TransactionOptions
-
Sets the
TransactionOptions.TransactionType
. - setTrustCertificate(String) - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Set the location of the trust certificate authority chain in PEM format.
- setTrustCertificatePrivateKey(String) - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Set the location of the private key for the trust certificate in PEM format.
- setTrustedInterfaces(Set<String>) - Method in class com.hazelcast.config.ManagementCenterConfig
-
Sets the trusted interfaces.
- setTrustedInterfaces(Set<String>) - Method in class com.hazelcast.config.MulticastConfig
-
Sets the trusted interfaces.
- setTrustedInterfaces(Set<String>) - Method in interface com.hazelcast.config.TrustedInterfacesConfigurable
-
Sets the trusted interfaces.
- setTrustStore(String) - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Set the trust store that holds SSL certificates.
- setTrustStorePassword(String) - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Set the password used to access the trust store.
- setTrustStoreProvider(String) - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Set the provider for the trust store.
- setTrustStoreType(String) - Method in class com.hazelcast.config.rest.RestConfig.Ssl
-
Set the type of the trust store.
- setTryCount(int) - Method in class com.hazelcast.client.config.ClientFailoverConfig
-
Sets the count that the client iterates over the given list of alternative clusters.
- setTtl(int) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
- setTtl(int) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
-
Sets the maximum number of times the IP Datagram (ping) can be forwarded, in most cases all Hazelcast cluster members would be within one network switch/router therefore
- setTtl(K, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Updates the TTL (time to live) value of the entry specified by
key
with a new TTL value. - setType(IndexType) - Method in class com.hazelcast.config.IndexConfig
-
Sets type of the index.
- setType(PermissionConfig.PermissionType) - Method in class com.hazelcast.config.PermissionConfig
- setType(String) - Method in class com.hazelcast.config.DataConnectionConfig
-
Sets the type of the
DataConnection
- setType(String) - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
-
Sets the Java KeyStore type (PKCS12, JCEKS etc.)
- setTypeClass(Class) - Method in class com.hazelcast.config.SerializerConfig
-
Sets the type of the class that will be serialized via this implementation.
- setTypeClassName(String) - Method in class com.hazelcast.config.SerializerConfig
-
This method is called only if typeClass is not set.
- setTypes(Class<K>, Class<V>) - Method in class com.hazelcast.config.AbstractCacheConfig
-
Sets the expected type of keys and values for a
Cache
configured with thisConfiguration
. - setTypes(Class<K>, Class<V>) - Method in interface com.hazelcast.config.CacheConfiguration
-
Sets the expected type of keys and values for a
Cache
configured with thisConfiguration
. - setUncommittedEntryCountToRejectNewAppends(int) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
- setUniqueKey(String) - Method in class com.hazelcast.config.BitmapIndexOptions
-
Sets unique key attribute in this index config.
- setUniqueKeyTransformation(BitmapIndexOptions.UniqueKeyTransformation) - Method in class com.hazelcast.config.BitmapIndexOptions
-
Sets unique key transformation in this index config.
- setUriString(String) - Method in class com.hazelcast.config.CacheConfig
-
Sets the URI string, which is the global identifier of the
ICache
. - setUrl(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- setUsage(LoginModuleConfig.LoginModuleUsage) - Method in class com.hazelcast.config.LoginModuleConfig
- setUseCanonicalHostname(Boolean) - Method in class com.hazelcast.config.security.KerberosIdentityConfig
-
Allows using fully qualified domain name instead of IP address when the SPN is constructed from a prefix and realm name.
- setUseDeduplication(boolean) - Method in class com.hazelcast.config.vector.VectorIndexConfig
-
Enables or disables deduplication.
- setUseEndpointPrivateAddress(boolean) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets whether the WAN connection manager should connect to the endpoint on the private address returned by the discovery SPI.
- setUseNameWithoutRealm(Boolean) - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
-
Allows cutting off the Kerberos realm part from authenticated name.
- setUseNativeByteOrder(boolean) - Method in class com.hazelcast.config.SerializationConfig
- setUsePublicIp(boolean) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
-
Decides whether the public or private IP should be used to connect to Hazelcast members.
- setUserCodeDeploymentConfig(ClientUserCodeDeploymentConfig) - Method in class com.hazelcast.client.config.ClientConfig
-
Set User Code Deployment configuration
- setUserCodeDeploymentConfig(UserCodeDeploymentConfig) - Method in class com.hazelcast.config.Config
-
Set User Code Deployment configuration
- setUserCodeNamespace(String) - Method in class com.hazelcast.config.CacheConfig
-
Associates the provided Namespace Name with this structure for
ClassLoader
awareness. - setUserCodeNamespace(String) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Associates the provided Namespace Name with this structure for
ClassLoader
awareness. - setUserCodeNamespace(String) - Method in class com.hazelcast.config.CollectionConfig
-
Associates the provided Namespace Name with this structure for
ClassLoader
awareness. - setUserCodeNamespace(String) - Method in class com.hazelcast.config.DurableExecutorConfig
-
Associates the provided Namespace Name with this structure for
ClassLoader
awareness. - setUserCodeNamespace(String) - Method in class com.hazelcast.config.ExecutorConfig
-
Associates the provided Namespace Name with this structure for
ClassLoader
awareness. - setUserCodeNamespace(String) - Method in class com.hazelcast.config.MapConfig
-
Associates the provided Namespace Name with this structure for
ClassLoader
awareness. - setUserCodeNamespace(String) - Method in class com.hazelcast.config.MultiMapConfig
-
Associates the provided Namespace Name with this structure for
ClassLoader
awareness. - setUserCodeNamespace(String) - Method in class com.hazelcast.config.QueueConfig
-
Associates the provided Namespace Name with this structure for
ClassLoader
awareness. - setUserCodeNamespace(String) - Method in class com.hazelcast.config.ReliableTopicConfig
-
Associates the provided Namespace Name with this structure for
ClassLoader
awareness. - setUserCodeNamespace(String) - Method in class com.hazelcast.config.ReplicatedMapConfig
-
Associates the provided Namespace Name with this structure for
ClassLoader
awareness. - setUserCodeNamespace(String) - Method in class com.hazelcast.config.RingbufferConfig
-
Associates the provided Namespace Name with this structure for
ClassLoader
awareness. - setUserCodeNamespace(String) - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Associates the provided Namespace Name with this structure for
ClassLoader
awareness. - setUserCodeNamespace(String) - Method in class com.hazelcast.config.TopicConfig
-
Associates the provided Namespace Name with this structure for
ClassLoader
awareness. - setUserCodeNamespace(String) - Method in interface com.hazelcast.config.UserCodeNamespaceAwareConfig
-
Associates the provided User Code Namespace Name with this structure for
ClassLoader
awareness. - setUserCodeNamespace(String) - Method in class com.hazelcast.jet.config.JobConfig
-
Sets the User Code Namespace (UCN) to use with this job.
- setUserContext(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- setUserContext(ConcurrentMap<String, Object>) - Method in class com.hazelcast.client.config.ClientConfig
- setUserContext(ConcurrentMap<String, Object>) - Method in class com.hazelcast.config.Config
-
Sets the user supplied context.
- setUserFilter(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- setUserMap(Map<String, SimpleAuthenticationConfig.UserDto>) - Method in class com.hazelcast.config.security.SimpleAuthenticationConfig
-
Replaces the users with ones from the given map.
- setUserNameAttribute(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- setUsernamePasswordIdentityConfig(UsernamePasswordIdentityConfig) - Method in class com.hazelcast.client.config.ClientSecurityConfig
- setUsernamePasswordIdentityConfig(UsernamePasswordIdentityConfig) - Method in class com.hazelcast.config.security.RealmConfig
- setUsernamePasswordIdentityConfig(String, String) - Method in class com.hazelcast.client.config.ClientSecurityConfig
- setUsernamePasswordIdentityConfig(String, String) - Method in class com.hazelcast.config.security.RealmConfig
- setUserSearchScope(LdapSearchScope) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- setValidationTimeoutSeconds(int) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Deprecated.Sets validation timeout for hot-restart process, includes validating cluster members expected to join and partition table on all cluster.
- setValidationTimeoutSeconds(int) - Method in class com.hazelcast.config.PersistenceConfig
-
Sets validation timeout for persistence restart process, includes validating cluster members expected to join and partition table on all cluster.
- setValue(E1) - Method in class com.hazelcast.jet.datamodel.Tuple2
- setValue(R) - Method in class com.hazelcast.jet.datamodel.KeyedWindowResult
-
Implements
Map.Entry
, throwsUnsupportedOperationException
. - setValue(V, long, TimeUnit) - Method in interface com.hazelcast.map.ExtendedMapEntry
-
Set the value and set the TTL to a non-default value for the IMap
- setValueClassName(String) - Method in class com.hazelcast.config.AbstractCacheConfig
- setValueCollectionType(MultiMapConfig.ValueCollectionType) - Method in class com.hazelcast.config.MultiMapConfig
-
Sets the collection type for the values of this MultiMap.
- setValueCollectionType(String) - Method in class com.hazelcast.config.MultiMapConfig
-
Sets the collection type for the values of this MultiMap.
- setValueType(Class<V>) - Method in class com.hazelcast.config.AbstractCacheConfig
- setValueType(String) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the value type for this
ICache
. - setValueWithoutChangingExpiryTime(V) - Method in interface com.hazelcast.map.ExtendedMapEntry
-
Calling this method can result with one of these two cases: When there is no previous entry, this method works same as
Map.Entry.setValue(V)
and creates entry with existing expiry settings When an entry already exists, it updates value without changing expiry time of it - setVectorCollectionConfigs(Map<String, VectorCollectionConfig>) - Method in class com.hazelcast.config.Config
-
Set the list of vector collection configurations.
- setVectorIndexConfigs(List<VectorIndexConfig>) - Method in class com.hazelcast.config.vector.VectorCollectionConfig
-
Sets the list of
VectorIndexConfig
instances for this vector collection configuration. - setVersion(Version) - Method in interface com.hazelcast.nio.VersionAware
-
If the serializer supports versioning it may set the version to use for the serialization on this object.
- setVersionIfNotSet(int) - Method in class com.hazelcast.nio.serialization.PortableId
-
Deprecated.
- setVertexName(String) - Method in class com.hazelcast.jet.core.test.TestProcessorContext
- setVertexName(String) - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
-
Sets the vertex name.
- setVertexName(String) - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
- setWanProtocolVersion(Version) - Method in interface com.hazelcast.nio.WanProtocolVersionAware
-
Sets the WAN protocol version.
- setWanReplicationConfigs(Map<String, WanReplicationConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of WAN replication configurations, mapped by config name.
- setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.CacheConfig
- setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the WAN target replication reference.
- setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.MapConfig
-
Sets the WAN target replication reference.
- setWhitelist(ClassFilter) - Method in class com.hazelcast.config.JavaSerializationFilterConfig
- setWhitelistedPrefixes(String) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Deprecated.Comma-separated list of class prefixes which will be loaded remotely.
- setWriteBatchSize(int) - Method in class com.hazelcast.config.MapStoreConfig
-
Sets the number of operations to be included in each batch processing round.
- setWriteCoalescing(boolean) - Method in class com.hazelcast.config.MapStoreConfig
-
Setting
MapStoreConfig.writeCoalescing
is meaningful if you are using write-behindMapStore
. - setWriteDelaySeconds(int) - Method in class com.hazelcast.config.MapStoreConfig
-
Sets the number of seconds to delay before writing (storing) the dirty records
- setWriteIOThreadCount(int) - Method in class com.hazelcast.config.LocalDeviceConfig
-
Sets the write IO thread count.
- setWriteThrough(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
- setWriteThrough(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
-
Set if write-through caching should be used.
- setWriteThrough(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Enables or disables write-through for this
ICache
: a write to the queue also loads the entry into the data store. - severe(String) - Method in class com.hazelcast.logging.AbstractLogger
- severe(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
- severe(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
- SHARED_JCACHE_INSTANCE_NAME - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
-
Name of default
HazelcastInstance
which may be started when obtaining the defaultCachingProvider
. - SHARED_LOCAL_FS - Static variable in class com.hazelcast.jet.hadoop.HadoopSources
-
When reading files from local file system using Hadoop, each processor reads files from its own local file system.
- sharedConsumer(boolean) - Method in class com.hazelcast.jet.pipeline.JmsSourceBuilder
-
Specifies whether the MessageConsumer of the JMS topic is shared, that is whether
createSharedConsumer()
orcreateSharedDurableConsumer()
was used to create it in theJmsSourceBuilder.consumerFn(FunctionEx)
. - sharedFileSystem(boolean) - Method in class com.hazelcast.jet.avro.AvroSourceBuilder
-
Sets whether files are in a shared storage visible to all members.
- sharedFileSystem(boolean) - Method in class com.hazelcast.jet.pipeline.file.FileSourceBuilder
-
If
sharedFileSystem
istrue
, Jet will assume all members see the same files. - sharedFileSystem(boolean) - Method in class com.hazelcast.jet.pipeline.FileSourceBuilder
-
Sets if files are in a shared storage visible to all members.
- sharedService(FunctionEx<? super ProcessorSupplier.Context, S>) - Static method in class com.hazelcast.jet.pipeline.ServiceFactories
-
A variant of
sharedService(createFn, destroyFn)
with a no-opdestroyFn
. - sharedService(FunctionEx<? super ProcessorSupplier.Context, S>, ConsumerEx<S>) - Static method in class com.hazelcast.jet.pipeline.ServiceFactories
-
Returns a
ServiceFactory
which will provide a single shared service object per cluster member. - SHORT - Enum constant in enum class com.hazelcast.config.properties.PropertyTypeConverter
-
TypeConverter
to convert an input string to an output short - SHORT - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
- SHORT_ARRAY - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
- shouldHandle(OutOfMemoryError) - Method in class com.hazelcast.core.OutOfMemoryHandler
-
Decides if the OutOfMemoryError thrown will be handled by this OutOfMemoryHandler or not.
- shouldValidateTheSchema() - Method in class com.hazelcast.config.AbstractConfigBuilder
- SHUFFLE_MEMBER_LIST - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Client shuffles the given member list to prevent all clients to connect to the same node when this property is set to true.
- shutdown() - Method in interface com.hazelcast.cluster.Cluster
-
Changes state of the cluster to the
ClusterState.PASSIVE
transactionally, then triggers the shutdown process on each node. - shutdown() - Method in interface com.hazelcast.core.HazelcastInstance
-
Shuts down this HazelcastInstance.
- shutdown() - Method in interface com.hazelcast.core.LifecycleService
-
Gracefully shuts down HazelcastInstance.
- shutdown() - Method in interface com.hazelcast.jet.JetInstance
-
Deprecated.since 5.0 Use
HazelcastInstance.shutdown()
instead. - shutdown() - Method in class com.hazelcast.logging.Log4j2Factory
- shutdown() - Method in interface com.hazelcast.logging.LoggingService
- shutdown() - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
-
Initiates an orderly shutdown in which previously submitted tasks are executed, but no new tasks will be accepted.
- shutdown() - Method in interface com.hazelcast.wan.WanConsumer
-
Callback method to shut down the WAN replication consumer.
- shutdown() - Method in interface com.hazelcast.wan.WanPublisher
-
Closes the publisher and its internal connections and shuts down other internal states.
- shutdown(HazelcastInstance) - Static method in class com.hazelcast.client.HazelcastClient
-
Shutdown the provided client and remove it from the managed list
- shutdown(TransactionOptions) - Method in interface com.hazelcast.cluster.Cluster
-
Changes state of the cluster to the
ClusterState.PASSIVE
transactionally, then triggers the shutdown process on each node. - shutdown(String) - Static method in class com.hazelcast.client.HazelcastClient
-
Shutdown the provided client and remove it from the managed list
- SHUTDOWN - Enum constant in enum class com.hazelcast.core.LifecycleEvent.LifecycleState
-
Fired when the member shut down is completed.
- SHUTDOWN - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- SHUTDOWN_TIMEOUT - Static variable in class com.hazelcast.jet.grpc.GrpcProperties
-
Time to wait for clean shutdown of a
ManagedChannel
- shutdownAll() - Static method in class com.hazelcast.client.HazelcastClient
-
Shuts down all the client HazelcastInstance created in this JVM.
- shutdownAll() - Static method in class com.hazelcast.core.Hazelcast
-
Shuts down all member
HazelcastInstance
s running on this JVM. - shutdownAll() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
-
Shuts down all running
HazelcastOSGiInstance
s on the owner bundle. - shutdownHazelcastInstance(HazelcastOSGiInstance) - Method in interface com.hazelcast.osgi.HazelcastOSGiService
-
Shuts down the given
HazelcastOSGiInstance
on the owner bundle. - SHUTDOWNHOOK_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Enable Hazelcast shutdownhook thread.
- SHUTDOWNHOOK_POLICY - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Behaviour when JVM is about to exit while Hazelcast instance is still running.
- SHUTTING_DOWN - Enum constant in enum class com.hazelcast.core.LifecycleEvent.LifecycleState
-
Fired when the member is shutting down.
- SilentException - Interface in com.hazelcast.spi.exception
-
Marker interface for exceptions.
- SimpleAuthenticationConfig - Class in com.hazelcast.config.security
-
Typed authentication configuration for
SimplePropertiesLoginModule
. - SimpleAuthenticationConfig() - Constructor for class com.hazelcast.config.security.SimpleAuthenticationConfig
- SimpleAuthenticationConfig.UserDto - Class in com.hazelcast.config.security
-
Helper immutable object representing user attributes (i.e. password and roles) in the
SimpleAuthenticationConfig
. - SimpleDiscoveryNode - Class in com.hazelcast.spi.discovery
-
Simple immutable implementation of the
DiscoveryNode
interface for convenience when implementing aDiscoveryStrategy
. - SimpleDiscoveryNode(Address) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
-
This constructor will set private and public addresses to the same value and no properties are available.
- SimpleDiscoveryNode(Address, Address) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
-
This constructor will set private and public addresses separately and no properties are available.
- SimpleDiscoveryNode(Address, Address, Map<String, String>) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
-
This constructor will set private and public addresses separately.
- SimpleDiscoveryNode(Address, Map<String, String>) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
-
This constructor will set private and public addresses to the same value.
- SimpleEvent - Class in com.hazelcast.jet.pipeline.test
-
A simple event with a timestamp and a sequence number.
- SimpleEvent(long, long) - Constructor for class com.hazelcast.jet.pipeline.test.SimpleEvent
-
Create an event with the given timestamp and sequence number
- SimplePropertyDefinition - Class in com.hazelcast.config.properties
-
Simple immutable implementation of
PropertyDefinition
for convenience of implementors. - SimplePropertyDefinition(String, boolean, TypeConverter) - Constructor for class com.hazelcast.config.properties.SimplePropertyDefinition
- SimplePropertyDefinition(String, boolean, TypeConverter, ValueValidator) - Constructor for class com.hazelcast.config.properties.SimplePropertyDefinition
- SimplePropertyDefinition(String, TypeConverter) - Constructor for class com.hazelcast.config.properties.SimplePropertyDefinition
- SimpleTokenCredentials - Class in com.hazelcast.security
-
Simple implementation of
Credentials
using a raw byte array token. - SimpleTokenCredentials() - Constructor for class com.hazelcast.security.SimpleTokenCredentials
- SimpleTokenCredentials(byte[]) - Constructor for class com.hazelcast.security.SimpleTokenCredentials
- SimulateLoadTask - Class in com.hazelcast.console
-
A simulated load test.
- SimulateLoadTask(int, int, String) - Constructor for class com.hazelcast.console.SimulateLoadTask
- SINGLE_COLUMN_AS_VALUE - Static variable in class com.hazelcast.mapstore.GenericMapLoader
-
Property key to decide on getting a single column as the value
- singleAttribute(String) - Static method in class com.hazelcast.projection.Projections
-
Returns a projection that extracts the value of the given
attributePath
. - singleton(T) - Static method in class com.hazelcast.jet.Traversers
-
Returns a traverser over the given single item.
- Sink<T> - Interface in com.hazelcast.jet.pipeline
-
A data sink in a Jet pipeline.
- SINK - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
-
Boolean flag which is true if the
Processor
sourcing the metric is a DAG sink. - sinkBuilder(String, FunctionEx<Processor.Context, ? extends C>) - Static method in class com.hazelcast.jet.pipeline.SinkBuilder
-
Returns a builder object that offers a step-by-step fluent API to build a custom
Sink
for the Pipeline API. - SinkBuilder<C,
T> - Class in com.hazelcast.jet.pipeline - SinkProcessors - Class in com.hazelcast.jet.core.processor
-
Static utility class with factories of sink processors (the terminators of the DAG data flow).
- Sinks - Class in com.hazelcast.jet.pipeline
-
Contains factory methods for various types of pipeline sinks.
- SinkStage - Interface in com.hazelcast.jet.pipeline
-
A pipeline stage that doesn't allow any downstream stages to be attached to it.
- size - Variable in class com.hazelcast.config.EvictionConfig
- size() - Method in interface com.hazelcast.cache.ICache
-
Total entry count.
- size() - Method in interface com.hazelcast.collection.BaseQueue
-
Returns the number of elements in this collection.
- size() - Method in interface com.hazelcast.jet.core.Inbox
-
Returns the number of objects in the inbox.
- size() - Method in class com.hazelcast.jet.core.test.TestInbox
-
Convenience for
inbox.queue().size()
- size() - Method in interface com.hazelcast.jet.pipeline.SourceBuilder.SourceBuffer
-
Returns the number of items the buffer holds.
- size() - Method in interface com.hazelcast.map.BaseMap
-
Returns the number of entries in this map.
- size() - Method in interface com.hazelcast.map.QueryCache
- size() - Method in interface com.hazelcast.multimap.BaseMultiMap
-
Returns the number of key-value pairs in the multimap.
- size() - Method in interface com.hazelcast.multimap.MultiMap
-
Returns the number of key-value pairs in the multimap.
- size() - Method in interface com.hazelcast.ringbuffer.ReadResultSet
-
Return the result set size.
- size() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
-
Returns number of items in the Ringbuffer.
- size() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
-
Returns number of items in the ringbuffer (meaning the number of items between the
RingbufferMergeData.getHeadSequence()
andRingbufferMergeData.getTailSequence()
). - size() - Method in interface com.hazelcast.spi.partitiongroup.MemberGroup
- size() - Method in interface com.hazelcast.transaction.TransactionalList
-
Returns the size of the list.
- size() - Method in interface com.hazelcast.transaction.TransactionalMap
-
Transactional implementation of
Map.size()
. - size() - Method in interface com.hazelcast.transaction.TransactionalMultiMap
-
Returns the number of key-value pairs in the multimap.
- size() - Method in interface com.hazelcast.transaction.TransactionalQueue
-
Returns the number of elements in this collection.
- size() - Method in interface com.hazelcast.transaction.TransactionalSet
-
Returns the size of the set.
- SIZE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- skip(long) - Method in class com.hazelcast.config.ConfigStream
- Slf4jFactory - Class in com.hazelcast.logging
- Slf4jFactory() - Constructor for class com.hazelcast.logging.Slf4jFactory
- slideBy() - Method in class com.hazelcast.jet.pipeline.SlidingWindowDefinition
-
Returns the size of the sliding step.
- sliding(long, long) - Static method in class com.hazelcast.jet.pipeline.WindowDefinition
-
Returns a sliding window definition with the given parameters.
- SlidingWindowDefinition - Class in com.hazelcast.jet.pipeline
-
Represents the definition of a sliding window.
- SlidingWindowPolicy - Class in com.hazelcast.jet.core
-
Contains parameters that define a sliding/tumbling window over which Jet will apply an aggregate function.
- slidingWinPolicy(long, long) - Static method in class com.hazelcast.jet.core.SlidingWindowPolicy
-
Returns the definition of a sliding window of length
windowSize
that slides byslideBy
. - SLOW_OPERATION_DETECTOR_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Enables or disables the
SlowOperationDetector
. - SLOW_OPERATION_DETECTOR_LOG_PURGE_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Purge interval for slow operation logs.
- SLOW_OPERATION_DETECTOR_LOG_RETENTION_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
This value defines the retention time of invocations in slow operation logs.
- SLOW_OPERATION_DETECTOR_STACK_TRACE_LOGGING_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Defines if the stacktraces of slow operations are logged in the log file.
- SLOW_OPERATION_DETECTOR_THRESHOLD_MILLIS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Defines a threshold above which a running operation in
OperationService
is considered to be slow. - SMALLINT - Enum constant in enum class com.hazelcast.sql.SqlColumnType
-
SMALLINT type, represented by
Short
- SNAPSHOT_BYTES - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
-
Tracks the total number of bytes written in the last snapshot by a particular
Vertex
. - SNAPSHOT_KEYS - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
-
Tracks the total number of keys written in the last snapshot by a particular
Vertex
. - snapshotCommitFinish(boolean) - Method in interface com.hazelcast.jet.core.Processor
-
This is the second phase of a two-phase commit.
- snapshotCommitPrepare() - Method in interface com.hazelcast.jet.core.Processor
-
Prepares the transactions for commit after the snapshot is completed.
- snapshotQueue() - Method in class com.hazelcast.jet.core.test.TestOutbox
-
Returns the queue to which snapshot is written.
- snapshotRestoreInterval() - Method in class com.hazelcast.jet.core.test.TestSupport.TestMode
-
How often the snapshot is restored. 1 means restore every snapshot, 2 every other snapshot.
- snapshottingEnabled() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
-
Returns true, if snapshots will be saved for this job.
- socket(String, int) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Convenience for
Sinks.socket(String, int, FunctionEx, Charset)
withObject.toString
as the conversion function and UTF-8 as the charset. - socket(String, int) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Convenience for
socket(host, port, charset)
with UTF-8 as the charset. - socket(String, int, FunctionEx<? super T, ? extends String>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Convenience for
Sinks.socket(String, int, FunctionEx, Charset)
with UTF-8 as the charset. - socket(String, int, FunctionEx<? super T, ? extends String>, Charset) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink that connects to the specified TCP socket and writes to it a string representation of the items it receives.
- socket(String, int, String) - Static method in class com.hazelcast.security.permission.ConnectorPermission
- socket(String, int, Charset) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Returns a source which connects to the specified socket and emits lines of text received from it.
- SOCKET_BIND_ANY - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Bind both server-socket and client-sockets to any local interface.
- SOCKET_BUFFER_DIRECT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
If the bytebuffers used in the socket should be a direct bytebuffer (
true
) or a regular bytebuffer (false
). - SOCKET_CLIENT_BIND - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Bind client socket to an interface when connecting to a remote server socket.
- SOCKET_CLIENT_BIND_ANY - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Bind client-sockets to any local interface.
- SOCKET_CLIENT_BUFFER_DIRECT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
If the bytebuffers used in the socket should be a direct bytebuffer (
true
) or a regular bytebuffer (false
). - SOCKET_CLIENT_RECEIVE_BUFFER_SIZE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Overrides receive buffer size for connections opened by clients.
- SOCKET_CLIENT_SEND_BUFFER_SIZE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Overrides send buffer size for connections opened by clients.
- SOCKET_CONNECT_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Socket connection timeout in seconds.
- SOCKET_KEEP_ALIVE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Socket set keep alive (SO_KEEPALIVE).
- SOCKET_KEEP_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Keep-Alive count: the maximum number of TCP keep-alive probes to send before giving up and closing the connection if no response is obtained from the other side.
- SOCKET_KEEP_IDLE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Keep-Alive idle time: the number of seconds of idle time before keep-alive initiates a probe.
- SOCKET_KEEP_INTERVAL - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Keep-Alive interval: the number of seconds between keep-alive probes.
- SOCKET_LINGER_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Set socket SO_LINGER option.
- SOCKET_NO_DELAY - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Socket set TCP no delay.
- SOCKET_PREFIX - Static variable in class com.hazelcast.security.permission.ConnectorPermission
- SOCKET_RECEIVE_BUFFER_SIZE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Socket receive buffer (SO_RCVBUF) size in KB.
- SOCKET_SEND_BUFFER_SIZE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Socket send buffer (SO_SNDBUF) size in KB.
- SOCKET_SERVER_BIND_ANY - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Bind server-socket to any local interface.
- SocketInterceptor - Interface in com.hazelcast.nio
-
An interface that provides the ability to intercept the creation of sockets.
- socketInterceptorConfig - Variable in class com.hazelcast.config.EndpointConfig
- SocketInterceptorConfig - Class in com.hazelcast.config
-
Contains the configuration for interceptor socket.
- SocketInterceptorConfig() - Constructor for class com.hazelcast.config.SocketInterceptorConfig
- SocketInterceptorConfig(SocketInterceptorConfig) - Constructor for class com.hazelcast.config.SocketInterceptorConfig
- SocketOptions - Class in com.hazelcast.client.config
-
TCP Socket options
- SocketOptions() - Constructor for class com.hazelcast.client.config.SocketOptions
- SocketOptions(SocketOptions) - Constructor for class com.hazelcast.client.config.SocketOptions
- sort() - Method in interface com.hazelcast.jet.pipeline.BatchStage
-
Attaches a stage that sorts the input items according to their natural order.
- sort(ComparatorEx<? super T>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
-
Attaches a stage that sorts the input items according to the supplied comparator.
- sort(Bson) - Method in class com.hazelcast.jet.mongodb.MongoSourceBuilder.Stream
-
Adds sort aggregate to this builder.
- SORTED - Enum constant in enum class com.hazelcast.config.IndexType
-
Sorted index.
- sorting(ComparatorEx<? super T>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that accumulates all input items into an
ArrayList
and sorts it with the given comparator. - sortP(Comparator<T>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for a vertex that sorts its input using a
PriorityQueue
and emits it in thecomplete
phase. - SOURCE - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
-
Boolean flag which is true if the
Processor
sourcing the metric is a DAG source. - SOURCE_ADDRESS - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
-
Source member address for items received from a distributed edge.
- SourceBuilder<C> - Class in com.hazelcast.jet.pipeline
-
Top-level class for Jet custom source builders.
- SourceBuilder.Batch<T> - Class in com.hazelcast.jet.pipeline
- SourceBuilder.FaultTolerant<B,
S> - Class in com.hazelcast.jet.pipeline -
Represents a step in building a custom source where you add a
SourceBuilder.FaultTolerant.restoreSnapshotFn(com.hazelcast.function.BiConsumerEx<? super C, ? super java.util.List<S>>)
after adding acreateSnapshotFn
. - SourceBuilder.SourceBuffer<T> - Interface in com.hazelcast.jet.pipeline
-
The buffer object that the
fillBufferFn
gets on each call. - SourceBuilder.Stream<T> - Class in com.hazelcast.jet.pipeline
- SourceBuilder.TimestampedSourceBuffer<T> - Interface in com.hazelcast.jet.pipeline
-
The buffer object that the
fillBufferFn
gets on each call. - SourceBuilder.TimestampedStream<T> - Class in com.hazelcast.jet.pipeline
- SourceProcessors - Class in com.hazelcast.jet.core.processor
-
Static utility class with factories of source processors (the DAG entry points).
- Sources - Class in com.hazelcast.jet.pipeline
-
Contains factory methods for various types of pipeline sources.
- SPECIFIC_MEMBER_PROCESSOR_META_SUPPLIER - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
- SpecificMemberPms() - Constructor for class com.hazelcast.jet.core.ProcessorMetaSupplier.SpecificMemberPms
- SpecificMemberPms(ProcessorSupplier, Address) - Constructor for class com.hazelcast.jet.core.ProcessorMetaSupplier.SpecificMemberPms
- SPI - Enum constant in enum class com.hazelcast.config.PartitionGroupConfig.MemberGroupType
-
MemberGroup implementation will be provided by the user via Discovery SPI.
- SplitBrainMergePolicy<V,
T extends MergingValue<V>, R> - Interface in com.hazelcast.spi.merge -
Policy for merging data structure values after a split-brain has been healed.
- SplitBrainMergePolicyProvider - Class in com.hazelcast.spi.merge
-
A provider for
SplitBrainMergePolicy
instances. - SplitBrainMergePolicyProvider(ClassLoader) - Constructor for class com.hazelcast.spi.merge.SplitBrainMergePolicyProvider
-
Constructs a new provider for
SplitBrainMergePolicy
classes. - SplitBrainMergeTypes - Class in com.hazelcast.spi.merge
-
Collection of interfaces which define the provided merge types for each data structure.
- SplitBrainMergeTypes() - Constructor for class com.hazelcast.spi.merge.SplitBrainMergeTypes
- SplitBrainMergeTypes.AtomicLongMergeTypes - Interface in com.hazelcast.spi.merge
-
Provided merge types of
IAtomicLong
. - SplitBrainMergeTypes.AtomicReferenceMergeTypes - Interface in com.hazelcast.spi.merge
-
Provided merge types of
IAtomicReference
. - SplitBrainMergeTypes.CacheMergeTypes<K,
V> - Interface in com.hazelcast.spi.merge -
Provided merge types of
ICache
. - SplitBrainMergeTypes.CardinalityEstimatorMergeTypes - Interface in com.hazelcast.spi.merge
-
Provided merge types of
CardinalityEstimator
. - SplitBrainMergeTypes.CollectionMergeTypes<V> - Interface in com.hazelcast.spi.merge
- SplitBrainMergeTypes.MapMergeTypes<K,
V> - Interface in com.hazelcast.spi.merge -
Provided merge types of
IMap
. - SplitBrainMergeTypes.MultiMapMergeTypes<K,
V> - Interface in com.hazelcast.spi.merge -
Provided merge types of
MultiMap
. - SplitBrainMergeTypes.QueueMergeTypes<V> - Interface in com.hazelcast.spi.merge
-
Provided merge types of
IQueue
. - SplitBrainMergeTypes.ReplicatedMapMergeTypes<K,
V> - Interface in com.hazelcast.spi.merge -
Provided merge types of
ReplicatedMap
. - SplitBrainMergeTypes.RingbufferMergeTypes - Interface in com.hazelcast.spi.merge
-
Provided merge types of
Ringbuffer
. - SplitBrainMergeTypes.ScheduledExecutorMergeTypes - Interface in com.hazelcast.spi.merge
-
Provided merge types of
IScheduledExecutorService
. - SplitBrainMergeTypes.VectorCollectionMergeTypes<K,
V extends VectorDocument<?>> - Interface in com.hazelcast.spi.merge -
Merge type of
VectorCollection
. - SplitBrainPolicyAwareConfig - Interface in com.hazelcast.config
-
Contract of data structure configuration that supports split-brain protection and merge policies.
- SplitBrainProtection - Interface in com.hazelcast.splitbrainprotection
-
SplitBrainProtection
provides access to the current status of a split brain protection. - SplitBrainProtectionConfig - Class in com.hazelcast.config
-
Configuration for cluster split brain protection, a means to protect consistency of data from network partitions.
- SplitBrainProtectionConfig() - Constructor for class com.hazelcast.config.SplitBrainProtectionConfig
- SplitBrainProtectionConfig(SplitBrainProtectionConfig) - Constructor for class com.hazelcast.config.SplitBrainProtectionConfig
- SplitBrainProtectionConfig(String) - Constructor for class com.hazelcast.config.SplitBrainProtectionConfig
- SplitBrainProtectionConfig(String, boolean) - Constructor for class com.hazelcast.config.SplitBrainProtectionConfig
- SplitBrainProtectionConfig(String, boolean, int) - Constructor for class com.hazelcast.config.SplitBrainProtectionConfig
- SplitBrainProtectionConfigBuilder - Class in com.hazelcast.config
-
Commons for split brain protection config builders.
- SplitBrainProtectionConfigBuilder() - Constructor for class com.hazelcast.config.SplitBrainProtectionConfigBuilder
- SplitBrainProtectionEvent - Class in com.hazelcast.splitbrainprotection
-
An Event that is sent when a
SplitBrainProtection
changes. - SplitBrainProtectionEvent(Object, int, Collection<Member>, boolean) - Constructor for class com.hazelcast.splitbrainprotection.SplitBrainProtectionEvent
- SplitBrainProtectionException - Exception in com.hazelcast.splitbrainprotection
-
An exception thrown when the cluster size is below the defined threshold.
- SplitBrainProtectionException(String) - Constructor for exception com.hazelcast.splitbrainprotection.SplitBrainProtectionException
- SplitBrainProtectionFunction - Interface in com.hazelcast.splitbrainprotection
-
A function that can be used to conclude whether the minimum cluster size property is satisfied?
- SplitBrainProtectionListener - Interface in com.hazelcast.splitbrainprotection
-
Listener to get notified when a split brain protection state is changed.
- SplitBrainProtectionListenerConfig - Class in com.hazelcast.config
-
Configuration class for
SplitBrainProtectionListener
- SplitBrainProtectionListenerConfig() - Constructor for class com.hazelcast.config.SplitBrainProtectionListenerConfig
- SplitBrainProtectionListenerConfig(SplitBrainProtectionListener) - Constructor for class com.hazelcast.config.SplitBrainProtectionListenerConfig
- SplitBrainProtectionListenerConfig(String) - Constructor for class com.hazelcast.config.SplitBrainProtectionListenerConfig
- SplitBrainProtectionOn - Enum Class in com.hazelcast.splitbrainprotection
-
Represents a cluster split brain protection type
- SplitBrainProtectionService - Interface in com.hazelcast.splitbrainprotection
-
Split brain protection service can be used to trigger cluster split brain protections at any time.
- SpringAware - Annotation Interface in com.hazelcast.spring.context
-
Annotates a class for injection of Spring dependencies.
- SpringHazelcastCachingProvider - Class in com.hazelcast.spring.cache
-
Spring utility class for connecting
HazelcastCachingProvider
interface and Hazelcast instance. - SpringManagedContext - Class in com.hazelcast.spring.context
-
ManagedContext
implementation for Hazelcast. - SpringManagedContext() - Constructor for class com.hazelcast.spring.context.SpringManagedContext
- SpringManagedContext(ApplicationContext) - Constructor for class com.hazelcast.spring.context.SpringManagedContext
- SpringXmlBuilder(ParserContext, BeanDefinitionBuilder) - Constructor for class com.hazelcast.spring.HazelcastClientBeanDefinitionParser.SpringXmlBuilder
- SpringXmlBuilderHelper() - Constructor for class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
- sql - Variable in class com.hazelcast.config.PredicateConfig
- sql(String) - Static method in class com.hazelcast.query.Predicates
-
Creates a predicate that will pass items that match the given SQL 'where' expression.
- SQL - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
-
Specific SQL permissions
- SQL_CUSTOM_CYCLIC_TYPES_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Enable experimental support for accessing cyclic nested fields by using custom types in SQL.
- SQL_TSTORE_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Enable experimental support for querying Tiered Storage IMaps via SQL.
- SqlColumnMetadata - Class in com.hazelcast.sql
-
SQL column metadata.
- SqlColumnMetadata(String, SqlColumnType, boolean) - Constructor for class com.hazelcast.sql.SqlColumnMetadata
- SqlColumnType - Enum Class in com.hazelcast.sql
-
SQL column type.
- SqlConfig - Class in com.hazelcast.config
-
SQL service configuration.
- SqlConfig() - Constructor for class com.hazelcast.config.SqlConfig
- SqlExpectedResultType - Enum Class in com.hazelcast.sql
-
The expected statement result type.
- SqlPermission - Class in com.hazelcast.security.permission
- SqlPermission(String, String...) - Constructor for class com.hazelcast.security.permission.SqlPermission
- SqlResult - Interface in com.hazelcast.sql
-
SQL query result.
- SqlRow - Interface in com.hazelcast.sql
-
SQL row.
- SqlRowMetadata - Class in com.hazelcast.sql
-
SQL row metadata.
- SqlRowMetadata(List<SqlColumnMetadata>) - Constructor for class com.hazelcast.sql.SqlRowMetadata
- sqlService - Variable in class com.hazelcast.mapstore.GenericMapLoader
- SqlService - Interface in com.hazelcast.sql
-
A service to execute SQL statements.
- SqlStatement - Class in com.hazelcast.sql
-
Definition of an SQL statement.
- SqlStatement(String) - Constructor for class com.hazelcast.sql.SqlStatement
- Ssl() - Constructor for class com.hazelcast.config.rest.RestConfig.Ssl
- sslConfig - Variable in class com.hazelcast.config.EndpointConfig
- SSLConfig - Class in com.hazelcast.config
-
SSL configuration.
- SSLConfig() - Constructor for class com.hazelcast.config.SSLConfig
- SSLConfig(SSLConfig) - Constructor for class com.hazelcast.config.SSLConfig
- Stage - Interface in com.hazelcast.jet.pipeline
-
The basic element of a Jet
pipeline
, represents a computation step. - StageWithKeyAndWindow<T,
K> - Interface in com.hazelcast.jet.pipeline -
Represents an intermediate step in the construction of a pipeline stage that performs a windowed group-and-aggregate operation.
- StageWithWindow<T> - Interface in com.hazelcast.jet.pipeline
-
Represents an intermediate step in the construction of a pipeline stage that performs a windowed aggregate operation.
- StaleAppendRequestException - Exception in com.hazelcast.cp.exception
-
A
CPSubsystemException
which is thrown when a Raft leader node appends an entry to its local Raft log, but demotes to the follower role before learning the commit status of the entry. - StaleAppendRequestException(RaftEndpoint) - Constructor for exception com.hazelcast.cp.exception.StaleAppendRequestException
- StaleSequenceException - Exception in com.hazelcast.ringbuffer
-
An
RuntimeException
that is thrown when accessing an item in theRingbuffer
using a sequence that is smaller than the current head sequence and that the ringbuffer store is disabled. - StaleSequenceException(String, long) - Constructor for exception com.hazelcast.ringbuffer.StaleSequenceException
-
Creates a StaleSequenceException with the given message.
- StaleSequenceException(String, long, Throwable) - Constructor for exception com.hazelcast.ringbuffer.StaleSequenceException
- StaleTaskException - Exception in com.hazelcast.scheduledexecutor
-
Exception thrown by the
IScheduledFuture
during any operation on a stale (=previously destroyed) task. - StaleTaskException(String) - Constructor for exception com.hazelcast.scheduledexecutor.StaleTaskException
- StaleTaskIdException - Exception in com.hazelcast.durableexecutor
-
An
RuntimeException
that is thrown when retrieving the result of a task viaDurableExecutorService
if the result of the task is overwritten. - StaleTaskIdException(String) - Constructor for exception com.hazelcast.durableexecutor.StaleTaskIdException
- STANDARD - Enum constant in enum class com.hazelcast.config.NativeMemoryConfig.MemoryAllocatorType
-
STANDARD memory allocator: allocate/free memory using default OS memory manager
- StandardLoggerFactory - Class in com.hazelcast.logging
- StandardLoggerFactory() - Constructor for class com.hazelcast.logging.StandardLoggerFactory
- start() - Method in class com.hazelcast.console.ConsoleApp
- start() - Method in class com.hazelcast.jet.datamodel.WindowResult
-
Returns the starting timestamp of the window.
- start() - Method in interface com.hazelcast.jet.JetService.JobBuilder
-
See
JetService.newJob(Pipeline, JobConfig)
for details. - start() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
- start() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategy
-
The
start
method is used to initialize internal state and perform any kind of startup procedure like multicast socket creation. - start() - Method in interface com.hazelcast.spi.discovery.integration.DiscoveryService
-
The
start
method is called on system startup to implement simple lifecycle management. - start() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategy
- START - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- START_FROM_CURRENT - Enum constant in enum class com.hazelcast.jet.pipeline.JournalInitialPosition
-
Skip all the history and emit only the events that occur after connecting to the journal.
- START_FROM_OLDEST - Enum constant in enum class com.hazelcast.jet.pipeline.JournalInitialPosition
-
Start from the oldest event still available.
- START_TIMESTAMP - Enum constant in enum class com.hazelcast.config.InstanceTrackingConfig.InstanceTrackingProperties
-
The timestamp of when the instance was started as returned by
System.currentTimeMillis()
. - startAtOperationTime(BsonTimestamp) - Method in class com.hazelcast.jet.mongodb.MongoSourceBuilder.Stream
-
Specifies time from which MongoDB's events will be read.
- STARTED - Enum constant in enum class com.hazelcast.core.LifecycleEvent.LifecycleState
-
Fired when the member start is completed.
- startIfAbsent() - Method in interface com.hazelcast.jet.JetService.JobBuilder
-
See
JetService.newJobIfAbsent(Pipeline, JobConfig)
for details. - STARTING - Enum constant in enum class com.hazelcast.core.LifecycleEvent.LifecycleState
-
Fired when the member is starting.
- STARTING - Enum constant in enum class com.hazelcast.jet.core.JobStatus
-
The job is in the initialization phase on a new coordinator.
- stateChanged(LifecycleEvent) - Method in interface com.hazelcast.core.LifecycleListener
-
Called when instance's state changes.
- StatefulTask<K,
V> - Interface in com.hazelcast.scheduledexecutor -
An interface to provide means for saving & loading state for
Runnable
andCallable
tasks scheduled with anIScheduledExecutorService
. - StaticCredentialsFactory - Class in com.hazelcast.config.security
-
The credentials factory implementation which just takes credentials in a constructor and provides it for every
StaticCredentialsFactory.newCredentials()
call. - StaticCredentialsFactory(Credentials) - Constructor for class com.hazelcast.config.security.StaticCredentialsFactory
- STATISTICS_ENABLED - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Deprecated.since 4.0. Use
ClientProperty.METRICS_ENABLED
("hazelcast.client.metrics.enabled"
) instead. - STATISTICS_PERIOD_SECONDS - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Deprecated.since 4.0. Use
ClientProperty.METRICS_COLLECTION_FREQUENCY
("hazelcast.client.metrics.collection.frequency"
) instead. - status() - Method in interface com.hazelcast.cp.CPGroup
-
Returns status of the CP group
- stop() - Method in class com.hazelcast.console.ConsoleApp
- STOPPED - Enum constant in enum class com.hazelcast.wan.WanPublisherState
-
State where neither new events are enqueued nor dequeued.
- store(long, T) - Method in interface com.hazelcast.ringbuffer.RingbufferStore
-
Stores one item with its corresponding sequence.
- store(Long, T) - Method in interface com.hazelcast.collection.QueueStore
-
Stores the key-value pair.
- store(K, V) - Method in interface com.hazelcast.map.MapStore
-
Stores the key-value pair.
- store(K, V) - Method in class com.hazelcast.map.MapStoreAdapter
-
Stores the key-value pair.
- store(K, V) - Method in class com.hazelcast.mapstore.GenericMapStore
- STORE_BINARY - Static variable in class com.hazelcast.config.QueueStoreConfig
-
Binary: By default, Hazelcast stores the queue items in serialized form in memory.
- STORE_BULK_LOAD - Static variable in class com.hazelcast.config.QueueStoreConfig
-
Bulk Load: When the queue is initialized, items are loaded from QueueStore in bulks.
- STORE_MEMORY_LIMIT - Static variable in class com.hazelcast.config.QueueStoreConfig
-
Memory Limit: This is the number of items after which Hazelcast will store items only to datastore.
- storeAll(long, T[]) - Method in interface com.hazelcast.ringbuffer.RingbufferStore
-
Stores multiple items.
- storeAll(Map<Long, T>) - Method in interface com.hazelcast.collection.QueueStore
-
Stores multiple entries.
- storeAll(Map<K, V>) - Method in interface com.hazelcast.map.MapStore
-
Stores multiple entries.
- storeAll(Map<K, V>) - Method in class com.hazelcast.map.MapStoreAdapter
-
Stores multiple entries.
- storeAll(Map<K, V>) - Method in class com.hazelcast.mapstore.GenericMapStore
- storeSequence(long) - Method in interface com.hazelcast.topic.ReliableMessageListener
-
Informs the ReliableMessageListener that it should store the sequence.
- stream() - Method in interface com.hazelcast.sql.SqlResult
-
Returns a stream of result rows.
- stream(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
StreamSource
for the Pipeline API. - stream(SupplierEx<? extends MongoClient>) - Static method in class com.hazelcast.jet.mongodb.MongoSources
-
Creates as builder for new stream mongo source.
- stream(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
StreamSource
for the Pipeline API. - stream(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 an unbounded stream source for a Jet pipeline.
- stream(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
StreamSource
for the Pipeline API. - stream(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
StreamSource
for the Pipeline API. - stream(String, String, String, Document, Document) - Static method in class com.hazelcast.jet.mongodb.MongoSources
-
Returns a MongoDB stream source which watches the changes on the collection.
- streamCacheP(String, PredicateEx<? super EventJournalCacheEvent<K, V>>, FunctionEx<? super EventJournalCacheEvent<K, V>, ? extends T>, JournalInitialPosition, EventTimePolicy<? super T>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
Returns a supplier of processors for
Sources.cacheJournal(String, JournalInitialPosition, FunctionEx, PredicateEx)
. - streamCacheP(String, JournalInitialPosition, EventTimePolicy<? super Map.Entry<K, V>>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
Returns a supplier of processors for
Sources.cacheJournal(String, JournalInitialPosition)
. - streamFilesP(String, Charset, String, boolean, BiFunctionEx<? super String, ? super String, ?>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
Returns a supplier of processors for
Sources.filesBuilder(java.lang.String)
. - streamFromProcessor(String, ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Returns an unbounded (event stream) source constructed directly from the given Core API processor meta-supplier.
- streamFromProcessorWithWatermarks(String, boolean, FunctionEx<EventTimePolicy<? super T>, ProcessorMetaSupplier>) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Returns an unbounded (event stream) source that will use the supplied function to create processor meta-suppliers as required by the Core API.
- StreamHashJoinBuilder<T0> - Class in com.hazelcast.jet.pipeline
-
Offers a step-by-step fluent API to build a hash-join pipeline stage.
- streamJmsQueueP(String, ProcessingGuarantee, EventTimePolicy<? super T>, SupplierEx<? extends Connection>, FunctionEx<? super Session, ? extends MessageConsumer>, FunctionEx<? super Message, ?>, FunctionEx<? super Message, ? extends T>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
Returns a supplier of processors for
Sources.jmsQueueBuilder(com.hazelcast.function.SupplierEx<? extends jakarta.jms.ConnectionFactory>)
. - streamJmsTopicP(String, boolean, ProcessingGuarantee, EventTimePolicy<? super T>, SupplierEx<? extends Connection>, FunctionEx<? super Session, ? extends MessageConsumer>, FunctionEx<? super Message, ?>, FunctionEx<? super Message, ? extends T>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
Returns a supplier of processors for
Sources.jmsTopicBuilder(com.hazelcast.function.SupplierEx<? extends jakarta.jms.ConnectionFactory>)
. - streamKafkaP(DataConnectionRef, FunctionEx<? super ConsumerRecord<K, V>, ? extends T>, EventTimePolicy<? super T>, String...) - Static method in class com.hazelcast.jet.kafka.KafkaProcessors
-
Returns a supplier of processors for
KafkaSources.kafka(DataConnectionRef, FunctionEx, String...)
. - streamKafkaP(Properties, FunctionEx<? super ConsumerRecord<K, V>, ? extends T>, EventTimePolicy<? super T>, TopicsConfig) - Static method in class com.hazelcast.jet.kafka.KafkaProcessors
-
Returns a supplier of processors for
KafkaSources.kafka(Properties, FunctionEx, TopicsConfig)
}. - streamKafkaP(Properties, FunctionEx<? super ConsumerRecord<K, V>, ? extends T>, EventTimePolicy<? super T>, String...) - Static method in class com.hazelcast.jet.kafka.KafkaProcessors
-
Returns a supplier of processors for
KafkaSources.kafka(Properties, FunctionEx, String...)
. - streamMapP(String, PredicateEx<? super EventJournalMapEvent<K, V>>, FunctionEx<? super EventJournalMapEvent<K, V>, ? extends T>, JournalInitialPosition, EventTimePolicy<? super T>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
Returns a supplier of processors for
Sources.mapJournal(String, JournalInitialPosition, FunctionEx, PredicateEx)
. - streamMapP(String, JournalInitialPosition, EventTimePolicy<? super Map.Entry<K, V>>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
Returns a supplier of processors for
Sources.mapJournal(String, JournalInitialPosition)
. - streamRemoteCacheP(String, ClientConfig, PredicateEx<? super EventJournalCacheEvent<K, V>>, FunctionEx<? super EventJournalCacheEvent<K, V>, ? extends T>, JournalInitialPosition, EventTimePolicy<? super T>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
Returns a supplier of processors for
Sources.remoteCacheJournal(String, ClientConfig, JournalInitialPosition, FunctionEx, PredicateEx)
. - streamRemoteCacheP(String, ClientConfig, JournalInitialPosition, EventTimePolicy<? super Map.Entry<K, V>>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
Returns a supplier of processors for
Sources.remoteCacheJournal(String, ClientConfig, JournalInitialPosition)
. - streamRemoteMapP(String, ClientConfig, PredicateEx<? super EventJournalMapEvent<K, V>>, FunctionEx<? super EventJournalMapEvent<K, V>, ? extends T>, JournalInitialPosition, EventTimePolicy<? super T>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
Returns a supplier of processors for
Sources.remoteMapJournal(String, ClientConfig, JournalInitialPosition, FunctionEx, PredicateEx)
. - streamRemoteMapP(String, ClientConfig, JournalInitialPosition, EventTimePolicy<? super Map.Entry<K, V>>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
Returns a supplier of processors for
Sources.remoteMapJournal(String, ClientConfig, JournalInitialPosition)
. - StreamSerializer<T> - Interface in com.hazelcast.nio.serialization
-
A base class for custom serialization.
- streamSocketP(String, int, Charset) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
Returns a supplier of processors for
Sources.socket(String, int, Charset)
. - StreamSource<T> - Interface in com.hazelcast.jet.pipeline
-
An infinite source of data for a Jet pipeline.
- StreamSourceStage<T> - Interface in com.hazelcast.jet.pipeline
-
A source stage in a distributed computation
pipeline
that will observe an unbounded amount of data (i.e., an event stream). - streamStage() - Method in interface com.hazelcast.jet.pipeline.StageWithWindow
-
Returns the pipeline stage associated with this object.
- StreamStage<T> - Interface in com.hazelcast.jet.pipeline
-
A stage in a distributed computation
pipeline
that will observe an unbounded amount of data (i.e., an event stream). - StreamStageWithKey<T,
K> - Interface in com.hazelcast.jet.pipeline -
An intermediate step while constructing a pipeline transform that involves a grouping key, such as windowed group-and-aggregate.
- STRING - Enum constant in enum class com.hazelcast.config.properties.PropertyTypeConverter
-
TypeConverter
that bypasses a string - STRING - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
- StringAndPartitionAwarePartitioningStrategy - Class in com.hazelcast.partition.strategy
- StringPartitioningStrategy - Class in com.hazelcast.partition.strategy
- StringPartitioningStrategy() - Constructor for class com.hazelcast.partition.strategy.StringPartitioningStrategy
- SUB_LIST - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- submit(Runnable) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
-
Submits a Runnable task for execution and returns a Future representing that task.
- submit(Runnable, MemberSelector, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to randomly selected members.
- submit(Runnable, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to a random member.
- submit(Runnable, T) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
-
Submits a Runnable task for execution and returns a Future representing that task.
- submit(Callable<T>) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
-
Submits a value-returning task for execution and returns a Future representing the pending results of the task.
- submit(Callable<T>, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to a randomly selected member and returns a Future representing that task.
- submit(Callable<T>, MemberSelector, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to a randomly selected member.
- submit(Callable<T>, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to a random member.
- SUBMIT_TO_ADDRESS - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- SUBMIT_TO_KEY - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- SUBMIT_TO_PARTITION - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- submitToAllMembers(Runnable, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to all the cluster members.
- submitToAllMembers(Callable<T>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to all cluster members and returns a map of Member-Future pairs representing pending completion of the task on each member.
- submitToAllMembers(Callable<T>, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to all the cluster members.
- submitToKey(K, EntryProcessor<K, V, R>) - Method in interface com.hazelcast.map.IMap
-
Applies the user defined
EntryProcessor
to the entry mapped by thekey
. - submitToKeyOwner(Runnable, Object) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
-
Submits a task to the owner of the specified key and returns a Future representing that task.
- submitToKeyOwner(Runnable, Object, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to the owner of the specified key.
- submitToKeyOwner(Callable<T>, Object) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to the owner of the specified key and returns a Future representing that task.
- submitToKeyOwner(Callable<T>, Object) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
-
Submits a task to the owner of the specified key and returns a Future representing that task.
- submitToKeyOwner(Callable<T>, Object, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to the owner of the specified key.
- submitToKeys(Set<K>, EntryProcessor<K, V, R>) - Method in interface com.hazelcast.map.IMap
- submitToMember(Runnable, Member, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to the specified member.
- submitToMember(Callable<T>, Member) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to the specified member and returns a Future representing that task.
- submitToMember(Callable<T>, Member, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to the specified member.
- submitToMembers(Runnable, MemberSelector, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to the selected members.
- submitToMembers(Runnable, Collection<Member>, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to the specified members.
- submitToMembers(Callable<T>, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to selected members and returns a map of Member-Future pairs representing pending completion of the task on each member.
- submitToMembers(Callable<T>, MemberSelector, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to the selected members.
- submitToMembers(Callable<T>, Collection<Member>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to given members and returns map of Member-Future pairs representing pending completion of the task on each member
- submitToMembers(Callable<T>, Collection<Member>, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to the specified members.
- SUBSCRIBE_TO_EVENT_JOURNAL - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- subtract(long) - Method in class com.hazelcast.jet.accumulator.LongAccumulator
-
Subtracts the supplied value from this accumulator, throwing an exception in the case of integer overflow.
- subtract(LongAccumulator) - Method in class com.hazelcast.jet.accumulator.LongAccumulator
-
Subtracts the value of the supplied accumulator from this one, throwing an exception in the case of integer overflow.
- subtractAllowingOverflow(long) - Method in class com.hazelcast.jet.accumulator.LongAccumulator
-
Subtracts the supplied value from this accumulator, allowing integer overflow.
- subtractAllowingOverflow(LongAccumulator) - Method in class com.hazelcast.jet.accumulator.LongAccumulator
-
Subtracts the value of the supplied accumulator from this one, allowing integer overflow.
- subtractAndGet(long) - Method in interface com.hazelcast.crdt.pncounter.PNCounter
-
Subtracts the given value from the current value.
- SUBTREE - Enum constant in enum class com.hazelcast.config.security.LdapSearchScope
-
Subtree of the search context.
- SUCCESS - Enum constant in enum class com.hazelcast.persistence.BackupTaskState
-
The backup task completed successfully
- SUFFICIENT - Enum constant in enum class com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
-
Sufficient
- summingDouble(ToDoubleFunctionEx<? super T>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that computes the sum of the
double
values it obtains by applyinggetDoubleValueFn
to each item. - summingLong(ToLongFunctionEx<? super T>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that computes the sum of the
long
values it obtains by applyinggetLongValueFn
to each item. - supplier - Variable in class com.hazelcast.jet.core.ProcessorMetaSupplier.SpecificMemberPms
- SupplierEx<T> - Interface in com.hazelcast.function
-
Serializable
variant ofjava.util.function.Supplier
which declares checked exception. - supplierFrom(ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.test.TestSupport
-
Wraps the provided
ProcessorMetaSupplier
with aSupplier<Processor>
that returns processors obtained from it. - supplierFrom(ProcessorMetaSupplier, ProcessorSupplier.Context) - Static method in class com.hazelcast.jet.core.test.TestSupport
-
Wraps the provided
ProcessorMetaSupplier
with aSupplier<Processor>
that returns processors obtained from it. - supplierFrom(ProcessorSupplier) - Static method in class com.hazelcast.jet.core.test.TestSupport
-
Wraps the provided
ProcessorSupplier
with aSupplier<Processor>
that returns processors obtained from it. - supplierFrom(ProcessorSupplier, ProcessorSupplier.Context) - Static method in class com.hazelcast.jet.core.test.TestSupport
-
Wraps the provided
ProcessorSupplier
with aSupplier<Processor>
that returns processors obtained from it. - supportsNativeTimestamps() - Method in interface com.hazelcast.jet.pipeline.StreamSource
-
Returns true if this source supports native timestamps.
- suspend() - Method in interface com.hazelcast.jet.Job
-
Gracefully suspends the current execution of the job.
- SUSPENDED - Enum constant in enum class com.hazelcast.jet.core.JobStatus
-
The job is suspended, and it can be manually resumed.
- SUSPENDED_EXPORTING_SNAPSHOT - Enum constant in enum class com.hazelcast.jet.core.JobStatus
-
The job is suspended and is exporting the snapshot.
- symmetricEncryptionConfig - Variable in class com.hazelcast.config.EndpointConfig
- SymmetricEncryptionConfig - Class in com.hazelcast.config
-
Deprecated.since 4.2
- SymmetricEncryptionConfig() - Constructor for class com.hazelcast.config.SymmetricEncryptionConfig
-
Deprecated.
- SYNC - Enum constant in enum class com.hazelcast.jet.cdc.Operation
-
Just like
Operation.INSERT
, but coming from the initial DB snapshot (as opposed to the change log). - SYNC - Enum constant in enum class com.hazelcast.wan.WanEventType
-
WAN sync event (carrying a piece of data for synchronization between clusters)
- SYSTEM_MEMORY - Enum constant in enum class com.hazelcast.config.PersistentMemoryMode
-
The persistent memory is onlined as system memory (aka KMEM DAX mode).
T
- table() - Method in interface com.hazelcast.jet.cdc.ChangeRecord
-
Returns the name of the table this record is part of.
- tag(int) - Static method in class com.hazelcast.jet.datamodel.Tag
-
Returns a tag object associated with the specified index.
- tag(String) - Method in class com.hazelcast.jet.core.metrics.Measurement
-
Returns the value associated with a specific tag, based on the metric description of this particular
Measurement
. - Tag<T> - Class in com.hazelcast.jet.datamodel
-
A tag object useful as a key in heterogeneous maps.
- tag0() - Static method in class com.hazelcast.jet.datamodel.Tag
-
Returns the tag constant
Tag.TAG_0
. - tag0() - Method in class com.hazelcast.jet.pipeline.AggregateBuilder
-
Returns the tag corresponding to the pipeline stage this builder was obtained from.
- tag0() - Method in class com.hazelcast.jet.pipeline.AggregateBuilder1
-
Returns the tag corresponding to the pipeline stage this builder was obtained from.
- tag0() - Method in class com.hazelcast.jet.pipeline.GroupAggregateBuilder
-
Returns the tag corresponding to the pipeline stage this builder was obtained from.
- tag0() - Method in class com.hazelcast.jet.pipeline.GroupAggregateBuilder1
-
Returns the tag corresponding to the pipeline stage this builder was obtained from.
- tag0() - Method in class com.hazelcast.jet.pipeline.WindowAggregateBuilder
-
Returns the tag corresponding to the pipeline stage this builder was obtained from.
- tag0() - Method in class com.hazelcast.jet.pipeline.WindowAggregateBuilder1
-
Returns the tag corresponding to the pipeline stage this builder was obtained from.
- tag0() - Method in class com.hazelcast.jet.pipeline.WindowGroupAggregateBuilder
-
Returns the tag corresponding to the pipeline stage this builder was obtained from.
- tag0() - Method in class com.hazelcast.jet.pipeline.WindowGroupAggregateBuilder1
-
Returns the tag corresponding to the pipeline stage this builder was obtained from.
- tag1() - Static method in class com.hazelcast.jet.datamodel.Tag
-
Returns the tag constant
Tag.TAG_1
. - tag2() - Static method in class com.hazelcast.jet.datamodel.Tag
-
Returns the tag constant
Tag.TAG_2
. - tagValueEquals(String, String) - Static method in class com.hazelcast.jet.core.metrics.MeasurementPredicates
-
Matches a
Measurement
which contains the specified tag and the tag has the specified value. - tagValueMatches(String, String) - Static method in class com.hazelcast.jet.core.metrics.MeasurementPredicates
-
Matches a
Measurement
which has this exact tag with a value matching the provided regular expression. - TAIL_SEQUENCE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- tailSequence() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
-
Returns the sequence of the tail.
- take() - Method in interface com.hazelcast.collection.BaseQueue
-
Retrieves and removes the head of this queue, waiting if necessary until an element becomes available.
- take() - Method in interface com.hazelcast.collection.IQueue
-
Retrieves and removes the head of this queue, waiting if necessary until an element becomes available.
- take() - Method in interface com.hazelcast.transaction.TransactionalQueue
-
Retrieves and removes the head of this queue, waiting if necessary until an element becomes available.
- TAKE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- takeWhile(Predicate<? super T>) - Method in interface com.hazelcast.jet.Traverser
-
Returns a traverser that will emit a prefix of the original traverser, up to the item for which the predicate fails (exclusive).
- TargetDisconnectedException - Exception in com.hazelcast.spi.exception
-
Thrown when a client invocation is failed because related target is disconnected and whether the invocation is run or not, is indeterminate
- TargetDisconnectedException(String) - Constructor for exception com.hazelcast.spi.exception.TargetDisconnectedException
- TargetDisconnectedException(String, Throwable) - Constructor for exception com.hazelcast.spi.exception.TargetDisconnectedException
- TargetNotMemberException - Exception in com.hazelcast.spi.exception
-
A
RetryableHazelcastException
that indicates operation was sent to a machine that isn't member of the cluster. - TargetNotMemberException(Object, int, String, String) - Constructor for exception com.hazelcast.spi.exception.TargetNotMemberException
- TargetNotMemberException(String) - Constructor for exception com.hazelcast.spi.exception.TargetNotMemberException
- TargetNotReplicaException - Exception in com.hazelcast.crdt
-
Exception that indicates that the receiver of a CRDT operation is not a CRDT replica.
- TargetNotReplicaException(String) - Constructor for exception com.hazelcast.crdt.TargetNotReplicaException
- TaskUtils - Class in com.hazelcast.scheduledexecutor
- TCP_JOIN_PORT_TRY_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The number of incremental ports, starting with port number defined in network configuration, that will be used to connect to a host which is defined without a port in the TCP-IP member list while a node is searching for a cluster.
- TCP_PREVIOUSLY_JOINED_MEMBER_ADDRESS_RETENTION_DURATION - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Specifies how long the address of a member that has previously joined the cluster will be retained/remembered in the TcpIpJoiner after it leaves the cluster.
- TcpIpConfig - Class in com.hazelcast.config
-
Contains the configuration for the Tcp/Ip join mechanism.
- TcpIpConfig() - Constructor for class com.hazelcast.config.TcpIpConfig
- tcpIpConfigXmlGenerator(ConfigXmlGenerator.XmlGenerator, JoinConfig) - Static method in class com.hazelcast.config.ConfigXmlGenerator
- TEMP_FILE_SUFFIX - Static variable in class com.hazelcast.jet.pipeline.FileSinkBuilder
-
A suffix added to file names until they are committed.
- Tenantable - Interface in com.hazelcast.spi.tenantcontrol
-
Interface to be implemented by classes which can be queried for requirement of a tenant context.
- TenantControl - Interface in com.hazelcast.spi.tenantcontrol
-
Hooks for multi-tenancy for application servers.
- TenantControl.Closeable - Interface in com.hazelcast.spi.tenantcontrol
-
Similar to the
Closeable
interface, except theTenantControl.Closeable.close()
method does not throw aIOException
. - TenantControlFactory - Interface in com.hazelcast.spi.tenantcontrol
-
A
TenantControlFactory
suppliesTenantControl
objects when Hazelcast service attaches the tenant control to a distributed object. - tenantUnavailable() - Method in interface com.hazelcast.spi.tenantcontrol.DestroyEventContext
-
Called to decouple Hazelcast object from the tenant
- term() - Method in record class com.hazelcast.cp.CPGroupsSnapshot.GroupInfo
-
Returns the value of the
term
record component. - terminate() - Method in interface com.hazelcast.core.LifecycleService
-
Terminate HazelcastInstance ungracefully.
- test(DiscoveryNode) - Method in interface com.hazelcast.spi.discovery.NodeFilter
-
Accepts or denies a
DiscoveryNode
based on the implemented rules. - test(T) - Method in interface com.hazelcast.function.PredicateEx
- test(T, U) - Method in interface com.hazelcast.function.BiPredicateEx
- test(T, U, V) - Method in interface com.hazelcast.jet.function.TriPredicate
-
Evaluates this predicate with the given arguments.
- TEST_CONTEXT - Static variable in class com.hazelcast.jet.core.test.TestSupport
-
A context various methods can probe to find context information about the current test.
- TEST_SOURCES_ITEMS_DISTRIBUTED_FILL_BUFFER_FN - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
- testEx(Member) - Method in interface com.hazelcast.jet.JetMemberSelector
-
Predicate to select members on which the job will run.
- testEx(T) - Method in interface com.hazelcast.function.PredicateEx
-
Exception-declaring version of
Predicate.test(T)
. - testEx(T, U) - Method in interface com.hazelcast.function.BiPredicateEx
-
Exception-declaring version of
BiPredicate.test(T, U)
. - testEx(T, U, V) - Method in interface com.hazelcast.jet.function.TriPredicate
-
Exception-declaring version of
TriPredicate.test(T, U, V)
. - TestInbox - Class in com.hazelcast.jet.core.test
-
Inbox
implementation suitable to be used in tests. - TestInbox() - Constructor for class com.hazelcast.jet.core.test.TestInbox
-
Constructs the inbox.
- TestInbox(Collection<?>) - Constructor for class com.hazelcast.jet.core.test.TestInbox
-
Convenience for
new TestInbox().queue().addAll(o)
- TestOutbox - Class in com.hazelcast.jet.core.test
-
Outbox
implementation suitable to be used in tests. - TestOutbox(int...) - Constructor for class com.hazelcast.jet.core.test.TestOutbox
- TestOutbox(int[], int) - Constructor for class com.hazelcast.jet.core.test.TestOutbox
- TestProcessorContext - Class in com.hazelcast.jet.core.test
-
Processor.Context
implementation suitable to be used in tests. - TestProcessorContext() - Constructor for class com.hazelcast.jet.core.test.TestProcessorContext
-
Constructor with default values.
- TestProcessorMetaSupplierContext - Class in com.hazelcast.jet.core.test
-
ProcessorMetaSupplier.Context
implementation suitable to be used in tests. - TestProcessorMetaSupplierContext() - Constructor for class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
- TestProcessorSupplierContext - Class in com.hazelcast.jet.core.test
-
Implementation of
ProcessorSupplier.Context
suitable to be used in tests. - TestProcessorSupplierContext() - Constructor for class com.hazelcast.jet.core.test.TestProcessorSupplierContext
- TESTS_HAVE_RUNNNERS - Static variable in class com.hazelcast.test.archunit.ArchUnitRules
- TestsHaveRunnersCondition - Class in com.hazelcast.test.archunit
-
Asserts that tests are annotated with `@RunWith` to ensure property isolation
- TestsHaveRunnersCondition() - Constructor for class com.hazelcast.test.archunit.TestsHaveRunnersCondition
- TestSources - Class in com.hazelcast.jet.pipeline.test
-
Contains factory methods for various mock sources which can be used for pipeline testing and development.
- TestSupport - Class in com.hazelcast.jet.core.test
-
A utility to test processors.
- TestSupport.TestContext - Class in com.hazelcast.jet.core.test
- TestSupport.TestEvent - Interface in com.hazelcast.jet.core.test
- TestSupport.TestMode - Class in com.hazelcast.jet.core.test
-
Describes the current test mode.
- text() - Static method in interface com.hazelcast.jet.pipeline.file.FileFormat
-
Returns a file format for text files where the whole file is a single string item.
- text(Charset) - Static method in interface com.hazelcast.jet.pipeline.file.FileFormat
-
Returns a file format for text files where the whole file is a single string item.
- TextFileFormat - Class in com.hazelcast.jet.pipeline.file
-
FileFormat
for text files where the whole file is oneString
data item. - thenComparing(ComparatorEx<? super T>) - Method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#thenComparing(Comparator)
. - thenComparing(FunctionEx<? super T, ? extends U>) - Method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#thenComparing(Function)
. - thenComparing(FunctionEx<? super T, ? extends U>, ComparatorEx<? super U>) - Method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#thenComparing(Function, Comparator)
. - thenComparing(Comparator<? super T>) - Method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#thenComparing(Comparator)
. - thenComparing(Function<? super T, ? extends U>) - Method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#thenComparing(Function)
. - thenComparing(Function<? super T, ? extends U>, Comparator<? super U>) - Method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#thenComparing(Function, Comparator)
. - thenComparingDouble(ToDoubleFunctionEx<? super T>) - Method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#thenComparingDouble(ToDoubleFunction)
. - thenComparingDouble(ToDoubleFunction<? super T>) - Method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#thenComparingDouble(ToDoubleFunction)
. - thenComparingInt(ToIntFunctionEx<? super T>) - Method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#thenComparingInt(ToIntFunction)
. - thenComparingInt(ToIntFunction<? super T>) - Method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#thenComparingInt(ToIntFunction)
. - thenComparingLong(ToLongFunctionEx<? super T>) - Method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#thenComparingLong(ToLongFunction)
. - thenComparingLong(ToLongFunction<? super T>) - Method in interface com.hazelcast.function.ComparatorEx
-
Serializable
variant ofjava.util.Comparator#thenComparingLong(ToLongFunction)
. - THIS_ATTRIBUTE_NAME - Enum constant in enum class com.hazelcast.query.QueryConstants
-
Attribute name of the "this".
- threadSafeMetric(String) - Static method in class com.hazelcast.jet.core.metrics.Metrics
-
Returns a thread-safe handler for manipulating the metric with the specified name and measurement unit.
- threadSafeMetric(String, Unit) - Static method in class com.hazelcast.jet.core.metrics.Metrics
-
Same as
Metrics.threadSafeMetric(String)
, but allows us to also specify the measurementUnit
of the metric. - THROTTLING_SLEEP_METRIC - Static variable in class com.hazelcast.jet.kinesis.KinesisSinks
-
One of the metrics exposed by the sink used to monitor the current sleep delay between consecutive sends (in milliseconds).
- THROW_EXCEPTION - Enum constant in enum class com.hazelcast.config.WanQueueFullBehavior
-
Instruct WAN replication implementation to throw an exception and doesn't allow further processing.
- THROW_EXCEPTION_ONLY_IF_REPLICATION_ACTIVE - Enum constant in enum class com.hazelcast.config.WanQueueFullBehavior
-
Similar to
WanQueueFullBehavior.THROW_EXCEPTION
but only throws exception when WAN replication is active. - TIERED_STORE_HYBRID_LOG_PAGE_SIZE_IN_MEGABYTES - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Page size for every instance of Hybrid Log on member.
- TieredStoreConfig - Class in com.hazelcast.config
-
Tiered-Store configuration.
- TieredStoreConfig() - Constructor for class com.hazelcast.config.TieredStoreConfig
- TieredStoreConfig(TieredStoreConfig) - Constructor for class com.hazelcast.config.TieredStoreConfig
- TIME - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
- TIME - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
- TIME - Enum constant in enum class com.hazelcast.sql.SqlColumnType
-
TIME type, represented by
LocalTime
- TIME_ARRAY - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
- TimedExpiryPolicyFactoryConfig() - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
- TimedExpiryPolicyFactoryConfig(CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType, CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
- TIMEOUT_DISABLED - Static variable in class com.hazelcast.sql.SqlStatement
-
Value for the timeout that is disabled, meaning there's no time limit to run a query.
- TIMEOUT_NOT_SET - Static variable in class com.hazelcast.sql.SqlStatement
-
Value for the timeout that is not set.
- timerFn(ConsumerEx<? super S>) - Method in class com.hazelcast.jet.pipeline.test.AssertionSinkBuilder
-
Sets the function that will be called periodically.
- timestamp() - Method in interface com.hazelcast.jet.cdc.ChangeRecord
-
Specifies the moment when the change event occurred in the database.
- timestamp() - Method in class com.hazelcast.jet.core.metrics.Measurement
-
Returns the timestamps associated with this
Measurement
, the moment when the value was gathered. - timestamp() - Method in class com.hazelcast.jet.core.Watermark
-
Returns the timestamp of this watermark item.
- timestamp() - Method in class com.hazelcast.jet.datamodel.TimestampedItem
-
Returns the timestamp.
- timestamp() - Method in class com.hazelcast.jet.pipeline.test.SimpleEvent
-
Timestamp of the event in milliseconds
- timestamp(long) - Method in interface com.hazelcast.auditlog.EventBuilder
-
If provided value greater than zero, then it sets the event timestamp explicitly.
- TIMESTAMP - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
- TIMESTAMP - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
- TIMESTAMP - Enum constant in enum class com.hazelcast.sql.SqlColumnType
-
TIMESTAMP type, represented by
LocalDateTime
- TIMESTAMP_ARRAY - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
- TIMESTAMP_WITH_TIME_ZONE - Enum constant in enum class com.hazelcast.sql.SqlColumnType
-
TIMESTAMP_WITH_TIME_ZONE type, represented by
OffsetDateTime
- TIMESTAMP_WITH_TIMEZONE - Enum constant in enum class com.hazelcast.nio.serialization.FieldKind
- TIMESTAMP_WITH_TIMEZONE - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
- TIMESTAMP_WITH_TIMEZONE_ARRAY - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
- TimestampedItem<T> - Class in com.hazelcast.jet.datamodel
-
Mutable wrapper around an item that adds a timestamp.
- TimestampedItem(long, T) - Constructor for class com.hazelcast.jet.datamodel.TimestampedItem
-
Creates a new timestamped item.
- timestampedStream(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 an unbounded stream source for a Jet pipeline.
- timestampFn() - Method in class com.hazelcast.jet.core.EventTimePolicy
-
Returns the function that extracts the timestamp from the event.
- TimestampKind - Enum Class in com.hazelcast.jet.core
-
Enumerates the two possible kinds of timestamp: event timestamp and frame timestamp.
- TINYINT - Enum constant in enum class com.hazelcast.sql.SqlColumnType
-
TINYINT type, represented by
Byte
- TlsAuthenticationConfig - Class in com.hazelcast.config.security
-
Typed authentication configuration for the
X509CertificateLoginModule
. - TlsAuthenticationConfig() - Constructor for class com.hazelcast.config.security.TlsAuthenticationConfig
- to(Vertex) - Method in class com.hazelcast.jet.core.Edge
-
Sets the destination vertex of this edge, with ordinal 0.
- to(Vertex, int) - Method in class com.hazelcast.jet.core.Edge
-
Sets the destination vertex and ordinal of this edge.
- toAggregator(AggregateOperation1<? super T, A, ? extends R>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Adapts this aggregate operation to be used for
IMap.aggregate(Aggregator)
calls. - toBuilder() - Method in interface com.hazelcast.vector.SearchOptions
- toByteArray() - Method in interface com.hazelcast.nio.ObjectDataOutput
- toByteArray(int) - Method in interface com.hazelcast.nio.ObjectDataOutput
- toBytes(long) - Method in enum class com.hazelcast.memory.MemoryUnit
- toCollection(SupplierEx<C>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that accumulates the items into a
Collection
. - toCollector() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation1
-
Deprecated.
- toCollector(AggregateOperation1<? super T, A, ? extends R>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Adapts this aggregate operation to a collector which can be passed to
Stream.collect(Collector)
. - toDag() - Method in interface com.hazelcast.jet.pipeline.Pipeline
-
Deprecated.since Jet 4.3, Jet performs this transformation on the server-side.
- toDotString() - Method in class com.hazelcast.jet.core.DAG
-
Returns a DOT format (graphviz) representation of the DAG.
- toDotString() - Method in interface com.hazelcast.jet.pipeline.Pipeline
-
Returns a DOT format (graphviz) representation of the Pipeline.
- toDotString(int, int) - Method in class com.hazelcast.jet.core.DAG
-
Returns a DOT format (graphviz) representation of the DAG, annotates the vertices using supplied default parallelism value, and the edges using supplied default queue size value.
- ToDoubleFunctionEx<T> - Interface in com.hazelcast.function
-
Serializable
variant ofjava.util.function.ToDoubleFunction
which declares checked exception. - toEntryProcessorFn(FunctionEx<? super E, ? extends EntryProcessor<K, V, R>>) - Method in class com.hazelcast.jet.pipeline.MapSinkEntryProcessorBuilder
- toFuture(Function<Stream<T>, R>) - Method in interface com.hazelcast.jet.Observable
-
Allows you to post-process the results of a Jet job on the client side using the standard Java
Stream API
. - toGigaBytes(long) - Method in enum class com.hazelcast.memory.MemoryUnit
- ToIntFunctionEx<T> - Interface in com.hazelcast.function
-
Serializable
variant ofjava.util.function.ToIntFunction
which declares checked exception. - toJson() - Method in interface com.hazelcast.jet.cdc.ChangeRecord
-
Returns the raw JSON string from the CDC event underlying this
ChangeRecord
. - toJson() - Method in interface com.hazelcast.jet.cdc.RecordPart
-
Returns the raw JSON string that this object wraps.
- toJson(int) - Method in class com.hazelcast.jet.core.DAG
-
Returns a JSON representation of the DAG.
- toJson(Object) - Static method in class com.hazelcast.jet.json.JsonUtil
-
Creates a JSON string for the given object.
- TokenCredentials - Interface in com.hazelcast.security
-
Credentials
type for custom authentication (token based). - TokenEncoding - Enum Class in com.hazelcast.config.security
-
Possible token encodings.
- TokenIdentityConfig - Class in com.hazelcast.config.security
-
Simple token identity configuration.
- TokenIdentityConfig(byte[]) - Constructor for class com.hazelcast.config.security.TokenIdentityConfig
- TokenIdentityConfig(TokenEncoding, String) - Constructor for class com.hazelcast.config.security.TokenIdentityConfig
- toKeyFn(FunctionEx<? super E, ? extends K>) - Method in class com.hazelcast.jet.pipeline.MapSinkEntryProcessorBuilder
- toKeyFn(FunctionEx<? super T, ? extends K>) - Method in class com.hazelcast.jet.pipeline.MapSinkBuilder
-
Set the key-extracting function.
- toKiloBytes(long) - Method in enum class com.hazelcast.memory.MemoryUnit
- toList() - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that accumulates the items into an
ArrayList
. - ToLongFunctionEx<T> - Interface in com.hazelcast.function
-
Serializable
variant ofjava.util.function.ToLongFunction
which declares checked exception. - toMap() - Method in interface com.hazelcast.jet.cdc.RecordPart
-
Presents a parsed form of the underlying JSON message as a
Map
. - toMap(FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends U>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that accumulates the items into a
HashMap
whose keys and values are the result of applying the provided mapping functions. - toMap(FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends U>, BinaryOperatorEx<U>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that accumulates the items into a
HashMap
whose keys and values are the result of applying the provided mapping functions. - toMap(FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends U>, BinaryOperatorEx<U>, SupplierEx<M>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that accumulates elements into a user-supplied
Map
instance. - toMegaBytes(long) - Method in enum class com.hazelcast.memory.MemoryUnit
- toNonCooperative() - Method in class com.hazelcast.jet.pipeline.ServiceFactory
-
Returns a copy of this
ServiceFactory
with theisCooperative
flag set tofalse
. - toObject(Class<T>) - Method in interface com.hazelcast.jet.cdc.RecordPart
-
Maps the entire element to an instance of the specified class.
- TOP_OBSERVED_WM - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
- topic(String) - Method in class com.hazelcast.jet.kafka.KafkaSinks.Builder
-
Sets the topic to write the messages to, if you write all messages to a single topic.
- TOPIC - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
-
Topic
- TopicConfig - Class in com.hazelcast.config
-
Contains the configuration for a
ITopic
. - TopicConfig() - Constructor for class com.hazelcast.config.TopicConfig
-
Creates a TopicConfig.
- TopicConfig(TopicConfig) - Constructor for class com.hazelcast.config.TopicConfig
-
Creates a
TopicConfig
by cloning another TopicConfig. - TopicConfig(String) - Constructor for class com.hazelcast.config.TopicConfig
-
Creates a TopicConfig with the given name.
- TopicConfig(String) - Constructor for class com.hazelcast.jet.kafka.TopicsConfig.TopicConfig
-
Creates new topic configuration for given topic name.
- TopicOverloadException - Exception in com.hazelcast.topic
-
A
HazelcastException
thrown when a publisher wants to write to a topic, but there is insufficient storage to deal with the event. - TopicOverloadException(String) - Constructor for exception com.hazelcast.topic.TopicOverloadException
-
Creates a TopicOverloadException.
- TopicOverloadPolicy - Enum Class in com.hazelcast.topic
-
A policy to deal with an overloaded topic; so topic where there is no place to store new messages.
- TopicPermission - Class in com.hazelcast.security.permission
- TopicPermission(String, String...) - Constructor for class com.hazelcast.security.permission.TopicPermission
- TopicsConfig - Class in com.hazelcast.jet.kafka
-
Contains the configuration for all Kafka topics that will be consumed by the Kafka source processor.
- TopicsConfig() - Constructor for class com.hazelcast.jet.kafka.TopicsConfig
- TopicsConfig.TopicConfig - Class in com.hazelcast.jet.kafka
-
Contains the configuration for a single Kafka topic.
- topN(int, ComparatorEx<? super T>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that finds the top
n
items according to the givencomparator
. - TopologyChangedException - Exception in com.hazelcast.jet.core
-
Thrown when a topology change causes a job to abort.
- TopologyChangedException() - Constructor for exception com.hazelcast.jet.core.TopologyChangedException
-
Creates the exception
- TopologyChangedException(String) - Constructor for exception com.hazelcast.jet.core.TopologyChangedException
-
Creates the exception with a message.
- TopologyChangedException(String, Throwable) - Constructor for exception com.hazelcast.jet.core.TopologyChangedException
-
Creates the exception with a message and a cause.
- toPrettyString() - Method in class com.hazelcast.memory.Capacity
-
Returns a pretty format String representation of this capacity.
- toPrettyString(long) - Static method in class com.hazelcast.memory.Capacity
-
Utility method to create a pretty format representation of given capacity in bytes.
- toPrettyString(long, MemoryUnit) - Static method in class com.hazelcast.memory.Capacity
-
Utility method to create a pretty format representation of given capacity with a specified unit.
- toRecordFn(FunctionEx<? super E, ? extends ProducerRecord<?, ?>>) - Method in class com.hazelcast.jet.kafka.KafkaSinks.Builder
-
Sets the function to convert stream items into Kafka's
ProducerRecord
. - ToResultSetFunction - Interface in com.hazelcast.jet.function
-
A function that accepts a JDBC connection to the database, the total parallelism and processor index as arguments and produces a result set.
- toSearchControlValue() - Method in enum class com.hazelcast.config.security.LdapSearchScope
- toSet() - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that accumulates the items into a
HashSet
. - toStoreValue(Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
- toString() - Method in class com.hazelcast.cache.HazelcastCachingProvider
- toString() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
- toString() - Method in class com.hazelcast.client.config.ClientCloudConfig
- toString() - Method in class com.hazelcast.client.config.ClientConfig
- toString() - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
- toString() - Method in class com.hazelcast.client.config.ClientFailoverConfig
- toString() - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
- toString() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
- toString() - Method in class com.hazelcast.client.config.ClientMetricsConfig
- toString() - Method in class com.hazelcast.client.config.ClientNetworkConfig
- toString() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
- toString() - Method in class com.hazelcast.client.config.ClientSecurityConfig
- toString() - Method in class com.hazelcast.client.config.ClientSqlConfig
- toString() - Method in class com.hazelcast.client.config.ClientTpcConfig
- toString() - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
-
Deprecated.
- toString() - Method in class com.hazelcast.client.config.ClusterRoutingConfig
- toString() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
- toString() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
- toString() - Method in class com.hazelcast.client.config.SocketOptions
- toString() - Method in class com.hazelcast.cluster.Address
- toString() - Method in class com.hazelcast.cluster.InitialMembershipEvent
- toString() - Method in class com.hazelcast.cluster.MembershipEvent
- toString() - Method in class com.hazelcast.collection.ItemEvent
- toString() - Method in class com.hazelcast.config.AbstractBaseFactoryWithPropertiesConfig
- toString() - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
- toString() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
- toString() - Method in class com.hazelcast.config.AdvancedNetworkConfig
- toString() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
- toString() - Method in class com.hazelcast.config.AttributeConfig
- toString() - Method in class com.hazelcast.config.AutoDetectionConfig
- toString() - Method in class com.hazelcast.config.BitmapIndexOptions
- toString() - Method in enum class com.hazelcast.config.BitmapIndexOptions.UniqueKeyTransformation
- toString() - Method in class com.hazelcast.config.BTreeIndexConfig
- toString() - Method in class com.hazelcast.config.CacheConfig
- toString() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
- toString() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
- toString() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
- toString() - Method in class com.hazelcast.config.CacheSimpleConfig
- toString() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
- toString() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
- toString() - Method in class com.hazelcast.config.ClassFilter
- toString() - Method in class com.hazelcast.config.Config
- toString() - Method in class com.hazelcast.config.cp.CPMapConfig
- toString() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
- toString() - Method in class com.hazelcast.config.cp.FencedLockConfig
- toString() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
- toString() - Method in class com.hazelcast.config.cp.SemaphoreConfig
- toString() - Method in class com.hazelcast.config.CredentialsFactoryConfig
- toString() - Method in class com.hazelcast.config.DataConnectionConfig
- toString() - Method in class com.hazelcast.config.DataPersistenceConfig
- toString() - Method in class com.hazelcast.config.DiscoveryConfig
- toString() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
- toString() - Method in class com.hazelcast.config.DiskTierConfig
- toString() - Method in class com.hazelcast.config.DurableExecutorConfig
- toString() - Method in class com.hazelcast.config.DynamicConfigurationConfig
- toString() - Method in class com.hazelcast.config.EncryptionAtRestConfig
- toString() - Method in class com.hazelcast.config.EntryListenerConfig
- toString() - Method in class com.hazelcast.config.EventJournalConfig
- toString() - Method in class com.hazelcast.config.EvictionConfig
- toString() - Method in class com.hazelcast.config.ExecutorConfig
- toString() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
- toString() - Method in class com.hazelcast.config.GlobalSerializerConfig
- toString() - Method in class com.hazelcast.config.HotRestartConfig
-
Deprecated.
- toString() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Deprecated.
- toString() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
- toString() - Method in class com.hazelcast.config.IndexConfig
- toString() - Method in class com.hazelcast.config.InstanceTrackingConfig
- toString() - Method in class com.hazelcast.config.InterfacesConfig
- toString() - Method in class com.hazelcast.config.ItemListenerConfig
- toString() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
- toString() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
- toString() - Method in class com.hazelcast.config.JoinConfig
- toString() - Method in class com.hazelcast.config.ListConfig
- toString() - Method in class com.hazelcast.config.ListenerConfig
- toString() - Method in class com.hazelcast.config.LocalDeviceConfig
- toString() - Method in class com.hazelcast.config.LoginModuleConfig
- toString() - Method in class com.hazelcast.config.ManagementCenterConfig
- toString() - Method in class com.hazelcast.config.MapConfig
- toString() - Method in class com.hazelcast.config.MapStoreConfig
- toString() - Method in class com.hazelcast.config.MemberAddressProviderConfig
- toString() - Method in class com.hazelcast.config.MemberGroupConfig
- toString() - Method in class com.hazelcast.config.MemcacheProtocolConfig
- toString() - Method in class com.hazelcast.config.MemoryTierConfig
- toString() - Method in class com.hazelcast.config.MergePolicyConfig
- toString() - Method in class com.hazelcast.config.MerkleTreeConfig
- toString() - Method in class com.hazelcast.config.MetricsConfig
- toString() - Method in class com.hazelcast.config.MetricsJmxConfig
- toString() - Method in class com.hazelcast.config.MetricsManagementCenterConfig
- toString() - Method in class com.hazelcast.config.MulticastConfig
- toString() - Method in class com.hazelcast.config.MultiMapConfig
- toString() - Method in class com.hazelcast.config.NativeMemoryConfig
- toString() - Method in class com.hazelcast.config.NearCacheConfig
- toString() - Method in class com.hazelcast.config.NearCachePreloaderConfig
- toString() - Method in class com.hazelcast.config.NetworkConfig
- toString() - Method in class com.hazelcast.config.PartitionGroupConfig
- toString() - Method in class com.hazelcast.config.PartitioningAttributeConfig
- toString() - Method in class com.hazelcast.config.PartitioningStrategyConfig
- toString() - Method in class com.hazelcast.config.PermissionConfig
- toString() - Method in class com.hazelcast.config.PermissionPolicyConfig
- toString() - Method in class com.hazelcast.config.PersistenceConfig
- toString() - Method in class com.hazelcast.config.PersistentMemoryConfig
- toString() - Method in class com.hazelcast.config.PersistentMemoryDirectoryConfig
- toString() - Method in class com.hazelcast.config.PredicateConfig
- toString() - Method in class com.hazelcast.config.QueryCacheConfig
- toString() - Method in class com.hazelcast.config.QueueConfig
- toString() - Method in class com.hazelcast.config.QueueStoreConfig
- toString() - Method in class com.hazelcast.config.ReliableTopicConfig
- toString() - Method in class com.hazelcast.config.ReplicatedMapConfig
- toString() - Method in class com.hazelcast.config.rest.RestConfig.Ssl
- toString() - Method in class com.hazelcast.config.rest.RestConfig
-
Returns a string representation of the RestConfig.
- toString() - Method in class com.hazelcast.config.RestApiConfig
-
Deprecated.
- toString() - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Deprecated.
- toString() - Method in class com.hazelcast.config.RingbufferConfig
- toString() - Method in class com.hazelcast.config.RingbufferStoreConfig
- toString() - Method in class com.hazelcast.config.ScheduledExecutorConfig
- toString() - Method in class com.hazelcast.config.security.CredentialsIdentityConfig
- toString() - Method in class com.hazelcast.config.security.JaasAuthenticationConfig
- toString() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
- toString() - Method in class com.hazelcast.config.security.KerberosIdentityConfig
- toString() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
- toString() - Method in enum class com.hazelcast.config.security.LdapRoleMappingMode
- toString() - Method in enum class com.hazelcast.config.security.LdapSearchScope
- toString() - Method in class com.hazelcast.config.security.RealmConfig
- toString() - Method in class com.hazelcast.config.security.SimpleAuthenticationConfig
- toString() - Method in class com.hazelcast.config.security.SimpleAuthenticationConfig.UserDto
- toString() - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
- toString() - Method in enum class com.hazelcast.config.security.TokenEncoding
- toString() - Method in class com.hazelcast.config.security.TokenIdentityConfig
- toString() - Method in class com.hazelcast.config.security.UsernamePasswordIdentityConfig
- toString() - Method in class com.hazelcast.config.SecurityConfig
- toString() - Method in class com.hazelcast.config.SerializationConfig
- toString() - Method in class com.hazelcast.config.SerializerConfig
- toString() - Method in class com.hazelcast.config.ServerSocketEndpointConfig
- toString() - Method in class com.hazelcast.config.ServiceConfig
- toString() - Method in class com.hazelcast.config.SetConfig
- toString() - Method in class com.hazelcast.config.SocketInterceptorConfig
- toString() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
- toString() - Method in class com.hazelcast.config.SqlConfig
- toString() - Method in class com.hazelcast.config.SSLConfig
- toString() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-
Deprecated.
- toString() - Method in class com.hazelcast.config.TcpIpConfig
- toString() - Method in class com.hazelcast.config.TieredStoreConfig
- toString() - Method in class com.hazelcast.config.TopicConfig
- toString() - Method in class com.hazelcast.config.tpc.TpcConfig
- toString() - Method in class com.hazelcast.config.tpc.TpcSocketConfig
- toString() - Method in class com.hazelcast.config.UserCodeNamespacesConfig
- toString() - Method in class com.hazelcast.config.VaultSecureStoreConfig
- toString() - Method in class com.hazelcast.config.vector.VectorCollectionConfig
- toString() - Method in class com.hazelcast.config.vector.VectorIndexConfig
- toString() - Method in class com.hazelcast.config.WanBatchPublisherConfig
- toString() - Method in class com.hazelcast.config.WanConsumerConfig
- toString() - Method in class com.hazelcast.config.WanCustomPublisherConfig
- toString() - Method in class com.hazelcast.config.WanReplicationConfig
- toString() - Method in class com.hazelcast.config.WanReplicationRef
- toString() - Method in class com.hazelcast.config.WanSyncConfig
- toString() - Method in class com.hazelcast.core.DistributedObjectEvent
- toString() - Method in class com.hazelcast.core.EntryEvent
- toString() - Method in class com.hazelcast.core.HazelcastJsonValue
-
Returns unaltered string that was used to create this object.
- toString() - Method in class com.hazelcast.core.LifecycleEvent
- toString() - Method in record class com.hazelcast.cp.CPGroupsSnapshot.GroupInfo
-
Returns a string representation of this record class.
- toString() - Method in class com.hazelcast.cp.CPGroupsSnapshot
- toString() - Method in class com.hazelcast.dataconnection.DataConnectionResource
- toString() - Method in class com.hazelcast.jet.accumulator.DoubleAccumulator
- toString() - Method in class com.hazelcast.jet.accumulator.LongAccumulator
- toString() - Method in class com.hazelcast.jet.accumulator.LongDoubleAccumulator
- toString() - Method in class com.hazelcast.jet.accumulator.LongLongAccumulator
- toString() - Method in class com.hazelcast.jet.accumulator.MutableReference
- toString() - Method in class com.hazelcast.jet.accumulator.PickAnyAccumulator
- toString() - Method in class com.hazelcast.jet.config.DeltaJobConfig
- toString() - Method in class com.hazelcast.jet.config.EdgeConfig
- toString() - Method in class com.hazelcast.jet.config.JetConfig
- toString() - Method in class com.hazelcast.jet.config.JobConfig
- toString() - Method in class com.hazelcast.jet.config.ResourceConfig
- toString() - Method in class com.hazelcast.jet.core.BroadcastKey
- toString() - Method in class com.hazelcast.jet.core.DAG
- toString() - Method in class com.hazelcast.jet.core.Edge
- toString() - Method in class com.hazelcast.jet.core.metrics.JobMetrics
- toString() - Method in class com.hazelcast.jet.core.metrics.Measurement
- toString() - Method in class com.hazelcast.jet.core.test.TestInbox
- toString() - Method in class com.hazelcast.jet.core.test.TestOutbox
- toString() - Method in class com.hazelcast.jet.core.test.TestSupport.TestMode
- toString() - Method in class com.hazelcast.jet.core.Vertex
- toString() - Method in class com.hazelcast.jet.core.Watermark
- toString() - Method in class com.hazelcast.jet.datamodel.ItemsByTag
- toString() - Method in class com.hazelcast.jet.datamodel.KeyedWindowResult
- toString() - Method in class com.hazelcast.jet.datamodel.Tag
- toString() - Method in class com.hazelcast.jet.datamodel.TimestampedItem
- toString() - Method in class com.hazelcast.jet.datamodel.Tuple2
- toString() - Method in class com.hazelcast.jet.datamodel.Tuple3
- toString() - Method in class com.hazelcast.jet.datamodel.Tuple4
- toString() - Method in class com.hazelcast.jet.datamodel.Tuple5
- toString() - Method in class com.hazelcast.jet.datamodel.WindowResult
- toString() - Method in class com.hazelcast.jet.JobStatusEvent
- toString() - Method in class com.hazelcast.jet.kafka.TopicsConfig.TopicConfig
- toString() - Method in class com.hazelcast.jet.kafka.TopicsConfig
- toString() - Method in class com.hazelcast.jet.pipeline.DataConnectionRef
- toString() - Method in class com.hazelcast.jet.pipeline.test.SimpleEvent
- toString() - Method in class com.hazelcast.kubernetes.RuntimeContext
- toString() - Method in class com.hazelcast.map.AbstractIMapEvent
-
Returns a String representation of this event.
- toString() - Method in class com.hazelcast.map.EventLostEvent
- toString() - Method in class com.hazelcast.map.MapEvent
- toString() - Method in class com.hazelcast.map.MapPartitionLostEvent
- toString() - Method in class com.hazelcast.memory.Capacity
- toString() - Method in class com.hazelcast.nio.serialization.PortableId
-
Deprecated.
- toString() - Method in class com.hazelcast.partition.PartitionAwareKey
- toString() - Method in class com.hazelcast.persistence.BackupTaskStatus
- toString() - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
- toString() - Method in class com.hazelcast.security.permission.AllPermissions
- toString() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
- toString() - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
- toString() - Method in class com.hazelcast.security.permission.ManagementPermission
- toString() - Method in class com.hazelcast.security.SimpleTokenCredentials
- toString() - Method in class com.hazelcast.security.UsernamePasswordCredentials
- toString() - Method in class com.hazelcast.spi.properties.HazelcastProperty
- toString() - Method in class com.hazelcast.spi.utils.PortRange
- toString() - Method in class com.hazelcast.splitbrainprotection.SplitBrainProtectionEvent
- toString() - Method in class com.hazelcast.sql.SqlColumnMetadata
- toString() - Method in enum class com.hazelcast.sql.SqlColumnType
- toString() - Method in class com.hazelcast.sql.SqlRowMetadata
- toString() - Method in class com.hazelcast.sql.SqlStatement
- toString() - Method in class com.hazelcast.transaction.TransactionOptions
- toString() - Method in record class com.hazelcast.vector.Hint
-
Returns a string representation of this record class.
- toString() - Method in class com.hazelcast.version.MemberVersion
- toString() - Method in class com.hazelcast.version.Version
- toString(int) - Method in class com.hazelcast.jet.core.DAG
-
Returns a string representation of the DAG.
- toStringFn(FunctionEx<? super T, String>) - Method in class com.hazelcast.jet.pipeline.FileSinkBuilder
-
Sets the function which converts the item to its string representation.
- total() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the total number of total operations
- totalParallelism() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
-
Returns the total number of
Processor
s that will be created across the cluster. - totalParallelism() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
- totalParallelism(int) - Method in class com.hazelcast.jet.core.test.TestSupport
-
Sets the totalParallelism for the Processor
- toTumblingByFrame() - Method in class com.hazelcast.jet.core.SlidingWindowPolicy
-
Converts this definition to one defining a tumbling window of the same length as this definition's frame.
- TOUCHED - Enum constant in enum class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
-
Expiry policy type for the
TouchedExpiryPolicy
. - toUrn() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
-
Returns the String representation of the handler.
- toValueFn(FunctionEx<? super T, ? extends V>) - Method in class com.hazelcast.jet.pipeline.MapSinkBuilder
-
Set the function to extract a value from the incoming items.
- TpcConfig - Class in com.hazelcast.config.tpc
-
Hazelcast TPC is the next generation of Hazelcast built with thread per core architecture.
- TpcConfig() - Constructor for class com.hazelcast.config.tpc.TpcConfig
- TpcSocketConfig - Class in com.hazelcast.config.tpc
-
Socket configuration for TPC.
- TpcSocketConfig() - Constructor for class com.hazelcast.config.tpc.TpcSocketConfig
- TRANSACTION - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
-
Transaction
- TransactionalList<E> - Interface in com.hazelcast.transaction
-
Transactional implementation of
IList
. - TransactionalMap<K,
V> - Interface in com.hazelcast.transaction -
Transactional implementation of
BaseMap
. - TransactionalMultiMap<K,
V> - Interface in com.hazelcast.transaction -
Transactional implementation of
BaseMultiMap
. - TransactionalObject - Interface in com.hazelcast.transaction
-
Marker interface for all transactional distributed objects.
- TransactionalQueue<E> - Interface in com.hazelcast.transaction
-
Transactional implementation of
BaseQueue
. - TransactionalSet<E> - Interface in com.hazelcast.transaction
-
Transactional implementation of
ISet
. - TransactionalTask<T> - Interface in com.hazelcast.transaction
-
Contains the logic that is going to be executed within a transaction.
- TransactionalTaskContext - Interface in com.hazelcast.transaction
-
Provides a context to access transactional data-structures, like the
TransactionalMap
. - TransactionContext - Interface in com.hazelcast.transaction
-
Provides a context to perform transactional operations: beginning/committing transactions, but also retrieving transactional data-structures like the
TransactionalMap
. - TransactionException - Exception in com.hazelcast.transaction
-
A
HazelcastException
that is thrown when something goes wrong while dealing with transactions and transactional data-structures. - TransactionException() - Constructor for exception com.hazelcast.transaction.TransactionException
- TransactionException(String) - Constructor for exception com.hazelcast.transaction.TransactionException
- TransactionException(String, Throwable) - Constructor for exception com.hazelcast.transaction.TransactionException
- TransactionException(Throwable) - Constructor for exception com.hazelcast.transaction.TransactionException
- TransactionManagerService - Interface in com.hazelcast.transaction
- TransactionNotActiveException - Exception in com.hazelcast.transaction
-
A
HazelcastException
thrown when a transactional operation is executed without an active transaction. - TransactionNotActiveException() - Constructor for exception com.hazelcast.transaction.TransactionNotActiveException
- TransactionNotActiveException(String) - Constructor for exception com.hazelcast.transaction.TransactionNotActiveException
- transactionOptions(SupplierEx<TransactionOptions>) - Method in class com.hazelcast.jet.mongodb.MongoSinkBuilder
-
Sets options which will be used by MongoDB transaction mechanism.
- TransactionOptions - Class in com.hazelcast.transaction
-
Contains the configuration for a Hazelcast transaction.
- TransactionOptions() - Constructor for class com.hazelcast.transaction.TransactionOptions
-
Creates a new default configured TransactionsOptions.
- TransactionOptions.TransactionType - Enum Class in com.hazelcast.transaction
-
The type of transaction.
- TransactionPermission - Class in com.hazelcast.security.permission
- TransactionPermission() - Constructor for class com.hazelcast.security.permission.TransactionPermission
- TransactionTimedOutException - Exception in com.hazelcast.transaction
-
Thrown when a transaction has timed out.
- TransactionTimedOutException() - Constructor for exception com.hazelcast.transaction.TransactionTimedOutException
- TransactionTimedOutException(String) - Constructor for exception com.hazelcast.transaction.TransactionTimedOutException
- TransactionTimedOutException(String, Throwable) - Constructor for exception com.hazelcast.transaction.TransactionTimedOutException
- TransactionTimedOutException(Throwable) - Constructor for exception com.hazelcast.transaction.TransactionTimedOutException
- transform(I) - Method in interface com.hazelcast.projection.Projection
-
Transforms the input object into the output object.
- traverseArray(T[]) - Static method in class com.hazelcast.jet.Traversers
-
Returns a traverser over the given array.
- traverseEnumeration(Enumeration<T>) - Static method in class com.hazelcast.jet.Traversers
-
Returns an adapter from
Enumeration
toTraverser
. - traverseItems(T...) - Static method in class com.hazelcast.jet.Traversers
-
Returns a traverser over the supplied arguments (or item array).
- traverseIterable(Iterable<? extends T>) - Static method in class com.hazelcast.jet.Traversers
-
Returns a traverser over the given iterable.
- traverseIterator(Iterator<? extends T>) - Static method in class com.hazelcast.jet.Traversers
-
Returns an adapter from
Iterator
toTraverser
. - traverseIterator(Iterator<? extends T>, boolean) - Static method in class com.hazelcast.jet.Traversers
-
Returns an adapter from
Iterator
toTraverser
. - Traverser<T> - Interface in com.hazelcast.jet
-
Traverses a potentially infinite sequence of non-
null
items. - Traversers - Class in com.hazelcast.jet
- traverseSpliterator(Spliterator<T>) - Static method in class com.hazelcast.jet.Traversers
-
Returns an adapter from
Spliterator
toTraverser
. - traverseStream(Stream<T>) - Static method in class com.hazelcast.jet.Traversers
-
Returns a traverser over the given stream.
- TriFunction<T0,
T1, T2, R> - Interface in com.hazelcast.jet.function -
Represents a three-arity function that accepts three arguments and produces a result.
- TriPredicate<T,
U, V> - Interface in com.hazelcast.jet.function -
Represents a predicate which accepts three arguments.
- TrustedInterfacesConfigurable<T extends TrustedInterfacesConfigurable<?>> - Interface in com.hazelcast.config
-
Interface defining methods used to configure trusted interfaces (source IP addresses).
- TRY_LOCK - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- TRY_PUT - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- TRY_REMOVE - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- tryAcquire() - Method in interface com.hazelcast.cp.ISemaphore
-
Acquires a permit if one is available, and returns
true
immediately. - tryAcquire(int) - Method in interface com.hazelcast.cp.ISemaphore
-
Acquires the given number of permits if they are available, and returns
true
immediately. - tryAcquire(int, long, TimeUnit) - Method in interface com.hazelcast.cp.ISemaphore
-
Acquires the given number of permits and returns
true
, if they become available during the given waiting time. - tryAcquire(long, TimeUnit) - Method in interface com.hazelcast.cp.ISemaphore
-
Acquires a permit and returns
true
, if one becomes available during the given waiting time and the current thread has not been interrupted. - tryCloseConnections(HazelcastInstance) - Method in class com.hazelcast.core.OutOfMemoryHandler
-
Tries to close the server socket and connections to other
HazelcastInstance
s. - tryEmit(int[], Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Offers the item to the outbox buckets identified in the supplied array.
- tryEmit(int, Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Offers the item to the outbox bucket at the supplied ordinal.
- tryEmit(Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Offers the item to all the outbox buckets (except the snapshot outbox).
- tryEmitToSnapshot(Object, Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Offers one key-value pair to the snapshot bucket.
- tryLock() - Method in interface com.hazelcast.cp.lock.FencedLock
-
Acquires the lock if it is available or already held by the current thread at the time of invocation & the acquire limit is not exceeded, and immediately returns with the value
true
. - tryLock(long, TimeUnit) - Method in interface com.hazelcast.cp.lock.FencedLock
-
Acquires the lock if it is free within the given waiting time, or already held by the current thread.
- tryLock(K) - Method in interface com.hazelcast.map.IMap
-
Tries to acquire the lock for the specified key.
- tryLock(K) - Method in interface com.hazelcast.multimap.MultiMap
-
Tries to acquire the lock for the specified key.
- tryLock(K, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Tries to acquire the lock for the specified key.
- tryLock(K, long, TimeUnit) - Method in interface com.hazelcast.multimap.MultiMap
-
Tries to acquire the lock for the specified key.
- tryLock(K, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Tries to acquire the lock for the specified key for the specified lease time.
- tryLock(K, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.multimap.MultiMap
-
Tries to acquire the lock for the specified key for the specified lease time.
- tryLockAndGetFence() - Method in interface com.hazelcast.cp.lock.FencedLock
-
Acquires the lock only if it is free or already held by the current thread at the time of invocation & the acquire limit is not exceeded, and returns the fencing token assigned to the current thread for this lock acquire.
- tryLockAndGetFence(long, TimeUnit) - Method in interface com.hazelcast.cp.lock.FencedLock
-
Acquires the lock if it is free within the given waiting time, or already held by the current thread at the time of invocation & the acquire limit is not exceeded, and returns the fencing token assigned to the current thread for this lock acquire.
- tryProcess() - Method in interface com.hazelcast.jet.core.Processor
-
This method will be called periodically and only when the current batch of items in the inbox has been exhausted.
- tryProcess(int, Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Tries to process the supplied input item, which was received from the edge with the supplied ordinal.
- tryProcess(T) - Method in class com.hazelcast.jet.core.AbstractProcessor.FlatMapper
-
Method designed to be called from one of
AbstractProcessor#tryProcessX()
methods. - tryProcess0(Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Tries to process the supplied input item, which was received from the edge with ordinal 0.
- tryProcess1(Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Tries to process the supplied input item, which was received from the edge with ordinal 1.
- tryProcess2(Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Tries to process the supplied input item, which was received from the edge with ordinal 2.
- tryProcess3(Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Tries to process the supplied input item, which was received from the edge with ordinal 3.
- tryProcess4(Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Tries to process the supplied input item, which was received from the edge with ordinal 4.
- tryProcessWatermark(int, Watermark) - Method in interface com.hazelcast.jet.core.Processor
-
Tries to process the supplied watermark.
- tryProcessWatermark(Watermark) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
This basic implementation only forwards the passed watermark.
- tryProcessWatermark(Watermark) - Method in interface com.hazelcast.jet.core.Processor
-
Tries to process the supplied watermark.
- tryPut(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Tries to put the given key and value into this map within a specified timeout value.
- tryRecover() - Method in interface com.hazelcast.map.QueryCache
-
This method can be used to recover from a possible event loss situation.
- tryRemove(K, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Tries to remove the entry with the given key from this map within the specified timeout value.
- trySetCount(int) - Method in interface com.hazelcast.cp.ICountDownLatch
-
Sets the count to the given value if the current count is zero.
- tryShutdown(HazelcastInstance) - Method in class com.hazelcast.core.OutOfMemoryHandler
-
Tries to shut down
HazelcastInstance
forcefully; including closing sockets and connections, stopping threads, etc. - tumbling(long) - Static method in class com.hazelcast.jet.pipeline.WindowDefinition
-
Returns a tumbling window definition with the given parameters.
- tumblingWinPolicy(long) - Static method in class com.hazelcast.jet.core.SlidingWindowPolicy
-
Returns the definition of a tumbling window of length
windowSize
. - tuple2(E0, E1) - Static method in class com.hazelcast.jet.datamodel.Tuple2
-
Returns a new 2-tuple with the supplied values.
- Tuple2<E0,
E1> - Class in com.hazelcast.jet.datamodel -
An immutable 2-tuple (pair) of statically typed fields.
- tuple3(E0, E1, E2) - Static method in class com.hazelcast.jet.datamodel.Tuple3
-
Returns a new 3-tuple with the supplied values.
- Tuple3<E0,
E1, E2> - Class in com.hazelcast.jet.datamodel -
An immutable 3-tuple (triple) of statically typed fields.
- tuple4(E0, E1, E2, E3) - Static method in class com.hazelcast.jet.datamodel.Tuple4
-
Returns a new 5-tuple with the supplied values.
- Tuple4<E0,
E1, E2, E3> - Class in com.hazelcast.jet.datamodel -
An immutable 4-tuple of statically typed fields.
- tuple5(E0, E1, E2, E3, E4) - Static method in class com.hazelcast.jet.datamodel.Tuple5
-
Returns a new 5-tuple with the supplied values.
- Tuple5<E0,
E1, E2, E3, E4> - Class in com.hazelcast.jet.datamodel -
An immutable 5-tuple of statically typed fields.
- TWO_PHASE - Enum constant in enum class com.hazelcast.transaction.TransactionOptions.TransactionType
-
The two phase commit is separated in 2 parts.
- type() - Method in interface com.hazelcast.dataconnection.DataConnectionRegistration
-
Mapping Type of registered data connection.
- type() - Method in class com.hazelcast.dataconnection.DataConnectionResource
-
Type of the resource, e.g.
- TYPE_NAME_PROPERTY - Static variable in class com.hazelcast.mapstore.GenericMapLoader
-
Property key to data connection type name
- typeConverter() - Method in interface com.hazelcast.config.properties.PropertyDefinition
-
The
TypeConverter
to be used to convert the string value read from XML to the expected type automatically. - typeConverter() - Method in class com.hazelcast.config.properties.SimplePropertyDefinition
- TypeConverter - Interface in com.hazelcast.core
-
Implementations of this interface define a certain type conversion.
- TypedByteArrayDeserializer<T> - Interface in com.hazelcast.nio.serialization
-
This interface allows deserialization of a binary data with a provided class type.
- TypedDataSerializable - Interface in com.hazelcast.nio.serialization
-
This interface adds the possibility for the class to act as if it is another class when being deserialized using DataSerializable
- TypedStreamDeserializer<T> - Interface in com.hazelcast.nio.serialization
-
This interface allows deserialization of a binary data with a provided class type.
- typeId() - Method in interface com.hazelcast.auditlog.AuditableEvent
U
- unaryService(SupplierEx<? extends ManagedChannelBuilder<?>>, FunctionEx<? super ManagedChannel, ? extends BiConsumerEx<T, StreamObserver<R>>>) - Static method in class com.hazelcast.jet.grpc.GrpcServices
-
Creates a
ServiceFactory
that calls out to a unary gRPC service. - unblock() - Method in class com.hazelcast.jet.core.test.TestOutbox
- unchecked(FunctionEx<V, R>) - Static method in interface com.hazelcast.function.FunctionEx
-
Enforces that the return type is FunctionEx, to be used to wrap some expressions without casting.
- UndefinedErrorCodeException - Exception in com.hazelcast.client
-
This exception is thrown when an exception that is coming from server is not recognized by the protocol and it can not be constructed by the client via reflection.
- UndefinedErrorCodeException(String, String, Throwable) - Constructor for exception com.hazelcast.client.UndefinedErrorCodeException
- unicast() - Method in class com.hazelcast.jet.core.Edge
-
Chooses the
UNICAST
routing policy for this edge. - UNICAST - Enum constant in enum class com.hazelcast.jet.core.Edge.RoutingPolicy
-
This policy chooses for each item a single destination processor from the candidate set, with no restriction on the choice.
- unit() - Method in interface com.hazelcast.jet.core.metrics.Metric
-
Return the measurement unit for the associated metric.
- Unit - Enum Class in com.hazelcast.jet.core.metrics
-
Measurement unit of user-defined metrics (see
Metric
). - UNIT - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
-
Unit of metric value, for details see
ProbeUnit
. - UNKNOWN - Enum constant in enum class com.hazelcast.spi.discovery.DiscoveryStrategyFactory.DiscoveryStrategyLevel
-
Level unknown, lowest priority.
- UNKNOWN - Static variable in class com.hazelcast.version.MemberVersion
-
UNKNOWN version.
- UNKNOWN - Static variable in class com.hazelcast.version.Version
-
Version 0.0 is UNKNOWN constant
UNKNOWN
is only equal to itself.is(Less|Greater)Than
method with anUNKNOWN
operand returns false.is(Less|Greater)OrEqual
with anUNKNOWN
operand returns false, unless both operands areUNKNOWN
.UNKNOWN.isUnknown(Less|Greater)(Than|OrEqual)
returns true.otherVersion.isUnknown(Less|Greater)(Than|OrEqual)
with anUNKNOWN
argument returns false. - UNKNOWN_VERSION - Static variable in class com.hazelcast.version.Version
-
Use 0 as major & minor values for UNKNOWN version
- unlock() - Method in interface com.hazelcast.cp.lock.FencedLock
-
Releases the lock if the lock is currently held by the current thread.
- unlock(K) - Method in interface com.hazelcast.map.IMap
-
Releases the lock for the specified key.
- unlock(K) - Method in interface com.hazelcast.multimap.MultiMap
-
Releases the lock for the specified key.
- UNLOCK - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- unregisterObject() - Method in interface com.hazelcast.spi.tenantcontrol.TenantControl
-
Invoked when the distributed object belonging to this tenant control has been destroyed.
- UNSPECIFIED - Enum constant in enum class com.hazelcast.jet.cdc.Operation
-
ChangeRecord
doesn't have an operation field, for example heartbeats. - UnsupportedClusterVersionException - Exception in com.hazelcast.client
-
An UnsupportedClusterVersionException is thrown when a Hazelcast Client attempts to connect to a cluster with a configuration that is not supported by the cluster version.
- UnsupportedClusterVersionException(String) - Constructor for exception com.hazelcast.client.UnsupportedClusterVersionException
-
Creates an UnsupportedClusterVersionException with the given message.
- UnsupportedRoutingModeException - Exception in com.hazelcast.client
-
An UnsupportedRoutingModeException is thrown when a Hazelcast Client is configured with a
RoutingMode
that is not supported by the cluster. - UnsupportedRoutingModeException(String) - Constructor for exception com.hazelcast.client.UnsupportedRoutingModeException
-
Creates an UnsupportedRoutingModeException with the given message.
- UPDATE - Enum constant in enum class com.hazelcast.jet.cdc.Operation
-
Record update, sourced from the DB changelog.
- UPDATE_COUNT - Enum constant in enum class com.hazelcast.sql.SqlExpectedResultType
-
The statement must produce an update count.
- UPDATE_ONLY - Enum constant in enum class com.hazelcast.jet.mongodb.WriteMode
-
Performs update.
- updateConfig(DeltaJobConfig) - Method in interface com.hazelcast.jet.Job
-
Applies the specified delta configuration to a
suspended
job and returns the updated configuration. - updateCount() - Method in interface com.hazelcast.sql.SqlResult
-
Returns the number of rows updated by the statement or -1 if this result is a row set.
- UPDATED - Enum constant in enum class com.hazelcast.cache.CacheEventType
-
An event type indicating that the cache entry was updated, i.e. a previous mapping existed.
- UPDATED - Enum constant in enum class com.hazelcast.core.EntryEventType
-
Fired if an entry is updated.
- updateFn(BiFunctionEx<? super V, ? super T, ? extends V>) - Method in class com.hazelcast.jet.pipeline.MapSinkBuilder
-
Set the function to update the value in Hazelcast IMap.
- updateMapP(int, String, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends EntryProcessor<K, V, R>>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for
Sinks.mapWithEntryProcessor(int, String, FunctionEx, FunctionEx)
. - updateMapP(MapSinkConfiguration<T, K, V>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
- updateMapP(String, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super V, ? super T, ? extends V>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for
Sinks.mapWithEntryProcessor(String, FunctionEx, FunctionEx)
. - updateMapP(String, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends EntryProcessor<K, V, R>>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for
Sinks.mapWithEntryProcessor(String, FunctionEx, FunctionEx)
. - updateMetaSupplier(UnaryOperator<ProcessorMetaSupplier>) - Method in class com.hazelcast.jet.core.Vertex
-
Applies the provided operator function to the current processor meta-supplier and replaces it with the one it returns.
- updateQuery(String) - Method in class com.hazelcast.jet.pipeline.JdbcSinkBuilder
-
The query to execute for each item.
- updateRemoteMapP(String, ClientConfig, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super V, ? super T, ? extends V>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for
Sinks.remoteMapWithUpdating(String, ClientConfig, FunctionEx, BiFunctionEx)
. - updateRemoteMapP(String, ClientConfig, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends EntryProcessor<K, V, R>>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for
Sinks.remoteMapWithEntryProcessor(String, ClientConfig, FunctionEx, FunctionEx)
. - UPSERT - Enum constant in enum class com.hazelcast.jet.mongodb.WriteMode
-
Performs update.
- UrlXmlConfig - Class in com.hazelcast.config
-
A
Config
which is loaded using some url pointing to a Hazelcast XML file. - UrlXmlConfig(String) - Constructor for class com.hazelcast.config.UrlXmlConfig
-
Creates new Config which is loaded from the given url and uses the System.properties to replace variables in the XML.
- UrlXmlConfig(String, Properties) - Constructor for class com.hazelcast.config.UrlXmlConfig
-
Creates new Config which is loaded from the given url.
- UrlXmlConfig(URL) - Constructor for class com.hazelcast.config.UrlXmlConfig
-
Creates new Config which is loaded from the given url and uses the System.properties to replace variables in the XML.
- UrlXmlConfig(URL, Properties) - Constructor for class com.hazelcast.config.UrlXmlConfig
-
Creates new Config which is loaded from the given url.
- UrlYamlConfig - Class in com.hazelcast.config
-
A
Config
which is loaded using some url pointing to a Hazelcast YAML file. - UrlYamlConfig(String) - Constructor for class com.hazelcast.config.UrlYamlConfig
-
Creates new Config which is loaded from the given url and uses the System.properties to replace variables in the YAML.
- UrlYamlConfig(String, Properties) - Constructor for class com.hazelcast.config.UrlYamlConfig
-
Creates new Config which is loaded from the given url.
- UrlYamlConfig(URL) - Constructor for class com.hazelcast.config.UrlYamlConfig
-
Creates new Config which is loaded from the given url and uses the System.properties to replace variables in the YAML.
- UrlYamlConfig(URL, Properties) - Constructor for class com.hazelcast.config.UrlYamlConfig
-
Creates new Config which is loaded from the given url.
- USE_NODE_NAME_AS_EXTERNAL_ADDRESS - Static variable in class com.hazelcast.kubernetes.KubernetesProperties
-
Configuration key:
use-node-name-as-external-address
- USED_HEAP_PERCENTAGE - Enum constant in enum class com.hazelcast.config.MaxSizePolicy
-
Policy based on maximum used JVM heap memory percentage per data structure (map, cache etc.) on each Hazelcast instance
- USED_HEAP_SIZE - Enum constant in enum class com.hazelcast.config.MaxSizePolicy
-
Policy based on maximum used JVM heap memory in megabytes per data structure (map, cache etc.) on each Hazelcast instance
- USED_NATIVE_MEMORY_PERCENTAGE - Enum constant in enum class com.hazelcast.config.MaxSizePolicy
-
Policy based on maximum used native memory percentage per data structure (map, cache etc.) on each Hazelcast instance
- USED_NATIVE_MEMORY_SIZE - Enum constant in enum class com.hazelcast.config.MaxSizePolicy
-
Policy based on maximum used native memory in megabytes per data structure (map, cache etc.) on each Hazelcast instance
- useHadoopForLocalFiles(boolean) - Method in class com.hazelcast.jet.pipeline.file.FileSourceBuilder
-
Specifies that Jet should use Apache Hadoop for files from the local filesystem.
- USER - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
-
Boolean flag which is true if the metric is user-defined (as opposed to built-in).
- USER_CODE_DEPLOYMENT - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
-
User code deployment
- USER_CODE_NAMESPACE - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
-
User Code Namespace permissions
- UserCodeDeploymentConfig - Class in com.hazelcast.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
- UserCodeDeploymentConfig() - Constructor for class com.hazelcast.config.UserCodeDeploymentConfig
-
Deprecated.
- UserCodeDeploymentConfig.ClassCacheMode - Enum Class in com.hazelcast.config
-
Deprecated.Controls caching of classes loaded from remote members
- UserCodeDeploymentConfig.ProviderMode - Enum Class in com.hazelcast.config
-
Deprecated.Controls how to react to receiving a classloading request from a remote member
- UserCodeDeploymentPermission - Class in com.hazelcast.security.permission
-
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
- UserCodeDeploymentPermission(String...) - Constructor for class com.hazelcast.security.permission.UserCodeDeploymentPermission
-
Deprecated.
- UserCodeNamespaceAwareConfig<T> - Interface in com.hazelcast.config
-
An interface to mark implementing configs as "Namespace aware", meaning they should support the definition of a
User Code Namespace
string which represents the User Code Namespace to associate with all operations pertaining to this config. - UserCodeNamespaceConfig - Class in com.hazelcast.config
-
Contains the configuration for a specific User Code Namespace, defining its identifier (name) as well as the definitions for resources it provides.
- UserCodeNamespaceConfig() - Constructor for class com.hazelcast.config.UserCodeNamespaceConfig
- UserCodeNamespaceConfig(UserCodeNamespaceConfig) - Constructor for class com.hazelcast.config.UserCodeNamespaceConfig
- UserCodeNamespaceConfig(String) - Constructor for class com.hazelcast.config.UserCodeNamespaceConfig
- UserCodeNamespaceConfig(String, Map<String, ResourceDefinition>) - Constructor for class com.hazelcast.config.UserCodeNamespaceConfig
- UserCodeNamespacePermission - Class in com.hazelcast.security.permission
- UserCodeNamespacePermission(String, String...) - Constructor for class com.hazelcast.security.permission.UserCodeNamespacePermission
- userCodeNamespacesConfig - Variable in class com.hazelcast.config.Config
- UserCodeNamespacesConfig - Class in com.hazelcast.config
-
Serves as the configuration container for all aspects of Namespaces, used in User Code Deployment.
- UserCodeNamespacesConfig() - Constructor for class com.hazelcast.config.UserCodeNamespacesConfig
- UserCodeNamespacesConfig(boolean, Map<String, UserCodeNamespaceConfig>) - Constructor for class com.hazelcast.config.UserCodeNamespacesConfig
- UserCodeNamespacesConfig(UserCodeNamespacesConfig) - Constructor for class com.hazelcast.config.UserCodeNamespacesConfig
- UserDto(String, String...) - Constructor for class com.hazelcast.config.security.SimpleAuthenticationConfig.UserDto
- USERNAME_PROPERTY - Static variable in class com.hazelcast.jet.mongodb.dataconnection.MongoDataConnection
-
Name of the property holding username.
- UsernamePasswordCredentials - Class in com.hazelcast.security
-
Simple implementation of
PasswordCredentials
using name and password as security attributes. - UsernamePasswordCredentials() - Constructor for class com.hazelcast.security.UsernamePasswordCredentials
- UsernamePasswordCredentials(String, String) - Constructor for class com.hazelcast.security.UsernamePasswordCredentials
- UsernamePasswordIdentityConfig - Class in com.hazelcast.config.security
-
Simple username/password identity configuration.
- UsernamePasswordIdentityConfig(String, String) - Constructor for class com.hazelcast.config.security.UsernamePasswordIdentityConfig
- UTF - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
- UTF_ARRAY - Enum constant in enum class com.hazelcast.nio.serialization.FieldType
- Util - Class in com.hazelcast.jet
-
Miscellaneous utility methods useful in DAG building logic.
V
- validate() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
- validate() - Method in class com.hazelcast.jet.python.PythonServiceConfig
-
Validates the configuration and throws an exception if a mandatory config option is missing.
- validate(DataConnectionConfig) - Static method in class com.hazelcast.config.DataConnectionConfigValidator
-
Checks if this configuration object is in coherent state - has all required properties set.
- validate(T) - Method in interface com.hazelcast.config.properties.ValueValidator
-
Validates the given value according to the defined validation logic and throws a ValidationException if configuration does not meet the requirements or logical errors are spotted.
- ValidationException - Exception in com.hazelcast.config.properties
-
This exception is thrown from
ValueValidator
implementations whenever the validation has not succeeded for any reason. - ValidationException(String) - Constructor for exception com.hazelcast.config.properties.ValidationException
- ValidationException(String, Throwable) - Constructor for exception com.hazelcast.config.properties.ValidationException
- ValidationException(Throwable) - Constructor for exception com.hazelcast.config.properties.ValidationException
- validator() - Method in interface com.hazelcast.config.properties.PropertyDefinition
-
Returns an optional validator to validate a value before finalizing the configuration.
- validator() - Method in class com.hazelcast.config.properties.SimplePropertyDefinition
- value - Variable in class com.hazelcast.core.EntryEvent
- value() - Method in interface com.hazelcast.jet.cdc.ChangeRecord
-
Returns the value part of the CDC event.
- value() - Method in class com.hazelcast.jet.core.metrics.Measurement
-
Returns the value associated with this
Measurement
. - value() - Method in enum class com.hazelcast.query.QueryConstants
- VALUE_COUNT - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- ValueCallback<T> - Interface in com.hazelcast.query.extractor
-
Enables notifying about values extracted in a
ValueExtractor
- ValueCollector<T> - Interface in com.hazelcast.query.extractor
-
Enables collecting values extracted in a
ValueExtractor
- valueCount(K) - Method in interface com.hazelcast.multimap.BaseMultiMap
-
Returns the number of values matching the given key in the multimap.
- valueCount(K) - Method in interface com.hazelcast.multimap.MultiMap
-
Returns the number of values that match the given key in the multimap.
- valueCount(K) - Method in interface com.hazelcast.transaction.TransactionalMultiMap
-
Returns the number of values matching the given key in the multimap.
- ValueExtractor<T,
A> - Interface in com.hazelcast.query.extractor -
Common superclass for all extractors that enable the user to define custom attributes and extract their values.
- valueOf(String) - Static method in enum class com.hazelcast.auditlog.Level
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.cache.CacheEventType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.client.config.ClientConnectionStrategyConfig.ReconnectMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.client.config.ClientSqlResubmissionMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.client.config.RoutingStrategy
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.cluster.ClusterState
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.AbstractXmlConfigBuilder.ConfigType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.BitmapIndexOptions.UniqueKeyTransformation
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.CacheDeserializedValues
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.ConsistencyCheckStrategy
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.EvictionPolicy
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.HotRestartClusterDataRecoveryPolicy
-
Deprecated.Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.IndexType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.InMemoryFormat
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.InstanceTrackingConfig.InstanceMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.InstanceTrackingConfig.InstanceProductName
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.InstanceTrackingConfig.InstanceTrackingProperties
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.MapStoreConfig.InitialLoadMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.MaxSizePolicy
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.MetadataPolicy
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.MultiMapConfig.ValueCollectionType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.NativeMemoryConfig.MemoryAllocatorType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.NearCacheConfig.LocalUpdatePolicy
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.OnJoinPermissionOperationName
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.PartitionGroupConfig.MemberGroupType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.PermissionConfig.PermissionType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.PersistenceClusterDataRecoveryPolicy
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.PersistentMemoryMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.properties.PropertyTypeConverter
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.rest.RestConfig.Ssl.ClientAuth
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.RestEndpointGroup
-
Deprecated.Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.ScheduledExecutorConfig.CapacityPolicy
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.security.LdapRoleMappingMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.security.LdapSearchScope
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.security.TokenEncoding
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.UserCodeDeploymentConfig.ClassCacheMode
-
Deprecated.Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.UserCodeDeploymentConfig.ProviderMode
-
Deprecated.Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.vector.Metric
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.WanAcknowledgeType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.config.WanQueueFullBehavior
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.core.DistributedObjectEvent.EventType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.core.EntryEventType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.core.ItemEventType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.core.LifecycleEvent.LifecycleState
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.cp.CPGroup.CPGroupStatus
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.cp.event.CPMembershipEvent.EventType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.cp.session.CPSession.CPSessionOwnerType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.jet.cdc.Operation
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.PostgresSnapshotMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.jet.config.ProcessingGuarantee
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.jet.config.ResourceType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.jet.core.Edge.RoutingPolicy
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.jet.core.JobStatus
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.jet.core.metrics.Unit
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.jet.core.TimestampKind
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.jet.mongodb.ResourceChecks
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.jet.mongodb.WriteMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.jet.pipeline.JournalInitialPosition
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.memory.MemoryUnit
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.nio.serialization.FieldKind
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.nio.serialization.FieldType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.persistence.BackupTaskState
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.query.QueryConstants
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.ringbuffer.OverflowPolicy
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.spi.discovery.DiscoveryStrategyFactory.DiscoveryStrategyLevel
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.spi.discovery.integration.DiscoveryMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.splitbrainprotection.SplitBrainProtectionOn
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.sql.SqlColumnType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.sql.SqlExpectedResultType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.topic.TopicOverloadPolicy
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.transaction.TransactionOptions.TransactionType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.wan.WanEventType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.hazelcast.wan.WanPublisherState
-
Returns the enum constant of this class with the specified name.
- ValueReader - Interface in com.hazelcast.query.extractor
-
Enables reading the value of the attribute specified by the path
- ValueReadingException - Exception in com.hazelcast.query.extractor
-
Exception thrown if there is any checked or unchecked exception caught in the value reading in
ValueReader
- ValueReadingException(String, Throwable) - Constructor for exception com.hazelcast.query.extractor.ValueReadingException
- values() - Static method in enum class com.hazelcast.auditlog.Level
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.cache.CacheEventType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.client.config.ClientConnectionStrategyConfig.ReconnectMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.client.config.ClientSqlResubmissionMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.client.config.RoutingStrategy
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.cluster.ClusterState
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.AbstractXmlConfigBuilder.ConfigType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.BitmapIndexOptions.UniqueKeyTransformation
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.CacheDeserializedValues
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.ConsistencyCheckStrategy
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.EvictionPolicy
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.HotRestartClusterDataRecoveryPolicy
-
Deprecated.Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.IndexType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.InMemoryFormat
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.InstanceTrackingConfig.InstanceMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.InstanceTrackingConfig.InstanceProductName
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.InstanceTrackingConfig.InstanceTrackingProperties
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.MapStoreConfig.InitialLoadMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.MaxSizePolicy
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.MetadataPolicy
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.MultiMapConfig.ValueCollectionType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.NativeMemoryConfig.MemoryAllocatorType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.NearCacheConfig.LocalUpdatePolicy
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.OnJoinPermissionOperationName
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.PartitionGroupConfig.MemberGroupType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.PermissionConfig.PermissionType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.PersistenceClusterDataRecoveryPolicy
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.PersistentMemoryMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.properties.PropertyTypeConverter
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.rest.RestConfig.Ssl.ClientAuth
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.RestEndpointGroup
-
Deprecated.Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.ScheduledExecutorConfig.CapacityPolicy
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.security.LdapRoleMappingMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.security.LdapSearchScope
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.security.TokenEncoding
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.UserCodeDeploymentConfig.ClassCacheMode
-
Deprecated.Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.UserCodeDeploymentConfig.ProviderMode
-
Deprecated.Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.vector.Metric
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.WanAcknowledgeType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.config.WanQueueFullBehavior
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.core.DistributedObjectEvent.EventType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.core.EntryEventType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.core.ItemEventType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.core.LifecycleEvent.LifecycleState
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.cp.CPGroup.CPGroupStatus
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.cp.event.CPMembershipEvent.EventType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.cp.session.CPSession.CPSessionOwnerType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.jet.cdc.Operation
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.jet.cdc.postgres.PostgresCdcSources.PostgresSnapshotMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.jet.config.ProcessingGuarantee
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.jet.config.ResourceType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.jet.core.Edge.RoutingPolicy
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.jet.core.JobStatus
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.jet.core.metrics.Unit
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.jet.core.TimestampKind
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.jet.mongodb.ResourceChecks
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.jet.mongodb.WriteMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.jet.pipeline.JournalInitialPosition
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in interface com.hazelcast.map.BaseMap
-
Returns a collection clone of the values contained in this map.
- values() - Method in interface com.hazelcast.map.IMap
-
Returns an immutable collection clone of the values contained in this map.
- values() - Method in interface com.hazelcast.map.QueryCache
- values() - Static method in enum class com.hazelcast.memory.MemoryUnit
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in interface com.hazelcast.multimap.MultiMap
-
Returns the collection of values in the multimap.
- values() - Static method in enum class com.hazelcast.nio.serialization.FieldKind
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.nio.serialization.FieldType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.persistence.BackupTaskState
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.query.QueryConstants
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
-
Returns a lazy
Collection
view of the values contained in this map.
A LazyCollection is optimized for querying speed (preventing eager deserialization and hashing on HashSet insertion) and does NOT provide all operations. - values() - Static method in enum class com.hazelcast.ringbuffer.OverflowPolicy
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.spi.discovery.DiscoveryStrategyFactory.DiscoveryStrategyLevel
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.spi.discovery.integration.DiscoveryMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.splitbrainprotection.SplitBrainProtectionOn
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.sql.SqlColumnType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.sql.SqlExpectedResultType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.topic.TopicOverloadPolicy
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in interface com.hazelcast.transaction.TransactionalMap
-
Transactional implementation of
IMap.values()
. - values() - Static method in enum class com.hazelcast.transaction.TransactionOptions.TransactionType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.wan.WanEventType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.hazelcast.wan.WanPublisherState
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values(Predicate<K, V>) - Method in interface com.hazelcast.map.BaseMap
-
Queries the map based on the specified predicate and returns the values of matching entries.
- values(Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
-
Queries the map based on the specified predicate and returns an immutable collection of the values of matching entries.
- values(Predicate<K, V>) - Method in interface com.hazelcast.map.QueryCache
- values(Predicate<K, V>) - Method in interface com.hazelcast.transaction.TransactionalMap
-
Transactional implementation of
IMap.values(com.hazelcast.query.Predicate)
. - values(Comparator<V>) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
-
Returns an eagerly populated
Collection
view of the values contained in this map. - VALUES - Static variable in class com.hazelcast.security.SecurityInterceptorConstants
- ValueValidator<T extends Comparable<T>> - Interface in com.hazelcast.config.properties
-
This interface defines a certain validation logic implementation to test if a given value is expected to be correct or not.
- varArity() - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder
-
Selects the variable-arity variant for this aggregate operation builder.
- VARCHAR - Enum constant in enum class com.hazelcast.sql.SqlColumnType
-
VARCHAR type, represented by
String
- VaultSecureStoreConfig - Class in com.hazelcast.config
-
HashiCorp Vault Secure Store configuration.
- VaultSecureStoreConfig(String, String, String) - Constructor for class com.hazelcast.config.VaultSecureStoreConfig
-
Creates a new Vault Secure Store configuration.
- vector() - Method in interface com.hazelcast.vector.VectorValues.SingleVectorValues
- VECTOR_COLLECTION - Enum constant in enum class com.hazelcast.config.PermissionConfig.PermissionType
-
Vector collection permissions
- VectorCollectionConfig - Class in com.hazelcast.config.vector
-
Configuration object for a vector collection.
- VectorCollectionConfig() - Constructor for class com.hazelcast.config.vector.VectorCollectionConfig
-
Creates a new, empty
VectorCollectionConfig
. - VectorCollectionConfig(VectorCollectionConfig) - Constructor for class com.hazelcast.config.vector.VectorCollectionConfig
-
Constructs a new
VectorCollectionConfig
instance by copying the values from the provided configuration. - VectorCollectionConfig(String) - Constructor for class com.hazelcast.config.vector.VectorCollectionConfig
-
Constructs a VectorCollectionConfig with the given name.
- VectorCollectionPermission - Class in com.hazelcast.security.permission
- VectorCollectionPermission(String, String...) - Constructor for class com.hazelcast.security.permission.VectorCollectionPermission
- VectorDocument<V> - Interface in com.hazelcast.vector
-
A
VectorDocument
includes a user-suppliedV value
and the associatedVectorValues
that represent the document. - VectorIndexConfig - Class in com.hazelcast.config.vector
-
Configuration for a vector index.
- VectorIndexConfig() - Constructor for class com.hazelcast.config.vector.VectorIndexConfig
-
Constructs an empty VectorIndexConfig.
- VectorIndexConfig(VectorIndexConfig) - Constructor for class com.hazelcast.config.vector.VectorIndexConfig
-
Constructs a new
VectorIndexConfig
instance by copying the values from the provided configuration. - VectorIndexConfig(String, Metric, int) - Constructor for class com.hazelcast.config.vector.VectorIndexConfig
-
Constructs a VectorIndexConfig with the given parameters.
- VectorIndexConfig(String, Metric, int, int, int, boolean) - Constructor for class com.hazelcast.config.vector.VectorIndexConfig
-
Constructs a VectorIndexConfig object with the specified parameters.
- VectorValues - Interface in com.hazelcast.vector
-
A
VectorValues
instance contains the vectors that describe aVectorDocument
. - VectorValues.MultiIndexVectorValues - Interface in com.hazelcast.vector
-
Provides a mapping from index name to vector, supplying vectors for a
VectorCollection
with multiple indexes defined. - VectorValues.SingleVectorValues - Interface in com.hazelcast.vector
-
Represents values of a single vector.
- verify() - Method in class com.hazelcast.config.JoinConfig
-
Verifies this JoinConfig is valid.
- verifyProcessor(SupplierEx<Processor>) - Static method in class com.hazelcast.jet.core.test.TestSupport
- verifyProcessor(ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.test.TestSupport
- verifyProcessor(ProcessorSupplier) - Static method in class com.hazelcast.jet.core.test.TestSupport
- version() - Method in interface com.hazelcast.cp.session.CPSession
-
Returns version of the session.
- Version - Class in com.hazelcast.version
-
A generic version to be used with
VersionAware
classes. - Version() - Constructor for class com.hazelcast.version.Version
- VERSION - Enum constant in enum class com.hazelcast.config.InstanceTrackingConfig.InstanceTrackingProperties
-
The instance version.
- VersionAware - Interface in com.hazelcast.nio
-
An instance which supports versioning.
- VersionedPortable - 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.
- vertex(Vertex) - Method in class com.hazelcast.jet.core.DAG
-
Adds a vertex to this DAG.
- Vertex - Class in com.hazelcast.jet.core
-
Represents a unit of data processing in a Jet computation job.
- Vertex(String, SupplierEx<? extends Processor>) - Constructor for class com.hazelcast.jet.core.Vertex
-
Creates a vertex from a
Supplier<Processor>
. - Vertex(String, ProcessorMetaSupplier) - Constructor for class com.hazelcast.jet.core.Vertex
-
Creates a vertex from a
ProcessorMetaSupplier
. - Vertex(String, ProcessorSupplier) - Constructor for class com.hazelcast.jet.core.Vertex
-
Creates a vertex from a
ProcessorSupplier
. - VERTEX - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
- VERTEX - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
-
DAG vertex name the of the metric.
- vertexName() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
-
Returns the name of the associated vertex.
- vertexName() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
- vertices() - Method in class com.hazelcast.jet.core.DAG
-
Returns a copy of the DAG's vertices.
W
- WAIT_SECONDS_BEFORE_JOIN - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The time that a newly-appointed master node waits before forming a cluster.
- waitAfterAttempt(int) - Method in interface com.hazelcast.jet.retry.IntervalFunction
-
Returns the wait time required before the specified attempt.
- WAN - Enum constant in enum class com.hazelcast.config.RestEndpointGroup
-
Deprecated.Group of HTTP REST APIs related to WAN Replication feature.
- WAN_ADD_CONFIG - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
-
Event type ID: WAN add config.
- WAN_CONSUMER_ACK_DELAY_BACKOFF_INIT_MS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Defines the initial backoff delay for the Enterprise WAN implementation's consumer.
- WAN_CONSUMER_ACK_DELAY_BACKOFF_MAX_MS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Defines the maximum backoff delay for the Enterprise WAN implementation's consumer.
- WAN_CONSUMER_ACK_DELAY_BACKOFF_MULTIPLIER - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Defines the multiplier (the speed of the function) for the backoff delay for the Enterprise WAN implementation's consumer.
- WAN_CONSUMER_INVOCATION_THRESHOLD - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Defines the pending invocation threshold for the Enterprise WAN replication implementation.
- WAN_REPLICATE_ICACHE_EVICTIONS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Defines whether WAN replication events should be fired when values are evicted from
ICache
objects. - WAN_REPLICATE_IMAP_EVICTIONS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Defines whether WAN replication events should be fired when values are evicted from
IMap
objects. - WAN_SYNC - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
-
Event type ID: WAN sync.
- WanAcknowledgeType - Enum Class in com.hazelcast.config
-
Determines acknowledge waiting type of wan replication operation invocation.
- WanBatchPublisherConfig - Class in com.hazelcast.config
-
Configuration object for the built-in WAN publisher (available in Hazelcast Enterprise).
- WanBatchPublisherConfig() - Constructor for class com.hazelcast.config.WanBatchPublisherConfig
- WanConsumer - Interface in com.hazelcast.wan
-
Interface to be implemented by custom WAN event consumers.
- WanConsumerConfig - Class in com.hazelcast.config
-
Config for processing WAN events received from a target cluster.
- WanConsumerConfig() - Constructor for class com.hazelcast.config.WanConsumerConfig
- WanCustomPublisherConfig - Class in com.hazelcast.config
-
Configuration object for a custom WAN publisher.
- WanCustomPublisherConfig() - Constructor for class com.hazelcast.config.WanCustomPublisherConfig
- WanEvent<T> - Interface in com.hazelcast.wan
-
Interface for all WAN replication messages
- WanEventCounters - Class in com.hazelcast.wan
-
Counters for WAN events for a single distributed object type (map or cache).
- WanEventCounters() - Constructor for class com.hazelcast.wan.WanEventCounters
- WanEventCounters.DistributedObjectWanEventCounters - Class in com.hazelcast.wan
-
Counters for WAN events for a single map or cache.
- WanEventType - Enum Class in com.hazelcast.wan
-
The type of the WAN event, signifies the type of the mutation that occurred that caused the WAN event.
- WanMigrationAwarePublisher<T> - Interface in com.hazelcast.wan
-
Interface for WAN publisher migration related events.
- WanProtocolVersionAware - Interface in com.hazelcast.nio
-
An instance which is used in WAN and supports versioning.
- WanPublisher<T> - Interface in com.hazelcast.wan
-
This interface offers the implementation of different kinds of replication techniques like TCP, UDP or maybe even an JMS based service.
- WanPublisherState - Enum Class in com.hazelcast.wan
-
Defines the state in which a WAN publisher can be in if it is not shutting down.
- WanQueueFullBehavior - Enum Class in com.hazelcast.config
-
Determines the behavior of WAN replication impl.
- WanQueueFullException - Exception in com.hazelcast.wan
-
A
HazelcastException
that is thrown when the wan replication queues are full - WanQueueFullException(String) - Constructor for exception com.hazelcast.wan.WanQueueFullException
- WanReplicationConfig - Class in com.hazelcast.config
-
Configuration for WAN replication.
- WanReplicationConfig() - Constructor for class com.hazelcast.config.WanReplicationConfig
- WanReplicationRef - Class in com.hazelcast.config
-
Configuration for a WAN target replication reference.
- WanReplicationRef() - Constructor for class com.hazelcast.config.WanReplicationRef
- WanReplicationRef(WanReplicationRef) - Constructor for class com.hazelcast.config.WanReplicationRef
- WanReplicationRef(String, String, List<String>, boolean) - Constructor for class com.hazelcast.config.WanReplicationRef
- WanSyncConfig - Class in com.hazelcast.config
-
Configuration object for the WAN sync mechanism.
- WanSyncConfig() - Constructor for class com.hazelcast.config.WanSyncConfig
- WANT - Enum constant in enum class com.hazelcast.config.rest.RestConfig.Ssl.ClientAuth
-
Client authentication is wanted but not mandatory.
- WARN - Enum constant in enum class com.hazelcast.auditlog.Level
-
Warning level.
- warning(String) - Method in class com.hazelcast.logging.AbstractLogger
- warning(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
- warning(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
- watch(String) - Method in class com.hazelcast.spi.utils.RestClient
-
Issues a watch request to a Kubernetes resource, starting with the given
resourceVersion
. - WatchResponse(HttpResponse<InputStream>) - Constructor for class com.hazelcast.spi.utils.RestClient.WatchResponse
- Watermark - Class in com.hazelcast.jet.core
-
Watermark is an item occasionally inserted into a disordered (sub)stream of timestamped items.
- Watermark(long) - Constructor for class com.hazelcast.jet.core.Watermark
-
Constructs a new watermark item with
0
watermark key. - Watermark(long, byte) - Constructor for class com.hazelcast.jet.core.Watermark
-
Constructs a new watermark item with specified key.
- WatermarkPolicy - Interface in com.hazelcast.jet.core
-
This object tracks and determines the current
Watermark
given the event timestamps as they occur for a single input stream. - watermarkThrottlingFrameOffset() - Method in class com.hazelcast.jet.core.EventTimePolicy
- watermarkThrottlingFrameSize() - Method in class com.hazelcast.jet.core.EventTimePolicy
-
This value together with
EventTimePolicy.watermarkThrottlingFrameOffset()
specify the frame size the watermarks are throttled to. - wholeItem() - Static method in class com.hazelcast.function.Functions
-
Synonym for
FunctionEx.identity()
, to be used as a projection function (e.g., key extractor). - WildcardConfigPatternMatcher - Class in com.hazelcast.config.matcher
-
This
ConfigPatternMatcher
supports a simplified wildcard matching. - WildcardConfigPatternMatcher() - Constructor for class com.hazelcast.config.matcher.WildcardConfigPatternMatcher
- window(WindowDefinition) - Method in interface com.hazelcast.jet.pipeline.StreamStage
-
Adds the given window definition to this stage, as the first step in the construction of a pipeline stage that performs windowed aggregation.
- window(WindowDefinition) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
-
Adds the definition of the window to use in the group-and-aggregate pipeline stage being constructed.
- WindowAggregateBuilder<R0> - Class in com.hazelcast.jet.pipeline
-
Offers a step-by-step fluent API to build a pipeline stage that performs a windowed co-aggregation of the data from several input stages.
- WindowAggregateBuilder1<T0> - Class in com.hazelcast.jet.pipeline
-
Offers a step-by-step fluent API to build a pipeline stage that performs a windowed co-aggregation of the data from several input stages.
- windowDefinition() - Method in interface com.hazelcast.jet.pipeline.StageWithKeyAndWindow
-
Returns the definition of the window for the windowed aggregation operation that you are about to construct using this object.
- windowDefinition() - Method in interface com.hazelcast.jet.pipeline.StageWithWindow
-
Returns the definition of the window for the windowed aggregation operation that you are about to construct using this object.
- WindowDefinition - Class in com.hazelcast.jet.pipeline
-
The definition of the window for a windowed aggregation operation.
- WindowDefinition() - Constructor for class com.hazelcast.jet.pipeline.WindowDefinition
- WindowGroupAggregateBuilder<K,
R0> - Class in com.hazelcast.jet.pipeline -
Offers a step-by-step API to build a pipeline stage that performs a windowed co-grouping and aggregation of the data from several input stages.
- WindowGroupAggregateBuilder1<T0,
K> - Class in com.hazelcast.jet.pipeline -
Offers a step-by-step API to build a pipeline stage that performs a windowed co-grouping and aggregation of the data from several input stages.
- WindowResult<R> - Class in com.hazelcast.jet.datamodel
-
Holds the result of an aggregate operation performed over a time window.
- WindowResult(long, long, R) - Constructor for class com.hazelcast.jet.datamodel.WindowResult
-
Constructs a window result that is not early.
- WindowResult(long, long, R, boolean) - Constructor for class com.hazelcast.jet.datamodel.WindowResult
- windowSize() - Method in class com.hazelcast.jet.core.SlidingWindowPolicy
-
Returns the length of the window (the size of the timestamp range it covers).
- windowSize() - Method in class com.hazelcast.jet.pipeline.SlidingWindowDefinition
-
Returns the length of the window (the size of the timestamp range it covers).
- withAcceptableHeartbeatPauseMillis(long) - Method in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
-
Duration in milliseconds corresponding to number of potentially lost/delayed heartbeats that will be accepted before considering it to be an anomaly.
- withAccumulateFn(BiConsumerEx<? super A, ? super NEW_T>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation1
-
Returns a copy of this aggregate operation, but with the
accumulate
primitive replaced with the one supplied here. - withAccumulateFn0(BiConsumerEx<? super A, ? super T0_NEW>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation2
-
Returns a copy of this aggregate operation, but with the
accumulate
primitive at index 0 replaced with the one supplied here. - withAccumulateFn0(BiConsumerEx<? super A, ? super T0_NEW>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation3
-
Returns a copy of this aggregate operation, but with the
accumulate
primitive at index 0 replaced with the one supplied here. - withAccumulateFn1(BiConsumerEx<? super A, ? super T1_NEW>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation2
-
Returns a copy of this aggregate operation, but with the
accumulate
primitive at index 1 replaced with the one supplied here. - withAccumulateFn1(BiConsumerEx<? super A, ? super T1_NEW>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation3
-
Returns a copy of this aggregate operation, but with the
accumulate
primitive at index 1 replaced with the one supplied here. - withAccumulateFn2(BiConsumerEx<? super A, ? super T2_NEW>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation3
-
Returns a copy of this aggregate operation, but with the
accumulate
primitive at index 2 replaced with the one supplied here. - withAccumulateFns(BiConsumerEx...) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
-
Returns a copy of this aggregate operation, but with all the
accumulate
primitives replaced with the ones supplied here. - withAttachedDirectory(String, File) - Method in class com.hazelcast.jet.pipeline.ServiceFactory
-
Attaches a directory to this service factory under the given ID.
- withAttachedFile(String, File) - Method in class com.hazelcast.jet.pipeline.ServiceFactory
-
Attaches a file to this service factory under the given ID.
- withBody(String) - Method in class com.hazelcast.spi.utils.RestClient
- withClass(Class<T>) - Method in class com.hazelcast.jet.pipeline.file.JsonFileFormat
-
Specifies class that data will be deserialized into.
- withCombiningAccumulateFn(FunctionEx<T, A>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
-
Returns a copy of this aggregate operation, but with the
accumulate
primitive replaced with one that expects to find accumulator objects in the input items and combines them all into a single accumulator of the same type. - withConfig(JobConfig) - Method in interface com.hazelcast.jet.JetService.JobBuilder
-
See
JobConfig
for details. - withCreate(SupplierEx<A>) - Static method in interface com.hazelcast.jet.aggregate.AggregateOperation
-
Returns a builder object, initialized with the supplied
create
primitive, that can be used to construct the definition of an aggregate operation in a step-by-step manner. - withCreateContextFn(FunctionEx<? super ProcessorSupplier.Context, ? extends C>) - Static method in class com.hazelcast.jet.pipeline.ServiceFactory
-
Creates a new
ServiceFactory
with the given function that creates the shared context object. - withCreateServiceFn(BiFunctionEx<? super Processor.Context, ? super C, ? extends S_NEW>) - Method in class com.hazelcast.jet.pipeline.ServiceFactory
-
Returns a copy of this
ServiceFactory
with the givencreateService
function. - withCredentials(String, String) - Method in class com.hazelcast.jet.kinesis.KinesisSinks.Builder
-
Specifies the AWS credentials to use for authentication purposes.
- withCredentials(String, String) - Method in class com.hazelcast.jet.kinesis.KinesisSources.Builder
-
Specifies the AWS credentials to use for authentication purposes.
- withCustomReplaceOptions(ConsumerEx<ReplaceOptions>) - Method in class com.hazelcast.jet.mongodb.MongoSinkBuilder
-
Provides an option to adjust options used in replace action.
- withDestroyContextFn(ConsumerEx<? super C>) - Method in class com.hazelcast.jet.pipeline.ServiceFactory
-
Returns a copy of this
ServiceFactory
with thedestroyContext
function replaced with the given function. - withDestroyServiceFn(ConsumerEx<? super S>) - Method in class com.hazelcast.jet.pipeline.ServiceFactory
-
Returns a copy of this
ServiceFactory
with thedestroyService
function replaced with the given function. - withEndpoint(String) - Method in class com.hazelcast.jet.kinesis.KinesisSinks.Builder
-
Specifies the AWS Kinesis endpoint (URL of the entry point for the AWS web service) to connect to.
- withEndpoint(String) - Method in class com.hazelcast.jet.kinesis.KinesisSources.Builder
-
Specifies the AWS Kinesis endpoint (URL of the entry point for the AWS web service) to connect to.
- withExecutorServiceSupplier(SupplierEx<ExecutorService>) - Method in class com.hazelcast.jet.kinesis.KinesisSinks.Builder
-
Specifies an executor service supplier that will be used by the
AwsConfig
to construct an AWS async client. - withExecutorServiceSupplier(SupplierEx<ExecutorService>) - Method in class com.hazelcast.jet.kinesis.KinesisSources.Builder
-
Specifies an executor service supplier that will be used by the
AwsConfig
to construct an AWS async client. - withHeader(String, String) - Method in class com.hazelcast.spi.utils.RestClient
- withHeaders(Map<String, String>) - Method in class com.hazelcast.spi.utils.RestClient
- withHeartbeatIntervalMillis(long) - Method in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
-
Bootstrap the stats with heartbeats that corresponds to this duration in milliseconds, with a rather high standard deviation (since environment is unknown in the beginning).
- withIdentityFinish() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
-
Returns a copy of this aggregate operation, but with the
finish
primitive replaced with the identity function. - withIdentityFinish() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation1
- withIdentityFinish() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation2
- withIdentityFinish() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation3
- withIngestionTimestamps() - Method in interface com.hazelcast.jet.pipeline.StreamSourceStage
-
Declares that the source will assign the time of ingestion as the event timestamp.
- withInitialShardIteratorRule(String, String, String) - Method in class com.hazelcast.jet.kinesis.KinesisSources.Builder
-
Specifies how initial reads of the shards should be done (see shardIteratorType for available options).
- withMaxSampleSize(int) - Method in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
-
Number of samples to use for calculation of mean and standard deviation of inter-arrival times.
- withMemberSelector(JetMemberSelector) - Method in interface com.hazelcast.jet.JetService.JobBuilder
-
Selects the members on which the job will run.
- withMinStdDeviationMillis(long) - Method in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
-
Minimum standard deviation (in milliseconds) to use for the normal distribution used when calculating phi.
- withNativeTimestamps(long) - Method in interface com.hazelcast.jet.pipeline.StreamSourceStage
-
Declares that the stream will use the source's native timestamps.
- withOffset(long) - Method in class com.hazelcast.jet.core.SlidingWindowPolicy
-
Returns a new window definition where all the frames are shifted by the given offset.
- withoutAttachedFiles() - Method in class com.hazelcast.jet.pipeline.ServiceFactory
-
Returns a copy of this
ServiceFactory
with any attached files removed. - withoutTimestamps() - Method in interface com.hazelcast.jet.pipeline.StreamSourceStage
-
Declares that the source will not assign any timestamp to the events it emits.
- withPermission(Permission) - Method in class com.hazelcast.jet.pipeline.ServiceFactory
-
Returns a copy of this
ServiceFactory
with setting the required permission. - withProjectionFn(BiFunctionEx<Record, Shard, T_NEW>) - Method in class com.hazelcast.jet.kinesis.KinesisSources.Builder
-
Specifies projection function, that will map input
Record
andShard
from which this record was read into user-defined type. - withReflect(Class<T>) - Method in class com.hazelcast.jet.pipeline.file.AvroFileFormat
-
Specifies to use reflection to deserialize data into the given class.
- withRegion(String) - Method in class com.hazelcast.jet.kinesis.KinesisSinks.Builder
-
Specifies the AWS Region (collection of AWS resources in a geographic area) to connect to.
- withRegion(String) - Method in class com.hazelcast.jet.kinesis.KinesisSources.Builder
-
Specifies the AWS Region (collection of AWS resources in a geographic area) to connect to.
- withRequestTimeoutSeconds(int) - Method in class com.hazelcast.spi.utils.RestClient
- withRetries(int) - Method in class com.hazelcast.spi.utils.RestClient
- withRetryStrategy(RetryStrategy) - Method in class com.hazelcast.jet.kinesis.KinesisSinks.Builder
-
Specifies how the source should behave when reading data from the stream fails.
- withRetryStrategy(RetryStrategy) - Method in class com.hazelcast.jet.kinesis.KinesisSources.Builder
-
Specifies how the source should behave when reading data from the stream fails.
- withSplitBrainProtectionSize(int) - Method in class com.hazelcast.config.SplitBrainProtectionConfigBuilder
- withSuspicionThreshold(double) - Method in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
-
Threshold for suspicion (φ) level.
- withTimestamps(ToLongFunctionEx<? super T>, long) - Method in interface com.hazelcast.jet.pipeline.StreamSourceStage
-
Declares that the source will extract timestamps from the stream items.
- wmKey() - Method in class com.hazelcast.jet.core.EventTimePolicy
- wrap() - Method in exception com.hazelcast.client.UndefinedErrorCodeException
- wrap() - Method in exception com.hazelcast.cp.exception.CannotReplicateException
- wrap() - Method in exception com.hazelcast.cp.exception.CPGroupDestroyedException
- wrap() - Method in exception com.hazelcast.cp.exception.CPSubsystemException
- wrap() - Method in exception com.hazelcast.cp.exception.LeaderDemotedException
- wrap() - Method in exception com.hazelcast.cp.exception.NotLeaderException
- wrap() - Method in exception com.hazelcast.cp.exception.StaleAppendRequestException
- wrap() - Method in exception com.hazelcast.ringbuffer.StaleSequenceException
- wrapFn() - Method in class com.hazelcast.jet.core.EventTimePolicy
-
Returns the function that transforms the received item and its timestamp into the emitted item.
- write(ObjectDataOutput, T) - Method in class com.hazelcast.jet.protobuf.ProtobufSerializer
- write(ObjectDataOutput, T) - Method in interface com.hazelcast.nio.serialization.StreamSerializer
-
This method writes object to ObjectDataOutput
- write(CompactWriter, ObjectId) - Method in class com.hazelcast.jet.mongodb.compact.ObjectIdCompactSerializer
- write(CompactWriter, T) - Method in interface com.hazelcast.nio.serialization.compact.CompactSerializer
- write(T) - Method in interface com.hazelcast.nio.serialization.ByteArraySerializer
-
Converts given object to byte array
- WRITE - Enum constant in enum class com.hazelcast.splitbrainprotection.SplitBrainProtectionOn
-
Only write operations will participate in a split brain protection.
- writeArrayOfBoolean(String, boolean[]) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes an array of booleans.
- writeArrayOfCompact(String, T[]) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes an array of nested compact objects.
- writeArrayOfDate(String, LocalDate[]) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes an array of dates consisting of year, month, and day.
- writeArrayOfDecimal(String, BigDecimal[]) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes an array of arbitrary precision and scale floating point numbers.
- writeArrayOfFloat32(String, float[]) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes an array of 32-bit IEEE 754 floating point numbers.
- writeArrayOfFloat64(String, double[]) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes an array of 64-bit IEEE 754 floating point numbers.
- writeArrayOfInt16(String, short[]) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes an array of 16-bit two's complement signed integers.
- writeArrayOfInt32(String, int[]) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes an array of 32-bit two's complement signed integers.
- writeArrayOfInt64(String, long[]) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes an array of 64-bit two's complement signed integers.
- writeArrayOfInt8(String, byte[]) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes an array of 8-bit two's complement signed integers.
- writeArrayOfNullableBoolean(String, Boolean[]) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a nullable array of nullable booleans.
- writeArrayOfNullableFloat32(String, Float[]) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a nullable array of nullable 32-bit IEEE 754 floating point numbers.
- writeArrayOfNullableFloat64(String, Double[]) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a nullable array of nullable 64-bit IEEE 754 floating point numbers.
- writeArrayOfNullableInt16(String, Short[]) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a nullable array of nullable 16-bit two's complement signed integers.
- writeArrayOfNullableInt32(String, Integer[]) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a nullable array of nullable 32-bit two's complement signed integers.
- writeArrayOfNullableInt64(String, Long[]) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a nullable array of nullable 64-bit two's complement signed integers.
- writeArrayOfNullableInt8(String, Byte[]) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a nullable array of nullable 8-bit two's complement signed integers.
- writeArrayOfString(String, String[]) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes an array of UTF-8 encoded strings.
- writeArrayOfTime(String, LocalTime[]) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes an array of times consisting of hour, minute, second, and nanoseconds.
- writeArrayOfTimestamp(String, LocalDateTime[]) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes an array of timestamps consisting of date and time.
- writeArrayOfTimestampWithTimezone(String, OffsetDateTime[]) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes an array of timestamps with timezone consisting of date, time and timezone offset.
- writeBoolean(String, boolean) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a boolean.
- writeBoolean(String, boolean) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes a primitive boolean.
- writeBooleanArray(boolean[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
- writeBooleanArray(String, boolean[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes a primitive boolean-array.
- writeBufferedP(FunctionEx<? super Processor.Context, ? extends W>, BiConsumerEx<? super W, ? super T>, ConsumerEx<? super W>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Shortcut for
SinkProcessors.writeBufferedP(FunctionEx, BiConsumerEx, ConsumerEx, ConsumerEx)
with a no-opdestroyFn
. - writeBufferedP(FunctionEx<? super Processor.Context, ? extends W>, BiConsumerEx<? super W, ? super T>, ConsumerEx<? super W>, ConsumerEx<? super W>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for a vertex that drains all the items from the inbox to an internal writer object and then does a flush.
- writeByte(String, byte) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes a primitive byte.
- writeByteArray(byte[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
- writeByteArray(String, byte[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes a primitive byte-array.
- writeCacheP(String) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for
Sinks.cache(String)
. - writeChar(String, int) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes a primitive char.
- writeCharArray(char[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
- writeCharArray(String, char[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes a primitive char-array.
- writeCompact(String, T) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a nested compact object.
- writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
- writeData(ObjectDataOutput) - Method in class com.hazelcast.cluster.Address
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.AttributeConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.BitmapIndexOptions
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.BTreeIndexConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CollectionConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.DataConnectionConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.DataPersistenceConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.DiscoveryConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.DiskTierConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.DurableExecutorConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.EntryListenerConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.EventJournalConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.EvictionConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ExecutorConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.HotRestartConfig
-
Deprecated.
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.IndexConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ItemListenerConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ListenerConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MapConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MapStoreConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MemoryTierConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MergePolicyConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MerkleTreeConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MultiMapConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.NearCacheConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.NearCachePreloaderConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.PartitioningAttributeConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.PartitioningStrategyConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.PermissionConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.PNCounterConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.PredicateConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.QueryCacheConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.QueueConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.QueueStoreConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ReliableTopicConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ReplicatedMapConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.RingbufferConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.RingbufferStoreConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ScheduledExecutorConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.TieredStoreConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.TopicConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.UserCodeNamespaceConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.vector.VectorCollectionConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.vector.VectorIndexConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanBatchPublisherConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanConsumerConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanReplicationConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanReplicationRef
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanSyncConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.console.Echo
- writeData(ObjectDataOutput) - Method in class com.hazelcast.jet.config.DeltaJobConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.jet.config.EdgeConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.jet.config.JobConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.jet.config.ResourceConfig
- writeData(ObjectDataOutput) - Method in class com.hazelcast.jet.core.DAG
- writeData(ObjectDataOutput) - Method in class com.hazelcast.jet.core.Edge
- writeData(ObjectDataOutput) - Method in class com.hazelcast.jet.core.metrics.JobMetrics
- writeData(ObjectDataOutput) - Method in class com.hazelcast.jet.core.metrics.Measurement
- writeData(ObjectDataOutput) - Method in class com.hazelcast.jet.core.ProcessorMetaSupplier.ExpectNothingProcessorSupplier
- writeData(ObjectDataOutput) - Method in class com.hazelcast.jet.core.ProcessorMetaSupplier.RandomMemberPms
- writeData(ObjectDataOutput) - Method in class com.hazelcast.jet.core.ProcessorMetaSupplier.SpecificMemberPms
- writeData(ObjectDataOutput) - Method in class com.hazelcast.jet.core.Vertex
- writeData(ObjectDataOutput) - Method in class com.hazelcast.jet.JobStatusEvent
- writeData(ObjectDataOutput) - Method in interface com.hazelcast.nio.serialization.DataSerializable
-
Writes object fields to output stream
- writeData(ObjectDataOutput) - Method in class com.hazelcast.nio.serialization.PortableId
-
Deprecated.
- writeData(ObjectDataOutput) - Method in class com.hazelcast.partition.PartitionAwareKey
- writeData(ObjectDataOutput) - Method in class com.hazelcast.security.SimpleTokenCredentials
- writeData(ObjectDataOutput) - Method in class com.hazelcast.security.UsernamePasswordCredentials
- writeData(ObjectDataOutput) - Method in class com.hazelcast.transaction.TransactionOptions
- writeData(ObjectDataOutput) - Method in class com.hazelcast.version.MemberVersion
- writeData(ObjectDataOutput) - Method in class com.hazelcast.version.Version
- writeDate(String, LocalDate) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a date consisting of year, month, and day.
- writeDate(String, LocalDate) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes a date field consisting of year, month of the year and day of the month
- writeDateArray(String, LocalDate[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes an array of Date's
- writeDecimal(String, BigDecimal) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes an arbitrary precision and scale floating point number.
- writeDecimal(String, BigDecimal) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes a decimal which is arbitrary precision and scale floating-point number
- writeDecimalArray(String, BigDecimal[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes an array of Decimals
- writeDouble(String, double) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes a primitive double.
- writeDoubleArray(double[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
- writeDoubleArray(String, double[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes a primitive double array.
- writeFactories(ObjectDataOutput) - Method in class com.hazelcast.config.CacheConfig
- writeFileP(String, Charset, String, long, boolean, FunctionEx<? super T, ? extends String>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for
Sinks.filesBuilder(java.lang.String)
. - writeFilesP(String, Schema, SupplierEx<DatumWriter<D>>, String) - Static method in class com.hazelcast.jet.avro.AvroProcessors
-
Returns a supplier of processors for
AvroSinks.files(java.lang.String, org.apache.avro.Schema, com.hazelcast.function.SupplierEx<org.apache.avro.io.DatumWriter<R>>)
. - writeFloat(String, float) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes a primitive float.
- writeFloat32(String, float) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a 32-bit IEEE 754 floating point number.
- writeFloat64(String, double) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a 64-bit IEEE 754 floating point number.
- writeFloatArray(float[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
- writeFloatArray(String, float[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes a primitive float array.
- writeHadoopP(Configuration, FunctionEx<? super E, K>, FunctionEx<? super E, V>) - Static method in class com.hazelcast.jet.hadoop.HadoopProcessors
-
Returns a supplier of processors for
HadoopSinks.outputFormat(Configuration, FunctionEx, FunctionEx)
. - writeInt(String, int) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes a primitive int.
- writeInt16(String, short) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a 16-bit two's complement signed integer.
- writeInt32(String, int) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a 32-bit two's complement signed integer.
- writeInt64(String, long) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a 64-bit two's complement signed integer.
- writeInt8(String, byte) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes an 8-bit two's complement signed integer.
- writeIntArray(int[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
- writeIntArray(String, int[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes a primitive int-array.
- writeJdbcP(String, DataConnectionRef, BiConsumerEx<? super PreparedStatement, ? super T>, boolean, int) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for
Sinks.jdbcBuilder()
. - writeJdbcP(String, String, SupplierEx<? extends CommonDataSource>, BiConsumerEx<? super PreparedStatement, ? super T>, boolean, int) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for
Sinks.jdbcBuilder()
. - writeJmsQueueP(String, boolean, SupplierEx<? extends Connection>, BiFunctionEx<? super Session, ? super T, ? extends Message>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for
Sinks.jmsQueueBuilder(com.hazelcast.function.SupplierEx<jakarta.jms.ConnectionFactory>)
. - writeJmsTopicP(String, boolean, SupplierEx<? extends Connection>, BiFunctionEx<? super Session, ? super T, ? extends Message>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for
Sinks.jmsTopicBuilder(com.hazelcast.function.SupplierEx<jakarta.jms.ConnectionFactory>)
. - writeKafkaP(DataConnectionRef, FunctionEx<? super T, ? extends ProducerRecord<K, V>>, boolean) - Static method in class com.hazelcast.jet.kafka.KafkaProcessors
-
Returns a supplier of processors for
KafkaSinks.kafka(DataConnectionRef, FunctionEx)
. - writeKafkaP(DataConnectionRef, String, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends V>, boolean) - Static method in class com.hazelcast.jet.kafka.KafkaProcessors
-
Returns a supplier of processors for
KafkaSinks.kafka(DataConnectionRef, String, FunctionEx, FunctionEx)
. - writeKafkaP(DataConnectionRef, Properties, FunctionEx<? super T, ? extends ProducerRecord<K, V>>, boolean) - Static method in class com.hazelcast.jet.kafka.KafkaProcessors
-
Returns a supplier of processors for
KafkaSinks.kafka(Properties, FunctionEx)
. - writeKafkaP(DataConnectionRef, Properties, String, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends V>, boolean) - Static method in class com.hazelcast.jet.kafka.KafkaProcessors
-
Returns a supplier of processors for
KafkaSinks.kafka(DataConnectionRef, Properties, String, FunctionEx, FunctionEx)
. - writeKafkaP(Properties, FunctionEx<? super T, ? extends ProducerRecord<K, V>>, boolean) - Static method in class com.hazelcast.jet.kafka.KafkaProcessors
-
Returns a supplier of processors for
KafkaSinks.kafka(Properties, FunctionEx)
. - writeKafkaP(Properties, String, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends V>, boolean) - Static method in class com.hazelcast.jet.kafka.KafkaProcessors
-
Returns a supplier of processors for
KafkaSinks.kafka(Properties, String, FunctionEx, FunctionEx)
. - writeKeyValueTypes(ObjectDataOutput) - Method in class com.hazelcast.config.CacheConfig
- writeListenerConfigurations(ObjectDataOutput) - Method in class com.hazelcast.config.CacheConfig
- writeListP(String) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for
Sinks.list(String)
. - writeLoggerP() - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
- writeLoggerP(FunctionEx<T, ? extends CharSequence>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
Returns a meta-supplier of processors for a sink vertex that logs all the data items it receives.
- writeLong(String, long) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes a primitive long.
- writeLongArray(long[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
- writeLongArray(String, long[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes a primitive long-array.
- writeMapP(MapSinkConfiguration<T, K, V>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors
- writeMapP(String) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for
Sinks.map(String)
. - writeMapP(String, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends V>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for
Sinks.map(String, FunctionEx, FunctionEx)
. - writeMode(WriteMode) - Method in class com.hazelcast.jet.mongodb.MongoSinkBuilder
-
Sets write mode used by the connector.
- WriteMode - Enum Class in com.hazelcast.jet.mongodb
-
Defines allowed operations.
- writeNullableBoolean(String, Boolean) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a nullable boolean.
- writeNullableFloat32(String, Float) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a nullable 32-bit IEEE 754 floating point number.
- writeNullableFloat64(String, Double) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a nullable 64-bit IEEE 754 floating point number.
- writeNullableInt16(String, Short) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a nullable 16-bit two's complement signed integer.
- writeNullableInt32(String, Integer) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a nullable 32-bit two's complement signed integer.
- writeNullableInt64(String, Long) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a nullable 64-bit two's complement signed integer.
- writeNullableInt8(String, Byte) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a nullable 8-bit two's complement signed integer.
- writeNullPortable(String, int, int) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.To write a null portable value, user needs to provide class and factoryIds of related class.
- writeObject(ObjectDataOutput) - Method in class com.hazelcast.jet.accumulator.LinTrendAccumulator
-
Serializes this accumulator.
- writeObject(Object) - Method in interface com.hazelcast.nio.ObjectDataOutput
- writeObservableP(String) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for
Sinks.observable(java.lang.String)
. - writePortable(PortableWriter) - Method in interface com.hazelcast.nio.serialization.Portable
-
Deprecated.Serialize this portable object using PortableWriter
- writePortable(String, Portable) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes a Portable.
- writePortableArray(String, Portable[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes a an array of Portables.
- writeRemoteCacheP(String, ClientConfig) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for
Sinks.remoteCache(String, ClientConfig)
. - writeRemoteListP(String, ClientConfig) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for
Sinks.remoteList(String, ClientConfig)
. - writeRemoteMapP(String, ClientConfig) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for
Sinks.remoteMap(String, ClientConfig)
. - writeRemoteMapP(String, ClientConfig, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends V>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for
Sinks.remoteMap(String, ClientConfig, FunctionEx, FunctionEx)
. - writeShort(String, short) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes a primitive short.
- writeShortArray(short[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
- writeShortArray(String, short[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes a primitive short-array.
- writeSocketP(String, int, FunctionEx<? super T, ? extends String>, Charset) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for
Sinks.socket(String, int)
. - writeString(String) - Method in interface com.hazelcast.nio.ObjectDataOutput
- writeString(String, String) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a UTF-8 encoded string.
- writeString(String, String) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes a UTF string.
- writeStringArray(String[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
- writeStringArray(String, String[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes a String-array.
- writeTenant(ObjectDataOutput) - Method in class com.hazelcast.config.CacheConfig
- writeTime(String, LocalTime) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a time consisting of hour, minute, second, and nanoseconds.
- writeTime(String, LocalTime) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Write a time field consisting of hour, minute, seconds and nanos parts
- writeTimeArray(String, LocalTime[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes an array of Time's
- writeTimestamp(String, LocalDateTime) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a timestamp consisting of date and time.
- writeTimestamp(String, LocalDateTime) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes a timestamp field consisting of year, month of the year, day of the month, hour, minute, seconds, nanos parts
- writeTimestampArray(String, LocalDateTime[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes an array of Timestamp's
- writeTimestampWithTimezone(String, OffsetDateTime) - Method in interface com.hazelcast.nio.serialization.compact.CompactWriter
-
Writes a timestamp with timezone consisting of date, time and timezone offset.
- writeTimestampWithTimezone(String, OffsetDateTime) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes a timestamp with timezone field consisting of year, month of the year, day of the month, offset seconds, hour, minute, seconds, nanos parts
- writeTimestampWithTimezoneArray(String, OffsetDateTime[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.Writes an array of TimestampWithTimezone's
- writeTo(Sink<? super T>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
-
Attaches a sink stage, one that accepts data but doesn't emit any.
- writeTo(Sink<? super T>, GeneralStage<? extends T>, GeneralStage<? extends T>, GeneralStage<? extends T>...) - Method in interface com.hazelcast.jet.pipeline.Pipeline
-
Attaches the supplied sink to two or more pipeline stages.
- writeUTF(String) - Method in interface com.hazelcast.nio.ObjectDataOutput
-
Deprecated.for the sake of better naming. Use
ObjectDataOutput.writeString(String)
instead - writeUTF(String, String) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.for the sake of better naming. Use
PortableWriter.writeString(String, String)
instead. - writeUTFArray(String[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
-
Deprecated.for the sake of better naming. Use
ObjectDataOutput.writeStringArray(String[])
instead - writeUTFArray(String, String[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Deprecated.for the sake of better naming. Use
PortableWriter.writeStringArray(String, String[])
instead. - WrongTargetException - Exception in com.hazelcast.spi.exception
-
A
RetryableHazelcastException
indicating that an operation is executed on a wrong member. - WrongTargetException(Member, Member, int, int, String) - Constructor for exception com.hazelcast.spi.exception.WrongTargetException
- WrongTargetException(Member, Member, int, int, String, String) - Constructor for exception com.hazelcast.spi.exception.WrongTargetException
- WrongTargetException(String) - Constructor for exception com.hazelcast.spi.exception.WrongTargetException
X
- XmlClientConfigBuilder - Class in com.hazelcast.client.config
-
Loads the
ClientConfig
using XML. - XmlClientConfigBuilder() - Constructor for class com.hazelcast.client.config.XmlClientConfigBuilder
-
Loads the client config using the following resolution mechanism: first it checks if a system property 'hazelcast.client.config' is set.
- XmlClientConfigBuilder(XmlClientConfigLocator) - Constructor for class com.hazelcast.client.config.XmlClientConfigBuilder
-
Constructs a
XmlClientConfigBuilder
that loads the configuration with the providedXmlClientConfigLocator
. - XmlClientConfigBuilder(File) - Constructor for class com.hazelcast.client.config.XmlClientConfigBuilder
- XmlClientConfigBuilder(InputStream) - Constructor for class com.hazelcast.client.config.XmlClientConfigBuilder
- XmlClientConfigBuilder(String) - Constructor for class com.hazelcast.client.config.XmlClientConfigBuilder
- XmlClientConfigBuilder(URL) - Constructor for class com.hazelcast.client.config.XmlClientConfigBuilder
- XmlClientFailoverConfigBuilder - Class in com.hazelcast.client.config
-
Loads the
ClientFailoverConfig
using XML. - XmlClientFailoverConfigBuilder() - Constructor for class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
-
Loads the client failover config using the following resolution mechanism: first it checks if a system property 'hazelcast.client.failover.config' is set.
- XmlClientFailoverConfigBuilder(XmlClientFailoverConfigLocator) - Constructor for class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
-
Constructs a
XmlClientFailoverConfigBuilder
that loads the configuration with the providedXmlClientFailoverConfigLocator
. - XmlClientFailoverConfigBuilder(File) - Constructor for class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
- XmlClientFailoverConfigBuilder(InputStream) - Constructor for class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
- XmlClientFailoverConfigBuilder(String) - Constructor for class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
- XmlClientFailoverConfigBuilder(URL) - Constructor for class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
- XmlConfigBuilder - Class in com.hazelcast.config
-
An XML
ConfigBuilder
implementation. - XmlConfigBuilder() - Constructor for class com.hazelcast.config.XmlConfigBuilder
-
Constructs a XmlConfigBuilder that tries to find a usable XML configuration file.
- XmlConfigBuilder(XmlConfigLocator) - Constructor for class com.hazelcast.config.XmlConfigBuilder
-
Constructs a
XmlConfigBuilder
that loads the configuration with the providedXmlConfigLocator
. - XmlConfigBuilder(InputStream) - Constructor for class com.hazelcast.config.XmlConfigBuilder
-
Constructs a XmlConfigBuilder that reads from the given InputStream.
- XmlConfigBuilder(String) - Constructor for class com.hazelcast.config.XmlConfigBuilder
-
Constructs a XmlConfigBuilder that reads from the provided XML file.
- XmlConfigBuilder(URL) - Constructor for class com.hazelcast.config.XmlConfigBuilder
-
Constructs a XMLConfigBuilder that reads from the given URL.
- XmlGenerator(StringBuilder) - Constructor for class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
- xmlToJavaName(String) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
Y
- YamlClientConfigBuilder - Class in com.hazelcast.client.config
-
Loads the
ClientConfig
using YAML. - YamlClientConfigBuilder() - Constructor for class com.hazelcast.client.config.YamlClientConfigBuilder
-
Loads the client config using the following resolution mechanism: first it checks if a system property 'hazelcast.client.config' is set.
- YamlClientConfigBuilder(YamlClientConfigLocator) - Constructor for class com.hazelcast.client.config.YamlClientConfigBuilder
-
Constructs a
YamlClientConfigBuilder
that loads the configuration with the providedYamlClientConfigLocator
. - YamlClientConfigBuilder(File) - Constructor for class com.hazelcast.client.config.YamlClientConfigBuilder
- YamlClientConfigBuilder(InputStream) - Constructor for class com.hazelcast.client.config.YamlClientConfigBuilder
- YamlClientConfigBuilder(String) - Constructor for class com.hazelcast.client.config.YamlClientConfigBuilder
- YamlClientConfigBuilder(URL) - Constructor for class com.hazelcast.client.config.YamlClientConfigBuilder
- YamlClientFailoverConfigBuilder - Class in com.hazelcast.client.config
-
Loads the
ClientFailoverConfig
using YAML. - YamlClientFailoverConfigBuilder() - Constructor for class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
-
Loads the client failover config using the following resolution mechanism: first it checks if a system property 'hazelcast.client.failover.config' is set.
- YamlClientFailoverConfigBuilder(YamlClientFailoverConfigLocator) - Constructor for class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
-
Constructs a
YamlClientFailoverConfigBuilder
that loads the configuration with the providedYamlClientFailoverConfigLocator
. - YamlClientFailoverConfigBuilder(File) - Constructor for class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
- YamlClientFailoverConfigBuilder(InputStream) - Constructor for class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
- YamlClientFailoverConfigBuilder(String) - Constructor for class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
- YamlClientFailoverConfigBuilder(URL) - Constructor for class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
- YamlConfigBuilder - Class in com.hazelcast.config
-
A YAML
ConfigBuilder
implementation. - YamlConfigBuilder() - Constructor for class com.hazelcast.config.YamlConfigBuilder
-
Constructs a YamlConfigBuilder that tries to find a usable YAML configuration file.
- YamlConfigBuilder(YamlConfigLocator) - Constructor for class com.hazelcast.config.YamlConfigBuilder
-
Constructs a
YamlConfigBuilder
that loads the configuration with the providedYamlConfigLocator
. - YamlConfigBuilder(InputStream) - Constructor for class com.hazelcast.config.YamlConfigBuilder
-
Constructs a YAMLConfigBuilder that reads from the given InputStream.
- YamlConfigBuilder(String) - Constructor for class com.hazelcast.config.YamlConfigBuilder
-
Constructs a YamlConfigBuilder that reads from the provided YAML file.
- YamlConfigBuilder(URL) - Constructor for class com.hazelcast.config.YamlConfigBuilder
-
Constructs a YamlConfigBuilder that reads from the given URL.
Z
- ZONE_AWARE - Enum constant in enum class com.hazelcast.config.PartitionGroupConfig.MemberGroupType
-
Zone Aware.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form