- AbstractCacheConfig<K,V> - Class in com.hazelcast.config
-
- AbstractCacheConfig() - Constructor for class com.hazelcast.config.AbstractCacheConfig
-
- AbstractCacheConfig(CompleteConfiguration<K, V>) - Constructor for class com.hazelcast.config.AbstractCacheConfig
-
- AbstractClusterLoginConfig<T extends AbstractClusterLoginConfig<T>> - Class in com.hazelcast.config.security
-
- AbstractClusterLoginConfig() - Constructor for class com.hazelcast.config.security.AbstractClusterLoginConfig
-
- AbstractDiscoveryStrategy - Class in com.hazelcast.spi.discovery
-
An common abstract superclass for
DiscoveryStrategy
implementations,
offering convenient access to configuration properties (which may be overridden
on the system's environment or JVM properties), as well as a
ILogger
instance.
- AbstractDiscoveryStrategy(ILogger, Map<String, Comparable>) - Constructor for class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
-
- AbstractFactoryWithPropertiesConfig<T extends AbstractFactoryWithPropertiesConfig<T>> - Class in com.hazelcast.config
-
Configuration base for config types with a factory class and its properties.
- AbstractFactoryWithPropertiesConfig() - Constructor for class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
-
- AbstractIMapEvent - Class in com.hazelcast.map
-
The abstract class for a map event
IMapEvent
.
- AbstractIMapEvent(Object, Member, int) - Constructor for class com.hazelcast.map.AbstractIMapEvent
-
Constructs a prototypical map Event.
- AbstractLoadBalancer - Class in com.hazelcast.client.util
-
- AbstractLoadBalancer() - Constructor for class com.hazelcast.client.util.AbstractLoadBalancer
-
- AbstractLogger - Class in com.hazelcast.logging
-
Abstract
ILogger
implementation that provides implementations for convenience methods like
finest, info, warning and severe.
- AbstractLogger() - Constructor for class com.hazelcast.logging.AbstractLogger
-
- AbstractPbeReplacer - Class in com.hazelcast.config.replacer
-
The common parent for
ConfigReplacer
implementations which allow to mask values by encrypting the value.
- AbstractPbeReplacer() - Constructor for class com.hazelcast.config.replacer.AbstractPbeReplacer
-
- AbstractProcessor - Class in com.hazelcast.jet.core
-
Base class to implement custom processors.
- AbstractProcessor() - Constructor for class com.hazelcast.jet.core.AbstractProcessor
-
- AbstractProcessor.FlatMapper<T,R> - Class in com.hazelcast.jet.core
-
- AbstractSymmetricEncryptionConfig<T extends AbstractSymmetricEncryptionConfig> - Class in com.hazelcast.config
-
Base class for symmetric encryption configuration classes.
- AbstractSymmetricEncryptionConfig() - Constructor for class com.hazelcast.config.AbstractSymmetricEncryptionConfig
-
- AbstractWanPublisherConfig - Class in com.hazelcast.config
-
Base class for WAN publisher configuration.
- AbstractWanPublisherConfig() - Constructor for class com.hazelcast.config.AbstractWanPublisherConfig
-
- AbstractXmlConfigBuilder - Class in com.hazelcast.config
-
Contains logic for replacing system variables in the XML file and importing XML files from different locations.
- AbstractXmlConfigBuilder() - Constructor for class com.hazelcast.config.AbstractXmlConfigBuilder
-
- AbstractXmlConfigBuilder.ConfigType - Enum in com.hazelcast.config
-
- AbstractXmlConfigHelper - Class in com.hazelcast.config
-
Contains Hazelcast XML Configuration helper methods and variables.
- AbstractXmlConfigHelper() - Constructor for class com.hazelcast.config.AbstractXmlConfigHelper
-
- AbstractYamlConfigBuilder - Class in com.hazelcast.config
-
Contains logic for replacing system variables in the YAML file and importing YAML files from different locations.
- AbstractYamlConfigBuilder() - Constructor for class com.hazelcast.config.AbstractYamlConfigBuilder
-
- accept(T, U) - Method in interface com.hazelcast.function.BiConsumerEx
-
- accept(T) - Method in interface com.hazelcast.function.ConsumerEx
-
- 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.
- acceptEx(T, U) - Method in interface com.hazelcast.function.BiConsumerEx
-
- acceptEx(T) - Method in interface com.hazelcast.function.ConsumerEx
-
- acceptsPaddingOnRead() - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
-
- accumulate(I) - Method in interface com.hazelcast.aggregation.Aggregator
-
Accumulates the given entries.
- 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(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).
- 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(Tag<T>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
-
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() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation1
-
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.
- acquire() - Method in interface com.hazelcast.cp.ISemaphore
-
Acquires a permit if one is available, and returns immediately,
reducing the number of available permits by one.
- acquire(int) - Method in interface com.hazelcast.cp.ISemaphore
-
Acquires the given number of permits if they are available,
and returns immediately, reducing the number of available permits
by the given amount.
- ACTION_ACQUIRE - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_ADD - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_AGGREGATE - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_ALL - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_CREATE - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_DESTROY - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_INDEX - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_INTERCEPT - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_LISTEN - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_LOCK - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_MODIFY - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_PROJECTION - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_PUBLISH - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_PUT - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_READ - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_RELEASE - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_REMOVE - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_USER_CODE_DEPLOY - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ActionConstants - Class in com.hazelcast.security.permission
-
- actions - Variable in class com.hazelcast.security.permission.InstancePermission
-
- add(Object) - Method in interface com.hazelcast.cardinality.CardinalityEstimator
-
Add a new object in the estimation set.
- add(CompletionStage<E>) - Method in class com.hazelcast.core.Pipelining
-
Adds a future to this Pipelining or blocks until there is capacity to add the future to the Pipelining.
- add(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(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(Object) - Method in class com.hazelcast.jet.core.test.TestInbox
-
Convenience for inbox.queue().add(o)
- 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<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<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>, 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(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(T) - Method in interface com.hazelcast.jet.pipeline.SourceBuilder.SourceBuffer
-
Adds an item to the buffer.
- add(T, long) - Method in interface com.hazelcast.jet.pipeline.SourceBuilder.TimestampedSourceBuffer
-
Adds an item to the buffer, assigning a timestamp to it.
- 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(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(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(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(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(E) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
-
Adds an item to the tail of the Ringbuffer.
- add(Permission) - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
-
- add(Permission) - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
-
- add(PermissionCollection) - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
-
- add(Permission) - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
-
- add(Object) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
-
Adds an item to the tail of the ringbuffer.
- add(E) - Method in interface com.hazelcast.transaction.TransactionalList
-
Adds a new item to the transactional list.
- add(E) - Method in interface com.hazelcast.transaction.TransactionalSet
-
Add new item to transactional set.
- 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(Object) - Method in interface com.hazelcast.cardinality.CardinalityEstimator
-
Add a new object in the estimation set.
- addAsync(E, OverflowPolicy) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
-
- addAttribute(String) - Method in class com.hazelcast.config.IndexConfig
-
Adds an index attribute with the given.
- addAttributeConfig(AttributeConfig) - Method in class com.hazelcast.config.MapConfig
-
- addAttributeInternal(String) - Method in class com.hazelcast.config.IndexConfig
-
- addBatchReplicationPublisherConfig(WanBatchPublisherConfig) - Method in class com.hazelcast.config.WanReplicationConfig
-
Adds a WAN publisher configuration using the built-in batching WAN
implementation to this WAN replication.
- addBooleanArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addBooleanField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addByteArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addByteField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addCacheConfig(CacheSimpleConfig) - Method in class com.hazelcast.config.Config
-
Adds the cache configuration.
- addCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.config.AbstractCacheConfig
-
Add a configuration for a CacheEntryListener
.
- addCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in interface com.hazelcast.config.CacheConfiguration
-
Add a configuration for a CacheEntryListener
.
- addCachePartitionLostListenerConfig(CachePartitionLostListenerConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Adds the CachePartitionLostListenerConfig to partitionLostListenerConfigs.
- addCardinalityEstimatorConfig(CardinalityEstimatorConfig) - Method in class com.hazelcast.config.Config
-
Adds the cardinality estimator configuration.
- addCharArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addCharField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addClass(String) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
-
- addClass(Class) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
-
- 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.
- addClassDefinition(ClassDefinition) - Method in class com.hazelcast.config.SerializationConfig
-
- addClasses(String...) - Method in class com.hazelcast.config.ClassFilter
-
- 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.
- 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.
- addClassTag(Class<? extends Object>, Tag) - Method in class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter
-
Define a tag for the Class
to serialize.
- addClientConfig(ClientConfig) - Method in class com.hazelcast.client.config.ClientFailoverConfig
-
Adds the client config to the end of the alternative client configurations list.
- addClientListener(ClientListener) - Method in interface com.hazelcast.client.ClientService
-
Adds a ClientListener.
- addClientPermissionConfig(PermissionConfig) - Method in class com.hazelcast.config.SecurityConfig
-
- addCustomPublisherConfig(WanCustomPublisherConfig) - Method in class com.hazelcast.config.WanReplicationConfig
-
Adds a custom WAN publisher implementation configuration to this WAN
replication.
- addDataSerializableFactory(int, DataSerializableFactory) - Method in class com.hazelcast.config.SerializationConfig
-
- addDataSerializableFactoryClass(int, String) - Method in class com.hazelcast.config.SerializationConfig
-
- addDataSerializableFactoryClass(int, Class<? extends DataSerializableFactory>) - Method in class com.hazelcast.config.SerializationConfig
-
- addDateArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
Adds an array of Date's to the class definition
- addDateField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
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
-
Adds an array of Decimal's to the class definition
- addDecimalField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
Adds a decimal which is arbitrary precision and scale floating-point number to the class definition
- 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
-
- addDistributedObjectListener(DistributedObjectListener) - Method in interface com.hazelcast.core.HazelcastInstance
-
Adds a Distributed Object listener which will be notified when a
new
DistributedObject
will be created or destroyed.
- addDoubleArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addDoubleField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addDurableExecutorConfig(DurableExecutorConfig) - Method in class com.hazelcast.config.Config
-
Adds the durable executor configuration.
- addEndpoint(String) - Method in class com.hazelcast.config.PermissionConfig
-
- addEntryListener(MapListener, boolean) - Method in interface com.hazelcast.map.IMap
-
- addEntryListener(MapListener, K, boolean) - Method in interface com.hazelcast.map.IMap
-
- addEntryListener(MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.map.IMap
-
- addEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.map.IMap
-
- addEntryListener(MapListener, boolean) - Method in interface com.hazelcast.map.QueryCache
-
- addEntryListener(MapListener, K, boolean) - Method in interface com.hazelcast.map.QueryCache
-
- addEntryListener(MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.map.QueryCache
-
- addEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.map.QueryCache
-
- addEntryListener(EntryListener<K, V>, boolean) - Method in interface com.hazelcast.multimap.MultiMap
-
Adds an entry listener for this multimap.
- addEntryListener(EntryListener<K, V>, K, boolean) - Method in interface com.hazelcast.multimap.MultiMap
-
Adds the specified entry listener for the specified key.
- addEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
-
Adds an entry listener for this map.
- addEntryListener(EntryListener<K, V>, K) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
-
Adds the specified entry listener for the specified key.
- addEntryListener(EntryListener<K, V>, Predicate<K, V>) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
-
Adds an continuous entry listener for this map.
- addEntryListener(EntryListener<K, V>, Predicate<K, V>, K) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
-
Adds an continuous entry listener for this map.
- addEntryListenerConfig(CacheSimpleEntryListenerConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
-
- addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MapConfig
-
- addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MultiMapConfig
-
Adds an entry listener to this MultiMap (listens for when entries are added or removed).
- addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.QueryCacheConfig
-
- 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
-
- 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.
- addFlattenedActiveParsers(List<JsonParser>) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserSequence
-
- addFloatArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addFloatField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addGroupAvailabilityListener(CPGroupAvailabilityListener) - Method in interface com.hazelcast.cp.CPSubsystem
-
Registers a new CPGroupAvailabilityListener to listen CP group availability changes.
- addImplicitResolver(Tag, Pattern, String) - Method in class com.hazelcast.org.snakeyaml.engine.v2.resolver.JsonScalarResolver
-
- addImplicitResolvers() - Method in class com.hazelcast.org.snakeyaml.engine.v2.resolver.JsonScalarResolver
-
- addIndex(IndexType, String...) - Method in interface com.hazelcast.map.IMap
-
Convenient method to add an index to this map with the given type and attributes.
- addIndex(IndexConfig) - Method in interface com.hazelcast.map.IMap
-
Adds an index to this map for the specified entries so
that queries can run faster.
- addIndex(IndexType, String...) - Method in interface com.hazelcast.map.QueryCache
-
- addIndex(IndexConfig) - Method in interface com.hazelcast.map.QueryCache
-
- addIndexConfig(IndexConfig) - Method in class com.hazelcast.config.MapConfig
-
- addIndexConfig(IndexConfig) - Method in class com.hazelcast.config.QueryCacheConfig
-
- 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
-
- addInterceptor(MapInterceptor) - Method in interface com.hazelcast.map.IMap
-
Adds an interceptor for this map.
- addInterface(String) - Method in class com.hazelcast.config.InterfacesConfig
-
Adds a new interface
- addInterface(String) - Method in class com.hazelcast.config.MemberGroupConfig
-
Adds an interface to the member group.
- addIntField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addItemListener(ItemListener<E>, boolean) - Method in interface com.hazelcast.collection.ICollection
-
Adds an item listener for this collection.
- addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.CollectionConfig
-
Adds an item listener to this collection (listens for when items are added or removed).
- addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.QueueConfig
-
Add an item listener configuration to this queue.
- addJar(String) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
-
String jarPath is searched in following order:
1.
- addJar(File) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
-
- 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(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.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.
- 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(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.
- 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
-
- addListenerConfig(SplitBrainProtectionListenerConfig) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
-
- addLocalEntryListener(MapListener) - Method in interface com.hazelcast.map.IMap
-
- addLocalEntryListener(MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.map.IMap
-
- addLocalEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.map.IMap
-
Adds a local entry listener for this map.
- addLocalEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.multimap.MultiMap
-
Adds a local entry listener for this multimap.
- addLockConfig(FencedLockConfig) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
- addLoginModuleConfig(LoginModuleConfig) - Method in class com.hazelcast.config.security.JaasAuthenticationConfig
-
- addLogListener(Level, LogListener) - Method in interface com.hazelcast.logging.LoggingService
-
- addLongArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addLongField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addMapConfig(MapConfig) - Method in class com.hazelcast.config.Config
-
Adds the map configuration.
- addMapPartitionLostListenerConfig(MapPartitionLostListenerConfig) - Method in class com.hazelcast.config.MapConfig
-
- addMember(String) - Method in class com.hazelcast.config.TcpIpConfig
-
Adds a 'well known' member.
- addMember(Member) - Method in interface com.hazelcast.spi.partitiongroup.MemberGroup
-
- addMemberGroupConfig(MemberGroupConfig) - Method in class com.hazelcast.config.PartitionGroupConfig
-
- addMembers(Collection<Member>) - Method in interface com.hazelcast.spi.partitiongroup.MemberGroup
-
- addMembershipListener(MembershipListener) - Method in interface com.hazelcast.cluster.Cluster
-
Adds MembershipListener to listen for membership updates.
- addMembershipListener(CPMembershipListener) - Method in interface com.hazelcast.cp.CPSubsystem
-
Registers a new CPMembershipListener to listen CP membership changes.
- addMessageListener(MessageListener<E>) - Method in interface com.hazelcast.topic.ITopic
-
Subscribes to this topic.
- addMessageListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.ReliableTopicConfig
-
Adds a message listener (listens for when messages are added or removed)
to this reliable topic.
- addMessageListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.TopicConfig
-
Adds a message listener to this topic (listens for when messages are added or removed).
- addMigrationListener(MigrationListener) - Method in interface com.hazelcast.partition.PartitionService
-
Adds a MigrationListener.
- addMultiMapConfig(MultiMapConfig) - Method in class com.hazelcast.config.Config
-
Adds the multimap configuration.
- addName(String, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
- addName(String, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
- addName(String, int, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
- addName(String, int[], int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
- addNearCacheConfig(NearCacheConfig) - Method in class com.hazelcast.client.config.ClientConfig
-
Helper method to add a new NearCacheConfig
- addObject(T) - Method in interface com.hazelcast.query.extractor.ValueCollector
-
Collects a value passed as an argument
- addObserver(Observer<T>) - Method in interface com.hazelcast.jet.Observable
-
Registers an
Observer
to this
Observable
.
- addOutboundPort(int) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Add outbound port to the outbound port list
- addOutboundPort(int) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
-
- addOutboundPort(int) - Method in class com.hazelcast.config.EndpointConfig
-
- addOutboundPort(int) - Method in class com.hazelcast.config.NetworkConfig
-
- addOutboundPort(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
- 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
-
- 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(String, Object) - Method in interface com.hazelcast.auditlog.EventBuilder
-
Adds single event parameter to the parameters Map.
- addParameter(Object) - Method in class com.hazelcast.sql.SqlStatement
-
Adds a single parameter to the end of the parameters list.
- addPartitionLostListener(CachePartitionLostListener) - Method in interface com.hazelcast.cache.ICache
-
Adds a CachePartitionLostListener.
- addPartitionLostListener(MapPartitionLostListener) - Method in interface com.hazelcast.map.IMap
-
Adds a MapPartitionLostListener.
- addPartitionLostListener(PartitionLostListener) - Method in interface com.hazelcast.partition.PartitionService
-
Adds a PartitionLostListener.
- 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
-
- addPortableFactory(int, PortableFactory) - Method in class com.hazelcast.config.SerializationConfig
-
- addPortableFactoryClass(int, Class<? extends PortableFactory>) - Method in class com.hazelcast.config.SerializationConfig
-
- addPortableFactoryClass(int, String) - Method in class com.hazelcast.config.SerializationConfig
-
- addPortableField(String, ClassDefinition) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addPrefixes(String...) - Method in class com.hazelcast.config.ClassFilter
-
- addProperty(String, Comparable) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
-
- addProperty(String, String) - Method in class com.hazelcast.config.ServiceConfig
-
- addProxyFactoryConfig(ProxyFactoryConfig) - Method in class com.hazelcast.client.config.ClientConfig
-
- addQueryCacheConfig(String, QueryCacheConfig) - Method in class com.hazelcast.client.config.ClientConfig
-
- addQueryCacheConfig(QueryCacheConfig) - Method in class com.hazelcast.config.MapConfig
-
- addQueueConfig(QueueConfig) - Method in class com.hazelcast.config.Config
-
Adds the queue configuration.
- addRealmConfig(String, RealmConfig) - Method in class com.hazelcast.client.config.ClientSecurityConfig
-
- addRealmConfig(String, RealmConfig) - Method in class com.hazelcast.config.SecurityConfig
-
- addReliableTopicConfig(ClientReliableTopicConfig) - Method in class com.hazelcast.client.config.ClientConfig
-
Adds a ClientReliableTopicConfig.
- addReliableTopicConfig(ReliableTopicConfig) - Method in class com.hazelcast.config.Config
-
Adds the reliable topic configuration.
- addReplicatedMapConfig(ReplicatedMapConfig) - Method in class com.hazelcast.config.Config
-
Adds the replicated map configuration.
- Address - Class in com.hazelcast.cluster
-
Represents an address of a member in the cluster.
- Address() - Constructor for class com.hazelcast.cluster.Address
-
- Address(String, int) - Constructor for class com.hazelcast.cluster.Address
-
- Address(InetAddress, int) - Constructor for class com.hazelcast.cluster.Address
-
- Address(InetSocketAddress) - Constructor for class com.hazelcast.cluster.Address
-
Creates a new Address
- Address(String, InetAddress, int) - Constructor for class com.hazelcast.cluster.Address
-
- Address(Address) - Constructor for class com.hazelcast.cluster.Address
-
- ADDRESS - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
-
Network address of the cluster member sourcing the metric.
- AddressHelper - Class in com.hazelcast.client.util
-
This is a client side utility class for working with addresses and cluster connections
- AddressPicker - Interface in com.hazelcast.instance
-
Strategy to select an
Address
that a Hazelcast cluster member binds its server socket to
and a (potentially different) address that Hazelcast will advertise to other cluster members and clients.
- 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
-
- addSerializerConfig(SerializerConfig) - Method in class com.hazelcast.config.SerializationConfig
-
- addSetConfig(SetConfig) - Method in class com.hazelcast.config.Config
-
Adds the set configuration.
- addShortArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addShortField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addSplitBrainProtectionConfig(SplitBrainProtectionConfig) - Method in class com.hazelcast.config.Config
-
Adds the split-brain protection configuration.
- addStringArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addStringField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addTimeArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
Adds an array of Time's to the class definition
- addTimeField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
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
-
Adds an array of Timestamp's to the class definition
- addTimestampField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
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
-
Adds an array of TimestampWithTimezone's to the class definition
- addTimestampWithTimezoneField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
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
- addTopicConfig(TopicConfig) - Method in class com.hazelcast.config.Config
-
Adds the topic configuration.
- addTrustedInterface(String) - Method in class com.hazelcast.config.ManagementCenterConfig
-
Adds a trusted interface.
- addTrustedInterface(String) - Method in class com.hazelcast.config.MulticastConfig
-
Adds a trusted interface.
- addTrustedInterface(String) - Method in interface com.hazelcast.config.TrustedInterfacesConfigurable
-
Adds trusted interface (i.e.
- addUTFArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addUTFField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addWanEndpointConfig(EndpointConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
-
Adds the given WAN EndpointConfig
to the endpoints configuration.
- addWanReplicationConfig(WanReplicationConfig) - Method in class com.hazelcast.config.Config
-
- 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(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(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
- 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(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(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(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(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.
- 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(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(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.
- aggregate3(BatchStage<T1>, BatchStage<T2>, AggregateOperation3<? super T, ? super T1, ? super T2, ?, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
-
Attaches a stage that performs the given aggregate operation over all
the items it receives from this stage as well as stage1
and
stage2
you supply.
- aggregate3(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(BatchStageWithKey<T1, ? extends K>, BatchStageWithKey<T2, ? extends K>, AggregateOperation3<? super T, ? super T1, ? super T2, ?, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
-
Attaches a stage that performs the given cogroup-and-aggregate operation
over the items from this stage as well as stage1
and stage2
you supply.
- aggregate3(AggregateOperation1<? super T, ?, ? extends R0>, BatchStageWithKey<T1, ? extends K>, AggregateOperation1<? super T1, ?, ? extends R1>, BatchStageWithKey<T2, ? extends K>, AggregateOperation1<? super T2, ?, ? extends R2>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
-
Attaches a stage that performs the given cogroup-and-aggregate
transformation of the items from this stage as well as stage1
and stage2
you supply.
- aggregate3(StreamStageWithKey<T1, ? extends K>, StreamStageWithKey<T2, ? extends K>, AggregateOperation3<? super T, ? super T1, ? super T2, ?, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StageWithKeyAndWindow
-
Attaches a stage that performs the given cogroup-and-aggregate operation
over the items from this stage as well as stage1
and stage2
you supply.
- 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(StreamStage<T1>, StreamStage<T2>, AggregateOperation3<? super T, ? super T1, ? super T2, ?, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StageWithWindow
-
Attaches a stage that performs the given aggregate operation over the
items it receives from this stage as well as stage1
and stage2
you supply.
- aggregate3(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.
- 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.
- 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() - 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() - 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() - 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() - 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.
- 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<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.
- 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(AggregateOperation1<? super T0, A0, ? extends R0>, AggregateOperation1<? super T1, A1, ? extends R1>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
- 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.
- 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(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
-
- 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).
- AGGREGATION_ACCUMULATION_PARALLEL_EVALUATION - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Run aggregation accumulation for multiple entries in parallel.
- Aggregator<I,R> - Interface in com.hazelcast.aggregation
-
Defines a contract for all aggregators.
- Aggregators - Class in com.hazelcast.aggregation
-
A utility class to create basic
Aggregator
instances.
- AliasedDiscoveryConfig<T extends AliasedDiscoveryConfig<T>> - Class in com.hazelcast.config
-
Configuration for discovery strategy aliases, e.g.
- AliasedDiscoveryConfig(String) - Constructor for class com.hazelcast.config.AliasedDiscoveryConfig
-
- AliasedDiscoveryConfig(AliasedDiscoveryConfig) - Constructor for class com.hazelcast.config.AliasedDiscoveryConfig
-
- AliasEvent - Class in com.hazelcast.org.snakeyaml.engine.v2.events
-
Marks the inclusion of a previously anchored node.
- AliasEvent(Optional<Anchor>, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.events.AliasEvent
-
- AliasEvent(Optional<Anchor>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.events.AliasEvent
-
- AliasToken - Class in com.hazelcast.org.snakeyaml.engine.v2.tokens
-
- AliasToken(Anchor, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.tokens.AliasToken
-
- allocBase64Buffer() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
Method for recycling or allocation byte buffer of "base 64 encode/decode" type.
- allocBase64Buffer(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
- allocByteBuffer(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
-
- allocByteBuffer(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
-
- allocCharBuffer(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
-
- allocCharBuffer(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
-
- allocConcatBuffer() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
- allocNameCopyBuffer(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
- allocReadIOBuffer() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
Method for recycling or allocation byte buffer of "read I/O" type.
- allocReadIOBuffer(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
- allocTokenBuffer() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
- allocTokenBuffer(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
- allocWriteEncodingBuffer() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
Method for recycling or allocation byte buffer of "write encoding" type.
- allocWriteEncodingBuffer(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
- 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, R0>, AggregateOperation1<? super T, A1, R1>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
- allOf(AggregateOperation1<? super T, A0, ? extends R0>, AggregateOperation1<? super T, A1, ? extends R1>, AggregateOperation1<? super T, A2, ? extends R2>, TriFunction<? super R0, ? super R1, ? super R2, ? extends R>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that is a composite of three aggregate
operations.
- allOf(AggregateOperation1<? super T, A0, ? extends R0>, AggregateOperation1<? super T, A1, ? extends R1>, AggregateOperation1<? super T, A2, ? extends R2>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
- AllOfAggregationBuilder<T> - Class in com.hazelcast.jet.aggregate
-
Offers a step-by-step API to create a composite of multiple aggregate
operations.
- allOfBuilder() - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns a builder object that helps you create a composite of multiple
aggregate operations.
- AllPermissions - Class in com.hazelcast.security.permission
-
- AllPermissions() - Constructor for class com.hazelcast.security.permission.AllPermissions
-
- AllPermissions.AllPermissionsCollection - Class in com.hazelcast.security.permission
-
- AllPermissionsCollection() - Constructor for class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
-
- AllPermissionsCollection(boolean) - Constructor for class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
-
- allReplicasInPartitionLost() - Method in interface com.hazelcast.partition.PartitionLostEvent
-
Returns true if all replicas of a partition are lost
- allToOne(Object) - Method in class com.hazelcast.jet.core.Edge
-
Activates a special-cased
PARTITIONED
routing policy where all items will be routed to the same partition ID,
determined from the given
key
.
- ALPHA - Static variable in class com.hazelcast.org.snakeyaml.engine.v2.common.CharConstants
-
- alter(IFunction<Long, Long>) - Method in interface com.hazelcast.cp.IAtomicLong
-
Alters the currently stored value by applying a function on it.
- alter(IFunction<E, E>) - Method in interface com.hazelcast.cp.IAtomicReference
-
Alters the currently stored reference by applying a function on it.
- alterAndGet(IFunction<Long, Long>) - Method in interface com.hazelcast.cp.IAtomicLong
-
Alters the currently stored value by applying a function on it and
gets the result.
- alterAndGet(IFunction<E, E>) - Method in interface com.hazelcast.cp.IAtomicReference
-
Alters the currently stored reference by applying a function on it and
gets the result.
- alterAndGetAsync(IFunction<Long, Long>) - Method in interface com.hazelcast.cp.IAtomicLong
-
Alters the currently stored value by applying a function on it and gets
the result.
- alterAndGetAsync(IFunction<E, E>) - Method in interface com.hazelcast.cp.IAtomicReference
-
Alters the currently stored reference by applying a function on it and
gets the result.
- alterAsync(IFunction<Long, Long>) - Method in interface com.hazelcast.cp.IAtomicLong
-
Alters the currently stored value by applying a function on it.
- alterAsync(IFunction<E, E>) - Method in interface com.hazelcast.cp.IAtomicReference
-
Alters the currently stored reference by applying a function on it.
- alwaysFalse() - Static method in interface com.hazelcast.function.PredicateEx
-
Returns a predicate that always evaluates to false
.
- alwaysFalse() - Static method in class com.hazelcast.query.Predicates
-
Creates an always false predicate that will filter out all items.
- alwaysTrue() - Static method in interface com.hazelcast.function.PredicateEx
-
Returns a predicate that always evaluates to true
.
- alwaysTrue() - Static method in class com.hazelcast.query.Predicates
-
Creates an always true predicate that will pass all items.
- Anchor - Class in com.hazelcast.org.snakeyaml.engine.v2.common
-
Value inside Anchor and Alias
- Anchor(String) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.common.Anchor
-
- AnchorGenerator - Interface in com.hazelcast.org.snakeyaml.engine.v2.serializer
-
- AnchorNode - Class in com.hazelcast.org.snakeyaml.engine.v2.nodes
-
This class is only used during representation (dumping)
- AnchorNode(Node) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.nodes.AnchorNode
-
- AnchorToken - Class in com.hazelcast.org.snakeyaml.engine.v2.tokens
-
- AnchorToken(Anchor, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.tokens.AnchorToken
-
- and(MemberSelector...) - Static method in class com.hazelcast.cluster.memberselector.MemberSelectors
-
Selects a member when all of the selectors succeed
- and(BiPredicateEx<? super T, ? super U>) - Method in interface com.hazelcast.function.BiPredicateEx
-
- and(PredicateEx<? super T>) - Method in interface com.hazelcast.function.PredicateEx
-
- and(TriPredicate<? super T, ? super U, ? super V>) - Method in interface com.hazelcast.jet.function.TriPredicate
-
Returns a composite predicate which evaluates the
equivalent of this.test(t, u, v) && other.test(t, u, v)
.
- and(Predicate) - Method in interface com.hazelcast.query.PredicateBuilder
-
- and(Predicate...) - Static method in class com.hazelcast.query.Predicates
-
Creates an and predicate that will perform the logical and operation on the given predicates
.
- andAccumulate(BiConsumerEx<? super A, ? super T>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder
-
- 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
-
- andAccumulate1(BiConsumerEx<? super A, ? super T1>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity1
-
- 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
-
- andCombine(BiConsumerEx<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity2
-
- andCombine(BiConsumerEx<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity3
-
- andCombine(BiConsumerEx<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.VarArity
-
- andDeduct(BiConsumerEx<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity1
-
Registers the
deduct
primitive.
- andDeduct(BiConsumerEx<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity2
-
Registers the
deduct
primitive.
- andDeduct(BiConsumerEx<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity3
-
Registers the
deduct
primitive.
- andDeduct(BiConsumerEx<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.VarArity
-
Registers the
deduct
primitive.
- andExport(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity1
-
Registers the
export
primitive.
- andExport(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity2
-
Registers the
export
primitive.
- andExport(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity3
-
Registers the
export
primitive.
- andExport(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.VarArity
-
Registers the
export
primitive.
- andExportFinish(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity1
-
Registers the supplied function as both the
export
and
finish
primitive.
- andExportFinish(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity2
-
Registers the supplied function as both the
export
and
finish
primitive.
- andExportFinish(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity3
-
Registers the supplied function as both the
export
and
finish
primitive.
- andExportFinish(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.VarArity
-
Registers the supplied function as both the
export
and
finish
primitive.
- andFinish(FunctionEx<? super A, ? extends R>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity1
-
Registers the
finish
primitive.
- andFinish(FunctionEx<? super A, ? extends R>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity2
-
Registers the
finish
primitive.
- andFinish(FunctionEx<? super A, ? extends R>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity3
-
Registers the
finish
primitive.
- andFinish(FunctionEx<? super A, ? extends R>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.VarArity
-
Registers the
finish
primitive.
- andThen(BiConsumerEx<? super T, ? super U>) - Method in interface com.hazelcast.function.BiConsumerEx
-
- andThen(FunctionEx<? super R, ? extends V>) - Method in interface com.hazelcast.function.BiFunctionEx
-
- andThen(ConsumerEx<? super T>) - Method in interface com.hazelcast.function.ConsumerEx
-
- andThen(FunctionEx<? super R, ? extends V>) - Method in interface com.hazelcast.function.FunctionEx
-
- andThen(FunctionEx<? super R, ? extends R_NEW>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
-
Returns a copy of this aggregate operation, but with the export
and finish
primitives composed with the supplied thenFn
.
- andThen(FunctionEx<? super R, ? extends R_NEW>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation1
-
- andThen(FunctionEx<? super R, ? extends R_NEW>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation2
-
- andThen(FunctionEx<? super R, ? extends R_NEW>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation3
-
- anyFrom(String) - Static method in class com.hazelcast.jet.json.JsonUtil
-
Converts a JSON string to an Object.
- append(char) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SegmentedStringWriter
-
- append(CharSequence) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SegmentedStringWriter
-
- append(CharSequence, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SegmentedStringWriter
-
- append(char) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.UTF8Writer
-
- append(JsonPointer) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
-
Mutant factory method that will return
`tail` if `this` instance is "empty" pointer, OR
`this` instance if `tail` is "empty" pointer, OR
Newly constructed
JsonPointer
instance that starts with all segments
of `this`, followed by all segments of `tail`.
- append(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
-
- append(char) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
- append(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
- append(String, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
- 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
-
- AppendableTraverser(int) - Constructor for class com.hazelcast.jet.core.AppendableTraverser
-
Creates an appendable traverser.
- appendDesc(StringBuilder) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
-
- appendFourBytes(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
-
- appendLabels(Set<String>) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
-
- appendProperties(Properties) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
-
- appendProperties(Map<String, ? extends Comparable>) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
-
- appendQuoted(StringBuilder, String) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.CharTypes
-
- appendQuoted(char[], int) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SerializedString
-
- appendQuoted(char[], int) - Method in interface com.hazelcast.com.fasterxml.jackson.core.SerializableString
-
Method that will append quoted characters of this String into given
buffer.
- appendQuotedUTF8(byte[], int) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SerializedString
-
- appendQuotedUTF8(byte[], int) - Method in interface com.hazelcast.com.fasterxml.jackson.core.SerializableString
-
Method that will append quoted UTF-8 bytes of this String into given
buffer, if there is enough room; if not, returns -1.
- appendThreeBytes(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
-
- appendToken(StringBuilder, StringBuilder) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- appendTwoBytes(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
-
- appendUnquoted(char[], int) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SerializedString
-
- appendUnquoted(char[], int) - Method in interface com.hazelcast.com.fasterxml.jackson.core.SerializableString
-
Method that will append unquoted characters of this String into given
buffer.
- appendUnquotedUTF8(byte[], int) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SerializedString
-
- appendUnquotedUTF8(byte[], int) - Method in interface com.hazelcast.com.fasterxml.jackson.core.SerializableString
-
Method that will append unquoted ('raw') UTF-8 bytes of this String into given
buffer.
- apply(T) - Method in interface com.hazelcast.core.IFunction
-
- apply(IFunction<Long, R>) - Method in interface com.hazelcast.cp.IAtomicLong
-
Applies a function on the value, the actual stored value will not change.
- apply(IFunction<E, R>) - Method in interface com.hazelcast.cp.IAtomicReference
-
Applies a function on the value, the actual stored value will not
change.
- apply(T, U) - Method in interface com.hazelcast.function.BiFunctionEx
-
- apply(T, T) - Method in interface com.hazelcast.function.BinaryOperatorEx
-
- apply(T) - Method in interface com.hazelcast.function.FunctionEx
-
- apply(long, long, K, R, boolean) - Method in interface com.hazelcast.jet.core.function.KeyedWindowResultFunction
-
Applies the 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(T0, T1, T2, T3) - Method in interface com.hazelcast.jet.function.QuadFunction
-
Applies this function to the given arguments.
- apply(T0, T1, T2) - Method in interface com.hazelcast.jet.function.TriFunction
-
Applies this function to the given arguments.
- apply(FunctionEx<? super BatchStage<T>, ? extends BatchStage<R>>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
-
Transforms this
stage using the provided transformFn
and
returns the transformed stage.
- apply(FunctionEx<? super StreamStage<T>, ? extends StreamStage<R>>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
-
Transforms this
stage using the provided transformFn
and
returns the transformed stage.
- apply(String, String, String, String) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructEnv
-
Implement the logic for missing and unset variables
- apply(Map.Entry<K, V>) - Method in interface com.hazelcast.query.Predicate
-
Applies this predicate to the given map entry.
- apply(Collection<Member>) - Method in interface com.hazelcast.splitbrainprotection.SplitBrainProtectionFunction
-
Determines whether the minimum cluster size property is satisfied based on the current list of members
in the cluster.
- 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
-
- applyAsInt(T) - Method in interface com.hazelcast.function.ToIntFunctionEx
-
- applyAsIntEx(T) - Method in interface com.hazelcast.function.ToIntFunctionEx
-
- applyAsLong(T) - Method in interface com.hazelcast.function.ToLongFunctionEx
-
- applyAsLongEx(T) - Method in interface com.hazelcast.function.ToLongFunctionEx
-
- applyAsync(IFunction<Long, R>) - Method in interface com.hazelcast.cp.IAtomicLong
-
Applies a function on the value, the actual stored value will not
change.
- applyAsync(IFunction<E, R>) - Method in interface com.hazelcast.cp.IAtomicReference
-
Applies a function on the value, the actual stored value will not
change.
- applyEx(T, U) - Method in interface com.hazelcast.function.BiFunctionEx
-
- applyEx(T, T) - Method in interface com.hazelcast.function.BinaryOperatorEx
-
- applyEx(T) - Method in interface com.hazelcast.function.FunctionEx
-
- applyEx(T, long) - Method in interface com.hazelcast.jet.core.function.ObjLongBiFunction
-
- applyEx(T0, T1, T2, T3) - Method in interface com.hazelcast.jet.function.QuadFunction
-
- applyEx(T0, T1, T2) - Method in interface com.hazelcast.jet.function.TriFunction
-
- arity() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
-
Returns the number of contributing streams this operation is set up to
handle.
- ArrayStack<T> - Class in com.hazelcast.org.snakeyaml.engine.v2.common
-
General stack implementation.
- ArrayStack(int) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.common.ArrayStack
-
Create empty stack
- asBitmask() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JacksonFeatureSet
-
Accessor for underlying bitmask
- asByteArray() - Method in enum com.hazelcast.com.fasterxml.jackson.core.JsonToken
-
- asCharArray() - Method in enum com.hazelcast.com.fasterxml.jackson.core.JsonToken
-
- 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
-
- asCredentialsFactory(ClassLoader) - Method in class com.hazelcast.config.security.KerberosIdentityConfig
-
- asCredentialsFactory() - Method in class com.hazelcast.config.security.RealmConfig
-
- asCredentialsFactory(ClassLoader) - Method in class com.hazelcast.config.security.TokenIdentityConfig
-
- asCredentialsFactory(ClassLoader) - Method in class com.hazelcast.config.security.UsernamePasswordIdentityConfig
-
- asLoginModuleConfigs() - Method in interface com.hazelcast.config.security.AuthenticationConfig
-
Converts current configuration to stack of login modules.
- asLoginModuleConfigs() - Method in class com.hazelcast.config.security.DefaultAuthenticationConfig
-
- asLoginModuleConfigs() - Method in class com.hazelcast.config.security.JaasAuthenticationConfig
-
- asLoginModuleConfigs() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
-
- asLoginModuleConfigs() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- asLoginModuleConfigs() - Method in class com.hazelcast.config.security.RealmConfig
-
- asLoginModuleConfigs() - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
-
- asProperty - Variable in class com.hazelcast.com.fasterxml.jackson.core.type.WritableTypeId
-
If type id is to be embedded as a regular property, name of the property;
otherwise `null`.
- asQuotedChars() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SerializedString
-
Accessor for accessing value that has been quoted (escaped) using JSON
quoting rules (using backslash-prefixed codes) into a char array.
- asQuotedChars() - Method in interface com.hazelcast.com.fasterxml.jackson.core.SerializableString
-
Returns JSON quoted form of the String, as character array.
- asQuotedUTF8() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SerializedString
-
Accessor for accessing value that has been quoted (escaped) using JSON
quoting rules (using backslash-prefixed codes), and encoded using
UTF-8 encoding into a byte array.
- asQuotedUTF8() - Method in interface com.hazelcast.com.fasterxml.jackson.core.SerializableString
-
Returns UTF-8 encoded version of JSON-quoted String.
- 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(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.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(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 of the given items in any order.
- assertEquals(String, Object, Object) - Static method in class com.hazelcast.jet.core.test.JetAssert
-
- 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(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.AssertionSinks
-
Asserts that the previous stage emitted the exact sequence of expected
items and nothing else.
- assertOutput(int, BiConsumer<TestSupport.TestMode, List<List<Object>>>) - Method in class com.hazelcast.jet.core.test.TestSupport
-
Runs the test with the specified custom assertion.
- assertSame(String, Object, Object) - Static method in class com.hazelcast.jet.core.test.JetAssert
-
Asserts that the two given objects are the same, when compared using
the
==
operator and if not, an
AssertionError
is thrown
with the given message.
- assertTrue(String, boolean) - Static method in class com.hazelcast.jet.core.test.JetAssert
-
Asserts that the given condition is true
.
- asString() - Method in enum com.hazelcast.com.fasterxml.jackson.core.JsonToken
-
- asToken() - Method in interface com.hazelcast.com.fasterxml.jackson.core.TreeNode
-
Method that can be used for efficient type detection
when using stream abstraction for traversing nodes.
- asUnquotedUTF8() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SerializedString
-
Accessor for accessing value as is (without JSON quoting (ecaping))
encoded as UTF-8 byte array.
- asUnquotedUTF8() - Method in interface com.hazelcast.com.fasterxml.jackson.core.SerializableString
-
Returns UTF-8 encoded version of unquoted String.
- asVersion() - Method in class com.hazelcast.version.MemberVersion
-
- at(JsonPointer) - Method in interface com.hazelcast.com.fasterxml.jackson.core.TreeNode
-
Method for locating node specified by given JSON pointer instances.
- at(String) - Method in interface com.hazelcast.com.fasterxml.jackson.core.TreeNode
-
Convenience method that is functionally equivalent to:
- 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
-
- 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.
- 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(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.
- 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(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.
- 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.
- AttributeConfig - Class in com.hazelcast.config
-
Contains the configuration of a custom attribute that will be extracted from a Map's entry using a given ValueExtractor.
- AttributeConfig() - Constructor for class com.hazelcast.config.AttributeConfig
-
Creates an empty AttributeConfig.
- AttributeConfig(String, String) - Constructor for class com.hazelcast.config.AttributeConfig
-
Creates a AttributeConfig with the given attribute and ordered setting.
- AttributeConfig(AttributeConfig) - Constructor for class com.hazelcast.config.AttributeConfig
-
- AuditableEvent - Interface in com.hazelcast.auditlog
-
Observable event in the system.
- AuditlogConfig - Class in com.hazelcast.config
-
Auditlog configuration.
- AuditlogConfig() - Constructor for class com.hazelcast.config.AuditlogConfig
-
- AuditlogService - Interface in com.hazelcast.auditlog
-
- AuditlogServiceFactory - Interface in com.hazelcast.auditlog
-
- AuditlogTypeIds - Class in com.hazelcast.auditlog
-
Auditable event type identifiers.
- AUTHENTICATION_CLIENT - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
-
Event type ID: Client authentication.
- AUTHENTICATION_MEMBER - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
-
Event type ID: Member authentication.
- AUTHENTICATION_REST - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
-
Event type ID: REST authentication.
- AuthenticationConfig - Interface in com.hazelcast.config.security
-
This interface represents authentication configuration in a security realm.
- AuthenticationException - Exception in com.hazelcast.client
-
- AuthenticationException() - Constructor for exception com.hazelcast.client.AuthenticationException
-
Creates a AuthenticationException with a default message.
- AuthenticationException(String) - Constructor for exception com.hazelcast.client.AuthenticationException
-
Creates a AuthenticationException with the given message.
- AutoDetectionConfig - Class in com.hazelcast.config
-
Configuration for the Discovery Strategy Auto Detection.
- AutoDetectionConfig() - Constructor for class com.hazelcast.config.AutoDetectionConfig
-
- autoDisposable(Runnable) - Static method in class com.hazelcast.scheduledexecutor.TaskUtils
-
- autoDisposable(Callable<V>) - Static method in class com.hazelcast.scheduledexecutor.TaskUtils
-
- 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.com.fasterxml.jackson.core.io.MergedStream
-
- 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
-
- await(long, TimeUnit) - Method in interface com.hazelcast.cp.ICountDownLatch
-
Causes the current thread to wait until the latch has counted down to
zero, or an exception is thrown, or the specified waiting time elapses.
- awaitConnected(long, TimeUnit) - Method in class com.hazelcast.client.util.ClientStateListener
-
Waits until the client is connected to cluster or the timeout expires.
- awaitConnected() - Method in class com.hazelcast.client.util.ClientStateListener
-
Waits until the client is connected to cluster.
- awaitDisconnected(long, TimeUnit) - Method in class com.hazelcast.client.util.ClientStateListener
-
Waits until the client is disconnected from the cluster or the timeout expires.
- awaitDisconnected() - Method in class com.hazelcast.client.util.ClientStateListener
-
Waits until the client is disconnected from the cluster.
- 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
-
- AwsDiscoveryStrategy - Class in com.hazelcast.aws
-
- AwsDiscoveryStrategyFactory - Class in com.hazelcast.aws
-
- 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
-
- AzureDiscoveryStrategy - Class in com.hazelcast.azure
-
- AzureDiscoveryStrategyFactory - Class in com.hazelcast.azure
-
- AzureDiscoveryStrategyFactory() - Constructor for class com.hazelcast.azure.AzureDiscoveryStrategyFactory
-
- cache(String) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink that puts Map.Entry
s it receives into a Hazelcast
ICache
with the specified name.
- cache(String) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Returns a source that fetches entries from a Hazelcast ICache
with the given name and emits them as Map.Entry
.
- CACHE_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.
- CacheConfig<K,V> - Class in com.hazelcast.config
-
Contains all the configuration for the
ICache
.
- CacheConfig() - Constructor for class com.hazelcast.config.CacheConfig
-
- CacheConfig(String) - Constructor for class com.hazelcast.config.CacheConfig
-
- CacheConfig(CompleteConfiguration<K, V>) - Constructor for class com.hazelcast.config.CacheConfig
-
- CacheConfig(CacheSimpleConfig) - Constructor for class com.hazelcast.config.CacheConfig
-
- CacheConfigAccessor - Class in com.hazelcast.config
-
- CacheConfiguration<K,V> - Interface in com.hazelcast.config
-
Mutable extension to CompleteConfiguration
- CacheDeserializedValues - Enum in com.hazelcast.config
-
Control caching of de-serialized values.
- CacheEntryView<K,V> - Interface in com.hazelcast.cache
-
Entry info for cache record.
- cacheEventNewValue() - Static method in class com.hazelcast.jet.Util
-
- cacheEventToEntry() - Static method in class com.hazelcast.jet.Util
-
- CacheEventType - Enum in com.hazelcast.cache
-
Hazelcast JCache implementation's internal event types.
- CacheEvictionPolicyComparator<K,V> - Interface in com.hazelcast.cache
-
- cacheJournal(String, JournalInitialPosition, FunctionEx<? super EventJournalCacheEvent<K, V>, ? extends T>, PredicateEx<? super EventJournalCacheEvent<K, V>>) - Static method in class com.hazelcast.jet.pipeline.Sources
-
Returns a source that will stream the
EventJournalCacheEvent
events of a Hazelcast
ICache
with the specified name.
- cacheJournal(String, JournalInitialPosition) - Static method in class com.hazelcast.jet.pipeline.Sources
-
- cacheLoaderFactory - Variable in class com.hazelcast.config.AbstractCacheConfig
-
The Factory
for the CacheLoader
.
- CacheNotExistsException - Exception in com.hazelcast.cache
-
This exception class is thrown while creating CacheRecordStore
instances but the cache config does not exist on the node to create the instance on.
- CacheNotExistsException(String) - Constructor for exception com.hazelcast.cache.CacheNotExistsException
-
- CachePartitionLostListenerConfig - Class in com.hazelcast.config
-
Configuration for CachePartitionLostListener
- CachePartitionLostListenerConfig() - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfig
-
- CachePartitionLostListenerConfig(String) - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfig
-
- CachePartitionLostListenerConfig(CachePartitionLostListener) - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfig
-
- CachePartitionLostListenerConfig(CachePartitionLostListenerConfig) - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfig
-
- CachePermission - Class in com.hazelcast.security.permission
-
- CachePermission(String, String...) - Constructor for class com.hazelcast.security.permission.CachePermission
-
- 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>>)
and
Sources.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 only
CREATED
and
UPDATED
events.
- CacheSimpleConfig - Class in com.hazelcast.config
-
Simple configuration to hold parsed XML configuration.
- CacheSimpleConfig(CacheSimpleConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfig
-
- CacheSimpleConfig(String) - Constructor for class com.hazelcast.config.CacheSimpleConfig
-
Create a Cache Simple Config for a cache with a specific name.
- CacheSimpleConfig() - Constructor for class com.hazelcast.config.CacheSimpleConfig
-
- CacheSimpleConfig.ExpiryPolicyFactoryConfig - Class in com.hazelcast.config
-
Represents configuration for "ExpiryPolicyFactory".
- CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig - Class in com.hazelcast.config
-
Represents duration configuration with duration amount and time unit
for the "TimedExpiryPolicyFactoryConfig".
- CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig - Class in com.hazelcast.config
-
Represents configuration for time based "ExpiryPolicyFactory" with duration and time unit.
- CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType - Enum in com.hazelcast.config
-
Represents type of the "TimedExpiryPolicyFactoryConfig".
- CacheSimpleEntryListenerConfig - Class in com.hazelcast.config
-
Simple configuration to hold parsed listener config.
- CacheSimpleEntryListenerConfig(CacheSimpleEntryListenerConfig) - Constructor for class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- CacheSimpleEntryListenerConfig() - Constructor for class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- CacheStatistics - Interface in com.hazelcast.cache
-
Cache statistics
- CacheUtil - Class in com.hazelcast.cache
-
Utility class for various cache related operations to be used by our internal structure and end user.
- cacheWriterFactory - Variable in class com.hazelcast.config.AbstractCacheConfig
-
The Factory
for the CacheWriter
.
- calcHash(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
- calcHash(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
- calcHash(int, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
- calcHash(int[], int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
- calcHash(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
-
Implementation of a hashing method for variable length
Strings.
- calcHash(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
-
- calculateVersion(String) - Static method in class com.hazelcast.instance.BuildInfo
-
- call() - Method in class com.hazelcast.console.Echo
-
- call() - Method in class com.hazelcast.console.SimulateLoadTask
-
- CallerNotMemberException - Exception in com.hazelcast.spi.exception
-
A
RetryableHazelcastException
that indicates that an operation was sent by a machine which isn't member
in the cluster when the operation is executed.
- CallerNotMemberException(Address, Address, int, String, String) - Constructor for exception com.hazelcast.spi.exception.CallerNotMemberException
-
- CallerNotMemberException(String) - Constructor for exception com.hazelcast.spi.exception.CallerNotMemberException
-
- calloc(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
-
- cancel() - Method in interface com.hazelcast.jet.Job
-
Makes a request to cancel this job and returns.
- cancel(JetCommandLine.Verbosity, JetCommandLine.TargetsMixin, String) - Method in class com.hazelcast.jet.server.JetCommandLine
-
- cancel(boolean) - Method in interface com.hazelcast.scheduledexecutor.IScheduledFuture
-
Attempts to cancel further scheduling of this task.
- 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
-
- canGetNextDataMember() - Method in class com.hazelcast.client.util.RandomLB
-
- canGetNextDataMember() - Method in class com.hazelcast.client.util.RoundRobinLB
-
- canGetNextDataMember() - Method in class com.hazelcast.client.util.StaticLB
-
- canHandleBinaryNatively() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Introspection method that higher-level functionality may call
to see whether underlying data format can read and write binary
data natively; that is, embeded it as-is without using encodings
such as Base64.
- canHandleBinaryNatively() - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
Introspection method that higher-level functionality may call
to see whether underlying data format can read and write binary
data natively; that is, embeded it as-is without using encodings
such as Base64.
- CannotReplicateException - Exception in com.hazelcast.cp.exception
-
A
CPSubsystemException
which is thrown when an entry cannot be
replicated, which can occur in one of the following cases:
a member leaves the CP group
CP group itself is terminated
uncommitted entry count reaches to
(see
RaftAlgorithmConfig.getUncommittedEntryCountToRejectNewAppends()
)
a membership change is requested before an entry is committed
on a term
- CannotReplicateException(RaftEndpoint) - Constructor for exception com.hazelcast.cp.exception.CannotReplicateException
-
- canOmitFields() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Introspection method to call to check whether it is ok to omit
writing of Object fields or not.
- canOmitFields() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- canOmitTagInNonPlainScalar() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.ImplicitTuple
-
- canOmitTagInPlainScalar() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.ImplicitTuple
-
- canParseAsync() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- canParseAsync() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Introspection method that can be used to check whether this
factory can create non-blocking parsers: parsers that do not
use blocking I/O abstractions but instead use a
NonBlockingInputFeeder
.
- canParseAsync() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method that can be called to determine if this parser instance
uses non-blocking ("asynchronous") input access for decoding or not.
- canParseAsync() - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
Introspection method that can be used to check whether this
factory can create non-blocking parsers: parsers that do not
use blocking I/O abstractions but instead use a
NonBlockingInputFeeder
.
- canReadObjectId() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Introspection method that may be called to see if the underlying
data format supports some kind of Object Ids natively (many do not;
for example, JSON doesn't).
- canReadObjectId() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- canReadTypeId() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Introspection method that may be called to see if the underlying
data format supports some kind of Type Ids natively (many do not;
for example, JSON doesn't).
- canReadTypeId() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- canUseCharArrays() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Introspection method that can be used by base factory to check
whether access using
char[]
is something that actual
parser implementations can take advantage of, over having to
use
Reader
.
- canUseSchema(FormatSchema) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method that can be used to quickly check whether given schema
is something that parsers and/or generators constructed by this
factory could use.
- canUseSchema(FormatSchema) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- canUseSchema(FormatSchema) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- canUseSchema(FormatSchema) - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
Method that can be used to quickly check whether given schema
is something that parsers and/or generators constructed by this
factory could use.
- canUseSchema(FormatSchema) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- canUseSchema(FormatSchema) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- canWriteBinaryNatively() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Introspection method that may be called to see if the underlying
data format supports "native" binary data; that is, an efficient
output of binary content without encoding.
- canWriteBinaryNatively() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- canWriteFormattedNumbers() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- canWriteFormattedNumbers() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- canWriteFormattedNumbers() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- canWriteObjectId() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Introspection method that may be called to see if the underlying
data format supports some kind of Object Ids natively (many do not;
for example, JSON doesn't).
- canWriteObjectId() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- canWriteTypeId() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Introspection method that may be called to see if the underlying
data format supports some kind of Type Ids natively (many do not;
for example, JSON doesn't).
- canWriteTypeId() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- capacity() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
-
Returns the capacity of this Ringbuffer.
- CardinalityEstimator - Interface in com.hazelcast.cardinality
-
CardinalityEstimator is a redundant and highly available distributed
data-structure used for probabilistic cardinality estimation purposes,
on unique items, in significantly sized data cultures.
- CardinalityEstimatorConfig - Class in com.hazelcast.config
-
- CardinalityEstimatorConfig() - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
-
- CardinalityEstimatorConfig(String) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
-
- CardinalityEstimatorConfig(String, int, int) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
-
- CardinalityEstimatorConfig(String, int, int, MergePolicyConfig) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
-
- CardinalityEstimatorConfig(String, int, int, String, MergePolicyConfig) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
-
- CardinalityEstimatorConfig(CardinalityEstimatorConfig) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
-
- CardinalityEstimatorPermission - Class in com.hazelcast.security.permission
-
- CardinalityEstimatorPermission(String, String...) - Constructor for class com.hazelcast.security.permission.CardinalityEstimatorPermission
-
- cause() - Method in interface com.hazelcast.auditlog.AuditableEvent
-
Return an exception or error (if any) which caused this event.
- cause(Throwable) - Method in interface com.hazelcast.auditlog.EventBuilder
-
Sets error/exception which caused the event (if any).
- changeClusterState(ClusterState) - Method in interface com.hazelcast.cluster.Cluster
-
Changes state of the cluster to the given state transactionally.
- changeClusterState(ClusterState, TransactionOptions) - Method in interface com.hazelcast.cluster.Cluster
-
Changes state of the cluster to the given state transactionally.
- changeClusterVersion(Version) - Method in interface com.hazelcast.cluster.Cluster
-
Changes the cluster version transactionally.
- changeClusterVersion(Version, TransactionOptions) - Method in interface com.hazelcast.cluster.Cluster
-
Changes the cluster version transactionally, with the transaction options provided.
- CHANNEL_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Number of parallel connection between members.
- CHAR_CONCAT_BUFFER - Static variable in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
-
Buffer used by generators; for byte-backed generators for buffering of
String
values to output (before encoding into UTF-8),
and for char-backed generators as actual concatenation buffer.
- CHAR_NAME_COPY_BUFFER - Static variable in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
-
For parsers, temporary buffer into which char[]
for names is copied
when requested as such; for WriterBasedGenerator
used for buffering
during writeString(Reader)
operation (not commonly used).
- CHAR_NULL - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- CHAR_TEXT_BUFFER - Static variable in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
-
Used through
TextBuffer
: directly by parsers (to concatenate
String values)
and indirectly via
SegmentedStringWriter
when serializing (databind level
ObjectMapper
and
ObjectWriter
).
- CHAR_TOKEN_BUFFER - Static variable in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
-
Buffer used as input buffer for tokenization for character-based parsers.
- CharacterEscapes - Class in com.hazelcast.com.fasterxml.jackson.core.io
-
Abstract base class that defines interface for customizing character
escaping aspects for String values, for formats that use escaping.
- CharacterEscapes() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.io.CharacterEscapes
-
- characterEscapes(CharacterEscapes) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactoryBuilder
-
Method for defining custom escapes factory uses for
JsonGenerator
s
it creates.
- characterEscapes() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactoryBuilder
-
- charBufferLength(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
-
- CharConstants - Class in com.hazelcast.org.snakeyaml.engine.v2.common
-
- charLength() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SerializedString
-
Returns length of the String as characters
- charLength() - Method in interface com.hazelcast.com.fasterxml.jackson.core.SerializableString
-
Returns length of the (unquoted) String as characters.
- 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.
- CharsToNameCanonicalizer - Class in com.hazelcast.com.fasterxml.jackson.core.sym
-
This class is a kind of specialized type-safe Map, from char array to
String value.
- charToHex(int) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.CharTypes
-
- CharTypes - Class in com.hazelcast.com.fasterxml.jackson.core.io
-
- CharTypes() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.io.CharTypes
-
- checkEvent(Event.ID) - Method in interface com.hazelcast.org.snakeyaml.engine.v2.parser.Parser
-
Check if the next event is one of the given type.
- checkEvent(Event.ID) - Method in class com.hazelcast.org.snakeyaml.engine.v2.parser.ParserImpl
-
Check the type of the next event.
- checkLocalParallelism(int) - Static method in class com.hazelcast.jet.core.Vertex
-
- checkPermission(Subject, Permission) - Method in interface com.hazelcast.security.SecurityContext
-
Checks whether current
Subject
has been granted specified permission or not.
- checkToken(Token.ID...) - Method in interface com.hazelcast.org.snakeyaml.engine.v2.scanner.Scanner
-
Check if the next token is one of the given types.
- checkToken(Token.ID...) - Method in class com.hazelcast.org.snakeyaml.engine.v2.scanner.ScannerImpl
-
Check whether the next token is one of the given types.
- checkValue(TokenFilter) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
-
Method called to check whether value is to be included at current output
position, either as Object property, Array element, or root value.
- child() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.DupDetector
-
- ClassDefinition - Interface in com.hazelcast.nio.serialization
-
Defines a class schema for
Portable
classes.
- ClassDefinitionBuilder - Class in com.hazelcast.nio.serialization
-
ClassDefinitionBuilder is used to build and register ClassDefinitions manually.
- ClassDefinitionBuilder(int, int) - Constructor for class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
IMPORTANT: It uses a default portableVersion (0) for non-versioned classes.
- ClassDefinitionBuilder(int, int, int) - Constructor for class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
IMPORTANT: Make sure that the version matches the portableVersion in the SerializationService
- ClassFilter - Class in com.hazelcast.config
-
Holds blacklist and whitelist configuration in java deserialization configuration.
- ClassFilter() - Constructor for class com.hazelcast.config.ClassFilter
-
- ClassFilter(ClassFilter) - Constructor for class com.hazelcast.config.ClassFilter
-
- classLoader - Variable in class com.hazelcast.config.AbstractCacheConfig
-
The ClassLoader to be used to resolve key & value types, if set
- className - Variable in class com.hazelcast.config.AbstractWanPublisherConfig
-
- className - Variable in class com.hazelcast.config.ListenerConfig
-
- className - Variable in class com.hazelcast.config.PredicateConfig
-
- className - Variable in class com.hazelcast.config.SecurityInterceptorConfig
-
- ClassNameFilter - Interface in com.hazelcast.nio.serialization
-
Allows to intercept class resolution during deserialization based on classname.
- ClasspathXmlConfig - Class in com.hazelcast.config
-
A
Config
which is initialized by loading an XML configuration file from the classpath.
- ClasspathXmlConfig(String) - Constructor for class com.hazelcast.config.ClasspathXmlConfig
-
Creates a config which is loaded from a classpath resource using the
Thread.currentThread()
contextClassLoader.
- ClasspathXmlConfig(String, Properties) - Constructor for class com.hazelcast.config.ClasspathXmlConfig
-
Creates a config which is loaded from a classpath resource using the
Thread.currentThread()
contextClassLoader.
- ClasspathXmlConfig(ClassLoader, String) - Constructor for class com.hazelcast.config.ClasspathXmlConfig
-
Creates a config which is loaded from a classpath resource.
- ClasspathXmlConfig(ClassLoader, String, Properties) - Constructor for class com.hazelcast.config.ClasspathXmlConfig
-
Creates a config which is loaded from a classpath resource.
- ClasspathYamlConfig - Class in com.hazelcast.config
-
A
Config
which is initialized by loading a YAML configuration file from the classpath.
- ClasspathYamlConfig(String) - Constructor for class com.hazelcast.config.ClasspathYamlConfig
-
Creates a config which is loaded from a classpath resource using the
Thread.currentThread()
contextClassLoader.
- ClasspathYamlConfig(String, Properties) - Constructor for class com.hazelcast.config.ClasspathYamlConfig
-
Creates a config which is loaded from a classpath resource using the
Thread.currentThread()
contextClassLoader.
- ClasspathYamlConfig(ClassLoader, String) - Constructor for class com.hazelcast.config.ClasspathYamlConfig
-
Creates a config which is loaded from a classpath resource.
- ClasspathYamlConfig(ClassLoader, String, Properties) - Constructor for class com.hazelcast.config.ClasspathYamlConfig
-
Creates a config which is loaded from a classpath resource.
- classTags - Variable in class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter
-
- 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
-
- 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.
- clearAndGetParent() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
-
- clearAndGetParent() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
- clearAsync() - Method in interface com.hazelcast.cp.IAtomicReference
-
Clears the current stored reference.
- clearCurrentToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- clearCurrentToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- clearCurrentToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- clearCurrentToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- clearLoadedLoggers() - Method in class com.hazelcast.logging.LoggerFactorySupport
-
- clearLocation() - Method in exception com.hazelcast.com.fasterxml.jackson.core.JsonProcessingException
-
Method that allows to remove context information from this exception's message.
- clearParameters() - Method in class com.hazelcast.sql.SqlStatement
-
Clears statement parameters.
- 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 - Interface in com.hazelcast.client
-
The Client interface allows to get information about
a connected client's socket address, type and UUID.
- CLIENT - Static variable in class com.hazelcast.instance.EndpointQualifier
-
- CLIENT_CACHING_PROVIDER - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
-
Class name of the client-side Caching Provider
- CLIENT_CLEANUP_PERIOD - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Time period to check if a client is still part of the cluster.
- CLIENT_CLEANUP_TIMEOUT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Timeout duration to decide if a client is still part of the cluster.
- CLIENT_ENGINE_BLOCKING_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The number of threads that the client engine has available for processing requests that are blocking
(example: related to transactions)
When not set it is set as core-size * 20.
- CLIENT_ENGINE_QUERY_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The number of threads that the client engine has available for processing
requests that are related to the query engine.
- CLIENT_ENGINE_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The number of threads that the client engine has available for processing
requests that are not partition specific.
- CLIENT_HEARTBEAT_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Time after which the member assumes the client is dead and closes its
connections to the client.
- CLIENT_PROTOCOL_UNVERIFIED_MESSAGE_BYTES - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Client protocol message size limit (in bytes) for unverified connections
(i.e.
- ClientClasspathXmlConfig - Class in com.hazelcast.client.config
-
A
ClientConfig
which is initialized by loading an XML configuration file from the classpath.
- ClientClasspathXmlConfig(String) - Constructor for class com.hazelcast.client.config.ClientClasspathXmlConfig
-
Creates a config which is loaded from a classpath resource using the
Thread.currentThread()
contextClassLoader.
- ClientClasspathXmlConfig(String, Properties) - Constructor for class com.hazelcast.client.config.ClientClasspathXmlConfig
-
Creates a config which is loaded from a classpath resource using the
Thread.currentThread()
contextClassLoader.
- ClientClasspathXmlConfig(ClassLoader, String, Properties) - Constructor for class com.hazelcast.client.config.ClientClasspathXmlConfig
-
Creates a config which is loaded from a classpath resource.
- ClientClasspathYamlConfig - Class in com.hazelcast.client.config
-
A
ClientConfig
which is initialized by loading an YAML configuration file from the classpath.
- ClientClasspathYamlConfig(String) - Constructor for class com.hazelcast.client.config.ClientClasspathYamlConfig
-
Creates a config which is loaded from a classpath resource using the
Thread.currentThread()
contextClassLoader.
- ClientClasspathYamlConfig(String, Properties) - Constructor for class com.hazelcast.client.config.ClientClasspathYamlConfig
-
Creates a config which is loaded from a classpath resource using the
Thread.currentThread()
contextClassLoader.
- ClientClasspathYamlConfig(ClassLoader, String, Properties) - Constructor for class com.hazelcast.client.config.ClientClasspathYamlConfig
-
Creates a config which is loaded from a classpath resource.
- ClientCloudConfig - Class in com.hazelcast.client.config
-
hazelcast.cloud configuration to let the client connect the cluster via hazelcast.cloud
- ClientCloudConfig() - Constructor for class com.hazelcast.client.config.ClientCloudConfig
-
- ClientCloudConfig(ClientCloudConfig) - Constructor for class com.hazelcast.client.config.ClientCloudConfig
-
- ClientConfig - Class in com.hazelcast.client.config
-
Main configuration to setup a Hazelcast Client
- ClientConfig() - Constructor for class com.hazelcast.client.config.ClientConfig
-
- ClientConfig(ClientConfig) - Constructor for class com.hazelcast.client.config.ClientConfig
-
- ClientConfigRecognizer - Class in com.hazelcast.client.config
-
ConfigRecognizer
implementation that recognizes Hazelcast
client declarative configurations based on an extensible set of
built-in
ConfigRecognizer
implementations.
- ClientConfigRecognizer() - Constructor for class com.hazelcast.client.config.ClientConfigRecognizer
-
Constructs an instance with the built-in set of
ConfigRecognizer
implementations only.
- ClientConfigRecognizer(ConfigRecognizer...) - Constructor for class com.hazelcast.client.config.ClientConfigRecognizer
-
Constructs an instance with the built-in set of
ConfigRecognizer
implementations extended with ones
provided in
customRecognizers
.
- ClientConfigXmlGenerator - Class in com.hazelcast.client.config
-
The ClientConfigXmlGenerator is responsible for transforming a
ClientConfig
to a Hazelcast Client XML string.
- clientConnected(Client) - Method in interface com.hazelcast.client.ClientListener
-
Invoked when a client is connected.
- ClientConnectionStrategyConfig - Class in com.hazelcast.client.config
-
Client connection strategy configuration is used for setting custom strategies and configuring strategy parameters.
- ClientConnectionStrategyConfig() - Constructor for class com.hazelcast.client.config.ClientConnectionStrategyConfig
-
- ClientConnectionStrategyConfig(ClientConnectionStrategyConfig) - Constructor for class com.hazelcast.client.config.ClientConnectionStrategyConfig
-
- ClientConnectionStrategyConfig.ReconnectMode - Enum in com.hazelcast.client.config
-
Reconnect options.
- ClientConsoleApp - Class in com.hazelcast.client.console
-
A demo application to demonstrate a Hazelcast client.
- ClientConsoleApp(HazelcastInstance, PrintStream) - Constructor for class com.hazelcast.client.console.ClientConsoleApp
-
- clientDisconnected(Client) - Method in interface com.hazelcast.client.ClientListener
-
Invoked when a client is disconnected.
- ClientFailoverClasspathXmlConfig - Class in com.hazelcast.client.config
-
A
ClientFailoverConfig
which is initialized by loading an XML
configuration file from the classpath.
- ClientFailoverClasspathXmlConfig(String) - Constructor for class com.hazelcast.client.config.ClientFailoverClasspathXmlConfig
-
Creates a config which is loaded from a classpath resource using the
Thread.currentThread()
contextClassLoader.
- ClientFailoverClasspathXmlConfig(String, Properties) - Constructor for class com.hazelcast.client.config.ClientFailoverClasspathXmlConfig
-
Creates a config which is loaded from a classpath resource using the
Thread.currentThread()
contextClassLoader.
- ClientFailoverClasspathXmlConfig(ClassLoader, String, Properties) - Constructor for class com.hazelcast.client.config.ClientFailoverClasspathXmlConfig
-
Creates a config which is loaded from a classpath resource.
- ClientFailoverClasspathYamlConfig - Class in com.hazelcast.client.config
-
A
ClientFailoverConfig
which is initialized by loading a YAML
configuration file from the classpath.
- ClientFailoverClasspathYamlConfig(String) - Constructor for class com.hazelcast.client.config.ClientFailoverClasspathYamlConfig
-
Creates a config which is loaded from a classpath resource using the
Thread.currentThread()
contextClassLoader.
- ClientFailoverClasspathYamlConfig(String, Properties) - Constructor for class com.hazelcast.client.config.ClientFailoverClasspathYamlConfig
-
Creates a config which is loaded from a classpath resource using the
Thread.currentThread()
contextClassLoader.
- ClientFailoverClasspathYamlConfig(ClassLoader, String, Properties) - Constructor for class com.hazelcast.client.config.ClientFailoverClasspathYamlConfig
-
Creates a config which is loaded from a classpath resource.
- ClientFailoverConfig - Class in com.hazelcast.client.config
-
Config class to configure multiple client configs to be used by single client instance.
- ClientFailoverConfig() - Constructor for class com.hazelcast.client.config.ClientFailoverConfig
-
- ClientFailoverConfigRecognizer - Class in com.hazelcast.client.config
-
ConfigRecognizer
implementation that recognizes Hazelcast
client failover declarative configurations based on an extensible set
of built-in
ConfigRecognizer
implementations.
- ClientFailoverConfigRecognizer() - Constructor for class com.hazelcast.client.config.ClientFailoverConfigRecognizer
-
Constructs an instance with the built-in set of
ConfigRecognizer
implementations only.
- ClientFailoverConfigRecognizer(ConfigRecognizer...) - Constructor for class com.hazelcast.client.config.ClientFailoverConfigRecognizer
-
Constructs an instance with the built-in set of
ConfigRecognizer
implementations extended with ones
provided in
customRecognizers
.
- ClientFlakeIdGeneratorConfig - Class in com.hazelcast.client.config
-
The
ClientFlakeIdGeneratorConfig
contains the configuration for the client
regarding
Flake ID Generator
.
- ClientFlakeIdGeneratorConfig(String) - Constructor for class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
-
- ClientFlakeIdGeneratorConfig(ClientFlakeIdGeneratorConfig) - Constructor for class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
-
Copy-constructor
- ClientIcmpPingConfig - Class in com.hazelcast.client.config
-
Configuration for icmp ping failure detector of clients.
- ClientIcmpPingConfig() - Constructor for class com.hazelcast.client.config.ClientIcmpPingConfig
-
- ClientIcmpPingConfig(ClientIcmpPingConfig) - Constructor for class com.hazelcast.client.config.ClientIcmpPingConfig
-
- ClientListener - Interface in com.hazelcast.client
-
The ClientListener provides the ability to listen to clients connecting and disconnecting from the member.
- ClientMetricsConfig - Class in com.hazelcast.client.config
-
Client-side metrics collection configuration.
- ClientMetricsConfig() - Constructor for class com.hazelcast.client.config.ClientMetricsConfig
-
- ClientMetricsConfig(ClientMetricsConfig) - Constructor for class com.hazelcast.client.config.ClientMetricsConfig
-
- ClientNetworkConfig - Class in com.hazelcast.client.config
-
Contains configuration parameters for client network related behaviour
- ClientNetworkConfig() - Constructor for class com.hazelcast.client.config.ClientNetworkConfig
-
- ClientNetworkConfig(ClientNetworkConfig) - Constructor for class com.hazelcast.client.config.ClientNetworkConfig
-
- ClientNotAllowedInClusterException - Exception in com.hazelcast.client
-
- ClientNotAllowedInClusterException(String) - Constructor for exception com.hazelcast.client.ClientNotAllowedInClusterException
-
Creates a ClientNotAllowedInClusterException with the given message.
- ClientOutOfMemoryHandler - Class in com.hazelcast.client
-
To clear resources of the client upon OutOfMemory
- ClientOutOfMemoryHandler() - Constructor for class com.hazelcast.client.ClientOutOfMemoryHandler
-
- ClientProperty - Class in com.hazelcast.client.properties
-
Defines the name and default value for Hazelcast Client properties.
- ClientReliableTopicConfig - Class in com.hazelcast.client.config
-
Contains the ReliableTopic configuration for a client.
- ClientReliableTopicConfig() - Constructor for class com.hazelcast.client.config.ClientReliableTopicConfig
-
- ClientReliableTopicConfig(String) - Constructor for class com.hazelcast.client.config.ClientReliableTopicConfig
-
Creates a new ReliableTopicConfig with default settings.
- ClientReliableTopicConfig(ClientReliableTopicConfig) - Constructor for class com.hazelcast.client.config.ClientReliableTopicConfig
-
Create a clone of given reliable topic
- ClientSecurityConfig - Class in com.hazelcast.client.config
-
Contains the security configuration for the client.
- ClientSecurityConfig() - Constructor for class com.hazelcast.client.config.ClientSecurityConfig
-
- ClientSecurityConfig(ClientSecurityConfig) - Constructor for class com.hazelcast.client.config.ClientSecurityConfig
-
- ClientService - Interface in com.hazelcast.client
-
ClientService allows you to query connected
Client
s and
attach/detach
ClientListener
s to listen to connection events.
- ClientStateListener - Class in com.hazelcast.client.util
-
Helper class for the user to track the lifecycle state of the client.
- ClientStateListener(ClientFailoverConfig) - Constructor for class com.hazelcast.client.util.ClientStateListener
-
Registers this instance with the provided client configuration
- ClientStateListener(ClientConfig) - Constructor for class com.hazelcast.client.util.ClientStateListener
-
Registers this instance with the provided client configuration
- ClientUserCodeDeploymentConfig - Class in com.hazelcast.client.config
-
Configuration of User Code Deployment.
- ClientUserCodeDeploymentConfig() - Constructor for class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
-
- ClientUserCodeDeploymentConfig(ClientUserCodeDeploymentConfig) - Constructor for class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
-
- clone() - Method in class com.hazelcast.jet.pipeline.ServiceFactory
-
- cloneWithBuilder() - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
Returned
GenericRecordBuilder
can be used to have exact copy and also just to update a couple of fields.
- close() - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- close(ClassLoader) - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- close(URI, ClassLoader) - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- close() - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
-
- close(ClassLoader) - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
-
- close(URI, ClassLoader) - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
-
- close() - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
-
- close(ClassLoader) - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
-
- close(URI, ClassLoader) - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
-
- close() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- close() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- close() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- close() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.MergedStream
-
- close() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SegmentedStringWriter
-
- close() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.UTF32Reader
-
- close() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.UTF8Writer
-
- close() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- close() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- close() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method called to close this generator, so that no more content
can be written.
- close() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Closes the parser so that no further iteration or data access
can be made; will also close the underlying input source
if parser either
owns the input source, or feature
JsonParser.Feature.AUTO_CLOSE_SOURCE
is enabled.
- close() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
-
- close() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- close() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- close() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserSequence
-
- 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(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 all members - successfully or
not.
- close() - Method in interface com.hazelcast.jet.pipeline.SourceBuilder.SourceBuffer
-
Closes the buffer, signaling that all items have been emitted.
- close() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.YamlUnicodeReader
-
- close() - Method in class com.hazelcast.org.snakeyaml.engine.v2.serializer.Serializer
-
- 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.
- closeArray(JsonGenerator) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
-
- closeObject(JsonGenerator) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
-
- Cluster - Interface in com.hazelcast.cluster
-
Hazelcast cluster interface.
- cluster(JetCommandLine.Verbosity, JetCommandLine.TargetsMixin) - Method in class com.hazelcast.jet.server.JetCommandLine
-
- CLUSTER_MEMBER_ADDED - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
-
Event type ID: Member joined.
- CLUSTER_MEMBER_REMOVED - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
-
Event type ID: Member removed from the cluster.
- CLUSTER_MEMBER_SUSPECTED - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
-
Event type ID: Cluster member suspected.
- CLUSTER_MERGE - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
-
Event type ID: Clusters merged.
- CLUSTER_PROMOTE_MEMBER - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
-
Event type ID: Lite member promoted.
- CLUSTER_SHUTDOWN - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
-
Event type ID: Cluster shutdown.
- CLUSTER_SHUTDOWN_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Once a member initiates cluster shutdown, it will either wait for all
members to leave the cluster before shutting itself down.
- ClusterPermission - Class in com.hazelcast.security.permission
-
- ClusterPermission(String) - Constructor for class com.hazelcast.security.permission.ClusterPermission
-
- ClusterPermissionCollection - Class in com.hazelcast.security.permission
-
- ClusterPermissionCollection() - Constructor for class com.hazelcast.security.permission.ClusterPermissionCollection
-
- ClusterPermissionCollection(Class<? extends Permission>) - Constructor for class com.hazelcast.security.permission.ClusterPermissionCollection
-
- ClusterProperty - Class in com.hazelcast.spi.properties
-
Defines the name and default value for Hazelcast properties.
- ClusterState - Enum in com.hazelcast.cluster
-
ClusterState
are several possible states of the cluster
where each state can allow and/or deny specific actions
and/or change behavior of specific actions.
- coAggregateOperationBuilder() - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns a builder object that offers a step-by-step fluent API to create
an aggregate operation that accepts multiple inputs.
- CoAggregateOperationBuilder - Class in com.hazelcast.jet.aggregate
-
Offers a step-by-step API to create an aggregate operation that
accepts multiple inputs.
- COALESCED_WM - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
-
Tracks the highest watermark observed on all the input queues
of a particular incoming
Edge
of a certain
Vertex
.
- codePointAt(CharSequence, int, int) - Static method in class com.hazelcast.org.snakeyaml.engine.external.com.google.gdata.util.common.base.UnicodeEscaper
-
Returns the Unicode code point of the character at the given index.
- 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.
- collectDefaults() - Static method in enum com.hazelcast.com.fasterxml.jackson.core.json.JsonReadFeature
-
Method that calculates bit set (flags) of all features that
are enabled by default.
- collectDefaults() - Static method in enum com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteFeature
-
Method that calculates bit set (flags) of all features that
are enabled by default.
- collectDefaults() - Static method in enum com.hazelcast.com.fasterxml.jackson.core.JsonFactory.Feature
-
Method that calculates bit set (flags) of all features that
are enabled by default.
- collectDefaults() - Static method in enum com.hazelcast.com.fasterxml.jackson.core.JsonGenerator.Feature
-
Method that calculates bit set (flags) of all features that
are enabled by default.
- collectDefaults() - Static method in enum com.hazelcast.com.fasterxml.jackson.core.JsonParser.Feature
-
Method that calculates bit set (flags) of all features that
are enabled by default.
- collectDefaults() - Static method in enum com.hazelcast.com.fasterxml.jackson.core.StreamReadFeature
-
Method that calculates bit set (flags) of all features that
are enabled by default.
- collectDefaults() - Static method in enum com.hazelcast.com.fasterxml.jackson.core.StreamWriteFeature
-
Method that calculates bit set (flags) of all features that
are enabled by default.
- 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
-
- CollectionEndEvent - Class in com.hazelcast.org.snakeyaml.engine.v2.events
-
Base class for the end events of the collection nodes.
- CollectionEndEvent(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.events.CollectionEndEvent
-
- CollectionEndEvent() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.events.CollectionEndEvent
-
- collectionFrequencySeconds - Variable in class com.hazelcast.config.BaseMetricsConfig
-
- CollectionNode<T> - Class in com.hazelcast.org.snakeyaml.engine.v2.nodes
-
- CollectionNode(Tag, FlowStyle, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.nodes.CollectionNode
-
- CollectionStartEvent - Class in com.hazelcast.org.snakeyaml.engine.v2.events
-
Base class for the start events of the collection nodes.
- CollectionStartEvent(Optional<Anchor>, Optional<String>, boolean, FlowStyle, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.events.CollectionStartEvent
-
- collisionCount() - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
-
Method mostly needed by unit tests; calculates number of
entries that are in collision list.
- COLUMN_NOT_FOUND - Static variable in class com.hazelcast.sql.SqlRowMetadata
-
Constant indicating that the column is not found.
- 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.console - package com.hazelcast.client.console
-
This package contains ClientConsoleApp
- com.hazelcast.client.properties - package com.hazelcast.client.properties
-
Contains the Hazelcast client properties implementation.
- com.hazelcast.client.util - package com.hazelcast.client.util
-
This package contains some utility classes and the base implementations of the
loadbalancer implementations
- com.hazelcast.cluster - package com.hazelcast.cluster
-
This package contains the cluster functionality.
- com.hazelcast.cluster.memberselector - package com.hazelcast.cluster.memberselector
-
- com.hazelcast.collection - package com.hazelcast.collection
-
This package contains classes to support the collection API.
- com.hazelcast.com.fasterxml.jackson.core - package com.hazelcast.com.fasterxml.jackson.core
-
Main public API classes of the core streaming JSON
processor: most importantly
JsonFactory
used for constructing
JSON parser (
JsonParser
)
and generator
(
JsonGenerator
)
instances.
- com.hazelcast.com.fasterxml.jackson.core.async - package com.hazelcast.com.fasterxml.jackson.core.async
-
Package that contains abstractions needed to support optional
non-blocking decoding (parsing) functionality.
- com.hazelcast.com.fasterxml.jackson.core.base - package com.hazelcast.com.fasterxml.jackson.core.base
-
Base classes used by concrete Parser and Generator implementations;
contain functionality that is not specific to JSON or input
abstraction (byte vs char).
- com.hazelcast.com.fasterxml.jackson.core.exc - package com.hazelcast.com.fasterxml.jackson.core.exc
-
- com.hazelcast.com.fasterxml.jackson.core.filter - package com.hazelcast.com.fasterxml.jackson.core.filter
-
- com.hazelcast.com.fasterxml.jackson.core.format - package com.hazelcast.com.fasterxml.jackson.core.format
-
Package that contains interfaces needed for dynamic, pluggable
format (auto)detection; as well as basic utility classes for
simple format detection functionality.
- com.hazelcast.com.fasterxml.jackson.core.io - package com.hazelcast.com.fasterxml.jackson.core.io
-
- com.hazelcast.com.fasterxml.jackson.core.json - package com.hazelcast.com.fasterxml.jackson.core.json
-
JSON-specific parser and generator implementation classes that
Jackson defines and uses.
- com.hazelcast.com.fasterxml.jackson.core.json.async - package com.hazelcast.com.fasterxml.jackson.core.json.async
-
Non-blocking ("async") JSON parser implementation.
- com.hazelcast.com.fasterxml.jackson.core.sym - package com.hazelcast.com.fasterxml.jackson.core.sym
-
Internal implementation classes for efficient handling of
of symbols in JSON (field names in Objects)
- com.hazelcast.com.fasterxml.jackson.core.type - package com.hazelcast.com.fasterxml.jackson.core.type
-
Contains classes needed for type introspection, mostly used by data binding
functionality.
- com.hazelcast.com.fasterxml.jackson.core.util - package com.hazelcast.com.fasterxml.jackson.core.util
-
Utility classes used by Jackson Core functionality.
- 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
-
- com.hazelcast.config.properties - package com.hazelcast.config.properties
-
This package contains the public API for properties defined in the XML configuration.
- com.hazelcast.config.replacer - package com.hazelcast.config.replacer
-
This package contains the public API and default implementation of variable replacers for configuration files.
- com.hazelcast.config.replacer.spi - package com.hazelcast.config.replacer.spi
-
This package contains the SPI for configuration files variable replacers.
- com.hazelcast.config.security - package com.hazelcast.config.security
-
Provides classes for configuring security realms in Hazelcast.
- com.hazelcast.console - package com.hazelcast.console
-
This package contains classes related to ConsoleApp
- com.hazelcast.core - package com.hazelcast.core
-
Provides core API interfaces/classes.
- com.hazelcast.core.server - package com.hazelcast.core.server
-
This package contains classes to launch standalone Hazelcast Instance
- com.hazelcast.cp - package com.hazelcast.cp
-
Contains public APIs of CP Subsystem
- com.hazelcast.cp.event - package com.hazelcast.cp.event
-
Contains definitions of CP Subsystem events and listeners.
- com.hazelcast.cp.exception - package com.hazelcast.cp.exception
-
Contains exceptions that can be thrown by APIs of CP Subsystem
- com.hazelcast.cp.lock - package com.hazelcast.cp.lock
-
Contains locking APIs of CP Subsystem
- com.hazelcast.cp.lock.exception - package com.hazelcast.cp.lock.exception
-
Contains exception classes related to the locking API of CP Subsystem
- com.hazelcast.cp.session - package com.hazelcast.cp.session
-
Contains session abstractions of CP Subsystem
- com.hazelcast.crdt - package com.hazelcast.crdt
-
This package contains the common classes for CRDT (conflict-free replicated
data type) implementations based on the Hazelcast infrastructure.
- com.hazelcast.crdt.pncounter - package com.hazelcast.crdt.pncounter
-
This package contains the PN (Positive-Negative) CRDT counter
interface.
- com.hazelcast.durableexecutor - package com.hazelcast.durableexecutor
-
This package contains DurableExecutorService functionality for Hazelcast.
The DurableExecutorService extends the
ExecutorService
and provides additional methods like
executing tasks on a member who is owner of a specific key.
- com.hazelcast.executor - package com.hazelcast.executor
-
This package contains public API for Hazelcast executors.
- com.hazelcast.flakeidgen - package com.hazelcast.flakeidgen
-
This package contains Flake ID Generator functionality for Hazelcast.
- com.hazelcast.function - package com.hazelcast.function
-
Serializable and exception-declaring variants of functional interfaces from
java.util.function
.
- com.hazelcast.gcp - package com.hazelcast.gcp
-
Provides interfaces/classes for Hazelcast GCP.
- com.hazelcast.hotrestart - package com.hazelcast.hotrestart
-
This package contains Hot Restart classes needed for open source Hazelcast code
- com.hazelcast.instance - package com.hazelcast.instance
-
This package contains Hazelcast Instance functionality.
- 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
-
- 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.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.function - package com.hazelcast.jet.function
-
Serializable and exception-declaring variants of functional interfaces from
java.util.function
.
- com.hazelcast.jet.json - package com.hazelcast.jet.json
-
Utility classes for JSON parsing and serialization.
- com.hazelcast.jet.pipeline - package com.hazelcast.jet.pipeline
-
The Pipeline API is Jet's high-level API to build and execute
distributed computation jobs.
- com.hazelcast.jet.pipeline.file - package com.hazelcast.jet.pipeline.file
-
This package offers the
FileSourceBuilder
which allows you to construct various kinds of
Pipeline
sources that read from local or distributed files.
- com.hazelcast.jet.pipeline.test - package com.hazelcast.jet.pipeline.test
-
This package contains various mock sources to help with pipeline testing
and development.
- com.hazelcast.jet.retry - package com.hazelcast.jet.retry
-
Interfaces and utility classes for defining and tracking various types of
retry behaviour.
- com.hazelcast.jet.server - package com.hazelcast.jet.server
-
Contains Java program entry points that will start a Jet server
instance, submit jobs to a Jet cluster, etc.
- com.hazelcast.json - package com.hazelcast.json
-
Contains Json interface
- 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
-
- 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
-
- 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.ssl - package com.hazelcast.nio.ssl
-
Contains interfaces/classes related to SSL for New IO
- com.hazelcast.org.snakeyaml.engine.external.com.google.gdata.util.common.base - package com.hazelcast.org.snakeyaml.engine.external.com.google.gdata.util.common.base
-
- com.hazelcast.org.snakeyaml.engine.v2.api - package com.hazelcast.org.snakeyaml.engine.v2.api
-
- com.hazelcast.org.snakeyaml.engine.v2.api.lowlevel - package com.hazelcast.org.snakeyaml.engine.v2.api.lowlevel
-
- com.hazelcast.org.snakeyaml.engine.v2.common - package com.hazelcast.org.snakeyaml.engine.v2.common
-
- com.hazelcast.org.snakeyaml.engine.v2.composer - package com.hazelcast.org.snakeyaml.engine.v2.composer
-
- com.hazelcast.org.snakeyaml.engine.v2.constructor - package com.hazelcast.org.snakeyaml.engine.v2.constructor
-
- com.hazelcast.org.snakeyaml.engine.v2.emitter - package com.hazelcast.org.snakeyaml.engine.v2.emitter
-
- com.hazelcast.org.snakeyaml.engine.v2.env - package com.hazelcast.org.snakeyaml.engine.v2.env
-
- com.hazelcast.org.snakeyaml.engine.v2.events - package com.hazelcast.org.snakeyaml.engine.v2.events
-
- com.hazelcast.org.snakeyaml.engine.v2.exceptions - package com.hazelcast.org.snakeyaml.engine.v2.exceptions
-
- com.hazelcast.org.snakeyaml.engine.v2.nodes - package com.hazelcast.org.snakeyaml.engine.v2.nodes
-
- com.hazelcast.org.snakeyaml.engine.v2.parser - package com.hazelcast.org.snakeyaml.engine.v2.parser
-
- com.hazelcast.org.snakeyaml.engine.v2.representer - package com.hazelcast.org.snakeyaml.engine.v2.representer
-
- com.hazelcast.org.snakeyaml.engine.v2.resolver - package com.hazelcast.org.snakeyaml.engine.v2.resolver
-
- com.hazelcast.org.snakeyaml.engine.v2.scanner - package com.hazelcast.org.snakeyaml.engine.v2.scanner
-
- com.hazelcast.org.snakeyaml.engine.v2.serializer - package com.hazelcast.org.snakeyaml.engine.v2.serializer
-
- com.hazelcast.org.snakeyaml.engine.v2.tokens - package com.hazelcast.org.snakeyaml.engine.v2.tokens
-
- com.hazelcast.osgi - package com.hazelcast.osgi
-
This package contains the OSGI functionality contract points for Hazelcast.
- com.hazelcast.partition - package com.hazelcast.partition
-
Contains the partition logic for Hazelcast.
- com.hazelcast.partition.strategy - package com.hazelcast.partition.strategy
-
Packages contains different partitioning strategies.
- com.hazelcast.projection - package com.hazelcast.projection
-
Contains classes related to projections.
- com.hazelcast.query - package com.hazelcast.query
-
Contains interfaces/classes related to Hazelcast query and indexing support.
- com.hazelcast.query.extractor - package com.hazelcast.query.extractor
-
Contains classes related to custom attributes and the extraction of their values.
- com.hazelcast.replicatedmap - package com.hazelcast.replicatedmap
-
Classes for replicated map.
- com.hazelcast.ringbuffer - package com.hazelcast.ringbuffer
-
- com.hazelcast.scheduledexecutor - package com.hazelcast.scheduledexecutor
-
This package contains ScheduledExecutorService functionality for Hazelcast.
- com.hazelcast.security - package com.hazelcast.security
-
Provides interfaces/classes for Hazelcast security implementation.
- com.hazelcast.security.jsm - package com.hazelcast.security.jsm
-
Contains Java Security Manager permissions.
- com.hazelcast.security.permission - package com.hazelcast.security.permission
-
Contains Hazelcast client permissions.
- com.hazelcast.spi - package com.hazelcast.spi
-
Contains functionality for the Hazelcast SPI
- com.hazelcast.spi.annotation - package com.hazelcast.spi.annotation
-
Contains annotations for Hazelcast SPI.
- com.hazelcast.spi.discovery - package com.hazelcast.spi.discovery
-
This package contains the public SPI for vendors and users to implement their
custom node / IP discovery strategy.
- com.hazelcast.spi.discovery.integration - package com.hazelcast.spi.discovery.integration
-
This package contains the public part of the integrators SPI and is meant for
people that integrate Hazelcast into their own systems or frameworks and cannot
use the default discovery service implementation (for example using a different
DiscoveryStrategy
lookup strategy like OSGi).
- com.hazelcast.spi.discovery.multicast - package com.hazelcast.spi.discovery.multicast
-
Contains the hazelcast multicast plugin classes
- com.hazelcast.spi.eviction - package com.hazelcast.spi.eviction
-
This package contains interfaces for eviction
- com.hazelcast.spi.exception - package com.hazelcast.spi.exception
-
Contains exceptions for Hazelcast SPI.
- com.hazelcast.spi.merge - package com.hazelcast.spi.merge
-
This package contains interfaces and classes of the split-brain merging SPI.
- com.hazelcast.spi.partitiongroup - package com.hazelcast.spi.partitiongroup
-
This package contains the basic SPI for the Partition Group SPI to define
or configure how Hazelcast will configure and distribute backups in the
cluster.
- com.hazelcast.spi.properties - package com.hazelcast.spi.properties
-
Contains the Hazelcast properties implementation.
- com.hazelcast.spi.tenantcontrol - package com.hazelcast.spi.tenantcontrol
-
Classes for tenant control
- com.hazelcast.splitbrainprotection - package com.hazelcast.splitbrainprotection
-
Contains classes related to cluster split brain protection.
- com.hazelcast.sql - package com.hazelcast.sql
-
This package contains the SQL API.
- com.hazelcast.topic - package com.hazelcast.topic
-
Contains the API for the
ITopic
.
- com.hazelcast.transaction - package com.hazelcast.transaction
-
Provides interfaces/classes for Hazelcast transaction support.
- com.hazelcast.version - package com.hazelcast.version
-
This package contains classes to support the versioning API.
- com.hazelcast.wan - package com.hazelcast.wan
-
This package contains the WAN replication API
- combine(Aggregator) - Method in interface com.hazelcast.aggregation.Aggregator
-
Incorporates the intermediary result of the given aggregator to this instance of the aggregator.
- 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).
- COMMIT_ID - Static variable in class com.hazelcast.instance.GeneratedBuildProperties
-
- commitTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
-
Commits a transaction.
- compact() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
-
- comparableMax() - Static method in class com.hazelcast.aggregation.Aggregators
-
- comparableMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
-
- comparableMin() - Static method in class com.hazelcast.aggregation.Aggregators
-
- comparableMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
-
- comparator - Variable in class com.hazelcast.config.EvictionConfig
-
- comparatorClassName - Variable in class com.hazelcast.config.EvictionConfig
-
- ComparatorEx<T> - Interface in com.hazelcast.function
-
- compare(CacheEntryView<K, V>, CacheEntryView<K, V>) - Method in interface com.hazelcast.cache.CacheEvictionPolicyComparator
-
- compare(T, T) - Method in interface com.hazelcast.function.ComparatorEx
-
- compare(EntryView<K, V>, EntryView<K, V>) - Method in interface com.hazelcast.map.MapEvictionPolicyComparator
-
Compares the given
EntryView
instances and
returns the result.
- compareAndSet(long, long) - Method in interface com.hazelcast.cp.IAtomicLong
-
Atomically sets the value to the given updated value
only if the current value ==
the expected value.
- compareAndSet(E, E) - Method in interface com.hazelcast.cp.IAtomicReference
-
Atomically sets the value to the given updated value
only if the current value ==
the expected value.
- compareAndSetAsync(long, long) - Method in interface com.hazelcast.cp.IAtomicLong
-
Atomically sets the value to the given updated value
only if the current value ==
the expected value.
- compareAndSetAsync(E, E) - Method in interface com.hazelcast.cp.IAtomicReference
-
Atomically sets the value to the given updated value only if the
current value ==
the expected value.
- compareEx(T, T) - Method in interface com.hazelcast.function.ComparatorEx
-
- compareTo(TypeReference<T>) - Method in class com.hazelcast.com.fasterxml.jackson.core.type.TypeReference
-
The only reason we define this method (and require implementation
of Comparable
) is to prevent constructing a
reference without type information.
- compareTo(Version) - Method in class com.hazelcast.com.fasterxml.jackson.core.Version
-
- 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(Function<? super T, ? extends U>, Comparator<? super U>) - Static method in interface com.hazelcast.function.ComparatorEx
-
- comparing(FunctionEx<? super T, ? extends U>, ComparatorEx<? super U>) - Static method in interface com.hazelcast.function.ComparatorEx
-
- comparing(Function<? super T, ? extends U>) - Static method in interface com.hazelcast.function.ComparatorEx
-
- comparing(FunctionEx<? super T, ? extends U>) - Static method in interface com.hazelcast.function.ComparatorEx
-
- comparingDouble(ToDoubleFunction<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
-
- comparingDouble(ToDoubleFunctionEx<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
-
- comparingInt(ToIntFunction<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
-
- comparingInt(ToIntFunctionEx<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
-
- comparingLong(ToLongFunction<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
-
- comparingLong(ToLongFunctionEx<? super T>) - Static method in interface com.hazelcast.function.ComparatorEx
-
- compile(String) - Static method in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
-
Factory method that parses given input and construct matching pointer
instance, if it represents a valid JSON Pointer: if not, a
IllegalArgumentException
is thrown.
- 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
-
- completeAndCoalesce(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
-
Method that will complete "manual" output process, coalesce
content (if necessary) and return results as a contiguous buffer.
- 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.
- compose(FunctionEx<? super V, ? extends T>) - Method in interface com.hazelcast.function.FunctionEx
-
- Compose - Class in com.hazelcast.org.snakeyaml.engine.v2.api.lowlevel
-
- Compose(LoadSettings) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.api.lowlevel.Compose
-
- composeAllFromInputStream(InputStream) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.lowlevel.Compose
-
Parse all YAML documents in a stream and produce corresponding representation trees.
- composeAllFromReader(Reader) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.lowlevel.Compose
-
Parse all YAML documents in a stream and produce corresponding representation trees.
- composeAllFromString(String) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.lowlevel.Compose
-
Parse all YAML documents in a stream and produce corresponding representation trees.
- composeInputStream(InputStream) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.lowlevel.Compose
-
Parse a YAML stream and produce
Node
- composeKeyNode(MappingNode) - Method in class com.hazelcast.org.snakeyaml.engine.v2.composer.Composer
-
- composeMappingChildren(List<NodeTuple>, MappingNode) - Method in class com.hazelcast.org.snakeyaml.engine.v2.composer.Composer
-
- composeMappingNode(Optional<Anchor>) - Method in class com.hazelcast.org.snakeyaml.engine.v2.composer.Composer
-
- Composer - Class in com.hazelcast.org.snakeyaml.engine.v2.composer
-
Creates a node graph from parser events.
- Composer(Parser, LoadSettings) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.composer.Composer
-
- composeReader(Reader) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.lowlevel.Compose
-
Parse a YAML stream and produce
Node
- ComposerException - Exception in com.hazelcast.org.snakeyaml.engine.v2.exceptions
-
General exception during composition step
- ComposerException(String, Optional<Mark>, String, Optional<Mark>) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v2.exceptions.ComposerException
-
- ComposerException(String, Optional<Mark>) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v2.exceptions.ComposerException
-
- composeScalarNode(Optional<Anchor>) - Method in class com.hazelcast.org.snakeyaml.engine.v2.composer.Composer
-
- composeSequenceNode(Optional<Anchor>) - Method in class com.hazelcast.org.snakeyaml.engine.v2.composer.Composer
-
- composeString(String) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.lowlevel.Compose
-
Parse a YAML stream and produce
Node
- composeValueNode(MappingNode) - Method in class com.hazelcast.org.snakeyaml.engine.v2.composer.Composer
-
- 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
-
- Config() - Constructor for class com.hazelcast.config.Config
-
- Config(String) - Constructor for class com.hazelcast.config.Config
-
- ConfigAccessor - Class in com.hazelcast.config
-
Private API for accessing configuration at runtime
- ConfigBuilder - Interface in com.hazelcast.config
-
Interface for all config builders.
- 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
-
- ConfigStream(InputStream) - Constructor for class com.hazelcast.config.ConfigStream
-
- ConfigStream(InputStream, int) - Constructor for class com.hazelcast.config.ConfigStream
-
- configure(JsonFactory.Feature, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- configure(JsonParser.Feature, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method for enabling or disabling specified parser feature
(check
JsonParser.Feature
for list of features)
- configure(JsonGenerator.Feature, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method for enabling or disabling specified generator feature
(check
JsonGenerator.Feature
for list of features)
- configure(JsonReadFeature, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactoryBuilder
-
- configure(JsonWriteFeature, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactoryBuilder
-
- configure(JsonGenerator.Feature, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for enabling or disabling specified feature:
check
JsonGenerator.Feature
for list of available features.
- configure(JsonParser.Feature, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method for enabling or disabling specified feature
(check
JsonParser.Feature
for list of features)
- configure(JsonFactory.Feature, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- configure(StreamReadFeature, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- configure(StreamWriteFeature, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- configure(JsonReadFeature, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- configure(JsonWriteFeature, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- configure(CallbackHandler) - Method in class com.hazelcast.config.security.StaticCredentialsFactory
-
- configure(CallbackHandler) - Method in interface com.hazelcast.security.ICredentialsFactory
-
- configure(Config, Properties) - Method in interface com.hazelcast.security.IPermissionPolicy
-
- configureCapacity(int) - Method in interface com.hazelcast.jet.Observable
-
Set the capacity of the underlying
Ringbuffer
, which defaults to
.
- configureHazelcast(Consumer<Config>) - Method in class com.hazelcast.jet.config.JetConfig
-
Convenience method for for configuring underlying Hazelcast IMDG instance.
- 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
-
- 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.
- connectionFn(FunctionEx<ConnectionFactory, Connection>) - Method in class com.hazelcast.jet.pipeline.JmsSinkBuilder
-
Sets the function which creates a connection given a connection factory.
- 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.
- 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
-
- ConsistencyCheckStrategy - Enum in com.hazelcast.config
-
Strategy for checking the consistency of data between replicas.
- ConsistencyLostException - Exception in com.hazelcast.core
-
Exception that indicates that the consistency guarantees provided by
some service has been lost.
- ConsistencyLostException(String) - Constructor for exception com.hazelcast.core.ConsistencyLostException
-
- ConsoleApp - Class in com.hazelcast.console
-
Special thanks to Alexandre Vasseur for providing this very nice test application.
- ConsoleApp(HazelcastInstance, PrintStream) - Constructor for class com.hazelcast.console.ConsoleApp
-
- constant(long) - Static method in interface com.hazelcast.jet.retry.IntervalFunction
-
Creates an IntervalFunction
which returns a fixed interval in
milliseconds.
- construct(String, int, int[], int) - Static method in class com.hazelcast.com.fasterxml.jackson.core.sym.NameN
-
- construct(Node) - Method in interface com.hazelcast.org.snakeyaml.engine.v2.api.ConstructNode
-
Construct a Java instance with all the properties injected when it is possible.
- construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.BaseConstructor
-
Construct complete YAML document.
- construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructEnv
-
- construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructOptionalClass
-
- construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructUuidClass
-
- construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructYamlBinary
-
- construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructYamlBool
-
- construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructYamlFloat
-
- construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructYamlInt
-
- construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructYamlMap
-
- construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructYamlNull
-
- construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructYamlOmap
-
- construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructYamlSeq
-
- construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructYamlSet
-
- construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructYamlStr
-
- ConstructEnv() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructEnv
-
- constructMapping(MappingNode) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.BaseConstructor
-
- constructMapping2ndStep(MappingNode, Map<Object, Object>) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.BaseConstructor
-
- constructMapping2ndStep(MappingNode, Map<Object, Object>) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor
-
- ConstructNode - Interface in com.hazelcast.org.snakeyaml.engine.v2.api
-
Provide a way to construct a Java instance from the composed Node.
- constructObject(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.BaseConstructor
-
Construct object from the specified Node.
- constructObjectNoCheck(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.BaseConstructor
-
- ConstructOptionalClass() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructOptionalClass
-
- ConstructorException - Exception in com.hazelcast.org.snakeyaml.engine.v2.exceptions
-
General exception during construction step
- ConstructorException(String, Optional<Mark>, String, Optional<Mark>, Throwable) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v2.exceptions.ConstructorException
-
- ConstructorException(String, Optional<Mark>, String, Optional<Mark>) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v2.exceptions.ConstructorException
-
- constructParser(int, ObjectCodec, ByteQuadsCanonicalizer, CharsToNameCanonicalizer, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ByteSourceJsonBootstrapper
-
- constructReader() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ByteSourceJsonBootstrapper
-
- constructRecursive(Node, Object) - Method in interface com.hazelcast.org.snakeyaml.engine.v2.api.ConstructNode
-
Apply the second step when constructing recursive structures.
- constructRecursive(Node, Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructYamlMap
-
- constructRecursive(Node, Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructYamlSeq
-
- constructRecursive(Node, Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructYamlSet
-
- constructScalar(ScalarNode) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.BaseConstructor
-
- constructSequence(SequenceNode) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.BaseConstructor
-
- constructSequenceStep2(SequenceNode, Collection<Object>) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.BaseConstructor
-
- constructSet(MappingNode) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.BaseConstructor
-
- constructSet2ndStep(MappingNode, Set<Object>) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.BaseConstructor
-
- constructSet2ndStep(MappingNode, Set<Object>) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor
-
- constructSingleDocument(Optional<Node>) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.BaseConstructor
-
Ensure that the stream contains a single document and construct it
- constructTextBuffer() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
- ConstructUuidClass() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructUuidClass
-
- ConstructYamlBinary() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructYamlBinary
-
- ConstructYamlBool() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructYamlBool
-
- ConstructYamlFloat() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructYamlFloat
-
- ConstructYamlInt() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructYamlInt
-
- ConstructYamlMap() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructYamlMap
-
- ConstructYamlNull() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructYamlNull
-
- ConstructYamlOmap() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructYamlOmap
-
- ConstructYamlSeq() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructYamlSeq
-
- ConstructYamlSet() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructYamlSet
-
- ConstructYamlStr() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructYamlStr
-
- ConsumerEx<T> - Interface in com.hazelcast.function
-
- consumerFn(FunctionEx<? super Session, ? extends MessageConsumer>) - Method in class com.hazelcast.jet.pipeline.JmsSourceBuilder
-
Sets the function which creates the message consumer from session.
- containedParsersCount() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserSequence
-
Method that is most useful for debugging or testing;
returns actual number of underlying parsers sequence
was constructed with (nor just ones remaining active)
- containedType(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
-
Method for accessing definitions of contained ("child")
types.
- containedTypeCount() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
-
Method for checking how many contained types this type
has.
- containedTypeName(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
-
Method for accessing name of type variable in indicated
position.
- contains(E) - Method in interface com.hazelcast.cp.IAtomicReference
-
Checks if the reference contains the value.
- containsAsync(E) - Method in interface com.hazelcast.cp.IAtomicReference
-
Checks if the reference contains the value.
- containsEntry(K, V) - Method in interface com.hazelcast.multimap.MultiMap
-
Returns whether the multimap contains the given key-value pair.
- containsKey(Object) - Method in interface com.hazelcast.map.BaseMap
-
Returns true
if this map contains an entry for the specified
key.
- containsKey(Object) - Method in interface com.hazelcast.map.IMap
-
Returns true
if this map contains an entry for the specified
key.
- containsKey(Object) - Method in interface com.hazelcast.map.QueryCache
-
- containsKey(K) - Method in interface com.hazelcast.multimap.MultiMap
-
Returns whether the multimap contains an entry with the key.
- containsKey(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
Returns true if value for given key is provided (either as a HazelcastProperty or a System property).
- containsKey(Object) - Method in interface com.hazelcast.transaction.TransactionalMap
-
- containsTag(String) - Static method in class com.hazelcast.jet.core.metrics.MeasurementPredicates
-
- 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.
- contentsAsArray() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
- contentsAsDecimal() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
Convenience method for converting contents of the buffer
into a
BigDecimal
.
- contentsAsDouble() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
Convenience method for converting contents of the buffer
into a Double value.
- contentsAsInt(boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
Specialized convenience method that will decode a 32-bit int,
of at most 9 digits (and possible leading minus sign).
- contentsAsLong(boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
Specialized convenience method that will decode a 64-bit int,
of at most 18 digits (and possible leading minus sign).
- contentsAsString() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
Accessor that may be used to get the contents of this buffer as a single
String
regardless of whether they were collected in a segmented
fashion or not: this typically require construction of the result String.
- contentsToWriter(Writer) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
Accessor that will write buffered contents using given
Writer
.
- 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) - 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(Comparable) - Method in interface com.hazelcast.core.TypeConverter
-
- convert(String) - Method in class com.hazelcast.jet.server.JetCommandLine.TargetsMixin.Converter
-
- convert(long, MemoryUnit) - Method in enum com.hazelcast.memory.MemoryUnit
-
- Converter() - Constructor for class com.hazelcast.jet.server.JetCommandLine.TargetsMixin.Converter
-
- convertNumberToBigDecimal() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- convertNumberToBigInteger() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- convertNumberToDouble() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- convertNumberToInt() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- convertNumberToLong() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- convertSurrogate(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.UTF8Writer
-
Method called to calculate Unicode code-point, from a surrogate pair.
- convertToEventType(CacheEventType) - Static method in enum com.hazelcast.cache.CacheEventType
-
- COOPERATIVE_DEFAULT - Static variable in class com.hazelcast.jet.pipeline.ServiceFactory
-
- 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.com.fasterxml.jackson.core.JsonFactory
-
Method for constructing a new
JsonFactory
that has
the same settings as this instance, but is otherwise
independent (i.e.
- copy(T, boolean) - Method in class com.hazelcast.config.CacheConfig
-
Copy this CacheConfig to given target
object whose type extends CacheConfig.
- copy() - Method in class com.hazelcast.config.CredentialsFactoryConfig
-
- copy() - Method in class com.hazelcast.config.security.CredentialsIdentityConfig
-
- copy() - Method in interface com.hazelcast.config.security.IdentityConfig
-
Makes a copy (or clone) of the config object.
- copy() - Method in class com.hazelcast.config.security.KerberosIdentityConfig
-
- copy() - Method in class com.hazelcast.config.security.TokenIdentityConfig
-
- copy() - Method in class com.hazelcast.config.security.UsernamePasswordIdentityConfig
-
- copy() - Method in class com.hazelcast.sql.SqlStatement
-
Creates a copy of this instance
- copyCurrentEvent(JsonParser) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for copying contents of the current event that
the given parser instance points to.
- copyCurrentEvent(JsonParser) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- copyCurrentStructure(JsonParser) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for copying contents of the current event
and following events that it encloses
the given parser instance points to.
- copyCurrentStructure(JsonParser) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- copyHexBytes() - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.CharTypes
-
- copyHexChars() - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.CharTypes
-
- copyWithInitializedDefaultMaxSizeForOnHeapMaps(NearCacheConfig) - Static method in class com.hazelcast.config.NearCacheConfigAccessor
-
- count() - Static method in class com.hazelcast.aggregation.Aggregators
-
- count(String) - Static method in class com.hazelcast.aggregation.Aggregators
-
- count() - Method in class com.hazelcast.jet.accumulator.PickAnyAccumulator
-
Returns the count of accumulated objects.
- countDown() - Method in interface com.hazelcast.cp.ICountDownLatch
-
Decrements the count of the latch, releasing all waiting threads if
the count reaches zero.
- CountDownLatchPermission - Class in com.hazelcast.security.permission
-
- CountDownLatchPermission(String, String...) - Constructor for class com.hazelcast.security.permission.CountDownLatchPermission
-
- counting() - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that counts the items it observes.
- CP_BASE_DIR_DEFAULT - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
-
The default directory name for storing CP data.
- CPGroup - Interface in com.hazelcast.cp
-
Contains information about a CP group.
- CPGroup.CPGroupStatus - Enum in com.hazelcast.cp
-
Represents status of a CP group
- CPGroupAvailabilityEvent - Interface in com.hazelcast.cp.event
-
CPGroupAvailabilityEvent is published when a CP group's
availability is decreased or it has lost the majority completely.
- CPGroupAvailabilityListener - Interface in com.hazelcast.cp.event
-
CPGroupAvailabilityListener is notified when availability
of a CP group decreases or it loses the majority completely.
- CPGroupDestroyedException - Exception in com.hazelcast.cp.exception
-
A CPSubsystemException
which is thrown when a request is sent to
a destroyed CP group.
- CPGroupDestroyedException() - Constructor for exception com.hazelcast.cp.exception.CPGroupDestroyedException
-
- CPGroupDestroyedException(CPGroupId) - Constructor for exception com.hazelcast.cp.exception.CPGroupDestroyedException
-
- CPGroupId - Interface in com.hazelcast.cp
-
Identifier for CP groups.
- CPMember - Interface in com.hazelcast.cp
-
A CP member is a Hazelcast member that is internally elected to be part of
the
CPSubsystem
, hence maintain CP data structures.
- CPMembershipEvent - Interface in com.hazelcast.cp.event
-
CPMembershipEvent is published when a CP member is added to
or removed from the CP Subsystem.
- CPMembershipEvent.EventType - Enum in com.hazelcast.cp.event
-
Membership event type.
- CPMembershipListener - Interface in com.hazelcast.cp.event
-
CPMembershipListener is notified when a CP member is added to
or removed from the CP Subsystem.
- CPSession - Interface in com.hazelcast.cp.session
-
Represents a CP session.
- CPSession.CPSessionOwnerType - Enum in com.hazelcast.cp.session
-
Represents type of endpoints that create CP sessions
- CPSessionManagementService - Interface in com.hazelcast.cp.session
-
This interface offers API for managing CP sessions.
- CPSubsystem - Interface in com.hazelcast.cp
-
CP Subsystem is a component of Hazelcast that builds a strongly consistent
layer for a set of distributed data structures.
- CPSubsystemConfig - Class in com.hazelcast.config.cp
-
Contains configuration options for CP Subsystem.
- CPSubsystemConfig() - Constructor for class com.hazelcast.config.cp.CPSubsystemConfig
-
- CPSubsystemConfig(CPSubsystemConfig) - Constructor for class com.hazelcast.config.cp.CPSubsystemConfig
-
- CPSubsystemException - Exception in com.hazelcast.cp.exception
-
Base exception for failures in CP Subsystem
- CPSubsystemException(UUID) - Constructor for exception com.hazelcast.cp.exception.CPSubsystemException
-
- CPSubsystemException(String, UUID) - Constructor for exception com.hazelcast.cp.exception.CPSubsystemException
-
- CPSubsystemException(String, Throwable, UUID) - Constructor for exception com.hazelcast.cp.exception.CPSubsystemException
-
- CPSubsystemManagementService - Interface in com.hazelcast.cp
-
This interface offers APIs for managing CP members and groups.
- CRDTReplicationConfig - Class in com.hazelcast.config
-
Configures the replication mechanism for all
CRDT
implementations.
- CRDTReplicationConfig() - Constructor for class com.hazelcast.config.CRDTReplicationConfig
-
- create() - 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
-
Creates a Portable instance using the given class ID
- CREATE - Static variable in class com.hazelcast.security.permission.InstancePermission
-
- createArray(Class<?>, int) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.BaseConstructor
-
- createArrayNode() - Method in class com.hazelcast.com.fasterxml.jackson.core.ObjectCodec
-
Method for construct root level Array nodes
for Tree Model instances.
- createArrayNode() - Method in class com.hazelcast.com.fasterxml.jackson.core.TreeCodec
-
- createAuditlog() - Method in interface com.hazelcast.auditlog.AuditlogServiceFactory
-
- createBackupEntryProcessor() - Method in interface com.hazelcast.cache.BackupAwareEntryProcessor
-
Either creates a new, specialized EntryProcessor
to be executed on the backup-partition, or returns
- createChildArrayContext(TokenFilter, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
-
- createChildArrayContext(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
-
- createChildArrayContext() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
- createChildArrayContext(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
- createChildObjectContext(TokenFilter, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
-
- createChildObjectContext(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
-
- createChildObjectContext() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
- createChildObjectContext(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
- createClientLoginContext(String, Credentials, Connection) - Method in interface com.hazelcast.security.SecurityContext
-
- createComposer(InputStream) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.Load
-
- createComposer(String) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.Load
-
- createComposer(Reader) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.Load
-
- 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.
- createDefaultInstance() - Static method in class com.hazelcast.com.fasterxml.jackson.core.util.Separators
-
- createDefaultList(int) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.BaseConstructor
-
- createDefaultMap(int) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.BaseConstructor
-
- createDefaultSet(int) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.BaseConstructor
-
- 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
-
- createFlattened(boolean, JsonParser, JsonParser) - Static method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserSequence
-
Method that will construct a sequence (possibly a sequence) that
contains all given sub-parsers.
- createFlattened(JsonParser, JsonParser) - Static method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserSequence
-
Deprecated.
- createFn() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
-
A primitive that returns a new accumulator.
- createGenerator(OutputStream, JsonEncoding) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method for constructing JSON generator for writing JSON content
using specified output stream.
- createGenerator(OutputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Convenience method for constructing generator that uses default
encoding of the format (UTF-8 for JSON and most other data formats).
- createGenerator(Writer) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method for constructing JSON generator for writing JSON content
using specified Writer.
- createGenerator(File, JsonEncoding) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method for constructing JSON generator for writing JSON content
to specified file, overwriting contents it might have (or creating
it if such file does not yet exist).
- createGenerator(DataOutput, JsonEncoding) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method for constructing generator for writing content using specified
DataOutput
instance.
- createGenerator(DataOutput) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Convenience method for constructing generator that uses default
encoding of the format (UTF-8 for JSON and most other data formats).
- createGenerator(DataOutput, JsonEncoding) - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
- createGenerator(DataOutput) - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
- createGenerator(File, JsonEncoding) - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
- createGenerator(OutputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
- createGenerator(OutputStream, JsonEncoding) - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
- createGenerator(Writer) - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
- createInstance() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
- createInstance() - Method in interface com.hazelcast.com.fasterxml.jackson.core.util.Instantiatable
-
Method called to ensure that we have a non-blueprint object to use;
it is either this object (if stateless), or a newly created object
with separate state.
- createIntNumber(String) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructYamlInt
-
- createJsonGenerator(OutputStream, JsonEncoding) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- createJsonGenerator(Writer) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- createJsonGenerator(OutputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- createJsonParser(File) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- createJsonParser(URL) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- createJsonParser(InputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- createJsonParser(Reader) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- createJsonParser(byte[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- createJsonParser(byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- createJsonParser(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- 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
-
- createMatcher(JsonFactory, MatchStrength) - Method in class com.hazelcast.com.fasterxml.jackson.core.format.InputAccessor.Std
-
- createMemberLoginContext(String, Credentials, Connection) - Method in interface com.hazelcast.security.SecurityContext
-
- createNonBlockingByteArrayParser() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- createNonBlockingByteArrayParser() - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
- createObjectNode() - Method in class com.hazelcast.com.fasterxml.jackson.core.ObjectCodec
-
Method for construct root level Object nodes
for Tree Model instances.
- createObjectNode() - Method in class com.hazelcast.com.fasterxml.jackson.core.TreeCodec
-
- createParser(File) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method for constructing JSON parser instance to parse
contents of specified file.
- createParser(URL) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method for constructing JSON parser instance to parse
contents of resource reference by given URL.
- createParser(InputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method for constructing JSON parser instance to parse
the contents accessed via specified input stream.
- createParser(Reader) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method for constructing parser for parsing
the contents accessed via specified Reader.
- createParser(byte[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method for constructing parser for parsing
the contents of given byte array.
- createParser(byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method for constructing parser for parsing
the contents of given byte array.
- createParser(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method for constructing parser for parsing
contents of given String.
- createParser(char[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method for constructing parser for parsing
contents of given char array.
- createParser(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method for constructing parser for parsing contents of given char array.
- createParser(DataInput) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Optional method for constructing parser for reading contents from specified
DataInput
instance.
- createParser(byte[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
- createParser(byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
- createParser(char[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
- createParser(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
- createParser(DataInput) - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
- createParser(File) - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
- createParser(InputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
- createParser(Reader) - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
- createParser(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
- createParser(URL) - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
- createParserWithMatch() - Method in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatMatcher
-
Convenience method for trying to construct a
JsonParser
for
parsing content which is assumed to be in detected data format.
- 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.
- createRoot() - Static method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
Factory method to call to create a symbol table instance with a
randomized seed value.
- createRoot(int) - Static method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
- createRoot() - Static method in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
-
Method called to create root canonicalizer for a
JsonFactory
instance.
- createRoot(int) - Static method in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
-
- createRootContext(TokenFilter) - Static method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
-
- createRootContext(int, int, DupDetector) - Static method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
-
- createRootContext(DupDetector) - Static method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
-
- createRootContext() - Static method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
- createRootContext(DupDetector) - Static method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
- createSecureCallable(Subject, Callable<V>) - Method in interface com.hazelcast.security.SecurityContext
-
Creates secure callable that runs in a sandbox.
- createSecureCallable(Subject, Runnable) - Method in interface com.hazelcast.security.SecurityContext
-
Creates secure callable that runs in a sandbox.
- createSerializer() - Method in interface com.hazelcast.nio.serialization.SerializerHook
-
Creates a new serializer for the serialization type
- 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
-
- createSnippet(int, int) - Method in class com.hazelcast.org.snakeyaml.engine.v2.exceptions.Mark
-
- createSnippet() - Method in class com.hazelcast.org.snakeyaml.engine.v2.exceptions.Mark
-
- createSqlContext(Subject) - Method in interface com.hazelcast.security.SecurityContext
-
- creationTime() - Method in interface com.hazelcast.cp.session.CPSession
-
Returns the timestamp of when the session was created
- 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(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[]
.
- 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.
- CsvFileFormat<T> - Class in com.hazelcast.jet.pipeline.file
-
- currentName() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method that can be called to get the name associated with
the current token: for
JsonToken.FIELD_NAME
s it will
be the same as what
JsonParser.getText()
returns;
for field values it will be preceding field name;
and for others (array values, root-level values) null.
- currentToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- currentToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- currentToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Accessor to find which token parser currently points to, if any;
null will be returned if none.
- currentToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- currentTokenId() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- currentTokenId() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- currentTokenId() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- currentTokenId() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- custom() - Static method in class com.hazelcast.jet.retry.RetryStrategies
-
Create a builder which can be used for setting up an arbitrarily complex
strategy.
- customTransform(String, SupplierEx<Processor>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
-
- customTransform(String, ProcessorSupplier) - Method in interface com.hazelcast.jet.pipeline.BatchStage
-
- customTransform(String, ProcessorMetaSupplier) - Method in interface com.hazelcast.jet.pipeline.BatchStage
-
- customTransform(String, SupplierEx<Processor>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
-
- customTransform(String, ProcessorSupplier) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
-
- customTransform(String, ProcessorMetaSupplier) - 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, 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, 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, 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, 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, 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, SupplierEx<Processor>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
-
- customTransform(String, ProcessorSupplier) - Method in interface com.hazelcast.jet.pipeline.StreamStage
-
- customTransform(String, ProcessorMetaSupplier) - Method in interface com.hazelcast.jet.pipeline.StreamStage
-
- customTransform(String, SupplierEx<Processor>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
-
- customTransform(String, ProcessorSupplier) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
-
- customTransform(String, ProcessorMetaSupplier) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
-
- DAG - Class in com.hazelcast.jet.core
-
Describes a computation to be performed by the Jet computation engine.
- DAG() - Constructor for class com.hazelcast.jet.core.DAG
-
- DAG - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
-
Serialization ID of the
DAG
class.
- dagJsonString() - Method in class com.hazelcast.jet.JobStateSnapshot
-
Returns the JSON representation of the DAG of the job this snapshot was
created from.
- DATA_MEMBER_SELECTOR - Static variable in class com.hazelcast.cluster.memberselector.MemberSelectors
-
A
MemberSelector
instance that selects only data members that own a partition
- DataFormatDetector - Class in com.hazelcast.com.fasterxml.jackson.core.format
-
Simple helper class that allows data format (content type) auto-detection,
given an ordered set of
JsonFactory
instances to use for actual low-level
detection.
- DataFormatDetector(JsonFactory...) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatDetector
-
- DataFormatDetector(Collection<JsonFactory>) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatDetector
-
- DataFormatMatcher - Class in com.hazelcast.com.fasterxml.jackson.core.format
-
Result object constructed by
DataFormatDetector
when requested
to detect format of given input data.
- DataFormatMatcher(InputStream, byte[], int, int, JsonFactory, MatchStrength) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatMatcher
-
- DataOutputAsStream - Class in com.hazelcast.com.fasterxml.jackson.core.io
-
Helper class to support use of
DataOutput
for output, directly,
without caller having to provide for implementation.
- DataOutputAsStream(DataOutput) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.io.DataOutputAsStream
-
- 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
-
- decode(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
-
Convenience method for decoding contents of a Base64-encoded String,
using this variant's settings.
- decode(String, ByteArrayBuilder) - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
-
Convenience method for decoding contents of a Base64-encoded String,
using this variant's settings
and appending decoded binary data using provided
ByteArrayBuilder
.
- decode(String) - Method in enum com.hazelcast.config.security.TokenEncoding
-
- decode(ByteBuffer) - Static method in class com.hazelcast.org.snakeyaml.engine.v2.common.UriEncoder
-
Decode '%'-escaped characters.
- decode(String) - Static method in class com.hazelcast.org.snakeyaml.engine.v2.common.UriEncoder
-
- decodeBase64Byte(byte) - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
-
- decodeBase64Char(char) - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
-
- decodeBase64Char(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
-
- decorate(IOContext, InputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.InputDecorator
-
Method called by
JsonFactory
instance when
creating parser given an
InputStream
, when this decorator
has been registered.
- decorate(IOContext, byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.InputDecorator
-
Method called by
JsonFactory
instance when
creating parser on given "raw" byte source.
- decorate(IOContext, DataInput) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.InputDecorator
-
Method called by
JsonFactory
instance when
creating parser given an
DataInput
, when this decorator
has been registered.
- decorate(IOContext, Reader) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.InputDecorator
-
Method called by
JsonFactory
instance when
creating parser given an
Reader
, when this decorator
has been registered.
- decorate(IOContext, OutputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.OutputDecorator
-
Method called by
JsonFactory
instance when
creating generator for given
OutputStream
, when this decorator
has been registered.
- decorate(IOContext, Writer) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.OutputDecorator
-
Method called by
JsonFactory
instance when
creating generator for given
Writer
, when this decorator
has been registered.
- 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.
- deduct(PickAnyAccumulator<T>) - Method in class com.hazelcast.jet.accumulator.PickAnyAccumulator
-
Deducts another accumulator from this one.
- deductFn() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
-
A primitive that accepts two accumulators and updates the state of the
left-hand one by deducting the state of the right-hand one from it.
- DEFAULT_ACKNOWLEDGE_TYPE - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
-
- DEFAULT_ALLOWED_FUTURE_MILLIS - Static variable in class com.hazelcast.config.FlakeIdGeneratorConfig
-
- DEFAULT_APPEND_REQUEST_BACKOFF_TIMEOUT_IN_MILLIS - Static variable in class com.hazelcast.config.cp.RaftAlgorithmConfig
-
Default append request backoff timeout in millis.
- DEFAULT_APPEND_REQUEST_MAX_ENTRY_COUNT - Static variable in class com.hazelcast.config.cp.RaftAlgorithmConfig
-
The default maximum append request entry count.
- DEFAULT_ASNYC_FILLUP - Static variable in class com.hazelcast.config.ReplicatedMapConfig
-
Default value of asynchronous fill up
- DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.CardinalityEstimatorConfig
-
The number of async backups per estimator
- DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.CollectionConfig
-
The default number of asynchronous backups
- DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.MultiMapConfig
-
The default number of asynchronous backups for this MultiMap.
- DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.QueueConfig
-
Default value of the asynchronous backup count.
- DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.RingbufferConfig
-
Default value of asynchronous backup count
- DEFAULT_BACKUP_COUNT - Static variable in class com.hazelcast.config.CacheSimpleConfig
-
The default number of backups.
- DEFAULT_BACKUP_COUNT - Static variable in class com.hazelcast.config.MapConfig
-
The default number of backups
- DEFAULT_BACKUP_COUNT - Static variable in class com.hazelcast.jet.config.InstanceConfig
-
- 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_BINARY_WRITE_CAPABILITIES - Static variable in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Default set of
StreamReadCapability
ies for typical binary formats,
to use either as-is, or as a base with possible differences.
- DEFAULT_BITS_NODE_ID - Static variable in class com.hazelcast.config.FlakeIdGeneratorConfig
-
- DEFAULT_BITS_SEQUENCE - Static variable in class com.hazelcast.config.FlakeIdGeneratorConfig
-
- DEFAULT_BUFFER_SIZE - Static variable in class com.hazelcast.config.QueryCacheConfig
-
By default, only buffer last DEFAULT_BUFFER_SIZE
events fired from a partition.
- DEFAULT_BUFFER_SIZE_BYTE - Static variable in class com.hazelcast.client.config.SocketOptions
-
default buffer size of Bytes
- DEFAULT_BULK_LOAD - Static variable in class com.hazelcast.config.QueueStoreConfig
-
The default size of batches in which the queue will be loaded from the
queue store.
- DEFAULT_CACHED_DESERIALIZED_VALUES - Static variable in class com.hazelcast.config.MapConfig
-
We want to cache values only when an index is defined.
- DEFAULT_CAPACITY - Static variable in class com.hazelcast.config.EventJournalConfig
-
Default value of capacity of the event journal.
- DEFAULT_CAPACITY - Static variable in class com.hazelcast.config.RingbufferConfig
-
Default value of capacity of the RingBuffer.
- DEFAULT_CIPHER_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
-
- DEFAULT_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_CLUSTER_NAME - Static variable in class com.hazelcast.jet.config.JetConfig
-
The default cluster name for a Jet cluster.
- DEFAULT_COALESCE - Static variable in class com.hazelcast.config.QueryCacheConfig
-
Default value of coalesce property.
- DEFAULT_COMMIT_INDEX_ADVANCE_COUNT_TO_SNAPSHOT - Static variable in class com.hazelcast.config.cp.RaftAlgorithmConfig
-
The default commit index advance count on Raft log to take a snapshot.
- DEFAULT_CURSOR_BUFFER_SIZE - Static variable in class com.hazelcast.sql.SqlStatement
-
Default cursor buffer size.
- DEFAULT_DATA_LOAD_TIMEOUT - Static variable in class com.hazelcast.config.HotRestartPersistenceConfig
-
Default load timeout
- DEFAULT_DATA_LOAD_TIMEOUT_SECONDS - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
-
The default data load timeout duration for restoring CP data from disk.
- DEFAULT_DELAY_SECONDS - Static variable in class com.hazelcast.config.QueryCacheConfig
-
Default value of delay seconds which an event wait in the buffer of a node, before sending to QueryCache
.
- DEFAULT_DISCOVERY_PERIOD_SECONDS - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
-
- DEFAULT_DURABILITY - Static variable in class com.hazelcast.config.DurableExecutorConfig
-
Durability of Executor.
- DEFAULT_EMPTY_QUEUE_TTL - Static variable in class com.hazelcast.config.QueueConfig
-
Default value for the TTL (time to live) for empty Queue.
- DEFAULT_ENABLED - Static variable in class com.hazelcast.config.InstanceTrackingConfig
-
Default setting whether instance tracking should be enabled or not.
- DEFAULT_ENABLED - Static variable in class com.hazelcast.config.MulticastConfig
-
Whether the multicast discovery mechanism has been enabled
- DEFAULT_ENTRY_STATS_ENABLED - Static variable in class com.hazelcast.config.MapConfig
-
Default value of whether per entry statistics are enabled or not
- DEFAULT_EPOCH_START - Static variable in class com.hazelcast.config.FlakeIdGeneratorConfig
-
- DEFAULT_EVICTION_POLICY - Static variable in class com.hazelcast.config.EvictionConfig
-
Default Eviction Policy.
- DEFAULT_EVICTION_POLICY - Static variable in class com.hazelcast.config.MapConfig
-
Default eviction policy
- DEFAULT_EXACTLY_ONCE - Static variable in class com.hazelcast.jet.pipeline.JdbcSinkBuilder
-
The default setting for whether exactly-once is allowed for the sink.
- DEFAULT_EXECUTOR_POOL_SIZE - Static variable in class com.hazelcast.config.SqlConfig
-
Default number of threads responsible for execution of SQL statements.
- DEFAULT_FACTORY_FEATURE_FLAGS - Static variable in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Bitfield (set of flags) of all factory features that are enabled by default.
- DEFAULT_FACTORY_FEATURE_FLAGS - Static variable in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
Bitfield (set of flags) of all factory features that are enabled by default.
- 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
-
- DEFAULT_GENERATOR_FEATURE_FLAGS - Static variable in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Bitfield (set of flags) of all generator features that are enabled
by default.
- DEFAULT_GENERATOR_FEATURE_FLAGS - Static variable in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
Bitfield (set of flags) of all generator features that are enabled
by default.
- 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_INVALIDATE_ON_CHANGE - Static variable in class com.hazelcast.config.NearCacheConfig
-
- DEFAULT_JET_MULTICAST_PORT - Static variable in class com.hazelcast.jet.config.JetConfig
-
The default port number for the cluster auto-discovery mechanism's
multicast communication.
- DEFAULT_KEYSTORE_TYPE - Static variable in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
-
The default Java KeyStore type (PKCS12).
- DEFAULT_LEADER_ELECTION_TIMEOUT_IN_MILLIS - Static variable in class com.hazelcast.config.cp.RaftAlgorithmConfig
-
The default leader election timeout in millis.
- DEFAULT_LEADER_HEARTBEAT_PERIOD_IN_MILLIS - Static variable in class com.hazelcast.config.cp.RaftAlgorithmConfig
-
The default leader heartbeat period in millis.
- DEFAULT_LOCAL_UPDATE_POLICY - Static variable in class com.hazelcast.config.NearCacheConfig
-
- DEFAULT_LOCK_ACQUIRE_LIMIT - Static variable in class com.hazelcast.config.cp.FencedLockConfig
-
The default reentrant lock acquire limit of
FencedLock
.
- DEFAULT_LOOPBACK_MODE_ENABLED - Static variable in class com.hazelcast.config.MulticastConfig
-
Default flag that indicates if the loopback mode
is turned on or off.
- DEFAULT_MAX_ATTEMPT - Static variable in class com.hazelcast.client.config.ClientIcmpPingConfig
-
- DEFAULT_MAX_CONCURRENT_INVOCATIONS - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
-
- DEFAULT_MAX_CONCURRENT_REPLICATION_TARGETS - Static variable in class com.hazelcast.config.CRDTReplicationConfig
-
The default maximum number of members to which the CRDT states are
replicated in a single round.
- DEFAULT_MAX_ENTRY_COUNT - Static variable in class com.hazelcast.config.EvictionConfig
-
Default maximum entry count.
- DEFAULT_MAX_IDLE_SECONDS - Static variable in class com.hazelcast.config.MapConfig
-
The number of default time to wait eviction in seconds.
- DEFAULT_MAX_IDLE_SECONDS - Static variable in class com.hazelcast.config.NearCacheConfig
-
Default value of the maximum idle time for eviction in seconds.
- DEFAULT_MAX_INPUT_LOOKAHEAD - Static variable in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatDetector
-
By default we will look ahead at most 64 bytes; in most cases,
much less (4 bytes or so) is needed, but we will allow bit more
leniency to support data formats that need more complex heuristics.
- DEFAULT_MAX_MISSED_LEADER_HEARTBEAT_COUNT - Static variable in class com.hazelcast.config.cp.RaftAlgorithmConfig
-
Default max number of missed heartbeats to trigger a new leader election.
- DEFAULT_MAX_SIZE - Static variable in class com.hazelcast.config.CollectionConfig
-
Default maximum size for the Configuration.
- DEFAULT_MAX_SIZE - Static variable in class com.hazelcast.config.MapConfig
-
Default max size.
- DEFAULT_MAX_SIZE - Static variable in class com.hazelcast.config.QueueConfig
-
Default value for the maximum size of the Queue.
- DEFAULT_MAX_SIZE_POLICY - Static variable in class com.hazelcast.config.EvictionConfig
-
Default Max-Size Policy.
- DEFAULT_MAX_SIZE_POLICY - Static variable in class com.hazelcast.config.MapConfig
-
Default max size policy
- DEFAULT_MAX_TARGET_ENDPOINTS - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
-
- DEFAULT_MEMORY_FORMAT - Static variable in class com.hazelcast.config.NearCacheConfig
-
Default value for the in-memory format.
- DEFAULT_MEMORY_LIMIT - Static variable in class com.hazelcast.config.QueueStoreConfig
-
The default number of queue item values to keep in memory.
- DEFAULT_MERGE_POLICY - Static variable in class com.hazelcast.config.MergePolicyConfig
-
Default merge policy.
- DEFAULT_MERGE_POLICY_CONFIG - Static variable in class com.hazelcast.config.CardinalityEstimatorConfig
-
The default merge policy used for cardinality estimators
- DEFAULT_METADATA_POLICY - Static variable in class com.hazelcast.config.MapConfig
-
Default metadata policy
- DEFAULT_METADATA_SPACE_PERCENTAGE - Static variable in class com.hazelcast.config.NativeMemoryConfig
-
Default metadata space percentage
- DEFAULT_METRICS_RETENTION_SECONDS - Static variable in class com.hazelcast.config.MetricsManagementCenterConfig
-
Default retention period for metrics.
- DEFAULT_MIN_BLOCK_SIZE - Static variable in class com.hazelcast.config.NativeMemoryConfig
-
Default minimum block size in bytes
- DEFAULT_MIN_STD_DEVIATION - Static variable in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
-
Default minimum standard deviation (in milliseconds) to use for the normal distribution used when
calculating phi.
- DEFAULT_MISSING_CP_MEMBER_AUTO_REMOVAL_SECONDS - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
-
The default duration to wait before automatically removing
a missing CP member from CP Subsystem.
- DEFAULT_MULTICAST_GROUP - Static variable in class com.hazelcast.config.MulticastConfig
-
Default group of multicast.
- DEFAULT_MULTICAST_PORT - Static variable in class com.hazelcast.config.MulticastConfig
-
Default value of port.
- DEFAULT_MULTICAST_TIMEOUT_SECONDS - Static variable in class com.hazelcast.config.MulticastConfig
-
Default timeout of multicast in seconds.
- DEFAULT_MULTICAST_TTL - Static variable in class com.hazelcast.config.MulticastConfig
-
Default value of time to live of multicast.
- DEFAULT_PACKET_SIZE_LIMIT - Static variable in class com.hazelcast.jet.config.EdgeConfig
-
- DEFAULT_PAGE_SIZE - Static variable in class com.hazelcast.config.NativeMemoryConfig
-
Default page size in bytes
- DEFAULT_PARALLELISM - Static variable in class com.hazelcast.config.HotRestartPersistenceConfig
-
Default level of parallelism in Hot Restart Persistence.
- DEFAULT_PARSER_FEATURE_FLAGS - Static variable in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Bitfield (set of flags) of all parser features that are enabled
by default.
- DEFAULT_PARSER_FEATURE_FLAGS - Static variable in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
Bitfield (set of flags) of all parser features that are enabled
by default.
- DEFAULT_PERSIST_WAN_REPLICATED_DATA - Static variable in class com.hazelcast.config.WanConsumerConfig
-
- DEFAULT_PHI_THRESHOLD - Static variable in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
-
Default threshold for suspicion (φ) level.
- DEFAULT_POLLING_INTERVAL - Static variable in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
-
Default interval (in seconds) for polling for changes in the KeyStore: 0 (polling
disabled).
- DEFAULT_POLLING_INTERVAL - Static variable in class com.hazelcast.config.VaultSecureStoreConfig
-
Default interval (in seconds) for polling for changes to the encryption key: 0
(polling disabled).
- DEFAULT_POOL_SIZE - Static variable in class com.hazelcast.config.DurableExecutorConfig
-
The number of executor threads per Member for the Executor based on this configuration.
- DEFAULT_POOL_SIZE - Static variable in class com.hazelcast.config.ExecutorConfig
-
The number of executor threads per Member for the Executor based on this configuration.
- DEFAULT_POPULATE - Static variable in class com.hazelcast.config.QueryCacheConfig
-
By default, execute an initial population query prior to creation of the QueryCache
.
- DEFAULT_PORT - Static variable in class com.hazelcast.config.NetworkConfig
-
Default value of port number.
- DEFAULT_PORT - Static variable in class com.hazelcast.config.ServerSocketEndpointConfig
-
Default value of port number.
- DEFAULT_PREFETCH_COUNT - Static variable in class com.hazelcast.config.FlakeIdGeneratorConfig
-
- DEFAULT_PREFETCH_VALIDITY_MILLIS - Static variable in class com.hazelcast.config.FlakeIdGeneratorConfig
-
- DEFAULT_QUEUE_CAPACITY - Static variable in class com.hazelcast.config.ExecutorConfig
-
Capacity of queue.
- DEFAULT_QUEUE_CAPACITY - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
-
- DEFAULT_QUEUE_FULL_BEHAVIOUR - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
-
- DEFAULT_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_QUOTE_CHAR - Static variable in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- 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_CAPABILITIES - Static variable in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Default set of
StreamReadCapability
ies that may be used as
basis for format-specific readers (or as bogus instance if non-null
set needs to be passed).
- DEFAULT_REALM - Static variable in class com.hazelcast.config.security.RealmConfig
-
Default security realm instance.
- DEFAULT_RECEIVE_WINDOW_MULTIPLIER - Static variable in class com.hazelcast.jet.config.EdgeConfig
-
- DEFAULT_REPLICA_COUNT - Static variable in class com.hazelcast.config.PNCounterConfig
-
The default number of replicas on which state for this CRDT is kept
- DEFAULT_REPLICATION_PERIOD_MILLIS - Static variable in class com.hazelcast.config.CRDTReplicationConfig
-
The default period between two CRDT replication rounds.
- DEFAULT_RESPONSE_TIMEOUT_MILLIS - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
-
- DEFAULT_RING_BUFFER_CAPACITY - Static variable in class com.hazelcast.config.DurableExecutorConfig
-
Capacity of RingBuffer (per partition).
- DEFAULT_ROOT_VALUE_SEPARATOR - Static variable in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- DEFAULT_ROOT_VALUE_SEPARATOR - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.PrettyPrinter
-
Default String used for separating root values is single space.
- DEFAULT_ROOT_VALUE_SEPARATOR - Static variable in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
Constant that specifies default "root-level" separator to use between
root values: a single space character.
- 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_SEMAPHORE_JDK_COMPATIBILITY - Static variable in class com.hazelcast.config.cp.SemaphoreConfig
-
The default value for the JDK compatibility mode
of CP
ISemaphore
- DEFAULT_SEPARATORS - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.PrettyPrinter
-
- DEFAULT_SERIALIZE_KEYS - Static variable in class com.hazelcast.config.NearCacheConfig
-
Do not serialize by default
- DEFAULT_SESSION_TTL_SECONDS - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
-
The default value for a CP session to be kept alive after the last
heartbeat it has received.
- DEFAULT_SNAPSHOT_ENABLED - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
-
- DEFAULT_SOCKET_CONNECT_TIMEOUT_SECONDS - Static variable in class com.hazelcast.config.EndpointConfig
-
- DEFAULT_SOCKET_LINGER_SECONDS - Static variable in class com.hazelcast.config.EndpointConfig
-
- DEFAULT_SOCKET_RECEIVE_BUFFER_SIZE_KB - Static variable in class com.hazelcast.config.EndpointConfig
-
- DEFAULT_SOCKET_SEND_BUFFER_SIZE_KB - Static variable in class com.hazelcast.config.EndpointConfig
-
- DEFAULT_STATEMENT_TIMEOUT_MILLIS - Static variable in class com.hazelcast.config.SqlConfig
-
Default timeout in milliseconds that is applied to statements without explicit timeout.
- DEFAULT_STATISTICS_ENABLED - Static variable in class com.hazelcast.config.MapConfig
-
Default value of whether statistics are enabled or not
- DEFAULT_STATISTICS_ENABLED - Static variable in class com.hazelcast.config.PNCounterConfig
-
Default value for statistics enabled.
- DEFAULT_STATISTICS_ENABLED - Static variable in class com.hazelcast.config.ReliableTopicConfig
-
Default value for statistics enabled.
- DEFAULT_STORE_INITIAL_DELAY_SECONDS - Static variable in class com.hazelcast.config.NearCachePreloaderConfig
-
Default initial delay for the Near Cache key storage.
- DEFAULT_STORE_INTERVAL_SECONDS - Static variable in class com.hazelcast.config.NearCachePreloaderConfig
-
Default interval for the Near Cache key storage (in seconds).
- DEFAULT_SYMMETRIC_ALGORITHM - Static variable in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
-
Default symmetric encryption algorithm.
- DEFAULT_SYMMETRIC_ALGORITHM - Static variable in class com.hazelcast.config.SymmetricEncryptionConfig
-
Deprecated.
Default symmetric encryption algorithm
- DEFAULT_SYMMETRIC_PASSWORD - Static variable in class com.hazelcast.config.SymmetricEncryptionConfig
-
Deprecated.
Default symmetric encryption password
- DEFAULT_SYMMETRIC_SALT - Static variable in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
-
Default symmetric encryption salt.
- DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.CardinalityEstimatorConfig
-
The number of sync backups per estimator
- DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.CollectionConfig
-
The default number of synchronous backups
- DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.MultiMapConfig
-
The default number of synchronous backups for this MultiMap.
- DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.QueueConfig
-
Default value for the synchronous backup count.
- DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.RingbufferConfig
-
Default value of synchronous backup count
- DEFAULT_TARGET_ENDPOINTS - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
-
- DEFAULT_TEXTUAL_WRITE_CAPABILITIES - Static variable in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Default set of
StreamReadCapability
ies for typical textual formats,
to use either as-is, or as a base with possible differences.
- 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_TOPIC_OVERLOAD_POLICY - Static variable in class com.hazelcast.client.config.ClientReliableTopicConfig
-
The default slow consumer policy.
- DEFAULT_TOPIC_OVERLOAD_POLICY - Static variable in class com.hazelcast.config.ReliableTopicConfig
-
The default slow consumer policy.
- DEFAULT_TTL - Static variable in class com.hazelcast.client.config.ClientIcmpPingConfig
-
- DEFAULT_TTL_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
-
- DEFAULT_UNIQUE_KEY_TRANSFORMATION - Static variable in class com.hazelcast.config.BitmapIndexOptions
-
- DEFAULT_USE_ENDPOINT_PRIVATE_ADDRESS - Static variable in class com.hazelcast.config.WanBatchPublisherConfig
-
- DEFAULT_VALIDATION_TIMEOUT - Static variable in class com.hazelcast.config.HotRestartPersistenceConfig
-
Default validation timeout
- DEFAULT_VALUE_COLLECTION_TYPE - Static variable in class com.hazelcast.config.MultiMapConfig
-
Default value collection type of this MultiMap.
- DEFAULT_WRITE_BATCH_SIZE - Static variable in class com.hazelcast.config.MapStoreConfig
-
Default batch size for writing
- DEFAULT_WRITE_CAPABILITIES - Static variable in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Default set of
StreamReadCapability
ies that may be used as
basis for format-specific readers (or as bogus instance if non-null
set needs to be passed).
- DEFAULT_WRITE_COALESCING - Static variable in class com.hazelcast.config.MapStoreConfig
-
Default write coalescing behavior
- DEFAULT_WRITE_DELAY_SECONDS - Static variable in class com.hazelcast.config.MapStoreConfig
-
Default delay seconds for writing
- DefaultAuthenticationConfig - Class in com.hazelcast.config.security
-
- defaultFlowStyle - Variable in class com.hazelcast.org.snakeyaml.engine.v2.representer.BaseRepresenter
-
- DefaultIndenter - Class in com.hazelcast.com.fasterxml.jackson.core.util
-
- DefaultIndenter() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.DefaultIndenter
-
Indent with two spaces and the system's default line feed
- DefaultIndenter(String, String) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.DefaultIndenter
-
Create an indenter which uses the indent
string to indent one level
and the eol
string to separate lines.
- 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
-
- 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.
- DefaultPrettyPrinter - Class in com.hazelcast.com.fasterxml.jackson.core.util
-
Default
PrettyPrinter
implementation that uses 2-space
indentation with platform-default linefeeds.
- DefaultPrettyPrinter() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
- DefaultPrettyPrinter(String) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
Constructor that specifies separator String to use between root values;
if null, no separator is printed.
- DefaultPrettyPrinter(SerializableString) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
Constructor that specifies separator String to use between root values;
if null, no separator is printed.
- DefaultPrettyPrinter(DefaultPrettyPrinter) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
- DefaultPrettyPrinter(DefaultPrettyPrinter, SerializableString) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
- DefaultPrettyPrinter.FixedSpaceIndenter - Class in com.hazelcast.com.fasterxml.jackson.core.util
-
This is a very simple indenter that only adds a
single space for indentation.
- DefaultPrettyPrinter.Indenter - Interface in com.hazelcast.com.fasterxml.jackson.core.util
-
Interface that defines objects that can produce indentation used
to separate object entries and array values.
- DefaultPrettyPrinter.NopIndenter - Class in com.hazelcast.com.fasterxml.jackson.core.util
-
Dummy implementation that adds no indentation whatsoever
- defaultScalarStyle - Variable in class com.hazelcast.org.snakeyaml.engine.v2.representer.BaseRepresenter
-
- delegate - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
Delegate object that method calls are delegated to.
- delegate() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- delegate - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
Delegate object that method calls are delegated to.
- delegate() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
Accessor for getting the immediate
JsonParser
this parser delegates calls to.
- delegateCopyMethods - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- delete(Long) - Method in interface com.hazelcast.collection.QueueStore
-
Deletes the entry with a given key from the store.
- delete(Object) - Method in interface com.hazelcast.map.BaseMap
-
Removes the mapping for a key from this map if it is present.
- delete(Object) - Method in interface com.hazelcast.map.IMap
-
Removes the mapping for the key from this map if it is present.
- delete(K) - Method in interface com.hazelcast.map.MapStore
-
Deletes the entry with a given key from the store.
- delete(K) - Method in class com.hazelcast.map.MapStoreAdapter
-
Deletes the entry with a given key from the store.
- delete(Object) - Method in interface com.hazelcast.multimap.MultiMap
-
Deletes all the entries with the given key.
- delete(Object) - Method in interface com.hazelcast.transaction.TransactionalMap
-
- 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.
- deleteSnapshot(JetCommandLine.Verbosity, JetCommandLine.TargetsMixin, String) - Method in class com.hazelcast.jet.server.JetCommandLine
-
- DenyAllPermissionCollection - Class in com.hazelcast.security.permission
-
- DenyAllPermissionCollection() - Constructor for class com.hazelcast.security.permission.DenyAllPermissionCollection
-
- DERIVED_FEATURES_MASK - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
Set of feature masks related to features that need updates of other
local configuration or state.
- description() - Method in interface com.hazelcast.jet.core.JobSuspensionCause
-
Describes the job suspension cause in a human-readable form.
- 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 class com.hazelcast.jet.JobStateSnapshot
-
Destroy the underlying distributed object.
- 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 interface com.hazelcast.nio.serialization.Serializer
-
Called when instance is shutting down.
- destroy() - Method in interface com.hazelcast.security.ICredentialsFactory
-
- destroy() - Method in interface com.hazelcast.security.IPermissionPolicy
-
- DESTROY - Static variable in class com.hazelcast.security.permission.InstancePermission
-
- destroy() - Method in interface com.hazelcast.security.SecurityContext
-
- 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
-
- 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.
- 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
-
- destroyServiceFn() - Method in class com.hazelcast.jet.pipeline.ServiceFactory
-
Returns the function that destroys the service object at the end of the
Jet job.
- detectEncoding() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ByteSourceJsonBootstrapper
-
Method that should be called after constructing an instace.
- 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.
- 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.
- DirectiveToken<T> - Class in com.hazelcast.org.snakeyaml.engine.v2.tokens
-
- DirectiveToken(String, Optional<List<T>>, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.tokens.DirectiveToken
-
- disable(JsonGenerator.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- disable(JsonParser.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- disable(JsonGenerator.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonGeneratorImpl
-
- disable(JsonFactory.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- disable(JsonParser.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method for disabling specified parser features
(check
JsonParser.Feature
for list of features)
- disable(JsonGenerator.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- disable(JsonReadFeature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactoryBuilder
-
- disable(JsonReadFeature, JsonReadFeature...) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactoryBuilder
-
- disable(JsonWriteFeature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactoryBuilder
-
- disable(JsonWriteFeature, JsonWriteFeature...) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactoryBuilder
-
- disable(JsonGenerator.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- disable(JsonParser.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- disable(JsonFactory.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- disable(StreamReadFeature) - Method in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- disable(StreamReadFeature, StreamReadFeature...) - Method in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- disable(StreamWriteFeature) - Method in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- disable(StreamWriteFeature, StreamWriteFeature...) - Method in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- disable(JsonReadFeature) - Method in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- disable(JsonReadFeature, JsonReadFeature...) - Method in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- disable(JsonWriteFeature) - Method in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- disable(JsonWriteFeature, JsonWriteFeature...) - Method in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- disable(JsonGenerator.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- disable(JsonParser.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- DISABLE_ROLLING - Static variable in class com.hazelcast.jet.pipeline.FileSinkBuilder
-
- DISABLE_STALE_READ_ON_PARTITION_MIGRATION - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Hazelcast allows read operations to be performed while a partition is
being migrated.
- disableAllGroups() - Method in class com.hazelcast.config.RestApiConfig
-
Disables all REST endpoint groups.
- disableAllGroups() - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Disables all REST endpoint groups.
- disableCompleteCall() - Method in class com.hazelcast.jet.core.test.TestSupport
-
Disables calling complete()
method during the test.
- disableGroups(RestEndpointGroup...) - Method in class com.hazelcast.config.RestApiConfig
-
Disables provided REST endpoint groups.
- disableGroups(RestEndpointGroup...) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Disables provided REST endpoint groups.
- disableLogging() - Method in class com.hazelcast.jet.core.test.TestSupport
-
Disables logging of input and output objects.
- disableProgressAssertion() - Method in class com.hazelcast.jet.core.test.TestSupport
-
Disables checking of progress of processing methods (see
class javadoc
for information on what is "progress").
- disableReentrancy() - Method in class com.hazelcast.config.cp.FencedLockConfig
-
Disable reentrancy.
- disableSnapshots() - Method in class com.hazelcast.jet.core.test.TestSupport
-
Disable snapshot save and restore before first item and after each
process()
and complete()
call.
- DiscardMergePolicy<V,T extends MergingValue<V>> - Class in com.hazelcast.spi.merge
-
Merges only entries from the destination data structure and discards all entries from the source data structure.
- DiscardMergePolicy() - Constructor for class com.hazelcast.spi.merge.DiscardMergePolicy
-
- discoverLocalMetadata() - Method in class com.hazelcast.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(DiscoveryServiceProvider, NodeFilter, String, Collection<DiscoveryStrategyConfig>) - Constructor for class com.hazelcast.config.DiscoveryConfig
-
- DiscoveryConfig(DiscoveryConfig) - Constructor for class com.hazelcast.config.DiscoveryConfig
-
- DiscoveryMode - Enum in com.hazelcast.spi.discovery.integration
-
The
DiscoveryMode
describes how the
DiscoveryStrategy
is going
to behave on discovery requests.
- DiscoveryNode - Class in com.hazelcast.spi.discovery
-
A DiscoveryNode
describes a nodes addresses (private and if
necessary a public one) as well as attributes assigned to this node.
- DiscoveryNode() - Constructor for class com.hazelcast.spi.discovery.DiscoveryNode
-
- DiscoveryService - Interface in com.hazelcast.spi.discovery.integration
-
The DiscoveryService
interface defines the basic entry point
into the Discovery SPI implementation.
- DiscoveryServiceProvider - Interface in com.hazelcast.spi.discovery.integration
-
The
DiscoveryServiceProvider
interface provides the possibility to build
DiscoveryService
s.
- DiscoveryServiceSettings - Class in com.hazelcast.spi.discovery.integration
-
- DiscoveryServiceSettings() - Constructor for class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
-
- DiscoveryStrategy - Interface in com.hazelcast.spi.discovery
-
The DiscoveryStrategy
itself is the actual implementation to discover
nodes based on whatever environment is used to run the Hazelcast cloud.
- DiscoveryStrategyConfig - Class in com.hazelcast.config
-
This configuration class describes a
DiscoveryStrategy
based on a parsed XML or configured manually using the config API
- DiscoveryStrategyConfig() - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
-
- DiscoveryStrategyConfig(String) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
-
- DiscoveryStrategyConfig(String, Map<String, Comparable>) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
-
- DiscoveryStrategyConfig(DiscoveryStrategyFactory) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
-
- DiscoveryStrategyConfig(DiscoveryStrategyFactory, Map<String, Comparable>) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
-
- DiscoveryStrategyConfig(DiscoveryStrategyConfig) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
-
- DiscoveryStrategyFactory - Interface in com.hazelcast.spi.discovery
-
The DiscoveryStrategyFactory
is the entry point for strategy vendors.
- DiscoveryStrategyFactory.DiscoveryStrategyLevel - Enum in com.hazelcast.spi.discovery
-
Level of the discovery strategy.
- discoveryStrategyLevel() - Method in 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.
- dispose() - Method in interface com.hazelcast.scheduledexecutor.IScheduledFuture
-
- disposeResult(long) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
-
Disposes the result with the given taskId
- distinct() - Static method in class com.hazelcast.aggregation.Aggregators
-
- distinct(String) - Static method in class com.hazelcast.aggregation.Aggregators
-
- distinct() - Method in interface com.hazelcast.jet.pipeline.BatchStage
-
Attaches a stage that emits just the items that are distinct according
to their definition of equality (equals
and hashCode
).
- distinct() - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
-
Attaches a stage that emits just the items that are distinct according
to the grouping key (no two items which map to the same key will be on
the output).
- distinct() - Method in interface com.hazelcast.jet.pipeline.StageWithKeyAndWindow
-
Attaches a stage that passes through just the items that are distinct
within their window according to the grouping key (no two items emitted
for a window map to the same key).
- distinct() - Method in interface com.hazelcast.jet.pipeline.StageWithWindow
-
Attaches a stage that passes through just the items that are distinct
within their window (no two items emitted for a window are equal).
- DISTRIBUTE_TO_ALL - Static variable in class com.hazelcast.jet.core.Edge
-
- distributed() - Method in class com.hazelcast.jet.core.Edge
-
Declares that the edge is distributed.
- distributed(int) - Method in class com.hazelcast.jet.pipeline.SourceBuilder.Batch
-
- distributed(int) - Method in class com.hazelcast.jet.pipeline.SourceBuilder.Stream
-
- distributed(int) - Method in class com.hazelcast.jet.pipeline.SourceBuilder.TimestampedStream
-
- DISTRIBUTED_BYTES_IN - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
-
Tracks the data volume (bytes) coming in over the network for
DISTRIBUTED input
Edge
s of particular
Vertex
instances running on various
Processor
s.
- DISTRIBUTED_BYTES_OUT - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
-
Tracks the data volume (bytes) going out over the network for
DISTRIBUTED output
Edge
s of particular
Vertex
instances running on various
Processor
s.
- DISTRIBUTED_ITEMS_IN - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
-
Counts data items coming in over the network for DISTRIBUTED input
Edge
s of particular
Vertex
instances running on
various
Processor
s.
- DISTRIBUTED_ITEMS_OUT - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
-
Counts data items going out over the network for DISTRIBUTED output
Edge
s of particular
Vertex
instances running on
various
Processor
s.
- DistributedObject - Interface in com.hazelcast.core
-
Base interface for all distributed objects.
- distributedObject - Variable in class com.hazelcast.core.DistributedObjectEvent
-
- distributedObjectCreated(DistributedObjectEvent) - Method in interface com.hazelcast.core.DistributedObjectListener
-
Invoked when a DistributedObject is created.
- distributedObjectDestroyed(DistributedObjectEvent) - Method in interface com.hazelcast.core.DistributedObjectListener
-
Invoked when a DistributedObject is destroyed.
- DistributedObjectDestroyedException - Exception in com.hazelcast.spi.exception
-
- DistributedObjectDestroyedException(String) - Constructor for exception com.hazelcast.spi.exception.DistributedObjectDestroyedException
-
- DistributedObjectEvent - Class in com.hazelcast.core
-
DistributedObjectEvent is fired when a
DistributedObject
is created or destroyed cluster-wide.
- DistributedObjectEvent(DistributedObjectEvent.EventType, String, String, DistributedObject, UUID) - Constructor for class com.hazelcast.core.DistributedObjectEvent
-
Constructs a DistributedObject Event.
- DistributedObjectEvent.EventType - Enum in com.hazelcast.core
-
Type of the DistributedObjectEvent.
- DistributedObjectListener - Interface in com.hazelcast.core
-
DistributedObjectListener notifies when a
DistributedObject
is created or destroyed cluster-wide.
- DistributedObjectUtil - Class in com.hazelcast.core
-
- 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.
- DISTRIBUTION - Static variable in class com.hazelcast.instance.GeneratedBuildProperties
-
- DocumentEndEvent - Class in com.hazelcast.org.snakeyaml.engine.v2.events
-
Marks the end of a document.
- DocumentEndEvent(boolean, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.events.DocumentEndEvent
-
- DocumentEndEvent(boolean) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.events.DocumentEndEvent
-
- DocumentEndToken - Class in com.hazelcast.org.snakeyaml.engine.v2.tokens
-
- DocumentEndToken(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.tokens.DocumentEndToken
-
- DocumentStartEvent - Class in com.hazelcast.org.snakeyaml.engine.v2.events
-
Marks the beginning of a document.
- DocumentStartEvent(boolean, Optional<SpecVersion>, Map<String, String>, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.events.DocumentStartEvent
-
- DocumentStartEvent(boolean, Optional<SpecVersion>, Map<String, String>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.events.DocumentStartEvent
-
- DocumentStartToken - Class in com.hazelcast.org.snakeyaml.engine.v2.tokens
-
- DocumentStartToken(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.tokens.DocumentStartToken
-
- domLevel3 - Variable in class com.hazelcast.config.AbstractXmlConfigHelper
-
- doPrepublicationChecks() - Method in interface com.hazelcast.wan.WanPublisher
-
Performs pre-publication checks (e.g.
- 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.
- 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
-
- drainTo(Collection<E>, int) - Method in interface com.hazelcast.jet.core.Inbox
-
Drains at most
limit
elements into the provided
Collection
.
- drainTo(Collection<M>, int, Function<E, M>) - Method in interface com.hazelcast.jet.core.Inbox
-
Drains and maps at most
limit
elements into the provided
Collection
.
- dropWhile(Predicate<? super T>) - Method in interface com.hazelcast.jet.Traverser
-
Returns a traverser that will emit a suffix of the original traverser,
starting from the item for which the predicate fails (inclusive).
- dueToError() - Method in interface com.hazelcast.jet.core.JobSuspensionCause
-
True if Jet suspended the job because it encountered an error during
execution.
- Dump - Class in com.hazelcast.org.snakeyaml.engine.v2.api
-
Common way to serialize any Java instance(s)
- Dump(DumpSettings) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.api.Dump
-
Create instance
- Dump(DumpSettings, BaseRepresenter) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.api.Dump
-
Create instance
- dump(Object, StreamDataWriter) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.Dump
-
Dump a single instance into a YAML document
- dumpAll(Iterator<? extends Object>, StreamDataWriter) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.Dump
-
Dump all the instances from the iterator into a stream with every instance in a separate YAML document
- dumpAllToString(Iterator<? extends Object>) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.Dump
-
Dump all the instances from the iterator into a stream with every instance in a separate YAML document
- DumpSettings - Class in com.hazelcast.org.snakeyaml.engine.v2.api
-
Fine tuning serializing/dumping
Description for all the fields can be found in the builder
- DumpSettingsBuilder - Class in com.hazelcast.org.snakeyaml.engine.v2.api
-
Builder pattern implementation for DumpSettings
- dumpToString(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.Dump
-
Dump all the instances from the iterator into a stream with every instance in a separate YAML document
- DupDetector - Class in com.hazelcast.com.fasterxml.jackson.core.json
-
- DuplicateKeyException - Exception in com.hazelcast.org.snakeyaml.engine.v2.exceptions
-
Indicate duplicate keys in the same mapping
- DuplicateKeyException(Optional<Mark>, Object, Optional<Mark>) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v2.exceptions.DuplicateKeyException
-
- DuplicateTaskException - Exception in com.hazelcast.scheduledexecutor
-
An exception thrown when a task's name is already used before for another (or the same, if re-attempted) schedule.
- DuplicateTaskException(String) - Constructor for exception com.hazelcast.scheduledexecutor.DuplicateTaskException
-
- DurableExecutorConfig - Class in com.hazelcast.config
-
- DurableExecutorConfig() - Constructor for class com.hazelcast.config.DurableExecutorConfig
-
- DurableExecutorConfig(String) - Constructor for class com.hazelcast.config.DurableExecutorConfig
-
- DurableExecutorConfig(String, int, int, int, boolean) - Constructor for class com.hazelcast.config.DurableExecutorConfig
-
- DurableExecutorConfig(String, int, int, int, String, boolean) - Constructor for class com.hazelcast.config.DurableExecutorConfig
-
- DurableExecutorConfig(DurableExecutorConfig) - Constructor for class com.hazelcast.config.DurableExecutorConfig
-
- DurableExecutorService - Interface in com.hazelcast.durableexecutor
-
- 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
-
- 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
-
- GcpDiscoveryStrategy - Class in com.hazelcast.gcp
-
- GcpDiscoveryStrategyFactory - Class in com.hazelcast.gcp
-
- 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
-
The common aspect of
batch
and
stream
pipeline stages, defining those operations that apply to both.
- GeneralStageWithKey<T,K> - Interface in com.hazelcast.jet.pipeline
-
An intermediate step when constructing a group-and-aggregate pipeline
stage.
- generate(ClientConfig) - Static method in class com.hazelcast.client.config.ClientConfigXmlGenerator
-
- generate(ClientConfig, int) - Static method in class com.hazelcast.client.config.ClientConfigXmlGenerator
-
Transforms the given
ClientConfig
to xml string
formatting the output with given
indent
, -1 means no
formatting.
- generate(Config) - Method in class com.hazelcast.config.ConfigXmlGenerator
-
Generates the XML string based on some Config.
- generate(JetConfig) - Static method in class com.hazelcast.jet.config.JetConfigXmlGenerator
-
- generate(JetConfig, int) - Static method in class com.hazelcast.jet.config.JetConfigXmlGenerator
-
Generates Hazelcast Jet XML string for given
JetConfig
using the
indent
value.
- generate(long, long) - Method in interface com.hazelcast.jet.pipeline.test.GeneratorFunction
-
Applies the function to the given timestamp and sequence.
- GeneratedBuildProperties - Class in com.hazelcast.instance
-
This class is generated in a build-time from a template stored at
src/main/template/com/hazelcast/instance/GeneratedBuildProperties.
- GeneratorBase - Class in com.hazelcast.com.fasterxml.jackson.core.base
-
This base class implements part of API that a JSON generator exposes
to applications, adds shared internal methods that sub-classes
can use and adds some abstract methods sub-classes must implement.
- GeneratorBase(int, ObjectCodec) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- GeneratorBase(int, ObjectCodec, JsonWriteContext) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- 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.
- GenericRecord - Interface in com.hazelcast.nio.serialization
-
A generic object interface that is returned to user when the domain class can not be created from any of the distributed
hazelcast data structures like
IMap
,
IQueue
etc.
- GenericRecordBuilder - Interface in com.hazelcast.nio.serialization
-
- get(K, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Retrieves the mapped value of the given key using a custom ExpiryPolicy
.
- get(String) - Method in interface com.hazelcast.com.fasterxml.jackson.core.TreeNode
-
Method for accessing value of the specified field of
an object node.
- get(int) - Method in interface com.hazelcast.com.fasterxml.jackson.core.TreeNode
-
Method for accessing value of the specified element of
an array node.
- get(String) - Static method in enum com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
-
- get() - Method in interface com.hazelcast.cp.IAtomicLong
-
Gets the current value.
- get() - Method in interface com.hazelcast.cp.IAtomicReference
-
Gets the current value.
- get() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
-
Returns the current value of the counter.
- get() - Method in interface com.hazelcast.function.SupplierEx
-
- get() - 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(String) - Method in class com.hazelcast.jet.core.metrics.JobMetrics
-
Returns all
Measurement
s associated with a given metric name.
- get(List<Address>) - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
- get(int) - Method in interface com.hazelcast.jet.core.ProcessorSupplier
-
- 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(Object) - Method in interface com.hazelcast.map.BaseMap
-
Returns the value for the specified key, or null
if this map does not contain this key.
- get(Object) - Method in interface com.hazelcast.map.IMap
-
Returns the value for the specified key, or null
if this map does not contain this key.
- get(Object) - Method in interface com.hazelcast.map.QueryCache
-
- get(K) - Method in interface com.hazelcast.multimap.BaseMultiMap
-
Returns the collection of values associated with the key.
- get(K) - Method in interface com.hazelcast.multimap.MultiMap
-
Returns the collection of values associated with the key.
- get(byte) - Static method in enum com.hazelcast.nio.serialization.FieldType
-
- get(String) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
-
- get(int) - Method in interface com.hazelcast.ringbuffer.ReadResultSet
-
Gets the item at the given index.
- get(int) - Method in interface com.hazelcast.security.Parameters
-
- get(String) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
Returns the value for the given key.
- get(Object) - Method in interface com.hazelcast.transaction.TransactionalMap
-
- get(K) - Method in interface com.hazelcast.transaction.TransactionalMultiMap
-
Returns the collection of values associated with the key.
- 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.
- get7BitOutputEscapes() - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.CharTypes
-
Accessor for getting a read-only encoding table for first 128 Unicode
code points (single-byte UTF-8 characters).
- get7BitOutputEscapes(int) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.CharTypes
-
- 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
- getAddresses() - Method in class com.hazelcast.jet.server.JetCommandLine.TargetsMixin
-
- 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.
- getAlias() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.AliasEvent
-
- getAll(Set<? extends K>, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Gets a collection of entries from the cache with custom expiry policy, returning them as
Map
of the values associated with the set of keys requested.
- getAll(Set<K>) - Method in interface com.hazelcast.map.IMap
-
Returns an immutable map of entries for the given keys.
- getAll(Set<K>) - Method in interface com.hazelcast.map.QueryCache
-
- getAllDiscoveryConfigs() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
-
- getAllHazelcastClients() - Static method in class com.hazelcast.client.HazelcastClient
-
Gets an immutable collection of all client HazelcastInstances created in this JVM.
- getAllHazelcastInstances() - Static method in class com.hazelcast.core.Hazelcast
-
Returns all active/running HazelcastInstances on this JVM.
- getAllHazelcastInstances() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
-
- getAllocatorType() - Method in class com.hazelcast.config.NativeMemoryConfig
-
- getAllowDuplicateKeys() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettings
-
- getAllowedFutureMillis() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
- getAllowRecursiveKeys() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettings
-
- 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 class com.hazelcast.org.snakeyaml.engine.v2.events.NodeEvent
-
Node anchor by which this node might later be referenced by a
AliasEvent
.
- getAnchor() - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.Node
-
Get the anchor if it was defined for this Node
- getAnchor() - Method in interface com.hazelcast.query.PagingPredicate
-
Retrieve the anchor object which is the last value object on the previous page.
- getAnchorGenerator() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettings
-
- getAndAdd(long) - Method in interface com.hazelcast.cp.IAtomicLong
-
Atomically adds the given value to the current value.
- getAndAdd(long) - Method in interface com.hazelcast.crdt.pncounter.PNCounter
-
Adds the given value to the current value.
- getAndAddAsync(long) - Method in interface com.hazelcast.cp.IAtomicLong
-
Atomically adds the given value to the current value.
- getAndAlter(IFunction<Long, Long>) - Method in interface com.hazelcast.cp.IAtomicLong
-
Alters the currently stored value by applying a function on it on and
gets the old value.
- getAndAlter(IFunction<E, E>) - Method in interface com.hazelcast.cp.IAtomicReference
-
Alters the currently stored reference by applying a function on it on
and gets the old value.
- getAndAlterAsync(IFunction<Long, Long>) - Method in interface com.hazelcast.cp.IAtomicLong
-
Alters the currently stored value by applying a function on it on and
gets the old value.
- getAndAlterAsync(IFunction<E, E>) - Method in interface com.hazelcast.cp.IAtomicReference
-
Alters the currently stored reference by applying a function on it on
and gets the old value.
- getAndClear() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SegmentedStringWriter
-
Main access method that will construct a String that contains
all the contents, release all internal buffers we may have,
and return result String.
- getAndDecrement() - Method in interface com.hazelcast.cp.IAtomicLong
-
Atomically decrements the current value by one.
- getAndDecrement() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
-
Decrements by one the current value.
- getAndDecrementAsync() - Method in interface com.hazelcast.cp.IAtomicLong
-
Atomically decrements the current value by one.
- getAndIncrement() - Method in interface com.hazelcast.cp.IAtomicLong
-
Atomically increments the current value by one.
- getAndIncrement() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
-
Increments by one the current value.
- getAndIncrementAsync() - Method in interface com.hazelcast.cp.IAtomicLong
-
Atomically increments the current value by one.
- getAndPut(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Associates the specified value with the specified key in this cache using a custom ExpiryPolicy
,
returning an existing value if one existed.
- getAndPutAsync(K, V) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously associates the specified value with the specified key in this cache,
returning an existing value if one existed.
- getAndPutAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously associates the specified value with the specified key in this cache,
returning an existing value if one existed using a custom ExpiryPolicy
.
- getAndRemoveAsync(K) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously removes the entry for a key and returns the previously assigned value or null
if no value was assigned.
- getAndReplace(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Atomically replaces the assigned value of the given key by the specified value using a
custom ExpiryPolicy
and returns the previously assigned value.
- getAndReplaceAsync(K, V) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously replaces the assigned value of the given key by the specified value and returns
the previously assigned value.
- getAndReplaceAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously replaces the assigned value of the given key by the specified value using a
custom ExpiryPolicy
and returns the previously assigned value.
- getAndSet(long) - Method in interface com.hazelcast.cp.IAtomicLong
-
Atomically sets the given value and returns the old value.
- getAndSet(E) - Method in interface com.hazelcast.cp.IAtomicReference
-
Gets the old value and sets the new value.
- getAndSetAsync(long) - Method in interface com.hazelcast.cp.IAtomicLong
-
Atomically sets the given value and returns the old value.
- getAndSetAsync(E) - Method in interface com.hazelcast.cp.IAtomicReference
-
Gets the value and sets the new value.
- getAndSubtract(long) - Method in interface com.hazelcast.crdt.pncounter.PNCounter
-
Subtracts the given value from the current value.
- getAppendRequestBackoffTimeoutInMillis() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
-
- getAppendRequestMaxEntryCount() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
-
- getArrayValueSeparator() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.Separators
-
- getArtifactId() - Method in class com.hazelcast.com.fasterxml.jackson.core.Version
-
- getAsync(K) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously retrieves the mapped value of the given key using a custom
ExpiryPolicy
.
- getAsync(K, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously gets an entry from cache using a custom ExpiryPolicy
.
- getAsync() - Method in interface com.hazelcast.cp.IAtomicLong
-
Gets the current value.
- getAsync() - Method in interface com.hazelcast.cp.IAtomicReference
-
Gets the current value.
- getAsync(K) - Method in interface com.hazelcast.map.IMap
-
Asynchronously gets the given key.
- getAsyncBackupCount() - Method in class com.hazelcast.config.CacheConfig
-
Gets the number of asynchronous backups for this
ICache
.
- getAsyncBackupCount() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the number of asynchronous backups for this
ICache
.
- getAsyncBackupCount() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
Gets the number of synchronous backups.
- getAsyncBackupCount() - Method in class com.hazelcast.config.CollectionConfig
-
Gets the number of asynchronous backups.
- getAsyncBackupCount() - Method in class com.hazelcast.config.MapConfig
-
Returns the asynchronous backup count for this
IMap
.
- getAsyncBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
-
Gets the number of asynchronous backups for this MultiMap.
- getAsyncBackupCount() - Method in class com.hazelcast.config.QueueConfig
-
Get the number of asynchronous backups for this queue.
- getAsyncBackupCount() - Method in class com.hazelcast.config.RingbufferConfig
-
Gets the number of asynchronous backups.
- getAtomicLong(String) - Method in interface com.hazelcast.cp.CPSubsystem
-
Returns a proxy for an
IAtomicLong
instance created on CP
Subsystem.
- getAtomicNumber() - Method in class com.hazelcast.client.console.ClientConsoleApp
-
- getAtomicNumber() - Method in class com.hazelcast.console.ConsoleApp
-
- getAtomicReference(String) - Method in interface com.hazelcast.cp.CPSubsystem
-
- getAttribute(String) - Method in interface com.hazelcast.cluster.Member
-
Returns the value of the specified key for this member or
null if value is undefined.
- getAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- getAttribute() - Method in interface com.hazelcast.query.PredicateBuilder
-
- getAttributeConfigs() - Method in class com.hazelcast.config.MapConfig
-
- getAttributes() - Method in interface com.hazelcast.cluster.Member
-
Returns configured attributes for this member.
This method might not be available on all native clients.
- getAttributes() - Method in class com.hazelcast.config.IndexConfig
-
Gets index attributes.
- getAttributes() - Method in class com.hazelcast.config.MemberAttributeConfig
-
- getAuditlogConfig() - Method in class com.hazelcast.config.Config
-
- getAutoDetectionConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Returns the configuration of the Auto Detection discovery.
- getAutoDetectionConfig() - Method in class com.hazelcast.config.JoinConfig
-
- getAverageAge() - Method in interface com.hazelcast.collection.LocalQueueStats
-
Returns the average age of the items in this member.
- getAverageGetTime() - Method in interface com.hazelcast.cache.CacheStatistics
-
The mean time to execute gets.
- getAverageHitLatency() - Method in interface com.hazelcast.query.LocalIndexStats
-
Returns the average hit latency (in nanoseconds) for the index.
- getAverageHitSelectivity() - Method in interface com.hazelcast.query.LocalIndexStats
-
Returns the average selectivity of the hits served by the index.
- getAveragePutTime() - Method in interface com.hazelcast.cache.CacheStatistics
-
The mean time to execute puts.
- getAverageRemoveTime() - Method in interface com.hazelcast.cache.CacheStatistics
-
The mean time to execute removes.
- getAwsConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
- 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
-
- getAzureConfig() - Method in class com.hazelcast.config.JoinConfig
-
- getAzureConfig() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the
AzureConfig
used by the discovery mechanism for this
WAN publisher.
- getBackupCount() - Method in class com.hazelcast.config.CacheConfig
-
Gets the number of synchronous backups for this
ICache
.
- getBackupCount() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the number of synchronous backups for this
ICache
.
- getBackupCount() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
Gets the number of synchronous backups.
- getBackupCount() - Method in class com.hazelcast.config.CollectionConfig
-
Gets the number of synchronous backups for this collection.
- getBackupCount() - Method in class com.hazelcast.config.MapConfig
-
Returns the backupCount for this
IMap
- getBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
-
Gets the number of synchronous backups for this MultiMap.
- getBackupCount() - Method in class com.hazelcast.config.QueueConfig
-
Get the number of synchronous backups for this queue.
- getBackupCount() - Method in class com.hazelcast.config.RingbufferConfig
-
Gets the number of synchronous backups.
- getBackupCount() - Method in class com.hazelcast.jet.config.InstanceConfig
-
- getBackupCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the number of backups per entry.
- getBackupDir() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Base directory for hot backups.
- getBackupDirectory() - Method in interface com.hazelcast.hotrestart.HotRestartService
-
Returns the hot restart backup directory.
- getBackupEntryCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the number of backup entries hold by this member.
- getBackupEntryMemoryCost() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns memory cost (number of bytes) of backup entries in this member.
- getBackupItemCount() - Method in interface com.hazelcast.collection.LocalQueueStats
-
Returns the number of backup items in this member.
- getBackupProcessor() - Method in interface com.hazelcast.map.EntryProcessor
-
Get the entry processor to be applied to backup entries.
- getBackupTaskStatus() - Method in interface com.hazelcast.hotrestart.HotRestartService
-
Returns the local hot restart backup task status (not the cluster backup status).
- getBaseDir() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Returns the base directory for persisting CP data.
- getBaseDir() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Base directory for all Hot Restart stores.
- getBaseName(String) - Static method in class com.hazelcast.partition.strategy.StringPartitioningStrategy
-
- getBatchMaxDelayMillis() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the maximum amount of time in milliseconds to wait before sending
a batch of events to target cluster, if
WanBatchPublisherConfig.getBatchSize()
of events
have not arrived within this duration.
- getBatchPublisherConfigs() - Method in class com.hazelcast.config.WanReplicationConfig
-
Returns the list of WAN publisher configurations using the built-in
batching WAN implementation for this WAN replication.
- getBatchSize() - Method in class com.hazelcast.config.MergePolicyConfig
-
Returns the batch size, which will be used to determine
the number of entries to be sent in a merge operation.
- getBatchSize() - Method in class com.hazelcast.config.QueryCacheConfig
-
After reaching this size, node sends buffered events to QueryCache
.
- getBatchSize() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the maximum batch size that can be sent to target cluster.
- getBestLineBreak() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettings
-
- getBigIntegerValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- getBigIntegerValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getBigIntegerValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Numeric accessor that can be called when the current
token is of type
JsonToken.VALUE_NUMBER_INT
and
it can not be used as a Java long primitive type due to its
magnitude.
- getBigIntegerValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getBinaryValue(Base64Variant) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- getBinaryValue(Base64Variant) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- getBinaryValue(Base64Variant) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getBinaryValue(Base64Variant) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- getBinaryValue(Base64Variant) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- getBinaryValue(Base64Variant) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- getBinaryValue(Base64Variant) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- getBinaryValue(Base64Variant) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method that can be used to read (and consume -- results
may not be accessible using other methods after the call)
base64-encoded binary data
included in the current textual JSON value.
- getBinaryValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- getBinaryValue(Base64Variant) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getBindAddress(EndpointQualifier) - Method in interface com.hazelcast.instance.AddressPicker
-
Returns a server socket listener address.
- getBindAddress() - Method in interface com.hazelcast.spi.MemberAddressProvider
-
What address should Hazelcast bind to.
- getBindAddress(EndpointQualifier) - Method in interface com.hazelcast.spi.MemberAddressProvider
-
- getBitmapIndexOptions() - Method in class com.hazelcast.config.IndexConfig
-
Provides access to index options specific to bitmap indexes.
- getBitsNodeId() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
- getBitsSequence() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
- getBlacklist() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
-
- getBlacklistedPrefixes() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Return currently configured blacklist prefixes.
- getBoolean(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getBoolean(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
- getBooleanArray(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getBooleanValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getBooleanValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- getBooleanValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getBuffer() - Method in class com.hazelcast.org.snakeyaml.engine.v2.exceptions.Mark
-
- getBufferRecycler() - Static method in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecyclers
-
Main accessor to call for accessing possibly recycled
BufferRecycler
instance.
- 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.
- getBufferSize() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettings
-
- getBufferWithoutReset() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
Method for accessing the currently active (last) content segment
without changing state of the buffer
- getBuild() - Method in class com.hazelcast.instance.BuildInfo
-
- getBuild() - Method in class com.hazelcast.instance.JetBuildInfo
-
- getBuildInfo() - Static method in class com.hazelcast.instance.BuildInfoProvider
-
Parses hazelcast-runtime.properties
for BuildInfo
; also checks for overrides in System.properties.
- getBuildNumber() - Method in class com.hazelcast.instance.BuildInfo
-
- getById(int) - Static method in enum com.hazelcast.cluster.ClusterState
-
- getById(int) - Static method in enum com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
-
- getById(byte) - Static method in enum com.hazelcast.config.ConsistencyCheckStrategy
-
Returns the ConsistencyCheckStrategy for the given ID.
- getById(int) - Static method in enum com.hazelcast.config.EvictionPolicy
-
- getById(int) - Static method in enum com.hazelcast.config.IndexType
-
Returns the IndexType as an enum.
- getById(int) - Static method in enum com.hazelcast.config.InMemoryFormat
-
- getById(int) - Static method in enum com.hazelcast.config.MaxSizePolicy
-
- getById(int) - Static method in enum com.hazelcast.config.MetadataPolicy
-
Returns the MetadataPolicy for the given ID.
- getById(byte) - Static method in enum com.hazelcast.config.ScheduledExecutorConfig.CapacityPolicy
-
- getById(int) - Static method in enum com.hazelcast.config.WanAcknowledgeType
-
- getById(int) - Static method in enum com.hazelcast.instance.ProtocolType
-
- getById(int) - Static method in enum com.hazelcast.ringbuffer.OverflowPolicy
-
Returns the OverflowPolicy for the given ID.
- getById(int) - Static method in enum com.hazelcast.sql.SqlColumnType
-
Returns the IndexType as an enum.
- getById(int) - Static method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
-
- getByte(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getByteArray(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getByteOffset() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonLocation
-
- 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
-
- getByteValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getByteValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Numeric accessor that can be called when the current
token is of type
JsonToken.VALUE_NUMBER_INT
and
it can be expressed as a value of Java byte primitive type.
- getByteValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getByType(int) - Static method in enum com.hazelcast.cache.CacheEventType
-
- getByType(int) - Static method in enum com.hazelcast.config.WanQueueFullBehavior
-
Returns the WANQueueFullBehavior as an enum.
- getByType(int) - Static method in enum com.hazelcast.core.EntryEventType
-
- getByType(int) - Static method in enum com.hazelcast.core.ItemEventType
-
- getByType(byte) - Static method in enum com.hazelcast.wan.WanPublisherState
-
Returns the WanPublisherState as an enum.
- getCache(String) - Method in interface com.hazelcast.core.ICacheManager
-
Returns the cache instance with the specified prefixed cache name.
- getCache(String) - Method in interface com.hazelcast.jet.JetCacheManager
-
Returns the cache instance with the specified, optionally prefixed, cache
name:
- 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
-
- getCacheEvictions() - Method in interface com.hazelcast.cache.CacheStatistics
-
The total number of evictions from the cache.
- getCacheGets() - Method in interface com.hazelcast.cache.CacheStatistics
-
The total number of requests to the cache.
- getCacheHitPercentage() - Method in interface com.hazelcast.cache.CacheStatistics
-
This is a measure of cache efficiency.
- getCacheHits() - Method in interface com.hazelcast.cache.CacheStatistics
-
The number of get requests that were satisfied by the cache.
- getCacheLoader() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Get classname of a class to be used as CacheLoader
.
- getCacheLoaderFactory() - Method in class com.hazelcast.config.AbstractCacheConfig
-
- getCacheLoaderFactory() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the factory for the CacheLoader
.
- getCacheManager(URI, ClassLoader, Properties) - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- getCacheManager(URI, ClassLoader) - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- getCacheManager() - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- getCacheManager(URI, ClassLoader, Properties) - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
-
- getCacheManager(URI, ClassLoader) - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
-
- getCacheManager() - Method in class com.hazelcast.cache.HazelcastMemberCachingProvider
-
- getCacheManager(URI, ClassLoader, Properties) - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
-
- getCacheManager(URI, ClassLoader) - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
-
- getCacheManager() - Method in class com.hazelcast.client.cache.HazelcastClientCachingProvider
-
- getCacheManager() - Method in interface com.hazelcast.core.HazelcastInstance
-
Obtain the
ICacheManager
that provides access to JSR-107 (JCache) caches configured on a Hazelcast cluster.
- getCacheManager() - Method in interface com.hazelcast.jet.JetInstance
-
Obtain the
JetCacheManager
that provides access to JSR-107 (JCache) caches
configured on a Hazelcast Jet cluster.
- 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.
- getCacheNameWithPrefix(String) - Method in interface com.hazelcast.cache.HazelcastCacheManager
-
Gets the cache name by adding the manager prefix.
- getCachePuts() - Method in interface com.hazelcast.cache.CacheStatistics
-
The total number of puts to the cache.
- getCacheRemovals() - Method in interface com.hazelcast.cache.CacheStatistics
-
The total number of removals from the cache.
- getCacheWriter() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Get classname of a class to be used as CacheWriter
.
- getCacheWriterFactory() - Method in class com.hazelcast.config.AbstractCacheConfig
-
- getCacheWriterFactory() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the factory for the CacheWriter
.
- getCancelledTaskCount() - Method in interface com.hazelcast.executor.LocalExecutorStats
-
Returns the number of cancelled operations on the executor service.
- getCapacity() - Method in class com.hazelcast.config.DurableExecutorConfig
-
Gets the ring buffer capacity of the executor task.
- getCapacity() - Method in class com.hazelcast.config.EventJournalConfig
-
Gets the capacity of the event journal.
- getCapacity() - Method in class com.hazelcast.config.RingbufferConfig
-
Gets the capacity of the ringbuffer.
- getCapacity() - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Gets the capacity of the executor
- getCapacity() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
-
Returns the capacity of this ringbuffer.
- getCapacityPolicy() - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
- getCardinalityEstimator(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
- 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.
- getChar(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getCharacterEscapes() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonGeneratorImpl
-
Method for accessing custom escapes factory uses for
JsonGenerator
s
it creates.
- getCharacterEscapes() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method for accessing custom escapes factory uses for
JsonGenerator
s
it creates.
- getCharacterEscapes() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for accessing custom escapes factory uses for
JsonGenerator
s
it creates.
- getCharacterEscapes() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- getCharArray(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getCharOffset() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonLocation
-
- getClassCacheMode() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Return the current ClassCacheMode
- getClassDefinitions() - Method in class com.hazelcast.config.SerializationConfig
-
- getClasses() - Method in class com.hazelcast.config.ClassFilter
-
Returns unmodifiable set of class names.
- getClassId() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-
- getClassId() - Method in class com.hazelcast.cluster.Address
-
- getClassId() - Method in class com.hazelcast.config.AttributeConfig
-
- getClassId() - Method in class com.hazelcast.config.AwsConfig
-
- getClassId() - Method in class com.hazelcast.config.AzureConfig
-
- getClassId() - Method in class com.hazelcast.config.BitmapIndexOptions
-
- getClassId() - Method in class com.hazelcast.config.CacheConfig
-
- getClassId() - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
-
- getClassId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
-
- getClassId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
-
- getClassId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
-
- getClassId() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- getClassId() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- getClassId() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
- getClassId() - Method in class com.hazelcast.config.DiscoveryConfig
-
- getClassId() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
-
- getClassId() - Method in class com.hazelcast.config.DurableExecutorConfig
-
- getClassId() - Method in class com.hazelcast.config.EntryListenerConfig
-
- getClassId() - Method in class com.hazelcast.config.EurekaConfig
-
- getClassId() - Method in class com.hazelcast.config.EventJournalConfig
-
- getClassId() - Method in class com.hazelcast.config.EvictionConfig
-
- getClassId() - Method in class com.hazelcast.config.ExecutorConfig
-
- getClassId() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
- getClassId() - Method in class com.hazelcast.config.GcpConfig
-
- getClassId() - Method in class com.hazelcast.config.HotRestartConfig
-
- getClassId() - Method in class com.hazelcast.config.IndexConfig
-
- getClassId() - Method in class com.hazelcast.config.ItemListenerConfig
-
- getClassId() - Method in class com.hazelcast.config.KubernetesConfig
-
- getClassId() - Method in class com.hazelcast.config.ListConfig
-
- getClassId() - Method in class com.hazelcast.config.ListenerConfig
-
- getClassId() - Method in class com.hazelcast.config.MapConfig
-
- getClassId() - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
-
- getClassId() - Method in class com.hazelcast.config.MapStoreConfig
-
- getClassId() - Method in class com.hazelcast.config.MergePolicyConfig
-
- getClassId() - Method in class com.hazelcast.config.MerkleTreeConfig
-
- getClassId() - Method in class com.hazelcast.config.MultiMapConfig
-
- getClassId() - Method in class com.hazelcast.config.NearCacheConfig
-
- getClassId() - Method in class com.hazelcast.config.NearCachePreloaderConfig
-
- getClassId() - Method in class com.hazelcast.config.PartitioningStrategyConfig
-
- getClassId() - Method in class com.hazelcast.config.PermissionConfig
-
- getClassId() - Method in class com.hazelcast.config.PNCounterConfig
-
- getClassId() - Method in class com.hazelcast.config.PredicateConfig
-
- getClassId() - Method in class com.hazelcast.config.QueryCacheConfig
-
- getClassId() - Method in class com.hazelcast.config.QueueConfig
-
- getClassId() - Method in class com.hazelcast.config.QueueStoreConfig
-
- getClassId() - Method in class com.hazelcast.config.ReliableTopicConfig
-
- getClassId() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- getClassId() - Method in class com.hazelcast.config.RingbufferConfig
-
- getClassId() - Method in class com.hazelcast.config.RingbufferStoreConfig
-
- getClassId() - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
- getClassId() - Method in class com.hazelcast.config.SetConfig
-
- getClassId() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
-
- getClassId() - Method in class com.hazelcast.config.SplitBrainProtectionListenerConfig
-
- getClassId() - Method in class com.hazelcast.config.TopicConfig
-
- getClassId() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
- getClassId() - Method in class com.hazelcast.config.WanConsumerConfig
-
- getClassId() - Method in class com.hazelcast.config.WanCustomPublisherConfig
-
- getClassId() - Method in class com.hazelcast.config.WanReplicationConfig
-
- getClassId() - Method in class com.hazelcast.config.WanReplicationRef
-
- getClassId() - Method in class com.hazelcast.config.WanSyncConfig
-
- getClassId() - Method in class com.hazelcast.instance.EndpointQualifier
-
- getClassId() - Method in class com.hazelcast.jet.config.JobConfig
-
- 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.Vertex
-
- getClassId() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Returns the class ID.
- getClassId() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- getClassId() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
-
- getClassId() - Method in interface com.hazelcast.nio.serialization.IdentifiedDataSerializable
-
Returns type identifier for this class.
- getClassId() - Method in interface com.hazelcast.nio.serialization.Portable
-
Returns class identifier for this portable class.
- getClassId() - Method in class com.hazelcast.security.SimpleTokenCredentials
-
- getClassId() - Method in class com.hazelcast.security.UsernamePasswordCredentials
-
- getClassId() - Method in class com.hazelcast.spi.merge.DiscardMergePolicy
-
- getClassId() - Method in class com.hazelcast.spi.merge.ExpirationTimeMergePolicy
-
- getClassId() - Method in class com.hazelcast.spi.merge.HigherHitsMergePolicy
-
- getClassId() - Method in class com.hazelcast.spi.merge.HyperLogLogMergePolicy
-
- getClassId() - Method in class com.hazelcast.spi.merge.LatestAccessMergePolicy
-
- getClassId() - Method in class com.hazelcast.spi.merge.LatestUpdateMergePolicy
-
- getClassId() - Method in class com.hazelcast.spi.merge.PassThroughMergePolicy
-
- getClassId() - Method in class com.hazelcast.spi.merge.PutIfAbsentMergePolicy
-
- getClassId() - Method in class com.hazelcast.version.MemberVersion
-
- getClassId() - Method in class com.hazelcast.version.Version
-
- getClassLoader() - Method in class com.hazelcast.client.config.ClientConfig
-
Gets the classLoader
- getClassLoader() - Method in class com.hazelcast.config.Config
-
Returns the class-loader that will be used in serialization.
- getClassLoader() - Method in interface com.hazelcast.nio.ObjectDataInput
-
Returns class loader that internally used for objects.
- getClassLoaderFactory() - Method in class com.hazelcast.jet.config.JobConfig
-
- getClassName() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
-
- getClassName() - Method in class com.hazelcast.config.AbstractWanPublisherConfig
-
- 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
-
- getClassName() - Method in class com.hazelcast.config.WanConsumerConfig
-
Returns the fully qualified class name of the class implementing
WanConsumer
.
- getClassNames() - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
-
- getClassType() - Method in interface com.hazelcast.nio.serialization.TypedDataSerializable
-
- getClassVersion() - Method in interface com.hazelcast.nio.serialization.VersionedPortable
-
Returns version for this Portable class
- getClientBlockUnmappedActions() - Method in class com.hazelcast.config.SecurityConfig
-
- getClientConfigs() - Method in class com.hazelcast.client.config.ClientFailoverConfig
-
Gets the configured list of alternative client configurations.
- getClientIcmpPingConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
ICMP ping is used to detect if machine that a remote hazelcast member runs on alive or not
- getClientPermissionConfigs() - Method in class com.hazelcast.config.SecurityConfig
-
- getClientPermissionConfigs() - Method in interface com.hazelcast.security.SecurityService
-
Returns latest client permission configuration.
- getClientPolicyConfig() - Method in class com.hazelcast.config.SecurityConfig
-
- getClientRealm() - Method in class com.hazelcast.config.SecurityConfig
-
- getClientService() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the client service of this Hazelcast instance.
- getClientType() - Method in interface com.hazelcast.client.Client
-
Type could be a client type from ConnectionType
or
it can be a custom client implementation with a name outside of this @{link ConnectionType}
- getCloudConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
- getCluster() - Method in class com.hazelcast.cluster.InitialMembershipEvent
-
Returns the cluster of the event.
- getCluster() - Method in class com.hazelcast.cluster.MembershipEvent
-
Returns the cluster of the event.
- getCluster() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the Cluster that this Hazelcast instance is part of.
- getCluster() - Method in interface com.hazelcast.jet.JetInstance
-
Returns information about the cluster this Jet instance is part of.
- 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 shutdown or start trying on alternative clusters
after reaching the timeout.
- getClusterDataRecoveryPolicy() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Returns the policy to be used when the cluster is started
- getClusterName() - Method in class com.hazelcast.client.config.ClientConfig
-
Returns the configured cluster name.
- getClusterName() - Method in class com.hazelcast.config.Config
-
Returns the cluster name uniquely identifying the hazelcast cluster.
- getClusterName() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the cluster name used as a publisher cluster name for authentication
on the target endpoint.
- getClusterName() - Method in class com.hazelcast.jet.server.JetCommandLine.TargetsMixin
-
- getClusterState() - Method in interface com.hazelcast.cluster.Cluster
-
Returns the state of the cluster.
- getClusterTime() - Method in interface com.hazelcast.cluster.Cluster
-
Returns the cluster-wide time in milliseconds.
- getClusterVersion() - Method in interface com.hazelcast.cluster.Cluster
-
The cluster version indicates the operating version of the cluster.
- getCode() - Method in exception com.hazelcast.sql.HazelcastSqlException
-
Gets the internal error code associated with the exception.
- getCodec() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- getCodec() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- getCodec() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- getCodec() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- getCodec() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- getCodec() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- getCodec() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- getCodec() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Accessor for
ObjectCodec
associated with this
parser, if any.
- getCodec() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- getCodec() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getCodePoint() - Method in exception com.hazelcast.org.snakeyaml.engine.v2.exceptions.ReaderException
-
- getCollectionFrequencySeconds() - Method in class com.hazelcast.config.BaseMetricsConfig
-
Returns the metrics collection frequency in seconds.
- getColumn() - Method in class com.hazelcast.org.snakeyaml.engine.v2.exceptions.Mark
-
starts with 0
- getColumn() - Method in class com.hazelcast.org.snakeyaml.engine.v2.scanner.StreamReader
-
- 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.
- getColumnNr() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonLocation
-
- getColumns() - Method in class com.hazelcast.sql.SqlRowMetadata
-
Gets columns metadata.
- getCommitId() - Method in class com.hazelcast.instance.BuildInfo
-
- getCommitIndexAdvanceCountToSnapshot() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
-
- getComparator() - Method in class com.hazelcast.config.EvictionConfig
-
- 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
-
- getCompleted() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
-
- getCompletedMigrations() - Method in interface com.hazelcast.partition.MigrationState
-
Returns the number of completed migrations in the migration plan.
- getCompletedTaskCount() - Method in interface com.hazelcast.executor.LocalExecutorStats
-
Returns the number of completed operations on the executor service.
- getConfig() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the configuration of this Hazelcast instance.
- getConfig() - Method in class com.hazelcast.jet.core.Edge
-
Returns the EdgeConfig
instance associated with this edge.
- getConfig() - Method in interface com.hazelcast.jet.JetInstance
-
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
-
Returns the
File
to the declarative configuration, which has been
parsed to create this
Config
instance.
- 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
-
Returns the
URL
to the declarative configuration, which has been parsed
to create this
Config
instance.
- 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.
- getConnectionRetryConfig() - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
-
Connection Retry Config is controls the period among the retries and when should a client gave up
retrying.
- getConnectionStrategyConfig() - Method in class com.hazelcast.client.config.ClientConfig
-
- getConnectionTimeout() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Timeout value in millis for nodes to accept client connection requests.
- getConnectionTimeoutSeconds() - Method in class com.hazelcast.config.TcpIpConfig
-
Returns the connection timeout.
- getConsistencyCheckStrategy() - Method in class com.hazelcast.config.WanSyncConfig
-
Returns the strategy for checking consistency of data between source and
target cluster.
- getConsumerConfig() - Method in class com.hazelcast.config.WanReplicationConfig
-
- getContentType() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
-
Method for accessing content type of this type, if type has
such a thing: simple types do not, structured types do
(like arrays, Collections and Maps)
- getContext() - Method in exception com.hazelcast.org.snakeyaml.engine.v2.exceptions.MarkedYamlEngineException
-
- getContextMark() - Method in exception com.hazelcast.org.snakeyaml.engine.v2.exceptions.MarkedYamlEngineException
-
- getCooperativeThreadCount() - Method in class com.hazelcast.jet.config.InstanceConfig
-
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
-
- getCPGroup(String) - Method in interface com.hazelcast.cp.CPSubsystemManagementService
-
Returns the active CP group with the given name.
- getCPGroupIds() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
-
Returns all active CP group ids.
- getCPMemberCount() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Returns the number of CP members that will initialize CP Subsystem.
- getCPMembers() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
-
Returns the current list of CP members
- getCPSessionManagementService() - Method in interface com.hazelcast.cp.CPSubsystem
-
- 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
-
- 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.instance.LocalInstanceStats
-
Returns the creation time of this distributed object instance on this member.
- getCreationTime() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the creation time of this map on this member.
- getCreationTime() - Method in interface com.hazelcast.nearcache.NearCacheStats
-
Returns the creation time of this Near Cache on this member.
- getCreationTime() - Method in interface com.hazelcast.spi.eviction.EvictableEntryView
-
- 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
-
- 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
-
- getCurrentIndex() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
-
- getCurrentKeyAlias() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
-
Returns the alias for the current encryption key entry or null
if no alias is set.
- getCurrentLocation() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Method that returns location of the last processed character;
usually for error reporting purposes
- getCurrentLocation() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getCurrentLocation() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- getCurrentLocation() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- getCurrentLocation() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- getCurrentLocation() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- getCurrentLocation() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method that returns location of the last processed character;
usually for error reporting purposes.
- getCurrentLocation() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getCurrentMembers() - Method in class com.hazelcast.splitbrainprotection.SplitBrainProtectionEvent
-
Returns the snapshot of member list at the time split brain protection happened
- getCurrentName() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Method that can be called to get the name associated with
the current event.
- getCurrentName() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- getCurrentName() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getCurrentName() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
-
- getCurrentName() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
-
- getCurrentName() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
- getCurrentName() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- getCurrentName() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
-
Method for accessing name associated with the current location.
- getCurrentName() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getCurrentSegment() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
-
- getCurrentSegment() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
- getCurrentSegmentLength() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
-
- getCurrentSegmentSize() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
- getCurrentState() - Method in class com.hazelcast.client.util.ClientStateListener
-
- getCurrentToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- getCurrentToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getCurrentToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- getCurrentToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getCurrentTokenId() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
Deprecated.
- getCurrentTokenId() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
Deprecated.
- getCurrentTokenId() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- getCurrentTokenId() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
Deprecated.
- getCurrentValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- getCurrentValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- getCurrentValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
-
- getCurrentValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
-
- getCurrentValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
- getCurrentValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Helper method, usually equivalent to:
getOutputContext().getCurrentValue();
- getCurrentValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Helper method, usually equivalent to:
getParsingContext().getCurrentValue();
- getCurrentValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
-
Method for accessing currently active value being used by data-binding
(as the source of streaming data to write, or destination of data being
read), at this level in hierarchy.
- getCurrentValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- getCurrentValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- 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).
- getCustomProperty(SettingKey) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettings
-
- getCustomProperty(SettingKey) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettings
-
- getCustomPublisherConfigs() - Method in class com.hazelcast.config.WanReplicationConfig
-
Returns the list of custom WAN publisher implementations for this WAN
replication.
- getDataLoadTimeoutSeconds() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Returns the timeout duration for CP members to restore their data from
stable storage.
- getDataLoadTimeoutSeconds() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Returns configured data load timeout for hot-restart process.
- getDataMembers() - Method in class com.hazelcast.client.util.AbstractLoadBalancer
-
- getDataSerializableFactories() - Method in class com.hazelcast.config.SerializationConfig
-
- getDataSerializableFactoryClasses() - Method in class com.hazelcast.config.SerializationConfig
-
- getDataStream() - Method in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatMatcher
-
Method to use for accessing input for which format detection has been done.
- getDate(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getDateArray(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getDecimal(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getDecimalArray(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getDecimalValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- getDecimalValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getDecimalValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- getDecimalValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- 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.
- getDefaultFlowStyle() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettings
-
- getDefaultHazelcastInstance() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
-
- getDefaultList() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettings
-
- getDefaultMap() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettings
-
- 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
-
- getDefaultScalarStyle() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettings
-
- getDefaultSet() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettings
-
- 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.
- getDefaultVariant() - Static method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variants
-
- 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
- getDelegate() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
Deprecated.
- getDelegatedInstance() - Method in interface com.hazelcast.osgi.HazelcastOSGiInstance
-
- getDeprecatedName() - Method in class com.hazelcast.spi.properties.HazelcastProperty
-
- getDepth() - Method in class com.hazelcast.config.MerkleTreeConfig
-
Returns the depth of the merkle tree.
- getDescriptor() - Method in enum com.hazelcast.instance.ProtocolType
-
- 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.
- getDirectory() - Method in class com.hazelcast.config.NearCachePreloaderConfig
-
- getDirectory() - Method in class com.hazelcast.config.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
-
- 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
-
- 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
-
- getDiscoveryStrategyType() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategyFactory
-
- getDiscoveryToken() - Method in class com.hazelcast.client.config.ClientCloudConfig
-
hazelcast.cloud discoveryToken of your cluster
- getDistributedObject() - Method in class com.hazelcast.core.DistributedObjectEvent
-
Returns the DistributedObject instance.
- getDistributedObject(String, String) - Method in interface com.hazelcast.core.HazelcastInstance
-
- getDistributedObjectName(String) - Static method in class com.hazelcast.cache.CacheUtil
-
Convenience method to obtain the name of Hazelcast distributed object corresponding to the cache identified
by the given cacheName
, assuming null URI
and ClassLoader
prefixes.
- getDistributedObjectName(String, URI, ClassLoader) - Static method in class com.hazelcast.cache.CacheUtil
-
Convenience method to obtain the name of Hazelcast distributed object corresponding to the cache identified
by the given arguments.
- getDistributedObjects() - Method in interface com.hazelcast.core.HazelcastInstance
-
- getDistributedTo() - Method in class com.hazelcast.jet.core.Edge
-
- getDouble() - Method in class com.hazelcast.jet.accumulator.LongDoubleAccumulator
-
Returns the double
value.
- getDouble(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getDouble(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
- getDoubleArray(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getDoubleValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- getDoubleValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getDoubleValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Numeric accessor that can be called when the current
token is of type
JsonToken.VALUE_NUMBER_FLOAT
and
it can be expressed as a Java double primitive type.
- getDoubleValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getDroppedCount() - Method in class com.hazelcast.wan.WanEventCounters.DistributedObjectWanEventCounters
-
Returns the number of dropped entry events
- getDupDetector() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
-
- getDupDetector() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
- getDurability() - Method in class com.hazelcast.config.DurableExecutorConfig
-
Gets the durability of the executor
- getDurability() - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Gets the durability of the executor
- getDurability() - Method in class com.hazelcast.transaction.TransactionOptions
-
Gets the transaction durability.
- getDurableExecutorConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the DurableExecutorConfig for the given name, creating one
if necessary and adding it to the collection of known configurations.
- getDurableExecutorConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of durable executor configurations, mapped by config
name.
- getDurableExecutorService(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates or returns the durable executor service for the given name.
- getDurationAmount() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
-
- getDurationConfig() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
-
- getElapsedTime() - Method in interface com.hazelcast.partition.ReplicaMigrationEvent
-
Returns the elapsed the time of this migration in milliseconds.
- getEmbeddedObject() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getEmbeddedObject() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- getEmbeddedObject() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- getEmbeddedObject() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getEmptyName() - Static method in class com.hazelcast.com.fasterxml.jackson.core.sym.Name1
-
- getEmptyPollOperationCount() - Method in interface com.hazelcast.collection.LocalQueueStats
-
Returns number of null returning poll operations.
- getEmptyQueueTtl() - Method in class com.hazelcast.config.QueueConfig
-
Returns the TTL (time to live) for emptying the Queue.
- getEnabledGroups() - Method in class com.hazelcast.config.RestApiConfig
-
Returns a not-null
set of enabled REST endpoint groups.
- getEnabledGroups() - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Returns a not-null
set of enabled REST endpoint groups.
- getEncoding() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
- getEncoding() - Method in class com.hazelcast.config.security.TokenIdentityConfig
-
- getEncoding() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.YamlUnicodeReader
-
Get stream encoding or NULL if stream is uninitialized.
- getEncodingForBytes(byte[]) - Static method in enum com.hazelcast.config.security.TokenEncoding
-
- getEncryptionAtRestConfig() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Returns the Hot Restart Encryption at Rest configuration.
- getEndMark() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.Event
-
- getEndMark() - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.Node
-
- getEndMark() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.Token
-
- 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
-
- getEntryCount() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
-
- getEntryListenerConfigs() - Method in class com.hazelcast.config.MapConfig
-
- getEntryListenerConfigs() - Method in class com.hazelcast.config.MultiMapConfig
-
Gets the list of entry listeners (listens for when entries are added or removed) for this MultiMap.
- getEntryListenerConfigs() - Method in class com.hazelcast.config.QueryCacheConfig
-
- getEntryObject() - Method in interface com.hazelcast.query.PredicateBuilder
-
- getEntryView(K) - Method in interface com.hazelcast.map.IMap
-
Returns the EntryView
for the specified key.
- getEnum(HazelcastProperty, Class<E>) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
- getEnv(String) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor.ConstructEnv
-
Get value of the environment variable
- getEnvConfig() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettings
-
- getEol() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultIndenter
-
- getEpochStart() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
- getEscapeCodesForAscii() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.CharacterEscapes
-
Method generators can call to get lookup table for determining
escape handling for first 128 characters of Unicode (ASCII
characters.
- getEscapeCodesForAscii() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonpCharacterEscapes
-
- getEscapeSequence(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.CharacterEscapes
-
Method generators can call to get lookup table for determining
exact escape sequence to use for given character.
- getEscapeSequence(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonpCharacterEscapes
-
- getEurekaConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
- 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
-
- getEventId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.AliasEvent
-
- getEventId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.DocumentEndEvent
-
- getEventId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.DocumentStartEvent
-
- getEventId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.Event
-
Get the type (kind) if this Event
- getEventId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.MappingEndEvent
-
- getEventId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.MappingStartEvent
-
- getEventId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.ScalarEvent
-
- getEventId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.SequenceEndEvent
-
- getEventId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.SequenceStartEvent
-
- getEventId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.StreamEndEvent
-
- getEventId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.StreamStartEvent
-
- getEventJournalConfig() - Method in class com.hazelcast.config.AbstractCacheConfig
-
Gets the EventJournalConfig
for this CacheConfiguration
- getEventJournalConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the EventJournalConfig
for this CacheSimpleConfig
- getEventJournalConfig() - Method in class com.hazelcast.config.MapConfig
-
Gets the EventJournalConfig
for this MapConfig
- getEventObject() - Method in interface com.hazelcast.wan.WanEvent
-
Returns the event object/data.
- getEventOperationCount() - Method in interface com.hazelcast.collection.LocalQueueStats
-
Returns number of event operations
- getEventOperationCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the number of Events Received
- getEventSource() - Method in interface com.hazelcast.partition.PartitionLostEvent
-
Returns the address of the node that dispatches the event
- getEventType() - Method in class com.hazelcast.cluster.MembershipEvent
-
Returns the membership event type;
#MEMBER_ADDED
#MEMBER_REMOVED
- getEventType() - Method in class com.hazelcast.collection.ItemEvent
-
Returns the event type.
- getEventType() - Method in class com.hazelcast.core.DistributedObjectEvent
-
- getEventType() - Method in class com.hazelcast.map.AbstractIMapEvent
-
- 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
-
- getEvictionConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the eviction configuration for this
ICache
.
- getEvictionConfig() - Method in class com.hazelcast.config.MapConfig
-
- getEvictionConfig() - Method in class com.hazelcast.config.NearCacheConfig
-
Returns the eviction configuration for this Near Cache.
- getEvictionConfig() - Method in class com.hazelcast.config.QueryCacheConfig
-
- getEvictionPolicy() - Method in class com.hazelcast.config.EvictionConfig
-
- getEvictions() - Method in interface com.hazelcast.nearcache.NearCacheStats
-
Returns the number of evictions of Near Cache entries owned by this member.
- getEvictionStrategyType() - Method in class com.hazelcast.config.EvictionConfig
-
Returns the EvictionStrategyType
of this eviction configuration.
- getEx() - Method in interface com.hazelcast.function.SupplierEx
-
- getExecutor() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
-
Gets the Executor that is going to process the events.
- getExecutor() - Method in class com.hazelcast.config.ReliableTopicConfig
-
Gets the Executor that is going to process the events.
- getExecutorConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the ExecutorConfig for the given name, creating one
if necessary and adding it to the collection of known configurations.
- getExecutorConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of executor configurations, mapped by config name.
- getExecutorName() - Method in interface com.hazelcast.core.Offloadable
-
Returns the name of the executor to which the processing unit will be off-loaded.
- getExecutorPoolSize() - Method in class com.hazelcast.config.SqlConfig
-
Gets the number of threads responsible for execution of SQL statements.
- getExecutorService(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates or returns the distributed executor service for the given name.
- getExpectedResultType() - Method in class com.hazelcast.sql.SqlStatement
-
Gets the expected result type.
- getExpirations() - Method in interface com.hazelcast.nearcache.NearCacheStats
-
Returns the number of TTL and max-idle expirations of Near Cache entries owned by this member.
- getExpirationTime() - Method in interface com.hazelcast.cache.CacheEntryView
-
Gets the expiration time in milliseconds of the cache entry.
- getExpirationTime() - Method in interface com.hazelcast.core.EntryView
-
Returns the expiration time of the entry.
- getExpirationTime() - Method in class com.hazelcast.map.EntryLoader.MetadataAwareValue
-
The expiration date of this entry.
- getExpirationTime() - Method in interface com.hazelcast.spi.merge.MergingExpirationTime
-
Returns the expiration time of the merge data.
- getExpiryForAccess() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-
- getExpiryForCreation() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-
- getExpiryForUpdate() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-
- getExpiryPolicy() - Method in interface com.hazelcast.cache.CacheEntryView
-
Gets the expiry policy associated with this entry if there is one.
- getExpiryPolicyFactory() - Method in class com.hazelcast.config.AbstractCacheConfig
-
- getExpiryPolicyFactoryConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the factory configuration for the ExpiryPolicy
.
- getExpiryPolicyType() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
-
- getExplicitRootTag() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettings
-
- getExtractorClassName() - Method in class com.hazelcast.config.AttributeConfig
-
Gets the full class name of the extractor in a String format, e.g.
- getFactory() - Method in class com.hazelcast.com.fasterxml.jackson.core.ObjectCodec
-
Accessor for finding underlying data format factory
(
JsonFactory
) codec will use for data binding.
- getFactoryClassName() - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
-
Returns the factory class name.
- getFactoryClassName() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns the name of the MapStoreFactory implementation class
- getFactoryClassName() - Method in class com.hazelcast.config.QueueStoreConfig
-
Returns the factory class name which will be used to instantiate the queue
store.
- getFactoryClassName() - Method in class com.hazelcast.config.RingbufferStoreConfig
-
- getFactoryId() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-
- getFactoryId() - Method in class com.hazelcast.cluster.Address
-
- getFactoryId() - Method in class com.hazelcast.config.AbstractCacheConfig
-
- getFactoryId() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
-
- getFactoryId() - Method in class com.hazelcast.config.AttributeConfig
-
- getFactoryId() - Method in class com.hazelcast.config.BitmapIndexOptions
-
- getFactoryId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
-
- getFactoryId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
-
- getFactoryId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
-
- getFactoryId() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- getFactoryId() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- getFactoryId() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
- getFactoryId() - Method in class com.hazelcast.config.CollectionConfig
-
- getFactoryId() - Method in class com.hazelcast.config.DiscoveryConfig
-
- getFactoryId() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
-
- getFactoryId() - Method in class com.hazelcast.config.DurableExecutorConfig
-
- getFactoryId() - Method in class com.hazelcast.config.EventJournalConfig
-
- getFactoryId() - Method in class com.hazelcast.config.EvictionConfig
-
- getFactoryId() - Method in class com.hazelcast.config.ExecutorConfig
-
- getFactoryId() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
- getFactoryId() - Method in class com.hazelcast.config.HotRestartConfig
-
- getFactoryId() - Method in class com.hazelcast.config.IndexConfig
-
- getFactoryId() - Method in class com.hazelcast.config.ListenerConfig
-
- getFactoryId() - Method in class com.hazelcast.config.MapConfig
-
- getFactoryId() - Method in class com.hazelcast.config.MapStoreConfig
-
- getFactoryId() - Method in class com.hazelcast.config.MergePolicyConfig
-
- getFactoryId() - Method in class com.hazelcast.config.MerkleTreeConfig
-
- getFactoryId() - Method in class com.hazelcast.config.MultiMapConfig
-
- getFactoryId() - Method in class com.hazelcast.config.NearCacheConfig
-
- getFactoryId() - Method in class com.hazelcast.config.NearCachePreloaderConfig
-
- getFactoryId() - Method in class com.hazelcast.config.PartitioningStrategyConfig
-
- getFactoryId() - Method in class com.hazelcast.config.PermissionConfig
-
- getFactoryId() - Method in class com.hazelcast.config.PNCounterConfig
-
- getFactoryId() - Method in class com.hazelcast.config.PredicateConfig
-
- getFactoryId() - Method in class com.hazelcast.config.QueryCacheConfig
-
- getFactoryId() - Method in class com.hazelcast.config.QueueConfig
-
- getFactoryId() - Method in class com.hazelcast.config.QueueStoreConfig
-
- getFactoryId() - Method in class com.hazelcast.config.ReliableTopicConfig
-
- getFactoryId() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- getFactoryId() - Method in class com.hazelcast.config.RingbufferConfig
-
- getFactoryId() - Method in class com.hazelcast.config.RingbufferStoreConfig
-
- getFactoryId() - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
- getFactoryId() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
-
- getFactoryId() - Method in class com.hazelcast.config.TopicConfig
-
- getFactoryId() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
- getFactoryId() - Method in class com.hazelcast.config.WanConsumerConfig
-
- getFactoryId() - Method in class com.hazelcast.config.WanCustomPublisherConfig
-
- getFactoryId() - Method in class com.hazelcast.config.WanReplicationConfig
-
- getFactoryId() - Method in class com.hazelcast.config.WanReplicationRef
-
- getFactoryId() - Method in class com.hazelcast.config.WanSyncConfig
-
- getFactoryId() - Method in class com.hazelcast.instance.EndpointQualifier
-
- 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.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.Vertex
-
- getFactoryId() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Returns the factory ID.
- getFactoryId() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- getFactoryId() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
-
- getFactoryId() - Method in interface com.hazelcast.nio.serialization.IdentifiedDataSerializable
-
Returns DataSerializableFactory factory ID for this class.
- getFactoryId() - Method in interface com.hazelcast.nio.serialization.Portable
-
Returns PortableFactory ID for this portable class
- getFactoryId() - Method in class com.hazelcast.security.SimpleTokenCredentials
-
- getFactoryId() - Method in class com.hazelcast.security.UsernamePasswordCredentials
-
- getFactoryId() - Method in class com.hazelcast.version.MemberVersion
-
- getFactoryId() - Method in class com.hazelcast.version.Version
-
- getFactoryImpl() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
-
- getFactoryImplementation() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns the map store factory implementation object.
- getFactoryImplementation() - Method in class com.hazelcast.config.QueueStoreConfig
-
Returns the queue store factory implementation which will be used to
instantiate the queue store.
- getFactoryImplementation() - Method in class com.hazelcast.config.RingbufferStoreConfig
-
- getFactoryImplementation() - Method in class com.hazelcast.config.SSLConfig
-
Returns the factory implementation object.
- getFeatureMask() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- getFeatureMask() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- getFeatureMask() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- getFeatureMask() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- getFeatureMask() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getFence() - Method in interface com.hazelcast.cp.lock.FencedLock
-
Returns the fencing token if the lock is held by the current thread.
- getField(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Gets the FieldDefinition for a particular field.
- getField(int) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Gets the FieldDefinition for a given fieldIndex.
- getFieldClassId(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Gets the class ID of a field.
- getFieldClassId(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- getFieldCount() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Returns the field count.
- getFieldNames() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Returns a Set of all field names.
- getFieldNames() - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getFieldNames() - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- getFieldType(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Get the FieldType for a given fieldName.
- getFieldType(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getFieldType(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- getFileName() - Method in class com.hazelcast.config.InstanceTrackingConfig
-
Returns the name of the file which will contain the tracking metadata.
- 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.
- getFilter() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- getFilter() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getFilter() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
-
- getFilterContext() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- 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
-
- getFlakeIdGeneratorConfigs() - Method in class com.hazelcast.config.Config
-
- getFloat(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getFloat(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
- getFloatArray(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getFloatValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- getFloatValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getFloatValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Numeric accessor that can be called when the current
token is of type
JsonToken.VALUE_NUMBER_FLOAT
and
it can be expressed as a Java float primitive type.
- getFloatValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getFlowControlPeriodMs() - Method in class com.hazelcast.jet.config.InstanceConfig
-
- getFlowStyle() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.CollectionStartEvent
-
true
if this collection is in flow style, false
for block style.
- getFlowStyle() - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.CollectionNode
-
Serialization style of this collection.
- getFormatFeatures() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Bulk access method for getting state of all
FormatFeature
s, format-specific
on/off configuration settings.
- getFormatFeatures() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Bulk access method for getting state of all
FormatFeature
s, format-specific
on/off configuration settings.
- getFormatGeneratorFeatures() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- getFormatGeneratorFeatures() - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
- getFormatName() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method that returns short textual id identifying format
this factory supports.
- getFormatName() - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
Method that returns short textual id identifying format
this factory supports.
- getFormatParserFeatures() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- getFormatParserFeatures() - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
- getFormatPattern() - Method in class com.hazelcast.config.InstanceTrackingConfig
-
Returns the pattern used to render the contents of the instance tracking file.
- getFormatReadFeatureType() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- getFormatReadFeatureType() - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
Method for accessing kind of
FormatFeature
that a parser
JsonParser
produced by this factory would accept, if any;
null
returned if none.
- getFormatWriteFeatureType() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- getFormatWriteFeatureType() - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
Method for accessing kind of
FormatFeature
that a parser
JsonGenerator
produced by this factory would accept, if any;
null
returned if none.
- getForUpdate(Object) - Method in interface com.hazelcast.transaction.TransactionalMap
-
Locks the key and then gets and returns the value to which the specified
key is mapped.
- getFunction() - Method in class com.hazelcast.spi.properties.HazelcastProperty
-
- getFunctionClassName() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
-
- getFunctionImplementation() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
-
- getFuture() - Method in interface com.hazelcast.jet.Job
-
Gets the future associated with the job.
- getGcpConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
- 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.
- getGeneratorFeatures() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- getGeneratorFeatures() - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
- getGenericRecord(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getGenericRecordArray(String) - Method in interface com.hazelcast.nio.serialization.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 class com.hazelcast.com.fasterxml.jackson.core.Version
-
- 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.
- getHandle() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.TagTuple
-
- 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.
- getHazelcastConfig() - Method in class com.hazelcast.jet.config.JetConfig
-
Returns the configuration object for the underlying Hazelcast IMDG
instance.
- getHazelcastInstance() - Method in interface com.hazelcast.cache.HazelcastCacheManager
-
- getHazelcastInstance() - Method in interface com.hazelcast.jet.JetInstance
-
Returns the underlying Hazelcast IMDG instance used by Jet.
- getHazelcastInstance() - Method in class com.hazelcast.security.HazelcastInstanceCallback
-
- 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
-
- 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
- getHighestEscapedChar() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonGeneratorImpl
-
- getHighestEscapedChar() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Accessor method for testing what is the highest unescaped character
configured for this generator.
- getHighestEscapedChar() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- getHitCount() - Method in interface com.hazelcast.query.LocalIndexStats
-
Returns the total number of hits into the index.
- getHits() - Method in interface com.hazelcast.cache.CacheEntryView
-
Gets the count of how many time this cache entry has been accessed.
- getHits() - Method in interface com.hazelcast.core.EntryView
-
Returns number of hits of the entry.
- getHits() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the number of hits (reads) of locally owned entries, including those
which are no longer in the map (for example, may have been evicted).
- getHits() - Method in interface com.hazelcast.nearcache.NearCacheStats
-
Returns the number of hits (reads) of Near Cache entries owned by this member.
- getHits() - Method in interface com.hazelcast.spi.eviction.EvictableEntryView
-
- getHits() - Method in interface com.hazelcast.spi.merge.MergingHits
-
Returns the access hits of the merge data.
- getHost() - Method in class com.hazelcast.cluster.Address
-
- getHotRestartConfig() - Method in class com.hazelcast.config.AbstractCacheConfig
-
Gets the HotRestartConfig
for this CacheConfiguration
- getHotRestartConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the HotRestartConfig
for this CacheSimpleConfig
- getHotRestartConfig() - Method in class com.hazelcast.config.MapConfig
-
Gets the HotRestartConfig
for this MapConfig
- getHotRestartPersistenceConfig() - Method in class com.hazelcast.config.Config
-
Returns the Hot Restart configuration for this hazelcast instance
- getHotRestartService() - Method in interface com.hazelcast.cluster.Cluster
-
Returns the Hot Restart service for interacting with Hot Restart.
- getIcmpFailureDetectorConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig
-
- getIcmpFailureDetectorConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
-
- getIcmpFailureDetectorConfig() - Method in class com.hazelcast.config.NetworkConfig
-
- getId() - Method in enum com.hazelcast.cluster.ClusterState
-
- getId() - Method in enum com.hazelcast.config.BitmapIndexOptions.UniqueKeyTransformation
-
- getId() - Method in enum com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
-
- getId() - Method in enum com.hazelcast.config.ConsistencyCheckStrategy
-
Gets the ID for this ConsistencyCheckStrategy.
- getId() - Method in enum com.hazelcast.config.EvictionPolicy
-
- getId() - Method in enum com.hazelcast.config.IndexType
-
- getId() - Method in enum com.hazelcast.config.InMemoryFormat
-
- getId() - Method in enum com.hazelcast.config.MaxSizePolicy
-
- getId() - Method in enum com.hazelcast.config.MetadataPolicy
-
Returns enumeration id of this policy.
- getId() - Method in enum com.hazelcast.config.ScheduledExecutorConfig.CapacityPolicy
-
- getId() - Method in enum com.hazelcast.config.WanAcknowledgeType
-
- getId() - Method in enum com.hazelcast.config.WanQueueFullBehavior
-
- getId() - Method in interface com.hazelcast.cp.CPGroupId
-
Returns unique id of the CP group.
- getId() - Method in enum com.hazelcast.instance.ProtocolType
-
- 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 interface com.hazelcast.jet.Job
-
Returns the ID of this job.
- getId() - Method in enum com.hazelcast.nio.serialization.FieldType
-
- getId() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
-
Gets the ID of service.
- getId() - Method in enum com.hazelcast.ringbuffer.OverflowPolicy
-
Gets the ID for the given OverflowPolicy.
- getId() - Method in enum com.hazelcast.sql.SqlColumnType
-
- getId() - Method in enum com.hazelcast.wan.WanPublisherState
-
Returns the ID of the WAN publisher state.
- getIdentifier() - Method in class com.hazelcast.instance.EndpointQualifier
-
- 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
-
- 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
-
- getImplementation() - Method in class com.hazelcast.config.SplitBrainProtectionListenerConfig
-
- getImplementation() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
- getImplementation() - Method in class com.hazelcast.config.WanConsumerConfig
-
- getImplicit() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.ScalarEvent
-
- getInboundEdges(String) - Method in class com.hazelcast.jet.core.DAG
-
Returns the inbound edges connected to the vertex with the given name.
- getIndent() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultIndenter
-
- getIndent() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettings
-
- getIndex() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
-
- getIndex() - Method in class com.hazelcast.org.snakeyaml.engine.v2.exceptions.Mark
-
starts with 0
- getIndex() - Method in class com.hazelcast.org.snakeyaml.engine.v2.scanner.StreamReader
-
- 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.
- getIndicatorIndent() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettings
-
- getInetAddress() - Method in class com.hazelcast.cluster.Address
-
- getInetSocketAddress() - Method in class com.hazelcast.cluster.Address
-
- getInitialBackoffMillis() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
-
how long to wait after the first failure before retrying
- getInitialLoadMode() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns the initial load mode.
- getInitialPermits() - Method in class com.hazelcast.config.cp.SemaphoreConfig
-
Returns initial permit count of the Semaphore
- getInitialPublisherState() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the initial WAN publisher state.
- getInitialSnapshotName() - Method in class com.hazelcast.jet.config.JobConfig
-
- 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.
- getInputCodeComment() - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.CharTypes
-
- getInputCodeLatin1() - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.CharTypes
-
- getInputCodeLatin1JsNames() - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.CharTypes
-
- getInputCodeUtf8() - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.CharTypes
-
- getInputCodeUtf8JsNames() - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.CharTypes
-
- getInputCodeWS() - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.CharTypes
-
- getInputDecorator() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method for getting currently configured input decorator (if any;
there is no default decorator).
- getInputSource() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- getInputSource() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- getInputSource() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- getInputSource() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- getInputSource() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method that can be used to get access to object that is used
to access input being parsed; this is usually either
InputStream
or
Reader
, depending on what
parser was constructed with.
- getInputSource() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getInputType() - Method in exception com.hazelcast.com.fasterxml.jackson.core.exc.InputCoercionException
-
Accessor for getting information about input type (in form of token, giving "shape"
of input) for which coercion failed.
- getInsertCount() - Method in interface com.hazelcast.query.LocalIndexStats
-
Returns the number of insert operations performed on the index.
- getInstance() - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.JsonStringEncoder
-
Factory method for getting an instance; this is either recycled per-thread instance,
or a newly constructed one.
- getInstanceConfig() - Method in class com.hazelcast.jet.config.JetConfig
-
Returns the Jet instance config.
- 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.
- getInt(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getIntArray(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getInteger(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
- 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
-
- getIntValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- getIntValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getIntValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Numeric accessor that can be called when the current
token is of type
JsonToken.VALUE_NUMBER_INT
and
it can be expressed as a value of Java int primitive type.
- getIntValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getInvalidations() - Method in interface com.hazelcast.nearcache.NearCacheStats
-
Returns the number of invalidations of Near Cache entries owned by this member.
- getItem() - Method in class com.hazelcast.collection.ItemEvent
-
Returns the item related to the event.
- getItemListenerConfigs() - Method in class com.hazelcast.config.CollectionConfig
-
Gets the list of ItemListenerConfigs.
- getItemListenerConfigs() - Method in class com.hazelcast.config.QueueConfig
-
Get the list of item listener configurations for this queue.
- getItems() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
-
Returns the array representing this ringbuffer.
- getIterationCount() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-
Deprecated.
- getJaasAuthenticationConfig() - Method in class com.hazelcast.config.security.RealmConfig
-
- getJarPaths() - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
-
- getJavaName() - Method in enum com.hazelcast.com.fasterxml.jackson.core.JsonEncoding
-
Method for accessing encoding name that JDK will support.
- getJavaSerializationFilterConfig() - Method in class com.hazelcast.config.SerializationConfig
-
- getJetBuildInfo() - Method in class com.hazelcast.instance.BuildInfo
-
- 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.JetInstance
-
Returns the job with the given id or null
if no such job could
be found.
- getJob(String) - Method in interface com.hazelcast.jet.JetInstance
-
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.
- getJobs() - Method in interface com.hazelcast.jet.JetInstance
-
Returns all submitted jobs including running and completed ones.
- getJobs(String) - Method in interface com.hazelcast.jet.JetInstance
-
Returns all jobs submitted with the given name, ordered in descending
order by submission time.
- getJobStateSnapshot(String) - Method in interface com.hazelcast.jet.JetInstance
-
Returns the
JobStateSnapshot
object representing an exported
snapshot with the given name.
- getJobStateSnapshots() - Method in interface com.hazelcast.jet.JetInstance
-
Returns the collection of exported job state snapshots stored in the
cluster.
- getJoin() - Method in class com.hazelcast.config.AdvancedNetworkConfig
-
- getJoin() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
-
- getJoin() - Method in class com.hazelcast.config.NetworkConfig
-
- getJsonFactory() - Method in class com.hazelcast.com.fasterxml.jackson.core.ObjectCodec
-
- 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
-
- 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.
- getKeyClassName() - Method in class com.hazelcast.config.AbstractCacheConfig
-
- getKeyNode() - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.NodeTuple
-
Key node.
- getKeySize() - Method in class com.hazelcast.config.EncryptionAtRestConfig
-
Returns the size (in bits) of the Hot Restart Store-level encryption key.
- getKeytabFile() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
-
- getKeytabFile() - Method in class com.hazelcast.config.security.KerberosIdentityConfig
-
- getKeyType() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
-
Method for accessing key type for this type, assuming type
has such a concept (only Map types do)
- 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
-
- 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.
- getLabel() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettings
-
- 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
-
- getLastAccessTime() - Method in interface com.hazelcast.spi.merge.MergingLastAccessTime
-
Returns the last access time of the merge data.
- getLastClearedToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- getLastClearedToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getLastClearedToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- getLastClearedToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getLastIdleTime(TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.ScheduledTaskStatistics
-
Returns the last period of time the task was idle, waiting to get scheduled
- getLastPersistenceDuration() - Method in interface com.hazelcast.nearcache.NearCacheStats
-
Returns the duration in milliseconds of the last Near Cache key persistence (when the pre-load feature is enabled).
- getLastPersistenceFailure() - Method in interface com.hazelcast.nearcache.NearCacheStats
-
Returns the failure reason of the last Near Cache persistence (when the pre-load feature is enabled).
- getLastPersistenceKeyCount() - Method in interface com.hazelcast.nearcache.NearCacheStats
-
Returns the number of persisted keys of the last Near Cache key persistence (when the pre-load feature is enabled).
- getLastPersistenceTime() - Method in interface com.hazelcast.nearcache.NearCacheStats
-
Returns the timestamp of the last Near Cache key persistence (when the pre-load feature is enabled).
- getLastPersistenceWrittenBytes() - Method in interface com.hazelcast.nearcache.NearCacheStats
-
Returns the written bytes of the last Near Cache key persistence (when the pre-load feature is enabled).
- getLastRunDuration(TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.ScheduledTaskStatistics
-
Returns the duration of the task's last execution.
- getLastStoredTime() - Method in interface com.hazelcast.core.EntryView
-
Returns the last time the value was flushed to its store (e.g.
- getLastStoredTime() - Method in interface com.hazelcast.spi.merge.MergingLastStoredTime
-
Returns the last stored time of the merge data.
- getLastUpdateTime() - Method in interface com.hazelcast.cache.CacheStatistics
-
Gets the last update time to cache.
- getLastUpdateTime() - Method in interface com.hazelcast.collection.LocalCollectionStats
-
Returns the last update time of the list.
- getLastUpdateTime() - Method in interface com.hazelcast.core.EntryView
-
Returns the last time the value was updated.
- getLastUpdateTime() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the last update time of the locally owned entries.
- getLastUpdateTime() - Method in interface com.hazelcast.spi.merge.MergingLastUpdateTime
-
Returns the last update time of the merge data.
- getLdapAuthenticationConfig() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
-
- getLdapAuthenticationConfig() - Method in class com.hazelcast.config.security.RealmConfig
-
- getLeaderElectionTimeoutInMillis() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
-
- getLeaderHeartbeatPeriodInMillis() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
-
- getLeaderUuid() - Method in exception com.hazelcast.cp.exception.CPSubsystemException
-
Returns the leader endpoint of related CP group, if known/available
by the time this exception is thrown.
- getLevel() - Method in interface com.hazelcast.logging.ILogger
-
Gets the logging level.
- getLevel() - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
-
- getLicenseKey() - Method in class com.hazelcast.config.Config
-
Returns the license key for this hazelcast instance.
- getLifecycleService() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the lifecycle service for this instance.
- getLine() - Method in class com.hazelcast.org.snakeyaml.engine.v2.exceptions.Mark
-
starts with 0
- getLine() - Method in class com.hazelcast.org.snakeyaml.engine.v2.scanner.StreamReader
-
- getLineNr() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonLocation
-
- 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.client.console.ClientConsoleApp
-
- 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
-
Returns the distributed list instance with the specified name.
- 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
-
- getListenerConfigs() - Method in class com.hazelcast.config.Config
-
- getListenerConfigs() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- getListenerConfigs() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
-
- getListenerConfigurations() - Method in class com.hazelcast.config.AbstractCacheConfig
-
- getLoadBalancer() - Method in class com.hazelcast.client.config.ClientConfig
-
Gets LoadBalancer
- getLoadBalancerClassName() - Method in class com.hazelcast.client.config.ClientConfig
-
Gets load balancer class name
- getLocalCacheStatistics() - Method in interface com.hazelcast.cache.ICache
-
Directly access local Cache Statistics.
- getLocalCPMember() - Method in interface com.hazelcast.cp.CPSubsystem
-
Returns the local CP member if this Hazelcast member is part of
CP Subsystem, returns null otherwise.
- getLocalCPMember() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
-
Returns the local CP member if this Hazelcast member is part of
CP Subsystem, returns null otherwise.
- getLocalEndpoint() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the local Endpoint which this HazelcastInstance belongs to.
- getLocalExecutorStats() - Method in interface com.hazelcast.core.IExecutorService
-
Returns local statistics related to this executor service.
- getLocalListStats() - Method in interface com.hazelcast.collection.IList
-
- 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
-
- 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
-
- getLocation() - Method in exception com.hazelcast.com.fasterxml.jackson.core.JacksonException
-
Accessor for location information related to position within input
or output (depending on operation), if available; if not available
may return null
.
- getLocation() - Method in exception com.hazelcast.com.fasterxml.jackson.core.JsonProcessingException
-
- getLock(String) - Method in interface com.hazelcast.cp.CPSubsystem
-
Returns a proxy for an
FencedLock
instance created on CP
Subsystem.
- getLockAcquireLimit() - Method in class com.hazelcast.config.cp.FencedLockConfig
-
Returns the maximum number of lock acquires a lock holder can perform.
- getLockConfigs() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
- 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(Class) - Static method in class com.hazelcast.logging.Logger
-
Obtains a
logger
for the given
clazz
.
- getLogger(String) - Static method in class com.hazelcast.logging.Logger
-
Obtains a
logger
of the given
name
.
- getLogger(String) - Method in interface com.hazelcast.logging.LoggerFactory
-
- getLogger(String) - Method in class com.hazelcast.logging.LoggerFactorySupport
-
- getLogger(String) - Method in interface com.hazelcast.logging.LoggingService
-
- getLogger(Class) - Method in interface com.hazelcast.logging.LoggingService
-
- getLogger(String) - Method in class com.hazelcast.logging.NoLogFactory
-
- getLogger() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
-
Returns a
ILogger
instance bound to the current class.
- getLogger() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
-
- getLoggingService() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the logging service of this Hazelcast instance.
- getLoggingService() - Method in class com.hazelcast.security.LoggingServiceCallback
-
- getLoginModuleConfigs() - Method in class com.hazelcast.config.security.JaasAuthenticationConfig
-
- getLogRecord() - Method in class com.hazelcast.logging.LogEvent
-
- getLong() - Method in class com.hazelcast.jet.accumulator.LongDoubleAccumulator
-
Returns the long
value.
- getLong(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getLong(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
- getLongArray(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getLongValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- getLongValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getLongValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Numeric accessor that can be called when the current
token is of type
JsonToken.VALUE_NUMBER_INT
and
it can be expressed as a Java long primitive type.
- getLongValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getLostBackupCount() - Method in interface com.hazelcast.partition.PartitionLostEvent
-
- getMajor() - Method in class com.hazelcast.org.snakeyaml.engine.v2.common.SpecVersion
-
- 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.
- getMajorVersion() - Method in class com.hazelcast.com.fasterxml.jackson.core.Version
-
- getManagedContext() - Method in class com.hazelcast.client.config.ClientConfig
-
- getManagedContext() - Method in class com.hazelcast.config.Config
-
Returns the external managed context.
- getManagementCenterConfig() - Method in class com.hazelcast.config.Config
-
Returns the management center configuration for this hazelcast instance.
- getManagementCenterConfig() - Method in class com.hazelcast.config.MetricsConfig
-
- getManagerPrefix() - Method in class com.hazelcast.config.CacheConfig
-
Gets the manager prefix of the
ICache
, such as "hz://".
- getMap() - Method in class com.hazelcast.client.console.ClientConsoleApp
-
- 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.jet.JetInstance
-
Returns the distributed map instance with the specified name.
- 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
- getMark() - Method in class com.hazelcast.org.snakeyaml.engine.v2.scanner.StreamReader
-
- getMask() - Method in interface com.hazelcast.com.fasterxml.jackson.core.FormatFeature
-
Returns bit mask for this feature instance; must be a single bit,
that is of form (1 << N)
- getMask() - Method in enum com.hazelcast.com.fasterxml.jackson.core.json.JsonReadFeature
-
- getMask() - Method in enum com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteFeature
-
- getMask() - Method in enum com.hazelcast.com.fasterxml.jackson.core.JsonFactory.Feature
-
- getMask() - Method in enum com.hazelcast.com.fasterxml.jackson.core.JsonGenerator.Feature
-
- getMask() - Method in enum com.hazelcast.com.fasterxml.jackson.core.JsonParser.Feature
-
- getMask() - Method in enum com.hazelcast.com.fasterxml.jackson.core.StreamReadCapability
-
- getMask() - Method in enum com.hazelcast.com.fasterxml.jackson.core.StreamReadFeature
-
- getMask() - Method in enum com.hazelcast.com.fasterxml.jackson.core.StreamWriteCapability
-
- getMask() - Method in enum com.hazelcast.com.fasterxml.jackson.core.StreamWriteFeature
-
- getMask() - Method in interface com.hazelcast.com.fasterxml.jackson.core.util.JacksonFeature
-
Returns bit mask for this feature instance; must be a single bit,
that is of form 1 << N
.
- getMatch() - Method in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatMatcher
-
Accessor for
JsonFactory
that represents format that data matched.
- getMatchCount() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
Accessor for finding number of matches, where specific token and sub-tree
starting (if structured type) are passed.
- getMatchCount() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
Accessor for finding number of matches, where specific token and sub-tree
starting (if structured type) are passed.
- getMatchedFormatName() - Method in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatMatcher
-
Accessor for getting brief textual name of matched format if any (null
if none).
- getMatchingIndex() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
-
- getMatchingProperty() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
-
- getMatchStrength() - Method in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatMatcher
-
- getMaxAge() - Method in interface com.hazelcast.collection.LocalQueueStats
-
Returns the maximum age of the items in this member.
- getMaxAliasesForCollections() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettings
-
- 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 any more.
- getMaxConcurrentInvocations() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the maximum number of WAN event batches being sent to the target
cluster concurrently.
- getMaxConcurrentReplicationTargets() - Method in class com.hazelcast.config.CRDTReplicationConfig
-
Returns the maximum number of target members that we replicate the CRDT
states to in one period.
- getMaxGetLatency() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the maximum latency of get operations.
- getMaxIdle() - Method in interface com.hazelcast.core.EntryView
-
Returns the last set max idle time in milliseconds.
- getMaxIdle() - Method in interface com.hazelcast.spi.merge.MergingMaxIdle
-
Returns the MaxIdle of the merge data.
- getMaxIdleSeconds() - Method in class com.hazelcast.config.MapConfig
-
Returns the maximum number of seconds for each entry to stay idle in the map.
- getMaxIdleSeconds() - Method in class com.hazelcast.config.NearCacheConfig
-
Returns the maximum number of seconds each entry can stay in the Near Cache as untouched (not-read).
- getMaxLineLength() - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
-
- getMaxMissedLeaderHeartbeatCount() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
-
- getMaxPutLatency() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the maximum latency of put operations.
- getMaxRemoveLatency() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the maximum latency of remove operations.
- getMaxSetLatency() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the maximum latency of set operations.
- getMaxSimpleKeyLength() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettings
-
- getMaxSize() - Method in class com.hazelcast.config.CollectionConfig
-
Gets the maximum size for the Configuration.
- getMaxSize() - Method in class com.hazelcast.config.QueueConfig
-
Returns the maximum size of the Queue.
- getMaxSizePolicy() - Method in class com.hazelcast.config.EvictionConfig
-
- 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
-
- getMemberGroups() - Method in interface com.hazelcast.spi.partitiongroup.PartitionGroupStrategy
-
- getMemberRealm() - Method in class com.hazelcast.config.SecurityConfig
-
- getMembers() - Method in class com.hazelcast.client.util.AbstractLoadBalancer
-
- getMembers() - Method in interface com.hazelcast.cluster.Cluster
-
Set of the current members in the cluster.
- getMembers() - Method in class com.hazelcast.cluster.InitialMembershipEvent
-
- getMembers() - Method in class com.hazelcast.cluster.MembershipEvent
-
Returns a consistent view of the the members immediately after this MembershipEvent has been processed.
- getMembers() - Method in class com.hazelcast.config.TcpIpConfig
-
Gets a list of all the well known members.
- getMemcacheProtocolConfig() - Method in class com.hazelcast.config.NetworkConfig
-
- getMemoryCost() - Method in interface com.hazelcast.query.LocalIndexStats
-
Returns the memory cost of the index in bytes.
- getMergePolicy(String) - Method in class com.hazelcast.spi.merge.SplitBrainMergePolicyProvider
-
- 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
-
- getMergePolicyConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- getMergePolicyConfig() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
- getMergePolicyConfig() - Method in class com.hazelcast.config.CollectionConfig
-
- getMergePolicyConfig() - Method in class com.hazelcast.config.MapConfig
-
- getMergePolicyConfig() - Method in class com.hazelcast.config.MultiMapConfig
-
- getMergePolicyConfig() - Method in class com.hazelcast.config.QueueConfig
-
- getMergePolicyConfig() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- getMergePolicyConfig() - Method in class com.hazelcast.config.RingbufferConfig
-
- getMergePolicyConfig() - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
- getMergingValue() - Method in class com.hazelcast.core.EntryEvent
-
Returns the incoming merging value of the entry event.
- getMerkleTreeConfig() - Method in class com.hazelcast.config.MapConfig
-
Gets the MerkleTreeConfig
for this MapConfig
- getMerkleTreesCost() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the heap cost of the Merkle trees
- getMessage() - Method in exception com.hazelcast.com.fasterxml.jackson.core.exc.StreamReadException
-
Overriding the getMessage() to include the request body
- getMessage() - Method in exception com.hazelcast.com.fasterxml.jackson.core.JsonParseException
-
- getMessage() - Method in exception com.hazelcast.com.fasterxml.jackson.core.JsonProcessingException
-
Default implementation overridden so that we can add location information
- getMessage() - Method in exception com.hazelcast.org.snakeyaml.engine.v2.exceptions.MarkedYamlEngineException
-
- 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
- getMessageSuffix() - Method in exception com.hazelcast.com.fasterxml.jackson.core.JsonProcessingException
-
Accessor that sub-classes can override to append additional
information right after the main message, but before
source location information.
- getMetadata() - Method in interface com.hazelcast.sql.SqlRow
-
Gets row metadata.
- getMetadataPolicy() - Method in class com.hazelcast.config.MapConfig
-
- 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.
- 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
-
- 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.org.snakeyaml.engine.v2.common.SpecVersion
-
- getMinor() - Method in class com.hazelcast.version.MemberVersion
-
- getMinor() - Method in class com.hazelcast.version.Version
-
- getMinorVersion() - Method in class com.hazelcast.com.fasterxml.jackson.core.Version
-
- getMisses() - Method in interface com.hazelcast.nearcache.NearCacheStats
-
Returns the number of misses of Near Cache entries owned by this member.
- getMissingCPMemberAutoRemovalSeconds() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Returns the duration to wait before automatically removing a missing
CP member from CP Subsystem
- getMode() - Method in class com.hazelcast.config.PersistentMemoryConfig
-
Returns the mode in which the persistent memory should be used.
- getModeName() - Method in enum com.hazelcast.config.InstanceTrackingConfig.InstanceMode
-
Returns the string representation of the instance mode name.
- getMulticastConfig() - Method in class com.hazelcast.config.JoinConfig
-
- getMulticastGroup() - Method in class com.hazelcast.config.MulticastConfig
-
Gets the multicast group.
- getMulticastPort() - Method in class com.hazelcast.config.MulticastConfig
-
Gets the multicast port.
- getMulticastTimeoutSeconds() - Method in class com.hazelcast.config.MulticastConfig
-
Gets the multicast timeout in seconds.
- getMulticastTimeToLive() - Method in class com.hazelcast.config.MulticastConfig
-
Gets the time to live for the multicast package.
- getMultiMap() - Method in class com.hazelcast.client.console.ClientConsoleApp
-
- 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 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.com.fasterxml.jackson.core.Base64Variant
-
- getName() - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.Name
-
- 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
-
- getName() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- getName() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
Gets the name of the cardinality estimator.
- getName() - Method in class com.hazelcast.config.CollectionConfig
-
Gets the name of this collection.
- getName() - Method in class com.hazelcast.config.cp.FencedLockConfig
-
Returns the name of FencedLock
- getName() - Method in class com.hazelcast.config.cp.SemaphoreConfig
-
Returns the name of CP ISemaphore
- getName() - Method in class com.hazelcast.config.DurableExecutorConfig
-
Gets the name of the executor task.
- getName() - Method in class com.hazelcast.config.EndpointConfig
-
- getName() - Method in class com.hazelcast.config.ExecutorConfig
-
Gets the name of the executor task.
- getName() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
Returns the configuration name.
- getName() - Method in class com.hazelcast.config.IndexConfig
-
Gets name of the index.
- getName() - Method in class com.hazelcast.config.MapConfig
-
Returns the name of this
IMap
- getName() - Method in class com.hazelcast.config.MultiMapConfig
-
Gets the name of this MultiMap.
- getName() - Method in interface com.hazelcast.config.NamedConfig
-
- getName() - Method in class com.hazelcast.config.NearCacheConfig
-
Returns the name of the Near Cache.
- getName() - Method in class com.hazelcast.config.PermissionConfig
-
- getName() - Method in class com.hazelcast.config.PNCounterConfig
-
Gets the name of the PN counter.
- getName() - Method in class com.hazelcast.config.QueryCacheConfig
-
Returns the name of QueryCache
.
- getName() - Method in class com.hazelcast.config.QueueConfig
-
- getName() - Method in class com.hazelcast.config.ReliableTopicConfig
-
Gets the name of the reliable topic.
- getName() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- getName() - Method in class com.hazelcast.config.RingbufferConfig
-
Returns the name of the ringbuffer.
- getName() - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Gets the name of the executor task.
- getName() - Method in class com.hazelcast.config.ServiceConfig
-
- getName() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
-
- getName() - Method in class com.hazelcast.config.TopicConfig
-
Gets the name of the topic, null if nothing is set.
- getName() - Method in class com.hazelcast.config.WanReplicationConfig
-
- getName() - Method in class com.hazelcast.config.WanReplicationRef
-
Returns the WAN replication reference name.
- getName() - Method in interface com.hazelcast.core.DistributedObject
-
Returns the unique name for this DistributedObject.
- getName(DistributedObject) - Static method in class com.hazelcast.core.DistributedObjectUtil
-
Gets the name of the given distributed object.
- getName() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the name of this Hazelcast instance.
- getName() - Method in interface com.hazelcast.cp.CPGroupId
-
Returns name of the CP group.
- getName() - Method in interface com.hazelcast.cp.IAtomicLong
-
Returns the name of this IAtomicLong instance.
- getName() - Method in interface com.hazelcast.cp.ISemaphore
-
Returns the name of this ISemaphore instance.
- getName() - Method in class com.hazelcast.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
-
Returns the name of the Jet instance.
- 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.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 class com.hazelcast.org.snakeyaml.engine.v2.exceptions.Mark
-
- getName() - Method in exception com.hazelcast.org.snakeyaml.engine.v2.exceptions.ReaderException
-
- getName() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.DirectiveToken
-
- getName() - Method in interface com.hazelcast.scheduledexecutor.NamedTask
-
Returns the name of the task.
- getName() - Method in interface com.hazelcast.security.Credentials
-
- getName() - Method in class com.hazelcast.security.SimpleTokenCredentials
-
Simple implementation which returns "<empty>"
for null
tokens and "<token>"
for all other tokens.
- getName() - Method in class com.hazelcast.security.UsernamePasswordCredentials
-
- getName() - Method in class com.hazelcast.spi.properties.HazelcastProperty
-
Returns the property name.
- getName() - Method in class com.hazelcast.sql.SqlColumnMetadata
-
Get column name.
- getName() - Method in interface com.hazelcast.topic.ITopic
-
Returns the name of this ITopic instance.
- getNamespaceType() - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- getNameWithPrefix() - Method in class com.hazelcast.config.CacheConfig
-
Gets the full name of the
ICache
, including the manager scope prefix.
- getNanos(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
- getNativeMemoryConfig() - Method in class com.hazelcast.client.config.ClientConfig
-
- getNativeMemoryConfig() - Method in class com.hazelcast.config.Config
-
Returns the native memory configuration for this hazelcast instance.
- getNearCacheConfig(String) - Method in class com.hazelcast.client.config.ClientConfig
-
- getNearCacheConfig() - Method in class com.hazelcast.config.MapConfig
-
Returns the Near Cache configuration
- getNearCacheConfigMap() - Method in class com.hazelcast.client.config.ClientConfig
-
Map of all configured NearCacheConfig's with the name key and configuration as the value
- getNearCacheStatistics() - Method in interface com.hazelcast.cache.CacheStatistics
-
Gets the Near Cache statistics.
- getNearCacheStats() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns statistics related to the Near Cache.
- getNetworkConfig() - Method in class com.hazelcast.client.config.ClientConfig
-
- getNetworkConfig() - Method in class com.hazelcast.config.Config
-
Returns the network configuration for this hazelcast instance.
- getNewValue() - Method in interface com.hazelcast.cache.EventJournalCacheEvent
-
Returns the new value for the event entry.
- getNewValue() - Method in interface com.hazelcast.map.EventJournalMapEvent
-
Returns the new value for the event entry.
- getNextChar(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
Deprecated.
- getNextChar(String, JsonToken) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- getNextSequenceToReadFrom() - Method in interface com.hazelcast.ringbuffer.ReadResultSet
-
Returns the sequence of the item following the last read item.
- getNodeFilter() - Method in class com.hazelcast.config.DiscoveryConfig
-
- getNodeFilterClass() - Method in class com.hazelcast.config.DiscoveryConfig
-
- getNodeIdOffset() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
- getNodeName() - Method in enum com.hazelcast.config.PermissionConfig.PermissionType
-
- getNodeType() - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.AnchorNode
-
- getNodeType() - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.MappingNode
-
- getNodeType() - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.Node
-
- getNodeType() - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.ScalarNode
-
- getNodeType() - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.SequenceNode
-
- getNonBlockingInputFeeder() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- getNonBlockingInputFeeder() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method that will either return a feeder instance (if parser uses
non-blocking, aka asynchronous access); or null
for
parsers that use blocking I/O.
- getNonPrintableStyle() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettings
-
- 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.
- getNumberType() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- getNumberType() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getNumberType() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- getNumberType() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getNumberValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- getNumberValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getNumberValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Generic number value accessor method that will work for
all kinds of numeric values.
- getNumberValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getNumberValueExact() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- getNumberValueExact() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method similar to
JsonParser.getNumberValue()
with the difference that
for floating-point numbers value returned may be
BigDecimal
if the underlying format does not store floating-point numbers using
native representation: for example, textual formats represent numbers
as Strings (which are 10-based), and conversion to
Double
is potentially lossy operation.
- getNumberValueExact() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- 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.
- getObjectEntrySeparator() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.Separators
-
- getObjectFieldValueSeparator() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.Separators
-
- getObjectId() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method that can be called to check whether current token
(one that was just read) has an associated Object id, and if
so, return it.
- getObjectId() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- 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.JetInstance
-
Returns an
Observable
instance with the specified name.
- getObservables() - Method in interface com.hazelcast.jet.JetInstance
-
- 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 given
defaultValue
.
- getOrDefault(String, PropertyDefinition, T) - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
-
Returns the value of the requested
PropertyDefinition
if available in the
declarative or programmatic configuration (XML or Config API), can be found in the
system's environment, or passed as a JVM property.
- getOrderComparator() - Method in class com.hazelcast.jet.core.Edge
-
- getOriginalMessage() - Method in exception com.hazelcast.com.fasterxml.jackson.core.JacksonException
-
Method that allows accessing the original "message" argument,
without additional decorations (like location information)
that overridden
Throwable.getMessage()
adds.
- getOriginalMessage() - Method in exception com.hazelcast.com.fasterxml.jackson.core.JsonProcessingException
-
- getOriginatingMemberId() - Method in exception com.hazelcast.sql.HazelcastSqlException
-
Gets ID of the member that caused or initiated an error condition.
- getOriginClassName() - Method in exception com.hazelcast.client.UndefinedErrorCodeException
-
- getOrNull(PropertyDefinition) - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
-
Returns the value of the requested
PropertyDefinition
if available in the
declarative or programmatic configuration (XML or Config API), otherwise it will
return
null
.
- getOrNull(String, PropertyDefinition) - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
-
Returns the value of the requested
PropertyDefinition
if available in the
declarative or programmatic configuration (XML or Config API), can be found in the
system's environment, or passed as a JVM property.
- getOrNullQueryCacheConfig(String, String) - Method in class com.hazelcast.client.config.ClientConfig
-
- getOtherOperationCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the total number of Other Operations
- getOtherOperationsCount() - Method in interface com.hazelcast.collection.LocalQueueStats
-
Returns number of other operations
- 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
-
- getOutputBuffered() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- getOutputBuffered() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- getOutputBuffered() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for verifying amount of content that is buffered by generator
but not yet flushed to the underlying target (stream, writer),
in units (byte, char) that the generator implementation uses for buffering;
or -1 if this information is not available.
- getOutputBuffered() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- getOutputContext() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
Note: type was co-variant until Jackson 2.7; reverted back to
base type in 2.8 to allow for overriding by subtypes that use
custom context type.
- getOutputContext() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- getOutputContext() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Accessor for context object that provides information about low-level
logical position withing output token stream.
- getOutputContext() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- getOutputDecorator() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method for getting currently configured output decorator (if any;
there is no default decorator).
- getOutputTarget() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- getOutputTarget() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- getOutputTarget() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method that can be used to get access to object that is used
as target for generated output; this is usually either
OutputStream
or
Writer
, depending on what
generator was constructed with.
- getOutputTarget() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- getOwnedEntryCount() - Method in interface com.hazelcast.cache.CacheStatistics
-
Returns the owned entry count in the cache.
- getOwnedEntryCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the number of entries owned by this member.
- getOwnedEntryCount() - Method in interface com.hazelcast.nearcache.NearCacheStats
-
Returns the number of Near Cache entries owned by this member.
- getOwnedEntryMemoryCost() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns memory cost (number of bytes) of owned entries in this member.
- getOwnedEntryMemoryCost() - Method in interface com.hazelcast.nearcache.NearCacheStats
-
Returns memory cost (number of bytes) of Near Cache entries owned by this member.
- getOwnedItemCount() - Method in interface com.hazelcast.collection.LocalQueueStats
-
Returns the number of owned items in this member.
- getOwner() - Method in interface com.hazelcast.partition.Partition
-
Returns the current member that owns this partition.
- getOwnerBundle() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
-
Gets the owner Bundle
of this instance.
- getOwnerService() - Method in interface com.hazelcast.osgi.HazelcastOSGiInstance
-
- getPackages() - Method in class com.hazelcast.config.ClassFilter
-
Returns unmodifiable set of package names.
- getPacketSizeLimit() - Method in class com.hazelcast.jet.config.EdgeConfig
-
- getPaddingByte() - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
-
- getPaddingChar() - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
-
- getPage() - Method in interface com.hazelcast.query.PagingPredicate
-
Returns the current page value.
- getPageSize() - Method in class com.hazelcast.config.NativeMemoryConfig
-
Returns the page size, in bytes, to be allocated by native memory manager as a single block.
- getPageSize() - Method in interface com.hazelcast.query.PagingPredicate
-
Returns the page size.
- getParallelism() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Gets the configured number of Hot Restart store instance to create for one Hazelcast instance.
- getParameters() - Method in class com.hazelcast.sql.SqlStatement
-
Gets the statement parameters.
- getParameterSource() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
-
- getParent() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
-
- getParent() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
-
- getParent() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
- getParent() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
-
Accessor for finding parent context of this context; will
return null for root context.
- getParent() - Method in class com.hazelcast.spi.properties.HazelcastProperty
-
- getParserFeatures() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- getParserFeatures() - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
- getParsingContext() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- getParsingContext() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- getParsingContext() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getParsingContext() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method that can be used to access current parsing context reader
is in.
- getParsingContext() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getPartition(Object) - Method in interface com.hazelcast.jet.core.DefaultPartitionStrategy
-
Returns the Hazelcast partition ID of the given object.
- 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.
- getPartition(Object) - Method in interface com.hazelcast.partition.PartitionService
-
Returns the partition that the given key belongs to.
- 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
-
Returns a custom implementation of a
PartitionGroupStrategy
to override
default behavior of zone aware backup strategies
PartitionGroupMetaData
or to provide a specific behavior in case the discovery environment does not provide
information about the infrastructure to be used for automatic configuration.
- getPartitionGroupStrategy() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategy
-
- getPartitionId() - Method in class com.hazelcast.map.EventLostEvent
-
- getPartitionId() - Method in class com.hazelcast.map.MapPartitionLostEvent
-
Returns the partition ID that has been lost for the given map
- getPartitionId() - Method in interface com.hazelcast.partition.Partition
-
Returns the ID of the partition.
- getPartitionId() - Method in interface com.hazelcast.partition.PartitionEvent
-
Returns the partition ID that the event is dispatched for.
- getPartitionId() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
-
Returns the partition ID the task is associated with.
- getPartitioningStrategy() - Method in class com.hazelcast.config.PartitioningStrategyConfig
-
- getPartitioningStrategyClass() - Method in class com.hazelcast.config.PartitioningStrategyConfig
-
- getPartitioningStrategyConfig() - Method in class com.hazelcast.config.MapConfig
-
- getPartitionKey() - Method in interface com.hazelcast.core.DistributedObject
-
Returns the key of the partition that this DistributedObject is assigned to.
- getPartitionKey() - Method in interface com.hazelcast.partition.PartitionAware
-
The key that will be used by Hazelcast to specify the partition.
- getPartitionKey() - Method in class com.hazelcast.partition.PartitionAwareKey
-
- getPartitionKey(K) - Method in interface com.hazelcast.partition.PartitioningStrategy
-
Returns the key object that will be used by Hazelcast to specify the partition.
- getPartitionKey(Object) - Method in class com.hazelcast.partition.strategy.DefaultPartitioningStrategy
-
- getPartitionKey(Object) - Method in class com.hazelcast.partition.strategy.StringAndPartitionAwarePartitioningStrategy
-
- getPartitionKey(Object) - Method in class com.hazelcast.partition.strategy.StringPartitioningStrategy
-
- getPartitionKey(String) - Static method in class com.hazelcast.partition.strategy.StringPartitioningStrategy
-
- getPartitionKey() - Method in interface com.hazelcast.query.PartitionPredicate
-
Returns the partition key that determines the partition the
target Predicate
is going to execute on.
- getPartitionLostListenerConfigs() - Method in class com.hazelcast.config.CacheConfig
-
Gets the partition lost listener references added to cache configuration.
- getPartitionLostListenerConfigs() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the partition lost listener references added to cache configuration.
- getPartitionLostListenerConfigs() - Method in class com.hazelcast.config.MapConfig
-
- getPartitions() - Method in interface com.hazelcast.partition.PartitionService
-
Returns a set containing all the
Partition
s in the cluster.
- getPartitionService() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the partition service of this Hazelcast instance.
- getPassword() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
-
Returns the Java KeyStore password.
- getPassword() - Method in class com.hazelcast.config.replacer.AbstractPbeReplacer
-
Provides password for a chosen SecretKeyFactory.
- getPassword() - Method in class com.hazelcast.config.replacer.EncryptionReplacer
-
- getPassword() - Method in class com.hazelcast.config.security.UsernamePasswordIdentityConfig
-
- getPassword() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-
Deprecated.
- getPassword() - Method in interface com.hazelcast.security.PasswordCredentials
-
- getPassword() - Method in class com.hazelcast.security.UsernamePasswordCredentials
-
Gets the password.
- getPasswordAttribute() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- getPatch() - Method in class com.hazelcast.version.MemberVersion
-
- getPatchLevel() - Method in class com.hazelcast.com.fasterxml.jackson.core.Version
-
- getPath() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
-
Returns the Java KeyStore file path.
- getPendingTaskCount() - Method in interface com.hazelcast.executor.LocalExecutorStats
-
Returns the number of pending operations on the executor service.
- getPermission(String, String, String...) - Static method in class com.hazelcast.security.permission.ActionConstants
-
Creates a permission
- getPermissions(Subject, Class<? extends Permission>) - Method in interface com.hazelcast.security.IPermissionPolicy
-
Determines permissions of subject.
- getPermissions() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
-
- getPersistenceCount() - Method in interface com.hazelcast.nearcache.NearCacheStats
-
Returns the number of Near Cache key persistences (when the pre-load feature is enabled).
- getPersistentMemoryConfig() - Method in class com.hazelcast.config.NativeMemoryConfig
-
Returns the persistent memory configuration this native memory
configuration uses.
- getPersistentMemoryDirectory() - Method in class com.hazelcast.config.NativeMemoryConfig
-
- 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.
- getPointer() - Method in class com.hazelcast.org.snakeyaml.engine.v2.exceptions.Mark
-
- getPolicy() - Method in class com.hazelcast.config.MergePolicyConfig
-
- getPollingInterval() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
-
Returns the polling interval (in seconds) for checking for changes in the KeyStore.
- getPollingInterval() - Method in class com.hazelcast.config.VaultSecureStoreConfig
-
Returns the Vault polling interval (in seconds).
- getPollOperationCount() - Method in interface com.hazelcast.collection.LocalQueueStats
-
Returns the number of poll/take/remove operations.
- getPoolSize() - Method in class com.hazelcast.config.DurableExecutorConfig
-
Gets the number of executor threads per member for the executor.
- getPoolSize() - Method in class com.hazelcast.config.ExecutorConfig
-
Gets the number of executor threads per member for the executor.
- getPoolSize() - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Gets the number of executor threads per member for the executor.
- getPort() - Method in class com.hazelcast.cluster.Address
-
- getPort() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
-
- getPort() - Method in class com.hazelcast.config.NetworkConfig
-
Returns the port the Hazelcast member will try to bind on.
- getPort() - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
Returns the port the Hazelcast member will try to bind on.
- getPortableFactories() - Method in class com.hazelcast.config.SerializationConfig
-
- getPortableFactoryClasses() - Method in class com.hazelcast.config.SerializationConfig
-
- getPortableVersion() - Method in class com.hazelcast.config.SerializationConfig
-
Portable version will be used to differentiate two versions of the same class that have changes on the class,
like adding/removing a field or changing a type of a field.
- getPortCount() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
-
- getPortCount() - Method in class com.hazelcast.config.NetworkConfig
-
Returns the maximum number of ports allowed to try to bind on.
- getPortCount() - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
Returns the maximum number of ports allowed to try to bind on.
- getPosition() - Method in exception com.hazelcast.org.snakeyaml.engine.v2.exceptions.ReaderException
-
- 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.
- getPossibleSocketAddresses(int, String, int) - Static method in class com.hazelcast.client.util.AddressHelper
-
- getPredicateConfig() - Method in class com.hazelcast.config.QueryCacheConfig
-
Returns the predicate of QueryCache
.
- getPrefetchCount() - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
-
- getPrefetchCount() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
- getPrefetchValidityMillis() - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
-
- getPrefetchValidityMillis() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
- getPrefix(URI, ClassLoader) - Static method in class com.hazelcast.cache.CacheUtil
-
- getPrefix() - Method in class com.hazelcast.config.replacer.EncryptionReplacer
-
- getPrefix() - Method in class com.hazelcast.config.replacer.PropertyReplacer
-
- getPrefix() - Method in interface com.hazelcast.config.replacer.spi.ConfigReplacer
-
Variable replacer prefix string.
- getPrefixedCacheName(String, URI, ClassLoader) - Static method in class com.hazelcast.cache.CacheUtil
-
- 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
-
- getPrettyPrinter() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Accessor for checking whether this generator has a configured
PrettyPrinter
; returns it if so, null if none configured.
- getPrettyPrinter() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- 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
-
- getPriority() - Method in enum com.hazelcast.spi.discovery.DiscoveryStrategyFactory.DiscoveryStrategyLevel
-
- getPriorityComparatorClassName() - Method in class com.hazelcast.config.QueueConfig
-
Returns the class name that will be used to compare queue items.
- getPrivateAddress() - Method in class com.hazelcast.spi.discovery.DiscoveryNode
-
Returns the private address of the discovered node.
- getPrivateAddress() - Method in class com.hazelcast.spi.discovery.SimpleDiscoveryNode
-
- getProblem() - Method in exception com.hazelcast.org.snakeyaml.engine.v2.exceptions.MarkedYamlEngineException
-
- getProblemMark() - Method in exception com.hazelcast.org.snakeyaml.engine.v2.exceptions.MarkedYamlEngineException
-
- getProcessingGuarantee() - Method in class com.hazelcast.jet.config.JobConfig
-
- getProcessor() - Method in exception com.hazelcast.com.fasterxml.jackson.core.exc.StreamReadException
-
- getProcessor() - Method in exception com.hazelcast.com.fasterxml.jackson.core.JacksonException
-
Method that allows accessing underlying processor that triggered
this exception; typically either
JsonParser
or
JsonGenerator
for exceptions that originate from streaming API, but other abstractions
when thrown by databinding.
- getProcessor() - Method in exception com.hazelcast.com.fasterxml.jackson.core.JsonGenerationException
-
- getProcessor() - Method in exception com.hazelcast.com.fasterxml.jackson.core.JsonParseException
-
- getProcessor() - Method in exception com.hazelcast.com.fasterxml.jackson.core.JsonProcessingException
-
Method that allows accessing underlying processor that triggered
this exception; typically either
JsonParser
or
JsonGenerator
for exceptions that originate from streaming API.
- getProductName() - Method in enum com.hazelcast.config.InstanceTrackingConfig.InstanceProductName
-
Returns the string representation of the instance product name
- getProgress() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
-
- getProperties() - Method in class com.hazelcast.client.config.ClientConfig
-
- getProperties() - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
-
Gets all properties.
- getProperties() - Method in class com.hazelcast.config.AbstractWanPublisherConfig
-
Returns the WAN publisher properties.
- getProperties() - Method in class com.hazelcast.config.AbstractXmlConfigBuilder
-
Gets the current used properties.
- getProperties() - Method in class com.hazelcast.config.AbstractYamlConfigBuilder
-
Gets the current used properties.
- getProperties() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
-
Returns all properties.
- getProperties() - Method in class com.hazelcast.config.Config
-
Returns the properties set on this config instance.
- getProperties() - Method in class com.hazelcast.config.CredentialsFactoryConfig
-
- getProperties() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
-
- getProperties() - Method in class com.hazelcast.config.LoginModuleConfig
-
- getProperties() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns all the properties
- getProperties() - Method in class com.hazelcast.config.MemberAddressProviderConfig
-
- getProperties() - Method in class com.hazelcast.config.PermissionPolicyConfig
-
- getProperties() - Method in class com.hazelcast.config.QueueStoreConfig
-
Returns the properties to be used when instantiating the queue store.
- getProperties() - Method in class com.hazelcast.config.RingbufferStoreConfig
-
- getProperties() - Method in class com.hazelcast.config.ServiceConfig
-
- getProperties() - Method in class com.hazelcast.config.SocketInterceptorConfig
-
Gets all properties.
- getProperties() - Method in class com.hazelcast.config.WanConsumerConfig
-
Returns the properties for the custom WAN consumer.
- getProperties() - Method in class com.hazelcast.jet.config.JetConfig
-
Returns the Jet-specific configuration properties.
- getProperties() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
-
Returns an immutable copy of the configuration properties.
- getProperties() - Method in class com.hazelcast.spi.discovery.DiscoveryNode
-
Returns a set of unmodifiable properties that are assigned to the discovered node.
- getProperties() - Method in class com.hazelcast.spi.discovery.SimpleDiscoveryNode
-
- getProperty(String) - Method in class com.hazelcast.client.config.ClientConfig
-
Gets a named property already set or from system properties if not exists.
- getProperty(String) - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
-
Gets a property.
- getProperty(String) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
-
Returns property value by the property name.
- getProperty(String) - Method in class com.hazelcast.config.Config
-
Returns the value for a named property.
- getProperty(String) - Method in class com.hazelcast.config.MapStoreConfig
-
Returns the given property
- getProperty(String) - Method in class com.hazelcast.config.QueueStoreConfig
-
Returns the property with the given name
which is used when
instantiating and interacting with the queue store.
- getProperty(String) - Method in class com.hazelcast.config.RingbufferStoreConfig
-
- getProperty(String) - Method in class com.hazelcast.config.SocketInterceptorConfig
-
Gets a property.
- getProperty(String) - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.Node
-
Get the custom runtime property.
- getPropertyName() - Method in enum com.hazelcast.config.InstanceTrackingConfig.InstanceTrackingProperties
-
Returns the property name which can be used in placeholders to be resolved
to an actual property value.
- getProtectOn() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
-
- getProtocolType() - Method in class com.hazelcast.config.EndpointConfig
-
- getProtocolType() - Method in class com.hazelcast.config.RestServerEndpointConfig
-
- getProviderFilter() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Get current filter or null
when no filter is defined.
- getProviderMode() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Return the current ProviderMode
- getProxyFactoryConfigs() - Method in class com.hazelcast.client.config.ClientConfig
-
- 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(EndpointQualifier) - Method in interface com.hazelcast.instance.AddressPicker
-
Returns a public address to be advertised to other cluster members and clients.
- 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
-
- getPublicAddressMap() - Method in interface com.hazelcast.instance.AddressPicker
-
- getPublisherId() - Method in class com.hazelcast.config.AbstractWanPublisherConfig
-
- getPublisherId() - Method in class com.hazelcast.config.WanCustomPublisherConfig
-
- getPublishingMember() - Method in class com.hazelcast.topic.Message
-
Returns the member that published the message.
- getPublishOperationCount() - Method in interface com.hazelcast.topic.LocalTopicStats
-
Returns the total number of published messages of this topic on this member
- getPublishTime() - Method in class com.hazelcast.topic.Message
-
Return the time when the message is published
- getPutOperationCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the number of put operations
- getQualifier() - Method in class com.hazelcast.config.EndpointConfig
-
- getQualifier() - Method in class com.hazelcast.config.RestServerEndpointConfig
-
- getQueryCache(String) - Method in interface com.hazelcast.map.IMap
-
Returns corresponding QueryCache
instance for the supplied name
or null.
- getQueryCache(String, Predicate<K, V>, boolean) - Method in interface com.hazelcast.map.IMap
-
Creates an always up to date snapshot of this IMap
according to the supplied parameters.
- getQueryCache(String, MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.map.IMap
-
Creates an always up to date snapshot of this IMap
according to
the supplied parameters.
- getQueryCacheConfigs() - Method in class com.hazelcast.client.config.ClientConfig
-
- getQueryCacheConfigs() - Method in class com.hazelcast.config.MapConfig
-
- getQueryCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the total number of queries performed on the map.
- getQueryCount() - Method in interface com.hazelcast.query.LocalIndexStats
-
Returns the total number of queries served by the index.
- getQueue() - Method in class com.hazelcast.client.console.ClientConsoleApp
-
- 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 interface com.hazelcast.transaction.TransactionalTaskContext
-
Returns the transactional queue instance with the specified name.
- getQueueCapacity() - Method in class com.hazelcast.config.ExecutorConfig
-
Gets the queue capacity of the executor task.
- getQueueCapacity() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the capacity of the primary and backup queue for WAN replication events.
- getQueueConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the QueueConfig for the given name, creating one
if necessary and adding it to the collection of known configurations.
- getQueueConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of
IQueue
configurations,
mapped by config name.
- getQueueFullBehavior() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the configured behaviour of this WAN publisher when the WAN queue
is full.
- 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
-
Returns the hit/miss ratio of Near Cache entries owned by this member.
- getRawClass() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
-
Accessor for type-erased
Class
of resolved type.
- getRawDataInput() - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- getRawDataOutput() - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
After writing portable fields one can subsequently write remaining fields in the old-fashioned way.
- getRawKey() - Method in interface com.hazelcast.spi.merge.MergingEntry
-
Returns the merging key in the in-memory format of the backing data structure.
- getRawPayload() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.RequestPayload
-
Returns the raw request payload object i.e, either byte[] or String
- 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.
- getReadCapabilities() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- getReadCapabilities() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- getReadCapabilities() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- getReadCapabilities() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- getReadCapabilities() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Accessor for getting metadata on capabilities of this parser, based on
underlying data format being read (directly or indirectly).
- getReadCapabilities() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getRealm() - Method in class com.hazelcast.config.security.KerberosIdentityConfig
-
- getRealmConfig(String) - Method in class com.hazelcast.client.config.ClientSecurityConfig
-
- getRealmConfig(String) - Method in class com.hazelcast.config.SecurityConfig
-
- getRealmConfig() - Method in class com.hazelcast.security.RealmConfigCallback
-
- getRealmConfigs() - Method in class com.hazelcast.client.config.ClientSecurityConfig
-
- getRealmConfigs() - Method in class com.hazelcast.config.SecurityConfig
-
- getRealmCredentialsFactory(String) - Method in class com.hazelcast.config.SecurityConfig
-
- getRealmLoginModuleConfigs(String) - Method in class com.hazelcast.config.SecurityConfig
-
- getRealmName() - Method in class com.hazelcast.security.RealmConfigCallback
-
- getRealNode() - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.AnchorNode
-
- 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
-
- getReferencedType() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
-
Method for accessing type of value that instances of this
type references, if any.
- 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
-
Returns a distributed reliable topic instance with the specified name.
- getReliableTopicConfig(String) - Method in class com.hazelcast.client.config.ClientConfig
-
Gets the ClientReliableTopicConfig for a given reliable topic name.
- getReliableTopicConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the ReliableTopicConfig for the given name, creating one
if necessary and adding it to the collection of known configurations.
- getReliableTopicConfigMap() - Method in class com.hazelcast.client.config.ClientConfig
-
Returns the map of reliable topic configurations,
mapped by config name.
- getReliableTopicConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of reliable topic configurations, mapped by config name.
- getRemainingMigrations() - Method in interface com.hazelcast.partition.MigrationState
-
Returns the number of remaining migrations in the migration plan.
- getRemoveCount() - Method in interface com.hazelcast.query.LocalIndexStats
-
Returns the number of remove operations performed on the index.
- getRemoveCount() - Method in class com.hazelcast.wan.WanEventCounters.DistributedObjectWanEventCounters
-
Returns the number of entry remove events
- getRemoveOperationCount() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the number of Remove operations
- getReplacement(String) - Method in class com.hazelcast.config.replacer.AbstractPbeReplacer
-
- getReplacement(String) - Method in class com.hazelcast.config.replacer.PropertyReplacer
-
- getReplacement(String) - Method in interface com.hazelcast.config.replacer.spi.ConfigReplacer
-
Provides String which should be used as a variable replacement for given masked value.
- getReplicaCount() - Method in class com.hazelcast.config.PNCounterConfig
-
Returns the number of replicas on which state for this PN counter will
be kept.
- getReplicaIndex() - Method in interface com.hazelcast.partition.ReplicaMigrationEvent
-
Returns the index of the partition replica.
- getReplicatedMap(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates or returns the replicated map instance with the specified name.
- getReplicatedMap(String) - Method in interface com.hazelcast.jet.JetInstance
-
Returns the replicated map instance with the specified name.
- getReplicatedMapConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the ReplicatedMapConfig for the given name, creating one
if necessary and adding it to the collection of known configurations.
- getReplicatedMapConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of
ReplicatedMap
configurations, mapped by config name.
- getReplicatedMapStats() - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
-
Returns LocalReplicatedMapStats for this replicated map.
- getReplicationPeriodMillis() - Method in class com.hazelcast.config.CRDTReplicationConfig
-
Returns the period between two replications of CRDT states in
milliseconds.
- getRepresentation() - Method in class com.hazelcast.org.snakeyaml.engine.v2.common.SpecVersion
-
- getRequestPayload() - Method in exception com.hazelcast.com.fasterxml.jackson.core.exc.StreamReadException
-
Method that may be called to find payload that was being parsed, if
one was specified for parser that threw this Exception.
- getRequestPayload() - Method in exception com.hazelcast.com.fasterxml.jackson.core.JsonParseException
-
- getRequestPayloadAsString() - Method in exception com.hazelcast.com.fasterxml.jackson.core.exc.StreamReadException
-
The method returns the String representation of the request payload if
one was specified for parser that threw this Exception.
- getRequestPayloadAsString() - Method in exception com.hazelcast.com.fasterxml.jackson.core.JsonParseException
-
- getRequiredMember() - Method in class com.hazelcast.config.TcpIpConfig
-
Gets the required member.
- getResourceConfigs() - Method in class com.hazelcast.jet.config.JobConfig
-
Returns all the registered resource configurations.
- getResourceType() - Method in class com.hazelcast.jet.config.ResourceConfig
-
Returns the type of the resource.
- getResponseTimeoutMillis() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the duration in milliseconds for the wait time before retrying to
send the events to target cluster again in case the acknowledgement
has not arrived.
- getRestApiConfig() - Method in class com.hazelcast.config.NetworkConfig
-
- getRestEndpointConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig
-
- getRetentionSeconds() - Method in class com.hazelcast.config.MetricsManagementCenterConfig
-
Returns the number of seconds the metrics will be retained on the
instance.
- getRevision() - Method in class com.hazelcast.instance.BuildInfo
-
- getRevision() - Method in class com.hazelcast.instance.JetBuildInfo
-
- getRingbuffer(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates or returns the distributed Ringbuffer instance with the specified name.
- getRingbufferConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the RingbufferConfig for the given name, creating one
if necessary and adding it to the collection of known configurations.
- getRingbufferConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of
Ringbuffer
configurations, mapped by config name.
- getRingbufferStoreConfig() - Method in class com.hazelcast.config.RingbufferConfig
-
Get the RingbufferStore (load and store ringbuffer items from/to a database)
configuration.
- getRoleAttribute() - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
-
- getRoleContext() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- getRoleFilter() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- getRoleMappingAttribute() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- getRoleMappingMode() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- getRoleMappingMode(String) - Static method in enum com.hazelcast.config.security.LdapRoleMappingMode
-
- getRoleNameAttribute() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- getRoleRecursionMaxDepth() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- getRoleSearchScope() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- getRootValueSeparator() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- getRoutingPolicy() - Method in class com.hazelcast.jet.core.Edge
-
- getRowMetadata() - Method in interface com.hazelcast.sql.SqlResult
-
Gets the row metadata.
- getSalt() - Method in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
-
Returns the salt.
- getScalar() - Method in class com.hazelcast.org.snakeyaml.engine.v2.emitter.ScalarAnalysis
-
- getScalarResolver() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettings
-
- getScalarResolver() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettings
-
- getScalarStyle() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.ScalarEvent
-
Style of the scalar.
- getScalarStyle() - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.ScalarNode
-
Get scalar style of this node.
- getScaleUpDelayMillis() - Method in class com.hazelcast.jet.config.InstanceConfig
-
- 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
-
- getScheduledFuture(ScheduledTaskHandler) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
-
- 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.com.fasterxml.jackson.core.JsonGenerator
-
Method for accessing Schema that this generator uses, if any; null
if none.
- getSchema() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method for accessing Schema that this parser uses, if any.
- getSchema() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- getSchema() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getSchema() - Method in class com.hazelcast.sql.SqlStatement
-
Gets the schema name.
- getSchemaType() - Method in interface com.hazelcast.com.fasterxml.jackson.core.FormatSchema
-
Method that can be used to get an identifier that can be used for diagnostics
purposes, to indicate what kind of data format this schema is used for: typically
it is a short name of format itself, but it can also contain additional information
in cases where data format supports multiple types of schemas.
- getScopedHost() - Method in class com.hazelcast.cluster.Address
-
- getScopedHostName(AddressUtil.AddressHolder) - Static method in class com.hazelcast.client.util.AddressHelper
-
- getScopeId() - Method in class com.hazelcast.cluster.Address
-
- getSearchScope(String) - Static method in enum com.hazelcast.config.security.LdapSearchScope
-
- getSeconds(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
- 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
-
- getSecurityConfig() - Method in class com.hazelcast.config.Config
-
Returns the security configuration for this hazelcast instance.
- getSecurityInterceptorConfigs() - Method in class com.hazelcast.config.SecurityConfig
-
- getSecurityRealm() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
-
- getSecurityRealm() - Method in class com.hazelcast.config.security.KerberosIdentityConfig
-
- getSecurityRealm() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- getSemaphore(String) - Method in interface com.hazelcast.cp.CPSubsystem
-
Returns a proxy for an
ISemaphore
instance created on CP
Subsystem.
- getSemaphoreConfigs() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
- getSequence(int) - Method in interface com.hazelcast.ringbuffer.ReadResultSet
-
Return the sequence number for the item at the given index.
- getSerializationConfig() - Method in class com.hazelcast.client.config.ClientConfig
-
- getSerializationConfig() - Method in class com.hazelcast.config.Config
-
Returns the serialization configuration for this hazelcast instance.
- getSerializationType() - Method in interface com.hazelcast.nio.serialization.SerializerHook
-
Returns the actual class type of the serialized object
- getSerializationVersion() - Method in class com.hazelcast.instance.BuildInfo
-
- getSerializerConfigs() - Method in class com.hazelcast.config.SerializationConfig
-
- getSerializerConfigs() - Method in class com.hazelcast.jet.config.JobConfig
-
Returns all the registered serializer configurations.
- getServerSocketCardinality() - Method in enum com.hazelcast.instance.ProtocolType
-
- getServerSocketChannel(EndpointQualifier) - Method in interface com.hazelcast.instance.AddressPicker
-
Returns a server channel.
- getServerSocketChannels() - Method in interface com.hazelcast.instance.AddressPicker
-
- 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.client.console.ClientConsoleApp
-
- 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 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
- getShort(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getShortArray(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getShortValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getShortValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Numeric accessor that can be called when the current
token is of type
JsonToken.VALUE_NUMBER_INT
and
it can be expressed as a value of Java short primitive type.
- getShortValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getSingleNode() - Method in class com.hazelcast.org.snakeyaml.engine.v2.composer.Composer
-
Reads a document from a source that contains only one document.
- getSingleType() - Method in enum com.hazelcast.nio.serialization.FieldType
-
- getSize() - Method in class com.hazelcast.config.EvictionConfig
-
- getSize() - Method in class com.hazelcast.config.NativeMemoryConfig
-
Returns size of the native memory region.
- getSkipAuthentication() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- getSkipEndpoint() - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
-
- getSkipIdentity() - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
-
- getSkipRole() - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
-
- getSnapshotIntervalMillis() - Method in class com.hazelcast.jet.config.JobConfig
-
- 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.
- getSocketAddresses(String) - Static method in class com.hazelcast.client.util.AddressHelper
-
- getSocketConnectTimeoutSeconds() - Method in class com.hazelcast.config.EndpointConfig
-
- getSocketFactoryClassName() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- getSocketInterceptorConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
- getSocketInterceptorConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
-
- getSocketInterceptorConfig() - Method in class com.hazelcast.config.EndpointConfig
-
- getSocketInterceptorConfig() - Method in class com.hazelcast.config.NetworkConfig
-
- getSocketLingerSeconds() - Method in class com.hazelcast.config.EndpointConfig
-
- getSocketOptions() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
- getSocketRcvBufferSizeKb() - Method in class com.hazelcast.config.EndpointConfig
-
- getSocketSendBufferSizeKb() - Method in class com.hazelcast.config.EndpointConfig
-
- getSource() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.DupDetector
-
- 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.
- getSourceRef() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonLocation
-
Reference to the original resource being read, if one available.
- getSourceReference() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
- getSpecVersion() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.DocumentStartEvent
-
- getSpecVersion() - Method in exception com.hazelcast.org.snakeyaml.engine.v2.exceptions.YamlVersionException
-
- getSplitBrainProtection(String) - Method in interface com.hazelcast.splitbrainprotection.SplitBrainProtectionService
-
- getSplitBrainProtectionConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the
SplitBrainProtectionConfig
for the given name, creating one
if necessary and adding it to the collection of known configurations.
- getSplitBrainProtectionConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of split brain protection configurations, mapped by
config name.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.CacheConfig
-
Gets the name of the associated split brain protection if any.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the name of the associated split brain protection if any.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
Returns the split brain protection name for operations.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.CollectionConfig
-
Returns the split brain protection name for operations.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.DurableExecutorConfig
-
Returns the split brain protection name for operations.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.ExecutorConfig
-
Returns the split brain protection name for operations.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.MapConfig
-
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.MultiMapConfig
-
Returns the split brain protection name for operations.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.PNCounterConfig
-
Returns the split brain protection name for operations.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.QueueConfig
-
Returns the split brain protection name for queue operations.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
Returns the split brain protection name for operations.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.RingbufferConfig
-
Returns the split brain protection name for operations.
- getSplitBrainProtectionName() - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Returns the split brain protection name for operations.
- getSplitBrainProtectionService() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the split brain protection service of this Hazelcast instance.
- getSpn() - Method in class com.hazelcast.config.security.KerberosIdentityConfig
-
- getSql() - Method in class com.hazelcast.config.PredicateConfig
-
Returns sql string for this config.
- getSql() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns a service to execute distributed SQL queries.
- getSql() - Method in interface com.hazelcast.jet.JetInstance
-
Returns the Hazelcast SQL service.
- getSql() - Method in class com.hazelcast.sql.SqlStatement
-
Gets the SQL string to be executed.
- getSqlConfig() - Method in class com.hazelcast.config.Config
-
- getSSLConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
- getSSLConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
-
- getSSLConfig() - Method in class com.hazelcast.config.EndpointConfig
-
- getSSLConfig() - Method in class com.hazelcast.config.NetworkConfig
-
- getSSLConfig() - Method in class com.hazelcast.config.VaultSecureStoreConfig
-
Returns the SSL/TLS configuration.
- getSSLContext() - Method in class com.hazelcast.nio.ssl.BasicSSLContextFactory
-
- getSSLContext() - Method in interface com.hazelcast.nio.ssl.SSLContextFactory
-
- getStartedTaskCount() - Method in interface com.hazelcast.executor.LocalExecutorStats
-
Returns the number of started operations on the executor service.
- getStartLocation(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
-
- getStartLocation(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
-
Optional method that may be used to access starting location of this context:
for example, in case of JSON `Object` context, offset at which `[` token was
read or written.
- getStartMark() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.Event
-
- getStartMark() - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.Node
-
- getStartMark() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.Token
-
- getStartTime() - Method in interface com.hazelcast.partition.MigrationState
-
Returns the start time of the migration in milliseconds since the epoch.
- getState() - Method in class com.hazelcast.core.LifecycleEvent
-
- getState() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
-
- getStatementTimeoutMillis() - Method in class com.hazelcast.config.SqlConfig
-
Gets the timeout in milliseconds that is applied to statements without an explicit timeout.
- getStats() - Method in interface com.hazelcast.scheduledexecutor.IScheduledFuture
-
Returns the statistics and time measurement info of the execution of this scheduled future in the
IScheduledExecutorService
it was scheduled.
- 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(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getString(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
-
- getStringArray(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getStyle() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.ScalarToken
-
- getSubmissionTime() - Method in interface com.hazelcast.jet.Job
-
Returns the time when the job was submitted to the cluster.
- getSuffix() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.TagTuple
-
- getSuspensionCause() - Method in interface com.hazelcast.jet.Job
-
- getSymmetricEncryptionConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
-
- getSymmetricEncryptionConfig() - Method in class com.hazelcast.config.EndpointConfig
-
- getSymmetricEncryptionConfig() - Method in class com.hazelcast.config.NetworkConfig
-
- getSyncConfig() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns the config for the WAN sync mechanism.
- getSyncCount() - Method in class com.hazelcast.wan.WanEventCounters.DistributedObjectWanEventCounters
-
Returns the number of entry sync events
- getSystemAuthentication() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- getSystemProperty() - Method in class com.hazelcast.spi.properties.HazelcastProperty
-
Gets the system property value of the property.
- getSystemUserDn() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- getSystemUserPassword() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- getTag() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
-
- getTag() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.CollectionStartEvent
-
Tag of this collection.
- getTag() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.ScalarEvent
-
Tag of this scalar.
- getTag() - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.Node
-
Tag of this node.
- getTag(Class<?>, Tag) - Method in class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter
-
- getTagConstructors() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettings
-
- getTagDirective() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettings
-
- getTags() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Returns the metadata on this supplier, a string-to-string map.
- getTags() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.DocumentStartEvent
-
Tag shorthands as defined by the %TAG
directive.
- getTailSequence() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
-
Returns the sequence of the tail.
- getTarget() - Method in interface com.hazelcast.query.PartitionPredicate
-
- 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.
- getTargetType() - Method in exception com.hazelcast.com.fasterxml.jackson.core.exc.InputCoercionException
-
Accessor for getting information about target type (in form of Java
Class
)
for which coercion failed.
- 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.
- getText() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- getText() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getText() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
Method for accessing textual representation of the current event;
if no current event (before first call to
ParserMinimalBase.nextToken()
, or
after encountering end-of-input), returns null.
- getText(Writer) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- getText() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
Method for accessing textual representation of the current event;
if no current event (before first call to
ReaderBasedJsonParser.nextToken()
, or
after encountering end-of-input), returns null.
- getText(Writer) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- getText() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- getText(Writer) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- getText() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- getText(Writer) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- getText() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method for accessing textual representation of the current token;
if no current token (before first call to
JsonParser.nextToken()
, or
after encountering end-of-input), returns null.
- getText(Writer) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method to read the textual representation of the current token in chunks and
pass it to the given Writer.
- getText() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getText(Writer) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getTextBuffer() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
Accessor that may be used to get the contents of this buffer as a single
char[]
regardless of whether they were collected in a segmented
fashion or not: this typically require allocation of the result buffer.
- getTextCharacters() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- getTextCharacters() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getTextCharacters() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- getTextCharacters() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- getTextCharacters() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- getTextCharacters() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- getTextCharacters() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method similar to
JsonParser.getText()
, but that will return
underlying (unmodifiable) character array that contains
textual value, instead of constructing a String object
to contain this information.
- getTextCharacters() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getTextLength() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- getTextLength() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getTextLength() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- getTextLength() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- getTextLength() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- getTextLength() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- getTextLength() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- getTextLength() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getTextOffset() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- getTextOffset() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getTextOffset() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- getTextOffset() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- getTextOffset() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- getTextOffset() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- getTextOffset() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- getTextOffset() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getTextOffset() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
- getThreshold() - Method in class com.hazelcast.splitbrainprotection.SplitBrainProtectionEvent
-
Returns the predefined split brain protection threshold
- getTime(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getTimeArray(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getTimedExpiryPolicyFactoryConfig() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
-
- getTimeoutMillis() - Method in class com.hazelcast.sql.SqlStatement
-
Gets the execution timeout in milliseconds.
- getTimeoutMillis() - Method in class com.hazelcast.transaction.TransactionOptions
-
Gets the timeout in milliseconds.
- getTimeoutMilliseconds() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
-
- getTimeoutMilliseconds() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
-
- getTimestamp() - Method in interface com.hazelcast.auditlog.AuditableEvent
-
Returns event timestamp as milliseconds from the epoch.
- getTimestamp(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getTimestampArray(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getTimestampWithTimezone(String) - Method in interface com.hazelcast.nio.serialization.GenericRecord
-
- getTimestampWithTimezoneArray(String) - Method in interface com.hazelcast.nio.serialization.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
-
- 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.
- getTokenBeingDecoded() - Method in exception com.hazelcast.com.fasterxml.jackson.core.io.JsonEOFException
-
Accessor for possibly available information about token that was being
decoded while encountering end of input.
- getTokenCharacterOffset() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- getTokenColumnNr() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- getTokenEncoded() - Method in class com.hazelcast.config.security.TokenIdentityConfig
-
- getTokenEncoding(String) - Static method in enum com.hazelcast.config.security.TokenEncoding
-
- getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.AliasToken
-
- getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.AnchorToken
-
- getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.BlockEndToken
-
- getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.BlockEntryToken
-
- getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.BlockMappingStartToken
-
- getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.BlockSequenceStartToken
-
- getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.DirectiveToken
-
- getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.DocumentEndToken
-
- getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.DocumentStartToken
-
- getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.FlowEntryToken
-
- getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.FlowMappingEndToken
-
- getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.FlowMappingStartToken
-
- getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.FlowSequenceEndToken
-
- getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.FlowSequenceStartToken
-
- getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.KeyToken
-
- getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.ScalarToken
-
- getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.StreamEndToken
-
- getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.StreamStartToken
-
- getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.TagToken
-
- getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.Token
-
For error reporting.
- getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.ValueToken
-
- getTokenIdentityConfig() - Method in class com.hazelcast.client.config.ClientSecurityConfig
-
- getTokenIdentityConfig() - Method in class com.hazelcast.config.security.RealmConfig
-
- getTokenLineNr() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- getTokenLocation() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Method that return the starting location of the current
token; that is, position of the first character from input
that starts the current token.
- getTokenLocation() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getTokenLocation() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- getTokenLocation() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- getTokenLocation() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- getTokenLocation() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- getTokenLocation() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method that return the starting location of the current
token; that is, position of the first character from input
that starts the current token.
- getTokenLocation() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getTopic() - Method in class com.hazelcast.client.console.ClientConsoleApp
-
- getTopic() - Method in class com.hazelcast.console.ConsoleApp
-
- getTopic(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates or returns the distributed topic instance with the specified name.
- getTopicConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the TopicConfig for the given name, creating one
if necessary and adding it to the collection of known configurations.
- getTopicConfigs() - Method in class com.hazelcast.config.Config
-
Returns the map of reliable topic configurations, mapped by config name.
- getTopicOverloadPolicy() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
-
Gets the TopicOverloadPolicy for this reliable topic.
- getTopicOverloadPolicy() - Method in class com.hazelcast.config.ReliableTopicConfig
-
Gets the TopicOverloadPolicy for this reliable topic.
- getTotal() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
-
- getTotalBackupCount() - Method in class com.hazelcast.config.CacheConfig
-
Gets the total backup count (backupCount + asyncBackupCount
) of the cache.
- getTotalBackupCount() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
Returns the total number of backups: backupCount plus asyncBackupCount.
- getTotalBackupCount() - Method in class com.hazelcast.config.CollectionConfig
-
Gets the total number of synchronous and asynchronous backups for this collection.
- getTotalBackupCount() - Method in class com.hazelcast.config.MapConfig
-
Returns the total number of backups: backupCount plus asyncBackupCount.
- getTotalBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
-
Gets the total number of backups (synchronous + asynchronous) for this MultiMap.
- getTotalBackupCount() - Method in class com.hazelcast.config.QueueConfig
-
Get the total number of backups: the backup count plus the asynchronous backup count.
- getTotalBackupCount() - Method in class com.hazelcast.config.RingbufferConfig
-
Returns the total number of backups: backupCount plus asyncBackupCount.
- getTotalElapsedTime() - Method in interface com.hazelcast.partition.MigrationState
-
Returns the total elapsed time of completed migrations in milliseconds.
- getTotalExecutionLatency() - Method in interface com.hazelcast.executor.LocalExecutorStats
-
Returns the total execution time of operations finished.
- getTotalGetLatency() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the total latency of get operations.
- getTotalIdleTime(TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.ScheduledTaskStatistics
-
Returns the total amount of time the task was idle, waiting to get scheduled in.
- getTotalInsertLatency() - Method in interface com.hazelcast.query.LocalIndexStats
-
Returns the total latency (in nanoseconds) of insert operations performed
on the index.
- getTotalPutLatency() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the total latency of put operations.
- getTotalRemoveLatency() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the total latency of remove operations.
- getTotalRemoveLatency() - Method in interface com.hazelcast.query.LocalIndexStats
-
Returns the total latency (in nanoseconds) of remove operations performed
on the index.
- getTotalRuns() - Method in interface com.hazelcast.scheduledexecutor.ScheduledTaskStatistics
-
Returns how many times the task was ran/called.
- getTotalRunTime(TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.ScheduledTaskStatistics
-
Returns the total amount of time the task spent while scheduled in.
- getTotalSetLatency() - Method in interface com.hazelcast.map.LocalMapStats
-
Returns the total latency of set operations.
- getTotalStartLatency() - Method in interface com.hazelcast.executor.LocalExecutorStats
-
Returns the total start latency of operations started.
- getTotalUpdateLatency() - Method in interface com.hazelcast.query.LocalIndexStats
-
Returns the total latency (in nanoseconds) of update operations performed
on the index.
- getTransactionalObject(String, String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
-
Returns the transactional object instance with the specified name and service name.
- getTransactionContext() - Method in interface com.hazelcast.transaction.HazelcastXAResource
-
Returns the TransactionContext associated with the current thread.
- getTransactionType() - Method in class com.hazelcast.transaction.TransactionOptions
-
- getTrustedInterfaces() - Method in class com.hazelcast.config.ManagementCenterConfig
-
Gets the trusted interfaces.
- getTrustedInterfaces() - Method in class com.hazelcast.config.MulticastConfig
-
Gets the trusted interfaces.
- getTrustedInterfaces() - Method in interface com.hazelcast.config.TrustedInterfacesConfigurable
-
Gets the trusted interfaces.
- getTryCount() - Method in class com.hazelcast.client.config.ClientFailoverConfig
-
Returns the count of attempts to connect to a cluster.
- getTtl() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
-
- getTtl() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
-
- getTtl() - Method in interface com.hazelcast.core.EntryView
-
Returns the last set time to live in milliseconds.
- getTtl() - Method in interface com.hazelcast.spi.merge.MergingTTL
-
Returns the TTL of the merge data.
- getTxnId() - Method in interface com.hazelcast.transaction.TransactionContext
-
Gets the ID that uniquely identifies the transaction.
- getType() - Method in enum com.hazelcast.cache.CacheEventType
-
- getType() - Method in interface com.hazelcast.cache.EventJournalCacheEvent
-
Returns the event type.
- getType() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.TypeReference
-
- getType() - Method in class com.hazelcast.config.IndexConfig
-
Gets type of the index.
- getType() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
-
Returns the type of the Java KeyStore.
- getType() - Method in class com.hazelcast.config.PermissionConfig
-
- getType(String) - Static method in enum com.hazelcast.config.PermissionConfig.PermissionType
-
- getType() - Method in enum com.hazelcast.core.EntryEventType
-
- getType() - Method in enum com.hazelcast.core.ItemEventType
-
- getType() - Method in interface com.hazelcast.cp.event.CPMembershipEvent
-
Returns the type of membership change.
- getType() - Method in class com.hazelcast.instance.EndpointQualifier
-
- getType() - Method in interface com.hazelcast.map.EventJournalMapEvent
-
Returns the event type.
- getType() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
-
- getType() - Method in class com.hazelcast.sql.SqlColumnMetadata
-
Gets column type.
- getTypeClass() - Method in class com.hazelcast.config.SerializerConfig
-
Gets the type of the class that will be serialized via this implementation.
- getTypeClassName() - Method in class com.hazelcast.config.SerializerConfig
-
Gets the name of the class that will be serialized via this implementation.
- getTypeDesc() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
-
- getTypeId() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method that can be called to check whether current token
(one that was just read) has an associated type id, and if
so, return it.
- getTypeId() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getTypeId() - Method in interface com.hazelcast.nio.serialization.Serializer
-
Uniquely identifies given serializer.
- getTypeSize() - Method in enum com.hazelcast.nio.serialization.FieldType
-
- getUnavailableMembers() - Method in interface com.hazelcast.cp.event.CPGroupAvailabilityEvent
-
Returns the unavailable members of the CP group.
- getUncommittedEntryCountToRejectNewAppends() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
-
- getUniqueKey() - Method in class com.hazelcast.config.BitmapIndexOptions
-
Returns the unique key attribute configured in this index config.
- getUniqueKeyTransformation() - Method in class com.hazelcast.config.BitmapIndexOptions
-
Returns the unique key transformation configured in this index.
- getUnit() - Method in class com.hazelcast.memory.MemorySize
-
Returns unit of memory size
- getUpdateCount() - Method in interface com.hazelcast.query.LocalIndexStats
-
Returns the number of update operations performed on the index.
- getUpdateCount() - Method in class com.hazelcast.wan.WanEventCounters.DistributedObjectWanEventCounters
-
Returns the number of entry update events
- getUpstreamBuildInfo() - Method in class com.hazelcast.instance.BuildInfo
-
- 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
-
- getUseMarks() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettings
-
- getUseNameWithoutRealm() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
-
- getUserCodeDeploymentConfig() - Method in class com.hazelcast.client.config.ClientConfig
-
Get current configuration of User Code Deployment.
- getUserCodeDeploymentConfig() - Method in class com.hazelcast.config.Config
-
Get current configuration of User Code Deployment.
- getUserContext() - Method in class com.hazelcast.client.config.ClientConfig
-
- getUserContext() - Method in class com.hazelcast.config.Config
-
Returns the user supplied context.
- getUserContext() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- getUserContext() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns a ConcurrentMap that can be used to add user-context to the HazelcastInstance.
- getUserFilter() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- getUsername() - Method in class com.hazelcast.config.security.UsernamePasswordIdentityConfig
-
- getUserNameAttribute() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- getUsernamePasswordIdentityConfig() - Method in class com.hazelcast.client.config.ClientSecurityConfig
-
- getUsernamePasswordIdentityConfig() - Method in class com.hazelcast.config.security.RealmConfig
-
- getUserSearchScope() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- getUuid() - Method in interface com.hazelcast.client.Client
-
Returns a unique UUID for this client.
- getUuid() - Method in interface com.hazelcast.cluster.Endpoint
-
Returns the UUID of this endpoint
- getUuid() - Method in interface com.hazelcast.cluster.Member
-
Returns the UUID of this member.
- getUuid() - Method in interface com.hazelcast.cp.CPMember
-
Returns the UUID of this CP member.
- getUuid() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
-
Returns the uuid of the member the task is associated with.
- getValidationTimeoutSeconds() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Returns configured validation timeout for hot-restart process.
- getValue() - Method in interface com.hazelcast.cache.CacheEntryView
-
Gets the value of the cache entry.
- getValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SerializedString
-
- getValue() - Method in interface com.hazelcast.com.fasterxml.jackson.core.SerializableString
-
Returns unquoted String that this object represents (and offers
serialized forms for)
- 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.jet.datamodel.KeyedWindowResult
-
- 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.MemorySize
-
Returns value of memory size in its original unit.
- getValue() - Method in class com.hazelcast.org.snakeyaml.engine.v2.common.Anchor
-
- getValue() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.ScalarEvent
-
String representation of the value.
- getValue() - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.CollectionNode
-
Returns the elements in this sequence.
- getValue() - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.MappingNode
-
Returns the entries of this map.
- getValue() - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.ScalarNode
-
Value of this scalar.
- getValue() - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.SequenceNode
-
Returns the elements in this sequence.
- getValue() - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.Tag
-
- getValue() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.AliasToken
-
- getValue() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.AnchorToken
-
- getValue() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.DirectiveToken
-
- getValue() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.ScalarToken
-
- getValue() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.TagToken
-
- getValue() - Method in interface com.hazelcast.spi.eviction.EvictableEntryView
-
Gets the value of the entry.
- getValue() - Method in interface com.hazelcast.spi.merge.MergingValue
-
Returns the deserialized merging value.
- getValueAsBoolean(boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- getValueAsBoolean() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getValueAsBoolean(boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getValueAsBoolean() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method that will try to convert value of current token to a
boolean.
- getValueAsBoolean(boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method that will try to convert value of current token to a
boolean.
- getValueAsBoolean() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getValueAsBoolean(boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getValueAsDouble(double) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- getValueAsDouble() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getValueAsDouble(double) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getValueAsDouble() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method that will try to convert value of current token to a Java
double.
- getValueAsDouble(double) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method that will try to convert value of current token to a
Java double.
- getValueAsDouble() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getValueAsDouble(double) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getValueAsInt() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- getValueAsInt(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- getValueAsInt() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getValueAsInt(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getValueAsInt() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- getValueAsInt(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- getValueAsInt() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- getValueAsInt(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- getValueAsInt() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method that will try to convert value of current token to a
Java int
value.
- getValueAsInt(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method that will try to convert value of current token to a
int.
- getValueAsInt() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getValueAsInt(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getValueAsLong() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- getValueAsLong(long) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- getValueAsLong() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getValueAsLong(long) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getValueAsLong() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method that will try to convert value of current token to a
long.
- getValueAsLong(long) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method that will try to convert value of current token to a
long.
- getValueAsLong() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getValueAsLong(long) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getValueAsString() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- getValueAsString(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- getValueAsString() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getValueAsString(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- getValueAsString() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- getValueAsString(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- getValueAsString() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- getValueAsString(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- getValueAsString() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- getValueAsString(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- getValueAsString() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- getValueAsString(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- getValueAsString() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method that will try to convert value of current token to a
String
.
- getValueAsString(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method that will try to convert value of current token to a
String
.
- getValueAsString() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getValueAsString(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- getValueClass() - Method in enum com.hazelcast.sql.SqlColumnType
-
Gets the Java class of the value of this SQL type.
- getValueClassName() - Method in class com.hazelcast.config.AbstractCacheConfig
-
- getValueCollectionType() - Method in class com.hazelcast.config.MultiMapConfig
-
Gets the collection type for the values of this MultiMap.
- getValueFor(String, String, String, String) - Method in interface com.hazelcast.org.snakeyaml.engine.v2.env.EnvConfig
-
Implement deviation from the standard logic.
- getValueNode() - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.NodeTuple
-
Value node.
- getValueType() - Method in class com.hazelcast.config.AbstractCacheConfig
-
- getValueType() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Gets the value type for this
ICache
.
- getVersion() - Method in interface com.hazelcast.cluster.Member
-
Returns the Hazelcast codebase version of this member; this may or may not be different from the version reported by
Cluster.getClusterVersion()
, for example when a node with a different codebase version is added to an
existing cluster.
- getVersion() - Method in interface com.hazelcast.core.EntryView
-
Returns the version of the entry.
- getVersion() - Method in class com.hazelcast.instance.BuildInfo
-
- getVersion() - Method in class com.hazelcast.instance.JetBuildInfo
-
- getVersion() - Method in class com.hazelcast.jet.server.JetCommandLine.JetVersionProvider
-
- getVersion() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
Returns the version.
- getVersion() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- getVersion() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
-
- getVersion() - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- getVersion() - Method in interface com.hazelcast.nio.VersionAware
-
- getVersion() - Method in interface com.hazelcast.spi.merge.MergingVersion
-
Returns the version of the merge data.
- getVersionFunction() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettings
-
- 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
-
Return currently configured whitelist prefixes
- getWidth() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettings
-
- getWriteBatchSize() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns the number of operations to be included in each batch processing round.
- getWriteCapabilities() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonGeneratorImpl
-
- getWriteCapabilities() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Accessor for getting metadata on capabilities of this generator, based on
underlying data format being read (directly or indirectly).
- getWriteCapabilities() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- getWriteDelaySeconds() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns the number of seconds to delay the store writes.
- getXAResource() - Method in interface com.hazelcast.core.HazelcastInstance
-
Gets xaResource which will participate in XATransaction.
- getYamlDirective() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettings
-
- gigaBytes() - Method in class com.hazelcast.memory.MemorySize
-
Returns value of memory size in giga-bytes.
- 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
-
- 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 given value
.
- greaterThan(Comparable) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
-
- greaterThan(String, Comparable) - Static method in class com.hazelcast.query.Predicates
-
Creates a greater than predicate that will pass items if the value stored under the given
item attribute
is greater than the given value
.
- GROUP - Static variable in class com.hazelcast.spi.discovery.multicast.MulticastProperties
-
Property used to define zones for node filtering.
- 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.
- 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 applying keyFn
and the value is a list of 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 applying keyFn
and the value is the result of applying the downstream aggregate
operation to 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 a
Map
(as obtained from createMapFn
) where the key is the
result of applying keyFn
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
-
- growArrayBy(int[], int) - Static method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- IAtomicLong - Interface in com.hazelcast.cp
-
IAtomicLong is a redundant and highly available distributed alternative to
the
AtomicLong
.
- IAtomicReference<E> - Interface in com.hazelcast.cp
-
IAtomicReference is a redundant and highly available distributed alternative
to the
AtomicReference
.
- ICache<K,V> - Interface in com.hazelcast.cache
-
This
ICache
interface is the
Cache
extension offered by
Hazelcast JCache.
In addition to the standard set of JCache methods defined in the JSR 107 specification, Hazelcast provides
additional operations to support a broader range of programing styles.
- ICacheManager - Interface in com.hazelcast.core
-
ICacheManager
is the entry point to access JSR-107 (JCache) caches via
HazelcastInstance
interface.
- IcmpFailureDetectorConfig - Class in com.hazelcast.config
-
This Failure Detector may be configured in addition to one of Deadline and Phi Accual Failure Detectors.
It operates at Layer 3 of the OSI protocol, and provides much quicker and more deterministic detection of hardware
and other lower level events.
- IcmpFailureDetectorConfig() - Constructor for class com.hazelcast.config.IcmpFailureDetectorConfig
-
- ICollection<E> - Interface in com.hazelcast.collection
-
Concurrent, distributed, partitioned, listenable collection.
- ICountDownLatch - Interface in com.hazelcast.cp
-
- ICredentialsFactory - Interface in com.hazelcast.security
-
ICredentialsFactory is used to create
Credentials
objects to be used during node authentication before connection is
accepted by the master node.
- id() - Method in enum com.hazelcast.com.fasterxml.jackson.core.JsonToken
-
- id - Variable in class com.hazelcast.com.fasterxml.jackson.core.type.WritableTypeId
-
Actual type id to use: usually {link java.lang.String}.
- id() - Method in interface com.hazelcast.cp.CPGroup
-
Returns unique id of the CP group
- id() - Method in enum com.hazelcast.cp.event.CPMembershipEvent.EventType
-
- id() - Method in interface com.hazelcast.cp.session.CPSession
-
Returns id of the session
- id() - Method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
-
- ID_EMBEDDED_OBJECT - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.JsonTokenId
-
- ID_END_ARRAY - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.JsonTokenId
-
- ID_END_OBJECT - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.JsonTokenId
-
- ID_FALSE - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.JsonTokenId
-
- ID_FIELD_NAME - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.JsonTokenId
-
- ID_NO_TOKEN - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.JsonTokenId
-
Id used to represent the case where no
JsonToken
is available: either because
JsonParser
has not been
advanced to first token, or because no more tokens will be
available (end-of-input or explicit closing of parser}.
- ID_NOT_AVAILABLE - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.JsonTokenId
-
Id used to represent
JsonToken.NOT_AVAILABLE
, used in
cases where a token may become available when more input
is available: this occurs in non-blocking use cases.
- ID_NULL - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.JsonTokenId
-
- ID_NUMBER_FLOAT - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.JsonTokenId
-
- ID_NUMBER_INT - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.JsonTokenId
-
- ID_START_ARRAY - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.JsonTokenId
-
- ID_START_OBJECT - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.JsonTokenId
-
- ID_STRING - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.JsonTokenId
-
- ID_TRUE - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.JsonTokenId
-
- IdentifiedDataSerializable - Interface in com.hazelcast.nio.serialization
-
IdentifiedDataSerializable is an extension to
DataSerializable
to avoid reflection during de-serialization.
- identity() - Static method in interface com.hazelcast.function.FunctionEx
-
- identity() - Static method in class com.hazelcast.projection.Projections
-
Returns a projection that does no transformation.
- IdentityConfig - Interface in com.hazelcast.config.security
-
This interface represents identity configuration in security realms or client security configurations.
- idFromString(String) - Static method in class com.hazelcast.jet.Util
-
- 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
-
- IFunction<T,R> - Interface in com.hazelcast.core
-
Represents a function that accepts one argument and produces a result.
- 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 item attribute
in a case-insensitive manner.
- IList<E> - Interface in com.hazelcast.collection
-
Concurrent, distributed implementation of
List
.
- illegalSurrogate(int) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.UTF8Writer
-
- illegalSurrogateDesc(int) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.UTF8Writer
-
- ILogger - Interface in com.hazelcast.logging
-
The Hazelcast logging interface.
- IMap<K,V> - Interface in com.hazelcast.map
-
Concurrent, distributed, observable and queryable map.
- IMapEvent - Interface in com.hazelcast.map
-
Map events common contract.
- 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
-
- ImplicitTuple - Class in com.hazelcast.org.snakeyaml.engine.v2.events
-
The implicit flag of a scalar event is a pair of boolean values that indicate
if the tag may be omitted when the scalar is emitted in a plain and non-plain
style correspondingly.
- ImplicitTuple(boolean, boolean) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.events.ImplicitTuple
-
- 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(Comparable...) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
-
- in(String, Comparable...) - Static method in class com.hazelcast.query.Predicates
-
Creates a in predicate that will pass items if the value stored under the given item attribute
is a member of the given values
set.
- inArray() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
-
Method that returns true if this context is an Array context;
that is, content is being read from or written to a JSON Array.
- 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.
- include - Variable in class com.hazelcast.com.fasterxml.jackson.core.type.WritableTypeId
-
Property used to indicate style of inclusion for this type id, in cases where
no native type id may be used (either because format has none, like JSON; or
because use of native type ids is disabled [with YAML]).
- INCLUDE_ALL - Static variable in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
-
Marker value that should be used to indicate inclusion of a structured
value (sub-tree representing Object or Array), or value of a named
property (regardless of type).
- includeBinary() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
-
Call made to verify whether leaf-level
Binary value
should be included in output or not.
- includeBoolean(boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
-
Call made to verify whether leaf-level
boolean value
should be included in output or not.
- includeElement(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.JsonPointerBasedFilter
-
- includeElement(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
-
Method called to check whether array element with specified index (zero-based),
at current output location, should be included in output.
- includeEmbeddedValue(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
-
Call made to verify whether leaf-level
embedded (Opaque) value
should be included in output or not.
- includeNull() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
-
Call made to verify whether leaf-level
null value
should be included in output or not.
- includeNumber(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
-
Call made to verify whether leaf-level
int
value
should be included in output or not.
- includeNumber(long) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
-
Call made to verify whether leaf-level
long
value
should be included in output or not.
- includeNumber(float) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
-
Call made to verify whether leaf-level
float
value
should be included in output or not.
- includeNumber(double) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
-
Call made to verify whether leaf-level
double
value
should be included in output or not.
- includeNumber(BigDecimal) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
-
Call made to verify whether leaf-level
BigDecimal
value
should be included in output or not.
- includeNumber(BigInteger) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
-
Call made to verify whether leaf-level
BigInteger
value
should be included in output or not.
- includeProperty(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.JsonPointerBasedFilter
-
- includeProperty(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
-
Method called to check whether property value with specified name,
at current output location, should be included in output.
- includeRawValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
-
Call made to verify whether leaf-level
raw (pre-encoded, not quoted by generator) value
should be included in output or not.
- includeRootValue(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
-
Method called to check whether root-level value,
at current output location, should be included in output.
- includeString(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
-
Call made to verify whether leaf-level
String value
should be included in output or not.
- includeString(Reader, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
-
Call made to verify whether leaf-level
"streaming" String value
should be included in output or not.
- includeValue(JsonParser) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
-
Call made when verifying whether a scaler value is being
read from a parser.
- 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
.
- incrementRemove(String) - Method in class com.hazelcast.wan.WanEventCounters
-
Increment the number of remove events for the distributedObjectName
.
- incrementSync(String) - Method in class com.hazelcast.wan.WanEventCounters
-
Increment the number of sync events for the distributedObjectName
.
- incrementSync(String, int) - Method in class com.hazelcast.wan.WanEventCounters
-
Increment the number of sync events for the distributedObjectName
by count
.
- incrementUpdate(String) - Method in class com.hazelcast.wan.WanEventCounters
-
Increment the number of update events for the distributedObjectName
.
- 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.
- indentArraysWith(DefaultPrettyPrinter.Indenter) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
- indentObjectsWith(DefaultPrettyPrinter.Indenter) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
- 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.
- IndexConfig - Class in com.hazelcast.config
-
Configuration of an index.
- IndexConfig() - Constructor for class com.hazelcast.config.IndexConfig
-
- IndexConfig(IndexType) - Constructor for class com.hazelcast.config.IndexConfig
-
Creates an index configuration of the given type.
- IndexConfig(IndexType, String...) - Constructor for class com.hazelcast.config.IndexConfig
-
Creates an index configuration of the given type with provided attributes.
- IndexConfig(IndexConfig) - Constructor for class com.hazelcast.config.IndexConfig
-
- IndexType - Enum in com.hazelcast.config
-
Type of the index.
- info(String) - Method in class com.hazelcast.logging.AbstractLogger
-
- info(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
-
- info(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
-
- info(String) - Method in interface com.hazelcast.logging.ILogger
-
- info(Throwable) - Method in interface com.hazelcast.logging.ILogger
-
- info(String, Throwable) - Method in interface com.hazelcast.logging.ILogger
-
Logs a message with an associated throwable at the
Level.INFO
level.
- init(CallbackHandler, Properties) - Method in interface com.hazelcast.auditlog.AuditlogServiceFactory
-
Initializes this class with given properties.
- init(Cluster, ClientConfig) - Method in interface com.hazelcast.client.LoadBalancer
-
Initializes the LoadBalancer.
- init(Cluster, ClientConfig) - Method in class com.hazelcast.client.util.AbstractLoadBalancer
-
- init(InitialMembershipEvent) - Method in class com.hazelcast.client.util.AbstractLoadBalancer
-
- init(Cluster, ClientConfig) - Method in class com.hazelcast.client.util.StaticLB
-
- init(InitialMembershipEvent) - Method in interface com.hazelcast.cluster.InitialMembershipListener
-
Called when this listener is registered.
- init(Properties) - Method in class com.hazelcast.config.replacer.AbstractPbeReplacer
-
- init(Properties) - Method in class com.hazelcast.config.replacer.EncryptionReplacer
-
- init(Properties) - Method in class com.hazelcast.config.replacer.PropertyReplacer
-
- init(Properties) - Method in interface com.hazelcast.config.replacer.spi.ConfigReplacer
-
Initialization method called before first usage of the config replacer.
- init(int) - Method in interface com.hazelcast.cp.ISemaphore
-
Tries to initialize this ISemaphore instance with the given permit count
- init(Outbox, Processor.Context) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
- 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(DefaultPartitionStrategy) - Method in class com.hazelcast.jet.core.Partitioner.Default
-
- init(DefaultPartitionStrategy) - Method in interface com.hazelcast.jet.core.Partitioner
-
- 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(ProcessorMetaSupplier.Context) - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Called on the cluster member that receives the client request, after
deserializing the meta-supplier instance.
- init(ProcessorSupplier.Context) - Method in interface com.hazelcast.jet.core.ProcessorSupplier
-
Called on each cluster member after deserialization.
- 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(HazelcastInstance, Properties, String) - Method in interface com.hazelcast.map.MapLoaderLifecycleSupport
-
Initializes this MapLoader implementation.
- init(Properties) - Method in interface com.hazelcast.nio.SocketInterceptor
-
- init(Properties) - Method in class com.hazelcast.nio.ssl.BasicSSLContextFactory
-
- init(Properties) - Method in interface com.hazelcast.nio.ssl.SSLContextFactory
-
Initializes this class with config from
SSLConfig
- init() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.YamlUnicodeReader
-
Read-ahead four bytes and check for BOM marks.
- 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(String, WanConsumerConfig) - Method in interface com.hazelcast.wan.WanConsumer
-
Initialize the WAN consumer.
- init(WanReplicationConfig, AbstractWanPublisherConfig) - Method in interface com.hazelcast.wan.WanPublisher
-
Initializes the publisher.
- INIT_CLUSTER_VERSION - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Override cluster version to use while node is not yet member of a cluster.
- INITIAL_MEMORY_SIZE - Static variable in class com.hazelcast.config.NativeMemoryConfig
-
Initial memory size in megabytes
- INITIAL_MIN_CLUSTER_SIZE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Initial expected cluster size to wait before member to start completely.
- INITIAL_WAIT_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Initial time in seconds to wait before member to start completely.
- initialize(Object) - Method in interface com.hazelcast.core.ManagedContext
-
Initialize the given object instance.
- InitialMembershipEvent - Class in com.hazelcast.cluster
-
- InitialMembershipEvent(Cluster, Set<Member>) - Constructor for class com.hazelcast.cluster.InitialMembershipEvent
-
- InitialMembershipListener - Interface in com.hazelcast.cluster
-
- initLoginModuleProperties() - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
-
- initLoginModuleProperties() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
-
- initLoginModuleProperties() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- initLoginModuleProperties() - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.AtomicLongPermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.AtomicReferencePermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.CachePermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.CardinalityEstimatorPermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.CountDownLatchPermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.DurableExecutorServicePermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.ExecutorServicePermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.FlakeIdGeneratorPermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.InstancePermission
-
init mask
- initMask(String[]) - Method in class com.hazelcast.security.permission.ListPermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.LockPermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.MapPermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.PNCounterPermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.QueuePermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.ReliableTopicPermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.ReplicatedMapPermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.RingBufferPermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.ScheduledExecutorPermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.SemaphorePermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.TopicPermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.UserCodeDeploymentPermission
-
- inLongRange(char[], int, int, boolean) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.NumberInput
-
Helper method for determining if given String representation of
an integral number would fit in 64-bit Java long or not.
- inLongRange(String, boolean) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.NumberInput
-
- InMemoryFormat - Enum in com.hazelcast.config
-
Storage format type of values stored in cluster
- InMemoryXmlConfig - Class in com.hazelcast.config
-
Creates a
Config
loaded from an in-memory Hazelcast XML String.
- InMemoryXmlConfig(String) - Constructor for class com.hazelcast.config.InMemoryXmlConfig
-
Creates a Config from the provided XML string and uses the System.properties to resolve variables
in the XML.
- InMemoryXmlConfig(String, Properties) - Constructor for class com.hazelcast.config.InMemoryXmlConfig
-
Creates a Config from the provided XML string and properties to resolve the variables in the XML.
- InMemoryYamlConfig - Class in com.hazelcast.config
-
Creates a
Config
loaded from an in-memory Hazelcast YAML String.
- InMemoryYamlConfig(String) - Constructor for class com.hazelcast.config.InMemoryYamlConfig
-
Creates a Config from the provided YAML string and uses the System.properties to resolve variables
in the YAML.
- InMemoryYamlConfig(String, Properties) - Constructor for class com.hazelcast.config.InMemoryYamlConfig
-
Creates a Config from the provided YAML string and properties to resolve the variables in the YAML.
- 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 a 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
-
- inObject() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
-
Method that returns true if this context is an Object context;
that is, content is being read from or written to a JSON Object.
- inProgress() - Method in enum com.hazelcast.hotrestart.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.
- InputAccessor - Interface in com.hazelcast.com.fasterxml.jackson.core.format
-
Interface used to expose beginning of a data file to data format
detection code.
- InputAccessor.Std - Class in com.hazelcast.com.fasterxml.jackson.core.format
-
Basic implementation that reads data from given
InputStream
and buffers it as necessary.
- InputCoercionException - Exception in com.hazelcast.com.fasterxml.jackson.core.exc
-
Exception type for read-side problems that are not direct decoding ("parsing")
problems (those would be reported as
JsonParseException
s),
but rather result from failed attempts to convert specific Java value out of valid
but incompatible input value.
- InputCoercionException(JsonParser, String, JsonToken, Class<?>) - Constructor for exception com.hazelcast.com.fasterxml.jackson.core.exc.InputCoercionException
-
- InputDecorator - Class in com.hazelcast.com.fasterxml.jackson.core.io
-
Handler class that can be used to decorate input sources.
- InputDecorator() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.io.InputDecorator
-
- inputDecorator() - Method in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- inputDecorator(InputDecorator) - Method in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- 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.
- inRoot() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
-
Method that returns true if this context is a Root context;
that is, content is being read from or written to without
enclosing array or object structure.
- 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 method in class com.hazelcast.com.fasterxml.jackson.core.JsonpCharacterEscapes
-
- instance - Static variable in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter.FixedSpaceIndenter
-
- instance - Static variable in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter.NopIndenter
-
- instance - Static variable in class com.hazelcast.com.fasterxml.jackson.core.util.InternCache
-
- 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
-
General configuration options pertaining to a Jet instance.
- InstanceConfig() - Constructor for class com.hazelcast.jet.config.InstanceConfig
-
- instanceOf(Class) - Static method in class com.hazelcast.query.Predicates
-
Creates an instance of predicate that will pass entries for which
the value class is an instanceof
the given klass
.
- InstancePermission - Class in com.hazelcast.security.permission
-
TODO: Object Permission
- InstancePermission(String, String...) - Constructor for class com.hazelcast.security.permission.InstancePermission
-
- InstanceTrackingConfig - Class in com.hazelcast.config
-
Configures tracking of a running Hazelcast instance.
- InstanceTrackingConfig() - Constructor for class com.hazelcast.config.InstanceTrackingConfig
-
- InstanceTrackingConfig(InstanceTrackingConfig) - Constructor for class com.hazelcast.config.InstanceTrackingConfig
-
- InstanceTrackingConfig.InstanceMode - Enum in com.hazelcast.config
-
The mode in which this instance is running.
- InstanceTrackingConfig.InstanceProductName - Enum in com.hazelcast.config
-
Product name for the Hazelcast instance
- InstanceTrackingConfig.InstanceTrackingProperties - Enum in com.hazelcast.config
-
Enumeration of instance properties provided to the format pattern for
output.
- Instantiatable<T> - Interface in com.hazelcast.com.fasterxml.jackson.core.util
-
Add-on interface used to indicate things that may be "blueprint" objects
which can not be used as is, but are used for creating usable per-process
(serialization, deserialization) instances, using
Instantiatable.createInstance()
method.
- INT - Static variable in class com.hazelcast.org.snakeyaml.engine.v2.nodes.Tag
-
- INT - Static variable in class com.hazelcast.org.snakeyaml.engine.v2.resolver.JsonScalarResolver
-
- INT_0 - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- INT_9 - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- INT_APOS - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- INT_ASTERISK - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- INT_BACKSLASH - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- INT_COLON - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- INT_COMMA - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- INT_CR - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- INT_e - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- INT_E - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- INT_HASH - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- INT_LBRACKET - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- INT_LCURLY - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- INT_LF - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- INT_MINUS - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- INT_PERIOD - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- INT_PLUS - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- INT_QUOTE - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- INT_RBRACKET - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- INT_RCURLY - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- INT_SLASH - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- INT_SPACE - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- INT_TAB - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- integerAvg() - Static method in class com.hazelcast.aggregation.Aggregators
-
- integerAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
-
- integerMax() - Static method in class com.hazelcast.aggregation.Aggregators
-
- integerMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
-
- integerMin() - Static method in class com.hazelcast.aggregation.Aggregators
-
- integerMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
-
- integerSum() - Static method in class com.hazelcast.aggregation.Aggregators
-
- integerSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
-
- interceptAfter(Credentials, String, String, String) - Method in interface com.hazelcast.security.SecurityContext
-
intercepts a request after process if any
SecurityInterceptor
configured
Any exception thrown during interception will be ignored
- interceptBefore(Credentials, String, String, String, Object[]) - Method in interface com.hazelcast.security.SecurityContext
-
- 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
-
- intern(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.InternCache
-
- InternCache - Class in com.hazelcast.com.fasterxml.jackson.core.util
-
Singleton class that adds a simple first-level cache in front of
regular String.intern() functionality.
- interruptBackupTask() - Method in interface com.hazelcast.hotrestart.HotRestartService
-
Interrupts the backup tasks on each cluster member if one is currently running.
- interruptLocalBackupTask() - Method in interface com.hazelcast.hotrestart.HotRestartService
-
Interrupts the local backup task if one is currently running.
- IntervalFunction - Interface in com.hazelcast.jet.retry
-
Function that computes the wait time necessary for each subsequent retry
attempt.
- intervalFunction(IntervalFunction) - Method in class com.hazelcast.jet.retry.RetryStrategies.Builder
-
Set a function to modify the waiting interval after a failure.
- INVALID_FENCE - Static variable in interface com.hazelcast.cp.lock.FencedLock
-
Representation of a failed lock attempt where
the caller thread has not acquired the lock
- InvalidConfigurationException - Exception in com.hazelcast.config
-
A InvalidConfigurationException is thrown when an Hazelcast faces
an invalid configuration.
- InvalidConfigurationException(String) - Constructor for exception com.hazelcast.config.InvalidConfigurationException
-
Creates a InvalidConfigurationException with the given message.
- InvalidConfigurationException(String, Throwable) - Constructor for exception com.hazelcast.config.InvalidConfigurationException
-
Constructs a new runtime exception with the specified detail message and cause.
- INVOCATION_MAX_RETRY_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Maximum number of retries for an invocation.
- INVOCATION_RETRY_PAUSE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Pause time between each retry cycle of an invocation in milliseconds.
- INVOCATION_RETRY_PAUSE_MILLIS - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Pause time between each retry cycle of an invocation in milliseconds.
- INVOCATION_TIMEOUT_SECONDS - Static variable in class com.hazelcast.client.properties.ClientProperty
-
When an invocation gets an exception because :
- Member throws an exception.
- IO_BALANCER_INTERVAL_SECONDS - Static variable in class com.hazelcast.client.properties.ClientProperty
-
The interval in seconds between IOBalancer
executions.
- IO_BALANCER_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The interval in seconds between
IOBalancer
executions.
- IO_INPUT_THREAD_COUNT - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Controls the number of IO input threads.
- IO_INPUT_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Controls the number of socket input threads.
- IO_OUTPUT_THREAD_COUNT - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Controls the number of IO output threads.
- IO_OUTPUT_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Controls the number of socket output threads.
- IO_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The number of threads doing socket input and the number of threads doing
socket output.
- IO_WRITE_THROUGH_ENABLED - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Optimization that allows sending of packets over the network to be done on the calling thread if the
conditions are right.
- IO_WRITE_THROUGH_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Optimization that allows sending of packets over the network to be done
on the calling thread if the conditions are right.
- IOContext - Class in com.hazelcast.com.fasterxml.jackson.core.io
-
To limit number of configuration and state objects to pass, all
contextual objects that need to be passed by the factory to
readers and writers are combined under this object.
- IOContext(BufferRecycler, Object, boolean) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
- 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
-
- isAbstract() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
-
- isAllowBlock() - Method in class com.hazelcast.org.snakeyaml.engine.v2.emitter.ScalarAnalysis
-
- isAllowBlockPlain() - Method in class com.hazelcast.org.snakeyaml.engine.v2.emitter.ScalarAnalysis
-
- isAllowFlowPlain() - Method in class com.hazelcast.org.snakeyaml.engine.v2.emitter.ScalarAnalysis
-
- isAllowOverrideDefaultSerializers() - Method in class com.hazelcast.config.SerializationConfig
-
- isAllowSingleQuoted() - Method in class com.hazelcast.org.snakeyaml.engine.v2.emitter.ScalarAnalysis
-
- isAllowUnsafe() - Method in class com.hazelcast.config.SerializationConfig
-
Unsafe, it is not public api of java.
- isArray() - Method in interface com.hazelcast.com.fasterxml.jackson.core.TreeNode
-
Method that returns true if this node is an Array node, false
otherwise.
- isArrayType() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
-
- isArrayType() - Method in enum com.hazelcast.nio.serialization.FieldType
-
- isAssignedToMember() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
-
- isAssignedToPartition() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
-
- isAsyncFillup() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
True if the replicated map is available for reads before the initial
replication is completed, false otherwise.
- isAsyncStart() - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
-
- 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
-
Returns whether or not automatically removal of stale Hot Restart data is enabled.
- isAutoScaling() - Method in class com.hazelcast.jet.config.JobConfig
-
- 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 smart client.
- isBetween(Version, Version) - Method in class com.hazelcast.version.Version
-
Checks if the version is between specified version (both ends inclusive)
- isBigEndian() - Method in enum com.hazelcast.com.fasterxml.jackson.core.JsonEncoding
-
Whether encoding is big-endian (if encoding supports such
notion).
- isBinary() - Method in class com.hazelcast.config.MultiMapConfig
-
Checks if the MultiMap is in binary (serialized) form.
- isBoolean() - Method in enum com.hazelcast.com.fasterxml.jackson.core.JsonToken
-
- isCacheLocalEntries() - Method in class com.hazelcast.config.NearCacheConfig
-
Checks if local entries are also cached in the Near Cache.
- isCanonical() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettings
-
- isCheckClassDefErrors() - Method in class com.hazelcast.config.SerializationConfig
-
Default value is true
(enabled).
- IScheduledExecutorService - Interface in com.hazelcast.scheduledexecutor
-
- IScheduledFuture<V> - Interface in com.hazelcast.scheduledexecutor
-
A delayed result-bearing action that can be cancelled.
- isClassArchive() - Method in enum 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.
- isClosed() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- isClosed() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- isClosed() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- isClosed() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method that can be called to determine whether this generator
is closed or not.
- isClosed() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method that can be called to determine whether this parser
is closed or not.
- isClosed() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- isClosed() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- isClusterSafe() - Method in interface com.hazelcast.partition.PartitionService
-
Checks whether the cluster is in a safe state.
- isCoalesce() - Method in class com.hazelcast.config.QueryCacheConfig
-
Returns true
if coalescing is is enabled, otherwise returns false
.
- isCollectionLikeType() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
-
- isConcrete() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
-
- isConnected() - Method in class com.hazelcast.client.util.ClientStateListener
-
- isContainerNode() - Method in interface com.hazelcast.com.fasterxml.jackson.core.TreeNode
-
Method that returns true for container nodes: Arrays and Objects.
- isContainerType() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
-
- 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
-
- isDefaultsDisabled() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
-
- isDestroyed() - Method in interface com.hazelcast.cache.ICache
-
Determines whether this Cache instance has been destroyed.
- isDisablePerEntryInvalidationEvents() - Method in class com.hazelcast.config.CacheConfig
-
Returns invalidation events disabled status for per entry.
- isDisablePerEntryInvalidationEvents() - Method in class com.hazelcast.config.CacheSimpleConfig
-
Returns invalidation events disabled status for per entry.
- isDiscoveryCompleted() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
-
Returns whether the CP discovery process is completed or not.
- 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 com.hazelcast.hotrestart.BackupTaskState
-
Returns true if the backup task completed (successfully or with failure)
- isDup(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.DupDetector
-
Method called to check whether a newly encountered property name would
be a duplicate within this context, and if not, update the state to remember
having seen the property name for checking more property names
- 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 class com.hazelcast.org.snakeyaml.engine.v2.common.ArrayStack
-
- isEmpty() - Method in class com.hazelcast.org.snakeyaml.engine.v2.emitter.ScalarAnalysis
-
- isEmpty() - Method in interface com.hazelcast.transaction.TransactionalMap
-
- isEnableCompression() - Method in class com.hazelcast.config.SerializationConfig
-
Enables compression when default java serialization is used.
- isEnabled() - Method in class com.hazelcast.client.config.ClientCloudConfig
-
- isEnabled() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
-
- isEnabled() - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
-
- isEnabled(JsonGenerator.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- isEnabled(JsonFactory.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Checked whether specified parser feature is enabled.
- isEnabled(JsonParser.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method for checking if the specified parser feature is enabled.
- isEnabled(StreamReadFeature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method for checking if the specified stream read feature is enabled.
- isEnabled(JsonGenerator.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Check whether specified generator feature is enabled.
- isEnabled(StreamWriteFeature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Check whether specified stream write feature is enabled.
- isEnabled(JsonGenerator.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for checking whether given feature is enabled.
- isEnabled(StreamWriteFeature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for checking whether given feature is enabled.
- isEnabled(JsonParser.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- isEnabled(StreamReadFeature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- isEnabled(JsonParser.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
- isEnabled(JsonGenerator.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
- isEnabled(F) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JacksonFeatureSet
-
Main accessor for checking whether given feature is enabled in this feature set.
- isEnabled(JsonGenerator.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- isEnabled(JsonParser.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- isEnabled() - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
-
Returns if this configuration is enabled.
- isEnabled() - Method in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
-
Returns if this configuration is enabled.
- isEnabled() - Method in class com.hazelcast.config.AdvancedNetworkConfig
-
- isEnabled() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
-
Checks whether the given join mechanism is enabled.
- isEnabled() - Method in class com.hazelcast.config.AutoDetectionConfig
-
Checks whether the auto detection mechanism is enabled.
- isEnabled() - Method in class com.hazelcast.config.BaseMetricsConfig
-
Returns if metrics collection is enabled.
- isEnabled() - Method in class com.hazelcast.config.DiscoveryConfig
-
- isEnabled() - Method in class com.hazelcast.config.EventJournalConfig
-
Returns if the event journal is enabled.
- isEnabled() - Method in class com.hazelcast.config.HotRestartConfig
-
Returns whether hot restart enabled on related data structure.
- isEnabled() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Returns whether hot restart enabled on this member.
- isEnabled() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
-
- isEnabled() - Method in class com.hazelcast.config.InstanceTrackingConfig
-
Returns true
if instance tracking is enabled.
- isEnabled() - Method in class com.hazelcast.config.InterfacesConfig
-
- isEnabled() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns if this configuration is enabled
- isEnabled() - Method in class com.hazelcast.config.MemberAddressProviderConfig
-
- isEnabled() - Method in class com.hazelcast.config.MemcacheProtocolConfig
-
Returns if MEMCACHE protocol support is enabled.
- isEnabled() - Method in class com.hazelcast.config.MerkleTreeConfig
-
Returns if the merkle tree is enabled.
- isEnabled() - Method in class com.hazelcast.config.MetricsJmxConfig
-
Returns whether metrics will be exposed through JMX MBeans.
- isEnabled() - Method in class com.hazelcast.config.MetricsManagementCenterConfig
-
Returns whether metrics will be exposed to Hazelcast Management
Center.
- isEnabled() - Method in class com.hazelcast.config.MulticastConfig
-
Check if the multicast discovery mechanism has been enabled.
- isEnabled() - Method in class com.hazelcast.config.NativeMemoryConfig
-
Returns true
if native memory allocation is enabled, false
otherwise.
- isEnabled() - Method in class com.hazelcast.config.NearCachePreloaderConfig
-
- isEnabled() - Method in class com.hazelcast.config.PartitionGroupConfig
-
Checks if this PartitionGroupConfig is enabled.
- isEnabled() - Method in class com.hazelcast.config.PersistentMemoryConfig
-
Returns if the persistent memory is enabled.
- isEnabled() - Method in class com.hazelcast.config.QueueStoreConfig
-
Returns true
if the queue store is enabled, false
otherwise.
- isEnabled() - Method in class com.hazelcast.config.RestApiConfig
-
Checks if REST API access is enabled.
- isEnabled() - Method in class com.hazelcast.config.RingbufferStoreConfig
-
- isEnabled() - Method in class com.hazelcast.config.SecurityConfig
-
- isEnabled() - Method in class com.hazelcast.config.ServiceConfig
-
- isEnabled() - Method in class com.hazelcast.config.SocketInterceptorConfig
-
Returns if this configuration is enabled.
- isEnabled() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
-
- isEnabled() - Method in class com.hazelcast.config.TcpIpConfig
-
Checks if the Tcp/Ip join mechanism is enabled.
- isEnabled() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Returns true if User Code Deployment is enabled
- isEnabledAndNotEmpty() - Method in class com.hazelcast.config.RestApiConfig
-
Return true if the REST API is enabled and at least one REST endpoint group is allowed.
- isEnabledAndNotEmpty() - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Return true if the REST API is enabled and at least one REST endpoint group is allowed.
- isEnabledByDefault() - Method in enum com.hazelcast.config.RestEndpointGroup
-
Returns if this group is enabled by default.
- isEnableSharedObject() - Method in class com.hazelcast.config.SerializationConfig
-
Enables shared object when default java serialization is used.
- isEnqueueNewEvents() - Method in enum com.hazelcast.wan.WanPublisherState
-
Returns true
if this state allows enqueueing new events,
false
otherwise.
- isEnterprise() - Method in class com.hazelcast.instance.BuildInfo
-
- isEnumType() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
-
- 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
- isExpectedNumberIntToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- isExpectedNumberIntToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- isExpectedNumberIntToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- isExpectedStartArrayToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- isExpectedStartArrayToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- isExpectedStartArrayToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Specialized accessor that can be used to verify that the current
token indicates start array (usually meaning that current token
is
JsonToken.START_ARRAY
) when start array is expected.
- isExpectedStartArrayToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- isExpectedStartObjectToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- isExpectedStartObjectToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- isExpectedStartObjectToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- isExpectedStartObjectToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- isExpired(long) - Method in interface com.hazelcast.cp.session.CPSession
-
Returns true if the session expires before the given timestamp.
- isExplicit() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.DocumentEndEvent
-
- isExplicit() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.DocumentStartEvent
-
- isExplicitEnd() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettings
-
- isExplicitStart() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettings
-
- 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.
- isFinal() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
-
- isFineEnabled() - Method in class com.hazelcast.logging.AbstractLogger
-
- isFineEnabled() - Method in interface com.hazelcast.logging.ILogger
-
- isFinestEnabled() - Method in class com.hazelcast.logging.AbstractLogger
-
- isFinestEnabled() - Method in interface com.hazelcast.logging.ILogger
-
- isFlow() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.CollectionStartEvent
-
- isFsync() - Method in class com.hazelcast.config.HotRestartConfig
-
Returns whether disk write should be followed by an fsync()
system call.
- isGlobalOrderingEnabled() - Method in class com.hazelcast.config.TopicConfig
-
Checks if global ordering is enabled (all nodes listening to the same topic
get their messages in the same order), or disabled (nodes get
the messages in the order that the messages are published).
- isGreaterOrEqual(Version) - Method in class com.hazelcast.version.Version
-
- isGreaterThan(Version) - Method in class com.hazelcast.version.Version
-
- isGroupEnabled(RestEndpointGroup) - Method in class com.hazelcast.config.RestApiConfig
-
Checks if given REST endpoint group is enabled.
- isGroupEnabled(RestEndpointGroup) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
Checks if given REST endpoint group is enabled.
- isHotBackupEnabled() - Method in interface com.hazelcast.hotrestart.HotRestartService
-
Returns if hot backup is enabled.
- isIdentityConfigured() - Method in class com.hazelcast.config.security.RealmConfig
-
- isImplicit() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.CollectionStartEvent
-
true
if the tag can be omitted while this collection is
emitted.
- isIncludeValue() - Method in class com.hazelcast.config.EntryListenerConfig
-
- isIncludeValue() - Method in class com.hazelcast.config.ItemListenerConfig
-
- isIncludeValue() - Method in class com.hazelcast.config.ListenerConfig
-
- isIncludeValue() - Method in class com.hazelcast.config.QueryCacheConfig
-
Returns true
if value caching enabled, otherwise returns false
.
- isIncludeValue() - Method in class com.hazelcast.config.SplitBrainProtectionListenerConfig
-
- isInfoEnabled() - Method in class com.hazelcast.logging.AbstractLogger
-
- isInfoEnabled() - Method in interface com.hazelcast.logging.ILogger
-
- isInline() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultIndenter
-
- isInline() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter.FixedSpaceIndenter
-
- isInline() - Method in interface com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter.Indenter
-
- isInline() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter.NopIndenter
-
- isInstanceTrackingEnabledSet(Config) - Static method in class com.hazelcast.config.ConfigAccessor
-
- isInterface() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
-
- isInvalidateOnChange() - Method in class com.hazelcast.config.NearCacheConfig
-
Checks if Near Cache entries are invalidated when the entries in the backing data structure are changed
(updated or removed).
- isIPv4() - Method in class com.hazelcast.cluster.Address
-
- isIPv6() - Method in class com.hazelcast.cluster.Address
-
- isJDKCompatible() - Method in class com.hazelcast.config.cp.SemaphoreConfig
-
Returns true if CP ISemaphore is compatible with
its JDK counterpart
- isJoinAllowed() - Method in enum com.hazelcast.cluster.ClusterState
-
Returns true
, if joining of a new member is allowed in this state.
- isKeepAlive() - Method in class com.hazelcast.client.config.SocketOptions
-
SO_KEEPALIVE socket option
- isLessOrEqual(Version) - Method in class com.hazelcast.version.Version
-
- isLessThan(Version) - Method in class com.hazelcast.version.Version
-
- isListed(String) - Method in class com.hazelcast.config.ClassFilter
-
- isLiteMember() - Method in interface com.hazelcast.cluster.Member
-
Returns true if this member is a lite member.
- isLiteMember() - Method in class com.hazelcast.config.Config
-
Returns true
if this member is a lite member.
- isLocal() - Method in class com.hazelcast.config.EntryListenerConfig
-
- isLocal() - Method in class com.hazelcast.config.ListenerConfig
-
- isLocal() - Method in class com.hazelcast.config.SplitBrainProtectionListenerConfig
-
- isLocalMemberSafe() - Method in interface com.hazelcast.partition.PartitionService
-
Checks whether local member is in safe state.
- isLocked() - Method in interface com.hazelcast.cp.lock.FencedLock
-
Returns whether this lock is locked or not.
- isLocked(K) - Method in interface com.hazelcast.map.IMap
-
Checks the lock for the specified key.
- isLocked() - Method in interface com.hazelcast.map.LockAware
-
- isLocked(K) - Method in interface com.hazelcast.multimap.MultiMap
-
Checks the lock for the specified key.
- isLockedByCurrentThread() - Method in interface com.hazelcast.cp.lock.FencedLock
-
Returns whether the lock is held by the current thread or not.
- isLoggable(Level) - Method in interface com.hazelcast.logging.ILogger
-
Checks if a message at the given level is going to be logged by this logger.
- isLoggable(Level) - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
-
- isLoopbackModeEnabled() - Method in class com.hazelcast.config.MulticastConfig
-
Check if the loopback mode is enabled in the multicast discovery mechanism.
- isLosslessRestartEnabled() - Method in class com.hazelcast.jet.config.InstanceConfig
-
- 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
.
- isMapLikeType() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
-
- isMemberSafe(Member) - Method in interface com.hazelcast.partition.PartitionService
-
Checks whether the given member is in safe state.
- isMerged() - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.MappingNode
-
- 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 com.hazelcast.cluster.ClusterState
-
Returns true
, if migrations and replications are allowed in this state.
- isMissingNode() - Method in interface com.hazelcast.com.fasterxml.jackson.core.TreeNode
-
Method that returns true for "virtual" nodes which represent
missing entries constructed by path accessor methods when
there is no actual node matching given criteria.
- isMultiline() - Method in class com.hazelcast.jet.pipeline.file.JsonFileFormat
-
Specifies if the Json parser should accept json records spanning
multiple lines.
- isMultiline() - Method in class com.hazelcast.org.snakeyaml.engine.v2.emitter.ScalarAnalysis
-
- isMultiLineFlow() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettings
-
- isMultiThreadingEnabled() - Method in class com.hazelcast.config.TopicConfig
-
Checks if multi-threaded processing of incoming messages is enabled or not.
- isNaN() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- isNaN() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Access for checking whether current token is a numeric value token, but
one that is of "not-a-number" (NaN) variety (including both "NaN" AND
positive/negative infinity!): not supported by all formats,
but often supported for
JsonToken.VALUE_NUMBER_FLOAT
.
- isNaN() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- 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.
- isNumeric() - Method in enum com.hazelcast.com.fasterxml.jackson.core.JsonToken
-
- isObject() - Method in interface com.hazelcast.com.fasterxml.jackson.core.TreeNode
-
Method that returns true if this node is an Object node, false
otherwise.
- isolated() - Method in class com.hazelcast.jet.core.Edge
-
Activates the
ISOLATED
routing policy
which establishes isolated paths from upstream to downstream processors.
- isOldValueRequired() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
If old value is required, previously assigned values for the affected keys
will be sent to this cache entry listener implementation.
- isOverrideJavaSerialization() - Method in class com.hazelcast.config.GlobalSerializerConfig
-
- isOverwritable() - Method in interface com.hazelcast.nio.serialization.SerializerHook
-
Defines if this serializer can be overridden by defining a custom
serializer in the configurations (codebase or configuration file)
- isParallelMode() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
-
- isParseDn() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- isPartitionPromotionAllowed() - Method in enum com.hazelcast.cluster.ClusterState
-
Returns true
, if partition promotions are allowed in this state.
- isPerEntryStatsEnabled() - Method in class com.hazelcast.config.MapConfig
-
Checks if entry level statistics are enabled for this map.
- isPersistenceEnabled() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Returns whether CP Subsystem Persistence enabled on this member.
- isPersistWanReplicatedData() - Method in class com.hazelcast.config.WanConsumerConfig
-
- isPlain() - Method in class com.hazelcast.org.snakeyaml.engine.v2.events.ScalarEvent
-
- isPlain() - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.ScalarNode
-
- isPlain() - Method in class com.hazelcast.org.snakeyaml.engine.v2.tokens.ScalarToken
-
- isPopulate() - Method in class com.hazelcast.config.QueryCacheConfig
-
Returns true
if initial population of QueryCache
is enabled, otherwise returns false
.
- isPortAutoIncrement() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
-
- isPortAutoIncrement() - Method in class com.hazelcast.config.NetworkConfig
-
Checks if a Hazelcast member is allowed find a free port by incrementing the port number when it encounters
an occupied port.
- isPortAutoIncrement() - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
Checks if a Hazelcast member is allowed find a free port by incrementing the port number when it encounters
an occupied port.
- isPresent() - Method in class com.hazelcast.splitbrainprotection.SplitBrainProtectionEvent
-
Returns the presence of the split brain protection
- isPreserveOrder() - Method in interface com.hazelcast.jet.pipeline.Pipeline
-
Returns the preserve order property of this pipeline
- isPrimitive() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
-
- isPrintable(String) - Static method in class com.hazelcast.org.snakeyaml.engine.v2.scanner.StreamReader
-
- isPrintable(int) - Static method in class com.hazelcast.org.snakeyaml.engine.v2.scanner.StreamReader
-
- 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.
- isRecursive() - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.Node
-
Indicates if this node must be constructed in two steps.
- isRedoOperation() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
- isReferenceType() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
-
Whether this type is a referential type, meaning that values are
basically pointers to "real" values (or null) and not regular
values themselves.
- isReplicateEnqueuedEvents() - Method in enum com.hazelcast.wan.WanPublisherState
-
Returns true
if this state allows dequeueing and replicating
events, false
otherwise.
- isRepublishingEnabled() - Method in class com.hazelcast.config.WanReplicationRef
-
Returns true
if incoming WAN events to this member should be
republished (forwarded) to this WAN replication reference.
- isResourceManaged() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
- 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
-
- isRunning() - Method in interface com.hazelcast.core.LifecycleService
-
Checks whether or not the instance is running.
- isScalarValue() - Method in enum com.hazelcast.com.fasterxml.jackson.core.JsonToken
-
Method that can be used to check whether this token represents
a valid non-structured value.
- isScriptingEnabled() - Method in class com.hazelcast.config.ManagementCenterConfig
-
Returns if scripting is allowed (true
) or disallowed (false
).
- isSerializeKeys() - Method in class com.hazelcast.config.NearCacheConfig
-
Checks if the Near Cache key is stored in serialized format or by-reference.
- isSevereEnabled() - Method in class com.hazelcast.logging.AbstractLogger
-
- isSevereEnabled() - Method in interface com.hazelcast.logging.ILogger
-
- isShutdown() - Method in class com.hazelcast.client.util.ClientStateListener
-
- isSmartRouting() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
- isSnapshot() - Method in class com.hazelcast.com.fasterxml.jackson.core.Version
-
- 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
-
- isSplitLines() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettings
-
- isStarted() - Method in class com.hazelcast.client.util.ClientStateListener
-
- isStartHandled() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
-
- 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.
- isStructEnd() - Method in enum com.hazelcast.com.fasterxml.jackson.core.JsonToken
-
Accessor that is functionally equivalent to:
this == JsonToken.END_OBJECT || this == JsonToken.END_ARRAY
- isStructStart() - Method in enum com.hazelcast.com.fasterxml.jackson.core.JsonToken
-
Accessor that is functionally equivalent to:
this == JsonToken.START_OBJECT || this == JsonToken.START_ARRAY
- 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
-
- 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 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
-
- isThrowable() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
-
- isTumbling() - Method in class com.hazelcast.jet.core.SlidingWindowPolicy
-
Tells whether this definition describes a tumbling window.
- isUknownVersion() - Method in class com.hazelcast.com.fasterxml.jackson.core.Version
-
- 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
-
- isUnknownVersion() - Method in class com.hazelcast.com.fasterxml.jackson.core.Version
-
- isUseEndpointPrivateAddress() - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Returns whether the WAN connection manager should connect to the
endpoint on the private address returned by the discovery SPI.
- isUseNativeByteOrder() - Method in class com.hazelcast.config.SerializationConfig
-
- isUsePublicIp() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
-
Checks whether the public or private IP should be used to connect to Hazelcast members.
- isUseUnicodeEncoding() - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettings
-
- isValueNode() - Method in interface com.hazelcast.com.fasterxml.jackson.core.TreeNode
-
Method that returns true for all value nodes: ones that
are not containers, and that do not represent "missing" nodes
in the path.
- isWarningEnabled() - Method in class com.hazelcast.logging.AbstractLogger
-
- isWarningEnabled() - Method in interface com.hazelcast.logging.ILogger
-
- 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.client.console.ClientConsoleApp
-
- itemAdded(ItemEvent<E>) - Method in interface com.hazelcast.collection.ItemListener
-
Invoked when an item is added.
- itemAdded(ItemEvent) - Method in class com.hazelcast.console.ConsoleApp
-
- ItemEvent<E> - Class in com.hazelcast.collection
-
Event for a collection item.
- ItemEvent(String, ItemEventType, E, Member) - Constructor for class com.hazelcast.collection.ItemEvent
-
- ItemEventType - Enum in com.hazelcast.core
-
Type of item events.
- ItemListener<E> - Interface in com.hazelcast.collection
-
- ItemListenerConfig - Class in com.hazelcast.config
-
Contains the configuration for an Item Listener.
- ItemListenerConfig() - Constructor for class com.hazelcast.config.ItemListenerConfig
-
- ItemListenerConfig(String, boolean) - Constructor for class com.hazelcast.config.ItemListenerConfig
-
- ItemListenerConfig(ItemListener, boolean) - Constructor for class com.hazelcast.config.ItemListenerConfig
-
- ItemListenerConfig(ItemListenerConfig) - Constructor for class com.hazelcast.config.ItemListenerConfig
-
- itemRemoved(ItemEvent) - Method in class com.hazelcast.client.console.ClientConsoleApp
-
- itemRemoved(ItemEvent<E>) - Method in interface com.hazelcast.collection.ItemListener
-
Invoked when an item is removed.
- itemRemoved(ItemEvent) - Method in class com.hazelcast.console.ConsoleApp
-
- 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 - Class in com.hazelcast.jet.datamodel
-
A heterogeneous map from Tag<E>
to E
, where E
can be different for each tag.
- ItemsByTag() - Constructor for class com.hazelcast.jet.datamodel.ItemsByTag
-
- 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.
- 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(int) - Method in interface com.hazelcast.cache.ICache
-
Creates and returns a cluster wide iterator
to iterate on all entries owned by this cache.
- iterator() - Method in class com.hazelcast.jet.core.DAG
-
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.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(int) - 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.
- 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.
- PackageVersion - Class in com.hazelcast.com.fasterxml.jackson.core.json
-
Automatically generated from PackageVersion.java.in during
packageVersion-generate execution of maven-replacer-plugin in
pom.xml.
- PackageVersion() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.json.PackageVersion
-
- packageVersionFor(Class<?>) - Static method in class com.hazelcast.com.fasterxml.jackson.core.util.VersionUtil
-
- PADDING_CHAR_NONE - Static variable in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
-
Placeholder used by "no padding" variant, to be used when a character
value is needed.
- paddingReadBehaviour() - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
-
- PagingPredicate<K,V> - Interface in com.hazelcast.query
-
This interface is a special Predicate which helps to get a page-by-page result of a query.
- pagingPredicate(int) - Static method in class com.hazelcast.query.Predicates
-
Creates a paging predicate with a page size.
- pagingPredicate(Predicate, int) - Static method in class com.hazelcast.query.Predicates
-
Creates a paging predicate with an inner predicate and page size.
- pagingPredicate(Comparator<Map.Entry<K, V>>, int) - Static method in class com.hazelcast.query.Predicates
-
Creates a paging predicate with a comparator and page size.
- pagingPredicate(Predicate<K, V>, Comparator<Map.Entry<K, V>>, int) - Static method in class com.hazelcast.query.Predicates
-
Creates a paging predicate with an inner predicate, comparator and page size.
- 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
-
- parentClassRepresenters - Variable in class com.hazelcast.org.snakeyaml.engine.v2.representer.BaseRepresenter
-
Keep representers which match a parent of the class to be represented
- 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
-
- parse(InputStream) - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
-
- parse(InputStream) - Method in class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
-
- parse(InputStream) - Method in class com.hazelcast.config.AbstractXmlConfigBuilder
-
Reads XML from InputStream and parses.
- parse(InputStream) - Method in class com.hazelcast.config.XmlConfigBuilder
-
- parse(String) - Static method in class com.hazelcast.memory.MemorySize
-
Parses string representation of a memory size value.
- parse(String, MemoryUnit) - Static method in class com.hazelcast.memory.MemorySize
-
Parses string representation of a memory size value.
- Parse - Class in com.hazelcast.org.snakeyaml.engine.v2.api.lowlevel
-
Read the input stream and parse the content into events (opposite for Present or Emit)
- Parse(LoadSettings) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.api.lowlevel.Parse
-
- parseAsDouble(String, double) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.NumberInput
-
- parseAsInt(String, int) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.NumberInput
-
- parseAsLong(String, long) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.NumberInput
-
- parseBigDecimal(String) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.NumberInput
-
- parseBigDecimal(char[]) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.NumberInput
-
- parseBigDecimal(char[], int, int) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.NumberInput
-
- parseDouble(String) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.NumberInput
-
- parseEscapedName(int[], int, int, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
Slower parsing method which is generally branched to when
an escape sequence is detected (or alternatively for long
names, one crossing input buffer boundary).
- parseEscapedName(int[], int, int, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
Slower parsing method which is generally branched to when an escape
sequence is detected (or alternatively for long names, one crossing
input buffer boundary).
- parseInputStream(InputStream) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.lowlevel.Parse
-
Parse a YAML stream and produce parsing events.
- parseInt(char[], int, int) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.NumberInput
-
Fast method for parsing unsigned integers that are known to fit into
regular 32-bit signed int type.
- parseInt(String) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.NumberInput
-
Helper method to (more) efficiently parse integer numbers from
String values.
- parseLong(char[], int, int) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.NumberInput
-
- parseLong(String) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.NumberInput
-
- parseLongName(int, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- parseMediumName(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- parseMediumName2(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- parser - Variable in class com.hazelcast.org.snakeyaml.engine.v2.composer.Composer
-
- Parser - Interface in com.hazelcast.org.snakeyaml.engine.v2.parser
-
This interface represents an input stream of
Events
.
- ParserBase - Class in com.hazelcast.com.fasterxml.jackson.core.base
-
Intermediate base class used by all Jackson
JsonParser
implementations.
- ParserBase(IOContext, int) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- parseReader(Reader) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.lowlevel.Parse
-
Parse a YAML stream and produce parsing events.
- ParserException - Exception in com.hazelcast.org.snakeyaml.engine.v2.exceptions
-
Exception thrown by the
Parser
implementations in case of malformed
input.
- ParserException(String, Optional<Mark>, String, Optional<Mark>) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v2.exceptions.ParserException
-
Constructs an instance.
- ParserException(String, Optional<Mark>) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v2.exceptions.ParserException
-
- ParserImpl - Class in com.hazelcast.org.snakeyaml.engine.v2.parser
-
# The following YAML grammar is LL(1) and is parsed by a recursive descent
parser.
- ParserImpl(StreamReader, LoadSettings) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.parser.ParserImpl
-
- ParserImpl(Scanner, LoadSettings) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.parser.ParserImpl
-
- ParserMinimalBase - Class in com.hazelcast.com.fasterxml.jackson.core.base
-
Intermediate base class used by all Jackson
JsonParser
implementations, but does not add any additional fields that depend
on particular method of obtaining input.
- ParserMinimalBase() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- ParserMinimalBase(int) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- parseString(String) - Static method in enum com.hazelcast.config.CacheDeserializedValues
-
Create instance from String
- parseString(String) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.lowlevel.Parse
-
Parse a YAML stream and produce parsing events.
- parseVersion(String, String, String) - Static method in class com.hazelcast.com.fasterxml.jackson.core.util.VersionUtil
-
Method used by PackageVersion
classes to decode version injected by Maven build.
- parseVersionPart(String) - Static method in class com.hazelcast.com.fasterxml.jackson.core.util.VersionUtil
-
- PARTIAL_MEMBER_DISCONNECTION_RESOLUTION_ALGORITHM_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The partial member disconnection resolution mechanism uses a graph algorithm
that finds a max-clique in non-polynomial time.
- PARTIAL_MEMBER_DISCONNECTION_RESOLUTION_HEARTBEAT_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The master member, i.e, the first member in the cluster member list
administrates the cluster and kicks unreachable members with the heartbeat
mechanism.
- Partition - Interface in com.hazelcast.partition
-
In Hazelcast the data is split up in partitions: by default, 271 and configurable through the 'hazelcast.partition.count'
ClusterProperty.
- PARTITION_BACKUP_SYNC_INTERVAL - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Interval for syncing backup replicas in seconds.
- PARTITION_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Total number of partitions in the Hazelcast cluster.
- PARTITION_FRAGMENTED_MIGRATION_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
When enabled, which is the default behavior, partitions are migrated/replicated
in small fragments instead of one big chunk.
- PARTITION_GROUP_HOST - Static variable in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
-
Deprecated.
- PARTITION_GROUP_NODE - Static variable in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
-
Metadata key definition for a node machine that containers/pods run on,
in case of container orchestration tools being used.
- PARTITION_GROUP_PLACEMENT - Static variable in enum 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_RACK - Static variable in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
-
Deprecated.
- PARTITION_GROUP_ZONE - Static variable in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
-
Metadata key definition for a low-latency link between (virtual) data centers in the same area
- PARTITION_MAX_PARALLEL_MIGRATIONS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Maximum number of partition migrations to be executed concurrently on a member.
- PARTITION_MAX_PARALLEL_REPLICATIONS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Maximum number of anti-entropy partition replications to be executed on a member.
- PARTITION_MIGRATION_INTERVAL - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Time in seconds to sleep after a migration task.
- PARTITION_MIGRATION_TIMEOUT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Timeout in seconds for all migration operations.
- PARTITION_OPERATION_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
The number of partition operation handler threads per member.
- PARTITION_TABLE_SEND_INTERVAL - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Interval for publishing partition table periodically to all cluster members
in seconds.
- PartitionAware<T> - Interface in com.hazelcast.partition
-
PartitionAware means that data will be based in the same member based on the partition key
and implementing tasks will be executed on the
PartitionAware.getPartitionKey()
's owner member.
- PartitionAwareKey<K,P> - Class in com.hazelcast.partition
-
- PartitionAwareKey(K, P) - Constructor for class com.hazelcast.partition.PartitionAwareKey
-
Creates a new PartitionAwareKey.
- 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 the
default
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.
- 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 in com.hazelcast.config
-
Type of member groups.
- PartitionGroupMetaData - Enum in com.hazelcast.spi.partitiongroup
-
This class contains the definition of known Discovery SPI metadata to support automatic
generation of zone aware and node aware backup strategies.
- PartitionGroupStrategy - Interface in com.hazelcast.spi.partitiongroup
-
A PartitionGroupStrategy
implementation defines a strategy
how backup groups are designed.
- partitionIdleTimeout() - Method in interface com.hazelcast.jet.pipeline.StreamSource
-
- PARTITIONING_STRATEGY_CLASS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
- PartitioningStrategy<K> - Interface in com.hazelcast.partition
-
PartitioningStrategy allows keys to be located on the same member.
- PartitioningStrategyConfig - Class in com.hazelcast.config
-
Contains the configuration for partitioning strategy.
- PartitioningStrategyConfig() - Constructor for class com.hazelcast.config.PartitioningStrategyConfig
-
- PartitioningStrategyConfig(PartitioningStrategyConfig) - Constructor for class com.hazelcast.config.PartitioningStrategyConfig
-
- PartitioningStrategyConfig(String) - Constructor for class com.hazelcast.config.PartitioningStrategyConfig
-
- PartitioningStrategyConfig(PartitioningStrategy) - Constructor for class com.hazelcast.config.PartitioningStrategyConfig
-
- partitionLost(MapPartitionLostEvent) - Method in interface com.hazelcast.map.listener.MapPartitionLostListener
-
Invoked when owner and all backups of a partition is lost for a specific map.
- partitionLost(PartitionLostEvent) - Method in interface com.hazelcast.partition.PartitionLostListener
-
Invoked when a 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<K,V> - Interface in com.hazelcast.query
-
- partitionPredicate(Object, Predicate<K, V>) - Static method in class com.hazelcast.query.Predicates
-
Creates a new partition predicate that restricts the execution of the target predicate to a single partition.
- PartitionService - Interface in com.hazelcast.partition
-
- PassThroughMergePolicy<V,T extends MergingValue<V>> - Class in com.hazelcast.spi.merge
-
Merges data structure entries from source to destination directly unless the merging entry is null
.
- PassThroughMergePolicy() - Constructor for class com.hazelcast.spi.merge.PassThroughMergePolicy
-
- PasswordCredentials - Interface in com.hazelcast.security
-
- path(String) - Method in interface com.hazelcast.com.fasterxml.jackson.core.TreeNode
-
Method for accessing value of the specified field of
an object node.
- path(int) - Method in interface com.hazelcast.com.fasterxml.jackson.core.TreeNode
-
Method for accessing value of the specified element of
an array node.
- pathAsPointer() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
-
Factory method for constructing a
JsonPointer
that points to the current
location within the stream that this context is for, excluding information about
"root context" (only relevant for multi-root-value cases)
- pathAsPointer(boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
-
Factory method for constructing a
JsonPointer
that points to the current
location within the stream that this context is for, optionally including
"root value index"
- 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(PredicateEx<? super T>, 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.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(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() - 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(PredicateEx<? super T>, FunctionEx<? super T, ? extends CharSequence>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
-
- peek(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() - Method in class com.hazelcast.org.snakeyaml.engine.v2.scanner.StreamReader
-
- peek(int) - Method in class com.hazelcast.org.snakeyaml.engine.v2.scanner.StreamReader
-
Peek the next index-th code point
- peek() - Method in interface com.hazelcast.transaction.TransactionalQueue
- peek(long, TimeUnit) - Method in interface com.hazelcast.transaction.TransactionalQueue
- peekEvent() - Method in interface com.hazelcast.org.snakeyaml.engine.v2.parser.Parser
-
Return the next event, but do not delete it from the stream.
- peekEvent() - Method in class com.hazelcast.org.snakeyaml.engine.v2.parser.ParserImpl
-
Get the next event.
- 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
-
- peekInputP(FunctionEx<T, ? extends CharSequence>, PredicateEx<T>, SupplierEx<Processor>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- peekInputP(ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- peekInputP(ProcessorSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- peekInputP(SupplierEx<Processor>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- 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
-
- peekOutputP(FunctionEx<? super T, ? extends CharSequence>, PredicateEx<? super T>, SupplierEx<Processor>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- peekOutputP(ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- peekOutputP(ProcessorSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- peekOutputP(SupplierEx<Processor>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- 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
-
- 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
-
- peekSnapshotP(SupplierEx<Processor>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- peekSnapshotP(ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- peekSnapshotP(ProcessorSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- peekToken() - Method in interface com.hazelcast.org.snakeyaml.engine.v2.scanner.Scanner
-
Return the next token, but do not delete it from the stream.
- peekToken() - Method in class com.hazelcast.org.snakeyaml.engine.v2.scanner.ScannerImpl
-
Return the next token, but do not delete it from the queue.
- PEM - Static variable in class com.hazelcast.com.fasterxml.jackson.core.Base64Variants
-
This variant is the one that predates
Base64Variants.MIME
: it is otherwise
identical, except that it mandates shorter line length.
- PercentEscaper - Class in com.hazelcast.org.snakeyaml.engine.external.com.google.gdata.util.common.base
-
A UnicodeEscaper
that escapes some set of Java characters using the
URI percent encoding scheme.
- PercentEscaper(String, boolean) - Constructor for class com.hazelcast.org.snakeyaml.engine.external.com.google.gdata.util.common.base.PercentEscaper
-
Constructs a URI escaper with the specified safe characters and optional
handling of the space character.
- PermissionConfig - Class in com.hazelcast.config
-
Contains the configuration for a permission.
- PermissionConfig() - Constructor for class com.hazelcast.config.PermissionConfig
-
- PermissionConfig(PermissionConfig.PermissionType, String, String) - Constructor for class com.hazelcast.config.PermissionConfig
-
- PermissionConfig(PermissionConfig) - Constructor for class com.hazelcast.config.PermissionConfig
-
- PermissionConfig.PermissionType - Enum in com.hazelcast.config
-
Type of permission
- PermissionPolicyConfig - Class in com.hazelcast.config
-
Contains the configuration for policy of permission
- PermissionPolicyConfig() - Constructor for class com.hazelcast.config.PermissionPolicyConfig
-
- PermissionPolicyConfig(String) - Constructor for class com.hazelcast.config.PermissionPolicyConfig
-
- PersistentMemoryConfig - Class in com.hazelcast.config
-
Configuration class for persistent memory devices (e.g.
- PersistentMemoryConfig() - Constructor for class com.hazelcast.config.PersistentMemoryConfig
-
- PersistentMemoryConfig(PersistentMemoryConfig) - Constructor for class com.hazelcast.config.PersistentMemoryConfig
-
- PersistentMemoryDirectoryConfig - Class in com.hazelcast.config
-
Configuration class for directories that persistent memories are mounted at.
- PersistentMemoryDirectoryConfig(String) - Constructor for class com.hazelcast.config.PersistentMemoryDirectoryConfig
-
Creates an instance with the directory
specified.
- PersistentMemoryDirectoryConfig(String, int) - Constructor for class com.hazelcast.config.PersistentMemoryDirectoryConfig
-
Creates an instance with the directory
and NUMA node specified.
- PersistentMemoryDirectoryConfig(PersistentMemoryDirectoryConfig) - Constructor for class com.hazelcast.config.PersistentMemoryDirectoryConfig
-
- PersistentMemoryMode - Enum in com.hazelcast.config
-
The enumeration of the supported persistent memory operational modes.
- PHONE_HOME_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Enable or disable the sending of phone home data to Hazelcast’s phone home
server.
- pickAddress() - Method in interface com.hazelcast.instance.AddressPicker
-
Picks both server socket listener address and public address.
- 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
-
- PickAnyAccumulator() - Constructor for class com.hazelcast.jet.accumulator.PickAnyAccumulator
-
Constructs an empty pickAny
accumulator.
- PickAnyAccumulator(T, long) - Constructor for class com.hazelcast.jet.accumulator.PickAnyAccumulator
-
Constructs a pickAny
accumulator with the full state passed in
the parameters.
- PingAware - Interface in com.hazelcast.splitbrainprotection
-
Split brain protection functions that need access to ICMP ping failure detector should implement this interface;
the instance of PingFailureDetector
used by this member's
ClusterHeartbeatManager
will be provided on initialization.
- 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.
- PNCounter - Interface in com.hazelcast.crdt.pncounter
-
PN (Positive-Negative) CRDT counter.
- PNCounterConfig - Class in com.hazelcast.config
-
- PNCounterConfig() - Constructor for class com.hazelcast.config.PNCounterConfig
-
- PNCounterConfig(String, int, String, boolean) - Constructor for class com.hazelcast.config.PNCounterConfig
-
- PNCounterConfig(String) - Constructor for class com.hazelcast.config.PNCounterConfig
-
- PNCounterConfig(PNCounterConfig) - Constructor for class com.hazelcast.config.PNCounterConfig
-
- PNCounterPermission - Class in com.hazelcast.security.permission
-
- PNCounterPermission(String, String...) - Constructor for class com.hazelcast.security.permission.PNCounterPermission
-
- 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(long, TimeUnit) - Method in interface com.hazelcast.collection.BaseQueue
-
Retrieves and removes the head of this queue, waiting up to the
specified wait time if necessary for an element to become available.
- poll() - Method in interface com.hazelcast.collection.IQueue
-
Retrieves and removes the head of this queue,
or returns null
if this queue is empty.
- poll(long, TimeUnit) - Method in interface com.hazelcast.collection.IQueue
-
Retrieves and removes the head of this queue, waiting up to the
specified wait time if necessary for an element to become available.
- poll() - Method in interface com.hazelcast.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.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.
- pop() - Method in class com.hazelcast.org.snakeyaml.engine.v2.common.ArrayStack
-
- 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.GenericRecordBuilder
-
- Portable - Interface in com.hazelcast.nio.serialization
-
Portable provides an alternative serialization method.
- PortableFactory - Interface in com.hazelcast.nio.serialization
-
PortableFactory is used to create Portable instances during de-serialization.
- PortableReader - Interface in com.hazelcast.nio.serialization
-
Provides means for reading portable fields from binary data in the form of java primitives,
arrays of java primitives, nested portable fields and array of portable fields.
- PortableWriter - Interface in com.hazelcast.nio.serialization
-
Provides means for writing portable fields to binary data in the form of java primitives,
arrays of java primitives, nested portable fields and arrays of portable fields.
- postponeMapFilling(Map<Object, Object>, Object, Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.BaseConstructor
-
- postponeSetFilling(Set<Object>, Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.BaseConstructor
-
- PostProcessingMapStore - Interface in com.hazelcast.map
-
Implement this interface if you modify the value in MapStore.store(K key, V value) method.
- Predicate<K,V> - Interface in com.hazelcast.query
-
Represents a map entry predicate.
- PredicateBuilder - Interface in com.hazelcast.query
-
This interface provides functionality to build a predicate.
- PredicateBuilder.EntryObject - Interface in com.hazelcast.query
-
This interface provides entry-level functionality related to building a predicate.
- PredicateConfig - Class in com.hazelcast.config
-
- PredicateConfig() - Constructor for class com.hazelcast.config.PredicateConfig
-
Creates a PredicateConfig without className/implementation.
- PredicateConfig(String) - Constructor for class com.hazelcast.config.PredicateConfig
-
Creates a PredicateConfig with the given className.
- PredicateConfig(PredicateConfig) - Constructor for class com.hazelcast.config.PredicateConfig
-
- PredicateConfig(Predicate) - Constructor for class com.hazelcast.config.PredicateConfig
-
Creates a PredicateConfig with the given implementation.
- PredicateEx<T> - Interface in com.hazelcast.function
-
- Predicates - Class in com.hazelcast.query
-
- PREFER_IPv4_STACK - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Prefer IPv4 network interface when picking a local address.
- 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(SupplierEx<? extends Processor>) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
- preferredLocalParallelism() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Returns the local parallelism the vertex should be configured with.
- preferredLocalParallelism(int) - Method in class com.hazelcast.jet.pipeline.SinkBuilder
-
Sets the local parallelism of the sink.
- PREFIX - Static variable in class com.hazelcast.org.snakeyaml.engine.v2.nodes.Tag
-
- prefix(int) - Method in class com.hazelcast.org.snakeyaml.engine.v2.scanner.StreamReader
-
peek the next length code points
- PrefixedDistributedObject - Interface in com.hazelcast.core
-
- prefixForward(int) - Method in class com.hazelcast.org.snakeyaml.engine.v2.scanner.StreamReader
-
prefix(length) immediately followed by forward(length)
- prepareEventContainerReplicationData(PartitionReplicationEvent, Collection<ServiceNamespace>) - Method in interface com.hazelcast.wan.WanMigrationAwarePublisher
-
Returns a container containing the WAN events for the given replication
event
and namespaces
to be replicated.
- 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.
- Present - Class in com.hazelcast.org.snakeyaml.engine.v2.api.lowlevel
-
Emit the events into a data stream (opposite for Parse)
- Present(DumpSettings) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.api.lowlevel.Present
-
Create Present (emitter)
- PrettyPrinter - Interface in com.hazelcast.com.fasterxml.jackson.core
-
Interface for objects that implement pretty printer functionality, such
as indentation.
- previousPage() - Method in interface com.hazelcast.query.PagingPredicate
-
Sets the page value to previous page.
- primaryCount() - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
Method mostly needed by unit tests; calculates number of
entries that are in the primary slot set.
- print(Object) - Method in class com.hazelcast.client.console.ClientConsoleApp
-
- print(Object) - Method in class com.hazelcast.console.ConsoleApp
-
- println(Object) - Method in class com.hazelcast.client.console.ClientConsoleApp
-
- 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 Type in com.hazelcast.spi.annotation
-
Marker for private functionality.
- ProbabilisticSplitBrainProtectionConfigBuilder - Class in com.hazelcast.config
-
Builder for a
SplitBrainProtectionConfig
configured with
ProbabilisticSplitBrainProtectionFunction
that
considers members present in the context of a split brain protection using a probabilistic,
adaptive split brain protection function.
- process(Node) - Method in class com.hazelcast.config.AbstractXmlConfigBuilder
-
- process(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.
- processDuplicateKeys(MappingNode) - Method in class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor
-
- processEventContainerReplicationData(int, T) - Method in interface com.hazelcast.wan.WanMigrationAwarePublisher
-
Processes the WAN event container received through intra-cluster replication
or migration.
- ProcessingGuarantee - Enum in com.hazelcast.jet.config
-
Defines what message processing guarantees are given under failure
conditions.
- 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
-
- processIOException(IOException) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.YamlOutputStreamWriter
-
- PROCESSOR - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
-
Global index of the
Processor
sourcing the metric.
- 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.Context - Interface in com.hazelcast.jet.core
-
Context passed to the processor in the
init()
call.
- 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).
- ProcessorMetaSupplier - Interface in com.hazelcast.jet.core
-
- 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.
- Processors - Class in com.hazelcast.jet.core.processor
-
Static utility class with factory methods for Jet processors.
- ProcessorSupplier - Interface in com.hazelcast.jet.core
-
- ProcessorSupplier.Context - Interface in com.hazelcast.jet.core
-
Context passed to the supplier in the
init()
call.
- 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
- 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<I,O> - Interface in com.hazelcast.projection
-
Enables transforming object into other objects.
- Projections - Class in com.hazelcast.projection
-
A utility class to create basic
Projection
instances.
- promoteLocalLiteMember() - Method in interface com.hazelcast.cluster.Cluster
-
Promotes local lite member to data member.
- promoteToCPMember() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
-
Promotes the local Hazelcast member to the CP role.
- properties - Variable in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
-
- properties - Variable in class com.hazelcast.config.AbstractWanPublisherConfig
-
- propertiesByInstanceItself(HazelcastInstance) - Static method in class com.hazelcast.cache.HazelcastCachingProvider
-
Create the
Properties
with the provided instance itself.
- propertiesByInstanceName(String) - Static method in class com.hazelcast.cache.HazelcastCachingProvider
-
Create the
Properties
with the provided instance name.
- propertiesByLocation(String) - Static method in class com.hazelcast.cache.HazelcastCachingProvider
-
Create the
Properties
with the provided config file location.
- PROPERTY_CIPHER_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
-
Replacer property name to configure
Cipher
algorithm name.
- PROPERTY_KEY_LENGTH_BITS - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
-
Replacer property name to configure key length (in bits).
- PROPERTY_PASSWORD_FILE - Static variable in class com.hazelcast.config.replacer.EncryptionReplacer
-
Replacer property name to configure path to a password file which content should be used as part of the encryption
password.
- PROPERTY_PASSWORD_NETWORK_INTERFACE - Static variable in class com.hazelcast.config.replacer.EncryptionReplacer
-
Replacer property name to configure network interface name used to retrieve MAC address used as part of the encryption
password.
- PROPERTY_PASSWORD_USER_PROPERTIES - Static variable in class com.hazelcast.config.replacer.EncryptionReplacer
-
Replacer property name to configure true
/false
flag contolling if users properties should be used as part
of the encryption password.
- PROPERTY_SALT_LENGTH_BYTES - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
-
Replacer property name to configure salt length (in bytes).
- PROPERTY_SECRET_KEY_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
-
Replacer property name to configure
SecretKeySpec
algorithm name.
- PROPERTY_SECRET_KEY_FACTORY_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
-
- PROPERTY_SECURITY_PROVIDER - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
-
Replacer property name to configure Java Security provider name used for
Cipher
and
SecretKeyFactory
selection.
- PropertyDefinition - Interface in com.hazelcast.config.properties
-
This interface describes an extended approach of the currently available
pure property based configuration inside Hazelcast and helps implementing
an automatic and transparent way to verify configuration as well as converting
types based on provided validators and converters.
- PropertyReplacer - Class in com.hazelcast.config.replacer
-
- PropertyReplacer() - Constructor for class com.hazelcast.config.replacer.PropertyReplacer
-
- PropertyTypeConverter - Enum in com.hazelcast.config.properties
-
This enum class contains basic
TypeConverter
implementations to
convert strings to all common basic Java types.
- protocolType - Variable in class com.hazelcast.config.EndpointConfig
-
- ProtocolType - Enum in com.hazelcast.instance
-
Types of server sockets.
- ProxyFactoryConfig - Class in com.hazelcast.client.config
-
This class is related to SPI.
- ProxyFactoryConfig() - Constructor for class com.hazelcast.client.config.ProxyFactoryConfig
-
- ProxyFactoryConfig(String, String) - Constructor for class com.hazelcast.client.config.ProxyFactoryConfig
-
- ProxyFactoryConfig(String, ClientProxyFactory) - Constructor for class com.hazelcast.client.config.ProxyFactoryConfig
-
- ProxyFactoryConfig(ProxyFactoryConfig) - Constructor for class com.hazelcast.client.config.ProxyFactoryConfig
-
- publish(E) - Method in interface com.hazelcast.topic.ITopic
-
Publishes the message to all subscribers of this topic.
- publishAll(Collection<? extends E>) - Method in interface com.hazelcast.topic.ITopic
-
Publishes all messages to all subscribers of this topic.
- publishAllAsync(Collection<? extends E>) - Method in interface com.hazelcast.topic.ITopic
-
Publishes all messages asynchronously to all subscribers of this topic.
- publishAsync(E) - Method in interface com.hazelcast.topic.ITopic
-
Publishes the message asynchronously to all subscribers of this topic.
- publisherId - Variable in class com.hazelcast.config.AbstractWanPublisherConfig
-
- publishReplicationEvent(WanEvent<T>) - Method in interface com.hazelcast.wan.WanPublisher
-
Publish the eventObject
WAN replication event.
- publishReplicationEventBackup(WanEvent<T>) - Method in interface com.hazelcast.wan.WanPublisher
-
Publish the eventObject
WAN replication event backup.
- push(T) - Method in class com.hazelcast.org.snakeyaml.engine.v2.common.ArrayStack
-
- 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(Tag<E>, E) - Method in class com.hazelcast.jet.datamodel.ItemsByTag
-
Associates the supplied value with the supplied tag.
- put(K, V) - Method in interface com.hazelcast.map.BaseMap
-
Associates the specified value with the specified key in this map.
- put(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.BaseMap
-
Associates the specified value with the specified key in this map
with a given ttl (time to live) value.
- put(K, V) - Method in interface com.hazelcast.map.IMap
-
Associates the specified value with the specified key in this map.
- put(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Puts an entry into this map with a given TTL (time to live) value.
- put(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Puts an entry into this map with a given TTL (time to live) value and
max idle time value.
- put(K, V) - Method in interface com.hazelcast.multimap.BaseMultiMap
-
Stores a key-value pair in the multimap.
- put(K, V) - Method in interface com.hazelcast.multimap.MultiMap
-
Stores a key-value pair in the multimap.
- put(K, V, long, TimeUnit) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
-
Associates a given value to the specified key and replicates it to the
cluster.
- put(K, V) - Method in interface com.hazelcast.transaction.TransactionalMap
-
- put(K, V, long, TimeUnit) - Method in interface com.hazelcast.transaction.TransactionalMap
-
- put(K, V) - Method in interface com.hazelcast.transaction.TransactionalMultiMap
-
Stores a key-value pair in the multimap.
- putAll(Map<? extends K, ? extends V>, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Copies all of the entries from the given map to the cache using a custom
ExpiryPolicy
.
- putAll(Map<? extends K, ? extends V>) - Method in interface com.hazelcast.map.IMap
- putAllAsync(Map<? extends K, ? extends V>) - Method in interface com.hazelcast.map.IMap
-
Asynchronously copies all of the mappings from the specified map to this map.
- putAllAsync(Map<? extends K, Collection<? extends V>>) - Method in interface com.hazelcast.multimap.MultiMap
-
Stores the given Map in the MultiMap asynchronously.
- putAllAsync(K, Collection<? extends V>) - Method in interface com.hazelcast.multimap.MultiMap
-
Stores the given Collection in the specified key of a MultiMap asynchronously.
- putAsync(K, V) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously associates the specified value with the specified key in the cache.
- putAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously associates the specified value with the specified key in the cache using
a custom ExpiryPolicy
.
- putAsync(K, V) - Method in interface com.hazelcast.map.IMap
-
Asynchronously puts the given key and value.
- putAsync(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Asynchronously puts the given key and value into this map with a given TTL (time to live) value.
- putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Asynchronously puts the given key and value into this map with a given
TTL (time to live) value and max idle time value.
- putIfAbsent(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Associates the specified key with the given value if and only if there is not yet
a mapping defined for the specified key.
- putIfAbsent(K, V) - Method in interface com.hazelcast.map.BaseMap
-
If the specified key is not already associated
with a value, associate it with the given value.
- putIfAbsent(K, V) - Method in interface com.hazelcast.map.IMap
-
If the specified key is not already associated
with a value, associate it with the given value.
- putIfAbsent(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Puts an entry into this map with a given TTL (time to live) value,
if the specified key is not already associated with a value.
- putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Puts an entry into this map with a given TTL (time to live) value and
max idle time value.
- putIfAbsent(K, V) - Method in interface com.hazelcast.transaction.TransactionalMap
-
- 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
-
- putQuotedUTF8(ByteBuffer) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SerializedString
-
- putQuotedUTF8(ByteBuffer) - Method in interface com.hazelcast.com.fasterxml.jackson.core.SerializableString
-
Method for appending JSON-escaped UTF-8 encoded String value into given
ByteBuffer
, if it fits.
- putTransient(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
- putTransient(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
- putUnquotedUTF8(ByteBuffer) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SerializedString
-
- putUnquotedUTF8(ByteBuffer) - Method in interface com.hazelcast.com.fasterxml.jackson.core.SerializableString
-
Method for appending unquoted ('raw') UTF-8 encoded String value into given
ByteBuffer
, if it fits.
- 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
-
- RandomLB - Class in com.hazelcast.client.util
-
- RandomLB() - Constructor for class com.hazelcast.client.util.RandomLB
-
- RawBytesFileFormat - Class in com.hazelcast.jet.pipeline.file
-
FileFormat
for binary files where the whole file is one byte[]
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.com.fasterxml.jackson.core.io.MergedStream
-
- read(byte[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.MergedStream
-
- read(byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.MergedStream
-
- read() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.UTF32Reader
-
Although this method is implemented by the base class, AND it should
never be called by main code, let's still implement it bit more
efficiently just in case
- read(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.UTF32Reader
-
- read() - Method in class com.hazelcast.config.ConfigStream
-
- read(byte[]) - Method in class com.hazelcast.config.ConfigStream
-
- read(byte[], int, int) - Method in class com.hazelcast.config.ConfigStream
-
- read(byte[]) - Method in interface com.hazelcast.nio.serialization.ByteArraySerializer
-
Converts given byte array to object
- read(ObjectDataInput) - Method in interface com.hazelcast.nio.serialization.StreamSerializer
-
Reads object from objectDataInputStream
- read(byte[], Class) - Method in interface com.hazelcast.nio.serialization.TypedByteArrayDeserializer
-
Reads object from objectDataInputStream
- read(ObjectDataInput, Class) - Method in interface com.hazelcast.nio.serialization.TypedStreamDeserializer
-
Reads object from objectDataInputStream
- read(char[], int, int) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.YamlUnicodeReader
-
- read(String, ValueCallback<T>) - Method in interface com.hazelcast.query.extractor.ValueReader
-
Read the value of the attribute specified by the path and returns the result via the callback.
- read(String, ValueCollector<T>) - Method in interface com.hazelcast.query.extractor.ValueReader
-
Read the value of the attribute specified by the path and returns the result directly to the collector.
- read(long) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
-
Reads one item from the ringbuffer.
- readBinaryValue(Base64Variant, OutputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- readBinaryValue(Base64Variant, OutputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- readBinaryValue(Base64Variant, OutputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- readBinaryValue(Base64Variant, OutputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- readBinaryValue(Base64Variant, OutputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- readBinaryValue(OutputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- readBinaryValue(Base64Variant, OutputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- readBinaryValue(Base64Variant, OutputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- readBoolean(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readBooleanArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-
- readBooleanArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readByte(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readByteArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-
- readByteArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readCacheP(String) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- readChar(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readCharArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-
- readCharArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readCount() - Method in interface com.hazelcast.ringbuffer.ReadResultSet
-
Returns the number of items that have been read before filtering.
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-
- readData(ObjectDataInput) - Method in class com.hazelcast.cluster.Address
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.AttributeConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.BitmapIndexOptions
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.CollectionConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.DiscoveryConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.DurableExecutorConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.EntryListenerConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.EventJournalConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.EvictionConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.ExecutorConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.HotRestartConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.IndexConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.ItemListenerConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.ListenerConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.MapConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.MapStoreConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.MergePolicyConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.MerkleTreeConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.MultiMapConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.NearCacheConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.NearCachePreloaderConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.PartitioningStrategyConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.PermissionConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.PNCounterConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.PredicateConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.QueryCacheConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.QueueConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.QueueStoreConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.ReliableTopicConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.RingbufferConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.RingbufferStoreConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.TopicConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.WanConsumerConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.WanReplicationConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.WanReplicationRef
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.WanSyncConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.console.Echo
-
- readData(ObjectDataInput) - Method in class com.hazelcast.instance.EndpointQualifier
-
- readData(ObjectDataInput) - Method in class com.hazelcast.jet.config.JobConfig
-
- 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.Vertex
-
- readData(ObjectDataInput) - Method in interface com.hazelcast.nio.serialization.DataSerializable
-
Reads fields from the input stream
- readData(ObjectDataInput) - Method in class com.hazelcast.partition.PartitionAwareKey
-
- readData(ObjectDataInput) - Method in class com.hazelcast.security.SimpleTokenCredentials
-
- readData(ObjectDataInput) - Method in class com.hazelcast.security.UsernamePasswordCredentials
-
- readData(ObjectDataInput) - Method in class com.hazelcast.transaction.TransactionOptions
-
- readData(ObjectDataInput) - Method in class com.hazelcast.version.MemberVersion
-
- readData(ObjectDataInput) - Method in class com.hazelcast.version.Version
-
- readDate(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
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
-
Reads an array of Date's to LocalDate[]
- readDecimal(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Reads a decimal which is arbitrary precision and scale floating-point number to BigDecimal
- readDecimalArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Reads an array of Decimal's to BigDecimal[]
- readDouble(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readDoubleArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-
- readDoubleArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- ReaderBasedJsonParser - Class in com.hazelcast.com.fasterxml.jackson.core.json
-
This is a concrete implementation of
JsonParser
, which is
based on a
Reader
to handle low-level character
conversion tasks.
- ReaderBasedJsonParser(IOContext, int, Reader, ObjectCodec, CharsToNameCanonicalizer, char[], int, int, boolean) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
Method called when caller wants to provide input buffer directly,
and it may or may not be recyclable use standard recycle context.
- ReaderBasedJsonParser(IOContext, int, Reader, ObjectCodec, CharsToNameCanonicalizer) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
Method called when input comes as a
Reader
, and buffer allocation
can be done using default mechanism.
- ReaderException - Exception in com.hazelcast.org.snakeyaml.engine.v2.exceptions
-
- ReaderException(String, int, int, String) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v2.exceptions.ReaderException
-
- readFactories(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
-
- readFilesP(String, Charset, String, boolean, BiFunctionEx<? super String, ? super String, ? extends R>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- readFilesP(String, String, boolean, FunctionEx<? super Path, ? extends Stream<I>>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- readFilesP(String, String, boolean, boolean, FunctionEx<? super Path, ? extends Stream<I>>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- readFloat(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readFloatArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-
- readFloatArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readFrom(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).
- readInt(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readIntArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-
- readIntArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readJdbcP(SupplierEx<? extends Connection>, ToResultSetFunction, FunctionEx<? super ResultSet, ? extends T>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- readJdbcP(String, String, 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
-
- readLong(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readLongArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-
- readLongArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- 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
-
- readMapP(String, Predicate<K, V>, Projection<? super Map.Entry<K, V>, ? extends T>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- readObject() - Method in interface com.hazelcast.nio.ObjectDataInput
-
- readObject(Class) - Method in interface com.hazelcast.nio.ObjectDataInput
-
- readOne(long) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
-
Reads one item from the Ringbuffer.
- ReadOnly - Interface in com.hazelcast.core
-
Allows notifying Hazelcast that the processing unit implementing this interface will not do any modifications.
- readPortable(PortableReader) - Method in interface com.hazelcast.nio.serialization.Portable
-
Read portable fields using PortableReader
- readPortable(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readPortableArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readRemoteCacheP(String, ClientConfig) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- readRemoteListP(String, ClientConfig) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- readRemoteMapP(String, ClientConfig) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- readRemoteMapP(String, ClientConfig, Predicate<K, V>, Projection<? super Map.Entry<K, V>, ? extends T>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- readResolve() - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
-
- readResolve() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SerializedString
-
- readResolve() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method that we need to override to actually make restoration go
through constructors etc: needed to allow JDK serializability of
factory instances.
- ReadResultSet<E> - Interface in com.hazelcast.ringbuffer
-
- readShort(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readShortArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-
- readShortArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readString() - Method in interface com.hazelcast.nio.ObjectDataInput
-
- readString(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readStringArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-
- readStringArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readTenant(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
-
- readTime(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Reads a time field consisting of hour, minute, seconds and nanos parts to LocalTime
- readTimeArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
Reads an array of Time's to LocalTime[]
- readTimestamp(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
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
-
Reads an array of Timestamp's to LocalDateTime[]
- readTimestampWithTimezone(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
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
-
Reads an array of TimestampWithTimezone's to OffsetDateTime[]
- readTree(JsonParser) - Method in class com.hazelcast.com.fasterxml.jackson.core.ObjectCodec
-
Method for deserializing JSON content as tree expressed
using set of
TreeNode
instances.
- readTree(JsonParser) - Method in class com.hazelcast.com.fasterxml.jackson.core.TreeCodec
-
- readUTF() - Method in interface com.hazelcast.nio.ObjectDataInput
-
- readUTF(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readUTFArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-
- readUTFArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readValue(JsonParser, Class<T>) - Method in class com.hazelcast.com.fasterxml.jackson.core.ObjectCodec
-
Method to deserialize JSON content into a non-container
type (it can be an array type, however): typically a bean, array
or a wrapper type (like
Boolean
).
- readValue(JsonParser, TypeReference<T>) - Method in class com.hazelcast.com.fasterxml.jackson.core.ObjectCodec
-
Method to deserialize JSON content into a Java type, reference
to which is passed as argument.
- readValue(JsonParser, ResolvedType) - Method in class com.hazelcast.com.fasterxml.jackson.core.ObjectCodec
-
Method to deserialize JSON content into a POJO, type specified
with fully resolved type object (so it can be a generic type,
including containers like
Collection
and
Map
).
- readValueAs(Class<T>) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method to deserialize JSON content into a non-container
type (it can be an array type, however): typically a bean, array
or a wrapper type (like
Boolean
).
- readValueAs(TypeReference<?>) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method to deserialize JSON content into a Java type, reference
to which is passed as argument.
- readValueAsTree() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method to deserialize JSON content into equivalent "tree model",
represented by root
TreeNode
of resulting model.
- readValues(JsonParser, Class<T>) - Method in class com.hazelcast.com.fasterxml.jackson.core.ObjectCodec
-
Method for reading sequence of Objects from parser stream,
all with same specified value type.
- readValues(JsonParser, TypeReference<T>) - Method in class com.hazelcast.com.fasterxml.jackson.core.ObjectCodec
-
Method for reading sequence of Objects from parser stream,
all with same specified value type.
- readValues(JsonParser, ResolvedType) - Method in class com.hazelcast.com.fasterxml.jackson.core.ObjectCodec
-
Method for reading sequence of Objects from parser stream,
all with same specified value type.
- readValuesAs(Class<T>) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method for reading sequence of Objects from parser stream,
all with same specified value type.
- readValuesAs(TypeReference<T>) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method for reading sequence of Objects from parser stream,
all with same specified value type.
- RealmConfig - Class in com.hazelcast.config.security
-
Security realm represents the security configuration for part of the system (e.g.
- RealmConfig() - Constructor for class com.hazelcast.config.security.RealmConfig
-
- RealmConfigCallback - Class in com.hazelcast.security
-
- RealmConfigCallback(String) - Constructor for class com.hazelcast.security.RealmConfigCallback
-
- rebalance(FunctionEx<? super T, ? extends K>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
-
- 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(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
-
- rebalance() - Method in interface com.hazelcast.jet.pipeline.StreamStage
-
- rebuild() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method that allows construction of differently configured factory, starting
with settings of this factory.
- RECEIVED_BATCHES - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
-
Counts incoming data item batches on input
Edge
s of particular
Vertex
instances running on various
Processor
s.
- RECEIVED_COUNT - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
-
Counts incoming data items on input
Edge
s of particular
Vertex
instances running on various
Processor
s.
- 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 with
RecentlyActiveSplitBrainProtectionFunction
that
considers members present in the context of a split brain protection if the last received heartbeat
is within a recent window of time.
- recreateAttachedDirectory(String) - Method in interface com.hazelcast.jet.core.ProcessorSupplier.Context
-
- recreateAttachedDirectory(String) - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
-
- recreateAttachedFile(String) - Method in interface com.hazelcast.jet.core.ProcessorSupplier.Context
-
- 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 item attribute
.
- RegexConfigPatternMatcher - Class in com.hazelcast.config.matcher
-
This ConfigPatternMatcher
uses Java regular expressions for matching.
- RegexConfigPatternMatcher() - Constructor for class com.hazelcast.config.matcher.RegexConfigPatternMatcher
-
- RegexConfigPatternMatcher(int) - Constructor for class com.hazelcast.config.matcher.RegexConfigPatternMatcher
-
- 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(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 class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
Method called by the using code to indicate it is done with this instance.
- release() - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
-
Method called by the using code to indicate it is done with this instance.
- release() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
-
Clean up method to call to release all buffers this object may be
using.
- release() - Method in interface com.hazelcast.cp.ISemaphore
-
Releases a permit and increases the number of available permits by one.
- release(int) - Method in interface com.hazelcast.cp.ISemaphore
-
Releases the given number of permits and increases the number of
available permits by that amount.
- releaseBase64Buffer(byte[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
- releaseBuffered(OutputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- releaseBuffered(OutputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- releaseBuffered(Writer) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- releaseBuffered(OutputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- releaseBuffered(OutputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- releaseBuffered(OutputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method that can be called to push back any content that
has been read but not consumed by the parser.
- releaseBuffered(Writer) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method that can be called to push back any content that
has been read but not consumed by the parser.
- releaseBuffers() - Static method in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecyclers
-
- releaseBuffers() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
Method called to indicate that the underlying buffers should now
be recycled if they haven't yet been recycled.
- releaseByteBuffer(int, byte[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
-
- releaseCharBuffer(int, char[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
-
- releaseConcatBuffer(char[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
- releaseNameCopyBuffer(char[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
- releaseReadIOBuffer(byte[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
Method to call when all the processing buffers can be safely
recycled.
- releaseTokenBuffer(char[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
- releaseWriteEncodingBuffer(byte[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
- ReliableMessageListener<E> - Interface in com.hazelcast.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.
- 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.
- ReliableTopicConfig - Class in com.hazelcast.config
-
Configuration for a reliable
ITopic
.
- ReliableTopicConfig() - Constructor for class com.hazelcast.config.ReliableTopicConfig
-
- ReliableTopicConfig(String) - Constructor for class com.hazelcast.config.ReliableTopicConfig
-
Creates a new ReliableTopicConfig with default settings.
- ReliableTopicConfig(ReliableTopicConfig) - Constructor for class com.hazelcast.config.ReliableTopicConfig
-
Creates a new ReliableTopicConfig by cloning an existing one.
- ReliableTopicPermission - Class in com.hazelcast.security.permission
-
- ReliableTopicPermission(String, String...) - Constructor for class com.hazelcast.security.permission.ReliableTopicPermission
-
- remainingCapacity() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
-
Returns the remaining capacity of the ringbuffer.
- remoteCache(String, ClientConfig) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink that puts Map.Entry
s it receives into a Hazelcast
ICache
with the specified name in a remote cluster identified by
the supplied ClientConfig
.
- 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 supplied
ClientConfig
and emits them as Map.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 Hazelcast
ICache
with the specified name from a
remote cluster.
- remoteCacheJournal(String, ClientConfig, JournalInitialPosition) - Static method in class com.hazelcast.jet.pipeline.Sources
-
- 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
supplied ClientConfig
.
- 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 supplied ClientConfig
.
- remoteMap(String, ClientConfig) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
Returns a sink that puts Map.Entry
s it receives into a Hazelcast
IMap
with the specified name in a remote cluster identified by
the supplied ClientConfig
.
- 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 supplied ClientConfig
.
- 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 supplied
ClientConfig
and emits them as Map.Entry
.
- 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
supplied ClientConfig
.
- 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 Hazelcast
IMap
with the specified name from a
remote cluster.
- remoteMapJournal(String, ClientConfig, JournalInitialPosition) - Static method in class com.hazelcast.jet.pipeline.Sources
-
- 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
-
- remoteMapWithMerging(String, ClientConfig, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends V>, BinaryOperatorEx<V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
- remoteMapWithMerging(String, ClientConfig, BinaryOperatorEx<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
-
- remoteMapWithUpdating(String, ClientConfig, BiFunctionEx<? super V, ? super E, ? extends V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
- 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(Object) - Method in interface com.hazelcast.map.BaseMap
-
Removes the mapping for a key from this map if it is present.
- remove(Object, Object) - Method in interface com.hazelcast.map.BaseMap
-
Removes the entry for a key only if currently mapped to a given value.
- remove(Object) - Method in interface com.hazelcast.map.IMap
-
Removes the mapping for a key from this map if it is present.
- remove(Object, Object) - Method in interface com.hazelcast.map.IMap
-
Removes the entry for a key only if currently mapped to a given value.
- remove(Object, Object) - Method in interface com.hazelcast.multimap.BaseMultiMap
-
Removes the given key value pair from the multimap.
- remove(Object) - Method in interface com.hazelcast.multimap.BaseMultiMap
-
Removes all the entries associated with the given key.
- remove(Object, Object) - Method in interface com.hazelcast.multimap.MultiMap
-
Removes the given key value pair from the multimap.
- remove(Object) - Method in interface com.hazelcast.multimap.MultiMap
-
Removes all the entries with the given key.
- remove() - Method in class com.hazelcast.spi.merge.RingbufferMergeDataReadOnlyIterator
-
- remove(E) - Method in interface com.hazelcast.transaction.TransactionalList
-
Removes an item from the transactional list.
- remove(Object) - Method in interface com.hazelcast.transaction.TransactionalMap
-
- remove(Object, Object) - Method in interface com.hazelcast.transaction.TransactionalMap
-
- remove(Object, Object) - Method in interface com.hazelcast.transaction.TransactionalMultiMap
-
Removes the given key value pair from the multimap.
- remove(Object) - Method in interface com.hazelcast.transaction.TransactionalMultiMap
-
Removes all the entries associated with the given key.
- remove(E) - Method in interface com.hazelcast.transaction.TransactionalSet
-
Remove item from transactional set.
- removeAll(Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
-
Removes all entries which match with the supplied predicate.
- removeAsync(K) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously removes the mapping for a key from this cache if it is present.
- removeAsync(K, V) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously removes the mapping for the given key if and only if the
currently mapped value equals to the value of oldValue
.
- removeAsync(K) - Method in interface com.hazelcast.map.IMap
-
Asynchronously removes the given key, returning an
CompletionStage
on which the caller can register further computation stages to be invoked
upon remove operation completion or block waiting for the operation to
complete using one of blocking ways to wait on
CompletionStage.toCompletableFuture()
.
- removeAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- removeCache(String, boolean) - Method in interface com.hazelcast.cache.HazelcastCacheManager
-
Removes the associated cache with the given cache name.
- removeCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.config.AbstractCacheConfig
-
Remove a configuration for a CacheEntryListener
.
- removeCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in interface com.hazelcast.config.CacheConfiguration
-
Remove a configuration for a CacheEntryListener
.
- removeClientListener(UUID) - Method in interface com.hazelcast.client.ClientService
-
Removes a ClientListener.
- removeCounter(String) - Method in class com.hazelcast.wan.WanEventCounters
-
Removes the counter for the given dataStructureName
.
- removeCPMember(UUID) - Method in interface com.hazelcast.cp.CPSubsystemManagementService
-
Removes the given unreachable CP member from the active CP members list
and all CP groups it belongs to.
- removeDistributedObjectListener(UUID) - Method in interface com.hazelcast.core.HazelcastInstance
-
Removes the specified Distributed Object listener.
- removeEntryListener(UUID) - Method in interface com.hazelcast.map.IMap
-
Removes the specified entry listener.
- removeEntryListener(UUID) - Method in interface com.hazelcast.map.QueryCache
-
- removeEntryListener(UUID) - Method in interface com.hazelcast.multimap.MultiMap
-
Removes the specified entry listener.
- removeEntryListener(UUID) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
-
Removes the specified entry listener.
- removeGroupAvailabilityListener(UUID) - Method in interface com.hazelcast.cp.CPSubsystem
-
Removes CPGroupAvailabilityListener registration.
- removeInterceptor(String) - Method in interface com.hazelcast.map.IMap
-
Removes the given interceptor for this map,
so it will not intercept operations anymore.
- removeItemListener(UUID) - Method in interface com.hazelcast.collection.ICollection
-
Removes the specified item listener.
- removeLifecycleListener(UUID) - Method in interface com.hazelcast.core.LifecycleService
-
Removes a lifecycle listener.
- removeLogListener(LogListener) - Method in interface com.hazelcast.logging.LoggingService
-
- removeMember(Member) - Method in interface com.hazelcast.spi.partitiongroup.MemberGroup
-
- removeMembershipListener(UUID) - Method in interface com.hazelcast.cluster.Cluster
-
Removes the specified MembershipListener.
- removeMembershipListener(UUID) - Method in interface com.hazelcast.cp.CPSubsystem
-
Removes membership listener registration.
- removeMessageListener(UUID) - Method in interface com.hazelcast.topic.ITopic
-
Stops receiving messages for the given message listener.
- removeMigrationListener(UUID) - Method in interface com.hazelcast.partition.PartitionService
-
Removes a MigrationListener.
- 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
-
- replace(K, V, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Atomically replaces the currently assigned value for the given key with the specified
newValue
if and only if the currently assigned value equals the value of
oldValue
using a custom ExpiryPolicy
.
- replace(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Atomically replaces the assigned value of the given key by the specified value
using a custom ExpiryPolicy
.
- replace(JetCommandLine.TargetsMixin) - Method in class com.hazelcast.jet.server.JetCommandLine.TargetsMixin
-
- replace(K, V) - Method in interface com.hazelcast.map.BaseMap
-
Replaces the entry for a key only if it is currently mapped to some value.
- replace(K, V, V) - Method in interface com.hazelcast.map.BaseMap
-
Replaces the entry for a key only if currently mapped to a given value.
- replace(K, V, V) - Method in interface com.hazelcast.map.IMap
-
Replaces the entry for a key only if currently mapped to a given value.
- replace(K, V) - Method in interface com.hazelcast.map.IMap
-
Replaces the entry for a key only if it is currently mapped to some value.
- replace(K, V) - Method in interface com.hazelcast.transaction.TransactionalMap
-
- replace(K, V, V) - Method in interface com.hazelcast.transaction.TransactionalMap
-
- replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.hazelcast.map.IMap
- replaceAsync(K, V) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously replaces the assigned value of the given key by the specified value.
- replaceAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously replaces the assigned value of the given key by the specified value
using a custom ExpiryPolicy
.
- replaceAsync(K, V, V) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously replaces the currently assigned value for the given key with the specified
newValue
if and only if the currently assigned value equals the value of
oldValue
.
- replaceAsync(K, V, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously replaces the currently assigned value for the given key with the specified
newValue
if and only if the currently assigned value equals the value of
oldValue
using a custom ExpiryPolicy
.
- replaceVariables(Node) - Method in class com.hazelcast.config.AbstractYamlConfigBuilder
-
- replicaMigrationCompleted(ReplicaMigrationEvent) - Method in interface com.hazelcast.partition.MigrationListener
-
Called when a partition replica migration is completed successfully.
- ReplicaMigrationEvent - Interface in com.hazelcast.partition
-
An event fired when a partition replica migration completes or fails.
- replicaMigrationFailed(ReplicaMigrationEvent) - Method in interface com.hazelcast.partition.MigrationListener
-
Called when a partition replica migration is failed.
- ReplicatedMap<K,V> - Interface in com.hazelcast.replicatedmap
-
A ReplicatedMap is a map data structure with weak consistency
and has entries stored locally on every node of the cluster.
- ReplicatedMapCantBeCreatedOnLiteMemberException - Exception in com.hazelcast.replicatedmap
-
- ReplicatedMapCantBeCreatedOnLiteMemberException(Address) - Constructor for exception com.hazelcast.replicatedmap.ReplicatedMapCantBeCreatedOnLiteMemberException
-
- ReplicatedMapCantBeCreatedOnLiteMemberException(String) - Constructor for exception com.hazelcast.replicatedmap.ReplicatedMapCantBeCreatedOnLiteMemberException
-
- ReplicatedMapConfig - Class in com.hazelcast.config
-
- ReplicatedMapConfig() - Constructor for class com.hazelcast.config.ReplicatedMapConfig
-
- ReplicatedMapConfig(String) - Constructor for class com.hazelcast.config.ReplicatedMapConfig
-
Creates a ReplicatedMapConfig with the given name.
- ReplicatedMapConfig(ReplicatedMapConfig) - Constructor for class com.hazelcast.config.ReplicatedMapConfig
-
- ReplicatedMapPermission - Class in com.hazelcast.security.permission
-
- ReplicatedMapPermission(String, String...) - Constructor for class com.hazelcast.security.permission.ReplicatedMapPermission
-
- replicatedMapService(String) - Static method in class com.hazelcast.jet.pipeline.ServiceFactories
-
Returns a factory that provides a
ReplicatedMap
as the service
object.
- reportEvent(long) - Method in interface com.hazelcast.jet.core.WatermarkPolicy
-
Called to report the observation of an event with the given timestamp.
- reportInvalidBase64Char(Base64Variant, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- reportInvalidBase64Char(Base64Variant, int, int, String) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- reportInvalidNumber(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
Method called to throw an exception for input token that looks like a number
based on first character(s), but is not valid according to rules of format.
- reportOverflowInt() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
Method called to throw an exception for integral (not floating point) input
token with value outside of Java signed 32-bit range when requested as int
.
- reportOverflowInt(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- reportOverflowInt(String, JsonToken) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- reportOverflowLong() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
Method called to throw an exception for integral (not floating point) input
token with value outside of Java signed 64-bit range when requested as long
.
- reportOverflowLong(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- reportOverflowLong(String, JsonToken) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- reportTooManyCollisions(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
-
- reportUnexpectedNumberChar(int, String) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- represent(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.representer.BaseRepresenter
-
Represent the provided Java instance to a Node
- RepresentArray() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentArray
-
- RepresentBoolean() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentBoolean
-
- RepresentByteArray() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentByteArray
-
- representData(Object) - Method in interface com.hazelcast.org.snakeyaml.engine.v2.api.RepresentToNode
-
Create a Node
- representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.representer.BaseRepresenter
-
- representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentArray
-
- representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentBoolean
-
- representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentByteArray
-
- representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentEnum
-
- representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentIterator
-
- representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentList
-
- representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentMap
-
- representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentNull
-
- representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentNumber
-
- representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentOptional
-
- representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentPrimitiveArray
-
- representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentSet
-
- representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentString
-
- representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentUuid
-
- representedObjects - Variable in class com.hazelcast.org.snakeyaml.engine.v2.representer.BaseRepresenter
-
- RepresentEnum() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentEnum
-
- representer - Variable in class com.hazelcast.org.snakeyaml.engine.v2.api.Dump
-
- representers - Variable in class com.hazelcast.org.snakeyaml.engine.v2.representer.BaseRepresenter
-
Keep representers which must match the class exactly
- RepresentIterator() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentIterator
-
- RepresentList() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentList
-
- RepresentMap() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentMap
-
- representMapping(Tag, Map<?, ?>, FlowStyle) - Method in class com.hazelcast.org.snakeyaml.engine.v2.representer.BaseRepresenter
-
- RepresentNull() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentNull
-
- RepresentNumber() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentNumber
-
- RepresentOptional() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentOptional
-
- RepresentPrimitiveArray() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentPrimitiveArray
-
- representScalar(Tag, String, ScalarStyle) - Method in class com.hazelcast.org.snakeyaml.engine.v2.representer.BaseRepresenter
-
- representScalar(Tag, String) - Method in class com.hazelcast.org.snakeyaml.engine.v2.representer.BaseRepresenter
-
- representSequence(Tag, Iterable<?>, FlowStyle) - Method in class com.hazelcast.org.snakeyaml.engine.v2.representer.BaseRepresenter
-
- RepresentSet() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentSet
-
- RepresentString() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentString
-
- RepresentToNode - Interface in com.hazelcast.org.snakeyaml.engine.v2.api
-
Create a Node Graph out of the provided Native Data Structure (Java instance).
- RepresentUuid() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter.RepresentUuid
-
- requestedByUser() - Method in interface com.hazelcast.jet.core.JobSuspensionCause
-
True if the user explicitly suspended the job.
- RequestPayload - Class in com.hazelcast.com.fasterxml.jackson.core.util
-
Container object used to contain optional information on content
being parsed, passed to
JsonParseException
in case of
exception being thrown; this may be useful for caller to display
information on failure.
- RequestPayload(byte[], String) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.RequestPayload
-
- RequestPayload(CharSequence) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.RequestPayload
-
- requiresCustomCodec() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method that can be called to determine if a custom
ObjectCodec
is needed for binding data parsed
using
JsonParser
constructed by this factory
(which typically also implies the same for serialization
with
JsonGenerator
).
- requiresCustomCodec() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method that can be called to determine if a custom
ObjectCodec
is needed for binding data parsed
using
JsonParser
constructed by this factory
(which typically also implies the same for serialization
with
JsonGenerator
).
- requiresCustomCodec() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- requiresObjectContext() - Method in enum com.hazelcast.com.fasterxml.jackson.core.type.WritableTypeId.Inclusion
-
- requiresPaddingOnRead() - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
-
- requiresPropertyOrdering() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Introspection method that higher-level functionality may call
to see whether underlying data format requires a stable ordering
of object properties or not.
- requiresPropertyOrdering() - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
Introspection method that higher-level functionality may call
to see whether underlying data format requires a stable ordering
of object properties or not.
- requiresTenantContext() - Method in interface com.hazelcast.spi.tenantcontrol.Tenantable
-
- reset(boolean, int, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- reset(int, TokenFilter, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
-
- reset() - Method in interface com.hazelcast.com.fasterxml.jackson.core.format.InputAccessor
-
Method that can be called to reset accessor to read from beginning
of input.
- reset() - Method in class com.hazelcast.com.fasterxml.jackson.core.format.InputAccessor.Std
-
- reset() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.MergedStream
-
- reset() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.DupDetector
-
- reset(int, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
-
Internal method to allow instance reuse: DO NOT USE unless you absolutely
know what you are doing.
- reset(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
Internal method to allow instance reuse: DO NOT USE unless you absolutely
know what you are doing.
- reset(int, Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
Internal method to allow instance reuse: DO NOT USE unless you absolutely
know what you are doing.
- reset() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
-
- 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.
- resetAndGetFirstSegment() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
-
Method called when starting "manual" output: will clear out
current state and return the first segment buffer to fill
- resetAsNaN(String, double) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- resetFloat(boolean, int, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- resetInt(boolean, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- 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
-
- resetWith(char) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
Method for clearing out possibly existing content, and replacing them with
a single-character content (so
TextBuffer.size()
would return
1
)
- resetWithCopy(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
- resetWithCopy(String, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
- resetWithEmpty() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
Method called to clear out any content text buffer may have, and
initializes buffer to use non-shared data.
- resetWithShared(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
Method called to initialize the buffer with a shared copy of data;
this means that buffer will just have pointers to actual data.
- resetWithString(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
- resolve(ProtocolType, String) - Static method in class com.hazelcast.instance.EndpointQualifier
-
- resolve(String, Boolean) - Method in class com.hazelcast.org.snakeyaml.engine.v2.resolver.JsonScalarResolver
-
- resolve(String, Boolean) - Method in interface com.hazelcast.org.snakeyaml.engine.v2.resolver.ScalarResolver
-
Resolve (detect) the tag of the scalar node of the given type.
- RESOLVE_NOT_READY_ADDRESSES - Static variable in class com.hazelcast.kubernetes.KubernetesProperties
-
Configuration key: resolve-not-ready-addresses
- resolved - Variable in class com.hazelcast.org.snakeyaml.engine.v2.nodes.Node
-
true when the tag is assigned by the resolver
- ResolvedType - Class in com.hazelcast.com.fasterxml.jackson.core.type
-
Type abstraction that represents Java type that has been resolved
(i.e.
- ResolvedType() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
-
- resolveForConfig(ProtocolType, String) - Static method in class com.hazelcast.instance.EndpointQualifier
-
- ResourceConfig - Class in com.hazelcast.jet.config
-
Describes a single resource to deploy to the Jet cluster.
- ResourceType - Enum in com.hazelcast.jet.config
-
Represents the type of the resource to be uploaded.
- 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
-
- REST - Static variable in class com.hazelcast.instance.EndpointQualifier
-
- RestApiConfig - Class in com.hazelcast.config
-
This class allows to control which parts of Hazelcast REST API will be enabled.
- RestApiConfig() - Constructor for class com.hazelcast.config.RestApiConfig
-
- 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.
- restart(JetCommandLine.Verbosity, JetCommandLine.TargetsMixin, String) - Method in class com.hazelcast.jet.server.JetCommandLine
-
- 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
-
- RestEndpointGroup - Enum in com.hazelcast.config
-
Enum of REST endpoint groups.
- 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(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.
- restoreFromSnapshot(Inbox) - Method in interface com.hazelcast.jet.core.Processor
-
Called when a batch of items is received during the "restore from
snapshot" operation.
- 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
-
Server socket endpoint config specialized for REST service
Allows configuring access to REST groups similar to
RestApiConfig
- RestServerEndpointConfig() - Constructor for class com.hazelcast.config.RestServerEndpointConfig
-
- 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
-
- resume(JetCommandLine.Verbosity, JetCommandLine.TargetsMixin, String) - Method in class com.hazelcast.jet.server.JetCommandLine
-
- retrieveAndDisposeResult(long) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
-
Retrieves and disposes the result with the given taskId
- retrieveInitialSequence() - Method in interface com.hazelcast.topic.ReliableMessageListener
-
Retrieves the initial sequence from which this ReliableMessageListener
should start.
- retrieveResult(long) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
-
Retrieves the result with the given taskId
- RetryableException - Interface in com.hazelcast.spi.exception
-
Marker interface for exceptions to indicate that an operation can be retried.
- RetryableHazelcastException - Exception in com.hazelcast.spi.exception
-
A 'marker' exception that indicates that an operation can be retried.
- RetryableHazelcastException() - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
-
- RetryableHazelcastException(String) - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
-
- RetryableHazelcastException(String, Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
-
- RetryableHazelcastException(Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
-
- RetryableIOException - Exception in com.hazelcast.spi.exception
-
A
IOException
indicating that there was a IO failure, but it can be retried.
- RetryableIOException() - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
-
- RetryableIOException(String) - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
-
- RetryableIOException(String, Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
-
- RetryableIOException(Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
-
- 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.
- reversed() - Method in interface com.hazelcast.function.ComparatorEx
-
- reverseOrder() - Static method in interface com.hazelcast.function.ComparatorEx
-
- REVISION - Static variable in class com.hazelcast.instance.GeneratedBuildProperties
-
- 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.
- 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
-
- RingbufferConfig() - Constructor for class com.hazelcast.config.RingbufferConfig
-
- RingbufferConfig(String) - Constructor for class com.hazelcast.config.RingbufferConfig
-
Creates a RingbufferConfig with the provided name.
- RingbufferConfig(RingbufferConfig) - Constructor for class com.hazelcast.config.RingbufferConfig
-
Clones a RingbufferConfig
- RingbufferConfig(String, RingbufferConfig) - Constructor for class com.hazelcast.config.RingbufferConfig
-
Creates a new RingbufferConfig by cloning an existing config and
overriding the name.
- RingbufferMergeData - Class in com.hazelcast.spi.merge
-
A ringbuffer implementation holding data involved in split-brain healing.
- RingbufferMergeData(int) - Constructor for class com.hazelcast.spi.merge.RingbufferMergeData
-
- RingbufferMergeData(Ringbuffer<Object>) - Constructor for class com.hazelcast.spi.merge.RingbufferMergeData
-
- RingbufferMergeDataReadOnlyIterator<E> - Class in com.hazelcast.spi.merge
-
- 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
-
- RingbufferStoreConfig() - Constructor for class com.hazelcast.config.RingbufferStoreConfig
-
- RingbufferStoreConfig(RingbufferStoreConfig) - Constructor for class com.hazelcast.config.RingbufferStoreConfig
-
- RingbufferStoreFactory<T> - Interface in com.hazelcast.ringbuffer
-
- 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(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
-
- rollingAggregate(long, AggregateOperation1<? super T, A, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
-
Attaches a rolling aggregation stage.
- rootDetector(JsonParser) - Static method in class com.hazelcast.com.fasterxml.jackson.core.json.DupDetector
-
- rootDetector(JsonGenerator) - Static method in class com.hazelcast.com.fasterxml.jackson.core.json.DupDetector
-
- rootFilter - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
Object consulted to determine whether to write parts of content generator
is asked to write or not.
- rootFilter - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
Object consulted to determine whether to write parts of content generator
is asked to write or not.
- rootValueSeparator(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactoryBuilder
-
Method that allows overriding String used for separating root-level
JSON values (default is single space character)
- rootValueSeparator(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactoryBuilder
-
Method that allows overriding String used for separating root-level
JSON values (default is single space character)
- rootValueSeparator() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactoryBuilder
-
- RoundRobinLB - Class in com.hazelcast.client.util
-
A
LoadBalancer
implementation that relies on using round robin
to a next member to send a request to.
- RoundRobinLB() - Constructor for class com.hazelcast.client.util.RoundRobinLB
-
- RoundRobinLB(int) - Constructor for class com.hazelcast.client.util.RoundRobinLB
-
- run() - Method in interface com.hazelcast.jet.function.RunnableEx
-
- run() - Method in class com.hazelcast.jet.server.JetCommandLine
-
- runEx() - Method in interface com.hazelcast.jet.function.RunnableEx
-
- RunnableEx - Interface in com.hazelcast.jet.function
-
- RuntimeInterruptedException - Exception in com.hazelcast.core
-
- 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
returns true
.
- SAFECHARS_URLENCODER - Static variable in class com.hazelcast.org.snakeyaml.engine.external.com.google.gdata.util.common.base.PercentEscaper
-
A string of safe characters that mimics the behavior of
URLEncoder
.
- SAFEPATHCHARS_URLENCODER - Static variable in class com.hazelcast.org.snakeyaml.engine.external.com.google.gdata.util.common.base.PercentEscaper
-
A string of characters that do not need to be encoded when used in URI
path segments, as specified in RFC 3986.
- SAFEQUERYSTRINGCHARS_URLENCODER - Static variable in class com.hazelcast.org.snakeyaml.engine.external.com.google.gdata.util.common.base.PercentEscaper
-
A string of characters that do not need to be encoded when used in URI
query strings, as specified in RFC 3986.
- 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.
- saveSnapshot(JetCommandLine.Verbosity, JetCommandLine.TargetsMixin, String, String, boolean) - Method in class com.hazelcast.jet.server.JetCommandLine
-
- 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.
- ScalarAnalysis - Class in com.hazelcast.org.snakeyaml.engine.v2.emitter
-
Accumulate information to choose the scalar style
- ScalarAnalysis(String, boolean, boolean, boolean, boolean, boolean, boolean) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.emitter.ScalarAnalysis
-
- ScalarEvent - Class in com.hazelcast.org.snakeyaml.engine.v2.events
-
Marks a scalar value.
- ScalarEvent(Optional<Anchor>, Optional<String>, ImplicitTuple, String, ScalarStyle, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.events.ScalarEvent
-
- ScalarEvent(Optional<Anchor>, Optional<String>, ImplicitTuple, String, ScalarStyle) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.events.ScalarEvent
-
- ScalarNode - Class in com.hazelcast.org.snakeyaml.engine.v2.nodes
-
Represents a scalar node.
- ScalarNode(Tag, boolean, String, ScalarStyle, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.nodes.ScalarNode
-
- ScalarNode(Tag, String, ScalarStyle) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.nodes.ScalarNode
-
- ScalarResolver - Interface in com.hazelcast.org.snakeyaml.engine.v2.resolver
-
ScalarResolver tries to detect a type of a scalar value by its content (when the tag is implicit)
- ScalarStyle - Enum in com.hazelcast.org.snakeyaml.engine.v2.common
-
YAML provides a rich set of scalar styles.
- ScalarToken - Class in com.hazelcast.org.snakeyaml.engine.v2.tokens
-
- ScalarToken(String, boolean, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.tokens.ScalarToken
-
- ScalarToken(String, boolean, ScalarStyle, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.tokens.ScalarToken
-
- scanner - Variable in class com.hazelcast.org.snakeyaml.engine.v2.parser.ParserImpl
-
- Scanner - Interface in com.hazelcast.org.snakeyaml.engine.v2.scanner
-
This interface represents an input stream of
Token
s.
- ScannerException - Exception in com.hazelcast.org.snakeyaml.engine.v2.exceptions
-
Exception thrown by the
Scanner
implementations in case of malformed
input.
- ScannerException(String, Optional<Mark>, String, Optional<Mark>) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v2.exceptions.ScannerException
-
Constructs an instance.
- ScannerException(String, Optional<Mark>) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v2.exceptions.ScannerException
-
- ScannerImpl - Class in com.hazelcast.org.snakeyaml.engine.v2.scanner
-
Scanner produces tokens of the following types:
STREAM-START
STREAM-END
DIRECTIVE(name, value)
DOCUMENT-START
DOCUMENT-END
BLOCK-SEQUENCE-START
BLOCK-MAPPING-START
BLOCK-END
FLOW-SEQUENCE-START
FLOW-MAPPING-START
FLOW-SEQUENCE-END
FLOW-MAPPING-END
BLOCK-ENTRY
FLOW-ENTRY
KEY
VALUE
ALIAS(value)
ANCHOR(value)
TAG(value)
SCALAR(value, plain, style)
Read comments in the Scanner code for more details.
- ScannerImpl(StreamReader) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.scanner.ScannerImpl
-
- schedule(Runnable, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
-
Creates and executes a one-shot action that becomes enabled after the given delay.
- schedule(Callable<V>, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
-
Creates and executes a one-shot action that becomes enabled after the given delay.
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
-
Creates and executes a periodic action that becomes enabled first after
the given initial delay, and subsequently with the given period.
- ScheduledExecutorConfig - Class in com.hazelcast.config
-
- ScheduledExecutorConfig() - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
-
- ScheduledExecutorConfig(String) - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
-
- ScheduledExecutorConfig(String, int, int, int, boolean) - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
-
- ScheduledExecutorConfig(String, int, int, int, String, MergePolicyConfig, ScheduledExecutorConfig.CapacityPolicy, boolean) - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
-
- ScheduledExecutorConfig(ScheduledExecutorConfig) - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
-
- ScheduledExecutorConfig.CapacityPolicy - Enum in com.hazelcast.config
-
Capacity policy options
- ScheduledExecutorPermission - Class in com.hazelcast.security.permission
-
- ScheduledExecutorPermission(String, String...) - Constructor for class com.hazelcast.security.permission.ScheduledExecutorPermission
-
- ScheduledTaskHandler - Class in com.hazelcast.scheduledexecutor
-
- ScheduledTaskHandler() - Constructor for class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
-
- ScheduledTaskStatistics - Interface in com.hazelcast.scheduledexecutor
-
- 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.
- schemaValidation(Document) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- SEARCH_DYNAMIC_CONFIG_FIRST - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
By default, search for data structures config is performed within static
configuration first:
Exact match in static config
Wildcard match in static config
Exact match in dynamic config
Wildcard match in dynamic config
Fallback to default
But sometimes it makes sense to perform search within dynamic configs
first.
- secondaryCount() - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
Method mostly needed by unit tests; calculates number of entries
in secondary buckets
- SecureCallable<V> - Interface in com.hazelcast.security
-
A secure callable that runs in a sandbox.
- SecureStoreConfig - Class in com.hazelcast.config
-
Abstract Secure Store configuration class.
- SecureStoreConfig() - Constructor for class com.hazelcast.config.SecureStoreConfig
-
- SecurityConfig - Class in com.hazelcast.config
-
Contains configuration for Security
- SecurityConfig() - Constructor for class com.hazelcast.config.SecurityConfig
-
- SecurityContext - Interface in com.hazelcast.security
-
- 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
-
- SecurityInterceptorConfig() - Constructor for class com.hazelcast.config.SecurityInterceptorConfig
-
- SecurityInterceptorConfig(String) - Constructor for class com.hazelcast.config.SecurityInterceptorConfig
-
- SecurityInterceptorConfig(SecurityInterceptor) - Constructor for class com.hazelcast.config.SecurityInterceptorConfig
-
- securityRealmGenerator(ConfigXmlGenerator.XmlGenerator, String, RealmConfig) - Method in class com.hazelcast.config.ConfigXmlGenerator
-
- SecurityService - Interface in com.hazelcast.security
-
Provides necessary methods to initiate security related config changes.
- SegmentedStringWriter - Class in com.hazelcast.com.fasterxml.jackson.core.io
-
Efficient alternative to
StringWriter
, based on using segmented
internal buffer.
- SegmentedStringWriter(BufferRecycler) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.io.SegmentedStringWriter
-
- select(Member) - Method in interface com.hazelcast.cluster.MemberSelector
-
Decides if the given member will be part of an operation or not.
- self() - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
-
- self() - Method in class com.hazelcast.config.AuditlogConfig
-
- self() - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
-
- self() - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
-
- self() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- self() - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
-
- self() - Method in class com.hazelcast.config.SSLConfig
-
- SemaphoreConfig - Class in com.hazelcast.config.cp
-
- 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
-
- SEPARATOR - Static variable in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
-
Character used to separate segments.
- Separators - Class in com.hazelcast.com.fasterxml.jackson.core.util
-
- Separators() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.Separators
-
- Separators(char, char, char) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.Separators
-
- SEQ - Static variable in class com.hazelcast.org.snakeyaml.engine.v2.nodes.Tag
-
- sequence() - Method in class com.hazelcast.jet.pipeline.test.SimpleEvent
-
Sequence number of the event
- 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.
- SequenceEndEvent - Class in com.hazelcast.org.snakeyaml.engine.v2.events
-
Marks the end of a sequence.
- SequenceEndEvent(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.events.SequenceEndEvent
-
- SequenceEndEvent() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.events.SequenceEndEvent
-
- SequenceNode - Class in com.hazelcast.org.snakeyaml.engine.v2.nodes
-
Represents a sequence.
- SequenceNode(Tag, boolean, List<Node>, FlowStyle, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.nodes.SequenceNode
-
- SequenceNode(Tag, List<Node>, FlowStyle) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.nodes.SequenceNode
-
- SequenceStartEvent - Class in com.hazelcast.org.snakeyaml.engine.v2.events
-
Marks the beginning of a sequence node.
- SequenceStartEvent(Optional<Anchor>, Optional<String>, boolean, FlowStyle, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.events.SequenceStartEvent
-
- SequenceStartEvent(Optional<Anchor>, Optional<String>, boolean, FlowStyle) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.events.SequenceStartEvent
-
- SerializableString - Interface in com.hazelcast.com.fasterxml.jackson.core
-
Interface that defines how Jackson package can interact with efficient
pre-serialized or lazily-serialized and reused String representations.
- SERIALIZATION_VERSION - Static variable in class com.hazelcast.instance.GeneratedBuildProperties
-
- SERIALIZATION_VERSION - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Hazelcast serialization version.
- SerializationConfig - Class in com.hazelcast.config
-
- 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
-
- Serialize - Class in com.hazelcast.org.snakeyaml.engine.v2.api.lowlevel
-
- Serialize(DumpSettings) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.api.lowlevel.Serialize
-
- serialize(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v2.serializer.Serializer
-
- serializeAll(List<Node>) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.lowlevel.Serialize
-
Serialize
Node
s and produce events.
- SerializedString - Class in com.hazelcast.com.fasterxml.jackson.core.io
-
String token that can lazily serialize String contained and then reuse that
serialization later on.
- SerializedString(String) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.io.SerializedString
-
- serializeOne(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.lowlevel.Serialize
-
Serialize a
Node
and produce events.
- Serializer - Interface in com.hazelcast.nio.serialization
-
Base interface of custom serialization interfaces
- Serializer - Class in com.hazelcast.org.snakeyaml.engine.v2.serializer
-
- Serializer(DumpSettings, Emitable) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.serializer.Serializer
-
- 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
-
- 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_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
-
- 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()
.
- ServiceNotFoundException - Exception in com.hazelcast.spi.exception
-
- 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(long) - Method in interface com.hazelcast.cp.IAtomicLong
-
Atomically sets the given value.
- set(E) - Method in interface com.hazelcast.cp.IAtomicReference
-
Atomically sets the given value.
- set(double) - Method in class com.hazelcast.jet.accumulator.DoubleAccumulator
-
Sets the value as given.
- set(long) - Method in class com.hazelcast.jet.accumulator.LongAccumulator
-
Sets the value as given.
- set(T) - Method in class com.hazelcast.jet.accumulator.MutableReference
-
Sets the value as given.
- set(long) - Method in interface com.hazelcast.jet.core.metrics.Metric
-
Sets the current value.
- set(K, V) - Method in interface com.hazelcast.map.BaseMap
-
Associates the specified value with the specified key in this map.
- set(K, V) - Method in interface com.hazelcast.map.IMap
-
Puts an entry into this map without returning the old value
(which is more efficient than put()
).
- set(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Puts an entry into this map with a given TTL (time to live) value,
without returning the old value (which is more efficient than put()
).
- set(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Puts an entry into this map with a given TTL (time to live) value and
max idle time value without returning the old value (which is more
efficient than put()
).
- SET - Static variable in class com.hazelcast.org.snakeyaml.engine.v2.nodes.Tag
-
- set(long, Object) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
-
Sets the item at the given sequence.
- set(K, V) - Method in interface com.hazelcast.transaction.TransactionalMap
-
- 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.
- 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
-
- setAllowDuplicateKeys(boolean) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettingsBuilder
-
YAML 1.2 does require unique keys.
- 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.
- setAllowRecursiveKeys(boolean) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettingsBuilder
-
Allow only non-recursive keys for maps and sets.
- setAllowUnsafe(boolean) - Method in class com.hazelcast.config.SerializationConfig
-
Unsafe, it is not public api of java.
- setAnchor(Optional<Anchor>) - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.Node
-
Set the anchor for this Node
- setAnchorGenerator(AnchorGenerator) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettingsBuilder
-
Define anchor name generator (by default 'id' + number)
- setAppendRequestBackoffTimeoutInMillis(long) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
-
- setAppendRequestMaxEntryCount(int) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
-
- setAsync(long) - Method in interface com.hazelcast.cp.IAtomicLong
-
Atomically sets the given value.
- setAsync(E) - Method in interface com.hazelcast.cp.IAtomicReference
-
Atomically sets the given value.
- setAsync(K, V) - Method in interface com.hazelcast.map.IMap
-
Asynchronously puts the given key and value.
- setAsync(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Asynchronously puts an entry into this map with a given TTL (time to live) value,
without returning the old value (which is more efficient than put()
).
- setAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Asynchronously puts an entry into this map with a given TTL (time to live)
value and max idle time value without returning the old value
(which is more efficient than put()
).
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.CacheConfig
-
Sets the number of asynchronous backups for this
ICache
.
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the number of asynchronous backups for this
ICache
.
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
Sets the number of synchronous backups.
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.CollectionConfig
-
Sets the number of asynchronous backups.
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.MapConfig
-
Sets the number of asynchronous backups.
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfig
-
Sets the number of asynchronous backups.
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.QueueConfig
-
Sets the number of asynchronous backups.
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.RingbufferConfig
-
Sets the number of asynchronous backups.
- setAsyncFillup(boolean) - Method in class com.hazelcast.config.ReplicatedMapConfig
-
True if the replicated map is available for reads before the initial
replication is completed, false otherwise.
- setAsyncStart(boolean) - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
-
- setAttribute(String, String) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- setAttribute(String) - Method in interface com.hazelcast.query.PredicateBuilder
-
- setAttributeConfigs(List<AttributeConfig>) - Method in class com.hazelcast.config.MapConfig
-
- setAttributes(List<String>) - Method in class com.hazelcast.config.IndexConfig
-
Sets index attributes.
- setAttributes(Map<String, String>) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- setAuditlogConfig(AuditlogConfig) - Method in class com.hazelcast.config.Config
-
- setAutoDetectionConfig(AutoDetectionConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Defines the Auto Detection configuration.
- setAutoDetectionConfig(AutoDetectionConfig) - Method in class com.hazelcast.config.JoinConfig
-
- setAutoDetectionEnabled(boolean) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
-
- setAutoRemoveStaleData(boolean) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Sets whether or not automatically removal of stale Hot Restart data is enabled.
- 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 increase performance for smart clients.
- setBackupCount(int) - Method in class com.hazelcast.config.CacheConfig
-
Sets the number of synchronous backups.
- setBackupCount(int) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the number of synchronous backups for this
ICache
.
- setBackupCount(int) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
Sets the number of synchronous backups.
- setBackupCount(int) - Method in class com.hazelcast.config.CollectionConfig
-
Sets the number of synchronous backups for this collection.
- setBackupCount(int) - Method in class com.hazelcast.config.MapConfig
-
Number of synchronous backups.
- setBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfig
-
Sets the number of synchronous backups.
- setBackupCount(int) - Method in class com.hazelcast.config.QueueConfig
-
Sets the number of synchronous backups for this queue.
- setBackupCount(int) - Method in class com.hazelcast.config.RingbufferConfig
-
Sets the number of synchronous backups.
- setBackupCount(int) - Method in class com.hazelcast.jet.config.InstanceConfig
-
Sets the number of backups that Jet will maintain for the job metadata
and snapshots.
- setBackupDir(File) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Sets base directory for all Hot Restart stores.
- setBaseDir(File) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Sets the base directory for persisting CP data.
- setBaseDir(File) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Sets base directory for all Hot Restart stores.
- setBatchMaxDelayMillis(int) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the maximum amount of time in milliseconds to wait before sending a
batch of events to target cluster, if
WanBatchPublisherConfig.getBatchSize()
of events
have not arrived within this duration.
- setBatchPublisherConfigs(List<WanBatchPublisherConfig>) - Method in class com.hazelcast.config.WanReplicationConfig
-
Sets the list of WAN publisher configurations using the built-in
batching WAN implementation for this WAN replication.
- setBatchSize(int) - Method in class com.hazelcast.config.MergePolicyConfig
-
Sets the batch size, which will be used to determine
the number of entries to be sent in a merge operation.
- setBatchSize(int) - Method in class com.hazelcast.config.QueryCacheConfig
-
Sets the batch size which will be used to determine number of events to be sent in a batch to QueryCache
- setBatchSize(int) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the maximum batch size that can be sent to target cluster.
- setBestLineBreak(String) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettingsBuilder
-
If the YAML is created for another platform (for instance on Windows to be consumed under Linux) than
this setting is used to define the line ending.
- setBinary(boolean) - Method in class com.hazelcast.config.MultiMapConfig
-
Enables or disables binary (serialized) form for this MultiMap.
- setBitmapIndexOptions(BitmapIndexOptions) - Method in class com.hazelcast.config.IndexConfig
-
Sets bitmap index options of this index config to the given ones.
- setBitsNodeId(int) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
Sets the bit-length of node id component.
- setBitsSequence(int) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
Sets the bit-length of the sequence component.
- setBlacklist(ClassFilter) - Method in class com.hazelcast.config.JavaSerializationFilterConfig
-
- setBlacklistedPrefixes(String) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Comma-separated list of class prefixes which will never be loaded remotely.
- setBoolean(String, boolean) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- setBooleanArray(String, boolean[]) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- 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.
- setBufferSize(Integer) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettingsBuilder
-
Buffer size for incoming data stream.
- setByte(String, byte) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- setByteArray(String, byte[]) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- 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
-
- setCacheLoader(String) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Set classname of a class to be used as CacheLoader
.
- setCacheLoaderFactory(Factory<? extends CacheLoader<K, V>>) - Method in class com.hazelcast.config.AbstractCacheConfig
-
- setCacheLoaderFactory(Factory<? extends CacheLoader<K, V>>) - Method in interface com.hazelcast.config.CacheConfiguration
-
Set the CacheLoader
factory.
- setCacheLoaderFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the factory for this CacheLoader
.
- setCacheLocalEntries(boolean) - Method in class com.hazelcast.config.NearCacheConfig
-
Sets if local entries are also cached in the Near Cache.
- setCacheWriter(String) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Set classname of a class to be used as CacheWriter
.
- setCacheWriterFactory(Factory<? extends CacheWriter<? super K, ? super V>>) - Method in class com.hazelcast.config.AbstractCacheConfig
-
- setCacheWriterFactory(Factory<? extends CacheWriter<? super K, ? super V>>) - Method in interface com.hazelcast.config.CacheConfiguration
-
Set the CacheWriter
factory.
- setCacheWriterFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the factory for this CacheWriter
.
- setCanonical(boolean) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettingsBuilder
-
Enforce canonical representation
- setCapacity(int) - Method in class com.hazelcast.config.DurableExecutorConfig
-
Sets the ring buffer capacity of the executor task.
- setCapacity(int) - Method in class com.hazelcast.config.EventJournalConfig
-
Sets the capacity of the event journal.
- setCapacity(int) - Method in class com.hazelcast.config.RingbufferConfig
-
Sets the capacity of the ringbuffer.
- setCapacity(int) - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Sets the capacity of the executor
The capacity represents the maximum number of tasks that a scheduler can have at any given point in time per partition.
- setCapacityPolicy(ScheduledExecutorConfig.CapacityPolicy) - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Set the capacity policy for the configured capacity value
To prevent any undesirable data-loss, capacity is ignored during partition migrations,
the count is updated accordingly, however the rejection is not enforced.
- setCardinalityEstimatorConfigs(Map<String, CardinalityEstimatorConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of cardinality estimator configurations, mapped by config name.
- setChar(String, char) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- setCharacterEscapes(CharacterEscapes) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonGeneratorImpl
-
- setCharacterEscapes(CharacterEscapes) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method for defining custom escapes factory uses for
JsonGenerator
s
it creates.
- setCharacterEscapes(CharacterEscapes) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for defining custom escapes factory uses for
JsonGenerator
s
it creates.
- setCharacterEscapes(CharacterEscapes) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- setCharArray(String, char[]) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- setCheckClassDefErrors(boolean) - Method in class com.hazelcast.config.SerializationConfig
-
When enabled, serialization system will check for class definitions error at start and throw an Serialization
Exception with error definition.
- setClass(Class<? extends Serializer>) - Method in class com.hazelcast.config.SerializerConfig
-
Sets the class of the serializer implementation.
- setClassCacheMode(UserCodeDeploymentConfig.ClassCacheMode) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Configure caching of classes loaded from remote members.
- setClassDefinitions(Set<ClassDefinition>) - Method in class com.hazelcast.config.SerializationConfig
-
- setClasses(Collection<String>) - Method in class com.hazelcast.config.ClassFilter
-
- setClassLoader(ClassLoader) - Method in class com.hazelcast.client.config.ClientConfig
-
Sets the classLoader which is used by serialization and listener configuration
- setClassLoader(ClassLoader) - Method in class com.hazelcast.config.AbstractCacheConfig
-
- setClassLoader(ClassLoader) - Method in class com.hazelcast.config.Config
-
Sets the class-loader to be used during de-serialization
and as context class-loader of Hazelcast internal threads.
- setClassLoaderFactory(JobClassLoaderFactory) - Method in class com.hazelcast.jet.config.JobConfig
-
- 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
-
- 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
-
- setClassName(String) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
- setClassName(String) - Method in class com.hazelcast.config.WanConsumerConfig
-
Sets the fully qualified class name of the class implementing
WanConsumer
.
- setClassName(String) - Method in class com.hazelcast.config.WanCustomPublisherConfig
-
- setClassNames(List<String>) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
-
- setClientBlockUnmappedActions(boolean) - Method in class com.hazelcast.config.SecurityConfig
-
Block or allow actions, submitted as tasks in an Executor from clients and have no permission mappings.
- setClientConfigs(List<ClientConfig>) - Method in class com.hazelcast.client.config.ClientFailoverConfig
-
Sets the configured list of alternative client configurations.
- setClientEndpointConfig(ServerSocketEndpointConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
-
Sets the server socket endpoint config for
CLIENT
protocol.
- setClientIcmpPingConfig(ClientIcmpPingConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
ICMP ping is used to detect if machine that a remote hazelcast member runs on alive or not
- setClientPermissionConfigs(Set<PermissionConfig>) - Method in class com.hazelcast.config.SecurityConfig
-
- setClientPolicyConfig(PermissionPolicyConfig) - Method in class com.hazelcast.config.SecurityConfig
-
- setClientRealm(String) - Method in class com.hazelcast.config.SecurityConfig
-
- setClientRealmConfig(String, RealmConfig) - Method in class com.hazelcast.config.SecurityConfig
-
- setCloudConfig(ClientCloudConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
- setClusterConnectTimeoutMillis(long) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
-
- setClusterDataRecoveryPolicy(HotRestartClusterDataRecoveryPolicy) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Sets the policy to be used when the cluster is started
- setClusterName(String) - Method in class com.hazelcast.client.config.ClientConfig
-
- setClusterName(String) - Method in class com.hazelcast.config.Config
-
Sets the cluster name uniquely identifying the hazelcast cluster.
- setClusterName(String) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the cluster name used as an endpoint group password for authentication
on the target endpoint.
- setCoalesce(boolean) - Method in class com.hazelcast.config.QueryCacheConfig
-
Set true
to enable coalescing, otherwise set false
.
- setCodec(ObjectCodec) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- setCodec(ObjectCodec) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- setCodec(ObjectCodec) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- setCodec(ObjectCodec) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- setCodec(ObjectCodec) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- setCodec(ObjectCodec) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method for associating a
ObjectCodec
(typically
a
com.hazelcast.com.fasterxml.jackson.databind.ObjectMapper
)
with this factory (and more importantly, parsers and generators
it constructs).
- setCodec(ObjectCodec) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- setCodec(ObjectCodec) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Setter that allows defining
ObjectCodec
associated with this
parser, if any.
- setCodec(ObjectCodec) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- setCodec(ObjectCodec) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- setCollectionFrequencySeconds(int) - Method in class com.hazelcast.config.BaseMetricsConfig
-
Sets the metrics collection frequency in seconds.
- setCommitIndexAdvanceCountToSnapshot(int) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
-
- setComparator(EvictionPolicyComparator) - Method in class com.hazelcast.config.EvictionConfig
-
- setComparatorClassName(String) - Method in class com.hazelcast.config.EvictionConfig
-
- SetConfig - Class in com.hazelcast.config
-
Contains the configuration for an
ISet
.
- SetConfig() - Constructor for class com.hazelcast.config.SetConfig
-
- SetConfig(String) - Constructor for class com.hazelcast.config.SetConfig
-
- SetConfig(SetConfig) - Constructor for class com.hazelcast.config.SetConfig
-
- setConfig(EdgeConfig) - Method in class com.hazelcast.jet.core.Edge
-
Assigns an EdgeConfig
to this edge.
- setConfigClassLoader(ClassLoader) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
-
- setConfigObject(Object) - Method in class com.hazelcast.config.ServiceConfig
-
- setConfigPatternMatcher(ConfigPatternMatcher) - Method in class com.hazelcast.client.config.ClientConfig
-
Sets the pattern matcher which is used to match item names to
configuration objects.
- setConfigPatternMatcher(ConfigPatternMatcher) - Method in class com.hazelcast.config.Config
-
Sets the pattern matcher which is used to match item names to
configuration objects.
- setConfigurationFile(File) - Method in class com.hazelcast.config.Config
-
Sets the
File
from which this configuration has been retrieved
and created.
- setConfigurationUrl(URL) - Method in class com.hazelcast.config.Config
-
Sets the
URL
from which this configuration has been retrieved
and created.
- setConnectionRetryConfig(ConnectionRetryConfig) - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
-
Connection Retry Config is controls the period among the retries and when should a client gave up
retrying.
- setConnectionStrategyConfig(ClientConnectionStrategyConfig) - Method in class com.hazelcast.client.config.ClientConfig
-
- setConnectionTimeout(int) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
- setConnectionTimeoutSeconds(int) - Method in class com.hazelcast.config.TcpIpConfig
-
Sets the connection timeout.
- setConsistencyCheckStrategy(ConsistencyCheckStrategy) - Method in class com.hazelcast.config.WanSyncConfig
-
Sets the strategy for checking consistency of data between source and
target cluster.
- setConsumerConfig(WanConsumerConfig) - Method in class com.hazelcast.config.WanReplicationConfig
-
- setCooperativeThreadCount(int) - Method in class com.hazelcast.jet.config.InstanceConfig
-
Sets the number of threads each cluster member will use to execute Jet
jobs.
- setCPMemberCount(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Sets the CP member count to initialize CP Subsystem.
- setCPSubsystemConfig(CPSubsystemConfig) - Method in class com.hazelcast.config.Config
-
Set CP subsystem configuration
- setCRDTReplicationConfig(CRDTReplicationConfig) - Method in class com.hazelcast.config.Config
-
Sets the replication configuration for CRDT
implementations.
- setCredentials(Credentials) - Method in class com.hazelcast.client.config.ClientConfig
-
Shortcut for getSecurityConfig().setCredentials()
- setCredentials(Credentials) - Method in class com.hazelcast.client.config.ClientSecurityConfig
-
- setCredentials(Credentials) - Method in class com.hazelcast.config.security.RealmConfig
-
- setCredentialsFactoryConfig(CredentialsFactoryConfig) - Method in class com.hazelcast.client.config.ClientSecurityConfig
-
- setCredentialsFactoryConfig(CredentialsFactoryConfig) - Method in class com.hazelcast.config.security.RealmConfig
-
- setCredentialsIdentityConfig(CredentialsIdentityConfig) - Method in class com.hazelcast.client.config.ClientSecurityConfig
-
- setCredentialsIdentityConfig(CredentialsIdentityConfig) - Method in class com.hazelcast.config.security.RealmConfig
-
- setCurrentAndReturn(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
Convenience method that finishes the current active content segment
(by specifying how many characters within consists of valid content)
and aggregates and returns resulting contents (similar to a call
to
TextBuffer.contentsAsString()
).
- setCurrentKeyAlias(String) - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
-
Sets the alias for the current encryption key entry.
- setCurrentLength(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
- setCurrentName(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
-
- setCurrentSegmentLength(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
-
- setCurrentValue(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- setCurrentValue(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- setCurrentValue(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
-
- setCurrentValue(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
-
- setCurrentValue(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
- setCurrentValue(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Helper method, usually equivalent to:
getOutputContext().setCurrentValue(v);
- setCurrentValue(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Helper method, usually equivalent to:
getParsingContext().setCurrentValue(v);
- setCurrentValue(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
-
- setCurrentValue(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- setCurrentValue(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- setCursorBufferSize(int) - Method in class com.hazelcast.sql.SqlStatement
-
Sets the cursor buffer size (measured in the number of rows).
- setCustomProperty(SettingKey, Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettingsBuilder
-
- setCustomProperty(SettingKey, Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettingsBuilder
-
- setCustomPublisherConfigs(List<WanCustomPublisherConfig>) - Method in class com.hazelcast.config.WanReplicationConfig
-
Sets the list of custom WAN publisher implementations for this WAN
replication.
- setDataLoadTimeoutSeconds(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Sets the timeout duration for CP members to restore their data from
stable storage.
- setDataLoadTimeoutSeconds(int) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Sets data load timeout for hot-restart process,
all members in the cluster should complete restoring their local data
before this timeout.
- setDataSerializableFactories(Map<Integer, DataSerializableFactory>) - Method in class com.hazelcast.config.SerializationConfig
-
- setDataSerializableFactoryClasses(Map<Integer, String>) - Method in class com.hazelcast.config.SerializationConfig
-
- setDate(String, LocalDate) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
Sets a date field consisting of year , month of the year and day of the month
It is legal to set the field again only when Builder is created with
GenericRecord.cloneWithBuilder()
.
- setDateArray(String, LocalDate[]) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- setDecimal(String, BigDecimal) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
Sets a decimal which is arbitrary precision and scale floating-point number
It is legal to set the field again only when Builder is created with
GenericRecord.cloneWithBuilder()
.
- setDecimalArray(String, BigDecimal[]) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- 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.
- setDefaultFlowStyle(FlowStyle) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettingsBuilder
-
Define flow style
- setDefaultList(IntFunction<List>) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettingsBuilder
-
Provide default List implementation.
- setDefaultMap(IntFunction<Map>) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettingsBuilder
-
Provide default Map implementation.
- setDefaultScalarStyle(ScalarStyle) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettingsBuilder
-
Define default scalar style
- setDefaultsDisabled(boolean) - Method in class com.hazelcast.config.JavaSerializationFilterConfig
-
- setDefaultSet(IntFunction<Set>) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettingsBuilder
-
Provide default Set implementation.
- setDelaySeconds(int) - Method in class com.hazelcast.config.QueryCacheConfig
-
Sets the minimum number of delay seconds which an event waits in the buffer of node
before sending to a QueryCache
- setDeprecatedName(String) - Method in class com.hazelcast.spi.properties.HazelcastProperty
-
Sets the deprecated name of ths property.
- setDepth(int) - Method in class com.hazelcast.config.MerkleTreeConfig
-
Sets the depth of the merkle tree.
- setDirectory(String) - Method in class com.hazelcast.config.NearCachePreloaderConfig
-
- setDirectory(String) - Method in class com.hazelcast.config.PersistentMemoryDirectoryConfig
-
- 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
-
- 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
-
- setDouble(double) - Method in class com.hazelcast.jet.accumulator.LongDoubleAccumulator
-
Sets the double
value.
- setDouble(String, double) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- setDoubleArray(String, double[]) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- 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.
- 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
-
- setEmptyQueueTtl(int) - Method in class com.hazelcast.config.QueueConfig
-
Sets the TTL (time to live) for emptying the Queue.
- setEnableCompression(boolean) - Method in class com.hazelcast.config.SerializationConfig
-
Enables compression when default java serialization is used.
- setEnabled(boolean) - Method in class com.hazelcast.client.config.ClientCloudConfig
-
- setEnabled(boolean) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
-
- setEnabled(boolean) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
-
- setEnabled(boolean) - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
-
Enables and disables this configuration.
- setEnabled(boolean) - Method in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
-
Enables and disables this configuration.
- setEnabled(boolean) - Method in class com.hazelcast.config.AdvancedNetworkConfig
-
- setEnabled(boolean) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
-
Enables or disables the join mechanism based on the given discovery config.
- setEnabled(boolean) - Method in class com.hazelcast.config.AutoDetectionConfig
-
Enables or disables the auto detection join mechanism.
- setEnabled(boolean) - Method in class com.hazelcast.config.BaseMetricsConfig
-
Sets whether metrics collection should be enabled for the node.
- setEnabled(boolean) - Method in class com.hazelcast.config.EventJournalConfig
-
Enables or disables the event journal.
- setEnabled(boolean) - Method in class com.hazelcast.config.HotRestartConfig
-
Sets whether hot restart is enabled on related data structure.
- setEnabled(boolean) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Sets whether hot restart is enabled on this member.
- setEnabled(boolean) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
-
Set whether the ICMP failure detector should be enabled or not.
- setEnabled(boolean) - Method in class com.hazelcast.config.InstanceTrackingConfig
-
Enables or disables instance tracking.
- setEnabled(boolean) - Method in class com.hazelcast.config.InterfacesConfig
-
- setEnabled(boolean) - Method in class com.hazelcast.config.MapStoreConfig
-
Enables and disables this configuration
- setEnabled(boolean) - Method in class com.hazelcast.config.MemberAddressProviderConfig
-
- setEnabled(boolean) - Method in class com.hazelcast.config.MemcacheProtocolConfig
-
Enables or disables the MEMCACHE protocol on the member.
- setEnabled(boolean) - Method in class com.hazelcast.config.MerkleTreeConfig
-
Enables or disables the merkle tree.
- setEnabled(boolean) - Method in class com.hazelcast.config.MetricsJmxConfig
-
Enables metrics exposure through JMX.
- setEnabled(boolean) - Method in class com.hazelcast.config.MetricsManagementCenterConfig
-
Enables exposing metrics to Hazelcast Management Center.
- setEnabled(boolean) - Method in class com.hazelcast.config.MulticastConfig
-
Enables or disables the multicast discovery mechanism
- setEnabled(boolean) - Method in class com.hazelcast.config.NativeMemoryConfig
-
Enables or disables native memory allocation.
- setEnabled(boolean) - Method in class com.hazelcast.config.NearCachePreloaderConfig
-
- setEnabled(boolean) - Method in class com.hazelcast.config.PartitionGroupConfig
-
Enables or disables this PartitionGroupConfig.
- setEnabled(boolean) - Method in class com.hazelcast.config.PersistentMemoryConfig
-
Enables or disables persistent memory.
- setEnabled(boolean) - Method in class com.hazelcast.config.QueueStoreConfig
-
Enables or disables the queue store.
- setEnabled(boolean) - Method in class com.hazelcast.config.RestApiConfig
-
Enables or disables the REST API on the member.
- setEnabled(boolean) - Method in class com.hazelcast.config.RingbufferStoreConfig
-
- setEnabled(boolean) - Method in class com.hazelcast.config.SecurityConfig
-
- setEnabled(boolean) - Method in class com.hazelcast.config.ServiceConfig
-
- setEnabled(boolean) - Method in class com.hazelcast.config.SocketInterceptorConfig
-
Enables and disables this configuration.
- setEnabled(boolean) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
-
- setEnabled(boolean) - Method in class com.hazelcast.config.TcpIpConfig
-
Enables or disables the Tcp/Ip join mechanism.
- setEnabled(boolean) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Enable or disable User Code Deployment.
- setEnabledGroups(Collection<RestEndpointGroup>) - Method in class com.hazelcast.config.RestApiConfig
-
- setEnabledGroups(Collection<RestEndpointGroup>) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
- setEnableSharedObject(boolean) - Method in class com.hazelcast.config.SerializationConfig
-
Enables shared object when default java serialization is used.
- setEncoding(JsonEncoding) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
- setEncryptionAtRestConfig(EncryptionAtRestConfig) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Sets the Hot Restart Encryption at Rest configuration.
- setEndMark(Optional<Mark>) - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.CollectionNode
-
- 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
-
- setEnvConfig(Optional<EnvConfig>) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettingsBuilder
-
Define EnvConfig to parse EVN format.
- setEpochStart(long) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
Sets the offset of timestamp component in milliseconds.
- setEurekaConfig(EurekaConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Sets configuration to connect nodes in Eureka environment.
- setEurekaConfig(EurekaConfig) - Method in class com.hazelcast.config.JoinConfig
-
- setEurekaConfig(EurekaConfig) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the
EurekaConfig
used by the discovery mechanism for this
WAN publisher.
- setEventJournalConfig(EventJournalConfig) - Method in class com.hazelcast.config.AbstractCacheConfig
-
Sets the EventJournalConfig
for this CacheConfiguration
- setEventJournalConfig(EventJournalConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the EventJournalConfig
for this CacheSimpleConfig
- setEventJournalConfig(EventJournalConfig) - Method in class com.hazelcast.config.MapConfig
-
Sets the EventJournalConfig
for this MapConfig
- setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.CacheConfig
-
- 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
-
- 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
-
- setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.EvictionConfig
-
- 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.
- setExecutorPoolSize(int) - Method in class com.hazelcast.config.SqlConfig
-
Sets the number of threads responsible for execution of SQL statements.
- setExpectedResultType(SqlExpectedResultType) - Method in class com.hazelcast.sql.SqlStatement
-
Sets the expected result type.
- setExpiryPolicy(K, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Associates the specified key with the given ExpiryPolicy
.
- setExpiryPolicy(Set<? extends K>, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Associates the specified key with the given ExpiryPolicy
.
- setExpiryPolicyFactory(Factory<? extends ExpiryPolicy>) - Method in class com.hazelcast.config.AbstractCacheConfig
-
- setExpiryPolicyFactory(Factory<? extends ExpiryPolicy>) - Method in interface com.hazelcast.config.CacheConfiguration
-
Set the Factory
for the ExpiryPolicy
.
- setExpiryPolicyFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the factory for this ExpiryPolicy
.
- setExpiryPolicyFactoryConfig(CacheSimpleConfig.ExpiryPolicyFactoryConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the factory configuration for this ExpiryPolicy
.
- setExplicitEnd(boolean) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettingsBuilder
-
Add '...' in the end of the document
- setExplicitRootTag(Optional<Tag>) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettingsBuilder
-
Define root
Tag
or let the tag to be detected automatically
- setExplicitStart(boolean) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettingsBuilder
-
Add '---' in the beginning of the document
- setExtractorClassName(String) - Method in class com.hazelcast.config.AttributeConfig
-
Sets the full class name of the extractor in a String format, e.g.
- setFactoryClassName(String) - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
-
Sets the factory class name.
- setFactoryClassName(String) - Method in class com.hazelcast.config.MapStoreConfig
-
Sets the name for the MapStoreFactory implementation class
- setFactoryClassName(String) - Method in class com.hazelcast.config.QueueStoreConfig
-
Sets the factory class name which will be used to instantiate the queue
store.
- setFactoryClassName(String) - Method in class com.hazelcast.config.RingbufferStoreConfig
-
- setFactoryClassName(String) - Method in class com.hazelcast.config.SSLConfig
-
Sets the name for the implementation class.
- setFactoryImpl(ClientProxyFactory) - Method in class com.hazelcast.client.config.ProxyFactoryConfig
-
Sets factory implementation of proxy factory
- setFactoryImplementation(Object) - Method in class com.hazelcast.config.MapStoreConfig
-
Sets the map store factory implementation object.
- setFactoryImplementation(QueueStoreFactory) - Method in class com.hazelcast.config.QueueStoreConfig
-
Sets the queue store factory implementation which will be used to
instantiate the queue store.
- setFactoryImplementation(RingbufferStoreFactory) - Method in class com.hazelcast.config.RingbufferStoreConfig
-
- setFactoryImplementation(Object) - Method in class com.hazelcast.config.SSLConfig
-
Sets the implementation object.
- setFailFastOnStartup(boolean) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
-
Sets whether the member should fail-fast on startup if ICMP is not allowed by the underlying OS.
- setFailOnIndeterminateOperationState(boolean) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Sets the value to determine if CP Subsystem calls will fail when
result of an API call becomes indeterminate.
- setFeatureMask(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
Deprecated.
- setFeatureMask(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Deprecated.
- setFeatureMask(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- setFeatureMask(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- setFeatureMask(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
Deprecated.
- setFeatureMask(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
Deprecated.
- setFieldName(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
-
- 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
-
- setFlakeIdGeneratorConfigs(Map<String, FlakeIdGeneratorConfig>) - Method in class com.hazelcast.config.Config
-
- setFloat(String, float) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- setFloatArray(String, float[]) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- setFlowControlPeriodMs(int) - Method in class com.hazelcast.jet.config.InstanceConfig
-
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.
- setFlowStyle(FlowStyle) - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.CollectionNode
-
- setFormatPattern(String) - Method in class com.hazelcast.config.InstanceTrackingConfig
-
Sets the pattern used to render the contents of the instance tracking file.
- setFsync(boolean) - Method in class com.hazelcast.config.HotRestartConfig
-
Sets whether disk write should be followed by an fsync()
system call.
- setFunctionClassName(String) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
-
- setFunctionImplementation(SplitBrainProtectionFunction) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
-
- setGcpConfig(GcpConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Sets configuration to connect nodes in GCP environment.
- setGcpConfig(GcpConfig) - Method in class com.hazelcast.config.JoinConfig
-
- setGcpConfig(GcpConfig) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the
GcpConfig
used by the discovery mechanism for this
WAN publisher.
- setGenericRecord(String, GenericRecord) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- setGenericRecordArray(String, GenericRecord[]) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- 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.
- setHazelcastConfig(Config) - Method in class com.hazelcast.jet.config.JetConfig
-
Sets the underlying Hazelcast IMDG instance's configuration object.
- setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.console.Echo
-
- setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.console.SimulateLoadTask
-
- setHazelcastInstance(HazelcastInstance) - Method in interface com.hazelcast.core.HazelcastInstanceAware
-
Gets the HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService.
- setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.security.HazelcastInstanceCallback
-
- setHeadSequence(long) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
-
Sets the head sequence.
- setHighestNonEscapedChar(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonGeneratorImpl
-
- setHighestNonEscapedChar(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method that can be called to request that generator escapes
all character codes above specified code point (if positive value);
or, to not escape any characters except for ones that must be
escaped for the data format (if -1).
- setHighestNonEscapedChar(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.AbstractCacheConfig
-
Sets the HotRestartConfig
for this CacheConfiguration
- setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the HotRestartConfig
for this CacheSimpleConfig
- setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.MapConfig
-
Sets the HotRestartConfig
for this MapConfig
- setHotRestartPersistenceConfig(HotRestartPersistenceConfig) - Method in class com.hazelcast.config.Config
-
Sets the Hot Restart configuration.
- setIcmpFailureDetectorConfig(IcmpFailureDetectorConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
-
- setIcmpFailureDetectorConfig(IcmpFailureDetectorConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
-
- setIcmpFailureDetectorConfig(IcmpFailureDetectorConfig) - Method in class com.hazelcast.config.NetworkConfig
-
- setIdleMaxParkNs(long) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the maximum duration in nanoseconds that the WAN replication thread
will be parked if there are no events to replicate.
- setIdleMinParkNs(long) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the minimum duration in nanoseconds that the WAN replication thread
will be parked if there are no events to replicate.
- setIfConfigured(Properties, String, String) - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
-
- setIfConfigured(Properties, String, Object) - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
-
- setIfConfigured(Properties, String, Enum<?>) - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
-
- setImplementation(WanPublisher) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
-
- setImplementation(CachePartitionLostListener) - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
-
- setImplementation(ICredentialsFactory) - Method in class com.hazelcast.config.CredentialsFactoryConfig
-
- setImplementation(EventListener) - Method in class com.hazelcast.config.EntryListenerConfig
-
- setImplementation(MapListener) - Method in class com.hazelcast.config.EntryListenerConfig
-
- setImplementation(Serializer) - Method in class com.hazelcast.config.GlobalSerializerConfig
-
- setImplementation(ItemListener) - Method in class com.hazelcast.config.ItemListenerConfig
-
- setImplementation(EventListener) - Method in class com.hazelcast.config.ListenerConfig
-
Sets the EventListener implementation.
- setImplementation(MapPartitionLostListener) - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
-
- setImplementation(Object) - Method in class com.hazelcast.config.MapStoreConfig
-
Sets the map store implementation object
- setImplementation(MemberAddressProvider) - Method in class com.hazelcast.config.MemberAddressProviderConfig
-
- setImplementation(IPermissionPolicy) - Method in class com.hazelcast.config.PermissionPolicyConfig
-
- setImplementation(Predicate) - Method in class com.hazelcast.config.PredicateConfig
-
Sets the Predicate implementation.
- setImplementation(SecurityInterceptor) - Method in class com.hazelcast.config.SecurityInterceptorConfig
-
- setImplementation(Serializer) - Method in class com.hazelcast.config.SerializerConfig
-
Sets the serializer implementation instance.
- setImplementation(Object) - Method in class com.hazelcast.config.ServiceConfig
-
- setImplementation(Object) - Method in class com.hazelcast.config.SocketInterceptorConfig
-
- setImplementation(SplitBrainProtectionListener) - Method in class com.hazelcast.config.SplitBrainProtectionListenerConfig
-
- setImplementation(WanPublisher) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
No-op method as the implementation cannot be changed for this publisher.
- setImplementation(WanConsumer) - Method in class com.hazelcast.config.WanConsumerConfig
-
Sets the implementation for this WAN consumer.
- setImplementation(WanPublisher) - Method in class com.hazelcast.config.WanCustomPublisherConfig
-
- setIncludeValue(boolean) - Method in class com.hazelcast.config.EntryListenerConfig
-
- setIncludeValue(boolean) - Method in class com.hazelcast.config.ItemListenerConfig
-
- setIncludeValue(boolean) - Method in class com.hazelcast.config.QueryCacheConfig
-
Set true
to enable value caching, otherwise set false
- setIndent(int) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettingsBuilder
-
Define the amount of the spaces for the indent in the block flow style.
- setIndexConfigs(List<IndexConfig>) - Method in class com.hazelcast.config.MapConfig
-
- setIndexConfigs(List<IndexConfig>) - Method in class com.hazelcast.config.QueryCacheConfig
-
- setIndicatorIndent(int) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettingsBuilder
-
It adds the specified indent for sequence indicator in the block flow.
- 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
-
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.CacheConfig
-
Data type that will be used to store records in this
ICache
.
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the InMemory Format for this
ICache
.
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.MapConfig
-
Binary type that will be used for storing records.
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.NearCacheConfig
-
Sets the data type used to store entries.
- setInMemoryFormat(String) - Method in class com.hazelcast.config.NearCacheConfig
-
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.QueryCacheConfig
-
Sets memory format of values of entries in QueryCache
.
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.ReplicatedMapConfig
-
Data type used to store entries.
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.RingbufferConfig
-
Sets the in-memory format.
- setInputDecorator(InputDecorator) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- setInstanceConfig(InstanceConfig) - Method in class com.hazelcast.jet.config.JetConfig
-
Sets the Jet instance config.
- setInstanceName(String) - Method in class com.hazelcast.client.config.ClientConfig
-
- setInstanceName(String) - Method in class com.hazelcast.config.Config
-
Sets the instance name uniquely identifying the hazelcast instance
created by this configuration.
- setInstanceTrackingConfig(InstanceTrackingConfig) - Method in class com.hazelcast.client.config.ClientConfig
-
Returns the configuration for tracking use of this Hazelcast instance.
- setInstanceTrackingConfig(InstanceTrackingConfig) - Method in class com.hazelcast.config.Config
-
Returns the configuration for tracking use of this Hazelcast instance.
- setInt(String, int) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- setIntArray(String, int[]) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- setInterfaces(InterfacesConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
-
- setInterfaces(InterfacesConfig) - Method in class com.hazelcast.config.EndpointConfig
-
- setInterfaces(Collection<String>) - Method in class com.hazelcast.config.InterfacesConfig
-
Adds a collection of interfaces.
- setInterfaces(Collection<String>) - Method in class com.hazelcast.config.MemberGroupConfig
-
Sets the interfaces that are part of a group.
- setInterfaces(InterfacesConfig) - Method in class com.hazelcast.config.NetworkConfig
-
- setInterfaces(InterfacesConfig) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
- setInterfaces(InterfacesConfig) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
- setIntervalMilliseconds(int) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
-
- setIntervalMilliseconds(int) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
-
Sets the time in milliseconds between each ping
This value can not be smaller than 1000 milliseconds
- setInvalidateOnChange(boolean) - Method in class com.hazelcast.config.NearCacheConfig
-
Sets if Near Cache entries are invalidated when the entries in the backing data structure are changed
(updated or removed).
- 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
-
String jarPath is searched in following order:
1.
- setJavaSerializationFilterConfig(JavaSerializationFilterConfig) - Method in class com.hazelcast.config.SerializationConfig
-
Allows to configure deserialization protection filter.
- setJDKCompatible(boolean) - Method in class com.hazelcast.config.cp.SemaphoreConfig
-
Sets JDK compatibility mode of CP ISemaphore
- setJetInstance(JetInstance) - Method in class com.hazelcast.jet.core.test.TestProcessorContext
-
- setJetInstance(JetInstance) - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
-
Sets the jet instance.
- setJetInstance(JetInstance) - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
-
- 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.TestProcessorMetaSupplierContext
-
Sets the job name.
- 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.
- setKeyClassName(String) - Method in class com.hazelcast.config.AbstractCacheConfig
-
- setKeySize(int) - Method in class com.hazelcast.config.EncryptionAtRestConfig
-
Sets the size (in bits) of the Hot Restart Store-level encryption key
(non-positive value implies falling back to the cipher-specific default
key length).
- setKeytabFile(String) - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
-
- setKeytabFile(String) - Method in class com.hazelcast.config.security.KerberosIdentityConfig
-
- setKeyType(Class<K>) - Method in class com.hazelcast.config.AbstractCacheConfig
-
- setKeyType(String) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the key type for this
ICache
.
- setKubernetesConfig(KubernetesConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Sets configuration to connect nodes in Kubernetes environment.
- setKubernetesConfig(KubernetesConfig) - Method in class com.hazelcast.config.JoinConfig
-
- setKubernetesConfig(KubernetesConfig) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the
KubernetesConfig
used by the discovery mechanism for this
WAN publisher.
- setLabel(String) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettingsBuilder
-
Label for the input data.
- setLabels(Set<String>) - Method in class com.hazelcast.client.config.ClientConfig
-
Set labels for the client.
- setLdapAuthenticationConfig(LdapAuthenticationConfig) - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
-
- setLdapAuthenticationConfig(LdapAuthenticationConfig) - Method in class com.hazelcast.config.security.RealmConfig
-
- setLeaderElectionTimeoutInMillis(long) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
-
- setLeaderHeartbeatPeriodInMillis(long) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
-
- 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
-
- setListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.Config
-
- 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
-
- 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
-
- 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
-
- 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.
- setLong(String, long) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- setLongArray(String, long[]) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- setLoopbackModeEnabled(boolean) - Method in class com.hazelcast.config.MulticastConfig
-
Enables or disables the loopback mode in the multicast discovery mechanism.
- setLosslessRestartEnabled(boolean) - Method in class com.hazelcast.jet.config.InstanceConfig
-
Sets whether lossless job restart is enabled for the node.
- setManagedContext(ManagedContext) - Method in class com.hazelcast.client.config.ClientConfig
-
- 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
-
- setManagementCenterConfig(ManagementCenterConfig) - Method in class com.hazelcast.config.Config
-
Sets the management center configuration for this hazelcast instance.
- setManagementCenterConfig(MetricsManagementCenterConfig) - Method in class com.hazelcast.config.MetricsConfig
-
- setManagementEnabled(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
-
Sets whether or not management is enabled on this cache.
- setManagementEnabled(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
-
Sets whether management is enabled on a cache.
- setManagementEnabled(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets management to enabled or disabled for this
ICache
.
- setManagerPrefix(String) - Method in class com.hazelcast.config.CacheConfig
-
Sets the manager prefix of the
ICache
.
- setMapConfigs(Map<String, MapConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of
IMap
configurations,
mapped by config name.
- setMapStoreConfig(MapStoreConfig) - Method in class com.hazelcast.config.MapConfig
-
Sets the map store configuration
- setMaxAliasesForCollections(int) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettingsBuilder
-
Restrict the number of aliases for collection nodes to prevent Billion laughs attack.
- setMaxAttempts(int) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
-
- setMaxAttempts(int) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
-
Set the max ping attempts before suspecting a member
- setMaxBackoffMillis(int) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
-
When backoff reaches this upper bound, it does not increase any more.
- setMaxConcurrentInvocations(int) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the maximum number of WAN event batches being sent to the target
cluster concurrently.
- setMaxConcurrentReplicationTargets(int) - Method in class com.hazelcast.config.CRDTReplicationConfig
-
Sets the maximum number of target members that we replicate the CRDT states
to in one period.
- setMaxIdleSeconds(int) - Method in class com.hazelcast.config.MapConfig
-
Maximum number of seconds for each entry to stay idle in the
map.
- setMaxIdleSeconds(int) - Method in class com.hazelcast.config.NearCacheConfig
-
Set the maximum number of seconds each entry can stay in the Near Cache as untouched (not-read).
- setMaxMissedLeaderHeartbeatCount(int) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
-
- setMaxSimpleKeyLength(int) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettingsBuilder
-
Define max key length to use simple key (without '?')
More info https://yaml.org/spec/1.2/spec.html#id2798057
- setMaxSize(int) - Method in class com.hazelcast.config.CollectionConfig
-
Sets the maximum size for the collection.
- setMaxSize(int) - Method in class com.hazelcast.config.QueueConfig
-
Sets the maximum size of the Queue.
- setMaxSizePolicy(MaxSizePolicy) - Method in class com.hazelcast.config.EvictionConfig
-
- 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.
- 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
-
- setMerged(boolean) - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.MappingNode
-
- 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
-
- setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
-
- setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
- setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.CollectionConfig
-
- setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.MapConfig
-
- setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.MultiMapConfig
-
- setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.QueueConfig
-
- setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.RingbufferConfig
-
- setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
- setMerkleTreeConfig(MerkleTreeConfig) - Method in class com.hazelcast.config.MapConfig
-
Sets the MerkleTreeConfig
for this MapConfig
- setMessageListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.ReliableTopicConfig
-
Sets the list of message listeners (listens for when messages are added
or removed) for this topic.
- setMessageListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.TopicConfig
-
Sets the list of message listeners (listens for when messages are added or removed) for this topic.
- setMetadataPolicy(MetadataPolicy) - Method in class com.hazelcast.config.MapConfig
-
Sets the metadata policy.
- setMetadataSpacePercentage(float) - Method in class com.hazelcast.config.NativeMemoryConfig
-
Sets the percentage of native memory space to be used to store metadata and internal memory structures
by the native memory manager.
- setMetricsConfig(ClientMetricsConfig) - Method in class com.hazelcast.client.config.ClientConfig
-
Sets the metrics collection config.
- setMetricsConfig(MetricsConfig) - Method in class com.hazelcast.config.Config
-
Sets the metrics collection config.
- 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.
- setMultiLineFlow(boolean) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettingsBuilder
-
Use pretty flow style when every value in the flow context gets a separate line.
- setMultiMapConfigs(Map<String, MultiMapConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of
MultiMap
configurations,
mapped by config name.
- setMultiplier(double) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
-
- setMultiThreadingEnabled(boolean) - Method in class com.hazelcast.config.TopicConfig
-
Enable multi-threaded message handling.
- setName(String) - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
-
Sets the name or name pattern for this config.
- setName(String) - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
-
Sets the name or name pattern for this config.
- setName(String) - Method in class com.hazelcast.config.AttributeConfig
-
Sets the name of the attribute extracted by the extractor.
- setName(String) - Method in class com.hazelcast.config.CacheConfig
-
- setName(String) - Method in class com.hazelcast.config.CacheSimpleConfig
-
- setName(String) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
Sets the name of the cardinality estimator.
- setName(String) - Method in class com.hazelcast.config.CollectionConfig
-
Sets the name of this collection.
- setName(String) - Method in class com.hazelcast.config.cp.FencedLockConfig
-
Sets the name of FencedLock
- setName(String) - Method in class com.hazelcast.config.cp.SemaphoreConfig
-
Sets the name of CP ISemaphore
- setName(String) - Method in class com.hazelcast.config.DurableExecutorConfig
-
Sets the name of the executor task.
- setName(String) - Method in class com.hazelcast.config.EndpointConfig
-
- setName(String) - Method in class com.hazelcast.config.ExecutorConfig
-
Sets the name of the executor task.
- setName(String) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
Sets the name or name pattern for this config.
- setName(String) - Method in class com.hazelcast.config.IndexConfig
-
Sets name of the index.
- setName(String) - Method in class com.hazelcast.config.MapConfig
-
Sets the name of the
IMap
- setName(String) - Method in class com.hazelcast.config.MultiMapConfig
-
Sets the name of this MultiMap.
- setName(String) - Method in interface com.hazelcast.config.NamedConfig
-
- setName(String) - Method in class com.hazelcast.config.NearCacheConfig
-
Sets the name of the Near Cache.
- setName(String) - Method in class com.hazelcast.config.PermissionConfig
-
- setName(String) - Method in class com.hazelcast.config.PNCounterConfig
-
Sets the name of the PN counter.
- setName(String) - Method in class com.hazelcast.config.QueryCacheConfig
-
Sets the name of QueryCache
.
- setName(String) - Method in class com.hazelcast.config.QueueConfig
-
Set the name for this queue.
- setName(String) - Method in class com.hazelcast.config.ReliableTopicConfig
-
Sets the name of the reliable topic.
- setName(String) - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- setName(String) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
- setName(String) - Method in class com.hazelcast.config.RingbufferConfig
-
Sets the name of the ringbuffer.
- setName(String) - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Sets the name of the executor task.
- setName(String) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
- setName(String) - Method in class com.hazelcast.config.ServiceConfig
-
- setName(String) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
-
- setName(String) - Method in class com.hazelcast.config.TopicConfig
-
Sets the name of the topic.
- setName(String) - Method in class com.hazelcast.config.WanReplicationConfig
-
Sets the name of this WAN replication config.
- setName(String) - Method in class com.hazelcast.config.WanReplicationRef
-
Sets the WAN replication reference name.
- setName(String) - Method in class com.hazelcast.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
-
- 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
-
- setNetworkConfig(ClientNetworkConfig) - Method in class com.hazelcast.client.config.ClientConfig
-
- setNetworkConfig(NetworkConfig) - Method in class com.hazelcast.config.Config
-
Sets the network configuration for this hazelcast instance.
- setNodeFilter(NodeFilter) - Method in class com.hazelcast.config.DiscoveryConfig
-
- setNodeFilterClass(String) - Method in class com.hazelcast.config.DiscoveryConfig
-
- setNodeIdOffset(long) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
Sets the offset that will be added to the node ID assigned to cluster member for this generator.
- setNonPrintableStyle(NonPrintableStyle) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettingsBuilder
-
When String object contains non-printable characters, they are escaped with \\u or \\x notation.
- setNumaNode(int) - Method in class com.hazelcast.config.PersistentMemoryDirectoryConfig
-
Sets the NUMA node the persistent memory mounted to the given
directory is attached to.
- 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
-
- setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Set outbound port definitions
- setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
-
- setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.config.EndpointConfig
-
- setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.config.NetworkConfig
-
- setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
- setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
- setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
Set outbond ports
- setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
-
- setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.config.EndpointConfig
-
- setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.config.NetworkConfig
-
- setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
- setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
- setOutOfMemoryHandler(OutOfMemoryHandler) - Static method in class com.hazelcast.client.HazelcastClient
-
Sets OutOfMemoryHandler to be used when an OutOfMemoryError
is caught by Hazelcast Client threads.
- setOutOfMemoryHandler(OutOfMemoryHandler) - Static method in class com.hazelcast.core.Hazelcast
-
Sets OutOfMemoryHandler
to be used when an OutOfMemoryError
is caught by Hazelcast threads.
- setOutputDecorator(OutputDecorator) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- 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.
- setParallelism(int) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Sets the number of Hot Restart store instances to create for one Hazelcast instance.
- setParallelMode(boolean) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
-
Set the ICMP detector to run in parallel mode, independent from the other failure detectors.
- setParameters(List<Object>) - Method in class com.hazelcast.sql.SqlStatement
-
Sets the statement parameters.
- setParseDn(boolean) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- setPartitionGroupConfig(PartitionGroupConfig) - Method in class com.hazelcast.config.Config
-
Sets the partition group configuration for this hazelcast instance.
- setPartitionIdleTimeout(long) - Method in interface com.hazelcast.jet.pipeline.StreamSource
-
Sets a timeout after which idle partitions will be excluded from
watermark coalescing.
- 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
-
- setPersistenceEnabled(boolean) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Sets whether CP Subsystem Persistence is enabled on this member.
- setPersistentMemoryConfig(PersistentMemoryConfig) - Method in class com.hazelcast.config.NativeMemoryConfig
-
Sets the persistent memory configuration this native memory
configuration uses.
- setPersistentMemoryDirectory(String) - Method in class com.hazelcast.config.NativeMemoryConfig
-
- 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
-
- setPollingInterval(int) - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
-
Sets the polling interval (in seconds) for checking for changes in the KeyStore.
- setPollingInterval(int) - Method in class com.hazelcast.config.VaultSecureStoreConfig
-
Sets the polling interval (in seconds) for checking for changes in Vault.
- setPoolSize(int) - Method in class com.hazelcast.config.DurableExecutorConfig
-
Sets the number of executor threads per member for the executor.
- setPoolSize(int) - Method in class com.hazelcast.config.ExecutorConfig
-
Sets the number of executor threads per member for the executor.
- setPoolSize(int) - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
Sets the number of executor threads per member for the executor.
- setPopulate(boolean) - Method in class com.hazelcast.config.QueryCacheConfig
-
Set true
to enable initial population, otherwise set false
.
- setPort(int) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
-
- setPort(int) - Method in class com.hazelcast.config.NetworkConfig
-
Sets the port the Hazelcast member will try to bind on.
- setPort(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
- setPort(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
Sets the port the Hazelcast member will try to bind on.
- setPortableFactories(Map<Integer, PortableFactory>) - Method in class com.hazelcast.config.SerializationConfig
-
- setPortableFactoryClasses(Map<Integer, String>) - Method in class com.hazelcast.config.SerializationConfig
-
- setPortableVersion(int) - Method in class com.hazelcast.config.SerializationConfig
-
- setPortAutoIncrement(boolean) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
-
- setPortAutoIncrement(boolean) - Method in class com.hazelcast.config.NetworkConfig
-
Sets if a Hazelcast member is allowed to find a free port by incrementing the port number when it encounters
an occupied port.
- setPortAutoIncrement(boolean) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
- setPortAutoIncrement(boolean) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
Sets if a Hazelcast member is allowed to find a free port by incrementing the port number when it encounters
an occupied port.
- setPortCount(int) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
-
- setPortCount(int) - Method in class com.hazelcast.config.NetworkConfig
-
The maximum number of ports allowed to use.
- setPortCount(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
The maximum number of ports allowed to use.
- setPredicateConfig(PredicateConfig) - Method in class com.hazelcast.config.QueryCacheConfig
-
Sets the predicate of QueryCache
.
- setPrefetchCount(int) - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
-
- setPrefetchCount(int) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
- 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
-
- 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.
- setPrettyPrinter(PrettyPrinter) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for setting a custom pretty printer, which is usually
used to add indentation for improved human readability.
- setPrettyPrinter(PrettyPrinter) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- setPrincipal(String) - Method in class com.hazelcast.config.PermissionConfig
-
- setPrincipal(String) - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
-
- setPrincipal(String) - Method in class com.hazelcast.config.security.KerberosIdentityConfig
-
- setPriorityComparatorClassName(String) - Method in class com.hazelcast.config.QueueConfig
-
Sets the class name that will be used to compare queue items.
- setProcessingGuarantee(ProcessingGuarantee) - Method in class com.hazelcast.jet.config.JobConfig
-
- 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(Properties) - Method in class com.hazelcast.client.config.ClientConfig
-
sets all properties
- setProperties(Properties) - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
-
- setProperties(Properties) - Method in class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
-
- setProperties(Properties) - Method in class com.hazelcast.client.config.YamlClientConfigBuilder
-
- setProperties(Properties) - Method in class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
-
- setProperties(Properties) - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
-
Sets the properties.
- setProperties(Map<String, Comparable>) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
-
Sets the WAN publisher properties.
- setProperties(Properties) - Method in class com.hazelcast.config.Config
-
Sets the properties for this config instance.
- setProperties(Properties) - Method in class com.hazelcast.config.CredentialsFactoryConfig
-
- setProperties(Map<String, Comparable>) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
-
- setProperties(Properties) - Method in class com.hazelcast.config.LoginModuleConfig
-
- setProperties(Properties) - Method in class com.hazelcast.config.MapStoreConfig
-
Sets the properties
- setProperties(Properties) - Method in class com.hazelcast.config.MemberAddressProviderConfig
-
- setProperties(Properties) - Method in class com.hazelcast.config.PermissionPolicyConfig
-
- setProperties(Properties) - Method in class com.hazelcast.config.QueueStoreConfig
-
Sets the properties to be used when instantiating the queue store.
- setProperties(Properties) - Method in class com.hazelcast.config.RingbufferStoreConfig
-
- setProperties(Properties) - Method in class com.hazelcast.config.ServiceConfig
-
- setProperties(Properties) - Method in class com.hazelcast.config.SocketInterceptorConfig
-
Sets the properties.
- setProperties(Map<String, Comparable>) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
- setProperties(Map<String, Comparable>) - Method in class com.hazelcast.config.WanConsumerConfig
-
Sets the properties for the custom WAN consumer.
- setProperties(Map<String, Comparable>) - Method in class com.hazelcast.config.WanCustomPublisherConfig
-
- setProperties(Properties) - Method in class com.hazelcast.config.XmlConfigBuilder
-
Sets the used properties.
- setProperties(Properties) - Method in class com.hazelcast.config.YamlConfigBuilder
-
- setProperties(Properties) - Method in class com.hazelcast.jet.config.JetConfig
-
Sets the Jet-specific configuration properties.
- setPropertiesInternal(Properties) - Method in class com.hazelcast.config.AbstractXmlConfigBuilder
-
Sets the used properties.
- setPropertiesInternal(Properties) - Method in class com.hazelcast.config.AbstractYamlConfigBuilder
-
- setProperty(String, String) - Method in class com.hazelcast.client.config.ClientConfig
-
Sets the value of a named property.
- setProperty(String, String) - Method in class com.hazelcast.config.AbstractFactoryWithPropertiesConfig
-
Sets a single property.
- setProperty(String, String) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
-
Sets the property understood by the given SPI Discovery Strategy.
- setProperty(String, String) - Method in class com.hazelcast.config.Config
-
Sets the value of a named property.
- setProperty(String, String) - Method in class com.hazelcast.config.LoginModuleConfig
-
- setProperty(String, String) - Method in class com.hazelcast.config.MapStoreConfig
-
- setProperty(String, String) - Method in class com.hazelcast.config.QueueStoreConfig
-
Sets a property to be used when instantiating the queue store.
- setProperty(String, String) - Method in class com.hazelcast.config.RingbufferStoreConfig
-
- setProperty(String, String) - Method in class com.hazelcast.config.SocketInterceptorConfig
-
Sets a property.
- setProperty(String, String) - Method in class com.hazelcast.jet.config.JetConfig
-
Sets the value of the specified property.
- setProperty(String, Object) - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.Node
-
Define a custom runtime property.
- setProtectOn(SplitBrainProtectionOn) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
-
- setProtocolType(ProtocolType) - Method in class com.hazelcast.config.EndpointConfig
-
- setProtocolType(ProtocolType) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
- setProviderFilter(String) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Filter to limit members that can be used for classloading request when a user class
is not available locally.
- setProviderMode(UserCodeDeploymentConfig.ProviderMode) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
-
Configure behaviour when providing classes to remote members.
- setProxyFactoryConfigs(List<ProxyFactoryConfig>) - Method in class com.hazelcast.client.config.ClientConfig
-
- setPublicAddress(String) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
-
- setPublicAddress(String) - Method in class com.hazelcast.config.NetworkConfig
-
Overrides the public address of a member.
- setPublicAddress(String) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
- setPublicAddress(String) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
Overrides the public address of a member.
- setPublisherId(String) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
-
- setPublisherId(String) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
- setPublisherId(String) - Method in class com.hazelcast.config.WanCustomPublisherConfig
-
- setQueryCacheConfigs(Map<String, Map<String, QueryCacheConfig>>) - Method in class com.hazelcast.client.config.ClientConfig
-
- setQueryCacheConfigs(List<QueryCacheConfig>) - Method in class com.hazelcast.config.MapConfig
-
- setQueueCapacity(int) - Method in class com.hazelcast.config.ExecutorConfig
-
Sets the queue capacity of the executor task.
- setQueueCapacity(int) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the capacity of the primary and backup queue for WAN replication events.
- setQueueConfigs(Map<String, QueueConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of
IQueue
configurations,
mapped by config name.
- setQueueFullBehavior(WanQueueFullBehavior) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the configured behaviour of this WAN publisher when the WAN queue is
full.
- 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.
- 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.
- setRealm(String) - Method in class com.hazelcast.config.security.KerberosIdentityConfig
-
- setRealmConfig(RealmConfig) - Method in class com.hazelcast.security.RealmConfigCallback
-
- setRealmConfigs(Map<String, RealmConfig>) - Method in class com.hazelcast.client.config.ClientSecurityConfig
-
- setRealmConfigs(Map<String, RealmConfig>) - Method in class com.hazelcast.config.SecurityConfig
-
- setReceiveWindowMultiplier(int) - Method in class com.hazelcast.jet.config.EdgeConfig
-
Sets the scaling factor used by the adaptive receive window sizing
function.
- setReconnectMode(ClientConnectionStrategyConfig.ReconnectMode) - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
-
How a client reconnect to cluster after a disconnect can be configured.
- setRecursive(boolean) - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.Node
-
- setRedoOperation(boolean) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
If true, client will redo the operations that were executing on the server and client lost the connection.
- setRelaxFlagsCheck(Boolean) - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
-
- setReliableTopicConfigMap(Map<String, ClientReliableTopicConfig>) - Method in class com.hazelcast.client.config.ClientConfig
-
- setReliableTopicConfigs(Map<String, ReliableTopicConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of reliable topic configurations, mapped by config name.
- setReplicaCount(int) - Method in class com.hazelcast.config.PNCounterConfig
-
Sets the number of replicas on which state for this PN counter will
be kept.
- setReplicatedMapConfigs(Map<String, ReplicatedMapConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of
ReplicatedMap
configurations,
mapped by config name.
- setReplicationPeriodMillis(int) - Method in class com.hazelcast.config.CRDTReplicationConfig
-
Sets the period between two replications of CRDT states in milliseconds.
- setRepublishingEnabled(boolean) - Method in class com.hazelcast.config.WanReplicationRef
-
Sets if incoming WAN events to this member should be republished
(forwarded) to this WAN replication reference.
- setRequestPayloadOnError(RequestPayload) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- setRequestPayloadOnError(byte[], String) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Sets the byte[] request payload and the charset
- setRequestPayloadOnError(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Sets the String request payload
- setRequiredMember(String) - Method in class com.hazelcast.config.TcpIpConfig
-
Sets the required member.
- setResponseTimeoutMillis(int) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the duration in milliseconds for the waiting time before retrying to
send the events to target cluster again in case of acknowledgement
is not arrived.
- setRestApiConfig(RestApiConfig) - Method in class com.hazelcast.config.NetworkConfig
-
- setRestEndpointConfig(RestServerEndpointConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
-
Sets the server socket endpoint config for
REST
protocol.
- setRetentionSeconds(int) - Method in class com.hazelcast.config.MetricsManagementCenterConfig
-
Sets the number of seconds the metrics will be retained on the
instance.
- setReuseAddress(boolean) - Method in class com.hazelcast.client.config.SocketOptions
-
Enable/disable the SO_REUSEADDR socket option.
- setReuseAddress(boolean) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
-
- setReuseAddress(boolean) - Method in class com.hazelcast.config.NetworkConfig
-
Sets the reuse address.
- setReuseAddress(boolean) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
- setReuseAddress(boolean) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
Sets the reuse address.
- setRingbufferConfigs(Map<String, RingbufferConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of
Ringbuffer
configurations,
mapped by config name.
- setRingbufferStoreConfig(RingbufferStoreConfig) - Method in class com.hazelcast.config.RingbufferConfig
-
Set the RingbufferStore (load and store ringbuffer items from/to a database)
configuration.
- setRoleAttribute(String) - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
-
- setRoleContext(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- setRoleFilter(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- setRoleMappingAttribute(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- setRoleMappingMode(LdapRoleMappingMode) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- setRoleNameAttribute(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- setRoleRecursionMaxDepth(Integer) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- setRoleSearchScope(LdapSearchScope) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- setRootValueSeparator(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonGeneratorImpl
-
- setRootValueSeparator(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method that allows overriding String used for separating root-level
JSON values (default is single space character)
- setRootValueSeparator(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method that allows overriding String used for separating root-level
JSON values (default is single space character)
- setRootValueSeparator(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- setRootValueSeparator(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.MinimalPrettyPrinter
-
- setSalt(String) - Method in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
-
Sets the salt used for encryption.
- setScalarResolver(ScalarResolver) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettingsBuilder
-
- setScalarResolver(ScalarResolver) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettingsBuilder
-
Provide resolver to detect a tag by the value of a scalar
- setScaleUpDelayMillis(long) - Method in class com.hazelcast.jet.config.InstanceConfig
-
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(FormatSchema) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method to call to make this generator use specified schema.
- setSchema(FormatSchema) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Method to call to make this parser use specified schema.
- setSchema(FormatSchema) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- setSchema(FormatSchema) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- setSchema(String) - Method in class com.hazelcast.sql.SqlStatement
-
Sets the schema name.
- setScopeId(String) - Method in class com.hazelcast.cluster.Address
-
- setScriptingEnabled(boolean) - Method in class com.hazelcast.config.ManagementCenterConfig
-
Enables/disables scripting on the member.
- setSecretPath(String) - Method in class com.hazelcast.config.VaultSecureStoreConfig
-
Sets the Vault secret path where the encryption keys is expected to be stored.
- setSecureStoreConfig(SecureStoreConfig) - Method in class com.hazelcast.config.EncryptionAtRestConfig
-
Sets the Secure Store configuration.
- setSecurityConfig(ClientSecurityConfig) - Method in class com.hazelcast.client.config.ClientConfig
-
- setSecurityConfig(SecurityConfig) - Method in class com.hazelcast.config.Config
-
Sets the security configuration for this hazelcast instance.
- setSecurityInterceptorConfigs(List<SecurityInterceptorConfig>) - Method in class com.hazelcast.config.SecurityConfig
-
- setSecurityRealm(String) - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
-
- setSecurityRealm(String) - Method in class com.hazelcast.config.security.KerberosIdentityConfig
-
- setSecurityRealm(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- setSemaphoreConfigs(Map<String, SemaphoreConfig>) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Sets the map of CP
ISemaphore
configurations,
mapped by config name.
- setSeparators(Separators) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.MinimalPrettyPrinter
-
- setSerializationConfig(SerializationConfig) - Method in class com.hazelcast.client.config.ClientConfig
-
- setSerializationConfig(SerializationConfig) - Method in class com.hazelcast.config.Config
-
Sets the serialization configuration for this hazelcast instance.
- setSerializationService(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.
- setSerializerConfigs(Collection<SerializerConfig>) - Method in class com.hazelcast.config.SerializationConfig
-
- setService(String) - Method in class com.hazelcast.client.config.ProxyFactoryConfig
-
- setServiceNamePrefix(String) - Method in class com.hazelcast.config.security.KerberosIdentityConfig
-
- setSessionHeartbeatIntervalSeconds(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Sets the interval for the periodically-committed CP session heartbeats.
- setSessionTimeToLiveSeconds(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
-
Sets the duration for a CP session to be kept alive
after its last session heartbeat.
- setSetConfigs(Map<String, SetConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of
ISet
configurations,
mapped by config name.
- setShort(String, short) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- setShortArray(String, short[]) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- setSize(int) - Method in class com.hazelcast.config.EvictionConfig
-
- setSize(MemorySize) - Method in class com.hazelcast.config.NativeMemoryConfig
-
Sets size of the native memory region.
- setSkipAuthentication(Boolean) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- setSkipEndpoint(Boolean) - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
-
- setSkipIdentity(Boolean) - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
-
- setSkipRole(Boolean) - Method in class com.hazelcast.config.security.AbstractClusterLoginConfig
-
- setSmartRouting(boolean) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
If true
, client will route the key based operations to owner of the key on best-effort basis.
- setSnapshotEnabled(boolean) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets if key-based coalescing is configured for this WAN publisher.
- 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.
- setSocketBufferDirect(boolean) - Method in class com.hazelcast.config.EndpointConfig
-
- setSocketBufferDirect(boolean) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
- setSocketBufferDirect(boolean) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
- setSocketConnectTimeoutSeconds(int) - Method in class com.hazelcast.config.EndpointConfig
-
- setSocketConnectTimeoutSeconds(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
- setSocketConnectTimeoutSeconds(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
- setSocketFactoryClassName(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
- setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
-
- setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.config.EndpointConfig
-
- setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.config.NetworkConfig
-
- setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
- setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
- setSocketKeepAlive(boolean) - Method in class com.hazelcast.config.EndpointConfig
-
- setSocketKeepAlive(boolean) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
- setSocketKeepAlive(boolean) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
- setSocketLingerSeconds(int) - Method in class com.hazelcast.config.EndpointConfig
-
- setSocketLingerSeconds(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
- setSocketLingerSeconds(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
- setSocketOptions(SocketOptions) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
- setSocketRcvBufferSizeKb(int) - Method in class com.hazelcast.config.EndpointConfig
-
- setSocketRcvBufferSizeKb(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
- setSocketRcvBufferSizeKb(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
- setSocketSendBufferSizeKb(int) - Method in class com.hazelcast.config.EndpointConfig
-
- setSocketSendBufferSizeKb(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
- setSocketSendBufferSizeKb(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
- setSocketTcpNoDelay(boolean) - Method in class com.hazelcast.config.EndpointConfig
-
- setSocketTcpNoDelay(boolean) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
- setSocketTcpNoDelay(boolean) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
- 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.
- setSplitLines(boolean) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettingsBuilder
-
Define whether to split long lines
- setSpn(String) - Method in class com.hazelcast.config.security.KerberosIdentityConfig
-
- setSql(String) - Method in class com.hazelcast.config.PredicateConfig
-
Sets sql string for this config.
- setSql(String) - Method in class com.hazelcast.sql.SqlStatement
-
Sets the SQL string to be executed.
- setSqlConfig(SqlConfig) - Method in class com.hazelcast.config.Config
-
Sets SQL config.
- setSSLConfig(SSLConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-
- setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
-
- setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.EndpointConfig
-
- setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.NetworkConfig
-
- setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
- setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
- setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.VaultSecureStoreConfig
-
Sets the SSL/TLS configuration.
- setStatementTimeoutMillis(long) - Method in class com.hazelcast.config.SqlConfig
-
Sets the timeout in milliseconds that is applied to statements without an explicit timeout.
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
-
Sets whether or not statistics gathering is enabled on this cache.
- setStatisticsEnabled(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
-
Sets whether statistics gathering is enabled on a cache.
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets statistics to enabled or disabled for this
ICache
.
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.CollectionConfig
-
Sets collection statistics to enabled or disabled.
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.DurableExecutorConfig
-
Enables or disables statistics gathering on the executor task.
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ExecutorConfig
-
Enables or disables statistics gathering on the executor task.
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
Enables or disables statistics gathering of LocalFlakeIdGeneratorStats
.
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.MapConfig
-
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.JobConfig
-
Sets whether metrics should be stored in the cluster after the job completes.
- setString(String, String) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- setStringArray(String, String[]) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- 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
-
- setSymmetricEncryptionConfig(SymmetricEncryptionConfig) - Method in class com.hazelcast.config.NetworkConfig
-
- setSymmetricEncryptionConfig(SymmetricEncryptionConfig) - Method in class com.hazelcast.config.RestServerEndpointConfig
-
- setSymmetricEncryptionConfig(SymmetricEncryptionConfig) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
-
- setSyncConfig(WanSyncConfig) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets the config for the WAN sync mechanism.
- setSynchronous(boolean) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
If true
, this cache entry listener implementation will be called in a synchronous manner.
- setSystemAuthentication(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- setSystemProperty(String) - Method in class com.hazelcast.spi.properties.HazelcastProperty
-
Sets the system property value of the property.
- setSystemUserDn(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- setSystemUserPassword(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- setTag(Tag) - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.Node
-
- setTagConstructors(Map<Tag, ConstructNode>) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettingsBuilder
-
Provide constructors for the specified tags.
- setTagDirective(Map<String, String>) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettingsBuilder
-
Add TAG directive (http://yaml.org/spec/1.2/spec.html#id2782090)
- 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.
- setTime(String, LocalTime) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
Sets a time field consisting of hour, minute, seconds and nanos parts
It is legal to set the field again only when Builder is created with
GenericRecord.cloneWithBuilder()
.
- setTimeArray(String, LocalTime[]) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- setTimeout(long, TimeUnit) - Method in class com.hazelcast.transaction.TransactionOptions
-
Sets the timeout.
- setTimeoutMillis(long) - Method in class com.hazelcast.sql.SqlStatement
-
Sets the execution timeout in milliseconds.
- setTimeoutMilliseconds(int) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
-
- setTimeoutMilliseconds(int) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
-
Sets the timeout in Milliseconds before declaring a failed ping
This cannot be more than the interval value.
- setTimestamp(long) - Method in class com.hazelcast.jet.datamodel.TimestampedItem
-
Sets the timestamp.
- setTimestamp(String, LocalDateTime) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
Sets a timestamp field consisting of
year , month of the year and day of the month, hour, minute, seconds, nanos parts
It is legal to set the field again only when Builder is created with
GenericRecord.cloneWithBuilder()
.
- setTimestampArray(String, LocalDateTime[]) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- setTimestampWithTimezone(String, OffsetDateTime) - Method in interface com.hazelcast.nio.serialization.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
It is legal to set the field again only when Builder is created with
GenericRecord.cloneWithBuilder()
.
- setTimestampWithTimezoneArray(String, OffsetDateTime[]) - Method in interface com.hazelcast.nio.serialization.GenericRecordBuilder
-
- 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.
- SettingKey - Interface in com.hazelcast.org.snakeyaml.engine.v2.api
-
Type for the custom keys in settings.
- settings - Variable in class com.hazelcast.org.snakeyaml.engine.v2.api.Dump
-
- settings - Variable in class com.hazelcast.org.snakeyaml.engine.v2.constructor.BaseConstructor
-
- settings - Variable in class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter
-
- setTlsAuthenticationConfig(TlsAuthenticationConfig) - Method in class com.hazelcast.config.security.RealmConfig
-
- setToken(String) - Method in class com.hazelcast.config.VaultSecureStoreConfig
-
Sets the Vault access token.
- setTokenIdentityConfig(TokenIdentityConfig) - Method in class com.hazelcast.client.config.ClientSecurityConfig
-
- setTokenIdentityConfig(TokenIdentityConfig) - Method in class com.hazelcast.config.security.RealmConfig
-
- setTopicConfigs(Map<String, TopicConfig>) - Method in class com.hazelcast.config.Config
-
Sets the map of
ITopic
configurations,
mapped by config name.
- setTopicOverloadPolicy(TopicOverloadPolicy) - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
-
Sets the TopicOverloadPolicy for this reliable topic.
- setTopicOverloadPolicy(TopicOverloadPolicy) - Method in class com.hazelcast.config.ReliableTopicConfig
-
Sets the TopicOverloadPolicy for this reliable topic.
- 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
-
- setTransactionType(TransactionOptions.TransactionType) - Method in class com.hazelcast.transaction.TransactionOptions
-
- setTrustedInterfaces(Set<String>) - Method in class com.hazelcast.config.ManagementCenterConfig
-
Sets the trusted interfaces.
- setTrustedInterfaces(Set<String>) - Method in class com.hazelcast.config.MulticastConfig
-
Sets the trusted interfaces.
- setTrustedInterfaces(Set<String>) - Method in interface com.hazelcast.config.TrustedInterfacesConfigurable
-
Sets the trusted interfaces.
- setTryCount(int) - Method in class com.hazelcast.client.config.ClientFailoverConfig
-
Sets the count of attempts to connect to a cluster.
- setTtl(int) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
-
- setTtl(int) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
-
Sets the maximum number of times the IP Datagram (ping) can be forwarded, in most cases
all Hazelcast cluster members would be within one network switch/router therefore
- setTtl(K, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
-
Updates the TTL (time to live) value of the entry specified by key
with a new TTL value.
- setType(IndexType) - Method in class com.hazelcast.config.IndexConfig
-
Sets type of the index.
- setType(String) - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
-
Sets the Java KeyStore type (PKCS12, JCEKS etc.)
- setType(PermissionConfig.PermissionType) - Method in class com.hazelcast.config.PermissionConfig
-
- setTypeClass(Class) - Method in class com.hazelcast.config.SerializerConfig
-
Sets the type of the class that will be serialized via this implementation.
- setTypeClassName(String) - Method in class com.hazelcast.config.SerializerConfig
-
This method is called only if typeClass is not set.
- setTypes(Class<K>, Class<V>) - Method in class com.hazelcast.config.AbstractCacheConfig
-
Sets the expected type of keys and values for a Cache
configured with this Configuration
.
- setTypes(Class<K>, Class<V>) - Method in interface com.hazelcast.config.CacheConfiguration
-
Sets the expected type of keys and values for a Cache
configured with this Configuration
.
- setUncommittedEntryCountToRejectNewAppends(int) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
-
- setUniqueKey(String) - Method in class com.hazelcast.config.BitmapIndexOptions
-
Sets unique key attribute in this index config.
- setUniqueKeyTransformation(BitmapIndexOptions.UniqueKeyTransformation) - Method in class com.hazelcast.config.BitmapIndexOptions
-
Sets unique key transformation in this index config.
- setUriString(String) - Method in class com.hazelcast.config.CacheConfig
-
Sets the URI string, which is the global identifier of the
ICache
.
- setUrl(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- setUsage(LoginModuleConfig.LoginModuleUsage) - Method in class com.hazelcast.config.LoginModuleConfig
-
- setUseCanonicalHostname(Boolean) - Method in class com.hazelcast.config.security.KerberosIdentityConfig
-
- setUseEndpointPrivateAddress(boolean) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
Sets whether the WAN connection manager should connect to the
endpoint on the private address returned by the discovery SPI.
- setUseMarks(boolean) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettingsBuilder
-
Marks are only used for error messages.
- setUseNameWithoutRealm(Boolean) - Method in class com.hazelcast.config.security.KerberosAuthenticationConfig
-
- setUseNativeByteOrder(boolean) - Method in class com.hazelcast.config.SerializationConfig
-
- setUsePublicIp(boolean) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
-
Decides whether the public or private IP should be used to connect to Hazelcast members.
- setUserCodeDeploymentConfig(ClientUserCodeDeploymentConfig) - Method in class com.hazelcast.client.config.ClientConfig
-
Set User Code Deployment configuration
- setUserCodeDeploymentConfig(UserCodeDeploymentConfig) - Method in class com.hazelcast.config.Config
-
Set User Code Deployment configuration
- setUserContext(ConcurrentMap<String, Object>) - Method in class com.hazelcast.client.config.ClientConfig
-
- setUserContext(ConcurrentMap<String, Object>) - Method in class com.hazelcast.config.Config
-
Sets the user supplied context.
- setUserContext(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- setUserFilter(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- setUserNameAttribute(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- setUsernamePasswordIdentityConfig(UsernamePasswordIdentityConfig) - Method in class com.hazelcast.client.config.ClientSecurityConfig
-
- setUsernamePasswordIdentityConfig(String, String) - Method in class com.hazelcast.client.config.ClientSecurityConfig
-
- setUsernamePasswordIdentityConfig(UsernamePasswordIdentityConfig) - Method in class com.hazelcast.config.security.RealmConfig
-
- setUsernamePasswordIdentityConfig(String, String) - Method in class com.hazelcast.config.security.RealmConfig
-
- setUserSearchScope(LdapSearchScope) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
-
- setUseUnicodeEncoding(boolean) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettingsBuilder
-
Specify whether to emit non-ASCII printable Unicode characters
(emit Unicode char or escape sequence starting with '\\u')
The default value is true.
- setValidationTimeoutSeconds(int) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
-
Sets validation timeout for hot-restart process, includes validating
cluster members expected to join and partition table on all cluster.
- setValue(R) - Method in class com.hazelcast.jet.datamodel.KeyedWindowResult
-
Implements Map.Entry
, throws UnsupportedOperationException
.
- setValue(E1) - Method in class com.hazelcast.jet.datamodel.Tuple2
-
- 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
- setValue(List<NodeTuple>) - Method in class com.hazelcast.org.snakeyaml.engine.v2.nodes.MappingNode
-
- setValueClassName(String) - Method in class com.hazelcast.config.AbstractCacheConfig
-
- setValueCollectionType(String) - Method in class com.hazelcast.config.MultiMapConfig
-
Sets the collection type for the values of this MultiMap.
- setValueCollectionType(MultiMapConfig.ValueCollectionType) - Method in class com.hazelcast.config.MultiMapConfig
-
Sets the collection type for the values of this MultiMap.
- setValueType(Class<V>) - Method in class com.hazelcast.config.AbstractCacheConfig
-
- setValueType(String) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Sets the value type for this
ICache
.
- setVersion(Version) - Method in interface com.hazelcast.nio.VersionAware
-
If the serializer supports versioning it may set the version to use for
the serialization on this object.
- setVersionFunction(UnaryOperator<SpecVersion>) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.LoadSettingsBuilder
-
Manage YAML directive value which defines the version of the YAML specification.
- 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
-
Comma-separated list of class prefixes which will be loaded remotely.
- setWidth(int) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettingsBuilder
-
Set max width for literal scalars.
- 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
-
- setWriteDelaySeconds(int) - Method in class com.hazelcast.config.MapStoreConfig
-
Sets the number of seconds to delay before writing (storing) the dirty records
- setWriteThrough(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
-
- setWriteThrough(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
-
Set if write-through caching should be used.
- setWriteThrough(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Enables or disables write-through for this
ICache
: a write to the queue also loads
the entry into the data store.
- setYamlDirective(Optional<SpecVersion>) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.DumpSettingsBuilder
-
Add YAML directive (http://yaml.org/spec/1.2/spec.html#id2781553)
- severe(String) - Method in class com.hazelcast.logging.AbstractLogger
-
- severe(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
-
- severe(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
-
- severe(String) - Method in interface com.hazelcast.logging.ILogger
-
- severe(Throwable) - Method in interface com.hazelcast.logging.ILogger
-
- severe(String, Throwable) - Method in interface com.hazelcast.logging.ILogger
-
Logs a message with an associated throwable at the
Level.SEVERE
level.
- SHARED_JCACHE_INSTANCE_NAME - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
-
Name of default
HazelcastInstance
which may be started when
obtaining the default
CachingProvider
.
- sharedConsumer(boolean) - Method in class com.hazelcast.jet.pipeline.JmsSourceBuilder
-
Specifies whether the MessageConsumer of the JMS topic is shared, that
is whether
createSharedConsumer()
or
createSharedDurableConsumer()
was used to create it in the
JmsSourceBuilder.consumerFn(FunctionEx)
.
- sharedFileSystem(boolean) - Method in class com.hazelcast.jet.pipeline.file.FileSourceBuilder
-
If sharedFileSystem
is true
, 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
-
- 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.
- sHexValues - Static variable in class com.hazelcast.com.fasterxml.jackson.core.io.CharTypes
-
Lookup table for the first 256 Unicode characters (ASCII / UTF-8)
range.
- SHORT_WRITE - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- shouldHandle(OutOfMemoryError) - Method in class com.hazelcast.core.OutOfMemoryHandler
-
Decides if the OutOfMemoryError thrown will be handled by this OutOfMemoryHandler or not.
- SHUFFLE_MEMBER_LIST - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Client shuffles the given member list to prevent all clients to connect to the same node when
this property is set to true.
- shutdown(HazelcastInstance) - Static method in class com.hazelcast.client.HazelcastClient
-
Shutdown the provided client and remove it from the managed list
- shutdown(String) - Static method in class com.hazelcast.client.HazelcastClient
-
Shutdown the provided client and remove it from the managed list
- shutdown() - Method in interface com.hazelcast.cluster.Cluster
-
Changes state of the cluster to the
ClusterState.PASSIVE
transactionally,
then triggers the shutdown process on each node.
- shutdown(TransactionOptions) - Method in interface com.hazelcast.cluster.Cluster
-
Changes state of the cluster to the
ClusterState.PASSIVE
transactionally, then
triggers the shutdown process on each node.
- shutdown() - Method in interface com.hazelcast.core.HazelcastInstance
-
Shuts down this HazelcastInstance.
- shutdown() - Method in interface com.hazelcast.core.LifecycleService
-
Gracefully shuts down HazelcastInstance.
- shutdown() - Method in interface com.hazelcast.jet.JetInstance
-
Shuts down the current instance.
- shutdown() - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
-
Initiates an orderly shutdown in which previously submitted tasks are
executed, but no new tasks will be accepted.
- shutdown() - Method in interface com.hazelcast.wan.WanConsumer
-
Callback method to shutdown the WAN replication consumer.
- shutdown() - Method in interface com.hazelcast.wan.WanPublisher
-
Closes the publisher and its internal connections and shuts down other internal states.
- shutdownAll() - Static method in class com.hazelcast.client.HazelcastClient
-
Shuts down all the client HazelcastInstance created in this JVM.
- shutdownAll() - Static method in class com.hazelcast.core.Hazelcast
-
- shutdownAll() - Static method in class com.hazelcast.jet.Jet
-
Shuts down all running Jet client and member instances.
- shutdownAll() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
-
- shutdownHazelcastInstance(HazelcastOSGiInstance) - Method in interface com.hazelcast.osgi.HazelcastOSGiService
-
- SHUTDOWNHOOK_ENABLED - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Enable Hazelcast shutdownhook thread.
- SHUTDOWNHOOK_POLICY - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Behaviour when JVM is about to exit while Hazelcast instance is still running.
- SilentException - Interface in com.hazelcast.spi.exception
-
Marked interface for exceptions.
- SimpleDiscoveryNode - Class in com.hazelcast.spi.discovery
-
- SimpleDiscoveryNode(Address) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
-
This constructor will set private and public addresses to the same value and no properties
are available.
- SimpleDiscoveryNode(Address, Map<String, String>) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
-
This constructor will set private and public addresses to the same value.
- SimpleDiscoveryNode(Address, Address) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
-
This constructor will set private and public addresses separately and no properties are available.
- SimpleDiscoveryNode(Address, Address, Map<String, String>) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
-
This constructor will set private and public addresses separately.
- 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
-
- SimplePropertyDefinition(String, TypeConverter) - Constructor for class com.hazelcast.config.properties.SimplePropertyDefinition
-
- SimplePropertyDefinition(String, boolean, TypeConverter) - Constructor for class com.hazelcast.config.properties.SimplePropertyDefinition
-
- SimplePropertyDefinition(String, boolean, TypeConverter, ValueValidator) - Constructor for class com.hazelcast.config.properties.SimplePropertyDefinition
-
- SimpleTokenCredentials - Class in com.hazelcast.security
-
Simple implementation of
Credentials
using a raw byte array token.
- SimpleTokenCredentials() - Constructor for class com.hazelcast.security.SimpleTokenCredentials
-
- SimpleTokenCredentials(byte[]) - Constructor for class com.hazelcast.security.SimpleTokenCredentials
-
- SimulateLoadTask - Class in com.hazelcast.console
-
A simulated load test.
- SimulateLoadTask(int, int, String) - Constructor for class com.hazelcast.console.SimulateLoadTask
-
- singleAttribute(String) - Static method in class com.hazelcast.projection.Projections
-
Returns a projection that extracts the value of the given attributePath
.
- singleton(T) - Static method in class com.hazelcast.jet.Traversers
-
Returns a traverser over the given single item.
- 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.
- Sink<T> - Interface in com.hazelcast.jet.pipeline
-
A data sink in a Jet pipeline.
- SinkBuilder<C,T> - Class in com.hazelcast.jet.pipeline
-
- 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.
- 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.
- sInputCodes - Static variable in class com.hazelcast.com.fasterxml.jackson.core.io.CharTypes
-
Lookup table used for determining which input characters
need special handling when contained in text segment.
- sInputCodesComment - Static variable in class com.hazelcast.com.fasterxml.jackson.core.io.CharTypes
-
Decoding table used to quickly determine characters that are
relevant within comment content.
- sInputCodesJsNames - Static variable in class com.hazelcast.com.fasterxml.jackson.core.io.CharTypes
-
To support non-default (and -standard) unquoted field names mode,
need to have alternate checking.
- sInputCodesUTF8 - Static variable in class com.hazelcast.com.fasterxml.jackson.core.io.CharTypes
-
Additionally we can combine UTF-8 decoding info into similar
data table.
- sInputCodesUtf8JsNames - Static variable in class com.hazelcast.com.fasterxml.jackson.core.io.CharTypes
-
This table is similar to Latin-1, except that it marks all "high-bit"
code as ok.
- sInputCodesWS - Static variable in class com.hazelcast.com.fasterxml.jackson.core.io.CharTypes
-
Decoding table used for skipping white space and comments.
- 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 class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
- size() - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
-
- size() - Method in interface com.hazelcast.com.fasterxml.jackson.core.TreeNode
-
Method that returns number of child nodes this node contains:
for Array nodes, number of child elements, for Object nodes,
number of fields, and for all other nodes 0.
- size() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
-
- size() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
-
- size - Variable in class com.hazelcast.config.EvictionConfig
-
- 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
-
- 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
-
- size() - Method in interface com.hazelcast.transaction.TransactionalMultiMap
-
Returns the number of key-value pairs in the multimap.
- size() - Method in interface com.hazelcast.transaction.TransactionalQueue
-
Returns the number of elements in this collection.
- size() - Method in interface com.hazelcast.transaction.TransactionalSet
-
Returns the size of the set.
- skip(long) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.MergedStream
-
- skip(long) - Method in class com.hazelcast.config.ConfigStream
-
- skipChildren() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- skipChildren() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
Need to override, re-implement similar to how method defined in
ParserMinimalBase
, to keep
state correct here.
- skipChildren() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- skipChildren() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- skipChildren() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserSequence
-
Need to override, re-implement similar to how method defined in
ParserMinimalBase
, to keep
state correct here.
- skipParentChecks() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
-
- skipUTF8BOM(DataInput) - Static method in class com.hazelcast.com.fasterxml.jackson.core.json.ByteSourceJsonBootstrapper
-
Helper method that may be called to see if given
DataInput
has BOM marker, and if so, to skip it.
- 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 by slideBy
.
- 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.
- slowParseName() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
Method called when not even first 8 bytes are guaranteed
to come consecutively.
- 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.
- snapshottingEnabled() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
-
Returns true, if snapshots will be saved for this job.
- 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, FunctionEx<? super T, ? extends String>) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
- socket(String, int) - Static method in class com.hazelcast.jet.pipeline.Sinks
-
- 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(String, int) - Static method in class com.hazelcast.jet.pipeline.Sources
-
- SOCKET_BIND_ANY - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Bind both server-socket and client-sockets to any local interface.
- SOCKET_BUFFER_DIRECT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
If the bytebuffers used in the socket should be a direct bytebuffer (true
)
or a regular bytebuffer (false
).
- SOCKET_CLIENT_BIND - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Bind client socket to an interface when connecting to a remote server
socket.
- SOCKET_CLIENT_BIND_ANY - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Bind client-sockets to any local interface.
- SOCKET_CLIENT_BUFFER_DIRECT - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
If the bytebuffers used in the socket should be a direct bytebuffer (true
)
or a regular bytebuffer (false
).
- SOCKET_CLIENT_RECEIVE_BUFFER_SIZE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Overrides receive buffer size for connections opened by clients.
- SOCKET_CLIENT_SEND_BUFFER_SIZE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Overrides send buffer size for connections opened by clients.
- SOCKET_CONNECT_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Socket connection timeout in seconds.
- SOCKET_KEEP_ALIVE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Socket set keep alive (SO_KEEPALIVE).
- SOCKET_LINGER_SECONDS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Set socket SO_LINGER option.
- SOCKET_NO_DELAY - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Socket set TCP no delay.
- SOCKET_RECEIVE_BUFFER_SIZE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Socket receive buffer (SO_RCVBUF) size in KB.
- SOCKET_SEND_BUFFER_SIZE - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Socket send buffer (SO_SNDBUF) size in KB.
- SOCKET_SERVER_BIND_ANY - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Bind server-socket to any local interface.
- SocketInterceptor - Interface in com.hazelcast.nio
-
An interface that provides the ability to intercept the creation of sockets.
- socketInterceptorConfig - Variable in class com.hazelcast.config.EndpointConfig
-
- SocketInterceptorConfig - Class in com.hazelcast.config
-
Contains the configuration for interceptor socket.
- SocketInterceptorConfig() - Constructor for class com.hazelcast.config.SocketInterceptorConfig
-
- SocketInterceptorConfig(SocketInterceptorConfig) - Constructor for class com.hazelcast.config.SocketInterceptorConfig
-
- SocketOptions - Class in com.hazelcast.client.config
-
TCP Socket options
- SocketOptions() - Constructor for class com.hazelcast.client.config.SocketOptions
-
- SocketOptions(SocketOptions) - Constructor for class com.hazelcast.client.config.SocketOptions
-
- 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.
- 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 the
complete
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
-
- 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
-
- sourceDescription() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonLocation
-
- 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.
- sOutputEscapes - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonGeneratorImpl
-
This is the default set of escape codes, over 7-bit ASCII range
(first 128 character codes), used for single-byte UTF-8 characters.
- sOutputEscapes128 - Static variable in class com.hazelcast.com.fasterxml.jackson.core.io.CharTypes
-
Lookup table used for determining which output characters in
7-bit ASCII range need to be quoted.
- SpecVersion - Class in com.hazelcast.org.snakeyaml.engine.v2.common
-
- SpecVersion(int, int) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.common.SpecVersion
-
- spilloverCount() - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
Method mostly needed by unit tests; calculates number of entries
in shared spill-over area
- 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
-
- SplitBrainMergePolicyProvider(ClassLoader) - Constructor for class com.hazelcast.spi.merge.SplitBrainMergePolicyProvider
-
- 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
-
- SplitBrainMergeTypes.AtomicReferenceMergeTypes - Interface in com.hazelcast.spi.merge
-
- SplitBrainMergeTypes.CacheMergeTypes<K,V> - Interface in com.hazelcast.spi.merge
-
Provided merge types of
ICache
.
- SplitBrainMergeTypes.CardinalityEstimatorMergeTypes - Interface in com.hazelcast.spi.merge
-
- SplitBrainMergeTypes.CollectionMergeTypes<V> - Interface in com.hazelcast.spi.merge
-
Provided merge types of collections (
ISet
and
IList
).
- SplitBrainMergeTypes.MapMergeTypes<K,V> - Interface in com.hazelcast.spi.merge
-
Provided merge types of
IMap
.
- SplitBrainMergeTypes.MultiMapMergeTypes<K,V> - Interface in com.hazelcast.spi.merge
-
- SplitBrainMergeTypes.QueueMergeTypes<V> - Interface in com.hazelcast.spi.merge
-
Provided merge types of
IQueue
.
- SplitBrainMergeTypes.ReplicatedMapMergeTypes<K,V> - Interface in com.hazelcast.spi.merge
-
- SplitBrainMergeTypes.RingbufferMergeTypes - Interface in com.hazelcast.spi.merge
-
- SplitBrainMergeTypes.ScheduledExecutorMergeTypes - Interface in com.hazelcast.spi.merge
-
- SplitBrainProtection - Interface in com.hazelcast.splitbrainprotection
-
- SplitBrainProtectionConfig - Class in com.hazelcast.config
-
Configuration for cluster split brain protection, a means to protect consistency of data from network
partitions.
- SplitBrainProtectionConfig() - Constructor for class com.hazelcast.config.SplitBrainProtectionConfig
-
- SplitBrainProtectionConfig(String) - Constructor for class com.hazelcast.config.SplitBrainProtectionConfig
-
- SplitBrainProtectionConfig(String, boolean) - Constructor for class com.hazelcast.config.SplitBrainProtectionConfig
-
- SplitBrainProtectionConfig(String, boolean, int) - Constructor for class com.hazelcast.config.SplitBrainProtectionConfig
-
- SplitBrainProtectionConfig(SplitBrainProtectionConfig) - Constructor for class com.hazelcast.config.SplitBrainProtectionConfig
-
- SplitBrainProtectionConfigBuilder - Class in com.hazelcast.config
-
Commons for split brain protection config builders.
- SplitBrainProtectionConfigBuilder() - Constructor for class com.hazelcast.config.SplitBrainProtectionConfigBuilder
-
- SplitBrainProtectionEvent - Class in com.hazelcast.splitbrainprotection
-
- SplitBrainProtectionEvent(Object, int, Collection<Member>, boolean) - Constructor for class com.hazelcast.splitbrainprotection.SplitBrainProtectionEvent
-
- SplitBrainProtectionException - Exception in com.hazelcast.splitbrainprotection
-
An exception thrown when the cluster size is below the defined threshold.
- SplitBrainProtectionException(String) - Constructor for exception com.hazelcast.splitbrainprotection.SplitBrainProtectionException
-
- SplitBrainProtectionFunction - Interface in com.hazelcast.splitbrainprotection
-
A function that can be used to conclude whether the minimum cluster size property is satisfied?
The split brain protection function is consulted:
When a cluster membership change occurs (member added or removed)
Whenever a hearbeat is received from a member, in case the
SplitBrainProtectionFunction
also
implements
HeartbeatAware
A
SplitBrainProtectionFunction
that implements
HeartbeatAware
will be also notified of heartbeats.
- SplitBrainProtectionListener - Interface in com.hazelcast.splitbrainprotection
-
Listener to get notified when a split brain protection state is changed.
- SplitBrainProtectionListenerConfig - Class in com.hazelcast.config
-
- SplitBrainProtectionListenerConfig() - Constructor for class com.hazelcast.config.SplitBrainProtectionListenerConfig
-
- SplitBrainProtectionListenerConfig(String) - Constructor for class com.hazelcast.config.SplitBrainProtectionListenerConfig
-
- SplitBrainProtectionListenerConfig(SplitBrainProtectionListener) - Constructor for class com.hazelcast.config.SplitBrainProtectionListenerConfig
-
- SplitBrainProtectionOn - Enum in com.hazelcast.splitbrainprotection
-
Represents a cluster split brain protection type
- SplitBrainProtectionService - Interface in com.hazelcast.splitbrainprotection
-
Split brain protection service can be used to trigger cluster split brain protections at any time.
- sql - Variable in class com.hazelcast.config.PredicateConfig
-
- sql(JetCommandLine.Verbosity, JetCommandLine.TargetsMixin) - Method in class com.hazelcast.jet.server.JetCommandLine
-
- sql(String) - Static method in class com.hazelcast.query.Predicates
-
Creates a predicate that will pass items that match the given SQL 'where' expression.
- SqlColumnMetadata - Class in com.hazelcast.sql
-
SQL column metadata.
- SqlColumnMetadata(String, SqlColumnType, boolean) - Constructor for class com.hazelcast.sql.SqlColumnMetadata
-
- SqlColumnType - Enum in com.hazelcast.sql
-
SQL column type.
- SqlConfig - Class in com.hazelcast.config
-
SQL service configuration.
- SqlConfig() - Constructor for class com.hazelcast.config.SqlConfig
-
- SqlExpectedResultType - Enum in com.hazelcast.sql
-
The expected statement result type.
- SqlResult - Interface in com.hazelcast.sql
-
SQL query result.
- SqlRow - Interface in com.hazelcast.sql
-
SQL row.
- SqlRowMetadata - Class in com.hazelcast.sql
-
SQL row metadata.
- SqlRowMetadata(List<SqlColumnMetadata>) - Constructor for class com.hazelcast.sql.SqlRowMetadata
-
- SqlService - Interface in com.hazelcast.sql
-
A service to execute SQL statements.
- SqlStatement - Class in com.hazelcast.sql
-
Definition of an SQL statement.
- SqlStatement(String) - Constructor for class com.hazelcast.sql.SqlStatement
-
- sslConfig - Variable in class com.hazelcast.config.EndpointConfig
-
- SSLConfig - Class in com.hazelcast.config
-
SSL configuration.
- SSLConfig() - Constructor for class com.hazelcast.config.SSLConfig
-
- SSLConfig(SSLConfig) - Constructor for class com.hazelcast.config.SSLConfig
-
- SSLContextFactory - Interface in com.hazelcast.nio.ssl
-
- 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 the
Ringbuffer
using a sequence that is smaller
than the current head sequence and that the ringbuffer store is disabled.
- StaleSequenceException(String, long) - Constructor for exception com.hazelcast.ringbuffer.StaleSequenceException
-
Creates a StaleSequenceException with the given message.
- StaleSequenceException(String, long, Throwable) - Constructor for exception com.hazelcast.ringbuffer.StaleSequenceException
-
- StaleTaskException - Exception in com.hazelcast.scheduledexecutor
-
Exception thrown by the
IScheduledFuture
during any operation on a stale (=previously destroyed) task.
- StaleTaskException(String) - Constructor for exception com.hazelcast.scheduledexecutor.StaleTaskException
-
- StaleTaskIdException - Exception in com.hazelcast.durableexecutor
-
- StaleTaskIdException(String) - Constructor for exception com.hazelcast.durableexecutor.StaleTaskIdException
-
- standardAsciiEscapesForJSON() - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.CharacterEscapes
-
Helper method that can be used to get a copy of standard JSON
escape definitions; this is useful when just wanting to slightly
customize definitions.
- StandardConstructor - Class in com.hazelcast.org.snakeyaml.engine.v2.constructor
-
Construct standard Java classes
- StandardConstructor(LoadSettings) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.constructor.StandardConstructor
-
- StandardConstructor.ConstructEnv - Class in com.hazelcast.org.snakeyaml.engine.v2.constructor
-
Construct scalar for format ${VARIABLE} replacing the template with the value from environment.
- StandardConstructor.ConstructOptionalClass - Class in com.hazelcast.org.snakeyaml.engine.v2.constructor
-
- StandardConstructor.ConstructUuidClass - Class in com.hazelcast.org.snakeyaml.engine.v2.constructor
-
- StandardConstructor.ConstructYamlBinary - Class in com.hazelcast.org.snakeyaml.engine.v2.constructor
-
- StandardConstructor.ConstructYamlBool - Class in com.hazelcast.org.snakeyaml.engine.v2.constructor
-
- StandardConstructor.ConstructYamlFloat - Class in com.hazelcast.org.snakeyaml.engine.v2.constructor
-
- StandardConstructor.ConstructYamlInt - Class in com.hazelcast.org.snakeyaml.engine.v2.constructor
-
- StandardConstructor.ConstructYamlMap - Class in com.hazelcast.org.snakeyaml.engine.v2.constructor
-
- StandardConstructor.ConstructYamlNull - Class in com.hazelcast.org.snakeyaml.engine.v2.constructor
-
- StandardConstructor.ConstructYamlOmap - Class in com.hazelcast.org.snakeyaml.engine.v2.constructor
-
- StandardConstructor.ConstructYamlSeq - Class in com.hazelcast.org.snakeyaml.engine.v2.constructor
-
- StandardConstructor.ConstructYamlSet - Class in com.hazelcast.org.snakeyaml.engine.v2.constructor
-
- StandardConstructor.ConstructYamlStr - Class in com.hazelcast.org.snakeyaml.engine.v2.constructor
-
- StandardLoggerFactory - Class in com.hazelcast.logging
-
- StandardLoggerFactory() - Constructor for class com.hazelcast.logging.StandardLoggerFactory
-
- StandardRepresenter - Class in com.hazelcast.org.snakeyaml.engine.v2.representer
-
Represent standard Java classes
- StandardRepresenter(DumpSettings) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.representer.StandardRepresenter
-
- StandardRepresenter.RepresentArray - Class in com.hazelcast.org.snakeyaml.engine.v2.representer
-
- StandardRepresenter.RepresentBoolean - Class in com.hazelcast.org.snakeyaml.engine.v2.representer
-
- StandardRepresenter.RepresentByteArray - Class in com.hazelcast.org.snakeyaml.engine.v2.representer
-
- StandardRepresenter.RepresentEnum - Class in com.hazelcast.org.snakeyaml.engine.v2.representer
-
- StandardRepresenter.RepresentIterator - Class in com.hazelcast.org.snakeyaml.engine.v2.representer
-
- StandardRepresenter.RepresentList - Class in com.hazelcast.org.snakeyaml.engine.v2.representer
-
- StandardRepresenter.RepresentMap - Class in com.hazelcast.org.snakeyaml.engine.v2.representer
-
- StandardRepresenter.RepresentNull - Class in com.hazelcast.org.snakeyaml.engine.v2.representer
-
- StandardRepresenter.RepresentNumber - Class in com.hazelcast.org.snakeyaml.engine.v2.representer
-
- StandardRepresenter.RepresentOptional - Class in com.hazelcast.org.snakeyaml.engine.v2.representer
-
- StandardRepresenter.RepresentPrimitiveArray - Class in com.hazelcast.org.snakeyaml.engine.v2.representer
-
Represents primitive arrays, such as short[] and float[], by converting
them into equivalent
List
using the appropriate
autoboxing type.
- StandardRepresenter.RepresentSet - Class in com.hazelcast.org.snakeyaml.engine.v2.representer
-
- StandardRepresenter.RepresentString - Class in com.hazelcast.org.snakeyaml.engine.v2.representer
-
- StandardRepresenter.RepresentUuid - Class in com.hazelcast.org.snakeyaml.engine.v2.representer
-
- start(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
-
- 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 class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
-
- start() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategy
-
The start
method is used to initialize internal state and perform any kind of
startup procedure like multicast socket creation.
- start() - Method in interface com.hazelcast.spi.discovery.integration.DiscoveryService
-
The start
method is called on system startup to implement simple
lifecycle management.
- start() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategy
-
- stateChanged(LifecycleEvent) - Method in class com.hazelcast.client.util.ClientStateListener
-
- stateChanged(LifecycleEvent) - Method in interface com.hazelcast.core.LifecycleListener
-
Called when instance's state changes.
- StatefulTask<K,V> - Interface in com.hazelcast.scheduledexecutor
-
- StaticCredentialsFactory - Class in com.hazelcast.config.security
-
- StaticCredentialsFactory(Credentials) - Constructor for class com.hazelcast.config.security.StaticCredentialsFactory
-
- StaticLB - Class in com.hazelcast.client.util
-
The StaticLB is a
LoadBalancer
that always returns the same member.
- StaticLB(Member) - Constructor for class com.hazelcast.client.util.StaticLB
-
- STATISTICS_ENABLED - Static variable in class com.hazelcast.client.properties.ClientProperty
-
Use to enable the client statistics collection.
- STATISTICS_PERIOD_SECONDS - Static variable in class com.hazelcast.client.properties.ClientProperty
-
The period in seconds the statistics run.
- status() - Method in interface com.hazelcast.cp.CPGroup
-
Returns status of the CP group
- STATUS_EXPECT_NAME - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
- STATUS_EXPECT_VALUE - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
- STATUS_OK_AFTER_COLON - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
- STATUS_OK_AFTER_COMMA - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
- STATUS_OK_AFTER_SPACE - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
- STATUS_OK_AS_IS - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
- Std(InputStream, byte[]) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.format.InputAccessor.Std
-
Constructor used when content to check is available via
input stream and must be read.
- Std(byte[]) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.format.InputAccessor.Std
-
Constructor used when the full input (or at least enough leading bytes
of full input) is available.
- Std(byte[], int, int) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.format.InputAccessor.Std
-
Constructor used when the full input (or at least enough leading bytes
of full input) is available.
- stop() - Method in class com.hazelcast.client.console.ClientConsoleApp
-
- stop() - Method in class com.hazelcast.console.ConsoleApp
-
- store(Long, T) - Method in interface com.hazelcast.collection.QueueStore
-
Stores the key-value pair.
- store(K, V) - Method in interface com.hazelcast.map.MapStore
-
Stores the key-value pair.
- store(K, V) - Method in class com.hazelcast.map.MapStoreAdapter
-
Stores the key-value pair.
- store(long, T) - Method in interface com.hazelcast.ringbuffer.RingbufferStore
-
Stores one item with it's corresponding sequence.
- STORE_BINARY - Static variable in class com.hazelcast.config.QueueStoreConfig
-
Binary: By default, Hazelcast stores the queue items in serialized form in memory.
- STORE_BULK_LOAD - Static variable in class com.hazelcast.config.QueueStoreConfig
-
Bulk Load: When the queue is initialized, items are loaded from QueueStore in bulks.
- STORE_MEMORY_LIMIT - Static variable in class com.hazelcast.config.QueueStoreConfig
-
Memory Limit: This is the number of items after which Hazelcast will store items only to
datastore.
- storeAll(Map<Long, T>) - Method in interface com.hazelcast.collection.QueueStore
-
Stores multiple entries.
- storeAll(Map<K, V>) - Method in interface com.hazelcast.map.MapStore
-
Stores multiple entries.
- storeAll(Map<K, V>) - Method in class com.hazelcast.map.MapStoreAdapter
-
Stores multiple entries.
- storeAll(long, T[]) - Method in interface com.hazelcast.ringbuffer.RingbufferStore
-
Stores multiple items.
- storeSequence(long) - Method in interface com.hazelcast.topic.ReliableMessageListener
-
Informs the ReliableMessageListener that it should store the sequence.
- STR - Static variable in class com.hazelcast.org.snakeyaml.engine.v2.nodes.Tag
-
- stream(String, FunctionEx<? super Processor.Context, ? extends C>) - Static method in class com.hazelcast.jet.pipeline.SourceBuilder
-
- streamCacheP(String, JournalInitialPosition, EventTimePolicy<? super Map.Entry<K, V>>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- 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
-
- StreamDataWriter - Interface in com.hazelcast.org.snakeyaml.engine.v2.api
-
Writer with the same methods as in
Writer
but without throwing IOExceptions
- StreamEndEvent - Class in com.hazelcast.org.snakeyaml.engine.v2.events
-
Marks the end of a stream that might have contained multiple documents.
- StreamEndEvent(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.events.StreamEndEvent
-
- StreamEndEvent() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.events.StreamEndEvent
-
- StreamEndToken - Class in com.hazelcast.org.snakeyaml.engine.v2.tokens
-
- StreamEndToken(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.tokens.StreamEndToken
-
- streamFilesP(String, Charset, String, boolean, BiFunctionEx<? super String, ? super String, ?>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- 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(SupplierEx<? extends Connection>, FunctionEx<? super Session, ? extends MessageConsumer>, FunctionEx<? super Message, ?>, FunctionEx<? super Message, ? extends T>, EventTimePolicy<? super T>, ProcessingGuarantee) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- streamJmsTopicP(SupplierEx<? extends Connection>, FunctionEx<? super Session, ? extends MessageConsumer>, boolean, FunctionEx<? super Message, ?>, FunctionEx<? super Message, ? extends T>, EventTimePolicy<? super T>, ProcessingGuarantee) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- streamMapP(String, JournalInitialPosition, EventTimePolicy<? super Map.Entry<K, V>>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- 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
-
- StreamReadCapability - Enum in com.hazelcast.com.fasterxml.jackson.core
-
Set of on/off capabilities that a
JsonParser
for given format
(or in case of buffering, original format) has.
- StreamReader - Class in com.hazelcast.org.snakeyaml.engine.v2.scanner
-
Reader: checks if code points are in allowed range.
- StreamReader(Reader, LoadSettings) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.scanner.StreamReader
-
- StreamReader(String, LoadSettings) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.scanner.StreamReader
-
- StreamReadException - Exception in com.hazelcast.com.fasterxml.jackson.core.exc
-
Intermediate base class for all read-side streaming processing problems, including
parsing and input value coercion problems.
- StreamReadException(JsonParser, String) - Constructor for exception com.hazelcast.com.fasterxml.jackson.core.exc.StreamReadException
-
- StreamReadException(JsonParser, String, Throwable) - Constructor for exception com.hazelcast.com.fasterxml.jackson.core.exc.StreamReadException
-
- StreamReadException(JsonParser, String, JsonLocation) - Constructor for exception com.hazelcast.com.fasterxml.jackson.core.exc.StreamReadException
-
- StreamReadException(String, JsonLocation, Throwable) - Constructor for exception com.hazelcast.com.fasterxml.jackson.core.exc.StreamReadException
-
- StreamReadFeature - Enum in com.hazelcast.com.fasterxml.jackson.core
-
Token reader (parser) features not-specific to any particular format backend.
- streamReadFeatures() - Method in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- streamRemoteCacheP(String, ClientConfig, JournalInitialPosition, EventTimePolicy<? super Map.Entry<K, V>>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- 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
-
- streamRemoteMapP(String, ClientConfig, JournalInitialPosition, EventTimePolicy<? super Map.Entry<K, V>>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- 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
-
- 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
-
- 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.
- StreamStartEvent - Class in com.hazelcast.org.snakeyaml.engine.v2.events
-
Marks the start of a stream that might contain multiple documents.
- StreamStartEvent(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.events.StreamStartEvent
-
- StreamStartEvent() - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.events.StreamStartEvent
-
- StreamStartToken - Class in com.hazelcast.org.snakeyaml.engine.v2.tokens
-
- StreamStartToken(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.tokens.StreamStartToken
-
- StreamWriteCapability - Enum in com.hazelcast.com.fasterxml.jackson.core
-
Set of on/off capabilities that a
JsonGenerator
for given format
(or in case of buffering, original format) has.
- StreamWriteFeature - Enum in com.hazelcast.com.fasterxml.jackson.core
-
Token writer (generator) features not-specific to any particular format backend.
- streamWriteFeatures() - Method in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- StringAndPartitionAwarePartitioningStrategy - Class in com.hazelcast.partition.strategy
-
- StringPartitioningStrategy - Class in com.hazelcast.partition.strategy
-
- StringPartitioningStrategy() - Constructor for class com.hazelcast.partition.strategy.StringPartitioningStrategy
-
- submit(Callable<T>, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to a randomly selected member and returns a Future
representing that task.
- submit(Runnable, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to a random member.
- submit(Runnable, MemberSelector, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to randomly selected members.
- submit(Callable<T>, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to a random member.
- submit(Callable<T>, MemberSelector, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to a randomly selected member.
- submit(Callable<T>) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
-
Submits a value-returning task for execution and returns a
Future representing the pending results of the task.
- submit(Runnable, T) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
-
Submits a Runnable task for execution and returns a Future
representing that task.
- submit(Runnable) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
-
Submits a Runnable task for execution and returns a Future
representing that task.
- submit(JetCommandLine.Verbosity, JetCommandLine.TargetsMixin, String, String, String, File, List<String>) - Method in class com.hazelcast.jet.server.JetCommandLine
-
- submitToAllMembers(Callable<T>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to all cluster members and returns a
map of Member-Future pairs representing pending completion of the task on each member.
- submitToAllMembers(Runnable, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to all the cluster members.
- submitToAllMembers(Callable<T>, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to all the cluster members.
- submitToKey(K, EntryProcessor<K, V, R>) - Method in interface com.hazelcast.map.IMap
-
Applies the user defined EntryProcessor
to the entry mapped by the key
.
- submitToKeyOwner(Callable<T>, Object) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to the owner of the specified key and returns a Future
representing that task.
- submitToKeyOwner(Runnable, Object, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to the owner of the specified key.
- submitToKeyOwner(Callable<T>, Object, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to the owner of the specified key.
- submitToKeyOwner(Callable<T>, Object) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
-
Submits a task to the owner of the specified key and returns a Future
representing that task.
- submitToKeyOwner(Runnable, Object) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
-
Submits a task to the owner of the specified key and returns a Future
representing that task.
- submitToKeys(Set<K>, EntryProcessor<K, V, R>) - Method in interface com.hazelcast.map.IMap
-
- submitToMember(Callable<T>, Member) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to the specified member and returns a Future
representing that task.
- submitToMember(Runnable, Member, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to the specified member.
- submitToMember(Callable<T>, Member, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to the specified member.
- submitToMembers(Callable<T>, Collection<Member>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to given members and returns
map of Member-Future pairs representing pending completion of the task on each member
- submitToMembers(Callable<T>, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to selected members and returns a
map of Member-Future pairs representing pending completion of the task on each member.
- submitToMembers(Runnable, Collection<Member>, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to the specified members.
- submitToMembers(Runnable, MemberSelector, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to the selected members.
- submitToMembers(Callable<T>, Collection<Member>, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
-
Submits a task to the specified members.
- submitToMembers(Callable<T>, MemberSelector, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to the selected members.
- 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.
- 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 applying getDoubleValueFn
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 applying getLongValueFn
to each item.
- SupplierEx<T> - Interface in com.hazelcast.function
-
- supplierFrom(ProcessorSupplier) - Static method in class com.hazelcast.jet.core.test.TestSupport
-
Wraps the provided ProcessorSupplier
with a Supplier<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 a Supplier<Processor>
that returns processors obtained from it.
- supplierFrom(ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.test.TestSupport
-
Wraps the provided ProcessorMetaSupplier
with a Supplier<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 a Supplier<Processor>
that returns processors obtained from it.
- supportsNativeTimestamps() - Method in interface com.hazelcast.jet.pipeline.StreamSource
-
- SURR1_FIRST - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- SURR1_LAST - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- SURR2_FIRST - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- SURR2_LAST - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- suspend() - Method in interface com.hazelcast.jet.Job
-
Gracefully suspends the current execution of the job.
- suspend(JetCommandLine.Verbosity, JetCommandLine.TargetsMixin, String) - Method in class com.hazelcast.jet.server.JetCommandLine
-
- switchAndReturnNext() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserSequence
-
- switchToNext() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserSequence
-
Method that will switch active delegate parser from the current one
to the next parser in sequence, if there is another parser left:
if so, the next parser will become the active delegate parser.
- symbolTableForTests() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- symmetricEncryptionConfig - Variable in class com.hazelcast.config.EndpointConfig
-
- SymmetricEncryptionConfig - Class in com.hazelcast.config
-
- SymmetricEncryptionConfig() - Constructor for class com.hazelcast.config.SymmetricEncryptionConfig
-
Deprecated.
- SYS_LF - Static variable in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultIndenter
-
- SYSTEM_LINEFEED_INSTANCE - Static variable in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultIndenter
-
- SYSTEM_PROPERTY_TRACK_REUSABLE_BUFFERS - Static variable in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecyclers
-
System property that is checked to see if recycled buffers (see
BufferRecycler
)
should be tracked, for purpose of forcing release of all such buffers, typically
during major classloading.
- validate() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
- validate(T) - Method in interface com.hazelcast.config.properties.ValueValidator
-
Validates the given value according to the defined validation logic
and throws a ValidationException if configuration does not meet the
requirements or logical errors are spotted.
- ValidationException - Exception in com.hazelcast.config.properties
-
This exception is thrown from
ValueValidator
implementations whenever the validation has not succeed for any reason.
- ValidationException(String) - Constructor for exception com.hazelcast.config.properties.ValidationException
-
- ValidationException(String, Throwable) - Constructor for exception com.hazelcast.config.properties.ValidationException
-
- ValidationException(Throwable) - Constructor for exception com.hazelcast.config.properties.ValidationException
-
- validator() - Method in interface com.hazelcast.config.properties.PropertyDefinition
-
Returns an optional validator to validate a value before finalizing the
configuration.
- validator() - Method in class com.hazelcast.config.properties.SimplePropertyDefinition
-
- value - Variable in class com.hazelcast.core.EntryEvent
-
- value() - Method in class com.hazelcast.jet.core.metrics.Measurement
-
- value() - Method in enum com.hazelcast.query.QueryConstants
-
- ValueCallback<T> - Interface in com.hazelcast.query.extractor
-
- ValueCollector<T> - Interface in com.hazelcast.query.extractor
-
- valueCount(K) - Method in interface com.hazelcast.multimap.BaseMultiMap
-
Returns the number of values matching the given key in the multimap.
- valueCount(K) - Method in interface com.hazelcast.multimap.MultiMap
-
Returns the number of values that match the given key in the multimap.
- valueCount(K) - Method in interface com.hazelcast.transaction.TransactionalMultiMap
-
Returns the number of values matching the given key in the multimap.
- ValueExtractor<T,A> - Interface in com.hazelcast.query.extractor
-
Common superclass for all extractors that enable the user to define custom attributes and extract their values.
- valueOf(String) - Static method in enum com.hazelcast.auditlog.Level
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.cache.CacheEventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.client.config.ClientConnectionStrategyConfig.ReconnectMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.cluster.ClusterState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.com.fasterxml.jackson.core.Base64Variant.PaddingReadBehaviour
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variants
-
Lookup method for finding one of standard variants by name.
- valueOf(String) - Static method in enum com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter.Inclusion
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.com.fasterxml.jackson.core.format.MatchStrength
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.com.fasterxml.jackson.core.json.JsonReadFeature
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteFeature
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.com.fasterxml.jackson.core.JsonEncoding
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.com.fasterxml.jackson.core.JsonFactory.Feature
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.com.fasterxml.jackson.core.JsonGenerator.Feature
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.com.fasterxml.jackson.core.JsonParser.Feature
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.com.fasterxml.jackson.core.JsonParser.NumberType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
-
- valueOf(String) - Static method in enum com.hazelcast.com.fasterxml.jackson.core.JsonToken
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.com.fasterxml.jackson.core.StreamReadCapability
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.com.fasterxml.jackson.core.StreamReadFeature
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.com.fasterxml.jackson.core.StreamWriteCapability
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.com.fasterxml.jackson.core.StreamWriteFeature
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.com.fasterxml.jackson.core.type.WritableTypeId.Inclusion
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.AbstractXmlConfigBuilder.ConfigType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.BitmapIndexOptions.UniqueKeyTransformation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.CacheDeserializedValues
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.ConsistencyCheckStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.EvictionPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.HotRestartClusterDataRecoveryPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.IndexType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.InMemoryFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.InstanceTrackingConfig.InstanceMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.InstanceTrackingConfig.InstanceProductName
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.InstanceTrackingConfig.InstanceTrackingProperties
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.MapStoreConfig.InitialLoadMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.MaxSizePolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.MetadataPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.MultiMapConfig.ValueCollectionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.NativeMemoryConfig.MemoryAllocatorType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.NearCacheConfig.LocalUpdatePolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.OnJoinPermissionOperationName
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.PartitionGroupConfig.MemberGroupType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.PermissionConfig.PermissionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.PersistentMemoryMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.properties.PropertyTypeConverter
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.RestEndpointGroup
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.ScheduledExecutorConfig.CapacityPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.security.LdapRoleMappingMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.security.LdapSearchScope
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.security.TokenEncoding
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.UserCodeDeploymentConfig.ClassCacheMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.UserCodeDeploymentConfig.ProviderMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.WanAcknowledgeType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.WanQueueFullBehavior
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.core.DistributedObjectEvent.EventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.core.EntryEventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.core.ItemEventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.core.LifecycleEvent.LifecycleState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.cp.CPGroup.CPGroupStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.cp.event.CPMembershipEvent.EventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.cp.session.CPSession.CPSessionOwnerType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.hotrestart.BackupTaskState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.instance.ProtocolType
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum com.hazelcast.instance.ProtocolType
-
- valueOf(String) - Static method in enum com.hazelcast.jet.config.ProcessingGuarantee
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.jet.config.ResourceType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.jet.core.Edge.RoutingPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.jet.core.JobStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.jet.core.metrics.Unit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.jet.core.TimestampKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.jet.pipeline.JournalInitialPosition
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.memory.MemoryUnit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.nio.serialization.FieldType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.org.snakeyaml.engine.v2.common.FlowStyle
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.org.snakeyaml.engine.v2.common.NonPrintableStyle
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.org.snakeyaml.engine.v2.common.ScalarStyle
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.org.snakeyaml.engine.v2.events.Event.ID
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.org.snakeyaml.engine.v2.nodes.NodeType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.org.snakeyaml.engine.v2.tokens.Token.ID
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.query.QueryConstants
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.ringbuffer.OverflowPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.spi.discovery.DiscoveryStrategyFactory.DiscoveryStrategyLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.spi.discovery.integration.DiscoveryMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.splitbrainprotection.SplitBrainProtectionOn
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.sql.SqlColumnType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.sql.SqlExpectedResultType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.topic.TopicOverloadPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.wan.WanEventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.wan.WanPublisherState
-
Returns the enum constant of this type with the specified name.
- ValueReader - Interface in com.hazelcast.query.extractor
-
Enables reading the value of the attribute specified by the path
- ValueReadingException - Exception in com.hazelcast.query.extractor
-
Exception thrown if there is any checked or unchecked exception caught in the value reading in
ValueReader
- ValueReadingException(String, Throwable) - Constructor for exception com.hazelcast.query.extractor.ValueReadingException
-
- values() - Static method in enum com.hazelcast.auditlog.Level
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.cache.CacheEventType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.client.config.ClientConnectionStrategyConfig.ReconnectMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.cluster.ClusterState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.com.fasterxml.jackson.core.Base64Variant.PaddingReadBehaviour
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter.Inclusion
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.com.fasterxml.jackson.core.format.MatchStrength
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.com.fasterxml.jackson.core.json.JsonReadFeature
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteFeature
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.com.fasterxml.jackson.core.JsonEncoding
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.com.fasterxml.jackson.core.JsonFactory.Feature
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.com.fasterxml.jackson.core.JsonGenerator.Feature
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.com.fasterxml.jackson.core.JsonParser.Feature
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.com.fasterxml.jackson.core.JsonParser.NumberType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.com.fasterxml.jackson.core.JsonToken
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.com.fasterxml.jackson.core.StreamReadCapability
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.com.fasterxml.jackson.core.StreamReadFeature
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.com.fasterxml.jackson.core.StreamWriteCapability
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.com.fasterxml.jackson.core.StreamWriteFeature
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.com.fasterxml.jackson.core.type.WritableTypeId.Inclusion
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.AbstractXmlConfigBuilder.ConfigType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.BitmapIndexOptions.UniqueKeyTransformation
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.CacheDeserializedValues
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.ConsistencyCheckStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.EvictionPolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.HotRestartClusterDataRecoveryPolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.IndexType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.InMemoryFormat
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.InstanceTrackingConfig.InstanceMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.InstanceTrackingConfig.InstanceProductName
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.InstanceTrackingConfig.InstanceTrackingProperties
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.MapStoreConfig.InitialLoadMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.MaxSizePolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.MetadataPolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.MultiMapConfig.ValueCollectionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.NativeMemoryConfig.MemoryAllocatorType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.NearCacheConfig.LocalUpdatePolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.OnJoinPermissionOperationName
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.PartitionGroupConfig.MemberGroupType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.PermissionConfig.PermissionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.PersistentMemoryMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.properties.PropertyTypeConverter
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.RestEndpointGroup
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.ScheduledExecutorConfig.CapacityPolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.security.LdapRoleMappingMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.security.LdapSearchScope
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.security.TokenEncoding
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.UserCodeDeploymentConfig.ClassCacheMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.UserCodeDeploymentConfig.ProviderMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.WanAcknowledgeType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.WanQueueFullBehavior
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.core.DistributedObjectEvent.EventType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.core.EntryEventType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.core.ItemEventType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.core.LifecycleEvent.LifecycleState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.cp.CPGroup.CPGroupStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.cp.event.CPMembershipEvent.EventType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.cp.session.CPSession.CPSessionOwnerType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.hotrestart.BackupTaskState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.instance.ProtocolType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.jet.config.ProcessingGuarantee
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.jet.config.ResourceType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.jet.core.Edge.RoutingPolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.jet.core.JobStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.jet.core.metrics.Unit
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.jet.core.TimestampKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.jet.pipeline.JournalInitialPosition
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in interface com.hazelcast.map.BaseMap
-
Returns a collection clone of the values contained in this map.
- values(Predicate<K, V>) - Method in interface com.hazelcast.map.BaseMap
-
Queries the map based on the specified predicate and
returns the values of matching entries.
- values() - Method in interface com.hazelcast.map.IMap
-
Returns an immutable collection clone of the values contained in this map.
- values(Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
-
Queries the map based on the specified predicate and returns an immutable
collection of the values of matching entries.
- values() - Method in interface com.hazelcast.map.QueryCache
-
- values(Predicate<K, V>) - Method in interface com.hazelcast.map.QueryCache
-
- values() - Static method in enum com.hazelcast.memory.MemoryUnit
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in interface com.hazelcast.multimap.MultiMap
-
Returns the collection of values in the multimap.
- values() - Static method in enum com.hazelcast.nio.serialization.FieldType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.org.snakeyaml.engine.v2.common.FlowStyle
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.org.snakeyaml.engine.v2.common.NonPrintableStyle
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.org.snakeyaml.engine.v2.common.ScalarStyle
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.org.snakeyaml.engine.v2.events.Event.ID
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.org.snakeyaml.engine.v2.nodes.NodeType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.org.snakeyaml.engine.v2.tokens.Token.ID
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.query.QueryConstants
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
-
Returns a lazy
Collection
view of the values contained in this map.
A LazyCollection is optimized for querying speed (preventing eager deserialization
and hashing on HashSet insertion) and does
NOT provide all operations.
- values(Comparator<V>) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
-
Returns an eagerly populated
Collection
view of the values contained in this map.
- values() - Static method in enum com.hazelcast.ringbuffer.OverflowPolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.spi.discovery.DiscoveryStrategyFactory.DiscoveryStrategyLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.spi.discovery.integration.DiscoveryMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.splitbrainprotection.SplitBrainProtectionOn
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.sql.SqlColumnType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.sql.SqlExpectedResultType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.topic.TopicOverloadPolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in interface com.hazelcast.transaction.TransactionalMap
-
- values(Predicate<K, V>) - Method in interface com.hazelcast.transaction.TransactionalMap
-
- values() - Static method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.wan.WanEventType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.wan.WanPublisherState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- valuesAsSet() - Static method in enum com.hazelcast.instance.ProtocolType
-
- valueShape - Variable in class com.hazelcast.com.fasterxml.jackson.core.type.WritableTypeId
-
Information about intended shape of the value being written (that is,
WritableTypeId.forValue
);
in case of structured values, start token of the structure; for scalars, value token.
- ValueToken - Class in com.hazelcast.org.snakeyaml.engine.v2.tokens
-
- ValueToken(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v2.tokens.ValueToken
-
- 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.
- 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.
- Verbosity() - Constructor for class com.hazelcast.jet.server.JetCommandLine.Verbosity
-
- verify() - Method in class com.hazelcast.config.JoinConfig
-
Verifies this JoinConfig is valid.
- verifyInternalConsistency() - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
-
Diagnostics method that will verify that internal data structures are consistent;
not meant as user-facing method but only for test suites and possible troubleshooting.
- verifyProcessor(SupplierEx<Processor>) - Static method in class com.hazelcast.jet.core.test.TestSupport
-
- verifyProcessor(ProcessorSupplier) - Static method in class com.hazelcast.jet.core.test.TestSupport
-
- verifyProcessor(ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.test.TestSupport
-
- version() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
Implemented with standard version number detection algorithm, typically using
a simple generated class, with information extracted from Maven project file
during build.
- version() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- version() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonGeneratorImpl
-
- VERSION - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.PackageVersion
-
- version() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.PackageVersion
-
- version() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- version() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Accessor for finding out version of the bundle that provided this generator instance.
- version() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Accessor for getting version of the core package, given a parser instance.
- version() - Method in class com.hazelcast.com.fasterxml.jackson.core.ObjectCodec
-
- version() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- version() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
-
- version() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.VersionUtil
-
Deprecated.
- Version - Class in com.hazelcast.com.fasterxml.jackson.core
-
Object that encapsulates versioning information of a component.
- Version(int, int, int, String) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.Version
-
- Version(int, int, int, String, String, String) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.Version
-
- version() - Method in interface com.hazelcast.com.fasterxml.jackson.core.Versioned
-
Method called to detect version of the component that implements this interface;
returned version should never be null, but may return specific "not available"
instance (see
Version
for details).
- version() - Method in interface com.hazelcast.cp.session.CPSession
-
Returns version of the session.
- VERSION - Static variable in class com.hazelcast.instance.GeneratedBuildProperties
-
- Version - Class in com.hazelcast.version
-
- Version() - Constructor for class com.hazelcast.version.Version
-
- VersionAware - Interface in com.hazelcast.nio
-
An instance which supports versioning.
- Versioned - Interface in com.hazelcast.com.fasterxml.jackson.core
-
Interface that those Jackson components that are explicitly versioned will implement.
- VersionedPortable - Interface in com.hazelcast.nio.serialization
-
An extension to
Portable
to support per-object version instead of a
global serialization version.
- versionFor(Class<?>) - Static method in class com.hazelcast.com.fasterxml.jackson.core.util.VersionUtil
-
Loads version information by introspecting a class named
"PackageVersion" in the same package as the given class.
- VersionUtil - Class in com.hazelcast.com.fasterxml.jackson.core.util
-
Functionality for supporting exposing of component
Version
s.
- VersionUtil() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.VersionUtil
-
- vertex(Vertex) - Method in class com.hazelcast.jet.core.DAG
-
Adds a vertex to this DAG.
- VERTEX - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
-
Serialization ID of the
Vertex
class.
- VERTEX - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
-
DAG vertex name the of the metric.
- 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, ProcessorSupplier) - Constructor for class com.hazelcast.jet.core.Vertex
-
Creates a vertex from a ProcessorSupplier
.
- Vertex(String, ProcessorMetaSupplier) - Constructor for class com.hazelcast.jet.core.Vertex
-
Creates a vertex from a ProcessorMetaSupplier
.
- 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
-
- 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_ADD_CONFIG - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
-
Event type ID: WAN add config.
- WAN_CONSUMER_ACK_DELAY_BACKOFF_INIT_MS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Defines the initial backoff delay for the Enterprise WAN
implementation's consumer.
- WAN_CONSUMER_ACK_DELAY_BACKOFF_MAX_MS - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Defines the maximum backoff delay for the Enterprise WAN
implementation's consumer.
- WAN_CONSUMER_ACK_DELAY_BACKOFF_MULTIPLIER - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Defines the multiplier (the speed of the function) for the backoff
delay for the Enterprise WAN implementation's consumer.
- WAN_CONSUMER_INVOCATION_THRESHOLD - Static variable in class com.hazelcast.spi.properties.ClusterProperty
-
Defines the pending invocation threshold for the Enterprise WAN
replication implementation.
- WAN_SYNC - Static variable in class com.hazelcast.auditlog.AuditlogTypeIds
-
Event type ID: WAN sync.
- WanAcknowledgeType - Enum in com.hazelcast.config
-
Determines acknowledge waiting type of wan replication operation invocation.
- WanBatchPublisherConfig - Class in com.hazelcast.config
-
Configuration object for the built-in WAN publisher (available in
Hazelcast Enterprise).
- WanBatchPublisherConfig() - Constructor for class com.hazelcast.config.WanBatchPublisherConfig
-
- WanConsumer - Interface in com.hazelcast.wan
-
Interface to be implemented by custom WAN event consumers.
- WanConsumerConfig - Class in com.hazelcast.config
-
Config for processing WAN events received from a target cluster.
- WanConsumerConfig() - Constructor for class com.hazelcast.config.WanConsumerConfig
-
- WanCustomPublisherConfig - Class in com.hazelcast.config
-
Configuration object for a custom WAN publisher.
- WanCustomPublisherConfig() - Constructor for class com.hazelcast.config.WanCustomPublisherConfig
-
- WanEvent<T> - Interface in com.hazelcast.wan
-
Interface for all WAN replication messages
- WanEventCounters - Class in com.hazelcast.wan
-
Counters for WAN events for a single distributed object type (map or
cache).
- WanEventCounters() - Constructor for class com.hazelcast.wan.WanEventCounters
-
- WanEventCounters.DistributedObjectWanEventCounters - Class in com.hazelcast.wan
-
Counters for WAN events for a single map or cache.
- WanEventType - Enum in com.hazelcast.wan
-
The type of the WAN event, signifies the type of the mutation that occurred
that caused the WAN event.
- WanMigrationAwarePublisher<T> - Interface in com.hazelcast.wan
-
Interface for WAN publisher migration related events.
- WanProtocolVersionAware - Interface in com.hazelcast.nio
-
An instance which is used in WAN and supports versioning.
- WanPublisher<T> - Interface in com.hazelcast.wan
-
This interface offers the implementation of different kinds of replication
techniques like TCP, UDP or maybe even an JMS based service.
- WanPublisherState - Enum in com.hazelcast.wan
-
Defines the state in which a WAN publisher can be in if it is not shutting
down.
- WanQueueFullBehavior - Enum in com.hazelcast.config
-
Determines the behavior of WAN replication
impl.
- WanQueueFullException - Exception in com.hazelcast.wan
-
- WanQueueFullException(String) - Constructor for exception com.hazelcast.wan.WanQueueFullException
-
- WanReplicationConfig - Class in com.hazelcast.config
-
Configuration for WAN replication.
- WanReplicationConfig() - Constructor for class com.hazelcast.config.WanReplicationConfig
-
- WanReplicationRef - Class in com.hazelcast.config
-
Configuration for a WAN target replication reference.
- WanReplicationRef() - Constructor for class com.hazelcast.config.WanReplicationRef
-
- WanReplicationRef(WanReplicationRef) - Constructor for class com.hazelcast.config.WanReplicationRef
-
- WanReplicationRef(String, String, List<String>, boolean) - Constructor for class com.hazelcast.config.WanReplicationRef
-
- WanSyncConfig - Class in com.hazelcast.config
-
Configuration object for the WAN sync mechanism.
- WanSyncConfig() - Constructor for class com.hazelcast.config.WanSyncConfig
-
- warning(String) - Method in class com.hazelcast.logging.AbstractLogger
-
- warning(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
-
- warning(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
-
- warning(String) - Method in interface com.hazelcast.logging.ILogger
-
- warning(Throwable) - Method in interface com.hazelcast.logging.ILogger
-
- warning(String, Throwable) - Method in interface com.hazelcast.logging.ILogger
-
Logs a message with an associated throwable at the
Level.WARNING
level.
- 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.
- 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
-
- wholeItem() - Static method in class com.hazelcast.function.Functions
-
- 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, boolean) - Constructor for class com.hazelcast.jet.datamodel.WindowResult
-
- WindowResult(long, long, R) - Constructor for class com.hazelcast.jet.datamodel.WindowResult
-
Constructs a window result that is not early.
- 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).
- with(F) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JacksonFeatureSet
-
Mutant factory for getting a set in which specified feature is enabled:
will either return this instance (if no change), or newly created set (if there
is change).
- 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.
- withArrayIndenter(DefaultPrettyPrinter.Indenter) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
- withArrayValueSeparator(char) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.Separators
-
- 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.
- 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.
- 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 given createService
function.
- withDestroyContextFn(ConsumerEx<? super C>) - Method in class com.hazelcast.jet.pipeline.ServiceFactory
-
Returns a copy of this ServiceFactory
with the destroyContext
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 the destroyService
function replaced with the given function.
- withDupDetector(DupDetector) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
-
- withDupDetector(DupDetector) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
- withEncoding(JsonEncoding) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
- withGenerator(JsonGenerator) - Method in exception com.hazelcast.com.fasterxml.jackson.core.JsonGenerationException
-
- 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
-
- withIndent(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultIndenter
-
- withIngestionTimestamps() - Method in interface com.hazelcast.jet.pipeline.StreamSourceStage
-
Declares that the source will assign the time of ingestion as the event
timestamp.
- withLinefeed(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultIndenter
-
- withMaxInputLookahead(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatDetector
-
Method that will return a detector instance that allows detectors to
read up to specified number of bytes when determining format match strength.
- 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.
- withMinimalMatch(MatchStrength) - Method in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatDetector
-
Method that will return a detector instance that uses given
minimal match level; match that may be returned unless a stronger match
is found with other format detectors.
- 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.
- withObjectEntrySeparator(char) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.Separators
-
- withObjectFieldValueSeparator(char) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.Separators
-
- withObjectIndenter(DefaultPrettyPrinter.Indenter) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
- 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.
- withOptimalMatch(MatchStrength) - Method in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatDetector
-
Method that will return a detector instance that uses given
optimal match level (match that is considered sufficient to return, without
trying to find stronger matches with other formats).
- without(F) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JacksonFeatureSet
-
Mutant factory for getting a set in which specified feature is disabled:
will either return this instance (if no change), or newly created set (if there
is change).
- withoutAttachedFiles() - Method in class com.hazelcast.jet.pipeline.ServiceFactory
-
Returns a copy of this
ServiceFactory
with any attached files
removed.
- withoutSpacesInObjectEntries() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
"Mutant factory" method that will return a pretty printer instance
that does not use spaces inside object entries; if 'this' instance already
does this, it is returned; if not, a new instance will be constructed
and returned.
- withoutTimestamps() - Method in interface com.hazelcast.jet.pipeline.StreamSourceStage
-
Declares that the source will not assign any timestamp to the events it
emits.
- withPaddingAllowed() - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
-
- withPaddingForbidden() - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
-
- withPaddingRequired() - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
-
- withParser(JsonParser) - Method in exception com.hazelcast.com.fasterxml.jackson.core.exc.InputCoercionException
-
- withParser(JsonParser) - Method in exception com.hazelcast.com.fasterxml.jackson.core.exc.StreamReadException
-
- withParser(JsonParser) - Method in exception com.hazelcast.com.fasterxml.jackson.core.JsonParseException
-
- withReadPadding(Base64Variant.PaddingReadBehaviour) - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
-
- withReflect(Class<T>) - Method in class com.hazelcast.jet.pipeline.file.AvroFileFormat
-
Specifies to use reflection to deserialize data into the given class.
- withRequestPayload(RequestPayload) - Method in exception com.hazelcast.com.fasterxml.jackson.core.exc.InputCoercionException
-
- withRequestPayload(RequestPayload) - Method in exception com.hazelcast.com.fasterxml.jackson.core.exc.StreamReadException
-
Fluent method that may be used to assign payload to this exception,
to let recipient access it for diagnostics purposes.
- withRequestPayload(RequestPayload) - Method in exception com.hazelcast.com.fasterxml.jackson.core.JsonParseException
-
Fluent method that may be used to assign payload to this exception,
to let recipient access it for diagnostics purposes.
- withRootSeparator(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
- withRootSeparator(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
- withSeparators(Separators) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
Method for configuring separators for this pretty-printer to use
- withSpacesInObjectEntries() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
"Mutant factory" method that will return a pretty printer instance
that does use spaces inside object entries; if 'this' instance already
does this, it is returned; if not, a new instance will be constructed
and returned.
- 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.
- withWritePadding(boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
-
- 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.
- wrapperWritten - Variable in class com.hazelcast.com.fasterxml.jackson.core.type.WritableTypeId
-
Flag that can be set to indicate that wrapper structure was written (during
prefix-writing); used to determine if suffix requires matching close markers.
- WritableTypeId - Class in com.hazelcast.com.fasterxml.jackson.core.type
-
This is a simple value class used between core streaming and higher level
databinding to pass information about type ids to write.
- WritableTypeId() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.type.WritableTypeId
-
- WritableTypeId(Object, JsonToken) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.type.WritableTypeId
-
Constructor used when calling a method for generating and writing Type Id;
caller only knows value object and its intended shape.
- WritableTypeId(Object, Class<?>, JsonToken) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.type.WritableTypeId
-
Constructor used when calling a method for generating and writing Type Id,
but where actual type to use for generating id is NOT the type of value
(but its supertype).
- WritableTypeId(Object, JsonToken, Object) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.type.WritableTypeId
-
Constructor used when calling a method for writing Type Id;
caller knows value object, its intended shape as well as id to
use; but not details of wrapping (if any).
- WritableTypeId.Inclusion - Enum in com.hazelcast.com.fasterxml.jackson.core.type
-
Enumeration of values that matches enum `As` from annotation
`JsonTypeInfo`: separate definition to avoid dependency between
streaming core and annotations packages; also allows more flexibility
in case new values needed at this level of internal API.
- write(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.DataOutputAsStream
-
- write(byte[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.DataOutputAsStream
-
- write(byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.DataOutputAsStream
-
- write(char[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SegmentedStringWriter
-
- write(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SegmentedStringWriter
-
- write(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SegmentedStringWriter
-
- write(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SegmentedStringWriter
-
- write(String, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SegmentedStringWriter
-
- write(char[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.UTF8Writer
-
- write(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.UTF8Writer
-
- write(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.UTF8Writer
-
- write(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.UTF8Writer
-
- write(String, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.UTF8Writer
-
- write(byte[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
-
- write(byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
-
- write(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
-
- write(T) - Method in interface com.hazelcast.nio.serialization.ByteArraySerializer
-
Converts given object to byte array
- write(ObjectDataOutput, T) - Method in interface com.hazelcast.nio.serialization.StreamSerializer
-
This method writes object to ObjectDataOutput
- write(String) - Method in interface com.hazelcast.org.snakeyaml.engine.v2.api.StreamDataWriter
-
- write(String, int, int) - Method in interface com.hazelcast.org.snakeyaml.engine.v2.api.StreamDataWriter
-
- write(String, int, int) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.YamlOutputStreamWriter
-
- write(String) - Method in class com.hazelcast.org.snakeyaml.engine.v2.api.YamlOutputStreamWriter
-
- WRITE_BINARY - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- WRITE_BOOLEAN - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- WRITE_NULL - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- WRITE_NUMBER - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- WRITE_RAW - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- WRITE_STRING - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- writeArray(int[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- writeArray(long[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- writeArray(double[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- writeArray(String[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- writeArray(int[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeArray(long[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeArray(double[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeArray(String[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeArrayFieldStart(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Convenience method for outputting a field entry ("member")
(that will contain a JSON Array value), and the START_ARRAY marker.
- writeArrayValueSeparator(JsonGenerator) - Method in interface com.hazelcast.com.fasterxml.jackson.core.PrettyPrinter
-
Method called after an array value has been completely
output, and before another value is to be output.
- writeArrayValueSeparator(JsonGenerator) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
Method called after an array value has been completely
output, and before another value is to be output.
- writeArrayValueSeparator(JsonGenerator) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.MinimalPrettyPrinter
-
Method called after an array value has been completely
output, and before another value is to be output.
- writeBinary(Base64Variant, InputStream, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- writeBinary(Base64Variant, byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeBinary(Base64Variant, InputStream, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeBinary(Base64Variant, byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeBinary(Base64Variant, InputStream, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeBinary(Base64Variant, byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeBinary(Base64Variant, InputStream, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeBinary(Base64Variant, byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method that will output given chunk of binary data as base64
encoded, as a complete String value (surrounded by double quotes).
- writeBinary(byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- writeBinary(byte[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- writeBinary(InputStream, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- writeBinary(Base64Variant, InputStream, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- writeBinary(Base64Variant, byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeBinary(Base64Variant, InputStream, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeBinaryField(String, byte[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Convenience method for outputting a field entry ("member")
that contains specified data in base64-encoded form.
- writeBoolean(boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeBoolean(boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeBoolean(boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeBoolean(boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for outputting literal JSON boolean value (one of
Strings 'true' and 'false').
- writeBoolean(boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeBoolean(String, boolean) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Writes a primitive boolean.
- writeBooleanArray(boolean[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
-
- writeBooleanArray(String, boolean[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Writes a primitive boolean-array.
- writeBooleanField(String, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Convenience method for outputting a field entry ("member")
that has a boolean value.
- 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
-
- 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
-
Writes a primitive byte.
- writeByteArray(byte[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
-
- writeByteArray(String, byte[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Writes a primitive byte-array.
- writeCacheP(String) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
- writeChar(String, int) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Writes a primitive char.
- writeCharArray(char[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
-
- writeCharArray(String, char[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Writes a primitive char-array.
- writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.cluster.Address
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.AttributeConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.BitmapIndexOptions
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CollectionConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.DiscoveryConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.DurableExecutorConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.EntryListenerConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.EventJournalConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.EvictionConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ExecutorConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.HotRestartConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.IndexConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ItemListenerConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ListenerConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MapConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MapStoreConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MergePolicyConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MerkleTreeConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MultiMapConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.NearCacheConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.NearCachePreloaderConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.PartitioningStrategyConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.PermissionConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.PNCounterConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.PredicateConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.QueryCacheConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.QueueConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.QueueStoreConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ReliableTopicConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.RingbufferConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.RingbufferStoreConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ScheduledExecutorConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.TopicConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanBatchPublisherConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanConsumerConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanReplicationConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanReplicationRef
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanSyncConfig
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.console.Echo
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.instance.EndpointQualifier
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.jet.config.JobConfig
-
- 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.Vertex
-
- writeData(ObjectDataOutput) - Method in interface com.hazelcast.nio.serialization.DataSerializable
-
Writes object fields to output stream
- writeData(ObjectDataOutput) - Method in class com.hazelcast.partition.PartitionAwareKey
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.security.SimpleTokenCredentials
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.security.UsernamePasswordCredentials
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.transaction.TransactionOptions
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.version.MemberVersion
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.version.Version
-
- writeDate(String, LocalDate) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
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
-
Writes an array of Date's
- writeDecimal(String, BigDecimal) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Writes a decimal which is arbitrary precision and scale floating-point number
- writeDecimalArray(String, BigDecimal[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Writes an array of Decimals
- writeDouble(String, double) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Writes a primitive double.
- writeDoubleArray(double[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
-
- writeDoubleArray(String, double[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Writes a primitive double array.
- writeEmbeddedObject(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method that can be called on backends that support passing opaque native
values that some data formats support; not used with JSON backend,
more common with binary formats.
- writeEmbeddedObject(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeEndArray() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeEndArray() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeEndArray() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeEndArray() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for writing closing marker of a JSON Array value
(character ']'; plus possible white space decoration
if pretty-printing is enabled).
- writeEndArray(JsonGenerator, int) - Method in interface com.hazelcast.com.fasterxml.jackson.core.PrettyPrinter
-
Method called after an Array value has been completely output
(minus closing bracket).
- writeEndArray(JsonGenerator, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
- writeEndArray() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeEndArray(JsonGenerator, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.MinimalPrettyPrinter
-
- writeEndObject() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeEndObject() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeEndObject() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeEndObject() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for writing closing marker of an Object value
(character '}'; plus possible white space decoration
if pretty-printing is enabled).
- writeEndObject(JsonGenerator, int) - Method in interface com.hazelcast.com.fasterxml.jackson.core.PrettyPrinter
-
Method called after an Object value has been completely output
(minus closing curly bracket).
- writeEndObject(JsonGenerator, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
- writeEndObject() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeEndObject(JsonGenerator, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.MinimalPrettyPrinter
-
- writeFactories(ObjectDataOutput) - Method in class com.hazelcast.config.CacheConfig
-
- writeFieldId(long) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeFieldId(long) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Alternative to
JsonGenerator.writeFieldName(String)
that may be used
in cases where property key is of numeric type; either where
underlying format supports such notion (some binary formats do,
unlike JSON), or for convenient conversion into String presentation.
- writeFieldId(long) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeFieldName(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- writeFieldName(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeFieldName(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeFieldName(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
Method that writer is to call before it writes a field name.
- writeFieldName(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeFieldName(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeFieldName(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeFieldName(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeFieldName(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for writing a field name (JSON String surrounded by
double quotes: syntactically identical to a JSON String value),
possibly decorated by white space if pretty-printing is enabled.
- writeFieldName(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method similar to
JsonGenerator.writeFieldName(String)
, main difference
being that it may perform better as some of processing (such as
quoting of certain characters, or encoding into external encoding
if supported by generator) can be done just once and reused for
later calls.
- writeFieldName(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeFieldName(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeFileP(String, Charset, String, long, boolean, FunctionEx<? super T, ? extends String>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
- writeFloat(String, float) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Writes a primitive float.
- writeFloatArray(float[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
-
- writeFloatArray(String, float[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Writes a primitive float array.
- writeIndentation(JsonGenerator, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultIndenter
-
- writeIndentation(JsonGenerator, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter.FixedSpaceIndenter
-
- writeIndentation(JsonGenerator, int) - Method in interface com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter.Indenter
-
- writeIndentation(JsonGenerator, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter.NopIndenter
-
- writeInt(String, int) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Writes a primitive int.
- writeIntArray(int[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
-
- writeIntArray(String, int[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Writes a primitive int-array.
- writeJdbcP(String, SupplierEx<? extends CommonDataSource>, BiConsumerEx<? super PreparedStatement, ? super T>, boolean, int) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
- writeJmsQueueP(String, boolean, SupplierEx<? extends Connection>, BiFunctionEx<? super Session, ? super T, ? extends Message>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
- writeJmsTopicP(String, boolean, SupplierEx<? extends Connection>, BiFunctionEx<? super Session, ? super T, ? extends Message>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
- 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
-
- 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.
- writeLoggerP() - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- writeLong(String, long) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Writes a primitive long.
- writeLongArray(long[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
-
- writeLongArray(String, long[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Writes a primitive long-array.
- writeMapP(String) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
- writeMapP(String, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends V>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
- writeNull() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeNull() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeNull() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeNull() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for outputting literal JSON null value.
- writeNull() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeNullField(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Convenience method for outputting a field entry ("member")
that has JSON literal value null.
- writeNullPortable(String, int, int) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
To write a null portable value, user needs to provide class and factoryIds of related class.
- writeNumber(short) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeNumber(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeNumber(long) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeNumber(BigInteger) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeNumber(double) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeNumber(float) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeNumber(BigDecimal) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeNumber(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeNumber(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeNumber(short) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeNumber(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeNumber(long) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeNumber(BigInteger) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeNumber(double) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeNumber(float) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeNumber(BigDecimal) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeNumber(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeNumber(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeNumber(short) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeNumber(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeNumber(long) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeNumber(BigInteger) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeNumber(double) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeNumber(float) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeNumber(BigDecimal) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeNumber(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeNumber(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeNumber(short) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for outputting given value as JSON number.
- writeNumber(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for outputting given value as JSON number.
- writeNumber(long) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for outputting given value as JSON number.
- writeNumber(BigInteger) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for outputting given value as JSON number.
- writeNumber(double) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for outputting indicate JSON numeric value.
- writeNumber(float) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for outputting indicate JSON numeric value.
- writeNumber(BigDecimal) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for outputting indicate JSON numeric value.
- writeNumber(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Write method that can be used for custom numeric types that can
not be (easily?) converted to "standard" Java number types.
- writeNumber(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- writeNumber(short) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeNumber(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeNumber(long) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeNumber(BigInteger) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeNumber(double) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeNumber(float) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeNumber(BigDecimal) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeNumber(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeNumber(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeNumberField(String, short) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Convenience method for outputting a field entry ("member")
that has the specified numeric value.
- writeNumberField(String, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Convenience method for outputting a field entry ("member")
that has the specified numeric value.
- writeNumberField(String, long) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Convenience method for outputting a field entry ("member")
that has the specified numeric value.
- writeNumberField(String, BigInteger) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Convenience method for outputting a field entry ("member")
that has the specified numeric value.
- writeNumberField(String, float) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Convenience method for outputting a field entry ("member")
that has the specified numeric value.
- writeNumberField(String, double) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Convenience method for outputting a field entry ("member")
that has the specified numeric value.
- writeNumberField(String, BigDecimal) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Convenience method for outputting a field entry ("member")
that has the specified numeric value.
- writeObject(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- writeObject(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for writing given Java object (POJO) as Json.
- writeObject(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeObject(ObjectDataOutput) - Method in class com.hazelcast.jet.accumulator.LinTrendAccumulator
-
Serializes this accumulator.
- writeObject(Object) - Method in interface com.hazelcast.nio.ObjectDataOutput
-
- writeObjectEntrySeparator(JsonGenerator) - Method in interface com.hazelcast.com.fasterxml.jackson.core.PrettyPrinter
-
Method called after an Object entry (field:value) has been completely
output, and before another value is to be output.
- writeObjectEntrySeparator(JsonGenerator) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
Method called after an object entry (field:value) has been completely
output, and before another value is to be output.
- writeObjectEntrySeparator(JsonGenerator) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.MinimalPrettyPrinter
-
Method called after an object entry (field:value) has been completely
output, and before another value is to be output.
- writeObjectField(String, Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Convenience method for outputting a field entry ("member")
that has contents of specific Java object as its value.
- writeObjectFieldStart(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Convenience method for outputting a field entry ("member")
(that will contain an Object value), and the START_OBJECT marker.
- writeObjectFieldValueSeparator(JsonGenerator) - Method in interface com.hazelcast.com.fasterxml.jackson.core.PrettyPrinter
-
Method called after an object field has been output, but
before the value is output.
- writeObjectFieldValueSeparator(JsonGenerator) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
Method called after an object field has been output, but
before the value is output.
- writeObjectFieldValueSeparator(JsonGenerator) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.MinimalPrettyPrinter
-
Method called after an object field has been output, but
before the value is output.
- writeObjectId(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeObjectId(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method that can be called to output so-called native Object Id.
- writeObjectId(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeObjectRef(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeObjectRef(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method that can be called to output references to native Object Ids.
- writeObjectRef(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeObservableP(String) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
- writeOmittedField(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeOmittedField(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method called to indicate that a property in this position was
skipped.
- writeOmittedField(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writePath(JsonGenerator) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
-
Method called to ensure that parent path from root is written up to
and including this node.
- writePortable(PortableWriter) - Method in interface com.hazelcast.nio.serialization.Portable
-
Serialize this portable object using PortableWriter
- writePortable(String, Portable) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Writes a Portable.
- writePortableArray(String, Portable[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Writes a an array of Portables.
- writeQuotedUTF8(OutputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SerializedString
-
- writeQuotedUTF8(OutputStream) - Method in interface com.hazelcast.com.fasterxml.jackson.core.SerializableString
-
Method for writing JSON-escaped UTF-8 encoded String value using given
OutputStream
.
- writeRaw(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeRaw(String, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeRaw(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeRaw(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeRaw(char) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeRaw(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeRaw(String, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeRaw(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeRaw(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeRaw(char) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeRaw(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeRaw(String, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeRaw(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeRaw(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeRaw(char) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeRaw(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method that will force generator to copy
input text verbatim with no modifications (including
that no escaping is done and no separators are added even
if context [array, object] would otherwise require such).
- writeRaw(String, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method that will force generator to copy
input text verbatim with no modifications (including
that no escaping is done and no separators are added even
if context [array, object] would otherwise require such).
- writeRaw(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method that will force generator to copy
input text verbatim with no modifications (including
that no escaping is done and no separators are added even
if context [array, object] would otherwise require such).
- writeRaw(char) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method that will force generator to copy
input text verbatim with no modifications (including
that no escaping is done and no separators are added even
if context [array, object] would otherwise require such).
- writeRaw(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method that will force generator to copy
input text verbatim with no modifications (including
that no escaping is done and no separators are added even
if context [array, object] would otherwise require such).
- writeRaw(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeRaw(String, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeRaw(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeRaw(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeRaw(char) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeRawUTF8String(byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeRawUTF8String(byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeRawUTF8String(byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeRawUTF8String(byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method similar to
JsonGenerator.writeString(String)
but that takes as
its input a UTF-8 encoded String that is to be output as-is, without additional
escaping (type of which depends on data format; backslashes for JSON).
- writeRawUTF8String(byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeRawValue(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- writeRawValue(String, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- writeRawValue(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- writeRawValue(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- writeRawValue(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeRawValue(String, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeRawValue(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeRawValue(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeRawValue(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method that will force generator to copy
input text verbatim without any modifications, but assuming
it must constitute a single legal JSON value (number, string,
boolean, null, Array or List).
- writeRawValue(String, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- writeRawValue(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- writeRawValue(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- writeRawValue(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeRawValue(String, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeRawValue(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- WriterBasedJsonGenerator - Class in com.hazelcast.com.fasterxml.jackson.core.json
-
- WriterBasedJsonGenerator(IOContext, int, ObjectCodec, Writer) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
Deprecated.
- WriterBasedJsonGenerator(IOContext, int, ObjectCodec, Writer, char) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeRemoteCacheP(String, ClientConfig) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
- writeRemoteListP(String, ClientConfig) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
- writeRemoteMapP(String, ClientConfig) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
- writeRemoteMapP(String, ClientConfig, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends V>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
- writeRootValueSeparator(JsonGenerator) - Method in interface com.hazelcast.com.fasterxml.jackson.core.PrettyPrinter
-
Method called after a root-level value has been completely
output, and before another value is to be output.
- writeRootValueSeparator(JsonGenerator) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
- writeRootValueSeparator(JsonGenerator) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.MinimalPrettyPrinter
-
- writeShort(String, short) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Writes a primitive short.
- writeShortArray(short[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
-
- writeShortArray(String, short[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Writes a primitive short-array.
- writeSocketP(String, int, FunctionEx<? super T, ? extends String>, Charset) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
- writeStartArray() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeStartArray(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeStartArray(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeStartArray(Object, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeStartArray() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeStartArray(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeStartArray(Object, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeStartArray() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeStartArray(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeStartArray(Object, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeStartArray() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for writing starting marker of a Array value
(for JSON this is character '['; plus possible white space decoration
if pretty-printing is enabled).
- writeStartArray(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- writeStartArray(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for writing start marker of an Array value, similar
to
JsonGenerator.writeStartArray()
,
but also specifying the "current value"
to assign to the new Array context being created.
- writeStartArray(Object, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- writeStartArray(JsonGenerator) - Method in interface com.hazelcast.com.fasterxml.jackson.core.PrettyPrinter
-
Method called when an Array value is to be output, before
any member/child values are output.
- writeStartArray(JsonGenerator) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
- writeStartArray() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeStartArray(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeStartArray(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeStartArray(Object, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeStartArray(JsonGenerator) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.MinimalPrettyPrinter
-
- writeStartObject(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- writeStartObject() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeStartObject(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeStartObject(Object, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeStartObject() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeStartObject(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeStartObject() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeStartObject(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeStartObject() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for writing starting marker of an Object value
(character '{'; plus possible white space decoration
if pretty-printing is enabled).
- writeStartObject(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for writing starting marker of an Object value
to represent the given Java Object value.
- writeStartObject(Object, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for writing starting marker of an Object value
to represent the given Java Object value.
- writeStartObject(JsonGenerator) - Method in interface com.hazelcast.com.fasterxml.jackson.core.PrettyPrinter
-
Method called when an Object value is to be output, before
any fields are output.
- writeStartObject(JsonGenerator) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
- writeStartObject() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeStartObject(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeStartObject(Object, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeStartObject(JsonGenerator) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.MinimalPrettyPrinter
-
- writeString(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- writeString(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeString(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeString(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeString(Reader, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeString(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeString(Reader, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeString(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeString(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeString(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeString(Reader, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeString(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeString(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeString(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for outputting a String value.
- writeString(Reader, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for outputting a String value.
- writeString(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for outputting a String value.
- writeString(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- writeString(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeString(Reader, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeString(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeString(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeString(String) - Method in interface com.hazelcast.nio.ObjectDataOutput
-
- writeString(String, String) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Writes an UTF string.
- writeStringArray(String[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
-
- writeStringArray(String, String[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Writes a String-array.
- writeStringField(String, String) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Convenience method for outputting a field entry ("member")
that has a String value.
- writeTenant(ObjectDataOutput) - Method in class com.hazelcast.config.CacheConfig
-
- writeTime(String, LocalTime) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Write a time field consisting of hour, minute, seconds and nanos parts
- writeTimeArray(String, LocalTime[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
Writes an array of Time's
- writeTimestamp(String, LocalDateTime) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
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
-
Writes an array of Timestamp's
- writeTimestampWithTimezone(String, OffsetDateTime) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
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
-
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.
- writeTree(TreeNode) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- writeTree(TreeNode) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method for writing given JSON tree (expressed as a tree
where given JsonNode is the root) using this generator.
- writeTree(JsonGenerator, TreeNode) - Method in class com.hazelcast.com.fasterxml.jackson.core.ObjectCodec
-
Method for serializing JSON content from given Tree instance, using
specified generator.
- writeTree(JsonGenerator, TreeNode) - Method in class com.hazelcast.com.fasterxml.jackson.core.TreeCodec
-
- writeTree(TreeNode) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeTypeId(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeTypeId(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method that can be called to output so-called native Type Id.
- writeTypeId(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeTypePrefix(WritableTypeId) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- writeTypeSuffix(WritableTypeId) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- writeUnquotedUTF8(OutputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SerializedString
-
- writeUnquotedUTF8(OutputStream) - Method in interface com.hazelcast.com.fasterxml.jackson.core.SerializableString
-
Method for writing unescaped UTF-8 encoded String value using given
OutputStream
.
- writeUTF(String) - Method in interface com.hazelcast.nio.ObjectDataOutput
-
- writeUTF(String, String) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
- writeUTF8String(byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- writeUTF8String(byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- writeUTF8String(byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- writeUTF8String(byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Method similar to
JsonGenerator.writeString(String)
but that takes as its input
a UTF-8 encoded String which has
not been escaped using whatever
escaping scheme data format requires (for JSON that is backslash-escaping
for control characters and double-quotes; for other formats something else).
- writeUTF8String(byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
-
- writeUTFArray(String[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
-
- writeUTFArray(String, String[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
- writeValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
- writeValue(JsonGenerator, Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.ObjectCodec
-
Method to serialize given Java Object, using generator
provided.
- WrongTargetException - Exception in com.hazelcast.spi.exception
-
- 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
-
- _addName(int[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
This is the main workhorse method used when we take a symbol
table miss.
- _allowMultipleMatches - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
Flag that determines whether filtering will continue after the first
match is indicated or not: if `false`, output is based on just the first
full match (returning
TokenFilter.INCLUDE_ALL
) and no more
checks are made; if `true` then filtering will be applied as necessary
until end of content.
- _allowMultipleMatches - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
Flag that determines whether filtering will continue after the first
match is indicated or not: if `false`, output is based on just the first
full match (returning
TokenFilter.INCLUDE_ALL
) and no more
checks are made; if `true` then filtering will be applied as necessary
until end of content.
- _appendSourceDesc(StringBuilder) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonLocation
-
- _arrayIndenter - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
By default, let's use only spaces to separate array values.
- _artifactId - Variable in class com.hazelcast.com.fasterxml.jackson.core.Version
-
- _ascii(byte[]) - Static method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
Deprecated.
- _asciiBytes(String) - Static method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
Deprecated.
- _asString(BigDecimal) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
Helper method used to serialize a
BigDecimal
as a String,
for serialization, taking into account configuration settings
- _asString - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
-
We will retain representation of the pointer, as a String,
so that
JsonPointer.toString()
should be as efficient as possible.
- _base64Buffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
Reference to the buffer allocated for temporary use with
base64 encoding or decoding.
- _bigEndian - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.UTF32Reader
-
- _binaryValue - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- _buckets - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
-
Overflow buckets; if primary doesn't match, lookup is done
from here.
- _buffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.format.InputAccessor.Std
-
- _buffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.UTF32Reader
-
- _bufferedData - Variable in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatMatcher
-
Content read during format matching process
- _bufferedEnd - Variable in class com.hazelcast.com.fasterxml.jackson.core.format.InputAccessor.Std
-
End of valid bytes in the buffer (points to one past last valid)
- _bufferedLength - Variable in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatMatcher
-
Number of bytes available in buffer.
- _bufferedStart - Variable in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatMatcher
-
Pointer to the first byte in buffer available for reading
- _bufferedStart - Variable in class com.hazelcast.com.fasterxml.jackson.core.format.InputAccessor.Std
-
- _bufferRecyclable - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
Flag that indicates whether the input buffer is recycable (and
needs to be returned to recycler once we are done) or not.
- _bufferRecyclable - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
Flag that indicates whether the output buffer is recycable (and
needs to be returned to recycler once we are done) or not.
- _bufferRecyclable - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
Flag that indicates whether the input buffer is recycable (and
needs to be returned to recycler once we are done) or not.
- _bufferRecycler - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
Recycler used for actual allocation/deallocation/reuse
- _byteArrayBuilder - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
ByteArrayBuilder is needed if 'getBinaryValue' is called.
- _byteBuffers - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
-
- _byteCount - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.UTF32Reader
-
Total read byte count; used for error reporting purposes
- _byteSymbolCanonicalizer - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Alternative to the basic symbol table, some stream-based
parsers use different name canonicalization method.
- _canonicalize - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
-
Whether any canonicalization should be attempted (whether using
intern or not.
- _cfgNumbersAsStrings - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- _cfgPrettyPrinter - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Object that handles pretty-printing (usually additional
white space to make results more human-readable) during
output.
- _cfgUnqNames - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonGeneratorImpl
-
Flag that is set if quoting is not to be added around
JSON Object property names.
- _characterEscapes - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonGeneratorImpl
-
Definition of custom character escapes to use for generators created
by this factory, if any.
- _characterEscapes - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Definition of custom character escapes to use for generators created
by this factory, if any.
- _characterEscapes - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonFactoryBuilder
-
- _charBuffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
Intermediate buffer in which characters of a String are copied
before being encoded.
- _charBufferLength - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
Length of _charBuffer
- _charBuffers - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
-
- _charCount - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.UTF32Reader
-
Total read character count; used for error reporting purposes
- _charset - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.RequestPayload
-
- _checkBinaryWrite() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- _checkForExistingToken - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserSequence
-
- _checkInvalidCopy(Class<?>) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- _checkParentPath() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- _checkParentPath(boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- _checkPropertyParentPath() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- _checkRawValueWrite() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- _checkStdFeatureChanges(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
Helper method called to verify changes to standard features.
- _checkStdFeatureChanges(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Helper method called to verify changes to standard features.
- _checkStdFeatureChanges(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonGeneratorImpl
-
- _child - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
-
- _child - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
-
- _child - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
- _closeArrayScope() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _closed - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
Flag that indicates whether generator is closed or not.
- _closed - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Flag that indicates whether parser is closed or not.
- _closeInput() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- _closeInput() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _closeInput() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- _closeInput() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- _closeInput() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _closeObjectScope() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _codec() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- _columnNr - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
-
- _columnNr - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonLocation
-
- _concatCBuffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
Reference to the buffer allocated for buffering it for
output, before being encoded: generally this means concatenating
output, then encoding when buffer fills up.
- _constructDefaultPrettyPrinter() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- _constructError(String, Throwable) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- _constructError(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- _constructHead() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
-
- _constructHead(int, JsonPointer) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
-
- _context - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.UTF32Reader
-
- _copyBuffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
Intermediate buffer in which characters of a String are copied
before being encoded.
- _copyCurrentContents(JsonParser) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- _count - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
Total number of Strings in the symbol table; only used for child tables.
- _createContext(Object, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Overridable factory method that actually instantiates desired
context object.
- _createDataOutputWrapper(DataOutput) - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
- _createGenerator(Writer, IOContext) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Overridable factory method that actually instantiates generator for
given
Writer
and context object.
- _createNonBlockingContext(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Overridable factory method that actually instantiates desired
context object for async (non-blocking) parsing
- _createParser(InputStream, IOContext) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Overridable factory method that actually instantiates desired parser
given
InputStream
and context object.
- _createParser(Reader, IOContext) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Overridable factory method that actually instantiates parser
using given
Reader
object for reading content.
- _createParser(char[], int, int, IOContext, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Overridable factory method that actually instantiates parser
using given char[]
object for accessing content.
- _createParser(byte[], int, int, IOContext) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Overridable factory method that actually instantiates parser
using given
Reader
object for reading content
passed as raw byte array.
- _createParser(DataInput, IOContext) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Optional factory method, expected to be overridden
- _createUTF8Generator(OutputStream, IOContext) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Overridable factory method that actually instantiates generator for
given
OutputStream
and context object, using UTF-8 encoding.
- _createWriter(OutputStream, JsonEncoding, IOContext) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- _currBufferStart - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
Since we are fed content that may or may not start at zero offset, we need
to keep track of the first byte within that buffer, to be able to calculate
logical offset within input "stream"
- _currentEscape - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
When custom escapes are used, this member variable is used
internally to hold a reference to currently used escape
- _currentName - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
-
Name of the field of which value is to be parsed; only
used for OBJECT contexts
- _currentName - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
-
- _currentName - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
Name of the field of which value is to be written; only
used for OBJECT contexts
- _currentValue - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
-
- _currentValue - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
- _currInputProcessed - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Number of characters/bytes that were contained in previous blocks
(blocks that were already processed prior to the current buffer).
- _currInputRow - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Current row location of current point in input buffer, starting
from 1, if available.
- _currInputRowAlt - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
Alternate row tracker, used to keep track of position by `\r` marker
(whereas _currInputRow
tracks `\n`).
- _currInputRowStart - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Current index of the first character of the current row in input
buffer.
- _currToken - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- _currToken - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- _decodeBase64(String, ByteArrayBuilder, Base64Variant) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
Helper method that can be used for base64 decoding in cases where
encoded content has already been read as a String.
- _decodeBase64(Base64Variant) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
Efficient handling for incremental parsing of base64-encoded
textual content.
- _decodeBase64(Base64Variant) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
Efficient handling for incremental parsing of base64-encoded
textual content.
- _decodeBase64(Base64Variant) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
Efficient handling for incremental parsing of base64-encoded
textual content.
- _decodeBase64Escape(Base64Variant, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- _decodeBase64Escape(Base64Variant, char, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- _decodeCharForError(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- _decodeCharForError(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _decodeEscaped() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Method that sub-classes must implement to support escaped sequences
in base64-encoded sections.
- _decodeEscaped() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _decodeEscaped() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- _decodeEscaped() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- _decodeEscaped() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _decodeSurrogate(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- _decorate(InputStream, IOContext) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- _decorate(Reader, IOContext) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- _decorate(DataInput, IOContext) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- _decorate(OutputStream, IOContext) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- _decorate(Writer, IOContext) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- _detectors - Variable in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatDetector
-
Ordered list of factories which both represent data formats to
detect (in precedence order, starting with highest) and are used
for actual detection.
- _dups - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
-
- _dups - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
- _enabled - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.JacksonFeatureSet
-
- _encoding - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
Encoding used by the underlying stream, if known.
- _endOfInput - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
Flag that is sent when calling application indicates that there will
be no more input to parse.
- _entityBuffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
6 character temporary buffer allocated if needed, for constructing
escape sequences
- _entityBuffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
Short (14 char) temporary buffer allocated if needed, for constructing
escape sequences
- _eofAsNextChar() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- _eofAsNextToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
Helper method called at point when all input has been exhausted and
input feeder has indicated no more input will be forthcoming.
- _expLength - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Length of the exponent part of the number, if any, not
including 'e' marker or sign, just digits.
- _exposedContext - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- _factoryFeatures - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Currently enabled factory features.
- _factoryFeatures - Variable in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- _failOnDoS - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
Flag that indicates whether we should throw an exception if enough
hash collisions are detected (true); or just worked around (false).
- _features - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- _features - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
- _fieldComplete(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _filter - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
-
Filter to use for items in this state (for properties of Objects,
elements of Arrays, and root-level values of root context)
- _filterContext - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
Although delegate has its own output context it is not sufficient since we actually
have to keep track of excluded (filtered out) structures as well as ones delegate
actually outputs.
- _filterContext() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- _findName(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _findName(int, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _findName(int, int, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _finishAndReturnString() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _finishErrorToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _finishErrorTokenWithEOF() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _finishFieldWithEscape() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _finishFloatExponent(boolean, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _finishFloatFraction() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _finishKeywordToken(String, int, JsonToken) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _finishKeywordTokenWithEOF(String, int, JsonToken) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _finishNonStdToken(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _finishNonStdTokenWithEOF(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _finishNumberIntegralPart(char[], int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _finishNumberLeadingNegZeroes() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _finishNumberLeadingZeroes() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _finishNumberMinus(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _finishString() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- _finishString() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- _finishString() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- _finishString() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _finishString2() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- _finishToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
Method called when decoding of a token has been started, but not yet completed due
to missing input; method is to continue decoding due to at least one more byte
being made available to decode.
- _finishTokenWithEOF() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _firstName - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.DupDetector
-
- _flags - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
-
- _flushBuffer() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- _flushBuffer() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- _fractLength - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Length of the fractional part (not including decimal
point or exponent), in characters.
- _generatorFeatures - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Currently enabled generator features.
- _getBufferRecycler() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Method used by factory to create buffer recycler instances
for parsers and generators.
- _getByteArrayBuilder() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- _getCharDesc(int) - Static method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- _getSourceReference() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Helper method used to encapsulate logic of including (or not) of
"source reference" when constructing
JsonLocation
instances.
- _getText2(JsonToken) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _getText2(JsonToken) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- _getText2(JsonToken) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- _getText2(JsonToken) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _gotName - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
Marker used to indicate that we just wrote a name, and
now expect a value to write
- _groupId - Variable in class com.hazelcast.com.fasterxml.jackson.core.Version
-
- _handleApos() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- _handleApos() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- _handleApos() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _handleBase64MissingPadding(Base64Variant) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- _handleEOF() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Method called when an EOF is encountered between tokens.
- _handleEOF() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
Method sub-classes need to implement
- _handleInvalidNumberStart(int, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
Method called if expected numeric value (due to leading sign) does not
look like a number
- _handleInvalidNumberStart(int, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
Method called if expected numeric value (due to leading sign) does not
look like a number
- _handleInvalidNumberStart(int, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
Method called if expected numeric value (due to leading sign) does not
look like a number
- _handleOddName(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
Method called when we see non-white space character other
than double quote, when expecting a field name.
- _handleOddName(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
Method called when we see non-white space character other
than double quote, when expecting a field name.
- _handleOddName(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
Method called when we see non-white space character other
than double quote, when expecting a field name.
- _handleOddValue(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
Method for handling cases where first non-space character
of an expected value token is not legal for standard JSON content.
- _handleUnexpectedValue(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
Method for handling cases where first non-space character
of an expected value token is not legal for standard JSON content.
- _handleUnexpectedValue(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
Method for handling cases where first non-space character
of an expected value token is not legal for standard JSON content.
- _handleUnrecognizedCharacterEscape(char) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- _hashArea - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
Primary hash information area: consists of 2 * _hashSize
entries of 16 bytes (4 ints), arranged in a cascading lookup
structure (details of which may be tweaked depending on expected rates
of collisions).
- _hashCode - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.Name
-
- _hashSeed - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- _hashShared - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
Flag that indicates whether underlying data structures for
the main hash area are shared or not.
- _hashShared - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
-
Flag that indicates whether underlying data structures for
the main hash area are shared or not.
- _hashSize - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
Number of slots for primary entries within
ByteQuadsCanonicalizer._hashArea
; which is
at most
1/8
of actual size of the underlying array (4-int slots,
primary covers only half of the area; plus, additional area for longer
symbols after hash area).
- _hashToIndex(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
-
Helper method that takes in a "raw" hash value, shuffles it as necessary,
and truncates to be used as the index.
- _hasTextualNull(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
Helper method used to determine whether we are currently pointing to
a String value of "null" (NOT a null token); and, if so, that parser
is to recognize and return it similar to if it was real null token.
- _hasToken - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserSequence
-
Flag used to indicate that `JsonParser.nextToken()` should not be called,
due to parser already pointing to a token.
- _head - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
-
Reference from currently matching segment (if any) to node
before leaf.
- _headContext - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- _icLatin1 - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _icLatin1 - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- _icLatin1 - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- _icLatin1 - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _in - Variable in class com.hazelcast.com.fasterxml.jackson.core.format.InputAccessor.Std
-
- _in - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.UTF32Reader
-
- _includeScalar() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.JsonPointerBasedFilter
-
- _includeScalar() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
-
Overridable default implementation delegated to all scalar value
inclusion check methods.
- _inclusion - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
Flag that determines whether path leading up to included content should
also be automatically included or not.
- _inclusion - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
Flag that determines whether path leading up to included content should
also be automatically included or not.
- _index - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
-
Index of the currently processed entry.
- _indexMask - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
-
Mask used to get index from hash values; equal to
_buckets.length - 1
, when _buckets.length is
a power of two.
- _inputBuffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _inputBuffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
Current buffer from which data is read; generally data is read into
buffer from input source.
- _inputBuffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
Current buffer from which data is read; generally data is read into
buffer from input source, but in some cases pre-loaded buffer
is handed to the parser.
- _inputData - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- _inputDecorator - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Optional helper object that may decorate input sources, to do
additional processing on input during parsing.
- _inputDecorator - Variable in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
Optional helper object that may decorate input sources, to do
additional processing on input during parsing.
- _inputEnd - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Index of character after last available one in the buffer.
- _inputPtr - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Pointer to next available character in buffer
- _inputStream - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _inputType - Variable in exception com.hazelcast.com.fasterxml.jackson.core.exc.InputCoercionException
-
Input token that represents input value that failed to coerce.
- _intern - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
Whether canonical symbol Strings are to be intern()ed before added
to the table or not.
- _intLength - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Length of integer part of the number, in characters
- _ioContext - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
I/O context for this reader.
- _ioContext - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonGeneratorImpl
-
- _isNextTokenNameMaybe(int, String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- _itemFilter - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
State that applies to the item within container, used where applicable.
- _itemFilter - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
State that applies to the item within container, used where applicable.
- _jdkSerializeValue - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.SerializedString
-
Ugly hack, to work through the requirement that _value is indeed final,
and that JDK serialization won't call ctor(s).
- _lastClearedToken - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- _lastClearedToken - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- _legacyDisable(JsonParser.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- _legacyDisable(JsonGenerator.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- _legacyEnable(JsonParser.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- _legacyEnable(JsonGenerator.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- _length - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.UTF32Reader
-
- _lineNr - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
-
- _lineNr - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonLocation
-
- _loadMore() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- _loadMore() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _loadMoreGuaranteed() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- _loadMoreGuaranteed() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _location - Variable in exception com.hazelcast.com.fasterxml.jackson.core.JsonProcessingException
-
- _longestCollisionList - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
-
We need to keep track of the longest collision list; this is needed
both to indicate problems with attacks and to allow flushing for
other cases.
- _longIntegerDesc(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- _longNameOffset - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
Offset within
ByteQuadsCanonicalizer._hashArea
that follows main slots and contains
quads for longer names (13 bytes or longer), and points to the
first available int that may be used for appending quads of the next
long name.
- _longNumberDesc(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- _majorState - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
Current main decoding state within logical tree
- _majorStateAfterValue - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _majorVersion - Variable in class com.hazelcast.com.fasterxml.jackson.core.Version
-
- _managedBuffers - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.UTF32Reader
-
- _managedResource - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
Flag that indicates whether underlying input/output source/target
object is fully managed by the owner of this context (parser or
generator).
- _match - Variable in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatMatcher
-
Factory that produced sufficient match (if any)
- _matchCount - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
-
- _matchCount - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
- _matchFalse() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _matchingElementIndex - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
-
- _matchingPropertyName - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
-
- _matchNull() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _matchStrength - Variable in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatMatcher
-
- _matchToken(String, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
Helper method for checking whether input matches expected token
- _matchToken(String, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- _matchToken(String, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _matchTrue() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _maximumNonEscapedChar - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonGeneratorImpl
-
Value between 128 (0x80) and 65535 (0xFFFF) that indicates highest
Unicode code point that will not need escaping; or 0 to indicate
that all characters can be represented without escaping.
- _maximumNonEscapedChar - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Optional threshold used for automatically escaping character above certain character
code value: either 0
to indicate that no threshold is specified, or value
at or above 127 to indicate last character code that is NOT automatically escaped
(but depends on other configuration rules for checking).
- _maximumNonEscapedChar - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonFactoryBuilder
-
- _maxInputLookahead - Variable in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatDetector
-
Maximum number of leading bytes of the input that we can read
to determine data format.
- _minimalMatch - Variable in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatDetector
-
Strength of minimal match we accept as the answer, unless
better matches are found.
- _minorState - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
Additional indicator within state; contextually relevant for just that state
- _minorStateAfterSplit - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
Secondary minor state indicator used during decoding of escapes and/or
multi-byte Unicode characters
- _minorVersion - Variable in class com.hazelcast.com.fasterxml.jackson.core.Version
-
- _name - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.Name
-
- _nameCopied - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Flag set to indicate whether the field name is available
from the name copy buffer or not (in addition to its String
representation being available via read context)
- _nameCopyBuffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- _nameCopyBuffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
Reference temporary buffer Parser instances need if calling
app decides it wants to access name via 'getTextCharacters' method.
- _names - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
- _nameStartCol - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- _nameStartCol - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _nameStartOffset - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- _nameStartOffset - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _nameStartRow - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- _nameStartRow - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _needToHandleName - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
-
Flag that indicates that the current name of this context
still needs to be read/written, if path from root down to
included leaf is to be exposed.
- _nesting - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
Number of open levels of nesting.
- _nextByte - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
Sometimes we need buffering for just a single byte we read but
have to "push back"
- _nextParserIndex - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserSequence
-
- _nextSegment - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
-
Reference to rest of the pointer beyond currently matching
segment (if any); null if this pointer refers to the matching
segment.
- _nextToken - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Secondary token related to the next token after current one;
used if its type is known.
- _nextToken2() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
Offlined handling for cases where there was no buffered token to
return, and the token read next could not be returned as-is,
at least not yet, but where we have not yet established that
buffering is needed.
- _nextTokenWithBuffering(TokenFilterContext) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
-
Method called when a new potentially included context is found.
- _nonStdToken(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _nonStdTokenType - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
When tokenizing non-standard ("odd") tokens, this is the type to consider;
also works as index to actual textual representation.
- _numberBigDecimal - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- _numberBigInt - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- _numberDouble - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- _numberInt - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- _numberLong - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- _numberNegative - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Flag that indicates whether numeric value has a negative
value.
- _numTypesValid - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Bitfield that indicates which numeric representations
have been calculated for the current type
- _objectCodec - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
- _objectCodec - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- _objectCodec - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
Codec used for data binding when (if) requested; typically full
ObjectMapper
, but that abstract is not part of core
package.
- _objectCodec - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
Codec used for data binding when (if) requested; typically full
ObjectMapper
, but that abstract is not part of core
package.
- _objectCodec - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Object that implements conversion functionality between
Java objects and JSON content.
- _objectFieldValueSeparatorWithSpaces - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
- _objectIndenter - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
By default, let's use linefeed-adding indenter for separate
object entries.
- _optimalMatch - Variable in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatDetector
-
Strength of match we consider to be good enough to be used
without checking any other formats.
- _optimizedStreamFromURL(URL) - Method in class com.hazelcast.com.fasterxml.jackson.core.TokenStreamFactory
-
Helper methods used for constructing an optimal stream for
parsers to use, when input is to be read from an URL.
- _origBufferLen - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
In addition to current buffer pointer, and end pointer,
we will also need to know number of bytes originally
contained.
- _originalStream - Variable in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatMatcher
-
- _output - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.DataOutputAsStream
-
- _outputBuffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- _outputBuffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- _outputDecorator - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Optional helper object that may decorate output object, to do
additional processing on output during content generation.
- _outputDecorator - Variable in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
Optional helper object that may decorate output object, to do
additional processing on output during content generation.
- _outputEnd - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
End marker of the output buffer; one past the last valid position
within the buffer.
- _outputEnd - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
End marker of the output buffer; one past the last valid position
within the buffer.
- _outputEscapes - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonGeneratorImpl
-
Currently active set of output escape code definitions (whether
and how to escape or not) for 7-bit ASCII range (first 128
character codes).
- _outputHead - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
Pointer to the first buffered character to output
- _outputMaxContiguous - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
Maximum number of char
s that we know will always fit
in the output buffer after escaping
- _outputStream - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
Underlying output stream used for writing JSON content.
- _outputSurrogates(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- _outputTail - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
Pointer to the position right beyond the last character to output
(end marker; may be past the buffer)
- _outputTail - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
Pointer to the position right beyond the last character to output
(end marker; may point to position right beyond the end of the buffer)
- _overflows - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
-
Lazily constructed structure that is used to keep track of
collision buckets that have overflowed once: this is used
to detect likely attempts at denial-of-service attacks that
uses hash collisions.
- _padLastQuad(int, int) - Static method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
Helper method needed to fix [jackson-core#148], masking of 0x00 character
- _parent - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
-
Parent context for this context; null for root context.
- _parent - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
-
Parent context for this context; null for root context.
- _parent - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
-
Parent context for this context; null for root context.
- _parent - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
Reference to the root symbol table, for child tables, so
that they can merge table information back as necessary.
- _parent - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
-
Sharing of learnt symbols is done by optional linking of symbol
table instances with their parents.
- _parseAposName() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- _parseAposName() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- _parseAposName() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _parseFloatThatStartsWithPeriod() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- _parseFloatThatStartsWithPeriod() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- _parseFloatThatStartsWithPeriod() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _parseIntValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- _parseName() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- _parseName(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- _parseName(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _parseNegNumber() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- _parseNegNumber() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- _parseNegNumber() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _parseNumericValue(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Method that will parse actual numeric value out of a syntactically
valid number value.
- _parsePosNumber(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
Initial parsing method for number values.
- _parsePosNumber(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
Initial parsing method for number values.
- _parsePosNumber(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
Initial parsing method for number values.
- _parseQuotedTail(String, int) - Static method in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
-
Method called to parse tail of pointer path, when a potentially
escaped character has been seen.
- _parserFeatures - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Currently enabled parser features.
- _parsers - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserSequence
-
Parsers other than the first one (which is initially assigned
as delegate)
- _parseTail(String) - Static method in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
-
- _parsingContext - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Information about parser context, context in which
the next token is to be parsed (root, array, object).
- _patchLevel - Variable in class com.hazelcast.com.fasterxml.jackson.core.Version
-
- _pathToMatch - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.JsonPointerBasedFilter
-
- _payloadAsBytes - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.RequestPayload
-
- _payloadAsText - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.RequestPayload
-
- _pending32 - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _pendingBytes - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _processor - Variable in exception com.hazelcast.com.fasterxml.jackson.core.exc.StreamReadException
-
- _processor - Variable in exception com.hazelcast.com.fasterxml.jackson.core.JsonGenerationException
-
- _ptr - Variable in class com.hazelcast.com.fasterxml.jackson.core.format.InputAccessor.Std
-
- _ptr - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.UTF32Reader
-
- _quad1 - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _quadBuffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
Temporary buffer used for name parsing.
- _quadBuffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
Temporary buffer used for name parsing.
- _quadBuffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
Temporary buffer used for name parsing.
- _quadLength - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _quoteChar - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
Character used for quoting JSON Object property names
and String values.
- _quoteChar - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
Character used for quoting JSON Object property names
and String values.
- _quoteChar - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
- _quoteChar - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonFactoryBuilder
-
- _quoted32 - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _quotedChars - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.SerializedString
-
- _quotedDigits - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _quotedUTF8Ref - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.SerializedString
-
- _readBinary(Base64Variant, OutputStream, byte[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- _readBinary(Base64Variant, OutputStream, byte[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- _readBinary(Base64Variant, OutputStream, byte[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _reader - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
Reader that can be used for reading more content, if one
buffer from input source, but in some cases pre-loaded buffer
is handed to the parser.
- _readIOBuffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
Reference to the allocated I/O buffer for low-level input reading,
if any allocated.
- _recyclerRef - Static variable in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecyclers
-
This
ThreadLocal
contains a
SoftReference
to a
BufferRecycler
used to provide a low-cost
buffer recycling between reader and writer instances.
- _releaseBuffers() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
Method called to release any buffers generator may be holding,
once generator is being closed.
- _releaseBuffers() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Method called to release internal buffers owned by the base
reader.
- _releaseBuffers() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _releaseBuffers() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
Method called to release internal buffers owned by the base
reader.
- _releaseBuffers() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
Method called to release internal buffers owned by the base
reader.
- _releaseBuffers() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- _releaseBuffers() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
Method called to release internal buffers owned by the base
reader.
- _releaseBuffers() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- _reportBase64EOF() - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
-
- _reportBase64UnexpectedPadding() - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
-
- _reportCantWriteValueExpectName(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonGeneratorImpl
-
- _reportError(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- _reportError(String, Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- _reportError(String, Object, Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- _reportError(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- _reportErrorToken(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _reportInputCoercion(String, JsonToken, Class<?>) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- _reportInvalidBase64(char, int, String) - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
-
- _reportInvalidChar(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _reportInvalidChar(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- _reportInvalidChar(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _reportInvalidEOF() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- _reportInvalidEOF(String, JsonToken) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- _reportInvalidEOF(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- _reportInvalidEOFInValue(JsonToken) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- _reportInvalidEOFInValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- _reportInvalidInitial(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _reportInvalidInitial(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- _reportInvalidInitial(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _reportInvalidOther(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _reportInvalidOther(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _reportInvalidOther(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _reportInvalidOther(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _reportInvalidToken(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- _reportInvalidToken(String, String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- _reportInvalidToken(int, String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- _reportInvalidToken(int, String, String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
- _reportInvalidToken(String, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _reportInvalidToken(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _reportInvalidToken(String, String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
- _reportMismatchedEndMarker(int, char) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- _reportMissingRootWS(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- _reportTooLongIntegral(int, String) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- _reportTooManyCollisions() - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
- _reportUnexpectedChar(int, String) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- _reportUnsupportedOperation() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- _reportUnsupportedOperation() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Helper method to call for operations that are not supported by
parser implementation.
- _requestPayload - Variable in exception com.hazelcast.com.fasterxml.jackson.core.exc.StreamReadException
-
Optional payload that can be assigned to pass along for error reporting
or handling purposes.
- _requestPayload - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
-
Optional container that holds the request payload which will be displayed on JSON parsing error.
- _rootCharSymbols - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Each factory comes equipped with a shared root symbol table.
- _rootSeparator - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
String printed between root-level values, if any.
- _rootValueSeparator - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.JsonGeneratorImpl
-
Separator to use, if any, between root-level values.
- _rootValueSeparator - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
-
Separator used between root-level values, if any; null indicates
"do not add separator".
- _rootValueSeparator - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonFactoryBuilder
-
- _rootValueSeparator - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.MinimalPrettyPrinter
-
- _secondaryStart - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
- _secondName - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.DupDetector
-
- _seed - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
Seed value we use as the base to make hash codes non-static between
different runs, but still stable for lifetime of a single symbol table
instance.
- _seed - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
-
Seed value we use as the base to make hash codes non-static between
different runs, but still stable for lifetime of a single symbol table
instance.
- _seen - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.DupDetector
-
Lazily constructed set of names already seen within this context.
- _separators - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
- _separators - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.MinimalPrettyPrinter
-
- _size - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
-
Current size (number of entries); needed to know if and when
rehash.
- _sizeThreshold - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
-
Limit that indicates maximum size this instance can hold before
it needs to be expanded and rehashed.
- _skipCR() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
We actually need to check the character value here
(to see if we have \n following \r).
- _skipCR() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
We actually need to check the character value here
(to see if we have \n following \r).
- _skipString() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
Method called to skim through rest of unparsed String value,
if it is not needed.
- _skipString() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
Method called to skim through rest of unparsed String value,
if it is not needed.
- _skipString() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
Method called to skim through rest of unparsed String value,
if it is not needed.
- _snapshotInfo - Variable in class com.hazelcast.com.fasterxml.jackson.core.Version
-
Additional information for snapshot versions; null for non-snapshot
(release) versions.
- _source - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.DupDetector
-
We need to store a back-reference here to parser/generator.
- _sourceRef - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
Reference to the source object, which can be used for displaying
location information
- _spacesInObjectEntries - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
By default we will add spaces around colons used to
separate object fields and values.
- _spilloverEnd - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
Pointer to the offset within spill-over area where there is room
for more spilled over entries (if any).
- _startAposString() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _startArrayScope() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _startFalseToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _startFloat(char[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _startFloatThatStartsWithPeriod() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _startHandled - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
-
Flag that indicates that start token has been read/written,
so that matching close token needs to be read/written as well
when context is getting closed.
- _startNegativeNumber() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _startNullToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _startNumberLeadingZero() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _startObjectScope() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _startPositiveNumber(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _startString() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _startTrueToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _startUnexpectedValue(boolean, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
-
- _streamReadFeatures - Variable in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- _streamWriteFeatures - Variable in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- _surrogate - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.UTF32Reader
-
Although input is fine with full Unicode set, Java still uses
16-bit chars, so we may have to split high-order chars into
surrogate pairs.
- _symbols - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
Symbol table that contains field names encountered so far
- _symbols - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
- _symbols - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
Symbol table that contains field names encountered so far
- _symbols - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
Symbol table that contains field names encountered so far
- _symbols - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
-
Primary matching symbols; it's expected most match occur from
here.
- _tableInfo - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
Member that is only used by the root table instance: root
passes immutable state info child instances, and children
may return new state if they add entries to the table.
- _tableInfo - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
-
Member that is only used by the root table instance: root
passes immutable state info child instances, and children
may return new state if they add entries to the table.
- _targetType - Variable in exception com.hazelcast.com.fasterxml.jackson.core.exc.InputCoercionException
-
Target type that input value failed to coerce to.
- _tertiaryShift - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
Constant that determines size of buckets for tertiary entries:
1 << _tertiaryShift
is the size, and shift value
is also used for translating from primary offset into
tertiary bucket (shift right by 4 + _tertiaryShift
).
- _tertiaryStart - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
-
- _textBuffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Buffer that contains contents of String values, including
field names if necessary (name split across boundary,
contains escape sequence, or access needed to char array)
- _this() - Method in class com.hazelcast.com.fasterxml.jackson.core.TSFBuilder
-
- _throwInternal() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- _throwInternal() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- _throwInvalidSpace(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- _throwUnquotedSpace(int, String) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Method called to report a problem with unquoted control character.
- _tmpBuf - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.UTF32Reader
-
- _token - Variable in exception com.hazelcast.com.fasterxml.jackson.core.io.JsonEOFException
-
Type of token that was being decoded, if parser had enough information
to recognize type (such as starting double-quote for Strings)
- _tokenCBuffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
Reference to the buffer allocated for tokenization purposes,
in which character input is read, and from which it can be
further returned.
- _tokenIncomplete - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
-
Flag that indicates that the current token has not yet
been fully processed, and needs to be finished for
some access (or skipped to obtain the next token)
- _tokenIncomplete - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
-
Flag that indicates that the current token has not yet
been fully processed, and needs to be finished for
some access (or skipped to obtain the next token)
- _tokenIncomplete - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
-
Flag that indicates that the current token has not yet
been fully processed, and needs to be finished for
some access (or skipped to obtain the next token)
- _tokenInputCol - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Column on input row that current token starts; 0-based (although
in the end it'll be converted to 1-based)
- _tokenInputRow - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Input row on which current token starts, 1-based
- _tokenInputTotal - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
Total number of bytes/characters read before start of current token.
- _totalBytes - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonLocation
-
- _totalChars - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonLocation
-
- _type - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
-
Indicates logical type of context as one of TYPE_xxx
consants.
- _type - Variable in class com.hazelcast.com.fasterxml.jackson.core.type.TypeReference
-
- _unquotedUTF8Ref - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.SerializedString
-
- _updateTokenLocation() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _validJsonTokenList() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- _validJsonValueList() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
-
- _value - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.SerializedString
-
- _valueComplete(JsonToken) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _valueCompleteInt(int, String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _valueNonStdNumberComplete(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
-
- _verifyAlloc(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
- _verifyOffsets(int, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
- _verifyPrettyValueWrite(String, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonGeneratorImpl
-
- _verifyRelease(byte[], byte[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
- _verifyRelease(char[], char[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
- _verifyValueWrite(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
Method called before trying to write a value (scalar or structured),
to verify that this is legal in current output state, as well as to
output separators if and as necessary.
- _verifyValueWrite(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- _verifyValueWrite(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- _withSpaces(boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
-
- _wrapError(String, Throwable) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
-
- _writeBinary(Base64Variant, byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- _writeBinary(Base64Variant, InputStream, byte[], int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- _writeBinary(Base64Variant, InputStream, byte[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- _writeBinary(Base64Variant, byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- _writeBinary(Base64Variant, InputStream, byte[], int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- _writeBinary(Base64Variant, InputStream, byte[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- _writeContext - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
-
Object that keeps track of the current contextual state
of the generator.
- _writeEncodingBuffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
-
Reference to the allocated I/O buffer used for low-level
encoding-related buffering.
- _writeFieldName(String, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- _writeFieldName(SerializableString, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- _writePPFieldName(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
Specialized version of _writeFieldName
, off-lined
to keep the "fast path" as simple (and hopefully fast) as possible.
- _writePPFieldName(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
-
- _writePPFieldName(String, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
Specialized version of _writeFieldName
, off-lined
to keep the "fast path" as simple (and hopefully fast) as possible.
- _writePPFieldName(SerializableString, boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- _writer - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
-
- _writeSimpleObject(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
-
Helper method to try to call appropriate write method for given
untyped Object.