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

A

AbstractAlterOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
AbstractAlterOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
 
AbstractAlterOperation(String, IFunction<Long, Long>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
 
AbstractAlterOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
AbstractAlterOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
 
AbstractAlterOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
 
AbstractAtomicLongOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
AbstractAtomicLongOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AbstractAtomicLongOperation
 
AbstractAtomicLongOperation(String) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AbstractAtomicLongOperation
 
AbstractAtomicReferenceOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
AbstractAtomicReferenceOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AbstractAtomicReferenceOperation
 
AbstractAtomicReferenceOperation(String) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AbstractAtomicReferenceOperation
 
AbstractBasicConfig<T extends AbstractBasicConfig> - Class in com.hazelcast.config
Provides a basic configuration for a split-brain aware data structure.
AbstractBasicConfig() - Constructor for class com.hazelcast.config.AbstractBasicConfig
 
AbstractBasicConfig(String) - Constructor for class com.hazelcast.config.AbstractBasicConfig
 
AbstractBasicConfig(AbstractBasicConfig) - Constructor for class com.hazelcast.config.AbstractBasicConfig
 
AbstractCacheConfig<K,V> - Class in com.hazelcast.config
Base class for CacheConfig
AbstractCacheConfig() - Constructor for class com.hazelcast.config.AbstractCacheConfig
 
AbstractCacheConfig(CompleteConfiguration<K, V>) - Constructor for class com.hazelcast.config.AbstractCacheConfig
 
AbstractChannelInitializer - Class in com.hazelcast.nio.tcp
A ChannelInitializer that runs on a member and used for unencrypted channels.
AbstractChannelInitializer(IOService, EndpointConfig) - Constructor for class com.hazelcast.nio.tcp.AbstractChannelInitializer
 
AbstractConfigLocator - Class in com.hazelcast.config
Abstract base class for config locators.
AbstractConfigLocator() - Constructor for class com.hazelcast.config.AbstractConfigLocator
 
AbstractConfigLocator(boolean) - Constructor for class com.hazelcast.config.AbstractConfigLocator
 
AbstractCRDTReplicationOperation<T extends IdentifiedDataSerializable> - Class in com.hazelcast.crdt
Base class for CRDT replication operations.
AbstractCRDTReplicationOperation() - Constructor for class com.hazelcast.crdt.AbstractCRDTReplicationOperation
 
AbstractCRDTReplicationOperation(Map<String, T>) - Constructor for class com.hazelcast.crdt.AbstractCRDTReplicationOperation
Constructs the replication operation.
AbstractCredentials - Class in com.hazelcast.security
Abstract implementation of Credentials
AbstractCredentials() - Constructor for class com.hazelcast.security.AbstractCredentials
 
AbstractCredentials(String) - Constructor for class com.hazelcast.security.AbstractCredentials
 
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
 
AbstractDistributedObject<S extends RemoteService> - Class in com.hazelcast.spi
Abstract DistributedObject implementation.
AbstractDistributedObject(NodeEngine, S) - Constructor for class com.hazelcast.spi.AbstractDistributedObject
 
AbstractDomConfigProcessor - Class in com.hazelcast.config
Base class of the config processors working from W3C DOM objects
AbstractDomConfigProcessor(boolean) - Constructor for class com.hazelcast.config.AbstractDomConfigProcessor
 
AbstractEntryProcessor<K,V> - Class in com.hazelcast.map
An abstract EntryProcessor that already has implemented the AbstractEntryProcessor.getBackupProcessor().
AbstractEntryProcessor() - Constructor for class com.hazelcast.map.AbstractEntryProcessor
Creates an AbstractEntryProcessor that applies the EntryProcessor.process(java.util.Map.Entry) to primary and backups.
AbstractEntryProcessor(boolean) - Constructor for class com.hazelcast.map.AbstractEntryProcessor
Creates an AbstractEntryProcessor.
AbstractExecutorThreadFactory - Class in com.hazelcast.util.executor
 
AbstractExecutorThreadFactory(ClassLoader) - Constructor for class com.hazelcast.util.executor.AbstractExecutorThreadFactory
 
AbstractIMapEvent - Class in com.hazelcast.core
The abstract class for a map event IMapEvent.
AbstractIMapEvent(Object, Member, int) - Constructor for class com.hazelcast.core.AbstractIMapEvent
Constructs a prototypical map Event.
AbstractLocalOperation - Class in com.hazelcast.spi
Abstract class for local operations, which should not be serializable.
AbstractLocalOperation() - Constructor for class com.hazelcast.spi.AbstractLocalOperation
 
AbstractLockOperation - Class in com.hazelcast.concurrent.lock.operations
 
AbstractLockOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
AbstractLockOperation(ObjectNamespace, Data, long) - Constructor for class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
AbstractLockOperation(ObjectNamespace, Data, long, long) - Constructor for class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
AbstractLockOperation(ObjectNamespace, Data, long, long, long) - Constructor for class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
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
 
AbstractMember - Class in com.hazelcast.instance
 
AbstractMember() - Constructor for class com.hazelcast.instance.AbstractMember
 
AbstractMember(Map<EndpointQualifier, Address>, MemberVersion, String, Map<String, Object>, boolean) - Constructor for class com.hazelcast.instance.AbstractMember
 
AbstractMember(AbstractMember) - Constructor for class com.hazelcast.instance.AbstractMember
 
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
 
AbstractPNCounterOperation - Class in com.hazelcast.crdt.pncounter.operations
Base class for PNCounter query and mutation operation implementations.
AbstractProcessor - Class in com.hazelcast.jet.core
Base class to implement custom processors.
AbstractProcessor() - Constructor for class com.hazelcast.jet.core.AbstractProcessor
 
AbstractProcessor.FlatMapper<T,R> - Class in com.hazelcast.jet.core
A helper that simplifies the implementation of tryProcess(ordinal, item) for emitting collections.
AbstractWaitNotifyKey - Class in com.hazelcast.spi
Abstract implementation of the WaitNotifyKey.
AbstractWaitNotifyKey(String, String) - Constructor for class com.hazelcast.spi.AbstractWaitNotifyKey
 
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) - Method in class com.hazelcast.jet.core.ResettableSingletonTraverser
Resets this traverser so that the following next() call will return the item supplied here.
accept(T, U) - Method in interface com.hazelcast.jet.function.BiConsumerEx
 
accept(T) - Method in interface com.hazelcast.jet.function.ConsumerEx
 
accept(Packet) - Method in class com.hazelcast.nio.tcp.TcpIpEndpointManager
 
accept(Visitor, Indexes) - Method in class com.hazelcast.query.PagingPredicate
 
accept(Visitor, Indexes) - Method in class com.hazelcast.query.SqlPredicate
 
accept(Visitor, Indexes) - Method in interface com.hazelcast.query.VisitablePredicate
Accept visitor.
accept(int, int, V) - Method in interface com.hazelcast.util.collection.BiInt2ObjectMap.EntryConsumer
A map entry
accept(T, U) - Method in interface com.hazelcast.util.function.BiConsumer
Performs this operation on the given arguments.
accept(T) - Method in interface com.hazelcast.util.function.Consumer
Performs this operation on the given argument.
accept(long, long) - Method in interface com.hazelcast.util.function.LongLongConsumer
Accept a key and value that comes as a tuple of longs.
acceptEx(T, U) - Method in interface com.hazelcast.jet.function.BiConsumerEx
Exception-declaring version of BiConsumer.accept(T, U).
acceptEx(T) - Method in interface com.hazelcast.jet.function.ConsumerEx
Exception-declaring version of Consumer.accept(T)
accumulate(I) - Method in class 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.
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 provided aggregate operation on all the items it receives.
acquire(String, int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
 
acquire() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
 
acquire(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
 
acquire() - Method in interface com.hazelcast.core.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.core.ISemaphore
Acquires the given number of permits if they are available, and returns immediately, reducing the number of available permits by the given amount.
ACQUIRE_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
ACQUIRE_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
AcquireBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
AcquireBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.AcquireBackupOperation
 
AcquireBackupOperation(String, int, String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.AcquireBackupOperation
 
AcquireOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
AcquireOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
 
AcquireOperation(String, int, long) - Constructor for class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
 
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(CountDownLatchContainer) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
add(ICompletableFuture<E>) - Method in class com.hazelcast.core.Pipelining
Adds a future to this Pipelining or blocks until there is capacity to add the future to the Pipelining.
add(E) - Method in interface com.hazelcast.core.TransactionalList
Adds a new item to the transactional list.
add(E) - Method in interface com.hazelcast.core.TransactionalSet
Add new item to transactional set.
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(Address, long) - Method in class com.hazelcast.spi.CallsPerMember
 
add(Address, long) - Method in interface com.hazelcast.spi.LiveOperations
Registers an invocation with this object.
add(Object) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Adds an item to the tail of the ringbuffer.
add(T) - Method in class com.hazelcast.util.collection.InflatableSet
 
add(T) - Method in class com.hazelcast.util.collection.InflatableSet.Builder
 
add(Integer) - Method in class com.hazelcast.util.collection.IntHashSet
 
add(int) - Method in class com.hazelcast.util.collection.IntHashSet
Primitive specialised overload of {this#add(Integer)}
add(Long) - Method in class com.hazelcast.util.collection.LongHashSet
add(long) - Method in class com.hazelcast.util.collection.LongHashSet
Primitive specialised overload of {this#add(Long)}
add(E) - Method in class com.hazelcast.util.collection.OAHashSet
 
add(E, int) - Method in class com.hazelcast.util.collection.OAHashSet
Adds the specified element to this set if it is not already present.
add(T, long) - Method in class com.hazelcast.util.ItemCounter
Add delta to the item
add(E) - Method in class com.hazelcast.util.UnmodifiableListIterator
 
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.
ADD_AND_GET - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
ADD_BACKUP - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
ADD_DYNAMIC_CONFIG_OP - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
addAction(String) - Method in class com.hazelcast.config.PermissionConfig
 
addAll(Collection<?>) - Method in class com.hazelcast.jet.core.test.TestInbox
Convenience for inbox.queue().addAll(collection)
addAll(Collection<? extends Integer>) - Method in class com.hazelcast.util.collection.IntHashSet
 
addAll(Collection<? extends Long>) - Method in class com.hazelcast.util.collection.LongHashSet
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 class com.hazelcast.concurrent.atomiclong.AtomicLongContainer
 
addAndGet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
addAndGet(long) - Method in interface com.hazelcast.core.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.
addAndGet(long, VectorClock) - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
Adds the given value to the current value.
addAndGet(long) - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
 
addAndGetAsync(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
addAndGetAsync(long) - Method in interface com.hazelcast.core.IAtomicLong
Atomically adds the given value to the current value.
AddAndGetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
AddAndGetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
 
AddAndGetOperation(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
 
addAsync(Object) - Method in interface com.hazelcast.cardinality.CardinalityEstimator
Add a new object in the estimation set.
addAsync(E, OverflowPolicy) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Asynchronously writes an item with a configurable OverflowPolicy.
addAtomicLongConfig(AtomicLongConfig) - Method in class com.hazelcast.config.Config
Adds the AtomicLong configuration.
addAtomicReferenceConfig(AtomicReferenceConfig) - Method in class com.hazelcast.config.Config
Adds the AtomicReference configuration.
addAwait(Data, String, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
AddBackupOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
AddBackupOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AddBackupOperation
 
AddBackupOperation(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AddBackupOperation
 
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 class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
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.
addCachePartitionLostListenerConfig(CachePartitionLostListenerConfig) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
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(Class...) - Method in class com.hazelcast.jet.config.JobConfig
Adds the supplied classes to the list of resources that will be available on the job's classpath while it's executing in the Jet cluster.
addClassDefinition(ClassDefinition) - Method in class com.hazelcast.config.SerializationConfig
 
addClasses(String...) - Method in class com.hazelcast.config.ClassFilter
 
addClassTag(Class<? extends Object>, Tag) - Method in class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter
Define a tag for the Class to serialize.
addClientListener(ClientListener) - Method in interface com.hazelcast.core.ClientService
Adds a ClientListener.
addClientLoginModuleConfig(LoginModuleConfig) - Method in class com.hazelcast.config.SecurityConfig
 
addClientPermissionConfig(PermissionConfig) - Method in class com.hazelcast.config.SecurityConfig
 
addComponents(List<String>, Map<String, String>, String) - Method in class com.hazelcast.aws.security.EC2RequestSigner
 
addConnectionListener(ConnectionListener) - Method in interface com.hazelcast.nio.ConnectionListenable
Registers a ConnectionListener.
addConnectionListener(ConnectionListener) - Method in class com.hazelcast.nio.DefaultAggregateEndpointManager
 
addConnectionListener(ConnectionListener) - Method in class com.hazelcast.nio.tcp.TcpIpEndpointManager
 
addConnectionListener(ConnectionListener) - Method in class com.hazelcast.nio.UnifiedAggregateEndpointManager
 
addCountDownLatchConfig(CountDownLatchConfig) - Method in class com.hazelcast.config.Config
Adds the CountDownLatch configuration.
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
 
addDiscoveryStrategyConfig(DiscoveryStrategyConfig) - Method in class com.hazelcast.config.DiscoveryConfig
Adds an enabled DiscoveryStrategy configuration.
addDiscoveryStrategyConfig(DiscoveryStrategyConfig) - Method in class com.hazelcast.config.DiscoveryConfigReadOnly
Deprecated.
 
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.
addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
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.core.IMap
Adds a MapListener for this map.
addEntryListener(EntryListener, boolean) - Method in interface com.hazelcast.core.IMap
Deprecated.
addEntryListener(MapListener, K, boolean) - Method in interface com.hazelcast.core.IMap
Adds a MapListener for this map.
addEntryListener(EntryListener, K, boolean) - Method in interface com.hazelcast.core.IMap
addEntryListener(MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
Adds a MapListener for this map.
addEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
addEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
Adds a MapListener for this map.
addEntryListener(EntryListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
addEntryListener(EntryListener<K, V>, boolean) - Method in interface com.hazelcast.core.MultiMap
Adds an entry listener for this multimap.
addEntryListener(EntryListener<K, V>, K, boolean) - Method in interface com.hazelcast.core.MultiMap
Adds the specified entry listener for the specified key.
addEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.core.ReplicatedMap
Adds an entry listener for this map.
addEntryListener(EntryListener<K, V>, K) - Method in interface com.hazelcast.core.ReplicatedMap
Adds the specified entry listener for the specified key.
addEntryListener(EntryListener<K, V>, Predicate<K, V>) - Method in interface com.hazelcast.core.ReplicatedMap
Adds an continuous entry listener for this map.
addEntryListener(EntryListener<K, V>, Predicate<K, V>, K) - Method in interface com.hazelcast.core.ReplicatedMap
Adds an continuous entry listener for this map.
addEntryListener(MapListener, boolean) - Method in interface com.hazelcast.map.QueryCache
 
addEntryListener(MapListener, K, boolean) - Method in interface com.hazelcast.map.QueryCache
 
addEntryListener(MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.map.QueryCache
 
addEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.map.QueryCache
 
addEntryListenerConfig(CacheSimpleEntryListenerConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
addEntryListenerConfig(CacheSimpleEntryListenerConfig) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MapConfig
 
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
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.MultiMapConfigReadOnly
Deprecated.
 
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.QueryCacheConfig
Adds EntryListenerConfig to this QueryCacheConfig.
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.ReplicatedMapConfig
 
addEventJournalConfig(EventJournalConfig) - Method in class com.hazelcast.config.Config
Adds the event journal configuration.
addExecutorConfig(ExecutorConfig) - Method in class com.hazelcast.config.Config
Adds the executor configuration.
addField(FieldDefinitionImpl) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addFilter(String) - Method in class com.hazelcast.config.WanReplicationRef
Adds the class name implementing the CacheWanEventFilter or MapWanEventFilter for filtering outbound WAN replication events.
addFilter(String) - Method in class com.hazelcast.config.WanReplicationRefReadOnly
Deprecated.
 
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
 
addImplicitResolver(Tag, Pattern, String) - Method in class com.hazelcast.org.snakeyaml.engine.v1.resolver.JsonScalarResolver
 
addImplicitResolvers() - Method in class com.hazelcast.org.snakeyaml.engine.v1.resolver.JsonScalarResolver
 
addIndex(String, boolean) - Method in interface com.hazelcast.core.IMap
Adds an index to this map for the specified entries so that queries can run faster.
addIndex(String, boolean) - Method in interface com.hazelcast.map.QueryCache
 
addIndexConfig(MapIndexConfig) - Method in class com.hazelcast.config.QueryCacheConfig
 
addIntArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addInterceptor(MapInterceptor) - Method in interface com.hazelcast.core.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.core.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.ListConfigReadOnly
Deprecated.
 
addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.QueueConfig
Add an item listener configuration to this queue.
addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.QueueConfigReadOnly
Deprecated.
 
addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.SetConfigReadOnly
Deprecated.
 
addJar(URL) - Method in class com.hazelcast.jet.config.JobConfig
Adds the JAR identified by the supplied URL to the list of JARs that will be a part of the job's classpath while it's executing in the Jet cluster.
addJar(File) - Method in class com.hazelcast.jet.config.JobConfig
Adds the supplied JAR file to the list of JARs that will be a part of the job's classpath while it's executing in the Jet cluster.
addJar(String) - Method in class com.hazelcast.jet.config.JobConfig
Adds the JAR identified by the supplied pathname to the list of JARs that will be a part of the job's classpath while it's executing in the Jet cluster.
addJobTrackerConfig(JobTrackerConfig) - Method in class com.hazelcast.config.Config
Adds the JobTracker configuration.
addLifecycleListener(LifecycleListener) - Method in interface com.hazelcast.core.LifecycleService
Add a listener object to listen for lifecycle events.
addLifecycleListener(LifecycleListener) - Method in class com.hazelcast.instance.LifecycleServiceImpl
 
addLifecycleListener(LifecycleListener) - Method in class com.hazelcast.instance.TerminatedLifecycleService
 
addListConfig(ListConfig) - Method in class com.hazelcast.config.Config
Adds the list configuration.
addListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.Config
Adds a configuration for an EventListener.
addListenerConfig(QuorumListenerConfig) - Method in class com.hazelcast.config.QuorumConfig
 
addLocalEntryListener(MapListener) - Method in interface com.hazelcast.core.IMap
Adds a MapListener for this map.
addLocalEntryListener(EntryListener) - Method in interface com.hazelcast.core.IMap
Deprecated.
addLocalEntryListener(MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
Adds a MapListener for this map.
addLocalEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
addLocalEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
Adds a local entry listener for this map.
addLocalEntryListener(EntryListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
addLocalEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.core.MultiMap
Adds a local entry listener for this multimap.
addLocalPartitionLostListener(PartitionLostListener) - Method in interface com.hazelcast.spi.partition.IPartitionService
 
addLockConfig(LockConfig) - Method in class com.hazelcast.config.Config
Adds the lock configuration.
addLockConfig(FencedLockConfig) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Adds the FencedLock configuration.
addLogListener(Level, LogListener) - Method in interface com.hazelcast.logging.LoggingService
 
addLogListener(Level, LogListener) - Method in class com.hazelcast.logging.LoggingServiceImpl
 
addLongArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addLongField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addMapAttributeConfig(MapAttributeConfig) - Method in class com.hazelcast.config.MapConfig
 
addMapConfig(MapConfig) - Method in class com.hazelcast.config.Config
Adds the map configuration.
addMapIndexConfig(MapIndexConfig) - Method in class com.hazelcast.config.MapConfig
 
addMapIndexConfig(MapIndexConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
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 class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
addMember(Member) - Method in interface com.hazelcast.partition.membergroup.MemberGroup
 
addMember(Member) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
addMemberGroupConfig(MemberGroupConfig) - Method in class com.hazelcast.config.PartitionGroupConfig
addMemberLoginModuleConfig(LoginModuleConfig) - Method in class com.hazelcast.config.SecurityConfig
 
addMembers(Collection<Member>) - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
addMembers(Collection<Member>) - Method in interface com.hazelcast.partition.membergroup.MemberGroup
 
addMembers(Collection<Member>) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
addMembershipListener(MembershipListener) - Method in interface com.hazelcast.core.Cluster
Adds MembershipListener to listen for membership updates.
addMerkleTreeConfig(MerkleTreeConfig) - Method in class com.hazelcast.config.Config
Adds the merkle tree configuration.
addMessageListener(MessageListener<E>) - Method in interface com.hazelcast.core.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).
addMessageListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.TopicConfigReadOnly
Deprecated.
 
addMigrationListener(MigrationListener) - Method in interface com.hazelcast.core.PartitionService
Adds a MigrationListener.
addMigrationListener(MigrationListener) - Method in interface com.hazelcast.spi.partition.IPartitionService
 
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
 
addObject(T) - Method in class com.hazelcast.query.extractor.ValueCollector
Collects a value passed as an argument
AddOperation - Class in com.hazelcast.crdt.pncounter.operations
Addition/subtraction operation for a PNCounter.
AddOperation(String, long, boolean, VectorClock) - Constructor for class com.hazelcast.crdt.pncounter.operations.AddOperation
Creates the addition operation.
AddOperation() - Constructor for class com.hazelcast.crdt.pncounter.operations.AddOperation
 
addOpToCancel(Address, long) - Method in class com.hazelcast.spi.CallsPerMember
 
addOrVote(T) - Method in class com.hazelcast.util.collection.WeightedEvictableList
Adds a new item to the list or votes for the given item if it already exists.
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.config.AdvancedNetworkConfig.MemberNetworkingView
 
addOutboundPortDefinition(String) - Method in class com.hazelcast.config.EndpointConfig
 
addOutboundPortDefinition(String) - Method in class com.hazelcast.config.NetworkConfig
 
addOutboundPortDefinition(String) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
addPackages(String...) - Method in class com.hazelcast.config.ClassFilter
 
addParam(String, String) - Method in class com.hazelcast.util.PhoneHome.PhoneHomeParameterCreator
 
addPartitionLostListener(CachePartitionLostListener) - Method in interface com.hazelcast.cache.ICache
Adds a CachePartitionLostListener.
addPartitionLostListener(MapPartitionLostListener) - Method in interface com.hazelcast.core.IMap
Adds a MapPartitionLostListener.
addPartitionLostListener(PartitionLostListener) - Method in interface com.hazelcast.core.PartitionService
Adds a PartitionLostListener.
addPartitionLostListener(PartitionLostListener) - Method in interface com.hazelcast.spi.partition.IPartitionService
 
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
 
addProxyListener(DistributedObjectListener) - Method in interface com.hazelcast.spi.ProxyService
 
addQueryCacheConfig(QueryCacheConfig) - Method in class com.hazelcast.config.MapConfig
Adds a new QueryCacheConfig to this MapConfig.
addQueueConfig(QueueConfig) - Method in class com.hazelcast.config.Config
Adds the queue configuration.
addQuorumConfig(QuorumConfig) - Method in class com.hazelcast.config.Config
Adds the split-brain protection configuration.
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.
addResource(URL) - Method in class com.hazelcast.jet.config.JobConfig
Adds the resource identified by the supplied URL to the list of resources that will be on the job's classpath while it's executing in the Jet cluster.
addResource(URL, String) - Method in class com.hazelcast.jet.config.JobConfig
Adds the resource identified by the supplied URL to the list of resources that will be on the job's classpath while it's executing in the Jet cluster.
addResource(File) - Method in class com.hazelcast.jet.config.JobConfig
Adds the supplied file to the list of resources that will be on the job's classpath while it's executing in the Jet cluster.
addResource(File, String) - Method in class com.hazelcast.jet.config.JobConfig
Adds the supplied file to the list of resources that will be on the job's classpath while it's executing in the Jet cluster.
addResource(String) - Method in class com.hazelcast.jet.config.JobConfig
Adds the resource identified by the supplied pathname to the list of resources that will be on the job's classpath while it's executing in the Jet cluster.
addResource(String, String) - Method in class com.hazelcast.jet.config.JobConfig
Adds the resource identified by the supplied pathname to the list of resources that will be on the job's classpath while it's executing in the Jet cluster.
address - Variable in class com.hazelcast.instance.AbstractMember
 
address - Variable in class com.hazelcast.instance.Node
Member-to-member address only.
ADDRESS - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
Network address of the cluster member sourcing the metric.
Address - Class in com.hazelcast.nio
Represents an address of a member in the cluster.
Address() - Constructor for class com.hazelcast.nio.Address
 
Address(String, int) - Constructor for class com.hazelcast.nio.Address
 
Address(InetAddress, int) - Constructor for class com.hazelcast.nio.Address
 
Address(InetSocketAddress) - Constructor for class com.hazelcast.nio.Address
Creates a new Address
Address(String, InetAddress, int) - Constructor for class com.hazelcast.nio.Address
 
Address(Address) - Constructor for class com.hazelcast.nio.Address
 
address - Variable in class com.hazelcast.util.AddressUtil.AddressMatcher
 
addresses() - Method in class com.hazelcast.spi.CallsPerMember
 
AddressHolder(String, int, String) - Constructor for class com.hazelcast.util.AddressUtil.AddressHolder
 
addressMap - Variable in class com.hazelcast.instance.AbstractMember
 
AddressMatcher(String[]) - Constructor for class com.hazelcast.util.AddressUtil.AddressMatcher
 
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.
AddressUtil - Class in com.hazelcast.util
AddressUtil contains Address helper methods.
AddressUtil.AddressHolder - Class in com.hazelcast.util
Holds address
AddressUtil.AddressMatcher - Class in com.hazelcast.util
http://docs.oracle.com/javase/1.5.0/docs/guide/net/ipv6_guide/index.html
AddressUtil.InvalidAddressException - Exception in com.hazelcast.util
Thrown when given address is not valid.
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.Config
Adds the ISemaphore configuration.
addSemaphoreConfig(CPSemaphoreConfig) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Adds the CP ISemaphore configuration.
addSerializerConfig(SerializerConfig) - Method in class com.hazelcast.config.SerializationConfig
 
addServiceConfig(ServiceConfig) - Method in class com.hazelcast.config.ServicesConfig
 
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
 
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.
addTopicConfig(TopicConfig) - Method in class com.hazelcast.config.Config
Adds the topic configuration.
addToValueList(Map<K, List<V>>, K, V) - Static method in class com.hazelcast.util.CollectionUtil
Adds a value to a list of values in the map.
addTrustedInterface(String) - Method in class com.hazelcast.config.MulticastConfig
Adds a trusted interface.
addUTFArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addUTFField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
AddWanConfigResult - Class in com.hazelcast.wan
The result of adding WAN configuration.
AddWanConfigResult(Collection<String>, Collection<String>) - Constructor for class com.hazelcast.wan.AddWanConfigResult
 
addWanEndpointConfig(EndpointConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
Adds the given WAN EndpointConfig to the endpoints configuration.
addWanPublisherConfig(WanPublisherConfig) - Method in class com.hazelcast.config.WanReplicationConfig
Adds a WAN publisher configuration to this WAN replication.
addWanReplicationConfig(WanReplicationConfig) - Method in class com.hazelcast.config.Config
Adds the WAN replication config under the name defined by WanReplicationConfig.getName().
addWanReplicationConfig(WanReplicationConfig) - Method in interface com.hazelcast.wan.WanReplicationService
Adds a new WanReplicationConfig to the cluster.
addWanReplicationConfigLocally(WanReplicationConfig) - Method in interface com.hazelcast.wan.WanReplicationService
Adds a new WanReplicationConfig to this member and creates the WanReplicationPublishers specified in the config.
advance() - Method in class com.hazelcast.util.collection.Long2LongHashMap.LongLongCursor
 
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
 
afterClusterStateChange(ClusterState, ClusterState, boolean) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
afterClusterStateChange(ClusterState, ClusterState, boolean) - Method in interface com.hazelcast.instance.NodeExtension
Called after the cluster state change transaction has completed (successfully or otherwise).
afterExecute(Runnable, Throwable) - Method in class com.hazelcast.util.executor.LoggingScheduledExecutor
 
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.
afterRun() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
 
afterRun() - Method in class com.hazelcast.crdt.AbstractCRDTReplicationOperation
 
afterRun() - Method in class com.hazelcast.spi.Operation
Is executed called after Operation.run() or Operation.call() method completes normally and the operation is not blocked, see CallStatus.WAIT.
afterRun() - Method in class com.hazelcast.util.executor.HazelcastManagedThread
Called after inner run method and can be overridden to customize.
afterRun() - Method in class com.hazelcast.util.executor.PoolExecutorThreadFactory.ManagedThread
 
afterStart() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
afterStart() - Method in interface com.hazelcast.instance.NodeExtension
Called after node is started
aggregate() - Method in class com.hazelcast.aggregation.Aggregator
Returns the result of the aggregation.
aggregate(Aggregator<Map.Entry<K, V>, R>) - Method in interface com.hazelcast.core.IMap
Applies the aggregation logic on all map entries and returns the result
aggregate(Aggregator<Map.Entry<K, V>, R>, Predicate<K, V>) - Method in interface com.hazelcast.core.IMap
Applies the aggregation logic on map entries filtered with the Predicated and returns the result
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in interface com.hazelcast.core.IMap
Deprecated.
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in interface com.hazelcast.core.IMap
Deprecated.
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in interface com.hazelcast.core.MultiMap
Deprecated.
The old Aggregations API is superseded by Fast Aggregations (com.hazelcast.aggregation) which does not yet support MultiMap. Hazelcast Jet can be used in the future to replace this functionality.
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in interface com.hazelcast.core.MultiMap
Deprecated.
The old Aggregations API is superseded by Fast Aggregations (com.hazelcast.aggregation) which does not yet support MultiMap. Hazelcast Jet can be used in the future to replace this functionality.
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.
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 emitting a 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 emitting a 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.
AggregateEndpointManager - Interface in com.hazelcast.nio
 
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
Convenience for aggregateOperation2(aggrOp0, aggrOp1, finishFn) that outputs a Tuple2(result0, result1).
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
Convenience for aggregateOperation3(aggrOp0, aggrOp1, aggrOp2, finishFn) that outputs a Tuple3(result0, result1, result2).
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<Key,Supplied,Result> - Interface in com.hazelcast.mapreduce.aggregation
Deprecated.
AGGREGATION_ACCUMULATION_PARALLEL_EVALUATION - Static variable in class com.hazelcast.spi.properties.GroupProperty
Run aggregation accumulation for multiple entries in parallel.
Aggregations - Class in com.hazelcast.mapreduce.aggregation
Deprecated.
Use fast-aggregations Aggregators
Aggregator<I,R> - Class in com.hazelcast.aggregation
Base class for all aggregators.
Aggregator() - Constructor for class com.hazelcast.aggregation.Aggregator
 
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
 
aliasedDiscoveryConfigsFrom(JoinConfig) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Gets a list of all aliased discovery configs from config.
aliasedDiscoveryConfigsFrom(WanPublisherConfig) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Gets a list of all aliased discovery configs from config.
AliasedDiscoveryConfigUtils - Class in com.hazelcast.config
Utility class for Aliased Discovery Configs.
AliasEvent - Class in com.hazelcast.org.snakeyaml.engine.v1.events
Marks the inclusion of a previously anchored node.
AliasEvent(Optional<Anchor>, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.events.AliasEvent
 
AliasEvent(Optional<Anchor>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.events.AliasEvent
 
AliasToken - Class in com.hazelcast.org.snakeyaml.engine.v1.tokens
 
AliasToken(Anchor, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.tokens.AliasToken
 
all() - Static method in class com.hazelcast.mapreduce.aggregation.Supplier
Deprecated.
The predefined Supplier selects all values and does not perform any kind of data transformation.
all(PropertyExtractor<ValueIn, ValueOut>) - Static method in class com.hazelcast.mapreduce.aggregation.Supplier
Deprecated.
The predefined Supplier selects all values and performs the given PropertyExtractors transformation to the input data.
allDone(Collection<Future>) - Static method in class com.hazelcast.util.FutureUtil
Check if all futures are done
allocBase64Buffer() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
 
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
Note: the method can only be called once during its life cycle.
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
 
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.
allowBlock - Variable in class com.hazelcast.org.snakeyaml.engine.v1.emitter.ScalarAnalysis
 
allowBlockPlain - Variable in class com.hazelcast.org.snakeyaml.engine.v1.emitter.ScalarAnalysis
 
allowFlowPlain - Variable in class com.hazelcast.org.snakeyaml.engine.v1.emitter.ScalarAnalysis
 
AllowingTextProtocolFilter - Class in com.hazelcast.nio.ascii
This class is an all allowing implementation of TextProtocolFilter.
AllowingTextProtocolFilter() - Constructor for class com.hazelcast.nio.ascii.AllowingTextProtocolFilter
 
allowSingleQuoted - Variable in class com.hazelcast.org.snakeyaml.engine.v1.emitter.ScalarAnalysis
 
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
 
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.
allUsePublicAddress(List<AliasedDiscoveryConfig<?>>) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Checks whether all aliased discovery configs have the tag <use-public-ip>true</use-public-ip.
ALPHA - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.common.CharConstants
 
ALTER - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
alter(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
ALTER - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
alter(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
alter(IFunction<Long, Long>) - Method in interface com.hazelcast.core.IAtomicLong
Alters the currently stored value by applying a function on it.
alter(IFunction<E, E>) - Method in interface com.hazelcast.core.IAtomicReference
Alters the currently stored reference by applying a function on it.
ALTER_AND_GET - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
ALTER_AND_GET - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
alterAndGet(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
alterAndGet(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
alterAndGet(IFunction<Long, Long>) - Method in interface com.hazelcast.core.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.core.IAtomicReference
Alters the currently stored reference by applying a function on it and gets the result.
alterAndGetAsync(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
alterAndGetAsync(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
alterAndGetAsync(IFunction<Long, Long>) - Method in interface com.hazelcast.core.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.core.IAtomicReference
Alters the currently stored reference by applying a function on it and gets the result.
AlterAndGetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
AlterAndGetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AlterAndGetOperation
 
AlterAndGetOperation(String, IFunction<Long, Long>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AlterAndGetOperation
 
AlterAndGetOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
AlterAndGetOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AlterAndGetOperation
 
AlterAndGetOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AlterAndGetOperation
 
alterAsync(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
alterAsync(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
alterAsync(IFunction<Long, Long>) - Method in interface com.hazelcast.core.IAtomicLong
Alters the currently stored value by applying a function on it.
alterAsync(IFunction<E, E>) - Method in interface com.hazelcast.core.IAtomicReference
Alters the currently stored reference by applying a function on it.
AlterOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
AlterOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AlterOperation
 
AlterOperation(String, IFunction<Long, Long>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AlterOperation
 
AlterOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
AlterOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AlterOperation
 
AlterOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AlterOperation
 
alwaysFalse() - Static method in interface com.hazelcast.jet.function.PredicateEx
Returns a predicate that always evaluates to false.
alwaysFalse() - Static method in class com.hazelcast.jet.pipeline.GenericPredicates
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.jet.function.PredicateEx
Returns a predicate that always evaluates to true.
alwaysTrue() - Static method in class com.hazelcast.jet.pipeline.GenericPredicates
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.v1.common
Value inside Anchor and Alias
Anchor(String) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.common.Anchor
 
ANCHOR_FORMAT - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.common.CharConstants
 
AnchorGenerator - Interface in com.hazelcast.org.snakeyaml.engine.v1.serializer
 
AnchorNode - Class in com.hazelcast.org.snakeyaml.engine.v1.nodes
 
AnchorNode(Node) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.nodes.AnchorNode
 
AnchorToken - Class in com.hazelcast.org.snakeyaml.engine.v1.tokens
 
AnchorToken(Anchor, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.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.jet.function.BiPredicateEx
and(PredicateEx<? super T>) - Method in interface com.hazelcast.jet.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<K, V>...) - Static method in class com.hazelcast.jet.pipeline.GenericPredicates
and(Predicate) - Method in class com.hazelcast.query.PredicateBuilder
 
and(Predicate...) - Static method in class com.hazelcast.query.Predicates
Creates an and predicate that will perform the logical and operation on the given predicates.
andAccumulate(BiConsumerEx<? super A, ? super T>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder
Registers the supplied accumulate primitive.
andAccumulate(Tag<T>, BiConsumerEx<? super A, ? super T>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder
Registers the supplied 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 supplied accumulate primitive for the stream tagged with the supplied tag.
andAccumulate0(BiConsumerEx<? super A, ? super T0>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder
Registers the supplied accumulate primitive for stream-0.
andAccumulate1(BiConsumerEx<? super A, ? super T1>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity1
Registers the supplied accumulate primitive for stream-1, returning the arity-2 variant of the builder.
andAccumulate2(BiConsumerEx<? super A, ? super T2>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity2
Registers the supplied accumulate primitive for stream-2, returning the arity-3 variant of the builder.
andCombine(BiConsumerEx<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity1
Registers the combine primitive.
andCombine(BiConsumerEx<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity2
Registers the combine primitive.
andCombine(BiConsumerEx<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity3
Registers the combine primitive.
andCombine(BiConsumerEx<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.VarArity
Registers the combine primitive.
andDeduct(BiConsumerEx<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity1
Registers the deduct primitive.
andDeduct(BiConsumerEx<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity2
Registers the deduct primitive.
andDeduct(BiConsumerEx<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity3
Registers the deduct primitive.
andDeduct(BiConsumerEx<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.VarArity
Registers the deduct primitive.
andExport(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity1
Registers the export primitive.
andExport(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity2
Registers the export primitive.
andExport(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity3
Registers the export primitive.
andExport(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.VarArity
Registers the export primitive.
andExportFinish(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity1
Registers the supplied function as both the export and finish primitive.
andExportFinish(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity2
Registers the supplied function as both the export and finish primitive.
andExportFinish(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity3
Registers the supplied function as both the export and finish primitive.
andExportFinish(FunctionEx<? super A, ? extends R_NEW>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.VarArity
Registers the supplied function as both the export and finish primitive.
andFinish(FunctionEx<? super A, ? extends R>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity1
Registers the supplied function as the finish primitive.
andFinish(FunctionEx<? super A, ? extends R>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity2
Registers the supplied function as the finish primitive.
andFinish(FunctionEx<? super A, ? extends R>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity3
Registers the supplied function as the finish primitive.
andFinish(FunctionEx<? super A, ? extends R>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.VarArity
Registers the supplied function as the finish primitive.
andThen(ExecutionCallback<V>) - Method in interface com.hazelcast.core.ICompletableFuture
Registers a callback that will run after this future is completed.
andThen(ExecutionCallback<V>, Executor) - Method in interface com.hazelcast.core.ICompletableFuture
Registers a callback that will run with the provided executor after this future is completed.
andThen(FunctionEx<? super R, ? extends R_NEW>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
Returns a copy of this aggregate operation, but with the export and finish primitives composed with the supplied thenFn.
andThen(FunctionEx<? super R, ? extends R_NEW>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation1
 
andThen(FunctionEx<? super R, ? extends R_NEW>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation2
 
andThen(FunctionEx<? super R, ? extends R_NEW>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation3
 
andThen(BiConsumerEx<? super T, ? super U>) - Method in interface com.hazelcast.jet.function.BiConsumerEx
andThen(FunctionEx<? super R, ? extends V>) - Method in interface com.hazelcast.jet.function.BiFunctionEx
andThen(ConsumerEx<? super T>) - Method in interface com.hazelcast.jet.function.ConsumerEx
andThen(FunctionEx<? super R, ? extends V>) - Method in interface com.hazelcast.jet.function.FunctionEx
andThen(ExecutionCallback<V>) - Method in class com.hazelcast.util.executor.CompletedFuture
 
andThen(ExecutionCallback<V>, Executor) - Method in class com.hazelcast.util.executor.CompletedFuture
 
andThen(ExecutionCallback<V>) - Method in class com.hazelcast.util.executor.DelegatingFuture
 
andThen(ExecutionCallback<V>, Executor) - Method in class com.hazelcast.util.executor.DelegatingFuture
 
ANY_THREAD - Static variable in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
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(boolean) - Method in class com.hazelcast.jet.pipeline.FileSinkBuilder
Sets whether to append (true) or overwrite (false) an existing file.
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.
append(T[], T[]) - Static method in class com.hazelcast.util.collection.ArrayUtils
Appends 2 arrays.
AppendableTraverser<T> - Class in com.hazelcast.jet.core
A traverser with an internal ArrayDeque.
AppendableTraverser(int) - Constructor for class com.hazelcast.jet.core.AppendableTraverser
Creates an appendable traverser.
appendChild(Node) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
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.
APPLICATION_VALIDATION_TOKEN - Static variable in class com.hazelcast.spi.properties.GroupProperty
Use this property to verify that Hazelcast nodes only join the cluster when their 'application' level configuration is the same.
APPLY - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
apply(IFunction<Long, R>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
APPLY - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
apply(IFunction<E, R>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
apply(IFunction<Long, R>) - Method in interface com.hazelcast.core.IAtomicLong
Applies a function on the value, the actual stored value will not change.
apply(IFunction<E, R>) - Method in interface com.hazelcast.core.IAtomicReference
Applies a function on the value, the actual stored value will not change.
apply(T, U) - Method in interface com.hazelcast.core.IBiFunction
Applies this function to the given arguments.
apply(T) - Method in interface com.hazelcast.core.IFunction
 
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(T, U) - Method in interface com.hazelcast.jet.function.BiFunctionEx
 
apply(T, T) - Method in interface com.hazelcast.jet.function.BinaryOperatorEx
 
apply(T) - Method in interface com.hazelcast.jet.function.FunctionEx
 
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(Map.Entry<KeyIn, ValueIn>) - Method in class com.hazelcast.mapreduce.aggregation.Supplier
Deprecated.
The apply method is used to apply the actual filtering or extraction / transformation to the input entry.
If the input value should be ignored by the aggregation, the Supplier has to return
apply(Map.Entry) - Method in class com.hazelcast.query.PagingPredicate
Used for delegating filtering to inner predicate.
apply(Map.Entry<K, V>) - Method in class com.hazelcast.query.PartitionPredicate
 
apply(Map.Entry<K, V>) - Method in interface com.hazelcast.query.Predicate
Applies this predicate to the given map entry.
apply(Map.Entry) - Method in class com.hazelcast.query.PredicateBuilder
 
apply(Map.Entry) - Method in class com.hazelcast.query.SqlPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.TruePredicate
 
apply(Collection<Member>) - Method in interface com.hazelcast.quorum.QuorumFunction
Determines if quorum is present based on the current list of members in the cluster.
apply(T) - Method in interface com.hazelcast.util.function.Function
 
apply(int) - Method in interface com.hazelcast.util.function.IntFunction
Applies this function to the given argument.
apply(long) - Method in interface com.hazelcast.util.function.LongFunction
Applies this function to the given argument.
APPLY_FN_ENTRY_PROCESSOR - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
Serialization ID of the UpdateMapP.ApplyFnEntryProcessor class.
applyAsDouble(T) - Method in interface com.hazelcast.jet.function.ToDoubleFunctionEx
 
applyAsDoubleEx(T) - Method in interface com.hazelcast.jet.function.ToDoubleFunctionEx
Exception-declaring version of ToDoubleFunction.applyAsDouble(T).
applyAsInt(T) - Method in interface com.hazelcast.jet.function.ToIntFunctionEx
 
applyAsIntEx(T) - Method in interface com.hazelcast.jet.function.ToIntFunctionEx
Exception-declaring version of ToIntFunction.applyAsInt(T).
applyAsLong(T) - Method in interface com.hazelcast.jet.function.ToLongFunctionEx
 
applyAsLongEx(T) - Method in interface com.hazelcast.jet.function.ToLongFunctionEx
Exception-declaring version of ToLongFunction.applyAsLong(T).
applyAsync(IFunction<Long, R>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
applyAsync(IFunction<E, R>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
applyAsync(IFunction<Long, R>) - Method in interface com.hazelcast.core.IAtomicLong
Applies a function on the value, the actual stored value will not change.
applyAsync(IFunction<E, R>) - Method in interface com.hazelcast.core.IAtomicReference
Applies a function on the value, the actual stored value will not change.
applyEx(T, long) - Method in interface com.hazelcast.jet.core.function.ObjLongBiFunction
Exception-declaring version of ObjLongBiFunction.apply(T, long).
applyEx(T, U) - Method in interface com.hazelcast.jet.function.BiFunctionEx
Exception-declaring version of BiFunction.apply(T, U).
applyEx(T, T) - Method in interface com.hazelcast.jet.function.BinaryOperatorEx
Exception-declaring version of BiFunction.apply(T, U).
applyEx(T) - Method in interface com.hazelcast.jet.function.FunctionEx
Exception-declaring version of Function.apply(T).
applyEx(T0, T1, T2, T3) - Method in interface com.hazelcast.jet.function.QuadFunction
Exception-declaring variant of QuadFunction.apply(T0, T1, T2, T3).
applyEx(T0, T1, T2) - Method in interface com.hazelcast.jet.function.TriFunction
Exception-declaring variant of TriFunction.apply(T0, T1, T2).
applyIfAbsent(K, IFunction<? super K, ? extends V>) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
applyIfAbsent(K, IFunction<? super K, ? extends V>) - Method in interface com.hazelcast.util.IConcurrentMap
applyIfPresent(K, IBiFunction<? super K, ? super V, ? extends V>) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
 
applyIfPresent(K, IBiFunction<? super K, ? super V, ? extends V>) - Method in interface com.hazelcast.util.IConcurrentMap
ApplyOperation<R> - Class in com.hazelcast.concurrent.atomiclong.operations
 
ApplyOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.ApplyOperation
 
ApplyOperation(String, IFunction<Long, R>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.ApplyOperation
 
ApplyOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
ApplyOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
 
ApplyOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
 
ArgumentParser<I,O> - Class in com.hazelcast.query.extractor
Common superclass for all argument parsers.
ArgumentParser() - Constructor for class com.hazelcast.query.extractor.ArgumentParser
 
arity() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
Returns the number of contributing streams this operation is set up to handle.
ArrayMerkleTree - Class in com.hazelcast.wan.merkletree
A not thread-safe, array based MerkleTree implementation, which represents each node of the tree as a single int containing the node's hash.
ArrayMerkleTree(int) - Constructor for class com.hazelcast.wan.merkletree.ArrayMerkleTree
 
ArrayStack<T> - Class in com.hazelcast.org.snakeyaml.engine.v1.common
General stack implementation.
ArrayStack(int) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.common.ArrayStack
Create empty stack
ArrayUtils - Class in com.hazelcast.util.collection
Convenient method for array manipulations.
asByteArray() - Method in enum com.hazelcast.com.fasterxml.jackson.core.JsonToken
 
asCharArray() - Method in enum com.hazelcast.com.fasterxml.jackson.core.JsonToken
 
asCompletableFuture(Future<V>) - Method in interface com.hazelcast.spi.ExecutionService
 
asElementIterable(NodeList) - Static method in class com.hazelcast.config.DomConfigHelper
 
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
 
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 as is (without JSON quoting) encoded using UTF-8 encoding.
asQuotedUTF8() - Method in interface com.hazelcast.com.fasterxml.jackson.core.SerializableString
Returns UTF-8 encoded version of JSON-quoted String.
asReadOnly() - Method in class com.hazelcast.config.MemberAttributeConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
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
Asserts that the two given objects are equal, when compared using Object.equals(Object).
assertFalse(String, boolean) - Static method in class com.hazelcast.jet.core.test.JetAssert
Asserts that the given condition is false.
AssertionCompletedException - Exception in com.hazelcast.jet.pipeline.test
An exception which indicates that an assertion passed successfully.
AssertionCompletedException() - Constructor for exception com.hazelcast.jet.pipeline.test.AssertionCompletedException
Creates the exception
AssertionCompletedException(String) - Constructor for exception com.hazelcast.jet.pipeline.test.AssertionCompletedException
Creates the exception with the given message
AssertionCompletedException(String, Throwable) - Constructor for exception com.hazelcast.jet.pipeline.test.AssertionCompletedException
Creates the exception with the given message and cause
Assertions - Class in com.hazelcast.jet.pipeline.test
Various assertions which can be used to assert items passing through the pipeline for correctness.
assertionSink(String, SupplierEx<? extends S>) - Static method in class com.hazelcast.jet.pipeline.test.AssertionSinkBuilder
Returns a builder object that offers a step-by-step fluent API to build an assertion Sink for the Pipeline API.
AssertionSinkBuilder<S,T> - Class in com.hazelcast.jet.pipeline.test
AssertionSinks - Class in com.hazelcast.jet.pipeline.test
Various assertions which can be used to assert items on the output of a pipeline.
assertOrdered(String, Collection<? extends T>) - Static method in class com.hazelcast.jet.pipeline.test.Assertions
Asserts that the previous stage emitted the exact sequence of expected items and nothing else.
assertOrdered(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.
assertRunningOnPartitionThread() - Static method in class com.hazelcast.util.ThreadUtil
 
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 that has been quoted using JSON quoting rules, and encoded using UTF-8 encoding.
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
 
asW3cNode(YamlNode) - Static method in class com.hazelcast.config.yaml.W3cDomUtil
Returns an adapted W3C Node view of the provided YamlNode
ASYNC_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
Name of the async executor.
asyncAddAndGet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncAddAndGet(long) - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Atomically adds the given value to the current value.
asyncAlter(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncAlter(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncAlter(IFunction<Long, Long>) - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Alters the currently stored value by applying a function on it.
asyncAlter(IFunction<E, E>) - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Alters the currently stored reference by applying a function on it.
asyncAlterAndGet(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncAlterAndGet(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncAlterAndGet(IFunction<Long, Long>) - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Alters the currently stored value by applying a function on it and gets the result.
asyncAlterAndGet(IFunction<E, E>) - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Alters the currently stored reference by applying a function on it and gets the result.
asyncApply(IFunction<Long, R>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncApply(IFunction<E, R>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncApply(IFunction<Long, R>) - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Applies a function on the value, the actual stored value will not change.
asyncApply(IFunction<E, R>) - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Applies a function on the value, the actual stored value will not change.
AsyncAtomicLong - Interface in com.hazelcast.core
Deprecated.
AsyncAtomicReference<E> - Interface in com.hazelcast.core
Deprecated.
asyncClear() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncClear() - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Clears the current stored reference.
asyncCompareAndSet(long, long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncCompareAndSet(E, E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncCompareAndSet(long, long) - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Atomically sets the value to the given updated value only if the current value == the expected value.
asyncCompareAndSet(E, E) - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Atomically sets the value to the given updated value only if the current value == the expected value.
asyncContains(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncContains(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Checks if the reference contains the value.
asyncDecrementAndGet() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncDecrementAndGet() - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Atomically decrements the current value by one.
asyncGet() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncGet() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncGet() - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Gets the current value.
asyncGet() - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Gets the current value.
asyncGetAndAdd(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncGetAndAdd(long) - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Atomically adds the given value to the current value.
asyncGetAndAlter(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncGetAndAlter(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncGetAndAlter(IFunction<Long, Long>) - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Alters the currently stored value by applying a function on it on and gets the old value.
asyncGetAndAlter(IFunction<E, E>) - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Alters the currently stored reference by applying a function on it on and gets the old value.
asyncGetAndIncrement() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncGetAndIncrement() - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Atomically increments the current value by one.
asyncGetAndSet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncGetAndSet(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncGetAndSet(long) - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Atomically sets the given value and returns the old value.
asyncGetAndSet(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Gets the value and sets the new value.
asyncIncrementAndGet() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncIncrementAndGet() - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Atomically increments the current value by one.
asyncIsNull() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncIsNull() - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Checks if the stored reference is null.
asyncSet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncSet(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncSet(long) - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Atomically sets the given value.
asyncSet(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Atomically sets the given value.
asyncSetAndGet(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncSetAndGet(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
will be removed from Hazelcast 3.4 since it doesn't really serve a purpose.
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:
ATOMIC_LONG_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
ATOMIC_LONG_NAME - Static variable in class com.hazelcast.concurrent.idgen.IdGeneratorService
 
ATOMIC_REFERENCE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
AtomicLongBackupAwareOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
AtomicLongBackupAwareOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBackupAwareOperation
 
AtomicLongBackupAwareOperation(String) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBackupAwareOperation
 
AtomicLongConfig - Class in com.hazelcast.config
Contains the configuration for an AtomicLong.
AtomicLongConfig(String) - Constructor for class com.hazelcast.config.AtomicLongConfig
 
AtomicLongConfig(AtomicLongConfig) - Constructor for class com.hazelcast.config.AtomicLongConfig
 
AtomicLongContainer - Class in com.hazelcast.concurrent.atomiclong
 
AtomicLongContainer() - Constructor for class com.hazelcast.concurrent.atomiclong.AtomicLongContainer
 
AtomicLongDataSerializerHook - Class in com.hazelcast.concurrent.atomiclong
 
AtomicLongDataSerializerHook() - Constructor for class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
AtomicLongPermission - Class in com.hazelcast.security.permission
 
AtomicLongPermission(String, String...) - Constructor for class com.hazelcast.security.permission.AtomicLongPermission
 
AtomicLongProxy - Class in com.hazelcast.concurrent.atomiclong
 
AtomicLongProxy(String, NodeEngine, AtomicLongService) - Constructor for class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
AtomicLongReplicationOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
AtomicLongReplicationOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
 
AtomicLongReplicationOperation(Map<String, Long>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
 
AtomicLongService - Class in com.hazelcast.concurrent.atomiclong
 
AtomicLongService() - Constructor for class com.hazelcast.concurrent.atomiclong.AtomicLongService
 
AtomicReferenceBackupAwareOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
AtomicReferenceBackupAwareOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBackupAwareOperation
 
AtomicReferenceBackupAwareOperation(String) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBackupAwareOperation
 
AtomicReferenceConfig - Class in com.hazelcast.config
Contains the configuration for an AtomicReference.
AtomicReferenceConfig(String) - Constructor for class com.hazelcast.config.AtomicReferenceConfig
 
AtomicReferenceConfig(AtomicReferenceConfig) - Constructor for class com.hazelcast.config.AtomicReferenceConfig
 
AtomicReferenceContainer - Class in com.hazelcast.concurrent.atomicreference
 
AtomicReferenceContainer() - Constructor for class com.hazelcast.concurrent.atomicreference.AtomicReferenceContainer
 
AtomicReferenceDataSerializerHook - Class in com.hazelcast.concurrent.atomicreference
 
AtomicReferenceDataSerializerHook() - Constructor for class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
AtomicReferencePermission - Class in com.hazelcast.security.permission
 
AtomicReferencePermission(String, String...) - Constructor for class com.hazelcast.security.permission.AtomicReferencePermission
 
AtomicReferenceProxy<E> - Class in com.hazelcast.concurrent.atomicreference
 
AtomicReferenceProxy(String, NodeEngine, AtomicReferenceService) - Constructor for class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
AtomicReferenceReplicationOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
AtomicReferenceReplicationOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
 
AtomicReferenceReplicationOperation(Map<String, Data>) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
 
AtomicReferenceService - Class in com.hazelcast.concurrent.atomicreference
 
AtomicReferenceService() - Constructor for class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
 
attributes - Variable in class com.hazelcast.instance.AbstractMember
 
attributes(Map<String, Object>) - Method in class com.hazelcast.instance.MemberImpl.Builder
 
AVAILABILITY_ZONE_URI - Static variable in class com.hazelcast.aws.utility.MetadataUtil
Post-fix URI to fetch availability-zone info.
available() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.MergedStream
 
AVAILABLE_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
AvailableOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
AvailableOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.AvailableOperation
 
AvailableOperation(String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.AvailableOperation
 
availablePermits() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
 
availablePermits() - Method in interface com.hazelcast.core.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.
AvroProcessors - Class in com.hazelcast.jet.avro
Static utility class with factories of Apache Avro source and sink processors.
AvroSinks - Class in com.hazelcast.jet.avro
Contains factory methods for Apache Avro sinks.
AvroSourceBuilder<D> - Class in com.hazelcast.jet.avro
Builder for an Avro file source which reads records from Avro files in a directory (but not its subdirectories) and emits output object created by mapOutputFn.
AvroSources - Class in com.hazelcast.jet.avro
Contains factory methods for Apache Avro sources.
await(long, TimeUnit) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
 
AWAIT - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
await(long, TimeUnit) - Method in interface com.hazelcast.core.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.
AWAIT_BACKUP - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
AWAIT_OPERATION - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
 
AwaitBackupOperation - Class in com.hazelcast.concurrent.lock.operations
 
AwaitBackupOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.AwaitBackupOperation
 
AwaitBackupOperation(ObjectNamespace, Data, long, String, String) - Constructor for class com.hazelcast.concurrent.lock.operations.AwaitBackupOperation
 
AwaitOperation - Class in com.hazelcast.concurrent.countdownlatch.operations
 
AwaitOperation() - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
 
AwaitOperation(String, long) - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
 
AwaitOperation - Class in com.hazelcast.concurrent.lock.operations
 
AwaitOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.AwaitOperation
 
AwaitOperation(ObjectNamespace, Data, long, long, String) - Constructor for class com.hazelcast.concurrent.lock.operations.AwaitOperation
 
AwaitOperation(ObjectNamespace, Data, long, long, String, long) - Constructor for class com.hazelcast.concurrent.lock.operations.AwaitOperation
 
awaitTermination(long, TimeUnit) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
 
awaitUntilDiscoveryCompleted(long, TimeUnit) - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Blocks until CP discovery process is completed, or the timeout occurs, or the current thread is interrupted, whichever happens first.
AWS_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
AWSClient - Class in com.hazelcast.aws
 
AWSClient(AwsConfig) - Constructor for class com.hazelcast.aws.AWSClient
 
AwsConfig - Class in com.hazelcast.aws
AWS Discovery Strategy configuration that corresponds to the properties passed in the Hazelcast configuration and listed in AwsProperties.
AwsConfig - Class in com.hazelcast.config
The AWSConfig contains the configuration for AWS join mechanism.
AwsConfig() - Constructor for class com.hazelcast.config.AwsConfig
 
AwsConfig(AwsConfig) - Constructor for class com.hazelcast.config.AwsConfig
 
AwsConfig.Builder - Class in com.hazelcast.aws
 
AwsConnectionException - Exception in com.hazelcast.aws.exception
Thrown to indicate an error while connecting to AWS.
AwsConnectionException(int, String) - Constructor for exception com.hazelcast.aws.exception.AwsConnectionException
 
AwsDiscoveryStrategy - Class in com.hazelcast.aws
AWS implementation of DiscoveryStrategy.
AwsDiscoveryStrategy(Map<String, Comparable>) - Constructor for class com.hazelcast.aws.AwsDiscoveryStrategy
 
AwsDiscoveryStrategyFactory - Class in com.hazelcast.aws
Factory class which returns AwsDiscoveryStrategy to Discovery SPI
AwsDiscoveryStrategyFactory() - Constructor for class com.hazelcast.aws.AwsDiscoveryStrategyFactory
 
AwsProperties - Enum in com.hazelcast.aws
Configuration properties for the Hazelcast Discovery Plugin for AWS.
AwsURLEncoder - Class in com.hazelcast.aws.utility
 
AZURE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
AzureConfig - Class in com.hazelcast.config
Configuration for the Azure Discovery Strategy.
AzureConfig() - Constructor for class com.hazelcast.config.AzureConfig
 
AzureConfig(AzureConfig) - Constructor for class com.hazelcast.config.AzureConfig
 

B

BackoffIdleStrategy - Class in com.hazelcast.util.concurrent
Idling strategy for threads when they have no work to do.
BackoffIdleStrategy(long, long, long, long) - Constructor for class com.hazelcast.util.concurrent.BackoffIdleStrategy
Create a set of state tracking idle behavior
BACKPRESSURE_BACKOFF_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Control the maximum timeout in millis to wait for an invocation space to be available.
BACKPRESSURE_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Using back pressure, you can prevent an overload of pending asynchronous backups.
BACKPRESSURE_MAX_CONCURRENT_INVOCATIONS_PER_PARTITION - Static variable in class com.hazelcast.spi.properties.GroupProperty
The maximum number of concurrent invocations per partition.
BACKPRESSURE_SYNCWINDOW - Static variable in class com.hazelcast.spi.properties.GroupProperty
Controls the frequency of a BackupAwareOperation getting its async backups converted to a sync backups.
backup - Variable in class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
 
backup - Variable in class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
 
backup() - Method in interface com.hazelcast.hotrestart.HotRestartService
Attempts to perform a cluster hot restart data backup.
backup(long) - Method in interface com.hazelcast.hotrestart.HotRestartService
Attempts to perform a cluster hot restart data backup.
backup() - Method in class com.hazelcast.hotrestart.NoOpHotRestartService
 
backup(long) - Method in class com.hazelcast.hotrestart.NoOpHotRestartService
 
BACKUP_DIR_PREFIX - Static variable in interface com.hazelcast.hotrestart.HotRestartService
The prefix for each hot restart backup directory.
BackupAwareEntryProcessor<K,V,T> - Interface in com.hazelcast.cache
An invocable function that allows applications to perform compound operations on a Cache.Entry atomically, according to the defined consistency of a Cache.
BackupAwareOperation - Interface in com.hazelcast.spi
A BackupAwareOperation is an Operation to indicate then when a change is made, a BackupOperation is created to replicate the backup.
BackupOperation - Interface in com.hazelcast.spi
When an BackupAwareOperation makes a change, the backups need to be replicated to other members (depending on the configuration and if change really happened).
BackupTaskState - Enum in com.hazelcast.hotrestart
The state of the hot restart backup task
BackupTaskStatus - Class in com.hazelcast.hotrestart
The status of the hot restart backup task, including progress and state.
BackupTaskStatus(BackupTaskState, int, int) - Constructor for class com.hazelcast.hotrestart.BackupTaskStatus
 
balloc(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
 
Base64 - Class in com.hazelcast.util
This class provides encode/decode for RFC 2045 Base64 as defined by RFC 2045, N.
BASE64_VALUE_INVALID - Static variable in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
Marker used to denote ascii characters that do not correspond to a 6-bit value (in this variant), and is not used as a padding character.
BASE64_VALUE_PADDING - Static variable in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
Marker used to denote ascii character (in decoding table) that is the padding character using this variant (if any).
Base64Coder - Class in com.hazelcast.org.snakeyaml.engine.external.biz.base64Coder
A Base64 encoder/decoder.
Base64Variant - Class in com.hazelcast.com.fasterxml.jackson.core
Class used to define specific details of which variant of Base64 encoding/decoding is to be used.
Base64Variant(String, String, boolean, char, int) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
 
Base64Variant(Base64Variant, String, int) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
"Copy constructor" that can be used when the base alphabet is identical to one used by another variant except for the maximum line length (and obviously, name).
Base64Variant(Base64Variant, String, boolean, char, int) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
"Copy constructor" that can be used when the base alphabet is identical to one used by another variant, but other details (padding, maximum line length) differ
Base64Variants - Class in com.hazelcast.com.fasterxml.jackson.core
Base64Variants() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.Base64Variants
 
BaseConstructor - Class in com.hazelcast.org.snakeyaml.engine.v1.constructor
 
BaseConstructor(LoadSettings) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.constructor.BaseConstructor
 
BaseMap<K,V> - Interface in com.hazelcast.core
Base interface for Hazelcast distributed maps.
BaseMultiMap<K,V> - Interface in com.hazelcast.core
Base interface for Hazelcast distributed multi-maps.
BaseQueue<E> - Interface in com.hazelcast.core
Base interface for Hazelcast distributed queues.
BaseRepresenter - Class in com.hazelcast.org.snakeyaml.engine.v1.representer
Represent basic YAML structures: scalar, sequence, mapping
BaseRepresenter() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.representer.BaseRepresenter
 
BasicSSLContextFactory - Class in com.hazelcast.nio.ssl
Empty implementation.
BasicSSLContextFactory() - Constructor for class com.hazelcast.nio.ssl.BasicSSLContextFactory
 
batch(String, FunctionEx<? super Processor.Context, ? extends C>) - Static method in class com.hazelcast.jet.pipeline.SourceBuilder
Returns a fluent-API builder with which you can create a batch source for a Jet pipeline.
batchFromProcessor(String, ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.pipeline.Sources
Returns a bounded (batch) source constructed directly from the given Core API processor meta-supplier.
BatchSource<T> - Interface in com.hazelcast.jet.pipeline
A finite source of data for a Jet pipeline.
BatchStage<T> - Interface in com.hazelcast.jet.pipeline
A stage in a distributed computation pipeline that will observe a finite amount of data (a batch).
BatchStageWithKey<T,K> - Interface in com.hazelcast.jet.pipeline
An intermediate step while constructing a group-and-aggregate batch pipeline stage.
BD_MAX_INT - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
BD_MAX_LONG - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
BD_MIN_INT - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
BD_MIN_LONG - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
before(Credentials, String, String, String, Parameters) - Method in interface com.hazelcast.security.SecurityInterceptor
 
BEFORE_AWAIT - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
BEFORE_AWAIT_BACKUP - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
beforeArrayValues(JsonGenerator) - Method in interface com.hazelcast.com.fasterxml.jackson.core.PrettyPrinter
Method called after array start marker has been output, and right before the first value is to be output.
beforeArrayValues(JsonGenerator) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
 
beforeArrayValues(JsonGenerator) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.MinimalPrettyPrinter
 
BeforeAwaitBackupOperation - Class in com.hazelcast.concurrent.lock.operations
 
BeforeAwaitBackupOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.BeforeAwaitBackupOperation
 
BeforeAwaitBackupOperation(ObjectNamespace, Data, long, String, String) - Constructor for class com.hazelcast.concurrent.lock.operations.BeforeAwaitBackupOperation
 
BeforeAwaitOperation - Class in com.hazelcast.concurrent.lock.operations
 
BeforeAwaitOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
 
BeforeAwaitOperation(ObjectNamespace, Data, long, String) - Constructor for class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
 
BeforeAwaitOperation(ObjectNamespace, Data, long, String, long) - Constructor for class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
 
beforeClusterStateChange(ClusterState, ClusterState, boolean) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
beforeClusterStateChange(ClusterState, ClusterState, boolean) - Method in interface com.hazelcast.instance.NodeExtension
Called before starting a cluster state change transaction.
beforeJoin() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
beforeJoin() - Method in interface com.hazelcast.instance.NodeExtension
Called before node attempts to join to the cluster
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
 
beforeMigration(PartitionMigrationEvent) - Method in interface com.hazelcast.spi.MigrationAwareService
Called before migration process starts, on both source and destination members.
beforeObjectEntries(JsonGenerator) - Method in interface com.hazelcast.com.fasterxml.jackson.core.PrettyPrinter
Method called after object start marker has been output, and right before the field name of the first entry is to be output.
beforeObjectEntries(JsonGenerator) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter
 
beforeObjectEntries(JsonGenerator) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.MinimalPrettyPrinter
 
beforeRun() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
 
beforeRun() - Method in class com.hazelcast.concurrent.lock.operations.SignalOperation
 
beforeRun() - Method in class com.hazelcast.spi.Operation
The beforeRun is called before either the Operation.run() or the Operation.call() method is called.
beforeRun() - Method in class com.hazelcast.util.executor.HazelcastManagedThread
Called before inner run method and can be overridden to customize.
beforeShutdown() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
beforeShutdown() - Method in interface com.hazelcast.instance.NodeExtension
Called before Node.shutdown()
beforeStart() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
beforeStart() - Method in interface com.hazelcast.instance.NodeExtension
Called before node is started
beginCombine() - Method in class com.hazelcast.mapreduce.Combiner
Deprecated.
This method is called before the first value is submitted to this Combiner instance.
beginReduce() - Method in class com.hazelcast.mapreduce.Reducer
Deprecated.
This method is called before the first value is submitted to this Reducer instance.
beginTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
Begins a transaction.
Beta - Annotation Type in com.hazelcast.spi.annotation
An element annotated with this annotation is considered beta status.
between(Vertex, Vertex) - Static method in class com.hazelcast.jet.core.Edge
Returns an edge between two vertices.
between(String, Comparable, Comparable) - Static method in class com.hazelcast.jet.pipeline.GenericPredicates
between(Comparable, Comparable) - Method in class com.hazelcast.query.EntryObject
 
between(String, Comparable, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates a between predicate that will pass items if the value stored under the given item attribute is contained inside the given range.
BI_MAX_INT - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
BI_MAX_LONG - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
BI_MIN_INT - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
BI_MIN_LONG - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
BiConsumer<T,U> - Interface in com.hazelcast.util.function
Represents an operation that accepts two input arguments and returns no result.
BiConsumerEx<T,U> - Interface in com.hazelcast.jet.function
Serializable variant of java.util.function.BiConsumer which declares checked exception.
BiFunctionEx<T,U,R> - Interface in com.hazelcast.jet.function
Serializable variant of java.util.function.BiFunction which declares checked exception.
bigDecimalAvg() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalAvg() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to calculate the BigDecimal average of all supplied values.
This aggregation is similar to:
bigDecimalMax() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalMax() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to find the BigDecimal maximum of all supplied values.
This aggregation is similar to:
bigDecimalMin() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalMin() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to find the BigDecimal minimum of all supplied values.
This aggregation is similar to:
bigDecimalSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalSum() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to calculate the BigDecimal sum of all supplied values.
This aggregation is similar to:
bigIntegerAvg() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerAvg() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to calculate the BigInteger average of all supplied values.
This aggregation is similar to:
bigIntegerMax() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerMax() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to find the BigInteger maximum of all supplied values.
This aggregation is similar to:
bigIntegerMin() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerMin() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to find the BigInteger minimum of all supplied values.
This aggregation is similar to:
bigIntegerSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerSum() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to calculate the BigInteger sum of all supplied values.
This aggregation is similar to:
BiInt2ObjectMap<V> - Class in com.hazelcast.util.collection
Map that takes two part int key and associates with an object.
BiInt2ObjectMap() - Constructor for class com.hazelcast.util.collection.BiInt2ObjectMap
Construct an empty map
BiInt2ObjectMap(int, double) - Constructor for class com.hazelcast.util.collection.BiInt2ObjectMap
BiInt2ObjectMap.EntryConsumer<V> - Interface in com.hazelcast.util.collection
Handler for a map entry
BINARY - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.nodes.Tag
 
BinaryInterface - Annotation Type in com.hazelcast.nio.serialization
Indicates that the binary serialized form of the annotated class is used in client-member communication over Hazelcast Open Binary Client Protocol or in other ways which may break Hazelcast or other systems.
BinaryOperatorEx<T> - Interface in com.hazelcast.jet.function
Serializable variant of java.util.function.BinaryOperator which declares checked exception.
BIND_SPOOFING_CHECKS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Controls whether we apply more strict checks upon BIND requests towards a cluster member.
BindRequest - Class in com.hazelcast.nio.tcp
 
BiPredicateEx<T,U> - Interface in com.hazelcast.jet.function
Serializable variant of java.util.function.BiPredicate which declares checked exception.
bits() - Method in enum com.hazelcast.com.fasterxml.jackson.core.JsonEncoding
 
Bits - Class in com.hazelcast.nio
Access and manipulate bits, bytes, primitives...
BitSetUtils - Class in com.hazelcast.util
Convenient method for BitSet manipulations
blacklist(Address, boolean) - Method in interface com.hazelcast.cluster.Joiner
Deprecated.
Adds an address to the blacklist.
block() - Method in class com.hazelcast.jet.core.test.TestOutbox
 
BLOCK_SIZE - Static variable in class com.hazelcast.concurrent.idgen.IdGeneratorImpl
 
BlockEndToken - Class in com.hazelcast.org.snakeyaml.engine.v1.tokens
 
BlockEndToken(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.tokens.BlockEndToken
 
BlockEntryToken - Class in com.hazelcast.org.snakeyaml.engine.v1.tokens
 
BlockEntryToken(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.tokens.BlockEntryToken
 
BlockingOperation - Interface in com.hazelcast.spi
An interface that can be implemented by an operation that can block.
BlockMappingStartToken - Class in com.hazelcast.org.snakeyaml.engine.v1.tokens
 
BlockMappingStartToken(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.tokens.BlockMappingStartToken
 
BlockSequenceStartToken - Class in com.hazelcast.org.snakeyaml.engine.v1.tokens
 
BlockSequenceStartToken(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.tokens.BlockSequenceStartToken
 
BOOL - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.nodes.Tag
 
BOOL - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.resolver.JsonScalarResolver
 
BOOLEAN_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
BOOLEAN_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
BOOLEAN_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
Boolean size in bytes
bothFalse() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.ImplicitTuple
 
bottomN(int, ComparatorEx<? super T>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that finds the bottom n items according to the given comparator.
boundsCheck(int, int, int) - Static method in class com.hazelcast.util.collection.ArrayUtils
Bounds check when copying to/from a buffer
broadcast() - Method in class com.hazelcast.jet.core.Edge
Activates the BROADCAST routing policy.
BroadcastKey<K> - Class in com.hazelcast.jet.core
Marks a key in the snapshot state to indicate that the corresponding entry should be broadcast to all processors when restoring the snapshot.
broadcastKey(K) - Static method in class com.hazelcast.jet.core.BroadcastKey
Returns a given key as a broadcast key.
bucketCount() - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
Returns number of primary slots table has currently
bucketCount() - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
Method for checking number of primary hash buckets this symbol table uses.
bucketCount() - Method in interface com.hazelcast.jet.core.Outbox
Returns the number of buckets in this outbox.
bucketCount() - Method in class com.hazelcast.jet.core.test.TestOutbox
 
BufferObjectDataInput - Interface in com.hazelcast.nio
 
BufferObjectDataOutput - Interface in com.hazelcast.nio
 
BufferRecycler - Class in com.hazelcast.com.fasterxml.jackson.core.util
This is a small utility class, whose main functionality is to allow simple reuse of raw byte/char buffers.
BufferRecycler() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
Default constructor used for creating instances of this default implementation.
BufferRecycler(int, int) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
Alternate constructor to be used by sub-classes, to allow customization of number of low-level buffers in use.
BufferRecyclers - Class in com.hazelcast.com.fasterxml.jackson.core.util
Helper entity used to control access to simple buffer recyling scheme used for some encoding, decoding tasks.
BufferRecyclers() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecyclers
 
build() - Method in class com.hazelcast.aws.AwsConfig.Builder
 
build() - Method in interface com.hazelcast.config.ConfigBuilder
Builds Config object.
build() - Method in class com.hazelcast.config.ProbabilisticQuorumConfigBuilder
 
build() - Method in class com.hazelcast.config.QuorumConfigBuilder
 
build() - Method in class com.hazelcast.config.RecentlyActiveQuorumConfigBuilder
 
build() - Method in class com.hazelcast.config.XmlConfigBuilder
 
build() - Method in class com.hazelcast.config.YamlConfigBuilder
 
BUILD - Static variable in class com.hazelcast.instance.GeneratedBuildProperties
 
build() - Method in class com.hazelcast.instance.MemberImpl.Builder
 
build() - Method in class com.hazelcast.jet.aggregate.AllOfAggregationBuilder
Builds and returns the composite AggregateOperation1.
build(FunctionEx<ItemsByTag, R>) - Method in class com.hazelcast.jet.aggregate.AllOfAggregationBuilder
Builds and returns the composite AggregateOperation1.
build() - Method in class com.hazelcast.jet.aggregate.CoAggregateOperationBuilder
Builds and returns the AggregateOperation.
build(FunctionEx<? super ItemsByTag, ? extends R>) - Method in class com.hazelcast.jet.aggregate.CoAggregateOperationBuilder
Builds and returns the multi-input AggregateOperation.
build(BiFunctionEx<String, ? super D, T>) - Method in class com.hazelcast.jet.avro.AvroSourceBuilder
Builds a custom Avro file BatchSource with supplied components and the output function mapOutputFn.
build() - Method in class com.hazelcast.jet.avro.AvroSourceBuilder
build(FunctionEx<? super ItemsByTag, ? extends R>) - Method in class com.hazelcast.jet.pipeline.AggregateBuilder
Creates and returns a pipeline stage that performs the co-aggregation of the stages registered with this builder object.
build() - Method in class com.hazelcast.jet.pipeline.AggregateBuilder
Creates and returns a pipeline stage that performs the co-aggregation of the stages registered with this builder object.
build(AggregateOperation<?, R>) - Method in class com.hazelcast.jet.pipeline.AggregateBuilder1
Creates and returns a pipeline stage that performs the co-aggregation of pipeline stages registered with this builder object.
build() - Method in class com.hazelcast.jet.pipeline.FileSinkBuilder
Creates and returns the file Sink with the supplied components.
build() - Method in class com.hazelcast.jet.pipeline.FileSourceBuilder
build(BiFunctionEx<String, String, ? extends T>) - Method in class com.hazelcast.jet.pipeline.FileSourceBuilder
Builds a custom file BatchSource with supplied components and the output function mapOutputFn.
build() - Method in class com.hazelcast.jet.pipeline.GroupAggregateBuilder
Creates and returns a pipeline stage that performs the co-aggregation of the stages registered with this builder object and emits a Map.Entry(key, resultsByTag) for each distinct key.
build(AggregateOperation<?, R>, BiFunctionEx<? super K, ? super R, OUT>) - Method in class com.hazelcast.jet.pipeline.GroupAggregateBuilder1
Deprecated.
This is a leftover from an earlier development cycle of the Pipeline API. Use GroupAggregateBuilder1.build(AggregateOperation) instead and add a separate mapping stage with mapToOutputFn.
build(AggregateOperation<?, R>) - Method in class com.hazelcast.jet.pipeline.GroupAggregateBuilder1
Creates and returns a pipeline stage that performs the co-grouping and aggregation of pipeline stages registered with this builder object.
build(BiFunctionEx<T0, ItemsByTag, R>) - Method in class com.hazelcast.jet.pipeline.HashJoinBuilder
Builds a new pipeline stage that performs the hash-join operation.
build() - Method in class com.hazelcast.jet.pipeline.JmsSinkBuilder
Creates and returns the JMS Sink with the supplied components.
build(FunctionEx<? super Message, ? extends T>) - Method in class com.hazelcast.jet.pipeline.JmsSourceBuilder
Creates and returns the JMS StreamSource with the supplied components and the projection function projectionFn.
build() - Method in class com.hazelcast.jet.pipeline.JmsSourceBuilder
build() - Method in class com.hazelcast.jet.pipeline.SinkBuilder
Creates and returns the Sink with the components you supplied to this builder.
build() - Method in class com.hazelcast.jet.pipeline.SourceBuilder.Batch
Builds and returns the batch source.
build() - Method in class com.hazelcast.jet.pipeline.SourceBuilder.Stream
Builds and returns the unbounded stream source.
build() - Method in class com.hazelcast.jet.pipeline.SourceBuilder.TimestampedStream
Builds and returns the timestamped stream source.
build(BiFunctionEx<T0, ItemsByTag, R>) - Method in class com.hazelcast.jet.pipeline.StreamHashJoinBuilder
Builds a new pipeline stage that performs the hash-join operation.
build() - Method in class com.hazelcast.jet.pipeline.test.AssertionSinkBuilder
Creates and returns the Sink with the components you supplied to this builder.
build() - Method in class com.hazelcast.jet.pipeline.WindowAggregateBuilder
Creates and returns a pipeline stage that performs a windowed co-aggregation of the stages registered with this builder object.
build(AggregateOperation<A, R>) - Method in class com.hazelcast.jet.pipeline.WindowAggregateBuilder1
Creates and returns a pipeline stage that performs a windowed co-aggregation of the pipeline stages registered with this builder object.
build() - Method in class com.hazelcast.jet.pipeline.WindowGroupAggregateBuilder
Creates and returns a pipeline stage that performs a windowed cogroup-and-aggregate operation on the stages registered with this builder object.
build(AggregateOperation<?, ? extends R>) - Method in class com.hazelcast.jet.pipeline.WindowGroupAggregateBuilder1
Creates and returns a pipeline stage that performs a windowed cogroup-and-aggregate of the pipeline stages registered with this builder object.
build() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
build() - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.DumpSettingsBuilder
Create immutable DumpSettings
build() - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.LoadSettingsBuilder
Build immutable LoadSettings
build() - Method in class com.hazelcast.util.collection.InflatableSet.Builder
 
buildConfig(Node) - Method in interface com.hazelcast.config.DomConfigProcessor
Traverses the DOM and fills the config
builder() - Static method in class com.hazelcast.aws.AwsConfig
 
Builder() - Constructor for class com.hazelcast.aws.AwsConfig.Builder
 
Builder(Address) - Constructor for class com.hazelcast.instance.MemberImpl.Builder
 
Builder(Map<EndpointQualifier, Address>) - Constructor for class com.hazelcast.instance.MemberImpl.Builder
 
BuildInfo - Class in com.hazelcast.instance
 
BuildInfo(String, String, String, int, boolean, byte) - Constructor for class com.hazelcast.instance.BuildInfo
 
BuildInfo(String, String, String, int, boolean, byte, BuildInfo) - Constructor for class com.hazelcast.instance.BuildInfo
 
BuildInfoProvider - Class in com.hazelcast.instance
Provides information about current Hazelcast build.
buildWatcher() - Method in class com.hazelcast.jet.pipeline.FileSourceBuilder
buildWatcher(BiFunctionEx<String, String, ? extends T>) - Method in class com.hazelcast.jet.pipeline.FileSourceBuilder
Builds a source that emits a stream of lines of text coming from files in the watched directory (but not its subdirectories).
BuiltInCacheMergePolicies - Enum in com.hazelcast.cache
Enum that represents all built-in CacheMergePolicy implementations.
BusySpinIdleStrategy - Class in com.hazelcast.util.concurrent
Busy spin strategy targeted at lowest possible latency.
BusySpinIdleStrategy() - Constructor for class com.hazelcast.util.concurrent.BusySpinIdleStrategy
 
byOrdinal(int) - Static method in enum com.hazelcast.mapreduce.JobPartitionState.State
Deprecated.
Returns an processing state by its given ordinal
BYTE_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
BYTE_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
BYTE_BASE64_CODEC_BUFFER - Static variable in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
Buffer used for concatenating binary data that is either being encoded as base64 output, or decoded from base64 input.
BYTE_READ_IO_BUFFER - Static variable in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
Buffer used for reading byte-based input.
BYTE_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
Byte size in bytes
BYTE_WRITE_CONCAT_BUFFER - Static variable in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
Buffer used for temporarily concatenating output; used for example when requesting output as byte array.
BYTE_WRITE_ENCODING_BUFFER - Static variable in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
Buffer used for temporarily storing encoded content; used for example by UTF-8 encoding writer
ByteArrayBuilder - Class in com.hazelcast.com.fasterxml.jackson.core.util
Helper class that is similar to ByteArrayOutputStream in usage, but more geared to Jackson use cases internally.
ByteArrayBuilder() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
 
ByteArrayBuilder(BufferRecycler) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
 
ByteArrayBuilder(int) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
 
ByteArrayBuilder(BufferRecycler, int) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
 
ByteArrayFeeder - Interface in com.hazelcast.com.fasterxml.jackson.core.async
NonBlockingInputFeeder implementation used when feeding data as byte arrays.
ByteArrayProcessor - Interface in com.hazelcast.util
A byte array processor used to produce a byte[] out of the given one.
ByteArraySerializer<T> - Interface in com.hazelcast.nio.serialization
For sample usage custom serialization and other way of custom serialization see StreamSerializer.
ByteBufferFeeder - Interface in com.hazelcast.com.fasterxml.jackson.core.async
NonBlockingInputFeeder implementation used when feeding data as ByteBuffer contents.
byteBufferLength(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
 
ByteQuadsCanonicalizer - Class in com.hazelcast.com.fasterxml.jackson.core.sym
Replacement for BytesToNameCanonicalizer which aims at more localized memory access due to flattening of name quad data.
bytes() - Method in class com.hazelcast.memory.MemorySize
Returns value of memory size in bytes.
ByteSourceJsonBootstrapper - Class in com.hazelcast.com.fasterxml.jackson.core.json
This class is used to determine the encoding of byte stream that is to contain JSON content.
ByteSourceJsonBootstrapper(IOContext, InputStream) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.json.ByteSourceJsonBootstrapper
 
ByteSourceJsonBootstrapper(IOContext, byte[], int, int) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.json.ByteSourceJsonBootstrapper
 
bytesToHex(byte[]) - Static method in class com.hazelcast.util.QuickMath
 
bytesToString(byte[], int, int) - Static method in class com.hazelcast.util.StringUtil
Creates a UTF8_CHARSET string from a byte array.
bytesToString(byte[]) - Static method in class com.hazelcast.util.StringUtil
Creates a UTF8_CHARSET string from a byte array.

C

cache(String) - Static method in class com.hazelcast.jet.pipeline.Sinks
Returns a sink that puts Map.Entrys it receives into a Hazelcast ICache with the specified name.
cache(String) - Static method in class com.hazelcast.jet.pipeline.Sources
Returns a source that fetches entries from a Hazelcast ICache with the given name and emits them as Map.Entry.
CACHE_INVALIDATION_MESSAGE_BATCH_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Defines cache invalidation event batch sending is enabled or not.
CACHE_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Defines the cache invalidation event batch sending frequency in seconds.
CACHE_INVALIDATION_MESSAGE_BATCH_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Defines the maximum number of cache invalidation events to be drained and sent to the event listeners in a batch.
CACHE_LINE_LENGTH - Static variable in class com.hazelcast.nio.Bits
Length of the data blocks used by the CPU cache sub-system in bytes.
CACHE_MANAGER_PREFIX - Static variable in interface com.hazelcast.cache.HazelcastCacheManager
Hazelcast's CacheManager prefix to be appended to the head of the cache name.
CACHE_PARTITION_LOST_LISTENER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
CacheConfig<K,V> - Class in com.hazelcast.config
Contains all the configuration for the ICache.
CacheConfig() - Constructor for class com.hazelcast.config.CacheConfig
 
CacheConfig(String) - Constructor for class com.hazelcast.config.CacheConfig
 
CacheConfig(CompleteConfiguration<K, V>) - Constructor for class com.hazelcast.config.CacheConfig
 
CacheConfig(CacheSimpleConfig) - Constructor for class com.hazelcast.config.CacheConfig
 
CacheConfigAccessor - Class in com.hazelcast.config
Accessor for CacheConfig fields
CacheConfigReadOnly<K,V> - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
CacheConfiguration<K,V> - Interface in com.hazelcast.config
Mutable extension to CompleteConfiguration
CacheDeserializedValues - Enum in com.hazelcast.config
Control caching of de-serialized values.
CachedExecutorServiceDelegate - Class in com.hazelcast.util.executor
 
CachedExecutorServiceDelegate(NodeEngine, String, ExecutorService, int, int) - Constructor for class com.hazelcast.util.executor.CachedExecutorServiceDelegate
 
CacheEntryView<K,V> - Interface in com.hazelcast.cache
Entry info for cache record.
cacheEventNewValue() - Static method in class com.hazelcast.jet.Util
Returns a projection that extracts the new value from an EventJournalCacheEvent.
cacheEventToEntry() - Static method in class com.hazelcast.jet.Util
Returns a projection that converts the EventJournalCacheEvent to a Map.Entry using the event's new value as a value.
CacheEventType - Enum in com.hazelcast.cache
Hazelcast JCache implementation's internal event types.
CacheEvictionConfig - Class in com.hazelcast.config
Deprecated.
Use EvictionConfig instead of this
CacheEvictionConfig() - Constructor for class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
CacheEvictionConfig(int, EvictionConfig.MaxSizePolicy, EvictionPolicy) - Constructor for class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
CacheEvictionConfig(int, CacheEvictionConfig.CacheMaxSizePolicy, EvictionPolicy) - Constructor for class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
CacheEvictionConfig(int, EvictionConfig.MaxSizePolicy, String) - Constructor for class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
CacheEvictionConfig(int, CacheEvictionConfig.CacheMaxSizePolicy, String) - Constructor for class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
CacheEvictionConfig(int, EvictionConfig.MaxSizePolicy, EvictionPolicyComparator) - Constructor for class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
CacheEvictionConfig(int, CacheEvictionConfig.CacheMaxSizePolicy, EvictionPolicyComparator) - Constructor for class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
CacheEvictionConfig(EvictionConfig) - Constructor for class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
CacheEvictionConfig.CacheMaxSizePolicy - Enum in com.hazelcast.config
Deprecated.
Cache Maximum Size Policy
CacheEvictionConfigReadOnly - Class in com.hazelcast.config
Deprecated.
Use EvictionConfigReadOnly instead of this
CacheEvictionConfigReadOnly(EvictionConfig) - Constructor for class com.hazelcast.config.CacheEvictionConfigReadOnly
Deprecated.
 
CacheEvictionPolicyComparator<K,V> - Class in com.hazelcast.cache
Cache specific EvictionPolicyComparator for comparing CacheEntryViews to be evicted.
CacheEvictionPolicyComparator() - Constructor for class com.hazelcast.cache.CacheEvictionPolicyComparator
 
cacheJournal(String, PredicateEx<? super EventJournalCacheEvent<K, V>>, FunctionEx<? super EventJournalCacheEvent<K, V>, ? extends T>, JournalInitialPosition) - 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
Convenience for Sources.cacheJournal(String, PredicateEx, FunctionEx, JournalInitialPosition) which will pass only CREATED and UPDATED events and will project the event's key and new value into a Map.Entry.
cacheLoaderFactory - Variable in class com.hazelcast.config.AbstractCacheConfig
The Factory for the CacheLoader.
CacheMergePolicy - Interface in com.hazelcast.cache
Policy for merging cache entries after a split-brain has been healed.
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
 
CachePartitionLostListenerConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
CachePartitionLostListenerConfigReadOnly(CachePartitionLostListenerConfig) - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfigReadOnly
Deprecated.
 
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
CacheSimpleConfig - Class in com.hazelcast.config
Simple configuration to hold parsed XML configuration.
CacheSimpleConfig(CacheSimpleConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfig
 
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".
CacheSimpleConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
CacheSimpleConfigReadOnly(CacheSimpleConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
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
 
CacheSimpleEntryListenerConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
CacheSimpleEntryListenerConfigReadOnly(CacheSimpleEntryListenerConfig) - Constructor for class com.hazelcast.config.CacheSimpleEntryListenerConfigReadOnly
Deprecated.
 
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
 
calculateInitialCapacity(int) - Static method in class com.hazelcast.util.MapUtil
Returns the initial hash map capacity needed for the expected map size.
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
 
call() - Method in class com.hazelcast.spi.Operation
Call the operation and returns the CallStatus.
CALLER_RUNS - Static variable in class com.hazelcast.util.ConcurrencyUtil
The Caller runs executor is an Executor that executes the task on the calling thread.
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
 
CallsPerMember - Class in com.hazelcast.spi
Implements LiveOperations and additionally collects the call IDs of operations on remote members whose cancellation was requested.
CallsPerMember(Address) - Constructor for class com.hazelcast.spi.CallsPerMember
 
CallStatus - Class in com.hazelcast.spi
The result of an Operation.call().
CallStatus(int) - Constructor for class com.hazelcast.spi.CallStatus
 
callTimeout - Variable in class com.hazelcast.spi.InvocationBuilder
 
canAcquireLock(Data, String, long) - Method in interface com.hazelcast.concurrent.lock.LockStore
Return if the key can be locked by the caller and thread ID.
canAcquireLock(Data, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
canAcquireLock(Data, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
 
CanCancelOperations - Interface in com.hazelcast.spi
Implemented by a service that can cancel its operations.
cancel() - Method in interface com.hazelcast.jet.Job
Makes a request to cancel this job and returns.
cancel(JetCommandLine.Verbosity, 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.
cancel(boolean) - Method in class com.hazelcast.util.executor.CompletedFuture
 
cancel(boolean) - Method in class com.hazelcast.util.executor.DelegatingFuture
 
cancel(K) - Method in interface com.hazelcast.util.scheduler.EntryTaskScheduler
Cancel all scheduled executions with the given key.
cancel(K) - Method in class com.hazelcast.util.scheduler.SecondsBasedEntryTaskScheduler
 
cancelAll() - Method in interface com.hazelcast.util.scheduler.EntryTaskScheduler
Cancel all scheduled executions
cancelAll() - Method in class com.hazelcast.util.scheduler.SecondsBasedEntryTaskScheduler
 
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).
cancelIfExists(K, V) - Method in interface com.hazelcast.util.scheduler.EntryTaskScheduler
Cancels the scheduled executions for the given key and value if present.
cancelIfExists(K, V) - Method in class com.hazelcast.util.scheduler.SecondsBasedEntryTaskScheduler
 
cancelled(boolean) - Method in class com.hazelcast.util.executor.CompletableFutureTask
 
cancelOperation(Address, long) - Method in interface com.hazelcast.spi.CanCancelOperations
Notifies this service that an operation was requested to be cancelled.
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.
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(Endpoint) - 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.v1.events.ImplicitTuple
 
canOmitTagInPlainScalar() - Method in class com.hazelcast.org.snakeyaml.engine.v1.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.
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
Method that can be used to verify that given schema can be used with this generator (using JsonGenerator.setSchema(com.hazelcast.com.fasterxml.jackson.core.FormatSchema)).
canUseSchema(FormatSchema) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Method that can be used to verify that given schema can be used with this parser (using JsonParser.setSchema(com.hazelcast.com.fasterxml.jackson.core.FormatSchema)).
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
Introspection method to call to check whether it is possible to write numbers using JsonGenerator.writeNumber(java.lang.String) using possible custom format, or not.
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.
capacity() - Method in class com.hazelcast.util.collection.BiInt2ObjectMap
Get the total capacity for the map to which the load factor with be a fraction of.
capacity() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
Get the total capacity for the map to which the load factor with be a fraction of.
capacity() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
Get the total capacity for the map to which the load factor with be a fraction of.
capacity() - Method in class com.hazelcast.util.collection.OAHashSet
Returns the capacity of the set
CARDINALITY_ESTIMATOR_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
CardinalityEstimator - Interface in com.hazelcast.cardinality
CardinalityEstimator is a redundant and highly available distributed data-structure used for probabilistic cardinality estimation purposes, on unique items, in significantly sized data cultures.
CardinalityEstimatorConfig - Class in com.hazelcast.config
Configuration options for the CardinalityEstimator
CardinalityEstimatorConfig() - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
 
CardinalityEstimatorConfig(String) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
 
CardinalityEstimatorConfig(String, int, int) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
 
CardinalityEstimatorConfig(String, int, int, MergePolicyConfig) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
 
CardinalityEstimatorConfig(String, int, int, String, MergePolicyConfig) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
 
CardinalityEstimatorConfig(CardinalityEstimatorConfig) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
 
CardinalityEstimatorPermission - Class in com.hazelcast.security.permission
 
CardinalityEstimatorPermission(String, String...) - Constructor for class com.hazelcast.security.permission.CardinalityEstimatorPermission
 
changeClusterState(ClusterState) - Method in interface com.hazelcast.core.Cluster
Changes state of the cluster to the given state transactionally.
changeClusterState(ClusterState, TransactionOptions) - Method in interface com.hazelcast.core.Cluster
Changes state of the cluster to the given state transactionally.
changeClusterVersion(Version) - Method in interface com.hazelcast.core.Cluster
Changes the cluster version transactionally.
changeClusterVersion(Version, TransactionOptions) - Method in interface com.hazelcast.core.Cluster
Changes the cluster version transactionally, with the transaction options provided.
changeNodeStateToActive() - Method in class com.hazelcast.instance.Node
 
changeNodeStateToPassive() - Method in class com.hazelcast.instance.Node
 
CHAR_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
CHAR_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
CHAR_CONCAT_BUFFER - Static variable in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
 
CHAR_NAME_COPY_BUFFER - Static variable in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
 
CHAR_NULL - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
CHAR_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
Char size in bytes
CHAR_TEXT_BUFFER - Static variable in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
 
CHAR_TOKEN_BUFFER - Static variable in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
 
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
 
charBufferLength(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecycler
 
CharConstants - Class in com.hazelcast.org.snakeyaml.engine.v1.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(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
 
check(YamlNode) - Static method in class com.hazelcast.config.yaml.YamlDomChecker
Performs checks on the provided YAML node recursively.
check(Node) - Method in class com.hazelcast.util.PhoneHome
 
checkAllDone(Collection<Future>) - Static method in class com.hazelcast.util.FutureUtil
Rethrow exeception of the fist future that completed with an exception
checkAsyncBackupCount(int, int) - Static method in class com.hazelcast.util.Preconditions
Tests if the newAsyncBackupCount count is valid.
checkBackupCount(int, int) - Static method in class com.hazelcast.util.Preconditions
Tests if the newBackupCount count is valid.
checkEvent(Event.ID) - Method in interface com.hazelcast.org.snakeyaml.engine.v1.parser.Parser
Check if the next event is one of the given type.
checkEvent(Event.ID) - Method in class com.hazelcast.org.snakeyaml.engine.v1.parser.ParserImpl
Check the type of the next event.
checkFalse(boolean, String) - Static method in class com.hazelcast.util.Preconditions
Tests whether the supplied expression is false.
checkHasNext(Iterator<T>, String) - Static method in class com.hazelcast.util.Preconditions
Check if iterator has next element.
checkHasText(String, String) - Static method in class com.hazelcast.util.Preconditions
Tests if a string contains text.
checkInstanceOf(Class<E>, Object, String) - Static method in class com.hazelcast.util.Preconditions
Tests whether the supplied object is an instance of the supplied class type.
checkInstanceOf(Class<E>, Object) - Static method in class com.hazelcast.util.Preconditions
 
checkLocalParallelism(int) - Static method in class com.hazelcast.jet.core.Vertex
Says whether the given integer is valid as the value of localParallelism.
checkNegative(long, String) - Static method in class com.hazelcast.util.Preconditions
Tests if the value is < 0.
checkNoNullInside(Iterable<T>, String) - Static method in class com.hazelcast.util.Preconditions
Tests if the elements inside the argument collection are not null.
checkNotInstanceOf(Class, E, String) - Static method in class com.hazelcast.util.Preconditions
Tests the supplied object to see if it is not a type of the supplied class.
checkNotNegative(long, String) - Static method in class com.hazelcast.util.Preconditions
Tests if the value is >= 0.
checkNotNegative(int, String) - Static method in class com.hazelcast.util.Preconditions
Tests if the value is >= 0.
checkNotNull(T, String) - Static method in class com.hazelcast.util.Preconditions
Tests if an argument is not null.
checkNotNull(T) - Static method in class com.hazelcast.util.Preconditions
Tests if an argument is not null.
checkPermission(Subject, Permission) - Method in interface com.hazelcast.security.SecurityContext
Checks whether current Subject has been granted specified permission or not.
checkPositive(long, String) - Static method in class com.hazelcast.util.Preconditions
Tests if a value is positive, that is strictly larger than 0 (value > 0).
checkPositive(double, String) - Static method in class com.hazelcast.util.Preconditions
Tests if a value is positive, that is strictly larger than 0 (value > 0).
checkPositive(int, String) - Static method in class com.hazelcast.util.Preconditions
Tests if a value is positive, that is strictly larger than 0 (value > 0).
checkState(boolean, String) - Static method in class com.hazelcast.util.Preconditions
Check the state of a condition
checkToken(Token.ID...) - Method in interface com.hazelcast.org.snakeyaml.engine.v1.scanner.Scanner
Check if the next token is one of the given types.
checkToken(Token.ID...) - Method in class com.hazelcast.org.snakeyaml.engine.v1.scanner.ScannerImpl
Check whether the next token is one of the given types.
checkTrue(boolean, String) - Static method in class com.hazelcast.util.Preconditions
Tests whether the supplied expression is true.
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.
checkWanReplicationQueues() - Method in interface com.hazelcast.wan.WanReplicationPublisher
Checks the size of the WAN replication queue and throws an exception if it has been reached or crossed.
checkWanReplicationQueues(String) - Method in interface com.hazelcast.wan.WanReplicationService
 
child() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.DupDetector
 
childElements(Node) - Static method in class com.hazelcast.config.DomConfigHelper
 
chunkSize(int) - Method in interface com.hazelcast.mapreduce.Job
Deprecated.
Defines the number of elements per chunk.
chunkSize(int) - Method in interface com.hazelcast.mapreduce.MappingJob
Deprecated.
Defines the number of elements per chunk.
chunkSize(int) - Method in interface com.hazelcast.mapreduce.ReducingJob
Deprecated.
Defines the number of elements per chunk.
chunkSize(int) - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
Deprecated.
Defines the number of elements per chunk.
ClassDefinition - Interface in com.hazelcast.nio.serialization
ClassDefinition 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
 
classIterator(Class<T>, String, ClassLoader) - Static method in class com.hazelcast.util.ServiceLoader
 
classLoader - Variable in class com.hazelcast.config.AbstractCacheConfig
The ClassLoader to be used to resolve key & value types, if set
classLoader - Variable in class com.hazelcast.util.executor.AbstractExecutorThreadFactory
 
ClassLoaderUtil - Class in com.hazelcast.nio
Utility class to deal with class loaders.
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
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.v1.representer.StandardRepresenter
 
cleanNodeName(Node) - Static method in class com.hazelcast.config.DomConfigHelper
 
clear() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
clear() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
clear() - Method in class com.hazelcast.config.InterfacesConfig
clears all interfaces.
clear() - Method in class com.hazelcast.config.MemberGroupConfig
Removes all interfaces from the member group.
clear() - Method in class com.hazelcast.config.PartitionGroupConfig
Removes all the PartitionGroupConfig.MemberGroupType instances.
clear() - Method in class com.hazelcast.config.ServicesConfig
 
clear() - Method in class com.hazelcast.config.TcpIpConfig
Removes all members.
clear() - Method in interface com.hazelcast.core.IAtomicReference
Clears the current stored reference.
clear() - Method in interface com.hazelcast.core.IMap
Clears the map and deletes the items from the backing map store.
clear() - Method in interface com.hazelcast.core.MultiMap
Clears the multimap.
clear() - Method in interface com.hazelcast.core.ReplicatedMap
The clear operation wipes data out of the replicated maps.
clear() - Method in class com.hazelcast.jet.core.test.TestInbox
Convenience for inbox.queue().clear()
clear() - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
clear() - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
clear() - Method in class com.hazelcast.spi.CallsPerMember
 
clear() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Clears the data in the ringbuffer.
clear() - Method in class com.hazelcast.util.collection.InflatableSet
 
clear() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
 
clear() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.KeySet
 
clear() - Method in class com.hazelcast.util.collection.IntHashSet
 
clear() - Method in class com.hazelcast.util.collection.Long2LongHashMap
 
clear() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
 
clear() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.KeySet
 
clear() - Method in class com.hazelcast.util.collection.LongHashSet
clear() - Method in class com.hazelcast.util.collection.MapDelegatingSet
clear() - Method in class com.hazelcast.util.collection.OAHashSet
 
clear() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
Removes all of the mappings from this map.
clear() - Method in class com.hazelcast.util.ItemCounter
Clears the counter.
clear() - Method in class com.hazelcast.wan.merkletree.ArrayMerkleTree
 
clear() - Method in interface com.hazelcast.wan.merkletree.MerkleTree
Clears the Merkle tree
clearAndGetParent() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
Method that can be used to both clear the accumulated references (specifically value set with JsonReadContext.setCurrentValue(Object)) that should not be retained, and returns parent (as would JsonReadContext.getParent() do).
clearAndGetParent() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
Method that can be used to both clear the accumulated references (specifically value set with JsonWriteContext.setCurrentValue(Object)) that should not be retained, and returns parent (as would JsonWriteContext.getParent() do).
clearAsync() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
clearAsync() - Method in interface com.hazelcast.core.IAtomicReference
Clears the current stored reference.
clearBit(byte, int) - Static method in class com.hazelcast.nio.Bits
Clears n-th bit of the byte value
clearBit(int, int) - Static method in class com.hazelcast.nio.Bits
Clears n-th bit of the integer value
clearClients() - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
 
clearCRDTState(Map<String, VectorClock>) - Method in interface com.hazelcast.crdt.CRDTReplicationAwareService
Removes all of the CRDTs with vector clocks equal to the provided vector clocks.
clearCRDTState(Map<String, VectorClock>) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
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
Method called to "consume" the current token by effectively removing it so that JsonParser.hasCurrentToken() returns false, and JsonParser.getCurrentToken() null).
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.
clearLockStore(int, ObjectNamespace) - Method in interface com.hazelcast.concurrent.lock.LockService
 
clearLockStore(int, ObjectNamespace) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
clearQueues(String, String) - Method in interface com.hazelcast.wan.WanReplicationService
Clears WAN replication queues of the given wanReplicationName for the given target.
clearServers() - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
 
Client - Interface in com.hazelcast.core
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_BINARY_NEW - Static variable in class com.hazelcast.nio.Protocols
New Client Protocol that is used for clients (Java, c++, c# client)
CLIENT_BLOCKING_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
Name of the client transaction executor.
CLIENT_ENDPOINT_REMOVE_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Time after which client connection is removed or owner node of a client is removed from the cluster.
CLIENT_ENGINE_BLOCKING_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
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.GroupProperty
The number of threads that the client engine has available for processing requests that are related to transactions When not set it is set as core-size.
CLIENT_ENGINE_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
The number of threads that the client engine has available for processing requests that are not partition specific.
CLIENT_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
Name of the client executor.
CLIENT_HEARTBEAT_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
CLIENT_MANAGEMENT_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
Name of the client management executor.
CLIENT_QUERY_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
Name of the client executor.
ClientAwareService - Interface in com.hazelcast.spi
A interface that can be implemented by a SPI Service so that it can be notified about client disconnects.
ClientChannelInitializer - Class in com.hazelcast.nio.tcp
 
clientConnected(Client) - Method in interface com.hazelcast.core.ClientListener
Invoked when a client is connected.
clientDisconnected(String) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
clientDisconnected(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
 
clientDisconnected(Client) - Method in interface com.hazelcast.core.ClientListener
Invoked when a client is disconnected.
clientDisconnected(String) - Method in interface com.hazelcast.spi.ClientAwareService
Invoked when a client disconnects from a member.
clientEngine - Variable in class com.hazelcast.instance.Node
 
ClientListener - Interface in com.hazelcast.core
The ClientListener provides the ability to listen to clients connecting and disconnecting from the member.
ClientService - Interface in com.hazelcast.core
ClientService allows you to query connected Clients and attach/detach ClientListeners to listen to connection events.
ClientType - Enum in com.hazelcast.core
Type of a Hazelcast client.
Clock - Class in com.hazelcast.util
Abstracts the system clock to simulate different clocks without changing the actual system time.
Clock.ClockImpl - Class in com.hazelcast.util
Extend this class if you want to provide your own clock implementation.
ClockImpl() - Constructor for class com.hazelcast.util.Clock.ClockImpl
 
ClockProperties - Class in com.hazelcast.util
Utility class to set system parameters for the clock implementation.
clone() - Method in class com.hazelcast.util.collection.InflatableSet
Returns a shallow copy of this InflatableSet instance: the keys and values themselves are not cloned.
cloneNode(boolean) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
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.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.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(String, Throwable) - Method in interface com.hazelcast.nio.Connection
Closes this connection.
close(Connection, String) - Static method in class com.hazelcast.nio.IOUtil
 
close(ServerSocket) - Static method in class com.hazelcast.nio.IOUtil
Quietly attempts to close a ServerSocket, swallowing any exception.
close(Socket) - Static method in class com.hazelcast.nio.IOUtil
Quietly attempts to close a Socket, swallowing any exception.
close(String, Throwable) - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
close() - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.YamlUnicodeReader
 
close() - Method in class com.hazelcast.org.snakeyaml.engine.v1.serializer.Serializer
 
close() - Method in class com.hazelcast.util.ContextMutexFactory.Mutex
 
closeArray(JsonGenerator) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
 
closeConnection() - Method in class com.hazelcast.nio.ascii.TextDecoder
 
closeObject(JsonGenerator) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
 
closeResource(Closeable) - Static method in class com.hazelcast.nio.IOUtil
Quietly attempts to close a Closeable resource, swallowing any exception.
CloudyUtility - Class in com.hazelcast.aws.utility
 
Cluster - Interface in com.hazelcast.core
Hazelcast cluster interface.
cluster(JetCommandLine.Verbosity) - Method in class com.hazelcast.jet.server.JetCommandLine
 
CLUSTER - Static variable in class com.hazelcast.nio.Protocols
Protocol that is used among nodes
CLUSTER_SHUTDOWN_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
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
 
clusterService - Variable in class com.hazelcast.instance.Node
 
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.
clusterVersionListeners - Variable in class com.hazelcast.instance.DefaultNodeExtension
 
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.
CoalescingDelayedTrigger - Class in com.hazelcast.util.scheduler
Coalescing trigger can be used when you want coalesce multiple execution of Runnable.
CoalescingDelayedTrigger(ExecutionService, long, long, Runnable) - Constructor for class com.hazelcast.util.scheduler.CoalescingDelayedTrigger
 
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.
collate(Iterable<ValueIn>) - Method in interface com.hazelcast.mapreduce.Collator
Deprecated.
This method is called with the mapped and possibly reduced values from the MapReduce algorithm.
Collator<ValueIn,ValueOut> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
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.
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.v1.events
Base class for the end events of the collection nodes.
CollectionEndEvent(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.events.CollectionEndEvent
 
CollectionEndEvent() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.events.CollectionEndEvent
 
CollectionNode<T> - Class in com.hazelcast.org.snakeyaml.engine.v1.nodes
Base class for the two collection types mapping and collection.
CollectionNode(Tag, FlowStyle, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.nodes.CollectionNode
 
CollectionStartEvent - Class in com.hazelcast.org.snakeyaml.engine.v1.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.v1.events.CollectionStartEvent
 
CollectionUtil - Class in com.hazelcast.util
Various collection utility methods.
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.
com.hazelcast.aggregation - package com.hazelcast.aggregation
Contains classes related to aggregations.
com.hazelcast.aws - package com.hazelcast.aws
Provides interfaces/classes for Hazelcast AWS.
com.hazelcast.aws.exception - package com.hazelcast.aws.exception
Provides Exceptions for Hazelcast AWS Plugin.
com.hazelcast.aws.security - package com.hazelcast.aws.security
Provides security classes for Hazelcast AWS.
com.hazelcast.aws.utility - package com.hazelcast.aws.utility
Provides utility classes for Hazelcast AWS.
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.cache.journal - package com.hazelcast.cache.journal
Contains EventJournal event interface for ICache.
com.hazelcast.cache.merge - package com.hazelcast.cache.merge
Contains out-of-the-box merge policies for ICache.
com.hazelcast.cardinality - package com.hazelcast.cardinality
This package contains Cardinality Estimator functionality for Hazelcast.
com.hazelcast.cluster - package com.hazelcast.cluster
This package contains the cluster functionality.
com.hazelcast.cluster.memberselector - package com.hazelcast.cluster.memberselector
This package contains several MemberSelector implementations.
com.hazelcast.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.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.concurrent.atomiclong - package com.hazelcast.concurrent.atomiclong
This package contains IAtomicLong functionality for Hazelcast.
The IAtomicLong is the distributed version of the AtomicLong.
com.hazelcast.concurrent.atomiclong.operations - package com.hazelcast.concurrent.atomiclong.operations
This package contains the operations on the IAtomicLong.
com.hazelcast.concurrent.atomicreference - package com.hazelcast.concurrent.atomicreference
This package contains IAtomicReferece functionality for Hazelcast.
The IAtomicReference is the distributed version of the AtomicReference.
com.hazelcast.concurrent.atomicreference.operations - package com.hazelcast.concurrent.atomicreference.operations
This package contains the operations on the IAtomicReference.
com.hazelcast.concurrent.countdownlatch - package com.hazelcast.concurrent.countdownlatch
This package contains ICountDownLatch functionality for Hazelcast.
The ICountDownLatch is the distributed version of the CountDownLatch.
com.hazelcast.concurrent.countdownlatch.operations - package com.hazelcast.concurrent.countdownlatch.operations
This package contains the operations on the ICountDownLatch.
com.hazelcast.concurrent.idgen - package com.hazelcast.concurrent.idgen
This package contains IdGenerator functionality for Hazelcast.
com.hazelcast.concurrent.lock - package com.hazelcast.concurrent.lock
This package contains Lock for Hazelcast.
The ILock is the distributed version of the Lock.
com.hazelcast.concurrent.lock.operations - package com.hazelcast.concurrent.lock.operations
This package contains the operations on the ILock.
com.hazelcast.concurrent.semaphore - package com.hazelcast.concurrent.semaphore
This package contains ISemaphore functionality for Hazelcast.
The ISemaphore is the distributed version of the Semaphore.
com.hazelcast.concurrent.semaphore.operations - package com.hazelcast.concurrent.semaphore.operations
This package contains the operations on the ISemaphore.
com.hazelcast.config - package com.hazelcast.config
Provides classes for configuring HazelcastInstance.
com.hazelcast.config.cp - package com.hazelcast.config.cp
This package contains configuration classes for the CPSubsystem
com.hazelcast.config.matcher - package com.hazelcast.config.matcher
Provides implementations for ConfigPatternMatcher.
com.hazelcast.config.properties - package com.hazelcast.config.properties
This package contains the public API for properties defined in the XML configuration.
com.hazelcast.config.replacer - package com.hazelcast.config.replacer
This package contains the public API and default implementation of variable replacers for configuration files.
com.hazelcast.config.replacer.spi - package com.hazelcast.config.replacer.spi
This package contains the SPI for configuration files variable replacers.
com.hazelcast.config.yaml - package com.hazelcast.config.yaml
Contains adapter and utility classes needed to adapt YAML DOM classes as W3C DOM ones, making config builders that accept W3C DOM able to build the config structure from YAML.
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 the CP subsystem
com.hazelcast.cp.exception - package com.hazelcast.cp.exception
Contains exceptions that can be thrown by APIs of the CP subsystem
com.hazelcast.cp.lock - package com.hazelcast.cp.lock
Contains locking APIs of the CP subsystem
com.hazelcast.cp.lock.exception - package com.hazelcast.cp.lock.exception
Contains exception classes related to the locking API of the CP subsystem
com.hazelcast.cp.session - package com.hazelcast.cp.session
Contains session abstractions of the CP subsystem
com.hazelcast.crdt - package com.hazelcast.crdt
This package contains 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 implementation.
com.hazelcast.crdt.pncounter.operations - package com.hazelcast.crdt.pncounter.operations
Contains the operations for the PNCounter member-side implementation.
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.flakeidgen - package com.hazelcast.flakeidgen
This package contains Flake ID Generator functionality for Hazelcast.
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
Classes intended to be used for accumulator objects in an AggregateOperation.
com.hazelcast.jet.aggregate - package com.hazelcast.jet.aggregate
Contains AggregateOperation and several its variants, as well as a builder object for the aggregate operations.
com.hazelcast.jet.avro - package com.hazelcast.jet.avro
Apache Avro file read/write support for Hazelcast Jet.
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.hadoop - package com.hazelcast.jet.hadoop
Apache Hadoop HDFS read/write support for Hazelcast Jet.
com.hazelcast.jet.kafka - package com.hazelcast.jet.kafka
Apache Kafka reader/writer support for Hazelcast Jet.
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.test - package com.hazelcast.jet.pipeline.test
This package contains various mock sources to help with pipeline testing and development.
com.hazelcast.jet.s3 - package com.hazelcast.jet.s3
AWS S3 read/write support for Hazelcast Jet.
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.jet.spring - package com.hazelcast.jet.spring
Spring integration for Hazelcast Jet
com.hazelcast.json - package com.hazelcast.json
Contains Json interface
com.hazelcast.logging - package com.hazelcast.logging
This package contains logging functionality for Hazelcast.
Since Hazelcast has a zero dependency policy, Hazelcast provides a logging abstraction like commons logging, so that different logging frameworks like log4j, can be hooked in.
com.hazelcast.map - package com.hazelcast.map
Contains Hazelcast map module classes.
com.hazelcast.map.eviction - package com.hazelcast.map.eviction
This package contains eviction specific classes.
com.hazelcast.map.journal - package com.hazelcast.map.journal
Contains EventJournal event interface for IMap.
com.hazelcast.map.listener - package com.hazelcast.map.listener
Contains various MapListener interfaces.
com.hazelcast.map.merge - package com.hazelcast.map.merge
Contains out-of-the-box merge policies for IMap.
com.hazelcast.mapreduce - package com.hazelcast.mapreduce
This package contains the MapReduce API definition for Hazelcast.
All map reduce operations running in a distributed manner inside the active Hazelcast cluster.
com.hazelcast.mapreduce.aggregation - package com.hazelcast.mapreduce.aggregation
This package contains the aggregation API and the convenience helper classes to retrieve predefined aggregation implementations.
com.hazelcast.memory - package com.hazelcast.memory
Provides classes/interfaces for memory utilities, heap/native memory storage support.
com.hazelcast.monitor - package com.hazelcast.monitor
Contains Hazelcast statistics interfaces related to map, queue, topic, multimap, executor service etc.
com.hazelcast.nio - package com.hazelcast.nio
This package contains classes related to New IO
com.hazelcast.nio.ascii - package com.hazelcast.nio.ascii
Contains SocketTextReader and SocketTextWriter classes;
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.nio.tcp - package com.hazelcast.nio.tcp
Contains functionality for the TCP/IP Networking for cluster members
This whole package is internal and no compatibility will be provided.
com.hazelcast.org.snakeyaml.engine.external.biz.base64Coder - package com.hazelcast.org.snakeyaml.engine.external.biz.base64Coder
 
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.v1.api - package com.hazelcast.org.snakeyaml.engine.v1.api
 
com.hazelcast.org.snakeyaml.engine.v1.api.lowlevel - package com.hazelcast.org.snakeyaml.engine.v1.api.lowlevel
 
com.hazelcast.org.snakeyaml.engine.v1.common - package com.hazelcast.org.snakeyaml.engine.v1.common
 
com.hazelcast.org.snakeyaml.engine.v1.composer - package com.hazelcast.org.snakeyaml.engine.v1.composer
 
com.hazelcast.org.snakeyaml.engine.v1.constructor - package com.hazelcast.org.snakeyaml.engine.v1.constructor
 
com.hazelcast.org.snakeyaml.engine.v1.emitter - package com.hazelcast.org.snakeyaml.engine.v1.emitter
 
com.hazelcast.org.snakeyaml.engine.v1.events - package com.hazelcast.org.snakeyaml.engine.v1.events
 
com.hazelcast.org.snakeyaml.engine.v1.exceptions - package com.hazelcast.org.snakeyaml.engine.v1.exceptions
 
com.hazelcast.org.snakeyaml.engine.v1.nodes - package com.hazelcast.org.snakeyaml.engine.v1.nodes
 
com.hazelcast.org.snakeyaml.engine.v1.parser - package com.hazelcast.org.snakeyaml.engine.v1.parser
 
com.hazelcast.org.snakeyaml.engine.v1.representer - package com.hazelcast.org.snakeyaml.engine.v1.representer
 
com.hazelcast.org.snakeyaml.engine.v1.resolver - package com.hazelcast.org.snakeyaml.engine.v1.resolver
 
com.hazelcast.org.snakeyaml.engine.v1.scanner - package com.hazelcast.org.snakeyaml.engine.v1.scanner
 
com.hazelcast.org.snakeyaml.engine.v1.serializer - package com.hazelcast.org.snakeyaml.engine.v1.serializer
 
com.hazelcast.org.snakeyaml.engine.v1.tokens - package com.hazelcast.org.snakeyaml.engine.v1.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.membergroup - package com.hazelcast.partition.membergroup
todo
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.quorum - package com.hazelcast.quorum
Contains classes related to cluster quorum.
com.hazelcast.replicatedmap - package com.hazelcast.replicatedmap
Classes for replicated map.
com.hazelcast.replicatedmap.merge - package com.hazelcast.replicatedmap.merge
Contains out-of-the-box merge policies for ReplicatedMap.
com.hazelcast.ringbuffer - package com.hazelcast.ringbuffer
Contains the API for the Ringbuffer.
com.hazelcast.scheduledexecutor - package com.hazelcast.scheduledexecutor
This package contains ScheduledExecutorService functionality for Hazelcast.
com.hazelcast.security - package com.hazelcast.security
Provides interfaces/classes for Hazelcast security implementation.
com.hazelcast.security.jsm - package com.hazelcast.security.jsm
Contains Java Security Manager permissions.
com.hazelcast.security.permission - package com.hazelcast.security.permission
Contains Hazelcast client permissions.
com.hazelcast.spi - package com.hazelcast.spi
Provides interfaces/classes for the Hazelcast SPI for building distributed data structures and services.
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.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.partition - package com.hazelcast.spi.partition
Contains the SPI for partition logic for Hazelcast.
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.serialization - package com.hazelcast.spi.serialization
Contains SPI related to serialization
com.hazelcast.spi.tenantcontrol - package com.hazelcast.spi.tenantcontrol
Classes for tenant control
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.util - package com.hazelcast.util
This package contains classes to support the inner workings of Hazelcast as well as some backports of newer Java features / data structures to support older Java versions in a clean and nice way.
com.hazelcast.util.collection - package com.hazelcast.util.collection
The Agrona project backport: collections.
com.hazelcast.util.concurrent - package com.hazelcast.util.concurrent
Abstractions that deal with common needs in concurrent programming.
com.hazelcast.util.executor - package com.hazelcast.util.executor
This package contains classes related to Util.Executor
com.hazelcast.util.function - package com.hazelcast.util.function
Backport of Java 8 functional interfaces which Agrona depends on.
com.hazelcast.util.scheduler - package com.hazelcast.util.scheduler
This package contains scheduler classes for Util
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
com.hazelcast.wan.merkletree - package com.hazelcast.wan.merkletree
This package contains Merkle tree based anti-entropy implementation
combine(Aggregator) - Method in class 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(ValueIn) - Method in class com.hazelcast.mapreduce.Combiner
Deprecated.
This method is called to supply values to be combined into an intermediate result chunk.
The combine method might be called multiple times so the combined chunk needs to be held internally in a member state of the Combiner.
After this method is called you need to Combiner.reset() the internal state to prepare for combining of the next chunk.
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 provided aggregate operation on all the items it receives.
Combiner<ValueIn,ValueOut> - Class in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
Combiner() - Constructor for class com.hazelcast.mapreduce.Combiner
Deprecated.
 
combiner(CombinerFactory<? super KeyIn, ? super ValueIn, ? extends ValueOut>) - Method in interface com.hazelcast.mapreduce.MappingJob
Deprecated.
Defines the CombinerFactory for this task.
CombinerFactory<KeyIn,ValueIn,ValueOut> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
combineToInt(short, short) - Static method in class com.hazelcast.nio.Bits
Combines two short integer values into an integer.
combineToLong(int, int) - Static method in class com.hazelcast.nio.Bits
Combines two integer values into a long integer.
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).
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
 
commitMigration(PartitionMigrationEvent) - Method in interface com.hazelcast.spi.MigrationAwareService
Commits the migration process for this service, on both source and destination members.
commitTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
Commits a transaction.
compact() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
 
compact() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
Compact the Map backing arrays by rehashing with a capacity just larger than current size and giving consideration to the load factor.
compact() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
Compact the Map backing arrays by rehashing with a capacity just larger than current size and giving consideration to the load factor.
compactOrClear(ByteBuffer) - Static method in class com.hazelcast.nio.IOUtil
Compacts or clears the buffer depending if bytes are remaining in the byte-buffer.
comparableMax() - Static method in class com.hazelcast.aggregation.Aggregators
 
comparableMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
comparableMax() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to find the maximum value of all supplied Comparable implementing values.
This aggregation is similar to:
comparableMin() - Static method in class com.hazelcast.aggregation.Aggregators
 
comparableMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
comparableMin() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to find the minimum value of all supplied Comparable implementing values.
This aggregation is similar to:
comparator - Variable in class com.hazelcast.config.EvictionConfig
 
comparatorClassName - Variable in class com.hazelcast.config.EvictionConfig
 
ComparatorEx<T> - Interface in com.hazelcast.jet.function
Serializable variant of java.util.Comparator which declares checked exception.
compare(CacheEntryView<K, V>, CacheEntryView<K, V>) - Method in class com.hazelcast.cache.CacheEvictionPolicyComparator
Compares the given EvictableEntryView instances and returns the result.
compare(T, T) - Method in interface com.hazelcast.jet.function.ComparatorEx
 
compare(EntryView, EntryView) - Method in class com.hazelcast.map.eviction.LFUEvictionPolicy
 
compare(EntryView, EntryView) - Method in class com.hazelcast.map.eviction.LRUEvictionPolicy
 
compare(EntryView<K, V>, EntryView<K, V>) - Method in class com.hazelcast.map.eviction.MapEvictionPolicy
compare(EntryView, EntryView) - Method in class com.hazelcast.map.eviction.RandomEvictionPolicy
 
compare(Comparator<Map.Entry>, IterationType, Map.Entry, Map.Entry) - Static method in class com.hazelcast.util.SortingUtil
 
COMPARE_AND_SET - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
COMPARE_AND_SET - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
compareAnchor(PagingPredicate, QueryableEntry, Map.Entry<Integer, Map.Entry>) - Static method in class com.hazelcast.util.SortingUtil
 
compareAndSet(long, long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongContainer
 
compareAndSet(long, long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
compareAndSet(Data, Data) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceContainer
 
compareAndSet(E, E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
compareAndSet(long, long) - Method in interface com.hazelcast.core.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.core.IAtomicReference
Atomically sets the value to the given updated value only if the current value == the expected value.
compareAndSetAsync(long, long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
compareAndSetAsync(E, E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
compareAndSetAsync(long, long) - Method in interface com.hazelcast.core.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.core.IAtomicReference
Atomically sets the value to the given updated value only if the current value == the expected value.
CompareAndSetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
CompareAndSetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
 
CompareAndSetOperation(String, long, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
 
CompareAndSetOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
CompareAndSetOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
 
CompareAndSetOperation(String, Data, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
 
compareDocumentPosition(Node) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
compareEx(T, T) - Method in interface com.hazelcast.jet.function.ComparatorEx
Exception-declaring version of Comparator.compare(T, T).
compareIntegers(int, int) - Static method in class com.hazelcast.util.QuickMath
Compares two integers
compareLongs(long, long) - Static method in class com.hazelcast.util.QuickMath
Compares two longs
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
 
compareTrees(MerkleTreeView, MerkleTreeView) - Static method in class com.hazelcast.wan.merkletree.MerkleTreeUtil
Compares the provided local and the remote Merkle trees and returns the breadth-first orders of the leaves that found to be different.
comparing(Function<? super T, ? extends U>, Comparator<? super U>) - Static method in interface com.hazelcast.jet.function.ComparatorEx
comparing(FunctionEx<? super T, ? extends U>, ComparatorEx<? super U>) - Static method in interface com.hazelcast.jet.function.ComparatorEx
comparing(Function<? super T, ? extends U>) - Static method in interface com.hazelcast.jet.function.ComparatorEx
comparing(FunctionEx<? super T, ? extends U>) - Static method in interface com.hazelcast.jet.function.ComparatorEx
comparingDouble(ToDoubleFunction<? super T>) - Static method in interface com.hazelcast.jet.function.ComparatorEx
comparingDouble(ToDoubleFunctionEx<? super T>) - Static method in interface com.hazelcast.jet.function.ComparatorEx
comparingInt(ToIntFunction<? super T>) - Static method in interface com.hazelcast.jet.function.ComparatorEx
comparingInt(ToIntFunctionEx<? super T>) - Static method in interface com.hazelcast.jet.function.ComparatorEx
comparingLong(ToLongFunction<? super T>) - Static method in interface com.hazelcast.jet.function.ComparatorEx
comparingLong(ToLongFunctionEx<? super T>) - Static method in interface com.hazelcast.jet.function.ComparatorEx
COMPATIBILITY_3_6_CLIENT_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
When this property is true, if the server can not determine the connected client version, it shall assume that it is of 3.6.x version client.
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.
CompletableFutureTask<V> - Class in com.hazelcast.util.executor
 
CompletableFutureTask(Callable<V>, ExecutorService) - Constructor for class com.hazelcast.util.executor.CompletableFutureTask
 
CompletableFutureTask(Runnable, V, ExecutorService) - Constructor for class com.hazelcast.util.executor.CompletableFutureTask
 
complete() - Method in interface com.hazelcast.jet.core.Processor
Called after all the inbound edges' streams are exhausted.
complete(Object) - Method in interface com.hazelcast.spi.InternalCompletableFuture
Completes this future.
complete(Object) - Method in class com.hazelcast.util.executor.CompletedFuture
 
complete(Object) - Method in class com.hazelcast.util.executor.DelegatingFuture
 
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.
CompletedFuture<V> - Class in com.hazelcast.util.executor
 
CompletedFuture(SerializationService, Object, Executor) - Constructor for class com.hazelcast.util.executor.CompletedFuture
 
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.jet.function.FunctionEx
Compose - Class in com.hazelcast.org.snakeyaml.engine.v1.api.lowlevel
 
Compose(LoadSettings) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.api.lowlevel.Compose
Create instance with provided LoadSettings
composeAllFromInputStream(InputStream) - Method in class com.hazelcast.org.snakeyaml.engine.v1.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.v1.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.v1.api.lowlevel.Compose
Parse all YAML documents in a stream and produce corresponding representation trees.
ComposedKeyMap<K1,K2,V> - Class in com.hazelcast.util.collection
Map with a composed key.
ComposedKeyMap() - Constructor for class com.hazelcast.util.collection.ComposedKeyMap
 
composeInputStream(InputStream) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.lowlevel.Compose
Parse a YAML stream and produce Node
composeKeyNode(MappingNode) - Method in class com.hazelcast.org.snakeyaml.engine.v1.composer.Composer
 
composeMappingChildren(List<NodeTuple>, MappingNode) - Method in class com.hazelcast.org.snakeyaml.engine.v1.composer.Composer
 
composeMappingNode(Optional<Anchor>) - Method in class com.hazelcast.org.snakeyaml.engine.v1.composer.Composer
 
Composer - Class in com.hazelcast.org.snakeyaml.engine.v1.composer
Creates a node graph from parser events.
Composer(Parser, ScalarResolver) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.composer.Composer
 
composeReader(Reader) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.lowlevel.Compose
Parse a YAML stream and produce Node
ComposerException - Exception in com.hazelcast.org.snakeyaml.engine.v1.exceptions
 
ComposerException(String, Optional<Mark>, String, Optional<Mark>) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v1.exceptions.ComposerException
 
ComposerException(String, Optional<Mark>) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v1.exceptions.ComposerException
 
composeScalarNode(Optional<Anchor>) - Method in class com.hazelcast.org.snakeyaml.engine.v1.composer.Composer
 
composeSequenceNode(Optional<Anchor>) - Method in class com.hazelcast.org.snakeyaml.engine.v1.composer.Composer
 
composeString(String) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.lowlevel.Compose
Parse a YAML stream and produce Node
composeValueNode(MappingNode) - Method in class com.hazelcast.org.snakeyaml.engine.v1.composer.Composer
 
compress(byte[]) - Static method in class com.hazelcast.nio.IOUtil
 
computeIfAbsent(int, IntFunction<? extends V>) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
Get a value for a given key, or if it does ot exist then default the value via a IntFunction and put it in the map.
computeIfAbsent(long, LongFunction<? extends V>) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
Get a value for a given key, or if it does ot exist then default the value via a LongFunction and put it in the map.
computePerturbationValue(int) - Static method in class com.hazelcast.util.HashUtil
Computes the key perturbation value applied before hashing.
concat(T[], T[], T[]) - Static method in class com.hazelcast.util.collection.ArrayUtils
Copies in order sourceFirst and sourceSecond into dest.
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.
ConcurrencyUtil - Class in com.hazelcast.util
Utility methods to getOrPutSynchronized and getOrPutIfAbsent in a thread safe way from a ConcurrentMap with a ConstructorFunction.
ConcurrentReferenceHashMap<K,V> - Class in com.hazelcast.util
An advanced hash table supporting configurable garbage collection semantics of keys and values, optional referential-equality, full concurrency of retrievals, and adjustable expected concurrency for updates.
ConcurrentReferenceHashMap(int, float, int, ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType, EnumSet<ConcurrentReferenceHashMap.Option>) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
Creates a new, empty map with the specified initial capacity, reference types, load factor, and concurrency level.
ConcurrentReferenceHashMap(int, float, int) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
Creates a new, empty map with the specified initial capacity, load factor, and concurrency level.
ConcurrentReferenceHashMap(int, float) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
Creates a new, empty map with the specified initial capacity and load factor and with the default reference types (weak keys, strong values), and concurrencyLevel (16).
ConcurrentReferenceHashMap(int, ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
Creates a new, empty map with the specified initial capacity, reference types, and with a default load factor (0.75) and concurrencyLevel (16).
ConcurrentReferenceHashMap(ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
Creates a new, empty reference map with the specified key and value reference types.
ConcurrentReferenceHashMap(ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType, EnumSet<ConcurrentReferenceHashMap.Option>) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
Creates a new, empty reference map with the specified reference types and behavioral options.
ConcurrentReferenceHashMap(int) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
Creates a new, empty map with the specified initial capacity, and with default reference types (weak keys, strong values), load factor (0.75) and concurrencyLevel (16).
ConcurrentReferenceHashMap() - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
Creates a new, empty map with a default initial capacity (16), reference types (weak keys, strong values), default load factor (0.75) and concurrencyLevel (16).
ConcurrentReferenceHashMap(Map<? extends K, ? extends V>) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
Creates a new map with the same mappings as the given map.
ConcurrentReferenceHashMap.Option - Enum in com.hazelcast.util
Behavior-changing configuration options for the map
ConcurrentReferenceHashMap.ReferenceType - Enum in com.hazelcast.util
An option specifying which Java reference type should be used to refer to a key and/or value.
ConcurrentReferenceHashMap.SimpleEntry<K,V> - Class in com.hazelcast.util
 
ConcurrentReferenceHashMap.WriteThroughEntry - Class in com.hazelcast.util
Custom Entry class used by EntryIterator.next(), that relays setValue changes to the underlying map.
ConditionKey - Class in com.hazelcast.concurrent.lock
 
ConditionKey(String, Data, String, String, long) - Constructor for class com.hazelcast.concurrent.lock.ConditionKey
 
Config - Class in com.hazelcast.config
Contains all the configuration to start a HazelcastInstance.
Config() - Constructor for class com.hazelcast.config.Config
 
Config(String) - Constructor for class com.hazelcast.config.Config
 
config - Variable in class com.hazelcast.instance.Node
 
ConfigAccessor - Class in com.hazelcast.config
Private API for accessing configuration at runtime
ConfigBuilder - Interface in com.hazelcast.config
Interface for all config builders.
ConfigDataSerializerHook - Class in com.hazelcast.config
DataSerializerHook for com.hazelcast.config classes
ConfigDataSerializerHook() - Constructor for class com.hazelcast.config.ConfigDataSerializerHook
 
ConfigLoader - Class in com.hazelcast.config
Provides loading service for a configuration.
ConfigMemberGroupFactory - Class in com.hazelcast.partition.membergroup
 
ConfigMemberGroupFactory(Collection<MemberGroupConfig>) - Constructor for class com.hazelcast.partition.membergroup.ConfigMemberGroupFactory
 
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
 
ConfigReplacer - Interface in com.hazelcast.config.replacer.spi
Interface to be implemented by pluggable variable replacers for the configuration files.
ConfigurableService<T> - Interface in com.hazelcast.spi
A capability for SPI services.
ConfigurationException - Exception in com.hazelcast.config
A HazelcastException that is thrown when something is wrong with the server or client configuration.
ConfigurationException(String, String, String) - Constructor for exception com.hazelcast.config.ConfigurationException
 
ConfigurationException(String) - Constructor for exception com.hazelcast.config.ConfigurationException
 
ConfigurationException(String, Throwable) - Constructor for exception com.hazelcast.config.ConfigurationException
 
configure(JsonFactory.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(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(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(GroupConfig, Properties) - Method in interface com.hazelcast.security.ICredentialsFactory
configure(Config, Properties) - Method in interface com.hazelcast.security.IPermissionPolicy
Configures IPermissionPolicy.
configure(T) - Method in interface com.hazelcast.spi.ConfigurableService
 
configureLogging() - Static method in class com.hazelcast.jet.server.StartServer
 
ConfigXmlGenerator - Class in com.hazelcast.config
The ConfigXmlGenerator is responsible for transforming a Config to a Hazelcast XML string.
ConfigXmlGenerator() - Constructor for class com.hazelcast.config.ConfigXmlGenerator
Creates a ConfigXmlGenerator that will format the code.
ConfigXmlGenerator(boolean) - Constructor for class com.hazelcast.config.ConfigXmlGenerator
Creates a ConfigXmlGenerator.
ConfigXmlGenerator(boolean, boolean) - Constructor for class com.hazelcast.config.ConfigXmlGenerator
Creates a ConfigXmlGenerator.
ConfigXmlGenerator.XmlGenerator - Class in com.hazelcast.config
Utility class to build xml using a StringBuilder.
CONNECT_ALL_WAIT_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
Connection - Interface in com.hazelcast.nio
Represents a 'connection' between two machines.
connection - Variable in class com.hazelcast.nio.tcp.PacketDecoder
 
CONNECTION_MONITOR_INTERVAL - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
CONNECTION_MONITOR_MAX_FAULTS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
connectionAdded(Connection) - Method in interface com.hazelcast.nio.ConnectionListener
 
connectionFn(FunctionEx<ConnectionFactory, Connection>) - Method in class com.hazelcast.jet.pipeline.JmsSinkBuilder
Sets the function which creates the connection from connection factory.
connectionFn(FunctionEx<? super ConnectionFactory, ? extends Connection>) - Method in class com.hazelcast.jet.pipeline.JmsSourceBuilder
Sets the function which creates the connection from connection factory.
ConnectionLifecycleListener<T extends Connection> - Interface in com.hazelcast.nio
 
ConnectionListenable - Interface in com.hazelcast.nio
Provides connection listen capabilities.
ConnectionListener - Interface in com.hazelcast.nio
A listener for the EndpointManager to listen to connections being added or removed.
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.
connectionRemoved(Connection) - Method in interface com.hazelcast.nio.ConnectionListener
 
ConnectionType - Enum in com.hazelcast.nio
An enumeration of all possible Connection types.
consistencyCheck(String, String, String) - Method in interface com.hazelcast.wan.WanReplicationService
Initiate WAN consistency check for a specific map.
ConsistencyCheckResult - Class in com.hazelcast.wan.merkletree
Result of the last WAN consistency check result
ConsistencyCheckResult() - Constructor for class com.hazelcast.wan.merkletree.ConsistencyCheckResult
 
ConsistencyCheckResult(int, int, int, int, int) - Constructor for class com.hazelcast.wan.merkletree.ConsistencyCheckResult
Constructs the result of the WAN consistency check comparison
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) - Constructor for class com.hazelcast.console.ConsoleApp
 
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.v1.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.v1.constructor.BaseConstructor
Construct complete YAML document.
construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructOptionalClass
 
construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructUndefined
 
construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructUuidClass
 
construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructYamlBinary
 
construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructYamlBool
 
construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructYamlFloat
 
construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructYamlInt
 
construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructYamlMap
 
construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructYamlNull
 
construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructYamlOmap
 
construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructYamlSeq
 
construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructYamlSet
 
construct(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructYamlStr
 
constructMapping(MappingNode) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.BaseConstructor
 
constructMapping2ndStep(MappingNode, Map<Object, Object>) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.BaseConstructor
 
constructMapping2ndStep(MappingNode, Map<Object, Object>) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor
 
ConstructNode - Interface in com.hazelcast.org.snakeyaml.engine.v1.api
Provide a way to construct a Java instance from the composed Node.
constructObject(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.BaseConstructor
Construct object from the specified Node.
constructObjectNoCheck(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.BaseConstructor
 
ConstructOptionalClass() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructOptionalClass
 
ConstructorException - Exception in com.hazelcast.org.snakeyaml.engine.v1.exceptions
 
ConstructorException(String, Optional<Mark>, String, Optional<Mark>, Throwable) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v1.exceptions.ConstructorException
 
ConstructorException(String, Optional<Mark>, String, Optional<Mark>) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v1.exceptions.ConstructorException
 
ConstructorFunction<K,V> - Interface in com.hazelcast.util
See ConcurrencyUtil
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.v1.api.ConstructNode
Apply the second step when constructing recursive structures.
constructRecursive(Node, Object) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructYamlMap
 
constructRecursive(Node, Object) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructYamlSeq
 
constructRecursive(Node, Object) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructYamlSet
 
constructScalar(ScalarNode) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.BaseConstructor
 
constructSequence(SequenceNode) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.BaseConstructor
 
constructSequenceStep2(SequenceNode, Collection<Object>) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.BaseConstructor
 
constructSet(MappingNode) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.BaseConstructor
 
constructSet2ndStep(MappingNode, Set<Object>) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.BaseConstructor
 
constructSet2ndStep(MappingNode, Set<Object>) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor
 
constructSingleDocument(Optional<Node>) - Method in class com.hazelcast.org.snakeyaml.engine.v1.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
 
ConstructUndefined() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructUndefined
 
ConstructUuidClass() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructUuidClass
 
ConstructYamlBinary() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructYamlBinary
 
ConstructYamlBool() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructYamlBool
 
ConstructYamlFloat() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructYamlFloat
 
ConstructYamlInt() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructYamlInt
 
ConstructYamlMap() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructYamlMap
 
ConstructYamlNull() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructYamlNull
 
ConstructYamlOmap() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructYamlOmap
 
ConstructYamlSeq() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructYamlSeq
 
ConstructYamlSet() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructYamlSet
 
ConstructYamlStr() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor.ConstructYamlStr
 
Consumer<T> - Interface in com.hazelcast.util.function
Represents an operation that accepts a single input argument and returns no result.
ConsumerEx<T> - Interface in com.hazelcast.jet.function
Serializable variant of java.util.function.Consumer which declares checked exception.
consumerFn(FunctionEx<? super Session, ? extends MessageConsumer>) - Method in class com.hazelcast.jet.pipeline.JmsSourceBuilder
Sets the function which creates the message consumer from session.
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.
CONTAINER - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
 
CONTAINER - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
contains(Data) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceContainer
 
CONTAINS - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
contains(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
contains(E) - Method in interface com.hazelcast.core.IAtomicReference
Checks if the reference contains the value.
contains(T[], T) - Static method in class com.hazelcast.util.collection.ArrayUtils
 
contains(Object) - Method in class com.hazelcast.util.collection.InflatableSet
 
contains(Object) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.KeySet
 
contains(int) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.KeySet
Non-boxing variant of contains().
contains(Object) - Method in class com.hazelcast.util.collection.IntHashSet
 
contains(int) - Method in class com.hazelcast.util.collection.IntHashSet
 
contains(Object) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.KeySet
 
contains(long) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.KeySet
Non-boxing variant of contains().
contains(Object) - Method in class com.hazelcast.util.collection.LongHashSet
contains(long) - Method in class com.hazelcast.util.collection.LongHashSet
contains(Object) - Method in class com.hazelcast.util.collection.MapDelegatingSet
contains(Object) - Method in class com.hazelcast.util.collection.OAHashSet
 
contains(Object, int) - Method in class com.hazelcast.util.collection.OAHashSet
Returns true if this set contains the specified element with the hash provided in parameter.
contains(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
Legacy method testing if some key maps into the specified value in this table.
containsAll(Collection<?>) - Method in class com.hazelcast.util.collection.IntHashSet
 
containsAll(IntHashSet) - Method in class com.hazelcast.util.collection.IntHashSet
IntHashSet specialised variant of {this#containsAll(Collection)}.
containsAll(Collection<?>) - Method in class com.hazelcast.util.collection.LongHashSet
containsAll(LongHashSet) - Method in class com.hazelcast.util.collection.LongHashSet
LongHashSet specialised variant of {this#containsAll(Collection)}.
containsAsync(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
containsAsync(E) - Method in interface com.hazelcast.core.IAtomicReference
Checks if the reference contains the value.
containsAtomicLong(String) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
 
containsCounter(String) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
Returns true if the CRDT state for the PN counter with the given name is present on this node.
containsEntry(K, V) - Method in interface com.hazelcast.core.MultiMap
Returns whether the multimap contains the given key-value pair.
containsKey(Object) - Method in interface com.hazelcast.core.BaseMap
Returns true if this map contains an entry for the specified key.
containsKey(Object) - Method in interface com.hazelcast.core.IMap
Returns true if this map contains an entry for the specified key.
containsKey(K) - Method in interface com.hazelcast.core.MultiMap
Returns whether the multimap contains an entry with the key.
containsKey(Object) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.containsKey(Object).
containsKey(Object) - Method in interface com.hazelcast.map.QueryCache
 
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 class com.hazelcast.util.collection.Int2ObjectHashMap
 
containsKey(int) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
Overloaded version of Map.containsKey(Object) that takes a primitive int key.
containsKey(long) - Method in class com.hazelcast.util.collection.Long2LongHashMap
Long primitive specialised containsKey.
containsKey(Object) - Method in class com.hazelcast.util.collection.Long2LongHashMap
 
containsKey(Object) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
 
containsKey(long) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
Overloaded version of Map.containsKey(Object) that takes a primitive long key.
containsKey(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
Tests if the specified object is a key in this table.
containsLatch(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
ContainsOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
ContainsOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.ContainsOperation
 
ContainsOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.ContainsOperation
 
containsReferenceContainer(String) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
 
containsSemaphore(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
 
containsTag(String) - Static method in class com.hazelcast.jet.core.metrics.MeasurementPredicates
Matches a Measurement which contain the specified tag.
containsValue(Object) - Method in interface com.hazelcast.core.IMap
containsValue(Object) - Method in interface com.hazelcast.core.MultiMap
Returns whether the multimap contains an entry with the value.
containsValue(Object) - Method in interface com.hazelcast.map.QueryCache
 
containsValue(Object) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
 
containsValue(long) - Method in class com.hazelcast.util.collection.Long2LongHashMap
 
containsValue(Object) - Method in class com.hazelcast.util.collection.Long2LongHashMap
 
containsValue(Object) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
 
containsValue(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
Returns true if this map maps one or more keys to the specified 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
 
contentsToWriter(Writer) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
 
Context<K,V> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
ContextFactories - Class in com.hazelcast.jet.pipeline
Utility class with methods that create several useful context factories.
ContextFactory<C> - Class in com.hazelcast.jet.pipeline
A holder of functions needed to create and destroy a context object.
ContextMutexFactory - Class in com.hazelcast.util
Provides reference-counted mutexes suitable for synchronization in the context of a supplied object.
ContextMutexFactory() - Constructor for class com.hazelcast.util.ContextMutexFactory
 
ContextMutexFactory.Mutex - Class in com.hazelcast.util
Reference counted mutex, which will remove itself from the mutexMap when it is no longer referenced.
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
Compares a Comparable typed value to another one.
convert(long, MemoryUnit) - Method in enum com.hazelcast.memory.MemoryUnit
 
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 UTF codepoint, from a surrogate pair.
convertToEventType(CacheEventType) - Static method in enum com.hazelcast.cache.CacheEventType
Converts a CacheEventType into EventType.
convertToLetter(int) - Method in class com.hazelcast.util.PhoneHome
 
COOPERATIVE_DEFAULT - Static variable in class com.hazelcast.jet.pipeline.ContextFactory
Default value for ContextFactory.isCooperative.
COOPERATIVE_WORKER - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
Index of the cooperative worker in a fixed worker pool sourcing the metric.
cooperativeTimeout(long) - Method in class com.hazelcast.jet.core.test.TestSupport
If timeout > 0, the test will fail if any call to processing method in a cooperative processor exceeds this timeout.
copy() - Method in class com.hazelcast.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(File, File) - Static method in class com.hazelcast.nio.IOUtil
Deep copies source to target and creates the target if necessary.
copy(InputStream, File) - Static method in class com.hazelcast.nio.IOUtil
Deep copies source to target.
copy(IntHashSet) - Method in class com.hazelcast.util.collection.IntHashSet
 
copy(LongHashSet) - Method in class com.hazelcast.util.collection.LongHashSet
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
 
copyFile(File, File, long) - Static method in class com.hazelcast.nio.IOUtil
Copies source file to target and creates the target if necessary.
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
 
copyTo(byte[], int) - Method in interface com.hazelcast.nio.serialization.Data
Copies the payload contained in the Data to the destination buffer.
copyToHeapBuffer(ByteBuffer, ByteBuffer) - Static method in class com.hazelcast.nio.IOUtil
 
copyWithoutNulls(T[], T[]) - Static method in class com.hazelcast.util.collection.ArrayUtils
Copy src array into destination and skip null values.
CoreService - Interface in com.hazelcast.spi
Marker interface for core Hazelcast services.
count() - Static method in class com.hazelcast.aggregation.Aggregators
 
count(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
count() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation for counting all supplied values.
This aggregation is similar to:
COUNT_DOWN_LATCH_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
 
COUNT_DOWN_LATCH_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
COUNT_DOWN_LATCH_REPLICATION_OPERATION - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
 
COUNT_DOWN_OPERATION - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
 
countDown() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
 
countDown() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
 
countDown(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
countDown() - Method in interface com.hazelcast.core.ICountDownLatch
Decrements the count of the latch, releasing all waiting threads if the count reaches zero.
CountDownLatchBackupOperation - Class in com.hazelcast.concurrent.countdownlatch.operations
 
CountDownLatchBackupOperation() - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
 
CountDownLatchBackupOperation(String, int) - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
 
CountDownLatchConfig - Class in com.hazelcast.config
Contains the configuration for an ICountDownLatch.
CountDownLatchConfig() - Constructor for class com.hazelcast.config.CountDownLatchConfig
Creates a default configured CountDownLatchConfig.
CountDownLatchConfig(String) - Constructor for class com.hazelcast.config.CountDownLatchConfig
Creates a default configured CountDownLatchConfig setting its name to the given name.
CountDownLatchConfig(CountDownLatchConfig) - Constructor for class com.hazelcast.config.CountDownLatchConfig
Creates a CountDownLatchConfig by cloning another one.
CountDownLatchContainer - Class in com.hazelcast.concurrent.countdownlatch
 
CountDownLatchContainer() - Constructor for class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
 
CountDownLatchContainer(String) - Constructor for class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
 
CountDownLatchDataSerializerHook - Class in com.hazelcast.concurrent.countdownlatch
 
CountDownLatchDataSerializerHook() - Constructor for class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
 
CountDownLatchPermission - Class in com.hazelcast.security.permission
 
CountDownLatchPermission(String, String...) - Constructor for class com.hazelcast.security.permission.CountDownLatchPermission
 
CountDownLatchProxy - Class in com.hazelcast.concurrent.countdownlatch
 
CountDownLatchProxy(String, NodeEngine) - Constructor for class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
 
CountDownLatchReplicationOperation - Class in com.hazelcast.concurrent.countdownlatch.operations
 
CountDownLatchReplicationOperation() - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
 
CountDownLatchReplicationOperation(Collection<CountDownLatchContainer>) - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
 
CountDownLatchService - Class in com.hazelcast.concurrent.countdownlatch
 
CountDownLatchService() - Constructor for class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
CountDownOperation - Class in com.hazelcast.concurrent.countdownlatch.operations
 
CountDownOperation() - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
 
CountDownOperation(String) - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
 
counting() - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that counts the items it observes.
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
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.
CPSemaphoreConfig - Class in com.hazelcast.config.cp
Contains configuration options for the CP ISemaphore
CPSemaphoreConfig() - Constructor for class com.hazelcast.config.cp.CPSemaphoreConfig
 
CPSemaphoreConfig(String) - Constructor for class com.hazelcast.config.cp.CPSemaphoreConfig
 
CPSemaphoreConfig(String, boolean) - Constructor for class com.hazelcast.config.cp.CPSemaphoreConfig
 
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
The public API for managing CP sessions.
CPSubsystem - Interface in com.hazelcast.cp
The CP subsystem is a component of a Hazelcast cluster that builds an in-memory strongly consistent layer.
CPSubsystemConfig - Class in com.hazelcast.config.cp
Contains configuration options for the CPSubsystem.
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 the CP subsystem
CPSubsystemException(Endpoint) - Constructor for exception com.hazelcast.cp.exception.CPSubsystemException
 
CPSubsystemException(String, Endpoint) - Constructor for exception com.hazelcast.cp.exception.CPSubsystemException
 
CPSubsystemException(String, Endpoint, Throwable) - Constructor for exception com.hazelcast.cp.exception.CPSubsystemException
 
CPSubsystemManagementService - Interface in com.hazelcast.cp
The public API for managing CP members and groups.
CRDT<T extends CRDT<T>> - Interface in com.hazelcast.crdt
Common interface for CRDT (conflict-free replicated data type) implementations.
CRDT_REPLICATION_MIGRATION_EXECUTOR - Static variable in class com.hazelcast.crdt.CRDTReplicationMigrationService
The executor for the CRDT replication and migration tasks
CRDT_TIMESTAMPED_LONG - Static variable in class com.hazelcast.crdt.CRDTDataSerializerHook
The constant for the PNCounter CRDTTimestampedLong
CRDTDataSerializerHook - Class in com.hazelcast.crdt
Serialization constants for all CRDT related objects
CRDTDataSerializerHook() - Constructor for class com.hazelcast.crdt.CRDTDataSerializerHook
 
CRDTReplicationAwareService<T> - Interface in com.hazelcast.crdt
Represents a service implementing a CRDT that may be replicated and migrated to other replicas of the same CRDT.
CRDTReplicationConfig - Class in com.hazelcast.config
Configures the replication mechanism for all CRDT implementations.
CRDTReplicationConfig() - Constructor for class com.hazelcast.config.CRDTReplicationConfig
 
CRDTReplicationContainer - Class in com.hazelcast.crdt
A container for a CRDT replication operation.
CRDTReplicationContainer(Operation, Map<String, VectorClock>) - Constructor for class com.hazelcast.crdt.CRDTReplicationContainer
 
CRDTReplicationMigrationService - Class in com.hazelcast.crdt
Service that handles replication and migration of CRDT data for all CRDT implementations.
CRDTReplicationMigrationService() - Constructor for class com.hazelcast.crdt.CRDTReplicationMigrationService
 
CRDTTimestampedLong - Class in com.hazelcast.crdt.pncounter.operations
Response for CRDT PN counter operations which contains the PN counter value as well as the current replica vector clock.
CRDTTimestampedLong() - Constructor for class com.hazelcast.crdt.pncounter.operations.CRDTTimestampedLong
 
CRDTTimestampedLong(long, VectorClock) - Constructor for class com.hazelcast.crdt.pncounter.operations.CRDTTimestampedLong
 
create(Node, List<String>) - Static method in class com.hazelcast.instance.NodeExtensionFactory
Uses the Hazelcast ServiceLoader to discover all registered NodeExtension classes and identify the one to instantiate and use as the provided node's extension.
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 given class ID
CREATE - Static variable in class com.hazelcast.security.permission.InstancePermission
 
create(Throwable, String) - Method in interface com.hazelcast.util.ExceptionUtil.RuntimeExceptionFactory
 
createAddressPicker(Node) - Method in class com.hazelcast.instance.DefaultNodeContext
 
createAddressPicker(Node) - Method in interface com.hazelcast.instance.NodeContext
 
createAndSetPhoneHome() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
createArray(Class<?>, int) - Method in class com.hazelcast.org.snakeyaml.engine.v1.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
 
createBackoffIdleStrategy(String) - Static method in class com.hazelcast.util.concurrent.BackoffIdleStrategy
Creates a new BackoffIdleStrategy.
createBackupEntryProcessor() - Method in interface com.hazelcast.cache.BackupAwareEntryProcessor
Either creates a new, specialized EntryProcessor to be executed on the backup-partition, or returns
createChannelInitializerProvider(IOService) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
createChannelInitializerProvider(IOService) - Method in interface com.hazelcast.instance.NodeExtension
Creates the ChannelInitializerProvider.
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
 
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
 
createClientLoginContext(Credentials) - Method in interface com.hazelcast.security.SecurityContext
Creates client LoginContext.
createClientUuid(Address) - Static method in class com.hazelcast.util.UuidUtil
Creates a new client UUID string, based on a cryptographically weak pseudo random number generator.
createClusterUuid() - Static method in class com.hazelcast.util.UuidUtil
Creates a new cluster UUID string, based on a cryptographically weak pseudo random number generator.
createComposer(LoadSettings, StreamReader) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.Load
 
createConcurrentHashMap(int) - Static method in class com.hazelcast.util.MapUtil
Utility method that creates an LinkedHashMap with its initialCapacity calculated to minimize rehash operations
createConcurrentSet() - Method in class com.hazelcast.config.AbstractCacheConfig
 
createConfigCheck() - Method in class com.hazelcast.instance.Node
 
createCopy(T[]) - Static method in class com.hazelcast.util.collection.ArrayUtils
Create copy of the src array.
createDefaultInstance() - Static method in class com.hazelcast.com.fasterxml.jackson.core.util.Separators
 
createDefaultList(int) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.BaseConstructor
 
createDefaultMap(int) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.BaseConstructor
 
createDefaultSet(int) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.BaseConstructor
 
createDiscoveryService(DiscoveryConfig, List<DiscoveryStrategyConfig>, Member) - Method in class com.hazelcast.instance.Node
 
createDiscoveryStrategyConfigs(JoinConfig) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Extracts aliased discovery configs from config and creates a list of DiscoveryStrategyConfig out of them.
createDiscoveryStrategyConfigs(WanPublisherConfig) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Extracts aliased discovery configs from config and creates a list of DiscoveryStrategyConfig out of them.
createDistributedObject(String) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
 
createDistributedObject(String) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
 
createDistributedObject(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
createDistributedObject(String) - Method in class com.hazelcast.concurrent.idgen.IdGeneratorService
 
createDistributedObject(String) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
createDistributedObject(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
 
createDistributedObject(String) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
createDistributedObject(String) - Method in interface com.hazelcast.spi.RemoteService
Creates a distributed object.
createDynamicConfigListener() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
createDynamicConfigListener() - Method in interface com.hazelcast.instance.NodeExtension
Creates a listener for changes in dynamic data structure configurations
createExtensionServices() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
createExtensionServices() - Method in interface com.hazelcast.instance.NodeExtension
Creates additional extension services, which will be registered by service manager during start-up.
createFactory() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
createFactory() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
createFactory() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
 
createFactory() - Method in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
createFactory() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
createFactory() - Method in class com.hazelcast.config.ConfigDataSerializerHook
 
createFactory() - Method in class com.hazelcast.crdt.CRDTDataSerializerHook
 
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 parser (possibly a sequence) that contains all given sub-parsers.
createFlattened(JsonParser, JsonParser) - Static method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserSequence
createFn() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
A primitive that returns a new accumulator.
createFn() - Method in class com.hazelcast.jet.pipeline.ContextFactory
Returns the create-function.
createFormattedCredential() - Method in class com.hazelcast.aws.security.EC2RequestSigner
 
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).
createHashMap(int) - Static method in class com.hazelcast.util.MapUtil
Utility method that creates an HashMap with its initialCapacity calculated to minimize rehash operations
createHashMapAdapter(int) - Static method in class com.hazelcast.util.MapUtil
Utility method that creates an HashMapAdapter with its initialCapacity calculated to minimize rehash operations
createHashSet(int) - Static method in class com.hazelcast.util.SetUtil
Utility method that creates an HashSet with its initialCapacity calculated to minimize rehash operations
createInboundHandlers(EndpointQualifier, TcpIpConnection, IOService) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
createInboundHandlers(EndpointQualifier, TcpIpConnection, IOService) - Method in interface com.hazelcast.instance.NodeExtension
Creates a InboundHandler for given Connection instance.
createInboundHandlers(EndpointQualifier, TcpIpConnection) - Method in interface com.hazelcast.nio.IOService
 
createInboundHandlers(EndpointQualifier, TcpIpConnection) - Method in class com.hazelcast.nio.NodeIOService
 
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.
createInstanceName(Config) - Static method in class com.hazelcast.instance.HazelcastInstanceFactory
 
createInt2ObjectHashMap(int) - Static method in class com.hazelcast.util.MapUtil
Utility method that creates an Int2ObjectHashMap with its initialCapacity calculated to minimize rehash operations
createInternalMemberGroups(Collection<? extends Member>) - Method in class com.hazelcast.partition.membergroup.ConfigMemberGroupFactory
 
createInternalMemberGroups(Collection<? extends Member>) - Method in class com.hazelcast.partition.membergroup.HostAwareMemberGroupFactory
 
createInternalMemberGroups(Collection<? extends Member>) - Method in class com.hazelcast.partition.membergroup.SPIAwareMemberGroupFactory
 
createInternalMemberGroups(Collection<? extends Member>) - Method in class com.hazelcast.partition.membergroup.ZoneAwareMemberGroupFactory
 
createInvocationBuilder(String, Operation, int) - Method in interface com.hazelcast.spi.OperationService
 
createInvocationBuilder(String, Operation, Address) - Method in interface com.hazelcast.spi.OperationService
 
createJMXManagementService(HazelcastInstanceImpl) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
createJMXManagementService(HazelcastInstanceImpl) - Method in interface com.hazelcast.instance.NodeExtension
 
createJoiner(Node) - Method in class com.hazelcast.instance.DefaultNodeContext
 
createJoiner(Node) - Method in interface com.hazelcast.instance.NodeContext
 
createJoinRequest(boolean) - Method in class com.hazelcast.instance.Node
 
createJsonGenerator(OutputStream, JsonEncoding) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
Deprecated.
createJsonGenerator(Writer) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
Deprecated.
Since 2.2, use JsonFactory.createGenerator(Writer) instead.
createJsonGenerator(OutputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
Deprecated.
createJsonParser(File) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
Deprecated.
Since 2.2, use JsonFactory.createParser(File) instead.
createJsonParser(URL) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
Deprecated.
Since 2.2, use JsonFactory.createParser(URL) instead.
createJsonParser(InputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
Deprecated.
createJsonParser(Reader) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
Deprecated.
Since 2.2, use JsonFactory.createParser(Reader) instead.
createJsonParser(byte[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
Deprecated.
Since 2.2, use JsonFactory.createParser(byte[]) instead.
createJsonParser(byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
Deprecated.
createJsonParser(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
Deprecated.
Since 2.2, use JsonFactory.createParser(String) instead.
createLinkedHashMap(int) - Static method in class com.hazelcast.util.MapUtil
Utility method that creates an LinkedHashMap with its initialCapacity calculated to minimize rehash operations
createLinkedHashSet(int) - Static method in class com.hazelcast.util.SetUtil
Utility method that creates an LinkedHashSet with its initialCapacity calculated to minimize rehash operations
createLockStore(int, ObjectNamespace) - Method in interface com.hazelcast.concurrent.lock.LockService
 
createLockStore(int, ObjectNamespace) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
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
 
createMemberGroups(Collection<? extends Member>) - Method in interface com.hazelcast.partition.membergroup.MemberGroupFactory
 
createMemberGroups(Collection<? extends Member>) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroupFactory
 
createMemberLoginContext(Credentials) - Method in interface com.hazelcast.security.SecurityContext
Creates member LoginContext.
createMemberUuid(Address) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
createMemberUuid(Address) - Method in interface com.hazelcast.instance.NodeExtension
Creates a UUID for local member
createMemberUuid(Address) - Static method in class com.hazelcast.util.UuidUtil
Creates a new member UUID string, based on a cryptographically weak pseudo random number generator.
createMulticastInputProcessor(IOService) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
createMulticastInputProcessor(IOService) - Method in interface com.hazelcast.instance.NodeExtension
Returns a byte array processor for incoming data on the Multicast joiner
createMulticastOutputProcessor(IOService) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
createMulticastOutputProcessor(IOService) - Method in interface com.hazelcast.instance.NodeExtension
Returns a byte array processor for outgoing data on the Multicast joiner
createNetworkingService(Node, ServerSocketRegistry) - Method in class com.hazelcast.instance.DefaultNodeContext
 
createNetworkingService(Node, ServerSocketRegistry) - Method in interface com.hazelcast.instance.NodeContext
 
createNew(K) - Method in interface com.hazelcast.util.ConstructorFunction
Creates a new instance of an object given the construction argument
createNew(K, Version) - Method in interface com.hazelcast.util.VersionAwareConstructorFunction
Creates a new instance of an object given the construction argument and the version of the object
createNode(Config, NodeContext) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
createNodeExtension(Node) - Method in class com.hazelcast.instance.DefaultNodeContext
 
createNodeExtension(Node) - Method in interface com.hazelcast.instance.NodeContext
 
createNonBlockingByteArrayParser() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
Optional method for constructing parser for non-blocking parsing via ByteArrayFeeder interface (accessed using JsonParser.getNonBlockingInputFeeder() from constructed instance).
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
 
createOperation() - Method in interface com.hazelcast.spi.OperationFactory
Creates the operation.
createOutboundHandlers(EndpointQualifier, TcpIpConnection, IOService) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
createOutboundHandlers(EndpointQualifier, TcpIpConnection, IOService) - Method in interface com.hazelcast.instance.NodeExtension
Creates a OutboundHandler for given Connection instance.
createOutboundHandlers(EndpointQualifier, TcpIpConnection) - Method in interface com.hazelcast.nio.IOService
 
createOutboundHandlers(EndpointQualifier, TcpIpConnection) - Method in class com.hazelcast.nio.NodeIOService
 
createParameters(Node) - Method in class com.hazelcast.util.PhoneHome
 
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.
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.
createRemoteMerkleTreeView(DataInput) - Static method in class com.hazelcast.wan.merkletree.MerkleTreeUtil
Creates a RemoteMerkleTreeView by reading the hashes of the leaves of a Merkle tree from the provided DataInput
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
Deprecated.
Since 2.3; use method that takes argument
createRootContext(DupDetector) - Static method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
 
createSamplingEntry(K, V) - Method in class com.hazelcast.util.SampleableConcurrentHashMap
 
createSecureCallable(Subject, Callable<V>) - Method in interface com.hazelcast.security.SecurityContext
Creates secure callable that runs in a sandbox.
createSerializationService() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
createSerializationService() - Method in interface com.hazelcast.instance.NodeExtension
Creates a SerializationService instance to be used by this Node.
createSerializer() - Method in interface com.hazelcast.nio.serialization.SerializerHook
Creates a new serializer for the serialization type
createService(Class<T>) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
createService(Class<T>) - Method in interface com.hazelcast.instance.NodeExtension
Creates a service which is an implementation of given type parameter.
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.v1.exceptions.Mark
 
createSnippet() - Method in class com.hazelcast.org.snakeyaml.engine.v1.exceptions.Mark
 
createSplitBrainJoinMessage() - Method in class com.hazelcast.instance.Node
 
createTextCommandService() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
createTextCommandService() - Method in interface com.hazelcast.instance.NodeExtension
 
createThread(Runnable) - Method in class com.hazelcast.util.executor.AbstractExecutorThreadFactory
 
createThread(Runnable) - Method in class com.hazelcast.util.executor.PoolExecutorThreadFactory
 
createThread(Runnable, String, int) - Method in class com.hazelcast.util.executor.PoolExecutorThreadFactory
 
createThread(Runnable) - Method in class com.hazelcast.util.executor.SingleExecutorThreadFactory
 
createThreadName(String, String) - Static method in class com.hazelcast.util.ThreadUtil
Creates the threadname with prefix and notation.
createThreadPoolName(String, String) - Static method in class com.hazelcast.util.ThreadUtil
Creates the threadpool name with prefix and notation.
createTimedMemberStateFactory(HazelcastInstanceImpl) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
createTimedMemberStateFactory(HazelcastInstanceImpl) - Method in interface com.hazelcast.instance.NodeExtension
Creates a TimedMemberStateFactory for a given Hazelcast instance
createTransactionalObject(String, Transaction) - Method in interface com.hazelcast.spi.TransactionalService
 
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 is a container object for endpoint (Members and Clients) security attributes.
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
 
CredentialsFactoryConfig(CredentialsFactoryConfig) - Constructor for class com.hazelcast.config.CredentialsFactoryConfig
 
currentName() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
 
currentTimeMillis() - Method in class com.hazelcast.util.Clock.ClockImpl
 
currentTimeMillis() - Static method in class com.hazelcast.util.Clock
Returns the current time in ms for the configured Clock.ClockImpl
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
Method similar to JsonParser.getCurrentToken() but that returns an int instead of JsonToken (enum value).
currentTokenId() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
 
cursor() - Method in class com.hazelcast.util.collection.Long2LongHashMap
Provides a cursor over the map's entries.
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 Processors.
customTransform(String, ProcessorSupplier) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
Attaches a stage with a custom transform based on the provided supplier of Core API Processors.
customTransform(String, ProcessorMetaSupplier) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
Attaches a stage with a custom transform based on the provided supplier of Core API Processors.
customTransform(String, SupplierEx<Processor>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
Attaches a stage with a custom transform based on the provided supplier of Core API Processors.
customTransform(String, ProcessorSupplier) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
Attaches a stage with a custom transform based on the provided supplier of Core API Processors.
customTransform(String, ProcessorMetaSupplier) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
Attaches a stage with a custom transform based on the provided supplier of Core API Processors.
customTransform(String, 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
 

D

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 - Interface in com.hazelcast.nio.serialization
Data is basic unit of serialization.
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.
dataSize() - Method in interface com.hazelcast.nio.serialization.Data
Returns size of internal binary data in bytes
DataType - Enum in com.hazelcast.nio.serialization
Defines type of the Data: heap or native.
deactivate(Operation) - Static method in class com.hazelcast.spi.OperationAccessor
Marks the supplied operation as "not active".
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) - Static method in class com.hazelcast.org.snakeyaml.engine.external.biz.base64Coder.Base64Coder
Decodes a byte array from Base64 format.
decode(char[]) - Static method in class com.hazelcast.org.snakeyaml.engine.external.biz.base64Coder.Base64Coder
Decodes a byte array from Base64 format.
decode(char[], int, int) - Static method in class com.hazelcast.org.snakeyaml.engine.external.biz.base64Coder.Base64Coder
Decodes a byte array from Base64 format.
decode(ByteBuffer) - Static method in class com.hazelcast.org.snakeyaml.engine.v1.common.UriEncoder
Decode '%'-escaped characters.
decode(String) - Static method in class com.hazelcast.org.snakeyaml.engine.v1.common.UriEncoder
 
decode(byte[]) - Static method in class com.hazelcast.util.Base64
Decodes Base64 data into octects
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
 
decodeLines(String) - Static method in class com.hazelcast.org.snakeyaml.engine.external.biz.base64Coder.Base64Coder
Decodes a byte array from Base64 format and ignores line separators, tabs and blanks.
decodeString(String) - Static method in class com.hazelcast.org.snakeyaml.engine.external.biz.base64Coder.Base64Coder
Decodes a string from Base64 format.
decompress(byte[]) - Static method in class com.hazelcast.nio.IOUtil
 
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.
decorateTask(Runnable, RunnableScheduledFuture<V>) - Method in class com.hazelcast.util.executor.LoggingScheduledExecutor
 
decorateTask(Callable<V>, RunnableScheduledFuture<V>) - Method in class com.hazelcast.util.executor.LoggingScheduledExecutor
 
decreaseHits(long) - Method in interface com.hazelcast.monitor.LocalRecordStoreStats
Decreases the number of hits of the locally owned entries of this partition.
decrementAndGet() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
decrementAndGet() - Method in interface com.hazelcast.core.IAtomicLong
Atomically decrements the current value by one.
decrementAndGet() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Decrements by one the current value.
decrementAndGet() - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
 
decrementAndGetAsync() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
decrementAndGetAsync() - Method in interface com.hazelcast.core.IAtomicLong
Atomically decrements the current value by one.
decrypt(String) - Method in class com.hazelcast.config.replacer.AbstractPbeReplacer
Decrypts given encrypted variable.
deduct(DoubleAccumulator) - Method in class com.hazelcast.jet.accumulator.DoubleAccumulator
Subtracts the value of the supplied accumulator from this one.
deduct(LinTrendAccumulator) - Method in class com.hazelcast.jet.accumulator.LinTrendAccumulator
Deducts the supplied accumulator from this one.
deductFn() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
A primitive that accepts two accumulators and updates the state of the left-hand one by deducting the state of the right-hand one from it.
DEFAULT_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
Default max 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_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.SemaphoreConfig
Default 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
The default value of the backup-count
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_BUFFER_SIZE - Static variable in class com.hazelcast.config.QueryCacheConfig
By default, only buffer last DEFAULT_BUFFER_SIZE events fired from a partition.
DEFAULT_CACHE_MERGE_POLICY - Static variable in class com.hazelcast.config.CacheSimpleConfig
Default policy for merging
DEFAULT_CACHED_DESERIALIZED_VALUES - Static variable in class com.hazelcast.config.MapConfig
We want to cache values only when an index is defined.
DEFAULT_CALL_TIMEOUT - Static variable in class com.hazelcast.spi.InvocationBuilder
Default call timeout.
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_CHUNK_SIZE - Static variable in class com.hazelcast.config.JobTrackerConfig
Default value of chunk size.
DEFAULT_CIPHER_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Default value for "cipherAlgorithm" property.
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
Default commit index advance to initiate a snapshot.
DEFAULT_COMMUNICATE_STATS - Static variable in class com.hazelcast.config.JobTrackerConfig
Default boolean value of communication statics.define how a map reduce job behaves
DEFAULT_CONCURRENCY_LEVEL - Static variable in class com.hazelcast.config.ReplicatedMapConfig
Default value of concurrency level
DEFAULT_DATA_LOAD_TIMEOUT - Static variable in class com.hazelcast.config.HotRestartPersistenceConfig
Default load timeout
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_DESERIALIZE_RESULT - Static variable in class com.hazelcast.spi.InvocationBuilder
True that the result of an operation automatically should be deserialized to an object.
DEFAULT_DURABILITY - Static variable in class com.hazelcast.config.DurableExecutorConfig
Durability of Executor.
DEFAULT_EMPTY_QUEUE_TTL - Static variable in class com.hazelcast.config.QueueConfig
Default value for the TTL (time to live) for empty Queue.
DEFAULT_ENABLED - Static variable in class com.hazelcast.config.MulticastConfig
Whether the multicast discovery mechanism has been enabled
DEFAULT_EVICTION_PERCENTAGE - Static variable in class com.hazelcast.config.MapConfig
The number of default eviction percentage
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 policy for eviction.
DEFAULT_EVICTION_POLICY - Static variable in class com.hazelcast.config.NearCacheConfig
Deprecated.
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_FLOW_CONTROL_PERIOD_MS - Static variable in class com.hazelcast.jet.config.InstanceConfig
The default value of the flow-control period.
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_GLOBAL_ORDERING_ENABLED - Static variable in class com.hazelcast.config.TopicConfig
Default global ordering configuration.
DEFAULT_GROUP_NAME - Static variable in class com.hazelcast.config.GroupConfig
Default group name.
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_GROUP_NAME - Static variable in class com.hazelcast.jet.config.JetConfig
The default group name for a Jet cluster See GroupConfig
DEFAULT_GROUP_PASSWORD - Static variable in class com.hazelcast.config.GroupConfig
Default group password.
DEFAULT_HEARTBEAT_INTERVAL_MILLIS - Static variable in class com.hazelcast.config.ProbabilisticQuorumConfigBuilder
Default value of heartbeat interval (in milliseconds).
DEFAULT_HEARTBEAT_INTERVAL_SECONDS - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
Default value of interval for the periodically-committed CP session heartbeats.
DEFAULT_HEARTBEAT_PAUSE_MILLIS - Static variable in class com.hazelcast.config.ProbabilisticQuorumConfigBuilder
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.RecentlyActiveQuorumConfigBuilder
Default duration of time window during which a heartbeat must have been received from a member, for it to be considered present for quorum (in milliseconds).
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_CAPACITY - Static variable in class com.hazelcast.util.collection.Int2ObjectHashMap
The default initial capacity for constructors not explicitly supplying it.
DEFAULT_INITIAL_CAPACITY - Static variable in class com.hazelcast.util.collection.Long2LongHashMap
The default initial capacity for constructors not explicitly supplying it
DEFAULT_INITIAL_CAPACITY - Static variable in class com.hazelcast.util.collection.Long2ObjectHashMap
The default initial capacity for constructors not explicitly supplying it
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_LEADER_ELECTION_TIMEOUT_IN_MILLIS - Static variable in class com.hazelcast.config.cp.RaftAlgorithmConfig
Default leader election timeout in millis.
DEFAULT_LEADER_HEARTBEAT_PERIOD_IN_MILLIS - Static variable in class com.hazelcast.config.cp.RaftAlgorithmConfig
Default leader heartbeat period in millis.
DEFAULT_LOAD_FACTOR - Static variable in class com.hazelcast.util.collection.Int2ObjectHashMap
The default load factor for constructors not explicitly supplying it.
DEFAULT_LOAD_FACTOR - Static variable in class com.hazelcast.util.collection.Long2LongHashMap
The default load factor for constructors not explicitly supplying it
DEFAULT_LOAD_FACTOR - Static variable in class com.hazelcast.util.collection.Long2ObjectHashMap
The default load factor for constructors not explicitly supplying it
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
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_MAP_MERGE_POLICY - Static variable in class com.hazelcast.config.MapConfig
Default policy for merging.
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_ENTRY_COUNT_FOR_ON_HEAP_MAP - Static variable in class com.hazelcast.config.EvictionConfig
Default maximum entry count for Map on-heap Near Caches.
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.MaxSizeConfig
Default maximum size of map.
DEFAULT_MAX_SIZE - Static variable in class com.hazelcast.config.NearCacheConfig
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_THREAD_SIZE - Static variable in class com.hazelcast.config.JobTrackerConfig
Default size of thread.
DEFAULT_MEMORY_FORMAT - Static variable in class com.hazelcast.config.NearCacheConfig
Default value for the in-memory format.
DEFAULT_MERGE_POLICY - Static variable in class com.hazelcast.config.MergePolicyConfig
Default merge policy.
DEFAULT_MERGE_POLICY - Static variable in class com.hazelcast.config.ReplicatedMapConfig
Default policy for merging
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_COLLECTION_SECONDS - Static variable in class com.hazelcast.jet.config.MetricsConfig
Default collection interval for metrics
DEFAULT_METRICS_RETENTION_SECONDS - Static variable in class com.hazelcast.jet.config.MetricsConfig
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_EVICTION_CHECK_MILLIS - Static variable in class com.hazelcast.config.MapConfig
Minimum time in milliseconds which should pass before asking if a partition of this map is evictable or not.
DEFAULT_MIN_STD_DEVIATION - Static variable in class com.hazelcast.config.ProbabilisticQuorumConfigBuilder
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
Default duration to wait before automatically removing a missing CP member from the 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
The default packet size limit.
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_PERSIST_WAN_REPLICATED_DATA - Static variable in class com.hazelcast.config.WanConsumerConfig
 
DEFAULT_PHI_THRESHOLD - Static variable in class com.hazelcast.config.ProbabilisticQuorumConfigBuilder
Default threshold for suspicion (φ) level.
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_SIZE - Static variable in class com.hazelcast.config.JobTrackerConfig
Default value of Queue size.
DEFAULT_QUEUE_SIZE - Static variable in class com.hazelcast.jet.config.EdgeConfig
The default size of the concurrent queues connecting processors within a cluster member.
DEFAULT_READ_BATCH_SIZE - Static variable in class com.hazelcast.config.ReliableTopicConfig
The default read batch size.
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_REPLICA_INDEX - Static variable in class com.hazelcast.spi.InvocationBuilder
Default replica index.
DEFAULT_REPLICATION_DELAY_MILLIS - Static variable in class com.hazelcast.config.ReplicatedMapConfig
Default value of delay of replication in millisecond
DEFAULT_REPLICATION_PERIOD_MILLIS - Static variable in class com.hazelcast.config.CRDTReplicationConfig
The default period between two CRDT replication rounds.
DEFAULT_RETRY_COUNT - Static variable in class com.hazelcast.config.JobTrackerConfig
Default value of retry counter.
DEFAULT_RING_BUFFER_CAPACITY - Static variable in class com.hazelcast.config.DurableExecutorConfig
Capacity of RingBuffer (per partition).
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.ProbabilisticQuorumConfigBuilder
Default number of samples to use for calculation of mean and standard deviation of inter-arrival times.
DEFAULT_SECRET_KEY_FACTORY_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Default value for "secretKeyFactoryAlgorithm" property.
DEFAULT_SEMAPHORE_JDK_COMPATIBILITY - Static variable in class com.hazelcast.config.cp.CPSemaphoreConfig
Default value for JDK compatibility mode of the 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
Default value for a CP session to be kept alive after the last heartbeat it has received.
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_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_PASSWORD - Static variable in class com.hazelcast.config.SymmetricEncryptionConfig
Default symmetric encryption password
DEFAULT_SYMMETRIC_SALT - Static variable in class com.hazelcast.config.SymmetricEncryptionConfig
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 sychronous backup count.
DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.RingbufferConfig
Default value of synchronous backup count
DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.SemaphoreConfig
Default synchronous backup count.
DEFAULT_TIMEOUT_MILLIS - Static variable in class com.hazelcast.transaction.TransactionOptions
2 minutes as default timeout value
DEFAULT_TOPIC_OVERLOAD_POLICY - Static variable in class com.hazelcast.config.ReliableTopicConfig
The default slow consumer policy.
DEFAULT_TOPOLOGY_CHANGED_STRATEGY - Static variable in class com.hazelcast.config.JobTrackerConfig
Define how a map reduce job behaves.
DEFAULT_TRY_COUNT - Static variable in class com.hazelcast.spi.InvocationBuilder
Default try count.
DEFAULT_TRY_PAUSE_MILLIS - Static variable in class com.hazelcast.spi.InvocationBuilder
Default try pause in milliseconds.
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_UNCOMMITTED_ENTRY_COUNT_TO_REJECT_NEW_APPENDS - Static variable in class com.hazelcast.config.cp.RaftAlgorithmConfig
Default max allowed uncommitted entry count.
DEFAULT_VALIDATION_TIMEOUT - Static variable in class com.hazelcast.config.HotRestartPersistenceConfig
Default validation timeout
DEFAULT_VALUE_COLLECTION_TYPE - Static variable in class com.hazelcast.config.MultiMapConfig
Default value collection type of this MultiMap.
DEFAULT_WRITE_BATCH_SIZE - Static variable in class com.hazelcast.config.MapStoreConfig
Default batch size for writing
DEFAULT_WRITE_COALESCING - Static variable in class com.hazelcast.config.MapStoreConfig
Default write coalescing behavior
DEFAULT_WRITE_DELAY_SECONDS - Static variable in class com.hazelcast.config.MapStoreConfig
Default delay seconds for writing
DefaultAggregateEndpointManager - Class in com.hazelcast.nio
 
DefaultAggregateEndpointManager(ConcurrentMap<EndpointQualifier, EndpointManager<TcpIpConnection>>) - Constructor for class com.hazelcast.nio.DefaultAggregateEndpointManager
 
DefaultChannelInitializerProvider - Class in com.hazelcast.nio.tcp
 
DefaultChannelInitializerProvider(IOService, Config) - Constructor for class com.hazelcast.nio.tcp.DefaultChannelInitializerProvider
 
defaultFlowStyle - Variable in class com.hazelcast.org.snakeyaml.engine.v1.representer.BaseRepresenter
 
DefaultGarbageCollectorStats - Class in com.hazelcast.memory
Default implementation of GarbageCollectorStats.
DefaultGarbageCollectorStats() - Constructor for class com.hazelcast.memory.DefaultGarbageCollectorStats
 
DefaultIndenter - Class in com.hazelcast.com.fasterxml.jackson.core.util
Default linefeed-based indenter, used by DefaultPrettyPrinter (unless overridden).
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.
DefaultMemberGroup - Class in com.hazelcast.partition.membergroup
 
DefaultMemberGroup() - Constructor for class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
DefaultMemberGroup(Collection<Member>) - Constructor for class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
DefaultMemoryStats - Class in com.hazelcast.memory
Default implementation of MemoryStats.
DefaultMemoryStats() - Constructor for class com.hazelcast.memory.DefaultMemoryStats
 
DefaultNodeContext - Class in com.hazelcast.instance
 
DefaultNodeContext() - Constructor for class com.hazelcast.instance.DefaultNodeContext
 
DefaultNodeExtension - Class in com.hazelcast.instance
 
DefaultNodeExtension(Node) - Constructor for class com.hazelcast.instance.DefaultNodeExtension
 
DefaultObjectNamespace - Class in com.hazelcast.spi
Deprecated.
DefaultObjectNamespace() - Constructor for class com.hazelcast.spi.DefaultObjectNamespace
Deprecated.
 
DefaultObjectNamespace(String, String) - Constructor for class com.hazelcast.spi.DefaultObjectNamespace
Deprecated.
 
DefaultObjectNamespace(ObjectNamespace) - Constructor for class com.hazelcast.spi.DefaultObjectNamespace
Deprecated.
 
DefaultOutOfMemoryHandler - Class in com.hazelcast.instance
Default OutOfMemoryHandler implementation that tries to release local resources (threads, connections, memory) immediately and disconnects members from the rest of the cluster.
DefaultOutOfMemoryHandler() - Constructor for class com.hazelcast.instance.DefaultOutOfMemoryHandler
 
DefaultOutOfMemoryHandler(double) - Constructor for class com.hazelcast.instance.DefaultOutOfMemoryHandler
 
DefaultOutOfMemoryHandler(double, MemoryInfoAccessor) - Constructor for class com.hazelcast.instance.DefaultOutOfMemoryHandler
 
defaultPartitioner() - Static method in interface com.hazelcast.jet.core.Partitioner
Returns a partitioner which applies the default Hazelcast partitioning.
DefaultPartitioningStrategy - Class in com.hazelcast.partition.strategy
A PartitioningStrategy that checks if the key implements PartitionAware.
DefaultPartitioningStrategy() - Constructor for class com.hazelcast.partition.strategy.DefaultPartitioningStrategy
 
DefaultPartitionStrategy - Interface in com.hazelcast.jet.core
A facade that hides the details of Hazelcast partitioning SPI and exposes just the partitioning strategy.
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.v1.representer.BaseRepresenter
 
delegate - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
Delegate object that method calls are delegated to.
delegate - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
Delegate object that method calls are delegated to.
delegateCopyMethods - Variable in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
DelegatingFuture<V> - Class in com.hazelcast.util.executor
A InternalCompletableFuture implementation that delegates the real logic to an underlying InternalCompletableFuture and decorates it with additional behavior: change the returned value by setting the result always deserializing the content caching the deserialized content so that a deserialization only happens once.
DelegatingFuture(InternalCompletableFuture, SerializationService) - Constructor for class com.hazelcast.util.executor.DelegatingFuture
 
DelegatingFuture(InternalCompletableFuture, SerializationService, V) - Constructor for class com.hazelcast.util.executor.DelegatingFuture
Creates a DelegatingFuture
delete(Object) - Method in interface com.hazelcast.core.BaseMap
Removes the mapping for a key from this map if it is present.
delete(Object) - Method in interface com.hazelcast.core.IMap
Removes the mapping for the key from this map if it is present.
delete(K) - Method in interface com.hazelcast.core.MapStore
Deletes the entry with a given key from the store.
delete(K) - Method in class com.hazelcast.core.MapStoreAdapter
Deletes the entry with a given key from the store.
delete(Object) - Method in interface com.hazelcast.core.MultiMap
Deletes all the entries with the given key.
delete(Long) - Method in interface com.hazelcast.core.QueueStore
Deletes the entry with a given key from the store.
delete(Object) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.delete(Object).
delete(File) - Static method in class com.hazelcast.nio.IOUtil
Ensures that the file described by the supplied parameter does not exist after the method returns.
deleteAll(Collection<K>) - Method in interface com.hazelcast.core.MapStore
Deletes multiple entries from the store.
deleteAll(Collection<K>) - Method in class com.hazelcast.core.MapStoreAdapter
Deletes multiple entries from the store.
deleteAll(Collection<Long>) - Method in interface com.hazelcast.core.QueueStore
Deletes multiple entries from the store.
deleteQuietly(File) - Static method in class com.hazelcast.nio.IOUtil
Ensures that the file described by the supplied parameter does not exist after the method returns.
deleteSnapshot(JetCommandLine.Verbosity, 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
 
deregisterAllListeners(String, String) - Method in interface com.hazelcast.spi.EventService
Deregisters all listeners belonging to the given service and topic.
deregisterClient(HazelcastInstance) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
 
deregisterListener(String, String, Object) - Method in interface com.hazelcast.spi.EventService
Deregisters a listener with the given registration ID.
deregisterServer(HazelcastInstance) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
 
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.
descendingKeys() - Method in class com.hazelcast.util.ItemCounter
Returns a List of keys in descending value order.
describeFlags(char) - Method in enum com.hazelcast.nio.Packet.Type
 
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.
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.concurrent.idgen.IdGeneratorImpl
 
destroy() - Method in interface com.hazelcast.core.DistributedObject
Destroys this object cluster-wide.
destroy() - Method in interface com.hazelcast.core.MapLoaderLifecycleSupport
Hazelcast will call this method before shutting down.
destroy() - Method in class com.hazelcast.jet.JobStateSnapshot
Destroy the underlying distributed object.
destroy() - Method in interface com.hazelcast.map.QueryCache
Destroys this cache.
destroy() - Method in interface com.hazelcast.nio.serialization.Serializer
Called when instance is shutting down.
destroy() - Method in interface com.hazelcast.security.ICredentialsFactory
destroy() - Method in interface com.hazelcast.security.IPermissionPolicy
DESTROY - Static variable in class com.hazelcast.security.permission.InstancePermission
 
destroy() - Method in interface com.hazelcast.security.SecurityContext
Destroys SecurityContext and all security elements.
destroy() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
destroy() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
 
destroy() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategy
The stop method is used to stop internal services, sockets or to destroy any kind of internal state.
destroy() - Method in interface com.hazelcast.spi.discovery.integration.DiscoveryService
The start method is called on system startup to implement simple lifecycle management.
destroy() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategy
 
destroy(T) - Method in interface com.hazelcast.spi.tenantcontrol.DestroyEventContext
Called to decouple Hazelcast object from the tenant
destroyDistributedObject(String) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
 
destroyDistributedObject(String) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
 
destroyDistributedObject(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
destroyDistributedObject(String) - Method in class com.hazelcast.concurrent.idgen.IdGeneratorService
 
destroyDistributedObject(String) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
destroyDistributedObject(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
 
destroyDistributedObject(String) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
destroyDistributedObject(String, String) - Method in interface com.hazelcast.spi.ProxyService
 
destroyDistributedObject(String) - Method in interface com.hazelcast.spi.RemoteService
Destroys a distributed object.
DestroyEventContext<T> - Interface in com.hazelcast.spi.tenantcontrol
Hook to decouple Hazelcast object from the tenant
destroyFn() - Method in class com.hazelcast.jet.pipeline.ContextFactory
Returns the destroy-function.
destroyFn(ConsumerEx<? super W>) - Method in class com.hazelcast.jet.pipeline.SinkBuilder
Sets the function that will destroy the writer 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
 
DETACH_MEMBER_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
DETACH_MEMBER_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
detachAll(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
 
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 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.
difference(IntHashSet) - Method in class com.hazelcast.util.collection.IntHashSet
Fast Path set difference for comparison with another IntHashSet.
difference(LongHashSet) - Method in class com.hazelcast.util.collection.LongHashSet
Fast Path set difference for comparison with another LongHashSet.
DirectiveToken<T> - Class in com.hazelcast.org.snakeyaml.engine.v1.tokens
 
DirectiveToken(String, Optional<List<T>>, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.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
Method for disabling specified parser features (check JsonFactory.Feature for list of features)
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
Method for disabling specified generator feature (check JsonGenerator.Feature for list of features)
disable(JsonGenerator.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
Method for disabling specified features (check JsonGenerator.Feature for list of features)
disable(JsonParser.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Method for disabling specified feature (check JsonParser.Feature for list of features)
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_STALE_READ_ON_PARTITION_MIGRATION - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
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.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.
discoverLocalMetadata() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategy
 
discoverNodes() - Method in class com.hazelcast.aws.AwsDiscoveryStrategy
 
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_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
DISCOVERY_SPI_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Enables the Discovery SPI lookup over the old native implementations.
DISCOVERY_SPI_PUBLIC_IP_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Enables the Discovery Joiner to use public ips from DiscoveredNode.
DISCOVERY_STRATEGY_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
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
 
DiscoveryConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
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 - Variable in class com.hazelcast.instance.Node
 
DiscoveryService - Interface in com.hazelcast.spi.discovery.integration
The DiscoveryService interface defines the basic entry point into the Discovery SPI implementation.
DiscoveryServiceProvider - Interface in com.hazelcast.spi.discovery.integration
The DiscoveryServiceProvider interface provides the possibility to build DiscoveryServices.
DiscoveryServiceSettings - Class in com.hazelcast.spi.discovery.integration
The DiscoveryServiceSettings class is used to pass the necessary configuration to create a DiscoveryService to the DiscoveryServiceProvider.
DiscoveryServiceSettings() - Constructor for class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
DiscoveryStrategy - Interface in com.hazelcast.spi.discovery
The DiscoveryStrategy itself is the actual implementation to discover nodes based on whatever environment is used to run the Hazelcast cloud.
DiscoveryStrategyConfig - Class in com.hazelcast.config
This configuration class describes a DiscoveryStrategy based on a parsed XML or configured manually using the config API
DiscoveryStrategyConfig() - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
 
DiscoveryStrategyConfig(String) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
 
DiscoveryStrategyConfig(String, Map<String, Comparable>) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
 
DiscoveryStrategyConfig(DiscoveryStrategyFactory) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
 
DiscoveryStrategyConfig(DiscoveryStrategyFactory, Map<String, Comparable>) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
 
DiscoveryStrategyConfig(DiscoveryStrategyConfig) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
 
DiscoveryStrategyFactory - Interface in com.hazelcast.spi.discovery
The DiscoveryStrategyFactory is the entry point for strategy vendors.
dispatchEvent(E, T) - Method in interface com.hazelcast.spi.EventPublishingService
Notifies the service of a published event.
Disposable - Interface in com.hazelcast.nio
A Disposable is a container of data and/or resources that can be disposed.
dispose() - Method in interface com.hazelcast.nio.Disposable
Disposes this object and releases any data and/or resources associated with it.
dispose() - Method in interface com.hazelcast.scheduledexecutor.IScheduledFuture
Used to destroy the instance of the IScheduledFuture in the scheduled executor.
disposeResult(long) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Disposes the result with the given taskId
distinct() - Static method in class com.hazelcast.aggregation.Aggregators
 
distinct(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
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).
distinctValues() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation for selecting all distinct values.
This aggregation is similar to:
distributed() - Method in class com.hazelcast.jet.core.Edge
Declares that the edge is distributed.
distributed(int) - Method in class com.hazelcast.jet.pipeline.SourceBuilder.Batch
 
distributed(int) - Method in class com.hazelcast.jet.pipeline.SourceBuilder.Stream
 
distributed(int) - Method in class com.hazelcast.jet.pipeline.SourceBuilder.TimestampedStream
 
DISTRIBUTED_BYTES_IN - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
Tracks the data volume (bytes) coming in over the network for DISTRIBUTED input Edges of particular Vertex instances running on various Processors.
DISTRIBUTED_BYTES_OUT - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
Tracks the data volume (bytes) going out over the network for DISTRIBUTED output Edges of particular Vertex instances running on various Processors.
DISTRIBUTED_ITEMS_IN - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
Counts data items coming in over the network for DISTRIBUTED input Edges of particular Vertex instances running on various Processors.
DISTRIBUTED_ITEMS_OUT - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
Counts data items going out over the network for DISTRIBUTED output Edges of particular Vertex instances running on various Processors.
DistributedObject - Interface in com.hazelcast.core
Base interface for all distributed objects.
distributedObject - Variable in class com.hazelcast.core.DistributedObjectEvent
 
distributedObjectCreated(DistributedObjectEvent) - Method in interface com.hazelcast.core.DistributedObjectListener
Invoked when a DistributedObject is created.
distributedObjectDestroyed(DistributedObjectEvent) - Method in interface com.hazelcast.core.DistributedObjectListener
Invoked when a DistributedObject is destroyed.
DistributedObjectDestroyedException - Exception in com.hazelcast.spi.exception
A HazelcastException that indicates that a DistributedObject access was attempted, but the object is destroyed.
DistributedObjectDestroyedException(String) - Constructor for exception com.hazelcast.spi.exception.DistributedObjectDestroyedException
 
DistributedObjectEvent - Class in com.hazelcast.core
DistributedObjectEvent is fired when a DistributedObject is created or destroyed cluster-wide.
DistributedObjectEvent(DistributedObjectEvent.EventType, String, String, DistributedObject) - 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.
DistributedObjectNamespace - Class in com.hazelcast.spi
Default ObjectNamespace implementation for DistributedObject.
DistributedObjectNamespace() - Constructor for class com.hazelcast.spi.DistributedObjectNamespace
 
DistributedObjectNamespace(String, String) - Constructor for class com.hazelcast.spi.DistributedObjectNamespace
 
DistributedObjectNamespace(ObjectNamespace) - Constructor for class com.hazelcast.spi.DistributedObjectNamespace
 
DistributedObjectUtil - Class in com.hazelcast.core
Utility class for DistributedObject.
DISTRIBUTION - Static variable in class com.hazelcast.instance.GeneratedBuildProperties
 
divideByAndCeilToInt(double, int) - Static method in class com.hazelcast.util.QuickMath
Divide d by k and return the smallest integer greater than or equal to the result.
divideByAndCeilToLong(double, int) - Static method in class com.hazelcast.util.QuickMath
Divide d by k and return the smallest integer greater than or equal to the result.
divideByAndRoundToInt(double, int) - Static method in class com.hazelcast.util.QuickMath
Divide d by k and return the int value closest to the result.
divideByAndRoundToLong(double, int) - Static method in class com.hazelcast.util.QuickMath
Divide d by k and return the long value closest to the result.
DocumentEndEvent - Class in com.hazelcast.org.snakeyaml.engine.v1.events
Marks the end of a document.
DocumentEndEvent(boolean, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.events.DocumentEndEvent
 
DocumentEndEvent(boolean) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.events.DocumentEndEvent
 
DocumentEndToken - Class in com.hazelcast.org.snakeyaml.engine.v1.tokens
 
DocumentEndToken(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.tokens.DocumentEndToken
 
DocumentStartEvent - Class in com.hazelcast.org.snakeyaml.engine.v1.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.v1.events.DocumentStartEvent
 
DocumentStartEvent(boolean, Optional<SpecVersion>, Map<String, String>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.events.DocumentStartEvent
 
DocumentStartToken - Class in com.hazelcast.org.snakeyaml.engine.v1.tokens
 
DocumentStartToken(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.tokens.DocumentStartToken
 
doMatch(String, String, int) - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
 
DomConfigHelper - Class in com.hazelcast.config
Helper class for accessing and extracting values from W3C DOM Node instances
DomConfigProcessor - Interface in com.hazelcast.config
Interface used by XML and YAML configuration classes for traversing and filling config object graph.
domLevel3 - Variable in class com.hazelcast.config.AbstractXmlConfigHelper
 
DONE_RESPONSE - Static variable in class com.hazelcast.spi.CallStatus
Signals that the Operation is done running and that a response is ready to be returned.
DONE_RESPONSE_ORDINAL - Static variable in class com.hazelcast.spi.CallStatus
The ordinal value for a CallStatus.DONE_RESPONSE.
DONE_VOID - Static variable in class com.hazelcast.spi.CallStatus
Signals that the Operation is done running, but no response will be returned.
DONE_VOID_ORDINAL - Static variable in class com.hazelcast.spi.CallStatus
The ordinal value for a CallStatus.DONE_VOID.
doneCallback - Variable in class com.hazelcast.spi.InvocationBuilder
 
DOUBLE_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
DOUBLE_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
DOUBLE_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
Double size in bytes
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
 
doubleAvg() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to calculate the double average of all supplied values.
This aggregation is similar to:
doubleMax() - Static method in class com.hazelcast.aggregation.Aggregators
 
doubleMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
doubleMax() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to find the double maximum of all supplied values.
This aggregation is similar to:
doubleMin() - Static method in class com.hazelcast.aggregation.Aggregators
 
doubleMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
doubleMin() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to find the double minimum of all supplied values.
This aggregation is similar to:
doubleSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
doubleSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
doubleSum() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to calculate the double sum of all supplied values.
This aggregation is similar to:
drain(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
 
drain(Consumer<E>) - Method in interface com.hazelcast.jet.core.Inbox
Passes each of this object's items to the supplied consumer until it is empty.
DRAIN_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
DRAIN_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
DrainBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
DrainBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.DrainBackupOperation
 
DrainBackupOperation(String, int, String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.DrainBackupOperation
 
DrainOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
DrainOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.DrainOperation
 
DrainOperation(String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.DrainOperation
 
drainPermits() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
 
drainPermits() - Method in interface com.hazelcast.core.ISemaphore
Acquires and returns all permits that are available at invocation time.
drainQueue(Queue<?>) - Static method in class com.hazelcast.util.QueueUtil
Drains the provided queue by the size of the queue as it is known upfront draining.
drainQueue(Queue<E>, Predicate<E>) - Static method in class com.hazelcast.util.QueueUtil
Drains the provided queue by the size of the queue as it is known upfront draining.
drainQueue(Queue<E>, int, Predicate<E>) - Static method in class com.hazelcast.util.QueueUtil
Drains the provided queue by the count provided in elementsToDrain.
drainQueueAndReset(int, Collection<T>, boolean) - Method in class com.hazelcast.jet.core.test.TestOutbox
Move all items from the queue to the target collection and make the outbox available to accept more items.
drainQueuesAndReset(List<? extends Collection<T>>, boolean) - Method in class com.hazelcast.jet.core.test.TestOutbox
Move all items from all queues (except the snapshot queue) to the target list of collections.
drainSnapshotQueueAndReset(Collection<? super Map.Entry<K, V>>, boolean) - Method in class com.hazelcast.jet.core.test.TestOutbox
Deserialize and move all items from the snapshot queue to the target collection and make the outbox available to accept more items.
drainTo(Collection<E>) - Method in interface com.hazelcast.jet.core.Inbox
Drains all elements into the provided Collection.
drainTo(Sink<? super T>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
Attaches a sink stage, one that accepts data but doesn't emit any.
drainTo(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.
drainTo(InputStream, OutputStream) - Static method in class com.hazelcast.nio.IOUtil
 
drawFrom(BatchSource<? extends T>) - Method in interface com.hazelcast.jet.pipeline.Pipeline
Returns a pipeline stage that represents a bounded (batch) data source.
drawFrom(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).
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).
Dump - Class in com.hazelcast.org.snakeyaml.engine.v1.api
Common way to serialize any Java instance(s)
Dump(DumpSettings) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.api.Dump
Create instance
Dump(DumpSettings, BaseRepresenter) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.api.Dump
Create instance
dump(Object, StreamDataWriter) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.Dump
Dump a single instance into a YAML document
dumpAll(Iterator<? extends Object>, StreamDataWriter) - Method in class com.hazelcast.org.snakeyaml.engine.v1.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.v1.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.v1.api
Fine tuning serializing/dumping Description for all the fields can be found in the builder
DumpSettingsBuilder - Class in com.hazelcast.org.snakeyaml.engine.v1.api
Builder pattern implementation for DumpSettings
DumpSettingsBuilder() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.api.DumpSettingsBuilder
Create builder
dumpToString(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v1.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
Helper class used if JsonParser.Feature.STRICT_DUPLICATE_DETECTION is enabled.
DuplicateInstanceNameException - Exception in com.hazelcast.core
Thrown when a duplicate instance name is detected.
DuplicateInstanceNameException(String) - Constructor for exception com.hazelcast.core.DuplicateInstanceNameException
Returns the message when a duplicate instance name is detected.
DuplicateKeyException - Exception in com.hazelcast.org.snakeyaml.engine.v1.exceptions
 
DuplicateKeyException(Optional<Mark>, Object, Optional<Mark>) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v1.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
 
DURABLE_EXECUTOR_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
DurableExecutorConfig - Class in com.hazelcast.config
Contains the configuration for an DurableExecutorService.
DurableExecutorConfig() - Constructor for class com.hazelcast.config.DurableExecutorConfig
 
DurableExecutorConfig(String) - Constructor for class com.hazelcast.config.DurableExecutorConfig
 
DurableExecutorConfig(String, int, int, int) - Constructor for class com.hazelcast.config.DurableExecutorConfig
 
DurableExecutorConfig(String, int, int, int, String) - Constructor for class com.hazelcast.config.DurableExecutorConfig
 
DurableExecutorConfig(DurableExecutorConfig) - Constructor for class com.hazelcast.config.DurableExecutorConfig
 
DurableExecutorService - Interface in com.hazelcast.durableexecutor
Durable implementation of ExecutorService.
DurableExecutorServiceFuture<V> - Interface in com.hazelcast.durableexecutor
A Future where one can obtain the task ID for tracking the response.
DurableExecutorServicePermission - Class in com.hazelcast.security.permission
 
DurableExecutorServicePermission(String, String...) - Constructor for class com.hazelcast.security.permission.DurableExecutorServicePermission
 
DurationConfig() - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
DurationConfig(long, TimeUnit) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
DYNAMIC_CONFIG_PRE_JOIN_OP - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 

E

earlyResultsPeriod() - Method in class com.hazelcast.jet.pipeline.WindowDefinition
Returns the early results period for this window definition.
EC2RequestSigner - Class in com.hazelcast.aws.security
 
EC2RequestSigner(AwsConfig, String, String) - Constructor for class com.hazelcast.aws.security.EC2RequestSigner
 
Echo - Class in com.hazelcast.console
Echoes to screen.
Echo() - Constructor for class com.hazelcast.console.Echo
 
Echo(String) - Constructor for class com.hazelcast.console.Echo
 
edge(Edge) - Method in class com.hazelcast.jet.core.DAG
Adds an edge to this DAG.
Edge - Class in com.hazelcast.jet.core
Represents an edge between two vertices in a DAG.
Edge() - Constructor for class com.hazelcast.jet.core.Edge
 
Edge(Vertex, int, Vertex, int) - Constructor for class com.hazelcast.jet.core.Edge
 
EDGE - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
Serialization ID of the Edge class.
Edge.RoutingPolicy - Enum in com.hazelcast.jet.core
An edge describes a connection from many upstream processors to many downstream processors.
EdgeConfig - Class in com.hazelcast.jet.config
A configuration object for a DAG Edge that holds fine-tuning parameters that influence its performance characteristics.
EdgeConfig() - Constructor for class com.hazelcast.jet.config.EdgeConfig
 
element() - Method in class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
Returns the current index element Calls to this method won't change state.
ElementAdapter - Class in com.hazelcast.config.yaml
Class adapting YamlNodes to Element.
elements() - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
elements() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
 
elements() - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
 
elements() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
Returns an enumeration of the values in this table.
emit(K, V) - Method in interface com.hazelcast.mapreduce.Context
Deprecated.
Emits a key-value pair to the intermediate working space.
emit(Event) - Method in interface com.hazelcast.org.snakeyaml.engine.v1.emitter.Emitable
 
emit(Event) - Method in class com.hazelcast.org.snakeyaml.engine.v1.emitter.Emitter
 
Emitable - Interface in com.hazelcast.org.snakeyaml.engine.v1.emitter
 
emitFromTraverser(int[], Traverser<E>) - Method in class com.hazelcast.jet.core.AbstractProcessor
Obtains items from the traverser and offers them to the outbox's buckets identified in the supplied array.
emitFromTraverser(int, Traverser<E>) - Method in class com.hazelcast.jet.core.AbstractProcessor
Obtains items from the traverser and offers them to the outbox's buckets identified in the supplied array.
emitFromTraverser(Traverser<?>) - Method in class com.hazelcast.jet.core.AbstractProcessor
Convenience for AbstractProcessor.emitFromTraverser(int, Traverser) which emits to all ordinals.
emitFromTraverserToSnapshot(Traverser<T>) - Method in class com.hazelcast.jet.core.AbstractProcessor
Obtains items from the traverser and offers them to the snapshot bucket of the outbox.
EMITTED_COUNT - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
Counts the data items emitted on outgoing Edges of particular Vertex instances running on various Processors.
Emitter - Class in com.hazelcast.org.snakeyaml.engine.v1.emitter
Emitter expects events obeying the following grammar: stream ::= STREAM-START document* STREAM-END document ::= DOCUMENT-START node DOCUMENT-END node ::= SCALAR | sequence | mapping sequence ::= SEQUENCE-START node* SEQUENCE-END mapping ::= MAPPING-START (node node)* MAPPING-END
Emitter(DumpSettings, StreamDataWriter) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.emitter.Emitter
 
EmitterException - Exception in com.hazelcast.org.snakeyaml.engine.v1.exceptions
 
EmitterException(String) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v1.exceptions.EmitterException
 
emitToString(Iterator<Event>) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.lowlevel.Present
 
EMPTY - Static variable in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
Marker instance used to represent segment that matches current node or position (that is, returns true for JsonPointer.matches()).
empty() - Static method in class com.hazelcast.jet.core.metrics.JobMetrics
Returns an empty JobMetrics object.
empty() - Static method in class com.hazelcast.jet.Traversers
Returns a traverser that always returns null.
empty - Variable in class com.hazelcast.org.snakeyaml.engine.v1.emitter.ScalarAnalysis
 
EMPTY - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.resolver.JsonScalarResolver
 
emptyAndGetCurrentSegment() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
 
EmptyStatement - Class in com.hazelcast.util
This class makes CheckStyle happy, if you have an ignored or expected exception, but need at least a single statement in the catch clause.
enable(JsonGenerator.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
 
enable(JsonParser.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
 
enable(JsonGenerator.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonGeneratorImpl
 
enable(JsonFactory.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
Method for enabling specified parser feature (check JsonFactory.Feature for list of features)
enable(JsonParser.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
Method for enabling specified parser feature (check JsonParser.Feature for list of features)
enable(JsonGenerator.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
Method for enabling specified generator features (check JsonGenerator.Feature for list of features)
enable(JsonGenerator.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
Method for enabling specified parser features: check JsonGenerator.Feature for list of available features.
enable(JsonParser.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Method for enabling specified parser feature (check JsonParser.Feature for list of features)
enable(JsonGenerator.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
 
enable(JsonParser.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
 
ENABLE_JMX - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
enableAllGroups() - Method in class com.hazelcast.config.RestApiConfig
Enables all REST endpoint groups.
enableAllGroups() - Method in class com.hazelcast.config.RestServerEndpointConfig
Enables all REST endpoint groups.
enabled - Variable in class com.hazelcast.config.QuorumConfigBuilder
Whether this quorum config is enabled or not
enabled(boolean) - Method in class com.hazelcast.config.QuorumConfigBuilder
 
enabledByDefault() - Method in interface com.hazelcast.com.fasterxml.jackson.core.FormatFeature
Accessor for checking whether this feature is enabled by default.
enabledByDefault() - Method in enum com.hazelcast.com.fasterxml.jackson.core.JsonFactory.Feature
 
enabledByDefault() - Method in enum com.hazelcast.com.fasterxml.jackson.core.JsonGenerator.Feature
 
enabledByDefault() - Method in enum com.hazelcast.com.fasterxml.jackson.core.JsonParser.Feature
 
enabledIn(int) - Method in interface com.hazelcast.com.fasterxml.jackson.core.FormatFeature
Convenience method for checking whether feature is enabled in given bitmask
enabledIn(int) - Method in enum com.hazelcast.com.fasterxml.jackson.core.JsonFactory.Feature
 
enabledIn(int) - Method in enum com.hazelcast.com.fasterxml.jackson.core.JsonGenerator.Feature
 
enabledIn(int) - Method in enum com.hazelcast.com.fasterxml.jackson.core.JsonParser.Feature
 
enableGroups(RestEndpointGroup...) - Method in class com.hazelcast.config.RestApiConfig
Enables provided REST endpoint groups.
enableGroups(RestEndpointGroup...) - Method in class com.hazelcast.config.RestServerEndpointConfig
Enables provided REST endpoint groups.
enableReentrancy() - Method in class com.hazelcast.config.cp.FencedLockConfig
Enables reentrancy.
encode(byte[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
Convenience method for converting given byte array as base64 encoded String using this variant's settings.
encode(byte[], boolean) - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
Convenience method for converting given byte array as base64 encoded String using this variant's settings, optionally enclosed in double-quotes.
encode(byte[]) - Static method in class com.hazelcast.org.snakeyaml.engine.external.biz.base64Coder.Base64Coder
Encodes a byte array into Base64 format.
encode(byte[], int) - Static method in class com.hazelcast.org.snakeyaml.engine.external.biz.base64Coder.Base64Coder
Encodes a byte array into Base64 format.
encode(byte[], int, int) - Static method in class com.hazelcast.org.snakeyaml.engine.external.biz.base64Coder.Base64Coder
Encodes a byte array into Base64 format.
encode(String) - Static method in class com.hazelcast.org.snakeyaml.engine.v1.common.UriEncoder
Escape special characters with '%'
encode(byte[]) - Static method in class com.hazelcast.util.Base64
Encodes hex octects into Base64
encodeAsUTF8(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.JsonStringEncoder
Will encode given String as UTF-8 (without any quoting), return resulting byte array.
encodeAsUTF8(String) - Static method in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecyclers
Helper method for encoding given String as UTF-8 encoded
encodeBase64BitsAsByte(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
 
encodeBase64BitsAsChar(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
 
encodeBase64Chunk(int, char[], int) - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
Method that encodes given right-aligned (LSB) 24-bit value into 4 base64 characters, stored in given result buffer.
encodeBase64Chunk(StringBuilder, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
 
encodeBase64Chunk(int, byte[], int) - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
Method that encodes given right-aligned (LSB) 24-bit value into 4 base64 bytes (ascii), stored in given result buffer.
encodeBase64Partial(int, int, char[], int) - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
Method that outputs partial chunk (which only encodes one or two bytes of data).
encodeBase64Partial(StringBuilder, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
 
encodeBase64Partial(int, int, byte[], int) - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
Method that outputs partial chunk (which only encodes one or two bytes of data).
encodeLines(byte[]) - Static method in class com.hazelcast.org.snakeyaml.engine.external.biz.base64Coder.Base64Coder
Encodes a byte array into Base 64 format and breaks the output into lines of 76 characters.
encodeLines(byte[], int, int, int, String) - Static method in class com.hazelcast.org.snakeyaml.engine.external.biz.base64Coder.Base64Coder
Encodes a byte array into Base 64 format and breaks the output into lines.
encodeString(String) - Static method in class com.hazelcast.org.snakeyaml.engine.external.biz.base64Coder.Base64Coder
Encodes a string into Base64 format.
encrypt(String, int) - Method in class com.hazelcast.config.replacer.AbstractPbeReplacer
Encrypts given string with key generated from AbstractPbeReplacer.getPassword() with given iteration count and return the masked value (to be used as the variable).
encrypt(String...) - Static method in class com.hazelcast.config.replacer.EncryptionReplacer
 
EncryptionReplacer - Class in com.hazelcast.config.replacer
This class is an example ConfigReplacer implementation which decrypts encrypted values.
EncryptionReplacer() - Constructor for class com.hazelcast.config.replacer.EncryptionReplacer
 
end() - Method in class com.hazelcast.jet.datamodel.WindowResult
Returns the ending timestamp of the window.
endMark - Variable in class com.hazelcast.org.snakeyaml.engine.v1.nodes.Node
 
endOfInput() - Method in interface com.hazelcast.com.fasterxml.jackson.core.async.NonBlockingInputFeeder
Method that should be called after last chunk of data to parse has been fed (with feedInput in sub-class); can be called regardless of what NonBlockingInputFeeder.needMoreInput() returns.
endOfInput() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
 
Endpoint - Interface in com.hazelcast.core
Endpoint represents a peer in the cluster.
endpoint() - Method in interface com.hazelcast.cp.session.CPSession
Returns the endpoint that has created this session
EndpointConfig - Class in com.hazelcast.config
Endpoint configuration that defines communication/networking properties common to both incoming/outgoing connections eg.
EndpointConfig() - Constructor for class com.hazelcast.config.EndpointConfig
 
EndpointConnectionLifecycleListener() - Constructor for class com.hazelcast.nio.tcp.TcpIpEndpointManager.EndpointConnectionLifecycleListener
 
EndpointManager<T extends Connection> - Interface in com.hazelcast.nio
Responsible for managing Connection objects.
endpointManager - Variable in class com.hazelcast.spi.InvocationBuilder
 
endpointName() - Method in interface com.hazelcast.cp.session.CPSession
Returns name of the endpoint that has created this session
EndpointQualifier - Class in com.hazelcast.instance
An EndpointQualifier is a (ProtocolType, String) tuple that uniquely identifies groups of network connections sharing a common ProtocolType and the same network settings, when Hazelcast is configured with AdvancedNetworkConfig enabled.
EndpointQualifier() - Constructor for class com.hazelcast.instance.EndpointQualifier
 
endpointType() - Method in interface com.hazelcast.cp.session.CPSession
Returns type of the endpoint that has created this session
enqueue(TextCommand) - Method in class com.hazelcast.nio.ascii.TextEncoder
 
ensureLoaded(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ByteSourceJsonBootstrapper
 
ensureMember(Address) - Method in class com.hazelcast.spi.CallsPerMember
Makes sure that a list of counters is created for a member.
ensureNotShared() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
Method called to make sure that buffer is not using shared input buffer; if it is, it will copy such contents to private buffer.
ensureQuorumPresent(String, QuorumType) - Method in interface com.hazelcast.quorum.QuorumService
Ensures that the quorum with the given name is present.
ENTERPRISE_LICENSE_KEY - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
entry(K, V) - Static method in class com.hazelcast.jet.Util
Returns a Map.Entry with the given key and value.
ENTRY_LISTENER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
EntryAdapter<K,V> - Class in com.hazelcast.core
Adapter for MapListener.
EntryAdapter() - Constructor for class com.hazelcast.core.EntryAdapter
 
entryAdded(EntryEvent) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
entryAdded(EntryEvent) - Method in class com.hazelcast.console.ConsoleApp
 
entryAdded(EntryEvent<K, V>) - Method in class com.hazelcast.core.EntryAdapter
 
entryAdded(EntryEvent<K, V>) - Method in interface com.hazelcast.map.listener.EntryAddedListener
Invoked upon addition of an entry.
EntryAddedListener<K,V> - Interface in com.hazelcast.map.listener
Invoked upon addition of an entry.
EntryBackupProcessor<K,V> - Interface in com.hazelcast.map
Processes an entry on a backup partition.
EntryEvent<K,V> - Class in com.hazelcast.core
Map Entry event.
EntryEvent(Object, Member, int, K, V) - Constructor for class com.hazelcast.core.EntryEvent
Constructs an entry event.
EntryEvent(Object, Member, int, K, V, V) - Constructor for class com.hazelcast.core.EntryEvent
Constructs an entry event.
EntryEvent(Object, Member, int, K, V, V, V) - Constructor for class com.hazelcast.core.EntryEvent
Constructs an entry event.
EntryEventType - Enum in com.hazelcast.core
Type of entry event.
entryEvicted(EntryEvent) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
entryEvicted(EntryEvent) - Method in class com.hazelcast.console.ConsoleApp
 
entryEvicted(EntryEvent<K, V>) - Method in class com.hazelcast.core.EntryAdapter
 
entryEvicted(EntryEvent<K, V>) - Method in interface com.hazelcast.map.listener.EntryEvictedListener
Invoked upon eviction of an entry.
EntryEvictedListener<K,V> - Interface in com.hazelcast.map.listener
Invoked upon eviction of an entry.
entryExpired(EntryEvent<K, V>) - Method in interface com.hazelcast.map.listener.EntryExpiredListener
Invoked upon expiration of an entry.
EntryExpiredListener<K,V> - Interface in com.hazelcast.map.listener
Listener which is notified after removal of an entry due to the expiration-based-eviction.
entryKey() - Static method in class com.hazelcast.jet.function.Functions
Returns a function that extracts the key of a Map.Entry.
EntryListener<K,V> - Interface in com.hazelcast.core
Map Entry listener to get notified when a map entry is added, removed, updated or evicted.
EntryListenerConfig - Class in com.hazelcast.config
Configuration for EntryListener
EntryListenerConfig() - Constructor for class com.hazelcast.config.EntryListenerConfig
 
EntryListenerConfig(String, boolean, boolean) - Constructor for class com.hazelcast.config.EntryListenerConfig
 
EntryListenerConfig(EntryListener, boolean, boolean) - Constructor for class com.hazelcast.config.EntryListenerConfig
 
EntryListenerConfig(MapListener, boolean, boolean) - Constructor for class com.hazelcast.config.EntryListenerConfig
 
EntryListenerConfig(EntryListenerConfig) - Constructor for class com.hazelcast.config.EntryListenerConfig
 
EntryListenerConfig.MapListenerToEntryListenerAdapter - Class in com.hazelcast.config
Wraps a MapListener into an EntryListener.
EntryListenerConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
EntryListenerConfigReadOnly(EntryListenerConfig) - Constructor for class com.hazelcast.config.EntryListenerConfigReadOnly
Deprecated.
 
entryLoaded(EntryEvent<K, V>) - Method in interface com.hazelcast.map.listener.EntryLoadedListener
Invoked upon load of an entry.
EntryLoadedListener<K,V> - Interface in com.hazelcast.map.listener
Invoked upon load of an entry.
entryMerged(EntryEvent<K, V>) - Method in interface com.hazelcast.map.listener.EntryMergedListener
Invoked after WAN replicated entry is merged.
EntryMergedListener<K,V> - Interface in com.hazelcast.map.listener
Invoked after WAN replicated entry is merged.
EntryObject - Class in com.hazelcast.query
This class provides functionality related to build predicate.
EntryObject(PredicateBuilder) - Constructor for class com.hazelcast.query.EntryObject
 
EntryProcessor<K,V> - Interface in com.hazelcast.map
An EntryProcessor passes you a Map.Entry.
entryRemoved(EntryEvent) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
entryRemoved(EntryEvent) - Method in class com.hazelcast.console.ConsoleApp
 
entryRemoved(EntryEvent<K, V>) - Method in class com.hazelcast.core.EntryAdapter
 
entryRemoved(EntryEvent<K, V>) - Method in interface com.hazelcast.map.listener.EntryRemovedListener
Invoked upon removal of an entry.
EntryRemovedListener<K,V> - Interface in com.hazelcast.map.listener
Invoked upon removal of an entry.
entrySet() - Method in interface com.hazelcast.core.IMap
Returns a Set clone of the mappings contained in this map.
entrySet(Predicate) - Method in interface com.hazelcast.core.IMap
Queries the map based on the specified predicate and returns the matching entries.
entrySet() - Method in interface com.hazelcast.core.MultiMap
Returns the set of key-value pairs in the multimap.
entrySet() - Method in interface com.hazelcast.core.ReplicatedMap
Returns a lazy Set view of the mappings contained in this map.
A LazySet is optimized for querying speed (preventing eager deserialization and hashing on HashSet insertion) and does NOT provide all operations.
entrySet() - Method in interface com.hazelcast.map.QueryCache
 
entrySet(Predicate) - Method in interface com.hazelcast.map.QueryCache
 
entrySet() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
This set's iterator also implements Map.Entry so the next() method can just return the iterator instance itself with no heap allocation.
entrySet() - Method in class com.hazelcast.util.collection.InternalListMultiMap
 
entrySet() - Method in class com.hazelcast.util.collection.InternalSetMultimap
 
entrySet() - Method in class com.hazelcast.util.collection.Long2LongHashMap
This set's iterator also implements Map.Entry so the next() method can just return the iterator instance itself with no heap allocation.
entrySet() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
This set's iterator also implements Map.Entry so the next() method can just return the iterator instance itself with no heap allocation.
entrySet() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
Returns a Set view of the mappings contained in this map.
EntryTaskScheduler<K,V> - Interface in com.hazelcast.util.scheduler
Schedules (or reschedules) the execution of given entry.
EntryTaskSchedulerFactory - Class in com.hazelcast.util.scheduler
Factory for EntryTaskSchedulers.
entryUpdated(EntryEvent) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
entryUpdated(EntryEvent) - Method in class com.hazelcast.console.ConsoleApp
 
entryUpdated(EntryEvent<K, V>) - Method in class com.hazelcast.core.EntryAdapter
 
entryUpdated(EntryEvent<K, V>) - Method in interface com.hazelcast.map.listener.EntryUpdatedListener
Invoked upon update of an entry.
EntryUpdatedListener<K,V> - Interface in com.hazelcast.map.listener
Invoked upon update of an entry.
entryValue() - Static method in class com.hazelcast.jet.function.Functions
Returns a function that extracts the value of a Map.Entry.
EntryView<K,V> - Interface in com.hazelcast.core
Represents a read-only view of a data structure entry.
Environment - Class in com.hazelcast.aws.utility
This class is used to lookup env vars, so that we can use mocks in our tests, when checking for the presence of an env var.
Environment() - Constructor for class com.hazelcast.aws.utility.Environment
 
equal(String, Comparable) - Static method in class com.hazelcast.jet.pipeline.GenericPredicates
equal(Comparable) - Method in class com.hazelcast.query.EntryObject
 
equal(String, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates an equal predicate that will pass items if the given value and the value stored under the given item attribute are equal.
equals(Object) - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
 
equals(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
 
equals(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SerializedString
 
equals(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonLocation
 
equals(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
 
equals(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.Name
 
equals(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.Name
 
equals(int, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.Name
 
equals(int[], int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.Name
 
equals(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.Name
 
equals(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.Name1
 
equals(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.Name1
 
equals(int, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.Name1
 
equals(int[], int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.Name1
 
equals(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.Name2
 
equals(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.Name2
 
equals(int, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.Name2
 
equals(int[], int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.Name2
 
equals(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.Name3
 
equals(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.Name3
 
equals(int, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.Name3
 
equals(int[], int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.Name3
 
equals(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.NameN
 
equals(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.NameN
 
equals(int, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.NameN
 
equals(int[], int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.NameN
 
equals(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.Version
 
equals(Object) - Method in class com.hazelcast.concurrent.lock.ConditionKey
 
equals(Object) - Method in class com.hazelcast.concurrent.lock.InternalLockNamespace
 
equals(Object) - Method in class com.hazelcast.concurrent.lock.LockWaitNotifyKey
 
equals(Object) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreWaitNotifyKey
 
equals(Object) - Method in class com.hazelcast.config.AbstractCacheConfig
 
equals(Object) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
 
equals(Object) - Method in class com.hazelcast.config.AtomicLongConfig
 
equals(Object) - Method in class com.hazelcast.config.AtomicReferenceConfig
 
equals(Object) - Method in class com.hazelcast.config.CacheConfig
 
equals(Object) - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
 
equals(Object) - Method in class com.hazelcast.config.CacheSimpleConfig
 
equals(Object) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
equals(Object) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
equals(Object) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
equals(Object) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
equals(Object) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
equals(Object) - Method in class com.hazelcast.config.ClassFilter
 
equals(Object) - Method in class com.hazelcast.config.CollectionConfig
 
equals(Object) - Method in class com.hazelcast.config.CountDownLatchConfig
 
equals(Object) - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
equals(Object) - Method in class com.hazelcast.config.DiscoveryConfig
 
equals(Object) - Method in class com.hazelcast.config.DurableExecutorConfig
 
equals(Object) - Method in class com.hazelcast.config.EntryListenerConfig
 
equals(Object) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
equals(Object) - Method in class com.hazelcast.config.EventJournalConfig
 
equals(Object) - Method in class com.hazelcast.config.EvictionConfig
 
equals(Object) - Method in class com.hazelcast.config.ExecutorConfig
 
equals(Object) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
equals(Object) - Method in class com.hazelcast.config.GlobalSerializerConfig
 
equals(Object) - Method in class com.hazelcast.config.GroupConfig
 
equals(Object) - Method in class com.hazelcast.config.HotRestartConfig
 
equals(Object) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
 
equals(Object) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
equals(Object) - Method in class com.hazelcast.config.InterfacesConfig
 
equals(Object) - Method in class com.hazelcast.config.ItemListenerConfig
 
equals(Object) - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
equals(Object) - Method in class com.hazelcast.config.ListenerConfig
 
equals(Object) - Method in class com.hazelcast.config.LockConfig
 
equals(Object) - Method in class com.hazelcast.config.LoginModuleConfig
 
equals(Object) - Method in class com.hazelcast.config.MapAttributeConfig
 
equals(Object) - Method in class com.hazelcast.config.MapConfig
 
equals(Object) - Method in class com.hazelcast.config.MapIndexConfig
 
equals(Object) - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
 
equals(Object) - Method in class com.hazelcast.config.MapStoreConfig
 
equals(Object) - Method in class com.hazelcast.config.matcher.LegacyMatchingPointConfigPatternMatcher
Deprecated.
 
equals(Object) - Method in class com.hazelcast.config.matcher.LegacyWildcardConfigPatternMatcher
Deprecated.
 
equals(Object) - Method in class com.hazelcast.config.matcher.MatchingPointConfigPatternMatcher
 
equals(Object) - Method in class com.hazelcast.config.matcher.RegexConfigPatternMatcher
 
equals(Object) - Method in class com.hazelcast.config.matcher.WildcardConfigPatternMatcher
 
equals(Object) - Method in class com.hazelcast.config.MaxSizeConfig
 
equals(Object) - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
equals(Object) - Method in class com.hazelcast.config.MemberGroupConfig
 
equals(Object) - Method in class com.hazelcast.config.MergePolicyConfig
 
equals(Object) - Method in class com.hazelcast.config.MerkleTreeConfig
 
equals(Object) - Method in class com.hazelcast.config.MulticastConfig
 
equals(Object) - Method in class com.hazelcast.config.MultiMapConfig
 
equals(Object) - Method in class com.hazelcast.config.NativeMemoryConfig
 
equals(Object) - Method in class com.hazelcast.config.NearCacheConfig
 
equals(Object) - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
equals(Object) - Method in class com.hazelcast.config.PartitionGroupConfig
 
equals(Object) - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
equals(Object) - Method in class com.hazelcast.config.PermissionConfig
 
equals(Object) - Method in class com.hazelcast.config.PermissionPolicyConfig
 
equals(Object) - Method in class com.hazelcast.config.PNCounterConfig
 
equals(Object) - Method in class com.hazelcast.config.PredicateConfig
 
equals(Object) - Method in class com.hazelcast.config.QueryCacheConfig
 
equals(Object) - Method in class com.hazelcast.config.QueueConfig
 
equals(Object) - Method in class com.hazelcast.config.QueueStoreConfig
 
equals(Object) - Method in class com.hazelcast.config.ReliableTopicConfig
 
equals(Object) - Method in class com.hazelcast.config.ReplicatedMapConfig
 
equals(Object) - Method in class com.hazelcast.config.RingbufferConfig
 
equals(Object) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
equals(Object) - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
equals(Object) - Method in class com.hazelcast.config.SecurityConfig
 
equals(Object) - Method in class com.hazelcast.config.SemaphoreConfig
 
equals(Object) - Method in class com.hazelcast.config.SerializationConfig
 
equals(Object) - Method in class com.hazelcast.config.SerializerConfig
 
equals(Object) - Method in class com.hazelcast.config.ServiceConfig
 
equals(Object) - Method in class com.hazelcast.config.ServicesConfig
 
equals(Object) - Method in class com.hazelcast.config.SocketInterceptorConfig
 
equals(Object) - Method in class com.hazelcast.config.SSLConfig
 
equals(Object) - Method in class com.hazelcast.config.TcpIpConfig
 
equals(Object) - Method in class com.hazelcast.config.TopicConfig
 
equals(Object) - Method in class com.hazelcast.config.WanConsumerConfig
 
equals(Object) - Method in class com.hazelcast.config.WanPublisherConfig
 
equals(Object) - Method in class com.hazelcast.config.WanReplicationConfig
 
equals(Object) - Method in class com.hazelcast.config.WanReplicationRef
 
equals(Object) - Method in class com.hazelcast.config.WanSyncConfig
 
equals(Object) - Method in class com.hazelcast.core.HazelcastJsonValue
 
equals(Object) - Method in class com.hazelcast.core.LifecycleEvent
 
equals(Object) - Method in class com.hazelcast.core.PartitionAwareKey
 
equals(Object) - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
equals(Object) - Method in class com.hazelcast.instance.AbstractMember
 
equals(Object) - Method in class com.hazelcast.instance.EndpointQualifier
 
equals(Object) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
equals(Object) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
equals(Object) - Method in class com.hazelcast.jet.accumulator.DoubleAccumulator
 
equals(Object) - Method in class com.hazelcast.jet.accumulator.LinTrendAccumulator
 
equals(Object) - Method in class com.hazelcast.jet.accumulator.LongAccumulator
 
equals(Object) - Method in class com.hazelcast.jet.accumulator.LongDoubleAccumulator
 
equals(Object) - Method in class com.hazelcast.jet.accumulator.LongLongAccumulator
 
equals(Object) - Method in class com.hazelcast.jet.accumulator.MutableReference
 
equals(Object) - Method in class com.hazelcast.jet.config.JobConfig
 
equals(Object) - Method in class com.hazelcast.jet.config.ResourceConfig
 
equals(Object) - Method in class com.hazelcast.jet.core.BroadcastKey
 
equals(Object) - Method in class com.hazelcast.jet.core.Edge
 
equals(Object) - Method in class com.hazelcast.jet.core.metrics.JobMetrics
 
equals(Object) - Method in class com.hazelcast.jet.core.metrics.Measurement
 
equals(Object) - Method in class com.hazelcast.jet.core.Watermark
 
equals(Object) - Method in class com.hazelcast.jet.datamodel.ItemsByTag
 
equals(Object) - Method in class com.hazelcast.jet.datamodel.KeyedWindowResult
 
equals(Object) - Method in class com.hazelcast.jet.datamodel.Tag
 
equals(Object) - Method in class com.hazelcast.jet.datamodel.TimestampedItem
 
equals(Object) - Method in class com.hazelcast.jet.datamodel.Tuple2
 
equals(Object) - Method in class com.hazelcast.jet.datamodel.Tuple3
 
equals(Object) - Method in class com.hazelcast.jet.datamodel.Tuple4
 
equals(Object) - Method in class com.hazelcast.jet.datamodel.Tuple5
 
equals(Object) - Method in class com.hazelcast.jet.datamodel.WindowResult
 
equals(Object) - Method in class com.hazelcast.jet.pipeline.test.SimpleEvent
 
equals(Object) - Method in class com.hazelcast.map.eviction.LFUEvictionPolicy
 
equals(Object) - Method in class com.hazelcast.map.eviction.LRUEvictionPolicy
 
equals(Object) - Method in class com.hazelcast.map.eviction.RandomEvictionPolicy
 
equals(Object) - Method in class com.hazelcast.memory.MemorySize
 
equals(Object) - Method in class com.hazelcast.nio.Address
 
equals(Object) - Method in class com.hazelcast.nio.Packet
 
equals(Object) - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
equals(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v1.common.Anchor
 
equals(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.Event
 
equals(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.Node
Node is only equal to itself
equals(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.Tag
 
equals(Object) - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
equals(Object) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
equals(Object) - Method in class com.hazelcast.query.PartitionPredicate
 
equals(Object) - Method in class com.hazelcast.query.SqlPredicate
 
equals(Object) - Method in class com.hazelcast.query.TruePredicate
 
equals(Object) - Method in class com.hazelcast.security.AbstractCredentials
 
equals(Object) - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
equals(Object) - Method in class com.hazelcast.security.permission.AllPermissions
 
equals(Object) - Method in class com.hazelcast.security.permission.ClusterPermission
 
equals(Object) - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
 
equals(Object) - Method in class com.hazelcast.security.permission.InstancePermission
 
equals(Object) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
equals(Object) - Method in class com.hazelcast.spi.AbstractWaitNotifyKey
 
equals(Object) - Method in class com.hazelcast.spi.DefaultObjectNamespace
Deprecated.
 
equals(Object) - Method in class com.hazelcast.spi.PartitionMigrationEvent
 
equals(Object) - Method in class com.hazelcast.util.collection.IntHashSet
 
equals(Object) - Method in class com.hazelcast.util.collection.LongHashSet
equals(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap.SimpleEntry
 
equals(Object) - Method in class com.hazelcast.util.ItemCounter
 
equals(Object) - Method in class com.hazelcast.util.MutableLong
 
equals(Object) - Method in class com.hazelcast.util.SampleableConcurrentHashMap.SamplingEntry
 
equals(Object) - Method in class com.hazelcast.util.scheduler.ScheduledEntry
 
equals(Object) - Method in class com.hazelcast.version.MemberVersion
 
equals(Object) - Method in class com.hazelcast.version.Version
 
equalsIgnoreCase(String, String) - Static method in class com.hazelcast.util.StringUtil
Returns true if two strings are equals ignoring the letter case in StringUtil.LOCALE_INTERNAL locale.
escape(String) - Method in interface com.hazelcast.org.snakeyaml.engine.external.com.google.gdata.util.common.base.Escaper
Returns the escaped form of a given literal string.
escape(Appendable) - Method in interface com.hazelcast.org.snakeyaml.engine.external.com.google.gdata.util.common.base.Escaper
Returns an Appendable instance which automatically escapes all text appended to it before passing the resulting text to an underlying Appendable.
escape(String) - Method in class com.hazelcast.org.snakeyaml.engine.external.com.google.gdata.util.common.base.PercentEscaper
 
escape(int) - Method in class com.hazelcast.org.snakeyaml.engine.external.com.google.gdata.util.common.base.PercentEscaper
Escapes the given Unicode code point in UTF-8.
escape(int) - Method in class com.hazelcast.org.snakeyaml.engine.external.com.google.gdata.util.common.base.UnicodeEscaper
Returns the escaped form of the given Unicode code point, or null if this code point does not need to be escaped.
escape(String) - Method in class com.hazelcast.org.snakeyaml.engine.external.com.google.gdata.util.common.base.UnicodeEscaper
Returns the escaped form of a given literal string.
escape(Appendable) - Method in class com.hazelcast.org.snakeyaml.engine.external.com.google.gdata.util.common.base.UnicodeEscaper
Returns an Appendable instance which automatically escapes all text appended to it before passing the resulting text to an underlying Appendable.
ESCAPE_CODES - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.common.CharConstants
A mapping from a character to a number of bytes to read-ahead for that escape sequence.
ESCAPE_CUSTOM - Static variable in class com.hazelcast.com.fasterxml.jackson.core.io.CharacterEscapes
Value used for lookup tables to indicate that matching characters will need custom escapes; and that another call to CharacterEscapes.getEscapeSequence(int) is needed to figure out exact escape sequence to output.
ESCAPE_NONE - Static variable in class com.hazelcast.com.fasterxml.jackson.core.io.CharacterEscapes
Value used for lookup tables to indicate that matching characters do not need to be escaped.
ESCAPE_REPLACEMENTS - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.common.CharConstants
A mapping from an escaped character in the input stream to the character that they should be replaced with.
ESCAPE_STANDARD - Static variable in class com.hazelcast.com.fasterxml.jackson.core.io.CharacterEscapes
Value used for lookup tables to indicate that matching characters are to be escaped using standard escaping; for JSON this means (for example) using "backslash - u" escape method.
escapedValue() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.ScalarEvent
 
Escaper - Interface in com.hazelcast.org.snakeyaml.engine.external.com.google.gdata.util.common.base
An object that converts literal text into a format safe for inclusion in a particular context (such as an XML document).
ESCAPES - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.common.CharConstants
A mapping from a character to be escaped to its code in the output stream.
escapeSlow(String, int) - Method in class com.hazelcast.org.snakeyaml.engine.external.com.google.gdata.util.common.base.UnicodeEscaper
Returns the escaped form of a given literal string, starting at the given index.
estimate() - Method in interface com.hazelcast.cardinality.CardinalityEstimator
Estimates the cardinality of the aggregation so far.
estimateAsync() - Method in interface com.hazelcast.cardinality.CardinalityEstimator
Estimates the cardinality of the aggregation so far.
EUREKA_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
EurekaConfig - Class in com.hazelcast.config
Configuration for the Eureka Discovery Strategy.
EurekaConfig() - Constructor for class com.hazelcast.config.EurekaConfig
 
EurekaConfig(EurekaConfig) - Constructor for class com.hazelcast.config.EurekaConfig
 
eval(Object) - Method in interface com.hazelcast.spi.EventFilter
Returns true if the event matches this filter.
evaluate(Key) - Method in interface com.hazelcast.mapreduce.KeyPredicate
Deprecated.
This method evaluates whether or not to select a key.
Event - Class in com.hazelcast.org.snakeyaml.engine.v1.events
Basic unit of output from a Parser or input of a Emitter.
Event(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.events.Event
 
Event() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.events.Event
 
Event.ID - Enum in com.hazelcast.org.snakeyaml.engine.v1.events
 
EVENT_JOURNAL_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
EVENT_QUEUE_CAPACITY - Static variable in class com.hazelcast.spi.properties.GroupProperty
The capacity of the EventServiceImpl executor.
EVENT_QUEUE_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The timeout for offering an event to the event executor for processing.
EVENT_SYNC_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.GroupProperty
To prevent overloading of the outbound connections, once in a while an event is made synchronous by wrapping it in a fake operation and waiting for a fake response.
EVENT_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Number of threads for the EventServiceImpl executor.
EVENT_TYPE - Static variable in class com.hazelcast.map.EventLostEvent
Event type ID.
EventFilter - Interface in com.hazelcast.spi
A predicate that can filter out events.
EventJournalCacheEvent<K,V> - Interface in com.hazelcast.cache.journal
The event for the cache event journal.
EventJournalConfig - Class in com.hazelcast.config
Configuration for an event journal.
EventJournalConfig() - Constructor for class com.hazelcast.config.EventJournalConfig
 
EventJournalConfig(EventJournalConfig) - Constructor for class com.hazelcast.config.EventJournalConfig
EventJournalMapEvent<K,V> - Interface in com.hazelcast.map.journal
The event for the map event journal.
eventLost(EventLostEvent) - Method in interface com.hazelcast.map.listener.EventLostListener
Invoked upon lost of event or events.
EventLostEvent - Class in com.hazelcast.map
This event is fired in case of an event lost detection.
EventLostEvent(String, Member, int) - Constructor for class com.hazelcast.map.EventLostEvent
 
EventLostListener - Interface in com.hazelcast.map.listener
Invoked upon lost of event or events.
EventPublishingService<E,T> - Interface in com.hazelcast.spi
A service for publishing events.
EventRegistration - Interface in com.hazelcast.spi
The result of a Event Registration.
EventService - Interface in com.hazelcast.spi
Component responsible for handling events like topic events or map.listener events.
EventTimeMapper<T> - Class in com.hazelcast.jet.core
A utility to that helps a source emit events according to a given EventTimePolicy.
EventTimeMapper(EventTimePolicy<? super T>) - Constructor for class com.hazelcast.jet.core.EventTimeMapper
The partition count is initially set to 0, call EventTimeMapper.addPartitions(int) to add partitions.
EventTimePolicy<T> - Class in com.hazelcast.jet.core
A holder of functions and parameters Jet needs to handle event time and the associated watermarks.
eventTimePolicy(ToLongFunctionEx<? super T>, ObjLongBiFunction<? super T, ?>, SupplierEx<? extends WatermarkPolicy>, long, long, long) - Static method in class com.hazelcast.jet.core.EventTimePolicy
Creates and returns a new event time policy.
eventTimePolicy(ToLongFunctionEx<? super T>, SupplierEx<? extends WatermarkPolicy>, long, long, long) - Static method in class com.hazelcast.jet.core.EventTimePolicy
Creates and returns a new event time policy.
evict(K) - Method in interface com.hazelcast.core.IMap
Evicts the specified key from this map.
evictAll() - Method in interface com.hazelcast.core.IMap
Evicts all keys from this map except the locked ones.
EvictionConfig - Class in com.hazelcast.config
Configuration for eviction.
EvictionConfig() - Constructor for class com.hazelcast.config.EvictionConfig
 
EvictionConfig(int, EvictionConfig.MaxSizePolicy, EvictionPolicy) - Constructor for class com.hazelcast.config.EvictionConfig
 
EvictionConfig(int, EvictionConfig.MaxSizePolicy, String) - Constructor for class com.hazelcast.config.EvictionConfig
 
EvictionConfig(int, EvictionConfig.MaxSizePolicy, EvictionPolicyComparator) - Constructor for class com.hazelcast.config.EvictionConfig
 
EvictionConfig(EvictionConfig) - Constructor for class com.hazelcast.config.EvictionConfig
 
EvictionConfig.MaxSizePolicy - Enum in com.hazelcast.config
Maximum Size Policy
EvictionConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
EvictionConfigReadOnly(EvictionConfig) - Constructor for class com.hazelcast.config.EvictionConfigReadOnly
Deprecated.
 
evictionPolicy - Variable in class com.hazelcast.config.EvictionConfig
 
EvictionPolicy - Enum in com.hazelcast.config
Eviction Policy enum.
ExceptionAction - Enum in com.hazelcast.spi
The possible actions that can be taken when a certain exception is thrown.
ExceptionUtil - Class in com.hazelcast.util
Contains various exception related utility methods.
ExceptionUtil.RuntimeExceptionFactory - Interface in com.hazelcast.util
Interface used by rethrow/peel to wrap the peeled exception
execute(Runnable, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
Executes a task on a randomly selected member.
execute(String, Runnable) - Method in interface com.hazelcast.spi.ExecutionService
 
execute(Operation) - Method in interface com.hazelcast.spi.OperationService
Executes an operation in the operation executor pool.
execute(TransactionalTaskContext) - Method in interface com.hazelcast.transaction.TransactionalTask
Executes the transactional logic.
execute(Runnable) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
 
execute(Runnable) - Method in class com.hazelcast.util.executor.StripedExecutor
 
executeAsync(Runnable) - Method in interface com.hazelcast.nio.IOService
 
executeAsync(Runnable) - Method in class com.hazelcast.nio.NodeIOService
 
executedLocally() - Method in class com.hazelcast.spi.Operation
Returns true if local member is the caller.
executeEventCallback(Runnable) - Method in interface com.hazelcast.spi.EventService
Executes an event callback on a random event thread.
executeOnAllMembers(Runnable) - Method in interface com.hazelcast.core.IExecutorService
Executes a task on all of the known cluster members.
executeOnEntries(EntryProcessor) - Method in interface com.hazelcast.core.IMap
Applies the user defined EntryProcessor to the all entries in the map.
executeOnEntries(EntryProcessor, Predicate) - Method in interface com.hazelcast.core.IMap
Applies the user defined EntryProcessor to the entries in the map which satisfy provided predicate.
executeOnKey(K, EntryProcessor) - Method in interface com.hazelcast.core.IMap
Applies the user defined EntryProcessor to the entry mapped by the key.
executeOnKeyOwner(Runnable, Object) - Method in interface com.hazelcast.core.IExecutorService
Executes a task on the owner of the specified key.
executeOnKeyOwner(Runnable, Object) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Executes a task on the owner of the specified key.
executeOnKeys(Set<K>, EntryProcessor) - Method in interface com.hazelcast.core.IMap
Applies the user defined EntryProcessor to the entries mapped by the collection of keys.
executeOnMember(Runnable, Member) - Method in interface com.hazelcast.core.IExecutorService
Executes a task on the specified member.
executeOnMembers(Runnable, Collection<Member>) - Method in interface com.hazelcast.core.IExecutorService
Executes a task on each of the specified members.
executeOnMembers(Runnable, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
Executes a task on each of the selected members.
executeRun() - Method in class com.hazelcast.util.executor.HazelcastManagedThread
Does the actual run and can be overridden to customize.
executeTransaction(TransactionalTask<T>) - Method in interface com.hazelcast.core.HazelcastInstance
Executes the given transactional task in current thread using default options and returns the result of the task.
executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in interface com.hazelcast.core.HazelcastInstance
Executes the given transactional task in current thread using given options and returns the result of the task.
executeTransaction(TransactionalTask<T>) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
executeTransaction(TransactionalTask<T>) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in interface com.hazelcast.transaction.TransactionManagerService
 
executeWithDelay() - Method in class com.hazelcast.util.scheduler.CoalescingDelayedTrigger
invoke delayed execution.
EXECUTION - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
Unique ID of a particular execution of a job (sourcing the metric), example value would be a numerical (long) ID encoded in a human readable form, like "2f7f-d88a-4669-6195", see Util.idToString(long) for details.
ExecutionCallback<V> - Interface in com.hazelcast.core
ExecutionCallback allows to asynchronously get notified when the execution is completed, either successfully or with error.
executionCallback - Variable in class com.hazelcast.spi.InvocationBuilder
 
executionId() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
Returns the job execution ID.
executionId() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
 
ExecutionService - Interface in com.hazelcast.spi
A Service responsible for providing access to 'system' executors and customer executors.
executionService - Variable in class com.hazelcast.spi.Offload
 
EXECUTOR_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
ExecutorConfig - Class in com.hazelcast.config
Contains the configuration for an IExecutorService.
ExecutorConfig() - Constructor for class com.hazelcast.config.ExecutorConfig
 
ExecutorConfig(String) - Constructor for class com.hazelcast.config.ExecutorConfig
 
ExecutorConfig(String, int) - Constructor for class com.hazelcast.config.ExecutorConfig
 
ExecutorConfig(ExecutorConfig) - Constructor for class com.hazelcast.config.ExecutorConfig
 
ExecutorConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
ExecutorConfigReadOnly(ExecutorConfig) - Constructor for class com.hazelcast.config.ExecutorConfigReadOnly
Deprecated.
 
ExecutorServicePermission - Class in com.hazelcast.security.permission
 
ExecutorServicePermission(String, String...) - Constructor for class com.hazelcast.security.permission.ExecutorServicePermission
 
ExecutorType - Enum in com.hazelcast.util.executor
 
expandCurrentSegment() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
Method called to expand size of the current segment, to accommodate for more contiguous content.
expandCurrentSegment(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
Method called to expand size of the current segment, to accommodate for more contiguous content.
expectComma() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
 
expectOutput(List<?>) - Method in class com.hazelcast.jet.core.test.TestSupport
Sets the expected output and runs the test.
expectOutputs(List<List<?>>) - Method in class com.hazelcast.jet.core.test.TestSupport
Specifies the expected outputs and runs the test.
expirationTime() - Method in interface com.hazelcast.cp.session.CPSession
Returns the timestamp of when the session will expire
ExpirationTimeMergePolicy<V,T extends MergingExpirationTime<V>> - Class in com.hazelcast.spi.merge
Merges data structure entries from source to destination data structure if the source entry will expire later than the destination entry.
ExpirationTimeMergePolicy() - Constructor for class com.hazelcast.spi.merge.ExpirationTimeMergePolicy
 
expiryPolicyFactory - Variable in class com.hazelcast.config.AbstractCacheConfig
The Factory for the ExpiryPolicy.
ExpiryPolicyFactoryConfig() - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
ExpiryPolicyFactoryConfig(String) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
ExpiryPolicyFactoryConfig(CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
export() - Method in class com.hazelcast.jet.accumulator.DoubleAccumulator
Returns the current value.
export() - Method in class com.hazelcast.jet.accumulator.LinTrendAccumulator
Computes the linear coefficient of the linear regression of the accumulated samples.
exportFn() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
A primitive that transforms the accumulator into a result of the aggregation.
exportSnapshot(String) - Method in interface com.hazelcast.jet.Job
Exports a state snapshot and saves it under the given name.
extendLeaseTime(Data, String, long, long) - Method in interface com.hazelcast.concurrent.lock.LockStore
Extend the lease time for an already locked key.
extendLeaseTime(Data, String, long, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
extendLeaseTime(Data, String, long, long) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
 
EXTENSION_PRIORITY_LIST - Static variable in class com.hazelcast.instance.DefaultNodeContext
 
extra - Variable in class com.hazelcast.com.fasterxml.jackson.core.type.WritableTypeId
Optional additional information that generator may add during "prefix write", to be available on matching "suffix write".
extract(ValueIn) - Method in interface com.hazelcast.mapreduce.aggregation.PropertyExtractor
Deprecated.
This method is called for every value that is about to be supplied to an aggregation (maybe filtered through an Predicate or KeyPredicate).
extract(T, A, ValueCollector) - Method in class com.hazelcast.query.extractor.ValueExtractor
Extracts a value from the given target object.
extractInt(long, boolean) - Static method in class com.hazelcast.nio.Bits
 
extractShort(int, boolean) - Static method in class com.hazelcast.nio.Bits
 

F

f0() - Method in class com.hazelcast.jet.datamodel.Tuple2
Returns the value of the field 0.
f0() - Method in class com.hazelcast.jet.datamodel.Tuple3
Returns the value of the field 0.
f0() - Method in class com.hazelcast.jet.datamodel.Tuple4
Returns the value of the field 0.
f0() - Method in class com.hazelcast.jet.datamodel.Tuple5
Returns the value of the field 0.
f1() - Method in class com.hazelcast.jet.datamodel.Tuple2
Returns the value of the field 1.
f1() - Method in class com.hazelcast.jet.datamodel.Tuple3
Returns the value of the field 1.
f1() - Method in class com.hazelcast.jet.datamodel.Tuple4
Returns the value of the field 1.
f1() - Method in class com.hazelcast.jet.datamodel.Tuple5
Returns the value of the field 1.
f2() - Method in class com.hazelcast.jet.datamodel.Tuple3
Returns the value of the field 2.
f2() - Method in class com.hazelcast.jet.datamodel.Tuple4
Returns the value of the field 2.
f2() - Method in class com.hazelcast.jet.datamodel.Tuple5
Returns the value of the field 2.
f3() - Method in class com.hazelcast.jet.datamodel.Tuple4
Returns the value of the field 3.
f3() - Method in class com.hazelcast.jet.datamodel.Tuple5
Returns the value of the field 3.
f4() - Method in class com.hazelcast.jet.datamodel.Tuple5
Returns the value of the field 4.
F_ID - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.crdt.CRDTDataSerializerHook
The CRDT (de)serializer factory ID
FACTOR - Static variable in class com.hazelcast.util.scheduler.SecondsBasedEntryTaskScheduler
 
FACTORY_ID - Static variable in class com.hazelcast.jet.config.JetConfigDataSerializerHook
 
FACTORY_ID - Static variable in class com.hazelcast.jet.core.JetDataSerializerHook
 
FACTORY_ID - Static variable in class com.hazelcast.jet.core.metrics.MetricsDataSerializerHook
 
fail(String) - Static method in class com.hazelcast.jet.core.test.JetAssert
Throws an AssertionError with the given message.
FAIL_ON_INDETERMINATE_OPERATION_STATE - Static variable in class com.hazelcast.spi.properties.GroupProperty
When this configuration is enabled, if an operation has sync backups and acks are not received from backup replicas in time, or the member which owns primary replica of the target partition leaves the cluster, then the invocation fails with IndeterminateOperationStateException.
failOnIndeterminateOperationState - Variable in class com.hazelcast.spi.InvocationBuilder
 
fastIntMix(int) - Static method in class com.hazelcast.util.HashUtil
Hash function based on Knuth's multiplicative method.
fastLongMix(long) - Static method in class com.hazelcast.util.HashUtil
Hash function based on Knuth's multiplicative method.
FEAT_MASK_TRAILING_COMMA - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
 
FEAT_MASK_TRAILING_COMMA - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
 
feedInput(byte[], int, int) - Method in interface com.hazelcast.com.fasterxml.jackson.core.async.ByteArrayFeeder
Method that can be called to feed more data, if (and only if) NonBlockingInputFeeder.needMoreInput() returns true.
feedInput(ByteBuffer) - Method in interface com.hazelcast.com.fasterxml.jackson.core.async.ByteBufferFeeder
Method that can be called to feed more data, if (and only if) NonBlockingInputFeeder.needMoreInput() returns true.
feedInput(byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
 
FencedLock - Interface in com.hazelcast.cp.lock
A linearizable & distributed & reentrant implementation of Lock.
FencedLockConfig - Class in com.hazelcast.config.cp
Contains configuration options for FencedLock
FencedLockConfig() - Constructor for class com.hazelcast.config.cp.FencedLockConfig
 
FencedLockConfig(String) - Constructor for class com.hazelcast.config.cp.FencedLockConfig
 
FencedLockConfig(String, int) - Constructor for class com.hazelcast.config.cp.FencedLockConfig
 
fetchEntries(int, int, List<Map.Entry<K, V>>) - Method in class com.hazelcast.util.SampleableConcurrentHashMap
Fetches entries from given tableIndex as size and puts them into entries list.
fetchKeys(int, int, List<K>) - Method in class com.hazelcast.util.SampleableConcurrentHashMap
Fetches keys from given tableIndex as size and puts them into keys list.
FieldDefinition - Interface in com.hazelcast.nio.serialization
FieldDefinition defines name, type, index of a field
fieldNames() - Method in interface com.hazelcast.com.fasterxml.jackson.core.TreeNode
Method for accessing names of all fields for this node, iff this node is an Object node.
fieldsToString() - Method in class com.hazelcast.config.CollectionConfig
Returns field names with values as concatenated String so it can be used in child classes' toString() methods.
FieldType - Enum in com.hazelcast.nio.serialization
 
files(String, SupplierEx<Schema>, SupplierEx<DatumWriter<R>>) - Static method in class com.hazelcast.jet.avro.AvroSinks
Returns a sink that that writes the items it receives to Apache Avro files.
files(String, SupplierEx<Schema>, Class<R>) - Static method in class com.hazelcast.jet.avro.AvroSinks
Convenience for AvroSinks.files(String, SupplierEx, SupplierEx) which uses either SpecificDatumWriter or ReflectDatumWriter depending on the supplied recordClass.
files(String, SupplierEx<Schema>) - Static method in class com.hazelcast.jet.avro.AvroSinks
Convenience for AvroSinks.files(String, SupplierEx, SupplierEx) which uses GenericDatumWriter.
files(String, Class<D>) - Static method in class com.hazelcast.jet.avro.AvroSources
Convenience for AvroSources.filesBuilder(String, Class) which reads all the files in the supplied directory as specific records using supplied datumClass.
files(String, BiFunctionEx<String, GenericRecord, D>) - Static method in class com.hazelcast.jet.avro.AvroSources
Convenience for AvroSources.filesBuilder(String, SupplierEx) which reads all the files in the supplied directory as generic records and emits the results of transforming each generic record with the supplied mapping function.
files(String) - Static method in class com.hazelcast.jet.pipeline.Sinks
Convenience for Sinks.filesBuilder(java.lang.String) with the UTF-8 charset and with overwriting of existing files.
files(String) - Static method in class com.hazelcast.jet.pipeline.Sources
A source to read all files in a directory in a batch way.
filesBuilder(String, Class<D>) - Static method in class com.hazelcast.jet.avro.AvroSources
Returns a builder object that offers a step-by-step fluent API to build a custom Avro file source for the Pipeline API.
filesBuilder(String, SupplierEx<? extends DatumReader<D>>) - Static method in class com.hazelcast.jet.avro.AvroSources
Returns a builder object that offers a step-by-step fluent API to build a custom Avro file source for the Pipeline API.
filesBuilder(String) - Static method in class com.hazelcast.jet.pipeline.Sinks
Returns a builder object that offers a step-by-step fluent API to build a custom file sink for the Pipeline API.
filesBuilder(String) - Static method in class com.hazelcast.jet.pipeline.Sources
Returns a builder object that offers a step-by-step fluent API to build a custom source to read files for the Pipeline API.
FileSinkBuilder<T> - Class in com.hazelcast.jet.pipeline
FileSourceBuilder - Class in com.hazelcast.jet.pipeline
Builder for a file source which reads lines from files in a directory (but not its subdirectories) and emits output object created by mapOutputFn
FileSystemXmlConfig - Class in com.hazelcast.config
A Config which includes functionality for loading itself from a XML configuration file.
FileSystemXmlConfig(String) - Constructor for class com.hazelcast.config.FileSystemXmlConfig
Creates a Config based on a Hazelcast xml file and uses the System.properties to resolve variables in the XML.
FileSystemXmlConfig(String, Properties) - Constructor for class com.hazelcast.config.FileSystemXmlConfig
Creates a Config based on a Hazelcast XML file.
FileSystemXmlConfig(File) - Constructor for class com.hazelcast.config.FileSystemXmlConfig
Creates a Config based on a Hazelcast xml file and uses the System.properties to resolve variables in the XML.
FileSystemXmlConfig(File, Properties) - Constructor for class com.hazelcast.config.FileSystemXmlConfig
Creates a Config based on a Hazelcast XML file.
FileSystemYamlConfig - Class in com.hazelcast.config
A Config which includes functionality for loading itself from a YAML configuration file.
FileSystemYamlConfig(String) - Constructor for class com.hazelcast.config.FileSystemYamlConfig
Creates a Config based on a Hazelcast yaml file and uses the System.properties to resolve variables in the YAML.
FileSystemYamlConfig(String, Properties) - Constructor for class com.hazelcast.config.FileSystemYamlConfig
Creates a Config based on a Hazelcast YAML file.
FileSystemYamlConfig(File) - Constructor for class com.hazelcast.config.FileSystemYamlConfig
Creates a Config based on a Hazelcast yaml file and uses the System.properties to resolve variables in the YAML.
FileSystemYamlConfig(File, Properties) - Constructor for class com.hazelcast.config.FileSystemYamlConfig
Creates a Config based on a Hazelcast YAML file.
fileWatcher(String) - Static method in class com.hazelcast.jet.pipeline.Sources
A source to stream lines added to files in a directory.
fillBufferFn(BiConsumerEx<? super C, ? super SourceBuilder.SourceBuffer<T_NEW>>) - Method in class com.hazelcast.jet.pipeline.SourceBuilder.Batch
Sets the function that Jet will call whenever it needs more data from your source.
fillBufferFn(BiConsumerEx<? super C, ? super SourceBuilder.SourceBuffer<T_NEW>>) - Method in class com.hazelcast.jet.pipeline.SourceBuilder.Stream
 
fillBufferFn(BiConsumerEx<? super C, ? super SourceBuilder.TimestampedSourceBuffer<T_NEW>>) - Method in class com.hazelcast.jet.pipeline.SourceBuilder.TimestampedStream
Sets the function that Jet will call whenever it needs more data from your source.
fillDataSerializableFactories(Node, SerializationConfig) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
fillJavaSerializationFilter(Node, SerializationConfig) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
fillNativeMemoryConfig(Node, NativeMemoryConfig) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
fillPortableFactories(Node, SerializationConfig) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
fillProperties(Node, Map<String, Comparable>) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
fillProperties(Node, Properties) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
fillProperties(Node, Map<String, Comparable>, boolean) - Static method in class com.hazelcast.config.DomConfigHelper
 
fillProperties(Node, Properties, boolean) - Static method in class com.hazelcast.config.DomConfigHelper
 
fillSerializers(Node, SerializationConfig) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
filter(String, String) - Method in class com.hazelcast.jet.core.metrics.JobMetrics
Convenience method for #filter(Predicate), returns a new JobMetrics instance containing only those Measurements which have the specified tag set to the specified value.
filter(Predicate<Measurement>) - Method in class com.hazelcast.jet.core.metrics.JobMetrics
Returns a new JobMetrics instance containing a subset of the Measurements found in the current one.
filter(PredicateEx<T>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
 
filter(PredicateEx<T>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
Attaches a filtering stage which applies the provided predicate function to each input item to decide whether to pass the item to the output or to discard it.
filter(PredicateEx<T>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
 
filter(Predicate<? super T>) - Method in interface com.hazelcast.jet.Traverser
Returns a traverser that will emit the same items as this traverser, but only those that pass the given predicate.
filter(String) - Method in interface com.hazelcast.nio.ClassNameFilter
filter(String) - Method in class com.hazelcast.nio.SerializationClassNameFilter
Throws SecurityException if the given class name appears on the blacklist or does not appear a whitelist.
filter(QueryContext) - Method in interface com.hazelcast.query.IndexAwarePredicate
Produces a filtered entry set by utilizing the indexes available while executing the query in the given query context.
filter(QueryContext) - Method in class com.hazelcast.query.PagingPredicate
Used if inner predicate is instanceof IndexAwarePredicate for filtering.
filter(QueryContext) - Method in class com.hazelcast.query.PredicateBuilder
 
filter(QueryContext) - Method in class com.hazelcast.query.SqlPredicate
 
filterConnection(String, TcpIpConnection) - Method in class com.hazelcast.nio.ascii.AllowingTextProtocolFilter
 
filterConnection(String, TcpIpConnection) - Method in class com.hazelcast.nio.ascii.RestApiFilter
 
filterFinishArray() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
Method called to indicate that output of non-filtered Array (one that may have been included either completely, or in part) is completed, in cases where filter other that TokenFilter.INCLUDE_ALL was returned.
filterFinishObject() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
Method called to indicate that output of non-filtered Object (one that may have been included either completely, or in part) is completed, in cases where filter other that TokenFilter.INCLUDE_ALL was returned.
filtering(PredicateEx<? super T>, AggregateOperation1<? super T, A, ? extends R>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Adapts an aggregate operation so that it accumulates only the items passing the filterFn and ignores others.
FilteringGeneratorDelegate - Class in com.hazelcast.com.fasterxml.jackson.core.filter
Specialized JsonGeneratorDelegate that allows use of TokenFilter for outputting a subset of content that caller tries to generate.
FilteringGeneratorDelegate(JsonGenerator, TokenFilter, boolean, boolean) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
 
FilteringParserDelegate - Class in com.hazelcast.com.fasterxml.jackson.core.filter
Specialized JsonParserDelegate that allows use of TokenFilter for outputting a subset of content that is visible to caller
FilteringParserDelegate(JsonParser, TokenFilter, boolean, boolean) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
 
filterP(PredicateEx<? super T>) - Static method in class com.hazelcast.jet.core.processor.Processors
Returns a supplier of processors for a vertex that emits the same items it receives, but only those that pass the given predicate.
filterStartArray() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.JsonPointerBasedFilter
 
filterStartArray() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
Method called to check whether Array value at current output location should be included in output.
filterStartObject() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.JsonPointerBasedFilter
 
filterStartObject() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
Method called to check whether Object value at current output location should be included in output.
filterStateful(SupplierEx<? extends S>, BiPredicateEx<? super S, ? super T>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
 
filterStateful(SupplierEx<? extends S>, BiPredicateEx<? super S, ? super T>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
 
filterStateful(SupplierEx<? extends S>, BiPredicateEx<? super S, ? super T>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
Attaches a stage that performs a stateful filtering operation.
filterStateful(SupplierEx<? extends S>, BiPredicateEx<? super S, ? super T>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
Attaches a stage that performs a stateful filtering operation.
filterStateful(SupplierEx<? extends S>, BiPredicateEx<? super S, ? super T>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
 
filterStateful(long, SupplierEx<? extends S>, BiPredicateEx<? super S, ? super T>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
Attaches a stage that performs a stateful filtering operation.
filterStateful(SupplierEx<? extends S>, BiPredicateEx<? super S, ? super T>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
 
filterUsingContext(ContextFactory<C>, BiPredicateEx<? super C, ? super T>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
 
filterUsingContext(ContextFactory<C>, TriPredicate<? super C, ? super K, ? super T>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
 
filterUsingContext(ContextFactory<C>, BiPredicateEx<? super C, ? super T>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
Attaches a filtering stage which applies the provided predicate function to each input item to decide whether to pass the item to the output or to discard it.
filterUsingContext(ContextFactory<C>, TriPredicate<? super C, ? super K, ? super T>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
Attaches a filtering stage which applies the provided predicate function to each input item to decide whether to pass the item to the output or to discard it.
filterUsingContext(ContextFactory<C>, BiPredicateEx<? super C, ? super T>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
 
filterUsingContext(ContextFactory<C>, TriPredicate<? super C, ? super K, ? super T>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
 
filterUsingContextAsync(ContextFactory<C>, BiFunctionEx<? super C, ? super T, ? extends CompletableFuture<Boolean>>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
 
filterUsingContextAsync(ContextFactory<C>, TriFunction<? super C, ? super K, ? super T, CompletableFuture<Boolean>>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
 
filterUsingContextAsync(ContextFactory<C>, BiFunctionEx<? super C, ? super T, ? extends CompletableFuture<Boolean>>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
Asynchronous version of GeneralStage.filterUsingContext(com.hazelcast.jet.pipeline.ContextFactory<C>, com.hazelcast.jet.function.BiPredicateEx<? super C, ? super T>): the filterAsyncFn returns a CompletableFuture<Boolean> instead of just a boolean.
filterUsingContextAsync(ContextFactory<C>, TriFunction<? super C, ? super K, ? super T, CompletableFuture<Boolean>>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
Asynchronous version of GeneralStageWithKey.filterUsingContext(com.hazelcast.jet.pipeline.ContextFactory<C>, com.hazelcast.jet.function.TriPredicate<? super C, ? super K, ? super T>): the filterAsyncFn returns a CompletableFuture<Boolean> instead of just a boolean.
filterUsingContextAsync(ContextFactory<C>, BiFunctionEx<? super C, ? super T, ? extends CompletableFuture<Boolean>>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
 
filterUsingContextAsync(ContextFactory<C>, TriFunction<? super C, ? super K, ? super T, CompletableFuture<Boolean>>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
 
filterUsingContextAsyncP(ContextFactory<C>, FunctionEx<T, K>, BiFunctionEx<? super C, ? super T, CompletableFuture<Boolean>>) - Static method in class com.hazelcast.jet.core.processor.Processors
Asynchronous version of Processors.filterUsingContextP(com.hazelcast.jet.pipeline.ContextFactory<C>, com.hazelcast.jet.function.BiPredicateEx<? super C, ? super T>): the filterAsyncFn returns a CompletableFuture<Boolean> instead of just a boolean.
filterUsingContextP(ContextFactory<C>, BiPredicateEx<? super C, ? super T>) - Static method in class com.hazelcast.jet.core.processor.Processors
Returns a supplier of processors for a vertex that emits the same items it receives, but only those that pass the given predicate.
finalizeChunk() - Method in class com.hazelcast.mapreduce.Combiner
Deprecated.
Creates a chunk of ValueOut to be sent to the Reducer for the according key.
finalizeCombine() - Method in class com.hazelcast.mapreduce.Combiner
Deprecated.
This method is called after the mapping phase on the local node is over.
finalized(Context<KeyOut, ValueOut>) - Method in interface com.hazelcast.mapreduce.LifecycleMapper
Deprecated.
This method is called after the Mapper.map(Object, Object, Context) method is executed for every value and can be used to finalize the internal state of the mapper or to emit a special value.
finalized(Context<KeyOut, ValueOut>) - Method in class com.hazelcast.mapreduce.LifecycleMapperAdapter
Deprecated.
This method is called after the Mapper.map(Object, Object, Context) method is executed for every value and can be used to finalize the internal state of the mapper or to emit a special value.
finalizeReduce() - Method in class com.hazelcast.mapreduce.Reducer
Deprecated.
finalizeReduce is called as last step for a reducing phase per key.
findAtomicLongConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only AtomicLong configuration for the given name.
findAtomicReferenceConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only AtomicReference configuration for the given name.
findCacheConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only CacheSimpleConfig configuration for the given name.
findCacheConfigOrNull(String) - Method in class com.hazelcast.config.Config
Returns the cache config with the given name or null if there is none.
findCacheEventJournalConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only cache EventJournal configuration for the given name.
findCardinalityEstimatorConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only CardinalityEstimator configuration for the given name.
findChildOf(TokenFilterContext) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
 
findCountDownLatchConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only CountDownLatch configuration for the given name.
findDurableExecutorConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only durable executor configuration for the given name.
findExecutorConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only executor configuration for the given name.
findFlakeIdGeneratorConfig(String) - Method in class com.hazelcast.config.Config
Returns a FlakeIdGeneratorConfig configuration for the given flake ID generator name.
findFormat(InputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatDetector
Method to call to find format that content (accessible via given InputStream) given has, as per configuration of this detector instance.
findFormat(byte[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatDetector
Method to call to find format that given content (full document) has, as per configuration of this detector instance.
findFormat(byte[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatDetector
Method to call to find format that given content (full document) has, as per configuration of this detector instance.
findJobTrackerConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only JobTracker configuration for the given name.
findListConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only IList configuration for the given name.
findLocation() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.DupDetector
 
findLockConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only ILock configuration for the given name.
findLockConfig(String) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the FencedLock configuration for the given name.
findMapConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only IMap configuration for the given name.
findMapEventJournalConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only map EventJournal configuration for the given name.
findMapMerkleTreeConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only map MerkleTreeConfig for the given name.
findMultiMapConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only MultiMap configuration for the given name.
findName(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
 
findName(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
 
findName(int, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
 
findName(int[], int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
 
findPNCounterConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only PNCounterConfig configuration for the given name.
findQueueConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only IQueue configuration for the given name.
findQuorumConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only split-brain protection configuration for the given name.
findReliableTopicConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only reliable topic configuration for the given name.
findReplicatedMapConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only ReplicatedMap configuration for the given name.
findRingbufferConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only Ringbuffer configuration for the given name.
findScheduledExecutorConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only scheduled executor configuration for the given name.
findSemaphoreConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only ISemaphore configuration for the given name.
findSemaphoreConfig(String) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the CP ISemaphore configuration for the given name.
findSetConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only ISet configuration for the given name.
findSymbol(char[], int, int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
 
findTopicConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only ITopic configuration for the given name.
fine(String) - Method in class com.hazelcast.logging.AbstractLogger
 
fine(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
fine(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
fine(String) - Method in interface com.hazelcast.logging.ILogger
Logs a message at the Level.FINE level.
fine(Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a throwable at the Level.FINE level.
fine(String, Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a message with an associated throwable at the Level.FINE level.
finest(String) - Method in class com.hazelcast.logging.AbstractLogger
 
finest(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
finest(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
finest(String) - Method in interface com.hazelcast.logging.ILogger
Logs a message at the Level.FINEST level.
finest(Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a throwable at the Level.FINEST level.
finest(String, Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a message with an associated throwable at the Level.FINEST level.
finishCurrentSegment() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
Method called when the current segment buffer is full; will append to current contents, allocate a new segment buffer and return it
finishCurrentSegment() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
 
finishFn() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
A primitive that transforms the accumulator into a result of the aggregation.
finishSnapshotRestore() - Method in interface com.hazelcast.jet.core.Processor
Called after a job was restarted from a snapshot and the processor has consumed all the snapshot data.
finishToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
 
finishToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
 
finishToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
 
finishToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Method that may be used to force full handling of the current token so that even if lazy processing is enabled, the whole contents are read for possible retrieval.
finishToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
 
fireLifecycleEvent(LifecycleEvent.LifecycleState) - Method in class com.hazelcast.instance.LifecycleServiceImpl
 
fireLifecycleEvent(LifecycleEvent) - Method in class com.hazelcast.instance.LifecycleServiceImpl
 
firstCaller - Variable in class com.hazelcast.concurrent.semaphore.operations.SemaphoreBackupOperation
 
fixAsyncStackTrace(Throwable, StackTraceElement[]) - Static method in class com.hazelcast.util.ExceptionUtil
This method changes the given async cause, and it adds the also given local stacktrace.
If the remoteCause is an ExecutionException and it has a non-null inner cause, this inner cause is unwrapped and the local stacktrace and exception message are added to the that instead of the given asyncCause itself.
fixAsyncStackTrace(Throwable, StackTraceElement[], String) - Static method in class com.hazelcast.util.ExceptionUtil
This method changes the given async cause, and it adds the also given local stacktrace separated by the supplied exception message.
If the remoteCause is an ExecutionException and it has a non-null inner cause, this inner cause is unwrapped and the local stacktrace and exception message are added to the that instead of the given remoteCause itself.
fixedPointSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
fixedPointSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
FixedSpaceIndenter() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter.FixedSpaceIndenter
 
fixScopeIdAndGetInetAddress(InetAddress) - Static method in class com.hazelcast.util.AddressUtil
 
FLAG_JET_FLOW_CONTROL - Static variable in class com.hazelcast.nio.Packet
Marks a Jet packet as Flow control
FLAG_OP_CONTROL - Static variable in class com.hazelcast.nio.Packet
Marks an Operation packet as Operation control (like invocation-heartbeats)
FLAG_OP_RESPONSE - Static variable in class com.hazelcast.nio.Packet
Marks an Operation packet as Response
FLAG_URGENT - Static variable in class com.hazelcast.nio.Packet
Marks the packet as Urgent
FLAKE_ID_GENERATOR_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
FlakeIdGenerator - Interface in com.hazelcast.flakeidgen
A cluster-wide unique ID generator.
FlakeIdGeneratorConfig - Class in com.hazelcast.config
The FlakeIdGeneratorConfig contains the configuration for the member regarding Flake ID Generator.
FlakeIdGeneratorConfig(String) - Constructor for class com.hazelcast.config.FlakeIdGeneratorConfig
 
FlakeIdGeneratorConfig(FlakeIdGeneratorConfig) - Constructor for class com.hazelcast.config.FlakeIdGeneratorConfig
Copy-constructor
FlakeIdGeneratorConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
FlakeIdGeneratorPermission - Class in com.hazelcast.security.permission
 
FlakeIdGeneratorPermission(String, String...) - Constructor for class com.hazelcast.security.permission.FlakeIdGeneratorPermission
 
flatMap(FunctionEx<? super T, ? extends Traverser<? extends R>>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
 
flatMap(FunctionEx<? super T, ? extends Traverser<? extends R>>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
Attaches a flat-mapping stage which applies the supplied function to each input item independently and emits all the items from the Traverser it returns.
flatMap(FunctionEx<? super T, ? extends Traverser<? extends R>>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
 
flatMap(Function<? super T, ? extends Traverser<? extends R>>) - Method in interface com.hazelcast.jet.Traverser
Returns a traverser that will apply the given mapping function to each item retrieved from this traverser and emit all the items from the resulting traversers, which must be null-terminated.
flatMapEvent(T, int, long) - Method in class com.hazelcast.jet.core.EventTimeMapper
Flat-maps the given event by (possibly) prepending it with a watermark.
flatMapIdle() - Method in class com.hazelcast.jet.core.EventTimeMapper
Call this method when there is no event coming.
flatMapP(FunctionEx<? super T, ? extends Traverser<? extends R>>) - Static method in class com.hazelcast.jet.core.processor.Processors
Returns a supplier of processors for a vertex that applies the provided item-to-traverser mapping function to each received item and emits all the items from the resulting traverser.
flatMapper(int, Function<? super T, ? extends Traverser<? extends R>>) - Method in class com.hazelcast.jet.core.AbstractProcessor
flatMapper(Function<? super T, ? extends Traverser<? extends R>>) - Method in class com.hazelcast.jet.core.AbstractProcessor
flatMapper(int[], Function<? super T, ? extends Traverser<? extends R>>) - Method in class com.hazelcast.jet.core.AbstractProcessor
flatMapping(FunctionEx<? super T, ? extends Traverser<? extends U>>, AggregateOperation1<? super U, A, ? extends R>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Adapts an aggregate operation that takes items of type U to one that takes items of type T, by exploding each T into a sequence of Us and then accumulating all of them.
flatMapStateful(SupplierEx<? extends S>, BiFunctionEx<? super S, ? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
 
flatMapStateful(SupplierEx<? extends S>, TriFunction<? super S, ? super K, ? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
 
flatMapStateful(SupplierEx<? extends S>, BiFunctionEx<? super S, ? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
Attaches a stage that performs a stateful flat-mapping operation.
flatMapStateful(SupplierEx<? extends S>, TriFunction<? super S, ? super K, ? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
Attaches a stage that performs a stateful flat-mapping operation.
flatMapStateful(SupplierEx<? extends S>, BiFunctionEx<? super S, ? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
 
flatMapStateful(long, SupplierEx<? extends S>, TriFunction<? super S, ? super K, ? super T, ? extends Traverser<R>>, TriFunction<? super S, ? super K, ? super Long, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
Attaches a stage that performs a stateful flat-mapping operation.
flatMapStateful(SupplierEx<? extends S>, TriFunction<? super S, ? super K, ? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
 
flatMapStatefulP(long, FunctionEx<? super T, ? extends K>, ToLongFunctionEx<? super T>, Supplier<? extends S>, TriFunction<? super S, ? super K, ? super T, ? extends Traverser<R>>, TriFunction<? super S, ? super K, ? super Long, ? extends Traverser<R>>) - Static method in class com.hazelcast.jet.core.processor.Processors
Returns a supplier of processors for a vertex that performs a stateful flat-mapping of its input.
flatMapUsingContext(ContextFactory<C>, BiFunctionEx<? super C, ? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
 
flatMapUsingContext(ContextFactory<C>, TriFunction<? super C, ? super K, ? super T, ? extends Traverser<? extends R>>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
 
flatMapUsingContext(ContextFactory<C>, BiFunctionEx<? super C, ? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
Attaches a flat-mapping stage which applies the supplied function to each input item independently and emits all items from the Traverser it returns as the output items.
flatMapUsingContext(ContextFactory<C>, TriFunction<? super C, ? super K, ? super T, ? extends Traverser<? extends R>>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
Attaches a flat-mapping stage which applies the supplied function to each input item independently and emits all the items from the Traverser it returns as the output items.
flatMapUsingContext(ContextFactory<C>, BiFunctionEx<? super C, ? super T, ? extends Traverser<R>>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
 
flatMapUsingContext(ContextFactory<C>, TriFunction<? super C, ? super K, ? super T, ? extends Traverser<? extends R>>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
 
flatMapUsingContextAsync(ContextFactory<C>, BiFunctionEx<? super C, ? super T, ? extends CompletableFuture<Traverser<R>>>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
 
flatMapUsingContextAsync(ContextFactory<C>, TriFunction<? super C, ? super K, ? super T, CompletableFuture<Traverser<R>>>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
 
flatMapUsingContextAsync(ContextFactory<C>, BiFunctionEx<? super C, ? super T, ? extends CompletableFuture<Traverser<R>>>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
flatMapUsingContextAsync(ContextFactory<C>, TriFunction<? super C, ? super K, ? super T, CompletableFuture<Traverser<R>>>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
flatMapUsingContextAsync(ContextFactory<C>, BiFunctionEx<? super C, ? super T, ? extends CompletableFuture<Traverser<R>>>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
 
flatMapUsingContextAsync(ContextFactory<C>, TriFunction<? super C, ? super K, ? super T, CompletableFuture<Traverser<R>>>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
 
flatMapUsingContextAsyncP(ContextFactory<C>, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super C, ? super T, CompletableFuture<Traverser<R>>>) - Static method in class com.hazelcast.jet.core.processor.Processors
flatMapUsingContextP(ContextFactory<C>, BiFunctionEx<? super C, ? super T, ? extends Traverser<? extends R>>) - Static method in class com.hazelcast.jet.core.processor.Processors
Returns a supplier of processors for a vertex that applies the provided item-to-traverser mapping function to each received item and emits all the items from the resulting traverser.
flattenMapping(MappingNode) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor
 
FLOAT - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.nodes.Tag
 
FLOAT - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.resolver.JsonScalarResolver
 
FLOAT_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
FLOAT_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
FLOAT_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
Float size in bytes
floatingPointSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
floatingPointSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
floorFrameTs(long) - Method in class com.hazelcast.jet.core.SlidingWindowPolicy
Returns the highest frame timestamp less than or equal to the given timestamp.
FlowEntryToken - Class in com.hazelcast.org.snakeyaml.engine.v1.tokens
 
FlowEntryToken(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.tokens.FlowEntryToken
 
FlowMappingEndToken - Class in com.hazelcast.org.snakeyaml.engine.v1.tokens
 
FlowMappingEndToken(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.tokens.FlowMappingEndToken
 
FlowMappingStartToken - Class in com.hazelcast.org.snakeyaml.engine.v1.tokens
 
FlowMappingStartToken(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.tokens.FlowMappingStartToken
 
FlowSequenceEndToken - Class in com.hazelcast.org.snakeyaml.engine.v1.tokens
 
FlowSequenceEndToken(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.tokens.FlowSequenceEndToken
 
FlowSequenceStartToken - Class in com.hazelcast.org.snakeyaml.engine.v1.tokens
 
FlowSequenceStartToken(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.tokens.FlowSequenceStartToken
 
FlowStyle - Enum in com.hazelcast.org.snakeyaml.engine.v1.common
Block styles use indentation to denote nesting and scope within the document.
flush() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
 
flush() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SegmentedStringWriter
 
flush() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.UTF8Writer
 
flush() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
 
flush() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
 
flush() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
Method called to flush any buffered content to the underlying target (output stream, writer), and to flush the target itself as well.
flush() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
 
flush() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
 
flush() - Method in interface com.hazelcast.core.IMap
If this map has a MapStore, this method flushes all the local dirty entries.
flush() - Method in interface com.hazelcast.org.snakeyaml.engine.v1.api.StreamDataWriter
Flushes this stream by writing any buffered output to the underlying stream.
flushFn(ConsumerEx<Session>) - Method in class com.hazelcast.jet.pipeline.JmsSinkBuilder
Sets the function which flushes the session after a batch of messages is sent.
flushFn(ConsumerEx<? super Session>) - Method in class com.hazelcast.jet.pipeline.JmsSourceBuilder
Sets the function which commits the session after consuming each message.
flushFn(ConsumerEx<? super W>) - Method in class com.hazelcast.jet.pipeline.SinkBuilder
Sets the function that implements the sink's flushing behavior.
footprint() - Method in class com.hazelcast.util.collection.OAHashSet
Returns the current memory consumption (in bytes)
footprint() - Method in class com.hazelcast.wan.merkletree.ArrayMerkleTree
 
footprint() - Method in interface com.hazelcast.wan.merkletree.MerkleTree
Returns the memory footprint of Merkle Tree in bytes
forceCloseSession(String, long) - Method in interface com.hazelcast.cp.session.CPSessionManagementService
If a Hazelcast instance that owns a CP session crashes, its CP session is not terminated immediately.
forceDestroyCPGroup(String) - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Unconditionally destroys the given active CP group without using the Raft algorithm mechanics.
forceLocalMemberToBeSafe(long, TimeUnit) - Method in interface com.hazelcast.core.PartitionService
Force the local member to be safe by checking and syncing partitions owned by the local member with at least one of the backups.
forceStartBeforeJoin() - Method in interface com.hazelcast.hotrestart.InternalHotRestartService
Executes force-start process, resets local hot restart data and member gets a new UUID.
forceStartBeforeJoin() - Method in class com.hazelcast.hotrestart.NoopInternalHotRestartService
 
forceTotalParallelismOne(ProcessorSupplier) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
Variant of ProcessorMetaSupplier.forceTotalParallelismOne(ProcessorSupplier, String) where the node for the supplier will be chosen randomly.
forceTotalParallelismOne(ProcessorSupplier, String) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
Wraps the provided ProcessorSupplier into a meta-supplier that will only use the given ProcessorSupplier on a single node.
forceUnlock() - Method in class com.hazelcast.concurrent.lock.LockProxy
 
forceUnlock(NodeEngine, Data) - Method in class com.hazelcast.concurrent.lock.LockProxySupport
 
forceUnlock(Data) - Method in interface com.hazelcast.concurrent.lock.LockStore
Unlock the key regardless of the owner.
forceUnlock(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
forceUnlock(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
 
forceUnlock() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
 
forceUnlock() - Method in interface com.hazelcast.core.ILock
Deprecated.
Releases the lock regardless of the lock owner.
forceUnlock(K) - Method in interface com.hazelcast.core.IMap
Releases the lock for the specified key regardless of the lock owner.
forceUnlock(K) - Method in interface com.hazelcast.core.MultiMap
Releases the lock for the specified key regardless of the lock owner.
forEach(BiInt2ObjectMap.EntryConsumer<V>) - Method in class com.hazelcast.util.collection.BiInt2ObjectMap
Iterate over the entries of the map
forEach(Consumer<V>) - Method in class com.hazelcast.util.collection.BiInt2ObjectMap
Iterate over the values in the map
forEach(BiConsumer<? super Long, ? super Long>) - Method in class com.hazelcast.util.collection.Long2LongHashMap
 
forEachKeyOfNode(int, Consumer<Object>) - Method in class com.hazelcast.wan.merkletree.ArrayMerkleTree
 
forEachKeyOfNode(int, Consumer<Object>) - Method in interface com.hazelcast.wan.merkletree.MerkleTree
Performs the given action for each key of the specified node until all elements have been processed or the action throws an exception.
FORMAT_NAME_JSON - Static variable in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
Name used to identify JSON format (and returned by JsonFactory.getFormatName()
FormatFeature - Interface in com.hazelcast.com.fasterxml.jackson.core
Marker interface that is to be implemented by data format - specific features.
FormatSchema - Interface in com.hazelcast.com.fasterxml.jackson.core
Simple tag interface used to mark schema objects that are used by some JsonParser and JsonGenerator implementations to further specify structure of expected format.
forPath(JsonStreamContext, boolean) - Static method in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
Factory method that will construct a pointer instance that describes path to location given JsonStreamContext points to.
forValue - Variable in class com.hazelcast.com.fasterxml.jackson.core.type.WritableTypeId
Java object for which type id is being written.
forValueType - Variable in class com.hazelcast.com.fasterxml.jackson.core.type.WritableTypeId
(optional) Super-type of WritableTypeId.forValue to use for type id generation (if no explicit id passed): used instead of actual class of WritableTypeId.forValue in cases where we do not want to use the "real" type but something more generic, usually to work around specific problem with implementation type, or its deserializer.
forward() - Method in class com.hazelcast.org.snakeyaml.engine.v1.scanner.StreamReader
 
forward(int) - Method in class com.hazelcast.org.snakeyaml.engine.v1.scanner.StreamReader
read the next length characters and move the pointer.
FragmentedMigrationAwareService - Interface in com.hazelcast.spi
FragmentedMigrationAwareService is an extension to the MigrationAwareService which allows migration/replication of partition replicas in smaller fragments.
frameOffset() - Method in class com.hazelcast.jet.core.SlidingWindowPolicy
Returns the frame offset.
frameSize() - Method in class com.hazelcast.jet.core.SlidingWindowPolicy
Returns the length of the frame (equal to the sliding step).
FREE_MAX_PERCENTAGE_PROP - Static variable in class com.hazelcast.instance.DefaultOutOfMemoryHandler
 
freePhysicalMemory() - Static method in class com.hazelcast.memory.MemoryStatsSupport
Returns the amount of physical memory that is available on the system in bytes or -1 if not available.
freeSwapSpace() - Static method in class com.hazelcast.memory.MemoryStatsSupport
Returns the amount of free swap space in bytes or -1 if not available.
from(Vertex) - Static method in class com.hazelcast.jet.core.Edge
Returns an edge with the given source vertex and no destination vertex.
from(Vertex, int) - Static method in class com.hazelcast.jet.core.Edge
Returns an edge with the given source vertex at the given ordinal and no destination vertex.
fromFlags(int) - Static method in enum com.hazelcast.nio.Packet.Type
 
fromJsonObject(JsonObject) - Static method in class com.hazelcast.util.JsonUtil
Transforms the provided JsonObject int a map of name/value pairs.
fromKeyPredicate(KeyPredicate<KeyIn>) - Static method in class com.hazelcast.mapreduce.aggregation.Supplier
Deprecated.
The predefined Supplier selects values using the given KeyPredicate and does not perform any kind of data transformation.
fromKeyPredicate(KeyPredicate<KeyIn>, Supplier<KeyIn, ValueIn, ValueOut>) - Static method in class com.hazelcast.mapreduce.aggregation.Supplier
Deprecated.
The predefined Supplier selects values using the given KeyPredicate and chains the filtered value to the given Supplier which might perform data transformation.
fromList(IList<? extends V>) - Static method in class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
A helper method to build a KeyValueSource implementation based on the specified IList.
The key returned by this KeyValueSource implementation is ALWAYS the name of the list itself, whereas the value are the entries of the list, one by one.
fromMap(IMap<? super K, ? extends V>) - Static method in class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
A helper method to build a KeyValueSource implementation based on the specified IMap
fromMaxSizePolicy(EvictionConfig.MaxSizePolicy) - Static method in enum com.hazelcast.config.CacheEvictionConfig.CacheMaxSizePolicy
Deprecated.
 
fromMultiMap(MultiMap<? super K, ? extends V>) - Static method in class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
A helper method to build a KeyValueSource implementation based on the specified MultiMap
fromPredicate(Predicate<KeyIn, ValueIn>) - Static method in class com.hazelcast.mapreduce.aggregation.Supplier
Deprecated.
The predefined Supplier selects values using the given Predicate and does not perform any kind of data transformation.
fromPredicate(Predicate<KeyIn, ValueIn>, Supplier<KeyIn, ValueIn, ValueOut>) - Static method in class com.hazelcast.mapreduce.aggregation.Supplier
Deprecated.
The predefined Supplier selects values using the given Predicate and chains the filtered value to the given Supplier which might perform data transformation.
fromProcessor(String, ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.pipeline.Sinks
Returns a sink constructed directly from the given Core API processor meta-supplier.
fromSet(ISet<? extends V>) - Static method in class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
A helper method to build a KeyValueSource implementation based on the specified ISet.
The key returned by this KeyValueSource implementation is ALWAYS the name of the set itself, whereas the value are the entries of the set, one by one.
function - Variable in class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
 
function - Variable in class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
 
function - Variable in class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
 
Function<T,R> - Interface in com.hazelcast.util.function
 
FunctionEx<T,R> - Interface in com.hazelcast.jet.function
Serializable variant of java.util.function.Function which declares checked exception.
Functions - Class in com.hazelcast.jet.function
Factory methods for several common functions.
FutureUtil - Class in com.hazelcast.util
This utility class contains convenience methods to work with multiple futures at the same time, e.g.
FutureUtil.ExceptionHandler - Interface in com.hazelcast.util
Internally used interface to define behavior of the FutureUtil methods when exceptions arise

G

GarbageCollectorStats - Interface in com.hazelcast.memory
Garbage collector statistics for the JVM which current HazelcastInstance belongs to.
GCP_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
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
 
GCStatsSupport - Class in com.hazelcast.memory
Used to gather garbage collection statistics.
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(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
Convenience for JetConfigXmlGenerator.generate(JetConfig, int) without any indentation
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.GroupProperty
The number of generic operation handler threads per member.
GENERIC_PARTITION_ID - Static variable in class com.hazelcast.spi.Operation
Marks an Operation as non-partition-specific.
GenericPredicates - Class in com.hazelcast.jet.pipeline
Generic wrappers for methods in Predicates.
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() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongContainer
 
GET - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
get() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
get() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceContainer
 
GET - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
get() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
get(String) - Static method in enum com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
 
get(Object) - Method in interface com.hazelcast.core.BaseMap
Returns the value for the specified key, or null if this map does not contain this key.
get(K) - Method in interface com.hazelcast.core.BaseMultiMap
Returns the collection of values associated with the key.
get() - Method in interface com.hazelcast.core.IAtomicLong
Gets the current value.
get() - Method in interface com.hazelcast.core.IAtomicReference
Gets the current value.
get(Object) - Method in interface com.hazelcast.core.IMap
Returns the value for the specified key, or null if this map does not contain this key.
get(K) - Method in interface com.hazelcast.core.MultiMap
Returns the collection of values associated with the key.
get(Object) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.get(Object).
get(K) - Method in interface com.hazelcast.core.TransactionalMultiMap
Returns the collection of values associated with the key.
get() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Returns the current value of the counter.
get(VectorClock) - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
Returns the current value of the counter.
get() - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
 
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(String) - Method in class com.hazelcast.jet.core.metrics.JobMetrics
Returns all Measurements associated with a given metric name.
get(List<Address>) - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
Called to create a mapping from member Address to the ProcessorSupplier that will be sent to that member.
get(int) - Method in interface com.hazelcast.jet.core.ProcessorSupplier
Called after ProcessorSupplier.init(Context) to retrieve instances of Processor that will be used during the execution of the Jet job.
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() - Method in interface com.hazelcast.jet.function.SupplierEx
 
get(Object) - Method in interface com.hazelcast.map.QueryCache
 
get(byte) - Static method in enum com.hazelcast.nio.serialization.FieldType
 
get(String) - Method in class com.hazelcast.query.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(int, int) - Method in class com.hazelcast.util.collection.BiInt2ObjectMap
Retrieve a value from the map.
get(K1, K2) - Method in class com.hazelcast.util.collection.ComposedKeyMap
 
get(Object) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
 
get(int) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
Overloaded version of Map.get(Object) that takes a primitive int key.
get(K) - Method in class com.hazelcast.util.collection.InternalListMultiMap
Return collection of values associated with a given key
get(K) - Method in class com.hazelcast.util.collection.InternalSetMultimap
Return Set of values associated with a given key
get(long) - Method in class com.hazelcast.util.collection.Long2LongHashMap
 
get(Object) - Method in class com.hazelcast.util.collection.Long2LongHashMap
 
get(Object) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
 
get(long) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
Overloaded version of Map.get(Object) that takes a primitive long key.
get(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
Returns the value to which the specified key is mapped, or null if this map contains no mapping for the key.
get() - Method in class com.hazelcast.util.executor.CompletedFuture
 
get(long, TimeUnit) - Method in class com.hazelcast.util.executor.CompletedFuture
 
get() - Method in class com.hazelcast.util.executor.DelegatingFuture
 
get(long, TimeUnit) - Method in class com.hazelcast.util.executor.DelegatingFuture
 
get() - Method in interface com.hazelcast.util.function.Supplier
 
get(T) - Method in class com.hazelcast.util.ItemCounter
Get current counter for an item item
get(K) - Method in interface com.hazelcast.util.scheduler.EntryTaskScheduler
Return the entry for the scheduled key.
get(K) - Method in class com.hazelcast.util.scheduler.SecondsBasedEntryTaskScheduler
 
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).
GET_AND_ADD - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
GET_AND_ALTER - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
GET_AND_ALTER - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
GET_AND_SET - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
GET_AND_SET - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
GET_COUNT_OPERATION - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
 
GET_FREE_PHYSICAL_MEMORY_SIZE_DISABLED - Static variable in class com.hazelcast.util.OperatingSystemMXBeanSupport
On AIX it can happen that the getFreePhysicalMemorySize method is very slow.
GET_LOCK_COUNT - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
GET_REMAINING_LEASETIME - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
getAccessHit() - Method in interface com.hazelcast.cache.CacheEntryView
Gets the count of how many time this cache entry has been accessed.
getAccessKey() - Method in class com.hazelcast.aws.AwsConfig
 
getAccessKey() - Method in class com.hazelcast.config.AwsConfig
getAcknowledgeType() - Method in class com.hazelcast.wan.WanReplicationEvent
 
getAcquireTime() - Method in interface com.hazelcast.concurrent.lock.LockResource
 
getActions() - Method in class com.hazelcast.config.PermissionConfig
 
getActions() - Method in class com.hazelcast.security.permission.AllPermissions
 
getActions() - Method in class com.hazelcast.security.permission.ConfigPermission
 
getActions() - Method in class com.hazelcast.security.permission.InstancePermission
 
getActions() - Method in class com.hazelcast.security.permission.TransactionPermission
 
getActiveConnections() - Method in interface com.hazelcast.nio.AggregateEndpointManager
 
getActiveConnections() - Method in class com.hazelcast.nio.DefaultAggregateEndpointManager
 
getActiveConnections() - Method in interface com.hazelcast.nio.EndpointManager
Returns all connections bind or not that are currently holding resources on this member.
getActiveConnections() - Method in class com.hazelcast.nio.tcp.TcpIpEndpointManager
 
getActiveConnections() - Method in class com.hazelcast.nio.UnifiedAggregateEndpointManager
 
getActiveMemberNetworkConfig(Config) - Static method in class com.hazelcast.config.ConfigAccessor
 
getActivePublisherName() - Method in interface com.hazelcast.monitor.WanSyncState
 
getActiveWanConfigName() - Method in interface com.hazelcast.monitor.WanSyncState
 
getActualDelayMillis() - Method in class com.hazelcast.util.scheduler.ScheduledEntry
 
getActualDelaySeconds() - Method in class com.hazelcast.util.scheduler.ScheduledEntry
 
getAddedPublisherIds() - Method in class com.hazelcast.wan.AddWanConfigResult
Returns the IDs for the WAN publishers which were added to the configuration.
getAddress() - Method in interface com.hazelcast.core.Member
Returns the Address of this Member.
getAddress() - Method in interface com.hazelcast.cp.CPMember
Returns the address of this CP member.
getAddress() - Method in class com.hazelcast.instance.AbstractMember
 
getAddress() - Method in interface com.hazelcast.monitor.MemberState
 
getAddress() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
Returns the address of the member the task is associated with.
getAddress() - Method in class com.hazelcast.util.AddressUtil.AddressHolder
 
getAddress() - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
 
getAddresses() - Method in class com.hazelcast.aws.AWSClient
 
getAddressHolder(String) - Static method in class com.hazelcast.util.AddressUtil
 
getAddressHolder(String, int) - Static method in class com.hazelcast.util.AddressUtil
 
getAddressMap() - Method in interface com.hazelcast.core.Member
 
getAddressMap() - Method in class com.hazelcast.instance.AbstractMember
 
getAddressMatcher(String) - Static method in class com.hazelcast.util.AddressUtil
Gets an AddressMatcher for a given addresses.
getAdvancedNetworkConfig() - Method in class com.hazelcast.config.Config
 
getAggregateEndpointManager() - Method in interface com.hazelcast.nio.NetworkingService
Return an aggregate endpoint which acts as a view of all endpoints merged together for reporting purposes eg.
getAggregateEndpointManager() - Method in class com.hazelcast.nio.tcp.TcpIpNetworkingService
The aggregate endpoint manager acts as a composite of all configured endpoints.
getAlgorithm() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
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.core.IMap
Returns the 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
 
getAllDistributedObjects() - Method in interface com.hazelcast.spi.ProxyService
 
getAllDone(Collection<Future>) - Static method in class com.hazelcast.util.FutureUtil
Get all futures that are done
getAllHazelcastInstances() - Static method in class com.hazelcast.core.Hazelcast
Returns all active/running HazelcastInstances on this JVM.
getAllHazelcastInstances() - Static method in class com.hazelcast.instance.HazelcastInstanceFactory
 
getAllHazelcastInstances() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Gets all active/running HazelcastOSGiInstances on the owner bundle.
getAllInterfaces(Class<?>) - Static method in class com.hazelcast.nio.ClassLoaderUtil
 
getAllKeys() - Method in class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
If KeyValueSource.isAllKeysSupported() returns true, a call to this method returns all clusterwide available keys.
getAllKeys0() - Method in class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
This method is meant to be overridden to implement collecting of all clusterwide available keys and return them from KeyValueSource.getAllKeys().
getAllLocks() - Method in interface com.hazelcast.concurrent.lock.LockService
 
getAllLocks() - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
getAllNamespaces(int) - Method in class com.hazelcast.concurrent.lock.LockStoreContainer
 
getAllocatorType() - Method in class com.hazelcast.config.NativeMemoryConfig
Returns the NativeMemoryConfig.MemoryAllocatorType to be used while allocating native memory.
getAllowDuplicateKeys() - Method in class com.hazelcast.org.snakeyaml.engine.v1.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.
getAllServiceNamespaces(PartitionReplicationEvent) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
getAllServiceNamespaces(PartitionReplicationEvent) - Method in interface com.hazelcast.spi.FragmentedMigrationAwareService
Returns all known namespaces for given replication event.
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.v1.common.Anchor
 
getAnchor() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.NodeEvent
Node anchor by which this node might later be referenced by a AliasEvent.
getAnchor() - Method in class 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.v1.api.DumpSettings
 
getAndAdd(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongContainer
 
getAndAdd(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
getAndAdd(long) - Method in interface com.hazelcast.core.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.
getAndAdd(long, VectorClock) - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
Adds the given value to the current value.
getAndAdd(long) - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
 
getAndAddAsync(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
getAndAddAsync(long) - Method in interface com.hazelcast.core.IAtomicLong
Atomically adds the given value to the current value.
GetAndAddOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
GetAndAddOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
 
GetAndAddOperation(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
 
getAndAlter(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
getAndAlter(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
getAndAlter(IFunction<Long, Long>) - Method in interface com.hazelcast.core.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.core.IAtomicReference
Alters the currently stored reference by applying a function on it on and gets the old value.
getAndAlterAsync(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
getAndAlterAsync(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
getAndAlterAsync(IFunction<Long, Long>) - Method in interface com.hazelcast.core.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.core.IAtomicReference
Alters the currently stored reference by applying a function on it on and gets the old value.
GetAndAlterOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
GetAndAlterOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetAndAlterOperation
 
GetAndAlterOperation(String, IFunction<Long, Long>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetAndAlterOperation
 
GetAndAlterOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
GetAndAlterOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.GetAndAlterOperation
 
GetAndAlterOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.GetAndAlterOperation
 
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.crdt.pncounter.PNCounter
Decrements by one the current value.
getAndDecrement() - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
 
getAndInc() - Method in class com.hazelcast.util.MutableInteger
 
getAndIncrement() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
getAndIncrement() - Method in interface com.hazelcast.core.IAtomicLong
Atomically increments the current value by one.
getAndIncrement() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Increments by one the current value.
getAndIncrement() - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
 
getAndIncrementAsync() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
getAndIncrementAsync() - Method in interface com.hazelcast.core.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 class com.hazelcast.concurrent.atomiclong.AtomicLongContainer
 
getAndSet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
getAndSet(Data) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceContainer
 
getAndSet(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
getAndSet(long) - Method in interface com.hazelcast.core.IAtomicLong
Atomically sets the given value and returns the old value.
getAndSet(E) - Method in interface com.hazelcast.core.IAtomicReference
Gets the old value and sets the new value.
getAndSet(T, long) - Method in class com.hazelcast.util.ItemCounter
Set counter for item and return previous value
getAndSetAsync(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
getAndSetAsync(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
getAndSetAsync(long) - Method in interface com.hazelcast.core.IAtomicLong
Atomically sets the given value and returns the old value.
getAndSetAsync(E) - Method in interface com.hazelcast.core.IAtomicReference
Gets the value and sets the new value.
GetAndSetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
GetAndSetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
 
GetAndSetOperation(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
 
GetAndSetOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
GetAndSetOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
 
GetAndSetOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
 
getAndSubtract(long) - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Subtracts the given value from the current value.
getAndSubtract(long, VectorClock) - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
Subtracts the given value from the current value.
getAndSubtract(long) - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
 
getAppendRequestBackoffTimeoutInMillis() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
getAppendRequestMaxEntryCount() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
getArray(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
Returns a field in a Json object as an array.
getArray(JsonObject, String, JsonArray) - Static method in class com.hazelcast.util.JsonUtil
Returns a field in a Json object as an array.
getArrayValueSeparator() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.Separators
 
getArtifactId() - Method in class com.hazelcast.com.fasterxml.jackson.core.Version
 
getAsReadOnly() - Method in class com.hazelcast.config.AtomicLongConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.AtomicReferenceConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.CacheConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.CacheEvictionConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.CacheSimpleConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.CollectionConfig
 
getAsReadOnly() - Method in class com.hazelcast.config.CountDownLatchConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.DiscoveryConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.EntryListenerConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.EvictionConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.ExecutorConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.ItemListenerConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.JobTrackerConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.ListConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.ListenerConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.LockConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.MapAttributeConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.MapConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.MapIndexConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.MapStoreConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.MaxSizeConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.MergePolicyConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.MultiMapConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.NearCacheConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.PartitioningStrategyConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.PredicateConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.QueryCacheConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.QueueConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.QueueStoreConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.ReliableTopicConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.ReplicatedMapConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.RingbufferConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.RingbufferStoreConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.SemaphoreConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.SetConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.TopicConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
getAsReadOnly() - Method in class com.hazelcast.config.WanReplicationRef
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
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 class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
getAsync() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
getAsync() - Method in interface com.hazelcast.core.IAtomicLong
Gets the current value.
getAsync() - Method in interface com.hazelcast.core.IAtomicReference
Gets the current value.
getAsync(K) - Method in interface com.hazelcast.core.IMap
Asynchronously gets the given key.
getAsyncBackupCount() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBackupAwareOperation
 
getAsyncBackupCount() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBackupAwareOperation
 
getAsyncBackupCount() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
getAsyncBackupCount() - Method in interface com.hazelcast.concurrent.lock.LockStoreInfo
 
getAsyncBackupCount() - Method in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
getAsyncBackupCount() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreBackupAwareOperation
 
getAsyncBackupCount() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDetachMemberOperation
 
getAsyncBackupCount() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
 
getAsyncBackupCount() - Method in class com.hazelcast.config.CacheConfig
Gets the number of asynchronous backups for this ICache.
getAsyncBackupCount() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the number of asynchronous backups for this ICache.
getAsyncBackupCount() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Gets the number of synchronous backups.
getAsyncBackupCount() - Method in class com.hazelcast.config.CollectionConfig
Gets the number of asynchronous backups.
getAsyncBackupCount() - Method in class com.hazelcast.config.MapConfig
Returns the asynchronous backup count for this IMap.
getAsyncBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
Gets the number of asynchronous backups for this MultiMap.
getAsyncBackupCount() - Method in class com.hazelcast.config.QueueConfig
Get the number of asynchronous backups for this queue.
getAsyncBackupCount() - Method in class com.hazelcast.config.RingbufferConfig
Gets the number of asynchronous backups.
getAsyncBackupCount() - Method in class com.hazelcast.config.SemaphoreConfig
Returns the number of asynchronous backups.
getAsyncBackupCount() - Method in interface com.hazelcast.spi.BackupAwareOperation
The asynchronous backup count.
getAtomicLong(String) - Method in interface com.hazelcast.core.HazelcastInstance
Deprecated.
This implementation may lose strong consistency in case of network failures or server failures. Please use CPSubsystem.getAtomicLong(String) instead. This method will be removed in Hazelcast 4.0.
getAtomicLong(String) - Method in interface com.hazelcast.cp.CPSubsystem
Returns a proxy for an IAtomicLong instance created on the CP subsystem.
getAtomicLong(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getAtomicLong(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getAtomicLongConfig(String) - Method in class com.hazelcast.config.Config
Returns the AtomicLongConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getAtomicLongConfigs() - Method in class com.hazelcast.config.Config
Returns the map of AtomicLong configurations, mapped by config name.
getAtomicNumber() - Method in class com.hazelcast.console.ConsoleApp
 
getAtomicReference(String) - Method in interface com.hazelcast.core.HazelcastInstance
Deprecated.
This implementation may lose strong consistency in case of network failures or server failures. Please use CPSubsystem.getAtomicReference(String) instead. This method will be removed in Hazelcast 4.0.
getAtomicReference(String) - Method in interface com.hazelcast.cp.CPSubsystem
Returns a proxy for an IAtomicReference instance created on the CP subsystem.
getAtomicReference(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getAtomicReference(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getAtomicReferenceConfig(String) - Method in class com.hazelcast.config.Config
Returns the AtomicReferenceConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getAtomicReferenceConfigs() - Method in class com.hazelcast.config.Config
Returns the map of AtomicReference configurations, mapped by config name.
getAttribute(Node, String) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
getAttribute(Node, String, boolean) - Static method in class com.hazelcast.config.DomConfigHelper
 
getAttribute() - Method in class com.hazelcast.config.MapIndexConfig
Gets the attribute that is going to be indexed.
getAttribute(String) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
getAttribute(String) - Method in class com.hazelcast.instance.AbstractMember
 
getAttribute() - Method in class com.hazelcast.query.PredicateBuilder
 
getAttributeNode(String) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
getAttributeNodeNS(String, String) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
getAttributeNS(String, String) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
getAttributes() - Method in class com.hazelcast.config.MemberAttributeConfig
 
getAttributes() - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
Deprecated.
 
getAttributes() - Method in class com.hazelcast.config.yaml.ElementAdapter
 
getAttributes() - Method in interface com.hazelcast.core.Member
Returns configured attributes for this member.
This method might not be available on all native clients.
getAttributes() - Method in class com.hazelcast.instance.AbstractMember
 
getAvailabilityZone() - Method in class com.hazelcast.aws.AWSClient
 
getAvailable() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
 
getAverageGetTime() - Method in interface com.hazelcast.cache.CacheStatistics
The mean time to execute gets.
getAverageGetTime() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the mean time to execute gets on the cache.
getAverageHitLatency() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the average hit latency (in nanoseconds) for the index.
getAverageHitSelectivity() - Method in interface com.hazelcast.monitor.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.
getAveragePutTime() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the mean time to execute puts on the cache.
getAverageRemoveTime() - Method in interface com.hazelcast.cache.CacheStatistics
The mean time to execute removes.
getAverageRemoveTime() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the mean time to execute removes on the cache.
getAvgAge() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns the average age of the items in this member.
getAwsConfig() - Method in class com.hazelcast.config.JoinConfig
 
getAwsConfig() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the AwsConfig used by the discovery mechanism for this WAN publisher.
getAzureConfig() - Method in class com.hazelcast.config.JoinConfig
 
getAzureConfig() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the AzureConfig used by the discovery mechanism for this WAN publisher.
getBackupCount() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
getBackupCount() - Method in interface com.hazelcast.concurrent.lock.LockStoreInfo
 
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.config.SemaphoreConfig
Returns the number of synchronous backups.
getBackupCount() - Method in class com.hazelcast.jet.config.InstanceConfig
Returns the number of backups used for job metadata and snapshots.
getBackupCount() - Method in interface com.hazelcast.monitor.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.
getBackupDirectory() - Method in class com.hazelcast.hotrestart.NoOpHotRestartService
 
getBackupDirectory() - Method in interface com.hazelcast.monitor.HotRestartState
 
getBackupEntryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the number of backup entries hold by this member.
getBackupEntryMemoryCost() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns memory cost (number of bytes) of backup entries in this member.
getBackupItemCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns the number of backup items in this member.
getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
 
getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
 
getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
 
getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
 
getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
 
getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.MergeOperation
 
getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.SetOperation
 
getBackupOperation() - Method in class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
 
getBackupOperation() - Method in class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
 
getBackupOperation() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
 
getBackupOperation() - Method in class com.hazelcast.concurrent.atomicreference.operations.MergeOperation
 
getBackupOperation() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetAndGetOperation
 
getBackupOperation() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetOperation
 
getBackupOperation() - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
 
getBackupOperation() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
 
getBackupOperation() - Method in class com.hazelcast.concurrent.lock.operations.LockOperation
 
getBackupOperation() - Method in class com.hazelcast.concurrent.lock.operations.SignalOperation
 
getBackupOperation() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
 
getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
 
getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainOperation
 
getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.IncreaseOperation
 
getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.InitOperation
 
getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceOperation
 
getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
 
getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDetachMemberOperation
 
getBackupOperation() - Method in interface com.hazelcast.spi.BackupAwareOperation
Creates the BackupOperation responsible for making the backup.
getBackupProcessor() - Method in class com.hazelcast.map.AbstractEntryProcessor
 
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).
getBackupTaskStatus() - Method in class com.hazelcast.hotrestart.NoOpHotRestartService
 
getBackupTaskStatus() - Method in interface com.hazelcast.monitor.HotRestartState
Returns the local hot restart backup task status (not the cluster backup status).
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
 
getBaseURI() - Method in class com.hazelcast.config.yaml.ElementAdapter
 
getBatchCount() - Method in interface com.hazelcast.monitor.LocalFlakeIdGeneratorStats
The average batch size can be calculated by dividing LocalFlakeIdGeneratorStats.getIdCount() by getBatchCount().
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.
getBestLineBreak() - Method in class com.hazelcast.org.snakeyaml.engine.v1.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
Convenience alternative to JsonParser.getBinaryValue(Base64Variant) that defaults to using Base64Variants.getDefaultVariant() as the default encoding.
getBinaryValue(Base64Variant) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
 
getBindAddress() - Method in interface com.hazelcast.instance.AddressPicker
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
 
getBlacklist() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
getBlacklistedPrefixes() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Return currently configured blacklist prefixes.
getBoolean(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured boolean value of a HazelcastProperty.
getBoolean(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
Returns a field in a Json object as a boolean.
getBoolean(JsonObject, String, boolean) - Static method in class com.hazelcast.util.JsonUtil
Returns a field in a Json object as a boolean.
getBooleanAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
 
getBooleanAttribute(String) - Method in interface com.hazelcast.core.Member
Returns the value of the specified key for this member, or null if the value is undefined.
getBooleanAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
 
getBooleanValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
 
getBooleanValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Convenience accessor that can be called when the current token is JsonToken.VALUE_TRUE or JsonToken.VALUE_FALSE.
getBooleanValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
 
getBooleanValue(String) - Static method in class com.hazelcast.config.DomConfigHelper
 
getBuffer() - Method in class com.hazelcast.org.snakeyaml.engine.v1.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.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.v1.api.LoadSettings
 
getBufferWithoutReset() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
 
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.
getBuildInfo() - Method in class com.hazelcast.instance.Node
 
getBuildNumber() - Method in class com.hazelcast.instance.BuildInfo
 
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.MetadataPolicy
Returns the MetadataPolicy for the given ID.
getById(int) - Static method in enum com.hazelcast.config.WanAcknowledgeType
Returns the WanAcknowledgeType for the given ID.
getById(int) - Static method in enum com.hazelcast.ringbuffer.OverflowPolicy
Returns the OverflowPolicy for the given ID.
getById(byte) - Static method in enum com.hazelcast.util.IterationType
Returns the IterationType for the given ID.
getByStatus(int) - Static method in enum com.hazelcast.wan.WanSyncStatus
 
getByteAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
 
getByteAttribute(String) - Method in interface com.hazelcast.core.Member
Returns the value of the specified key for this member or null if the value is undefined.
getByteAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
 
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(byte) - Static method in enum com.hazelcast.config.WanPublisherState
Returns the WanPublisherState as an enum.
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
 
getByValue(int) - Static method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
 
getCache(String) - Method in interface com.hazelcast.core.ICacheManager
Returns the cache instance with the specified prefixed cache name.
getCache(String) - Method in class com.hazelcast.instance.HazelcastInstanceCacheManager
 
getCache(String) - Method in interface com.hazelcast.jet.JetCacheManager
Returns the cache instance with the specified, optionally prefixed, cache name:
getCacheByFullName(String) - Method in class com.hazelcast.instance.HazelcastInstanceCacheManager
 
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
 
getCacheEntryListenerConfigurations() - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
getCacheEntryListenerFactory() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
getCacheEntryListeners() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets a list of CacheSimpleEntryListenerConfig from this ICache.
getCacheEntryListeners() - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
getCacheEventJournalConfig(String) - Method in class com.hazelcast.config.Config
Returns the cache event journal config for the given name, creating one if necessary and adding it to the collection of known configurations.
getCacheEventJournalConfigs() - Method in class com.hazelcast.config.Config
Returns the map of cache event journal configurations, mapped by config name.
getCacheEvictions() - Method in interface com.hazelcast.cache.CacheStatistics
The total number of evictions from the cache.
getCacheEvictions() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the number of evictions on the cache.
getCacheGets() - Method in interface com.hazelcast.cache.CacheStatistics
The total number of requests to the cache.
getCacheGets() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the number of gets on the cache.
getCacheHitPercentage() - Method in interface com.hazelcast.cache.CacheStatistics
This is a measure of cache efficiency.
getCacheHitPercentage() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the percentage of hits (successful get operations) on the cache.
getCacheHits() - Method in interface com.hazelcast.cache.CacheStatistics
The number of get requests that were satisfied by the cache.
getCacheHits() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the number of hits (successful get operations) on 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() - 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 class com.hazelcast.instance.HazelcastInstanceImpl
 
getCacheManager() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
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.
getCacheMisses() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the number of missed cache accesses on the cache.
getCacheMissPercentage() - Method in interface com.hazelcast.cache.CacheStatistics
Returns the percentage of cache accesses that did not find a requested entry in the cache.
getCacheMissPercentage() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the percentage of missed cache accesses on the cache.
getCacheName() - Method in class com.hazelcast.config.EventJournalConfig
Returns the cache name to which this config applies.
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.
getCachePuts() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the number of puts to the queue.
getCacheRemovals() - Method in interface com.hazelcast.cache.CacheStatistics
The total number of removals from the cache.
getCacheRemovals() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the number of removals from the queue.
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.
getCallerAddress() - Method in class com.hazelcast.spi.Operation
 
getCallerUuid() - Method in class com.hazelcast.spi.Operation
 
getCallId() - Method in class com.hazelcast.spi.Operation
Gets the call ID of this operation.
getCallTimeout() - Method in class com.hazelcast.spi.InvocationBuilder
 
getCallTimeout() - Method in class com.hazelcast.spi.Operation
Gets the call timeout in milliseconds.
getCancelledTaskCount() - Method in interface com.hazelcast.monitor.LocalExecutorStats
Returns the number of cancelled operations on the executor service.
getCanonicalHeaders() - Method in class com.hazelcast.aws.security.EC2RequestSigner
 
getCanonicalizedQueryString(Map<String, String>) - Method in class com.hazelcast.aws.security.EC2RequestSigner
 
getCanonicalizedQueryString(List<String>) - Method in class com.hazelcast.aws.security.EC2RequestSigner
 
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.
getCardinalityEstimator(String) - Method in interface com.hazelcast.core.HazelcastInstance
Obtain a CardinalityEstimator with the given name.
getCardinalityEstimator(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getCardinalityEstimator(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
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.
getChannel() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
getCharacterEscapes() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonGeneratorImpl
Method for accessing custom escapes factory uses for JsonGenerators it creates.
getCharacterEscapes() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
Method for accessing custom escapes factory uses for JsonGenerators it creates.
getCharacterEscapes() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
Method for accessing custom escapes factory uses for JsonGenerators it creates.
getCharacterEscapes() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
 
getCharOffset() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonLocation
 
getChildNodes() - Method in class com.hazelcast.config.yaml.ElementAdapter
 
getChunkSize() - Method in class com.hazelcast.config.JobTrackerConfig
Gets the number of emitted values before a chunk is send to the reducers.
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 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.Portable
Returns class identifier for this portable class.
getClassId() - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
getClassLoader() - Method in class com.hazelcast.config.Config
Returns the class-loader that will be used in serialization.
getClassLoader() - Method in interface com.hazelcast.nio.ObjectDataInput
Returns class loader that internally used for objects.
getClassLoaderFactory() - Method in class com.hazelcast.jet.config.JobConfig
Returns the configured JobClassLoaderFactory.
getClassName() - Method in class com.hazelcast.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
 
getClassName() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
getClassName() - Method in class com.hazelcast.config.SecurityInterceptorConfig
 
getClassName() - Method in class com.hazelcast.config.SerializerConfig
Returns the class name of the serializer implementation.
getClassName() - Method in class com.hazelcast.config.ServiceConfig
 
getClassName() - Method in class com.hazelcast.config.SocketInterceptorConfig
Returns the name of the SocketInterceptor implementation class.
getClassName() - Method in class com.hazelcast.config.WanConsumerConfig
Returns the fully qualified class name of the class implementing WanReplicationConsumer.
getClassName() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the name of the class implementing the WanReplicationEndpoint.
getClassType() - Method in class com.hazelcast.config.LegacyCacheConfig
 
getClassType() - Method in class com.hazelcast.config.LegacyCacheEvictionConfig
 
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
 
getClientEngine() - Method in class com.hazelcast.instance.Node
 
getClientEngine() - Method in interface com.hazelcast.nio.IOService
 
getClientEngine() - Method in class com.hazelcast.nio.NodeIOService
 
getClientLoginModuleConfigs() - Method in class com.hazelcast.config.SecurityConfig
 
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
 
getClients() - Method in interface com.hazelcast.monitor.MemberState
 
getClientService() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the client service of this Hazelcast instance.
getClientService() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getClientService() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getClientType() - Method in interface com.hazelcast.core.Client
Returns the type of this client.
getCloseCause() - Method in interface com.hazelcast.nio.Connection
Gets the cause this Connection was closed.
getCloseCause() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
getCloseReason() - Method in interface com.hazelcast.nio.Connection
Gets the reason this Connection was closed.
getCloseReason() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
getCluster() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the Cluster that this Hazelcast instance is part of.
getCluster() - Method in class com.hazelcast.core.InitialMembershipEvent
Returns the cluster of the event.
getCluster() - Method in class com.hazelcast.core.MembershipEvent
Returns the cluster of the event.
getCluster() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getCluster() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getCluster() - Method in interface com.hazelcast.jet.JetInstance
Returns information about the cluster this Jet instance is part of.
getClusterDataRecoveryPolicy() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Returns the policy to be used when the cluster is started
getClusterHotRestartStatus() - Method in interface com.hazelcast.monitor.MemberState
 
getClusterService() - Method in class com.hazelcast.instance.Node
 
getClusterService() - Method in interface com.hazelcast.spi.NodeEngine
Gets the ClusterService.
getClusterState() - Method in interface com.hazelcast.core.Cluster
Returns the state of the cluster.
getClusterState() - Method in interface com.hazelcast.monitor.NodeState
 
getClusterTime() - Method in interface com.hazelcast.core.Cluster
Returns the cluster-wide time in milliseconds.
getClusterVersion() - Method in interface com.hazelcast.core.Cluster
The cluster version indicates the operating version of the cluster.
getClusterVersion() - Method in interface com.hazelcast.monitor.NodeState
 
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
Method for accessing the object used for writing Java object as JSON content (using method JsonGenerator.writeObject(java.lang.Object)).
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.v1.exceptions.ReaderException
 
getCollator() - Method in interface com.hazelcast.mapreduce.aggregation.Aggregation
Deprecated.
Returns the Collator implementation used in this aggregation.
getCollectionIntervalSeconds() - Method in class com.hazelcast.jet.config.MetricsConfig
Returns the metrics collection interval.
getColumn() - Method in class com.hazelcast.org.snakeyaml.engine.v1.exceptions.Mark
starts with 0
getColumn() - Method in class com.hazelcast.org.snakeyaml.engine.v1.scanner.StreamReader
 
getColumnNr() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonLocation
 
getCombinerFactory() - Method in interface com.hazelcast.mapreduce.aggregation.Aggregation
Deprecated.
Returns the CombinerFactory for this aggregation to pre-reduce values on mapping nodes.
getCommitIndexAdvanceCountToSnapshot() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
getCommittedHeap() - Method in class com.hazelcast.memory.DefaultMemoryStats
 
getCommittedHeap() - Method in interface com.hazelcast.memory.MemoryStats
Returns the amount of memory in bytes that is committed for the Java virtual machine to use.
getCommittedNative() - Method in class com.hazelcast.memory.DefaultMemoryStats
 
getCommittedNative() - Method in interface com.hazelcast.memory.MemoryStats
Returns the amount of native memory in bytes that is committed for current HazelcastInstance to use.
getComparator() - Method in class com.hazelcast.config.EvictionConfig
Returns the instance of the configured EvictionPolicyComparator implementation.
getComparator() - Method in class com.hazelcast.query.PagingPredicate
 
getComparatorClassName() - Method in class com.hazelcast.config.EvictionConfig
Returns the class name of the configured EvictionPolicyComparator implementation.
getCompletableFuture() - Method in interface com.hazelcast.mapreduce.TrackableJob
Deprecated.
Returns the ICompletableFuture to add callbacks or wait for the resulting value of the tracked job.
getCompleted() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
getCompletedTaskCount() - Method in interface com.hazelcast.monitor.LocalExecutorStats
Returns the number of completed operations on the executor service.
getCompletedTaskCount() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
 
getCompletedTaskCount() - Method in interface com.hazelcast.util.executor.ManagedExecutorService
 
getConcurrencyLevel() - Method in class com.hazelcast.config.ReplicatedMapConfig
Deprecated.
new implementation doesn't use mutexes
getConditionId() - Method in class com.hazelcast.concurrent.lock.ConditionKey
 
getConfig() - Method in class com.hazelcast.config.LegacyCacheEvictionConfig
 
getConfig() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the configuration of this Hazelcast instance.
getConfig() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getConfig() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getConfig() - Method in class com.hazelcast.instance.Node
 
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 interface com.hazelcast.spi.NodeEngine
Returns the Config that was used to create the HazelcastInstance.
getConfigAndReset() - Method in class com.hazelcast.config.LegacyCacheConfig
 
getConfigByTag(JoinConfig, String) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Gets the AliasedDiscoveryConfig from config by tag.
getConfigByTag(WanPublisherConfig, String) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Gets the AliasedDiscoveryConfig from config by tag.
getConfigClassLoader() - Method in class com.hazelcast.instance.Node
 
getConfigClassLoader() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
getConfigClassLoader() - Method in interface com.hazelcast.spi.NodeEngine
Returns the Config ClassLoader.
getConfigObject() - Method in class com.hazelcast.config.ServiceConfig
 
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.config.AbstractYamlConfigBuilder
 
getConfigRoot() - Method in class com.hazelcast.config.YamlConfigBuilder
 
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.AbstractConfigLocator
 
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 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.AbstractConfigLocator
 
getConfigurationUrl() - Method in class com.hazelcast.config.Config
Returns the URL to the declarative configuration, which has been parsed to create this Config instance.
getConn() - Method in class com.hazelcast.nio.Packet
Gets the Connection this Packet was send with.
getConnectedClients() - Method in interface com.hazelcast.core.ClientService
Returns all connected clients to this member.
getConnection(Address) - Method in interface com.hazelcast.nio.EndpointManager
Gets the connection for a given address.
getConnection(Address) - Method in class com.hazelcast.nio.tcp.TcpIpEndpointManager
 
getConnection() - Method in class com.hazelcast.spi.Operation
 
getConnectionId() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
getConnectionMonitorInterval() - Method in interface com.hazelcast.nio.IOService
 
getConnectionMonitorInterval() - Method in class com.hazelcast.nio.NodeIOService
 
getConnectionMonitorMaxFaults() - Method in interface com.hazelcast.nio.IOService
 
getConnectionMonitorMaxFaults() - Method in class com.hazelcast.nio.NodeIOService
 
getConnectionRetries() - Method in class com.hazelcast.aws.AwsConfig
 
getConnections() - Method in interface com.hazelcast.nio.AggregateEndpointManager
 
getConnections() - Method in class com.hazelcast.nio.DefaultAggregateEndpointManager
 
getConnections() - Method in interface com.hazelcast.nio.EndpointManager
Returns connections that have been successfully established (ie.
getConnections() - Method in class com.hazelcast.nio.tcp.TcpIpEndpointManager
 
getConnections() - Method in class com.hazelcast.nio.UnifiedAggregateEndpointManager
 
getConnectionTimeoutSeconds() - Method in class com.hazelcast.aws.AwsConfig
 
getConnectionTimeoutSeconds() - Method in class com.hazelcast.config.AwsConfig
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.
getConstruct() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.Node
 
getConstructor(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.BaseConstructor
Select ConstructNode inside the provided Node or the one associated with the Tag
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.v1.exceptions.MarkedYamlEngineException
 
getContextMark() - Method in exception com.hazelcast.org.snakeyaml.engine.v1.exceptions.MarkedYamlEngineException
 
getContextType() - Method in interface com.hazelcast.spi.tenantcontrol.DestroyEventContext
 
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 class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
 
getCount() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
 
getCount(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
getCount() - Method in interface com.hazelcast.core.ICountDownLatch
Returns the current count.
getCountDownLatch(String) - Method in interface com.hazelcast.core.HazelcastInstance
Deprecated.
This implementation may lose strong consistency in case of network failures or server failures. Please use CPSubsystem.getCountDownLatch(String) instead. This method will be removed in Hazelcast 4.0.
getCountDownLatch(String) - Method in interface com.hazelcast.cp.CPSubsystem
Returns a proxy for an ICountDownLatch instance created on the CP subsystem.
getCountDownLatch(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getCountDownLatch(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getCountDownLatchConfig(String) - Method in class com.hazelcast.config.Config
Returns the CountDownLatchConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getCountDownLatchConfigs() - Method in class com.hazelcast.config.Config
Returns the map of CountDownLatch configurations, mapped by config name.
getCountDownLatchContainer(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
getCounter(String) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
Returns the counter with the given name.
GetCountOperation - Class in com.hazelcast.concurrent.countdownlatch.operations
 
GetCountOperation() - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.GetCountOperation
 
GetCountOperation(String) - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.GetCountOperation
 
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 the CP subsystem.
getCPMembers() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Returns the current list of CP members
getCpMemberUuid() - Method in interface com.hazelcast.monitor.MemberState
Returns the local CP member's UUID if this Hazelcast member is part of the CP subsystem, returns null otherwise.
getCPSessionManagementService() - Method in interface com.hazelcast.cp.CPSubsystem
Returns the CPSessionManagementService of this Hazelcast instance.
getCPSubsystem() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the CP subsystem that offers a set of in-memory linearizable data structures
getCPSubsystem() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getCPSubsystem() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getCPSubsystemConfig() - Method in class com.hazelcast.config.Config
Get current configuration for the CP subsystem
getCPSubsystemManagementService() - Method in interface com.hazelcast.cp.CPSubsystem
Returns the CPSubsystemManagementService of this Hazelcast instance.
getCRDTReplicationConfig() - Method in class com.hazelcast.config.Config
 
getCreationTime() - Method in interface com.hazelcast.cache.CacheStatistics
Gets the cache creation time.
getCreationTime() - Method in interface com.hazelcast.core.EntryView
Returns the creation time of the entry.
getCreationTime() - Method in interface com.hazelcast.monitor.LocalInstanceStats
Returns the creation time of this distributed object instance on this member.
getCreationTime() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the creation time of this map on this member.
getCreationTime() - Method in interface com.hazelcast.monitor.LocalTopicStats
Returns the creation time of this topic on this member
getCreationTime() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the creation time of this Near Cache on this member.
getCreationTime() - Method in interface com.hazelcast.spi.merge.MergingCreationTime
Returns the creation time of the merge data.
getCredentialScope() - Method in class com.hazelcast.aws.security.EC2RequestSigner
 
getCredentialsFactory() - Method in interface com.hazelcast.security.SecurityContext
Returns current ICredentialsFactory.
getCurrentClusterHotRestartStatus() - Method in interface com.hazelcast.hotrestart.InternalHotRestartService
Returns latest Hot Restart status as Management Center DTO.
getCurrentClusterHotRestartStatus() - Method in class com.hazelcast.hotrestart.NoopInternalHotRestartService
 
getCurrentIndex() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
 
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.quorum.QuorumEvent
Returns the snapshot of member list at the time quorum 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
Method that can be called to get the name associated with the current token: for JsonToken.FIELD_NAMEs 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.
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
 
getCurrentReplicaIndex() - Method in class com.hazelcast.spi.PartitionMigrationEvent
Gets the index of the partition replica that current member owns currently, before migration starts.
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
 
getCurrentTargetReplicaAddress() - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
Returns the current target replica address to which this proxy is sending invocations.
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
Alias for JsonParser.currentToken(), will be deprecated in Jackson 2.9
getCurrentToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
 
getCurrentTokenId() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
getCurrentTokenId() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
 
getCurrentTokenId() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Alias for JsonParser.currentTokenId(), will be deprecated in Jackson 2.9
getCurrentTokenId() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
 
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
 
getCurrentVectorClock() - Method in interface com.hazelcast.crdt.CRDT
Returns the current vector clock which reflects the current CRDT state.
getCurrentVectorClock() - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
 
getCurrentWatermark() - Method in interface com.hazelcast.jet.core.WatermarkPolicy
Called to get the current watermark in the absence of an observed event.
getDataLoadTimeoutSeconds() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Returns configured data load timeout for hot-restart process.
getDataSerializableFactories() - Method in class com.hazelcast.config.SerializationConfig
 
getDataSerializableFactoryClasses() - Method in class com.hazelcast.config.SerializationConfig
 
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.
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
Numeric accessor that can be called when the current token is of type JsonToken.VALUE_NUMBER_FLOAT or JsonToken.VALUE_NUMBER_INT.
getDecimalValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
 
getDecodedDataLength(byte[]) - Static method in class com.hazelcast.util.Base64
returns length of decoded data given an array containing encoded data.
getDefault() - Static method in enum com.hazelcast.cache.BuiltInCacheMergePolicies
Gets the definition of the default CacheMergePolicy.
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
 
getDefaultEdgeConfig() - Method in class com.hazelcast.jet.config.JetConfig
Returns the default DAG edge configuration.
getDefaultFlowStyle() - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.DumpSettings
 
getDefaultHazelcastInstance() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Gets the default HazelcastOSGiInstance.
getDefaultList() - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.LoadSettings
 
getDefaultMap() - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.LoadSettings
 
getDefaultProperties() - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
getDefaultScalarStyle() - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.DumpSettings
 
getDefaultSet() - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.LoadSettings
 
getDefaultURI() - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
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
Method used to get the default variant ("MIME_NO_LINEFEEDS") for cases where caller does not explicitly specify the variant.
getDefinition() - Method in enum com.hazelcast.aws.AwsProperties
 
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
 
getDelegatedInstance() - Method in interface com.hazelcast.osgi.HazelcastOSGiInstance
Gets the delegated (underlying) HazelcastInstance.
getDeprecatedName() - Method in class com.hazelcast.spi.properties.HazelcastProperty
 
getDepth() - Method in class com.hazelcast.config.MerkleTreeConfig
Returns the depth of the merkle tree.
getDescriptor() - Method in enum com.hazelcast.instance.ProtocolType
 
getDeserializedKey() - Method in interface com.hazelcast.spi.merge.MergingEntry
Returns the deserialized merging key.
getDeserializedValue() - Method in interface com.hazelcast.spi.merge.MergingValue
Returns the deserialized merging value.
getDestination() - Method in class com.hazelcast.jet.core.Edge
Returns this edge's destination vertex.
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.
getDiffPercentage() - Method in class com.hazelcast.wan.merkletree.ConsistencyCheckResult
 
getDirectory() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
getDirtyEntryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the number of entries that the member owns and are dirty (updated but not persisted yet).
getDiscoveryConfig() - Method in class com.hazelcast.config.JoinConfig
Returns the currently defined DiscoveryConfig
getDiscoveryConfig() - Method in class com.hazelcast.config.WanPublisherConfig
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
 
getDiscoveryService() - Method in class com.hazelcast.instance.Node
 
getDiscoveryServiceProvider() - Method in class com.hazelcast.config.DiscoveryConfig
 
getDiscoveryStrategyConfigs() - Method in class com.hazelcast.config.DiscoveryConfig
Returns the defined DiscoveryStrategy configurations.
getDiscoveryStrategyFactory() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
getDiscoveryStrategyType() - Method in class com.hazelcast.aws.AwsDiscoveryStrategyFactory
 
getDiscoveryStrategyType() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategyFactory
Returns the type of the DiscoveryStrategy itself.
getDiscoveryStrategyType() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategyFactory
 
getDistributedObject() - Method in class com.hazelcast.core.DistributedObjectEvent
Returns the DistributedObject instance.
getDistributedObject(String, String) - Method in interface com.hazelcast.core.HazelcastInstance
 
getDistributedObject(String, String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getDistributedObject(String, String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getDistributedObject(String, String) - Method in interface com.hazelcast.spi.ProxyService
 
getDistributedObjectName(String) - Static method in class com.hazelcast.cache.CacheUtil
Convenience method to obtain the name of Hazelcast distributed object corresponding to the cache identified by the given cacheName, assuming null URI and ClassLoader prefixes.
getDistributedObjectName(String, URI, ClassLoader) - Static method in class com.hazelcast.cache.CacheUtil
Convenience method to obtain the name of Hazelcast distributed object corresponding to the cache identified by the given arguments.
getDistributedObjectName() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
getDistributedObjectName() - Method in interface com.hazelcast.spi.tenantcontrol.DestroyEventContext
 
getDistributedObjectNames(String) - Method in interface com.hazelcast.spi.ProxyService
 
getDistributedObjects() - Method in interface com.hazelcast.core.HazelcastInstance
Returns all DistributedObjects, that is all maps, queues, topics, locks etc.
getDistributedObjects() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getDistributedObjects() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getDistributedObjects(String) - Method in interface com.hazelcast.spi.ProxyService
 
getDouble() - Method in class com.hazelcast.jet.accumulator.LongDoubleAccumulator
Returns the double value.
getDouble(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured double value of a HazelcastProperty.
getDouble(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
Returns a field in a Json object as a double.
getDouble(JsonObject, String, double) - Static method in class com.hazelcast.util.JsonUtil
Returns a field in a Json object as a double.
getDoubleAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
 
getDoubleAttribute(String) - Method in interface com.hazelcast.core.Member
Returns the value of the specified key for this member or null if value is undefined.
getDoubleAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
 
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
 
getDoubleValue(String, String) - Static method in class com.hazelcast.config.DomConfigHelper
 
getDoubleValue(String, String, double) - Static method in class com.hazelcast.config.DomConfigHelper
 
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.
getDurableExecutorService(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getDurableExecutorService(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getDurationAmount() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
getDurationConfig() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
getDurationSecs() - Method in interface com.hazelcast.wan.WanSyncStats
Returns the duration of the synchronization in seconds
getElementsByTagName(String) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
getElementsByTagNameNS(String, String) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
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
Accessor that can be called if (and only if) the current token is JsonToken.VALUE_EMBEDDED_OBJECT.
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.monitor.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.
getEncoder() - Method in class com.hazelcast.nio.ascii.TextDecoder
 
getEncoding() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.IOContext
 
getEncoding() - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.YamlUnicodeReader
Get stream encoding or NULL if stream is uninitialized.
getEndMark() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.Event
 
getEndMark() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.Node
 
getEndMark() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.Token
 
getEndpoint() - Method in class com.hazelcast.aws.AWSClient
 
getEndpoint() - Method in class com.hazelcast.config.WanPublisherConfig
 
getEndPoint() - Method in interface com.hazelcast.nio.Connection
Gets the Address of the other side of this Connection.
getEndPoint() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
getEndPoint() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionErrorHandler
 
getEndpoint() - Method in class com.hazelcast.security.AbstractCredentials
 
getEndpoint() - Method in interface com.hazelcast.security.Credentials
Returns IP address of endpoint.
getEndpointConfigs() - Method in class com.hazelcast.config.AdvancedNetworkConfig
 
getEndpointManager() - Method in class com.hazelcast.instance.Node
 
getEndpointManager(EndpointQualifier) - Method in class com.hazelcast.instance.Node
 
getEndpointManager() - Method in interface com.hazelcast.nio.Connection
 
getEndpointManager(EndpointQualifier) - Method in class com.hazelcast.nio.DefaultAggregateEndpointManager
 
getEndpointManager(EndpointQualifier) - Method in interface com.hazelcast.nio.NetworkingService
Returns the relevant EndpointManager given an EndpointQualifier On single-endpoint setups (legacy mode), then a View relevant to the requested Endpoint is returned which purely acts as a facade to hide the API differences and maintain common signatures.
getEndpointManager() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
getEndpointManager(EndpointQualifier) - Method in class com.hazelcast.nio.tcp.TcpIpNetworkingService
Returns the respective endpoint manager based on the qualifier.
getEndpointManager(EndpointQualifier) - Method in class com.hazelcast.nio.UnifiedAggregateEndpointManager
 
getEndpointQualifier() - Method in class com.hazelcast.nio.tcp.TcpIpEndpointManager
 
getEndpoints() - Method in class com.hazelcast.config.PermissionConfig
 
getEntryCount() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
 
getEntryKey() - Method in class com.hazelcast.util.SampleableConcurrentHashMap.SamplingEntry
 
getEntryListenerConfigs() - Method in class com.hazelcast.config.MapConfig
 
getEntryListenerConfigs() - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
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.MultiMapConfigReadOnly
Deprecated.
 
getEntryListenerConfigs() - Method in class com.hazelcast.config.QueryCacheConfig
 
getEntryObject() - Method in class com.hazelcast.query.PredicateBuilder
 
getEntryValue() - Method in class com.hazelcast.util.SampleableConcurrentHashMap.SamplingEntry
 
getEntryView(K) - Method in interface com.hazelcast.core.IMap
Returns the EntryView for the specified key.
getEnum(HazelcastProperty, Class<E>) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured enum value of a GroupProperty.
getEnvVar(String) - Method in class com.hazelcast.aws.utility.Environment
 
getEol() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultIndenter
 
getErrorMessage() - Method in exception com.hazelcast.aws.exception.AwsConnectionException
 
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.config.JoinConfig
 
getEurekaConfig() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the EurekaConfig used by the discovery mechanism for this WAN publisher.
getEventId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.AliasEvent
 
getEventId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.DocumentEndEvent
 
getEventId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.DocumentStartEvent
 
getEventId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.Event
 
getEventId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.MappingEndEvent
 
getEventId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.MappingStartEvent
 
getEventId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.ScalarEvent
 
getEventId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.SequenceEndEvent
 
getEventId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.SequenceStartEvent
 
getEventId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.StreamEndEvent
 
getEventId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.StreamStartEvent
 
getEventObject() - Method in class com.hazelcast.wan.WanReplicationEvent
Gets the event object.
getEventOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the number of Events Received
getEventOperationCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns number of event operations
getEventQueueCapacity() - Method in interface com.hazelcast.spi.EventService
Returns the queue capacity per event thread.
getEventQueueSize() - Method in interface com.hazelcast.spi.EventService
Returns the current total event queue size.
getEventService() - Method in interface com.hazelcast.nio.IOService
 
getEventService() - Method in class com.hazelcast.nio.NodeIOService
 
getEventService() - Method in interface com.hazelcast.spi.NodeEngine
Gets the EventService.
getEventSource() - Method in class com.hazelcast.partition.PartitionLostEvent
Returns the address of the node that dispatches the event
getEventSource() - Method in class com.hazelcast.spi.partition.IPartitionLostEvent
The address of the node that detects the partition lost.
getEventThreadCount() - Method in interface com.hazelcast.spi.EventService
Returns the event thread count.
getEventType() - Method in class com.hazelcast.core.AbstractIMapEvent
Returns the event type EntryEventType.
getEventType() - Method in class com.hazelcast.core.DistributedObjectEvent
getEventType() - Method in interface com.hazelcast.core.IMapEvent
Return the event type
getEventType() - Method in class com.hazelcast.core.ItemEvent
Returns the event type.
getEventType() - Method in class com.hazelcast.core.MembershipEvent
Returns the membership event type; #MEMBER_ADDED #MEMBER_REMOVED #MEMBER_ATTRIBUTE_CHANGED
getEventType() - Method in class com.hazelcast.map.EventLostEvent
Intentionally returns null.
getEvictionConfig() - Method in class com.hazelcast.config.CacheConfig
Gets the EvictionConfig instance of the eviction configuration for this ICache.
getEvictionConfig() - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
getEvictionConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the eviction configuration for this ICache.
getEvictionConfig() - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
getEvictionConfig() - Method in class com.hazelcast.config.NearCacheConfig
Returns the eviction configuration for this Near Cache.
getEvictionConfig() - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
getEvictionConfig() - Method in class com.hazelcast.config.QueryCacheConfig
Returns EvictionConfig instance for this QueryCache
getEvictionPercentage() - Method in class com.hazelcast.config.MapConfig
Deprecated.
As of version 3.7, eviction mechanism changed. It uses a probabilistic algorithm based on sampling. Please see documentation for further details.
getEvictionPolicy() - Method in class com.hazelcast.config.EvictionConfig
Returns the EvictionPolicy of this eviction configuration.
getEvictionPolicy() - Method in class com.hazelcast.config.MapConfig
Returns the EvictionPolicy.
getEvictionPolicy() - Method in class com.hazelcast.config.NearCacheConfig
getEvictionPolicyType() - Method in class com.hazelcast.config.EvictionConfig
Deprecated.
getEvictions() - Method in interface com.hazelcast.monitor.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.jet.function.SupplierEx
Exception-declaring version of Supplier.get().
getExcludedMemberUuids() - Method in interface com.hazelcast.hotrestart.InternalHotRestartService
Returns UUIDs of the members that have been excluded during the cluster start.
getExcludedMemberUuids() - Method in class com.hazelcast.hotrestart.NoopInternalHotRestartService
 
getExecutionCallback() - Method in class com.hazelcast.spi.InvocationBuilder
Gets the ExecutionCallback.
getExecutionService() - Method in interface com.hazelcast.spi.NodeEngine
Gets the ExecutionService.
getExecutor() - Method in class com.hazelcast.config.ReliableTopicConfig
Gets the Executor that is going to process the events.
getExecutor(String) - Method in interface com.hazelcast.spi.ExecutionService
 
getExecutorConfig(String) - Method in class com.hazelcast.config.Config
Returns the ExecutorConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getExecutorConfigs() - Method in class com.hazelcast.config.Config
Returns the map of executor configurations, mapped by config name.
getExecutorName() - Method in interface com.hazelcast.core.Offloadable
Returns the name of the executor to which the processing unit will be off-loaded.
getExecutorService(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed executor service for the given name.
getExecutorService(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getExecutorService(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getExpirations() - Method in interface com.hazelcast.monitor.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.concurrent.lock.LockResource
 
getExpirationTime() - Method in interface com.hazelcast.core.EntryView
Returns the expiration time of the 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.v1.api.DumpSettings
 
getExtractor() - Method in class com.hazelcast.config.MapAttributeConfig
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.MapStoreConfig
Returns the name of the MapStoreFactory implementation class
getFactoryClassName() - Method in class com.hazelcast.config.MCMutualAuthConfig
Returns the name of the implementation class.
getFactoryClassName() - Method in class com.hazelcast.config.QueueStoreConfig
 
getFactoryClassName() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
getFactoryClassName() - Method in class com.hazelcast.config.SSLConfig
Returns the name of the implementation class.
getFactoryId() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
 
getFactoryId() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AbstractAtomicLongOperation
 
getFactoryId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
 
getFactoryId() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.concurrent.atomicreference.operations.AbstractAtomicReferenceOperation
 
getFactoryId() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
 
getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
 
getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
 
getFactoryId() - Method in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
getFactoryId() - Method in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
getFactoryId() - Method in class com.hazelcast.concurrent.lock.operations.LockReplicationOperation
 
getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
 
getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreReplicationOperation
 
getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
 
getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.config.AbstractBasicConfig
 
getFactoryId() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
 
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.ConfigDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.config.CountDownLatchConfig
 
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.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
getFactoryId() - Method in class com.hazelcast.config.EventJournalConfig
 
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.ListenerConfig
 
getFactoryId() - Method in class com.hazelcast.config.LockConfig
 
getFactoryId() - Method in class com.hazelcast.config.MapAttributeConfig
 
getFactoryId() - Method in class com.hazelcast.config.MapConfig
 
getFactoryId() - Method in class com.hazelcast.config.MapIndexConfig
 
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.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.QuorumConfig
 
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.SemaphoreConfig
 
getFactoryId() - Method in class com.hazelcast.config.TopicConfig
 
getFactoryId() - Method in class com.hazelcast.config.WanConsumerConfig
 
getFactoryId() - Method in class com.hazelcast.config.WanPublisherConfig
 
getFactoryId() - Method in class com.hazelcast.config.WanReplicationConfig
 
getFactoryId() - Method in class com.hazelcast.config.WanSyncConfig
 
getFactoryId() - Method in class com.hazelcast.crdt.AbstractCRDTReplicationOperation
 
getFactoryId() - Method in class com.hazelcast.crdt.CRDTDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.crdt.pncounter.operations.AbstractPNCounterOperation
 
getFactoryId() - Method in class com.hazelcast.crdt.pncounter.operations.CRDTTimestampedLong
 
getFactoryId() - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
 
getFactoryId() - Method in class com.hazelcast.instance.EndpointQualifier
 
getFactoryId() - Method in class com.hazelcast.instance.MemberImpl
 
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 class com.hazelcast.map.eviction.LFUEvictionPolicy
 
getFactoryId() - Method in class com.hazelcast.map.eviction.LRUEvictionPolicy
 
getFactoryId() - Method in class com.hazelcast.map.eviction.RandomEvictionPolicy
 
getFactoryId() - Method in class com.hazelcast.map.merge.HigherHitsMapMergePolicy
 
getFactoryId() - Method in class com.hazelcast.map.merge.IgnoreMergingEntryMapMergePolicy
 
getFactoryId() - Method in class com.hazelcast.map.merge.LatestUpdateMapMergePolicy
 
getFactoryId() - Method in class com.hazelcast.map.merge.PassThroughMergePolicy
 
getFactoryId() - Method in class com.hazelcast.map.merge.PutIfAbsentMapMergePolicy
 
getFactoryId() - Method in class com.hazelcast.nio.Address
 
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.query.PagingPredicate
 
getFactoryId() - Method in class com.hazelcast.query.PartitionPredicate
 
getFactoryId() - Method in class com.hazelcast.query.SqlPredicate
 
getFactoryId() - Method in class com.hazelcast.query.TruePredicate
 
getFactoryId() - Method in class com.hazelcast.replicatedmap.merge.HigherHitsMapMergePolicy
 
getFactoryId() - Method in class com.hazelcast.replicatedmap.merge.LatestUpdateMapMergePolicy
 
getFactoryId() - Method in class com.hazelcast.replicatedmap.merge.PassThroughMergePolicy
 
getFactoryId() - Method in class com.hazelcast.replicatedmap.merge.PutIfAbsentMapMergePolicy
 
getFactoryId() - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
getFactoryId() - Method in class com.hazelcast.spi.AbstractLocalOperation
 
getFactoryId() - Method in class com.hazelcast.spi.DistributedObjectNamespace
 
getFactoryId() - Method in class com.hazelcast.spi.OperationControl
 
getFactoryId() - Method in class com.hazelcast.version.MemberVersion
 
getFactoryId() - Method in class com.hazelcast.version.Version
 
getFactoryId() - Method in class com.hazelcast.wan.WanReplicationEvent
 
getFactoryImplementation() - Method in class com.hazelcast.config.MapStoreConfig
Returns the map store factory implementation object.
getFactoryImplementation() - Method in class com.hazelcast.config.MCMutualAuthConfig
Returns the factory implementation object.
getFactoryImplementation() - Method in class com.hazelcast.config.QueueStoreConfig
 
getFactoryImplementation() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
getFactoryImplementation() - Method in class com.hazelcast.config.SSLConfig
Returns the factory implementation object.
getFeature(String, String) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
getFeatureMask() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
 
getFeatureMask() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
Bulk access method for getting state of all standard (non-dataformat-specific) JsonGenerator.Features.
getFeatureMask() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Bulk access method for getting state of all standard JsonParser.Features.
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.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.PortableReader
 
getFileFromResources(String) - Static method in class com.hazelcast.nio.IOUtil
 
getFileFromResourcesAsStream(String) - Static method in class com.hazelcast.nio.IOUtil
 
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
 
getFilter() - Method in interface com.hazelcast.spi.EventRegistration
Returns the EventFilter attached to this registration.
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.
getFirst(Iterable<T>, T) - Static method in class com.hazelcast.util.IterableUtil
 
getFirstChild() - Method in class com.hazelcast.config.yaml.ElementAdapter
 
getFlags() - Method in class com.hazelcast.nio.Packet
 
getFlakeIdGenerator(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns a cluster-wide unique ID generator.
getFlakeIdGenerator(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getFlakeIdGenerator(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
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.
getFlakeIdGeneratorConfigs() - Method in class com.hazelcast.config.Config
Returns the map of FlakeIdGenerator configurations, mapped by config name.
getFloat(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured float value of a HazelcastProperty.
getFloat(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
Returns a field in a Json object as a float.
getFloat(JsonObject, String, float) - Static method in class com.hazelcast.util.JsonUtil
Returns a field in a Json object as a float.
getFloatAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
 
getFloatAttribute(String) - Method in interface com.hazelcast.core.Member
Returns the value of the specified key for this member or null if value is undefined.
getFloatAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
 
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
Returns the flow-control period in milliseconds.
getFlowStyle() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.CollectionStartEvent
true if this collection is in flow style, false for block style.
getFlowStyle() - Method in class com.hazelcast.org.snakeyaml.engine.v1.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 FormatFeatures, 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 FormatFeatures, format-specific on/off configuration settings.
getFormatName() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
Method that returns short textual id identifying format this factory supports.
getFormatReadFeatureType() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
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
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.core.TransactionalMap
Locks the key and then gets and returns the value to which the specified key is mapped.
getFrameLength() - Method in class com.hazelcast.nio.Packet
 
getFreeHeap() - Method in class com.hazelcast.memory.DefaultMemoryStats
 
getFreeHeap() - Method in interface com.hazelcast.memory.MemoryStats
Returns the amount of free memory in the JVM in bytes.
getFreeMemory() - Method in interface com.hazelcast.util.MemoryInfoAccessor
Returns the amount of free memory in the Java virtual machine in bytes.
getFreeMemory() - Method in class com.hazelcast.util.RuntimeMemoryInfoAccessor
 
getFreeNative() - Method in class com.hazelcast.memory.DefaultMemoryStats
 
getFreeNative() - Method in interface com.hazelcast.memory.MemoryStats
Returns the amount of free native memory in current HazelcastInstance in bytes.
getFreePhysical() - Method in class com.hazelcast.memory.DefaultMemoryStats
 
getFreePhysical() - Method in interface com.hazelcast.memory.MemoryStats
Returns free physical memory available in OS.
getFuture() - Method in interface com.hazelcast.jet.Job
Gets the future associated with the job.
getFuture() - Method in class com.hazelcast.util.executor.DelegatingFuture
 
getGcpConfig() - Method in class com.hazelcast.config.JoinConfig
 
getGcpConfig() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the GcpConfig used by the discovery mechanism for this WAN publisher.
getGCStats() - Method in class com.hazelcast.memory.DefaultMemoryStats
 
getGCStats() - Static method in class com.hazelcast.memory.GCStatsSupport
 
getGCStats() - Method in interface com.hazelcast.memory.MemoryStats
Returns the garbage collector statistics for the JVM
getGCStats() - Method in interface com.hazelcast.monitor.LocalMemoryStats
 
getGetOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the number of get operations
getGlobalSerializerConfig() - Method in class com.hazelcast.config.SerializationConfig
 
getGlobalTaskScheduler() - Method in interface com.hazelcast.spi.ExecutionService
 
getGroupConfig() - Method in class com.hazelcast.config.Config
Returns the configuration for hazelcast groups.
getGroupId() - Method in class com.hazelcast.com.fasterxml.jackson.core.Version
 
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
getGroupName() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the group name used as an endpoint group name for authentication on the target endpoint.
getGroupSize() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns number of CP members that each CP group will consist of Returns 0 if CP member count is 0.
getGroupType() - Method in class com.hazelcast.config.PartitionGroupConfig
Returns the MemberGroupType configured.
getHandle() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.TagTuple
 
getHandler() - Method in interface com.hazelcast.scheduledexecutor.IScheduledFuture
Returns the scheduled future resource handler.
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
Gets the underlying HazelcastInstance implementation.
getHazelcastInstance(String) - Static method in class com.hazelcast.instance.HazelcastInstanceFactory
 
getHazelcastInstance() - Method in interface com.hazelcast.jet.JetInstance
Returns the underlying Hazelcast IMDG instance used by Jet.
getHazelcastInstance() - Method in interface com.hazelcast.spi.NodeEngine
Returns the HazelcastInstance that this NodeEngine belongs to.
getHazelcastInstanceByName(String) - Static method in class com.hazelcast.core.Hazelcast
Returns an existing HazelcastInstance with instanceName.
getHazelcastInstanceByName(String) - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Gets an existing HazelcastOSGiInstance with its instanceName.
getHazelcastName() - Method in interface com.hazelcast.nio.IOService
 
getHazelcastName() - Method in class com.hazelcast.nio.NodeIOService
 
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.monitor.LocalMapStats
Cost of map & Near Cache & backup & Merkle trees in bytes
getHeapCost() - Method in interface com.hazelcast.nio.serialization.Data
Returns approximate heap cost of this Data object 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.monitor.LocalIndexStats
Returns the total number of hits into the index.
getHits() - Method in interface com.hazelcast.core.EntryView
Returns number of hits of the entry.
getHits() - Method in interface com.hazelcast.monitor.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.monitor.LocalRecordStoreStats
Returns the number of hits (reads) of the locally owned entries of this partition.
getHits() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the number of hits (reads) of Near Cache entries owned by this member.
getHits() - Method in interface com.hazelcast.spi.merge.MergingHits
Returns the access hits of the merge data.
getHost() - Method in class com.hazelcast.nio.Address
 
getHostHeader() - Method in class com.hazelcast.aws.AwsConfig
 
getHostHeader() - Method in class com.hazelcast.config.AwsConfig
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.core.Cluster
Returns the Hot Restart service for interacting with Hot Restart.
getHotRestartService() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
getHotRestartService() - Method in interface com.hazelcast.instance.NodeExtension
Returns the public hot restart service
getHotRestartState() - Method in interface com.hazelcast.monitor.MemberState
 
getHttpReponseCode() - Method in exception com.hazelcast.aws.exception.AwsConnectionException
 
getHzPort() - Method in class com.hazelcast.aws.AwsConfig
 
getHzPort() - Method in class com.hazelcast.config.AwsConfig
getIamRole() - Method in class com.hazelcast.aws.AwsConfig
 
getIamRole() - Method in class com.hazelcast.config.AwsConfig
getIcmpFailureDetectorConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig
Returns the current IcmpFailureDetectorConfig.
getIcmpFailureDetectorConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getIcmpFailureDetectorConfig() - Method in class com.hazelcast.config.NetworkConfig
Returns the current IcmpFailureDetectorConfig.
getId() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
 
getId() - Method in enum com.hazelcast.cluster.MemberAttributeOperationType
Gets the ID of the MemberAttributeOperationType.
getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
 
getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AddBackupOperation
 
getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AlterAndGetOperation
 
getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AlterOperation
 
getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.ApplyOperation
 
getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
 
getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
 
getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
 
getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAlterOperation
 
getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
 
getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetOperation
 
getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.MergeBackupOperation
 
getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.MergeOperation
 
getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.SetBackupOperation
 
getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.SetOperation
 
getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.AlterAndGetOperation
 
getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.AlterOperation
 
getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
 
getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
 
getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
 
getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.ContainsOperation
 
getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndAlterOperation
 
getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
 
getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetOperation
 
getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.IsNullOperation
 
getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.MergeBackupOperation
 
getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.MergeOperation
 
getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetAndGetOperation
 
getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetBackupOperation
 
getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetOperation
 
getId() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
 
getId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
 
getId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
 
getId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
 
getId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
 
getId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.GetCountOperation
 
getId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
 
getId() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
getId() - Method in class com.hazelcast.concurrent.lock.operations.AwaitBackupOperation
 
getId() - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
 
getId() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitBackupOperation
 
getId() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
 
getId() - Method in class com.hazelcast.concurrent.lock.operations.GetLockCountOperation
 
getId() - Method in class com.hazelcast.concurrent.lock.operations.GetRemainingLeaseTimeOperation
 
getId() - Method in class com.hazelcast.concurrent.lock.operations.IsLockedOperation
 
getId() - Method in class com.hazelcast.concurrent.lock.operations.LocalLockCleanupOperation
 
getId() - Method in class com.hazelcast.concurrent.lock.operations.LockBackupOperation
 
getId() - Method in class com.hazelcast.concurrent.lock.operations.LockOperation
 
getId() - Method in class com.hazelcast.concurrent.lock.operations.LockReplicationOperation
 
getId() - Method in class com.hazelcast.concurrent.lock.operations.SignalBackupOperation
 
getId() - Method in class com.hazelcast.concurrent.lock.operations.SignalOperation
 
getId() - Method in class com.hazelcast.concurrent.lock.operations.UnlockBackupOperation
 
getId() - Method in class com.hazelcast.concurrent.lock.operations.UnlockIfLeaseExpiredOperation
 
getId() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
 
getId() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireBackupOperation
 
getId() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
 
getId() - Method in class com.hazelcast.concurrent.semaphore.operations.AvailableOperation
 
getId() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainBackupOperation
 
getId() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainOperation
 
getId() - Method in class com.hazelcast.concurrent.semaphore.operations.IncreaseBackupOperation
 
getId() - Method in class com.hazelcast.concurrent.semaphore.operations.IncreaseOperation
 
getId() - Method in class com.hazelcast.concurrent.semaphore.operations.InitBackupOperation
 
getId() - Method in class com.hazelcast.concurrent.semaphore.operations.InitOperation
 
getId() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceBackupOperation
 
getId() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceOperation
 
getId() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseBackupOperation
 
getId() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
 
getId() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDetachMemberBackupOperation
 
getId() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDetachMemberOperation
 
getId() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreReplicationOperation
 
getId() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
 
getId() - Method in class com.hazelcast.config.AtomicLongConfig
 
getId() - Method in class com.hazelcast.config.AtomicReferenceConfig
 
getId() - Method in class com.hazelcast.config.AwsConfig
 
getId() - Method in class com.hazelcast.config.AzureConfig
 
getId() - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
 
getId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
getId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
getId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
getId() - Method in class com.hazelcast.config.CacheSimpleConfig
 
getId() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
getId() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
getId() - Method in enum com.hazelcast.config.ConsistencyCheckStrategy
Gets the ID for this ConsistencyCheckStrategy.
getId() - Method in class com.hazelcast.config.CountDownLatchConfig
 
getId() - Method in class com.hazelcast.config.DiscoveryConfig
 
getId() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
getId() - Method in class com.hazelcast.config.DurableExecutorConfig
 
getId() - Method in class com.hazelcast.config.EntryListenerConfig
 
getId() - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
getId() - Method in class com.hazelcast.config.EurekaConfig
 
getId() - Method in class com.hazelcast.config.EventJournalConfig
 
getId() - Method in class com.hazelcast.config.ExecutorConfig
 
getId() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
getId() - Method in class com.hazelcast.config.GcpConfig
 
getId() - Method in class com.hazelcast.config.HotRestartConfig
 
getId() - Method in class com.hazelcast.config.ItemListenerConfig
 
getId() - Method in class com.hazelcast.config.KubernetesConfig
 
getId() - Method in class com.hazelcast.config.ListConfig
 
getId() - Method in class com.hazelcast.config.ListenerConfig
 
getId() - Method in class com.hazelcast.config.LockConfig
 
getId() - Method in class com.hazelcast.config.MapAttributeConfig
 
getId() - Method in class com.hazelcast.config.MapConfig
 
getId() - Method in class com.hazelcast.config.MapIndexConfig
 
getId() - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
 
getId() - Method in class com.hazelcast.config.MapStoreConfig
 
getId() - Method in class com.hazelcast.config.MergePolicyConfig
 
getId() - Method in class com.hazelcast.config.MerkleTreeConfig
 
getId() - Method in enum com.hazelcast.config.MetadataPolicy
Returns enumeration id of this policy.
getId() - Method in class com.hazelcast.config.MultiMapConfig
 
getId() - Method in class com.hazelcast.config.NearCacheConfig
 
getId() - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
getId() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
getId() - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
getId() - Method in class com.hazelcast.config.PNCounterConfig
 
getId() - Method in class com.hazelcast.config.PredicateConfig
 
getId() - Method in class com.hazelcast.config.QueryCacheConfig
 
getId() - Method in class com.hazelcast.config.QueueConfig
 
getId() - Method in class com.hazelcast.config.QueueStoreConfig
 
getId() - Method in class com.hazelcast.config.QuorumConfig
 
getId() - Method in class com.hazelcast.config.QuorumListenerConfig
 
getId() - Method in class com.hazelcast.config.ReliableTopicConfig
 
getId() - Method in class com.hazelcast.config.ReplicatedMapConfig
 
getId() - Method in class com.hazelcast.config.RingbufferConfig
 
getId() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
getId() - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
getId() - Method in class com.hazelcast.config.SemaphoreConfig
 
getId() - Method in class com.hazelcast.config.SetConfig
 
getId() - Method in class com.hazelcast.config.TopicConfig
 
getId() - Method in enum com.hazelcast.config.WanAcknowledgeType
Gets the ID for the given WanAcknowledgeType.
getId() - Method in class com.hazelcast.config.WanConsumerConfig
 
getId() - Method in class com.hazelcast.config.WanPublisherConfig
 
getId() - Method in enum com.hazelcast.config.WanPublisherState
Returns the ID of the WAN publisher state.
getId() - Method in enum com.hazelcast.config.WANQueueFullBehavior
Gets the ID for the given WANQueueFullBehavior.
getId() - Method in class com.hazelcast.config.WanReplicationConfig
 
getId() - Method in class com.hazelcast.config.WanSyncConfig
 
getId() - Method in class com.hazelcast.crdt.pncounter.operations.AddOperation
 
getId() - Method in class com.hazelcast.crdt.pncounter.operations.CRDTTimestampedLong
 
getId() - Method in class com.hazelcast.crdt.pncounter.operations.GetOperation
 
getId() - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
 
getId() - Method in class com.hazelcast.crdt.pncounter.PNCounterReplicationOperation
 
getId() - Method in class com.hazelcast.instance.EndpointQualifier
 
getId() - Method in class com.hazelcast.instance.MemberImpl
 
getId() - Method in class com.hazelcast.jet.config.JobConfig
 
getId() - Method in class com.hazelcast.jet.config.ResourceConfig
The ID of the resource, null for archives.
getId() - Method in class com.hazelcast.jet.core.DAG
 
getId() - Method in class com.hazelcast.jet.core.Edge
 
getId() - Method in class com.hazelcast.jet.core.metrics.JobMetrics
 
getId() - Method in class com.hazelcast.jet.core.metrics.Measurement
 
getId() - Method in class com.hazelcast.jet.core.Vertex
 
getId() - Method in interface com.hazelcast.jet.Job
Returns the ID of this job.
getId() - Method in class com.hazelcast.map.eviction.LFUEvictionPolicy
 
getId() - Method in class com.hazelcast.map.eviction.LRUEvictionPolicy
 
getId() - Method in class com.hazelcast.map.eviction.RandomEvictionPolicy
 
getId() - Method in class com.hazelcast.map.merge.HigherHitsMapMergePolicy
 
getId() - Method in class com.hazelcast.map.merge.IgnoreMergingEntryMapMergePolicy
 
getId() - Method in class com.hazelcast.map.merge.LatestUpdateMapMergePolicy
 
getId() - Method in class com.hazelcast.map.merge.PassThroughMergePolicy
 
getId() - Method in class com.hazelcast.map.merge.PutIfAbsentMapMergePolicy
 
getId() - Method in class com.hazelcast.nio.Address
 
getId() - Method in enum com.hazelcast.nio.serialization.FieldType
 
getId() - Method in interface com.hazelcast.nio.serialization.IdentifiedDataSerializable
Returns type identifier for this class.
getId() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Gets the ID of service.
getId() - Method in class com.hazelcast.query.PagingPredicate
 
getId() - Method in class com.hazelcast.query.PartitionPredicate
 
getId() - Method in class com.hazelcast.query.SqlPredicate
 
getId() - Method in class com.hazelcast.query.TruePredicate
 
getId() - Method in class com.hazelcast.replicatedmap.merge.HigherHitsMapMergePolicy
 
getId() - Method in class com.hazelcast.replicatedmap.merge.LatestUpdateMapMergePolicy
 
getId() - Method in class com.hazelcast.replicatedmap.merge.PassThroughMergePolicy
 
getId() - Method in class com.hazelcast.replicatedmap.merge.PutIfAbsentMapMergePolicy
 
getId() - Method in enum com.hazelcast.ringbuffer.OverflowPolicy
Gets the ID for the given OverflowPolicy.
getId() - Method in class com.hazelcast.spi.AbstractLocalOperation
 
getId() - Method in class com.hazelcast.spi.DistributedObjectNamespace
 
getId() - Method in interface com.hazelcast.spi.EventRegistration
Returns the event registration ID.
getId() - Method in class com.hazelcast.spi.merge.DiscardMergePolicy
 
getId() - Method in class com.hazelcast.spi.merge.ExpirationTimeMergePolicy
 
getId() - Method in class com.hazelcast.spi.merge.HigherHitsMergePolicy
 
getId() - Method in class com.hazelcast.spi.merge.HyperLogLogMergePolicy
 
getId() - Method in class com.hazelcast.spi.merge.LatestAccessMergePolicy
 
getId() - Method in class com.hazelcast.spi.merge.LatestUpdateMergePolicy
 
getId() - Method in class com.hazelcast.spi.merge.PassThroughMergePolicy
 
getId() - Method in class com.hazelcast.spi.merge.PutIfAbsentMergePolicy
 
getId() - Method in class com.hazelcast.spi.OperationControl
 
getId() - Method in enum com.hazelcast.util.IterationType
Gets the ID for the given IterationType.
getId() - Method in class com.hazelcast.version.MemberVersion
 
getId() - Method in class com.hazelcast.version.Version
 
getId() - Method in class com.hazelcast.wan.WanReplicationEvent
 
getIdCount() - Method in interface com.hazelcast.monitor.LocalFlakeIdGeneratorStats
Note that the ID count returned is the number of generated IDs not the number of consumed IDs.
getIdentifier() - Method in class com.hazelcast.instance.EndpointQualifier
 
getIdGenerator(String) - Method in interface com.hazelcast.core.HazelcastInstance
Deprecated.
The implementation can produce duplicate IDs in case of network split, even with split-brain protection enabled (during short window while split-brain is detected). Use HazelcastInstance.getFlakeIdGenerator(String) for an alternative implementation which does not suffer from this problem.
getIdGenerator(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getIdGenerator(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getIdOffset() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
getIdString() - Method in interface com.hazelcast.jet.Job
Returns the string representation of this job's ID.
getIgnoredPublisherIds() - Method in class com.hazelcast.wan.AddWanConfigResult
Returns the IDs for the WAN publishers which were ignored and not added to the configuration.
getImplementation() - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
 
getImplementation() - Method in class com.hazelcast.config.CachePartitionLostListenerConfigReadOnly
Deprecated.
 
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.LoginModuleConfig
Deprecated.
getImplementation() - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
 
getImplementation() - Method in class com.hazelcast.config.MapPartitionLostListenerConfigReadOnly
Deprecated.
 
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.QuorumListenerConfig
 
getImplementation() - Method in class com.hazelcast.config.SecurityInterceptorConfig
 
getImplementation() - Method in class com.hazelcast.config.SerializerConfig
Returns the implementation of the serializer class.
getImplementation() - Method in class com.hazelcast.config.ServiceConfig
 
getImplementation() - Method in class com.hazelcast.config.SocketInterceptorConfig
Returns the SocketInterceptor implementation object.
getImplementation() - Method in class com.hazelcast.config.WanConsumerConfig
Returns the implementation implementing WanReplicationConsumer.
getImplementation() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the implementation of the WanReplicationEndpoint.
getImplementationClass() - Method in enum com.hazelcast.cache.BuiltInCacheMergePolicies
 
getImplementationClassName() - Method in enum com.hazelcast.cache.BuiltInCacheMergePolicies
Gets the name of the implementation class of CacheMergePolicy.
getImplicit() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.ScalarEvent
 
getIn() - Method in class com.hazelcast.config.AbstractConfigLocator
 
getInboundEdges(String) - Method in class com.hazelcast.jet.core.DAG
Returns the inbound edges connected to the vertex with the given name.
getInboundNetworkStats() - Method in interface com.hazelcast.nio.AggregateEndpointManager
Gets network stats for incoming traffic.
getInboundNetworkStats() - Method in class com.hazelcast.nio.DefaultAggregateEndpointManager
 
getInboundNetworkStats() - Method in class com.hazelcast.nio.UnifiedAggregateEndpointManager
 
getIndent() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultIndenter
 
getIndent() - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.DumpSettings
 
getIndex() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
 
getIndex() - Method in class com.hazelcast.org.snakeyaml.engine.v1.exceptions.Mark
starts with 0
getIndex() - Method in class com.hazelcast.org.snakeyaml.engine.v1.scanner.StreamReader
 
getIndexConfigs() - Method in class com.hazelcast.config.QueryCacheConfig
 
getIndexedQueryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the total number of indexed queries performed on the map.
getIndexStats() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the per-index statistics map keyed by the index name.
getIndicatorIndent() - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.DumpSettings
 
getInetAddress() - Method in class com.hazelcast.instance.AbstractMember
 
getInetAddress() - Method in class com.hazelcast.nio.Address
 
getInetAddress() - Method in interface com.hazelcast.nio.Connection
Returns remote address of this Connection.
getInetAddress() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
getInetAddressFor(Inet6Address, String) - Static method in class com.hazelcast.util.AddressUtil
 
getInetSocketAddress() - Method in interface com.hazelcast.core.Member
Deprecated.
getInetSocketAddress() - Method in class com.hazelcast.instance.AbstractMember
 
getInetSocketAddress() - Method in class com.hazelcast.nio.Address
 
getInitialLoadMode() - Method in class com.hazelcast.config.MapStoreConfig
Returns the initial load mode.
getInitialPermits() - Method in class com.hazelcast.config.SemaphoreConfig
Gets the initial number of permits.
getInitialPublisherState() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the initial WAN publisher state.
getInitialSnapshotName() - Method in class com.hazelcast.jet.config.JobConfig
Returns the configured initial snapshot name or null if no initial snapshot is configured.
getInMemoryFormat() - Method in class com.hazelcast.config.CacheConfig
Gets the data type that will be used to store records.
getInMemoryFormat() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the InMemory Format for this ICache.
getInMemoryFormat() - Method in class com.hazelcast.config.MapConfig
Returns the data type that will be used for storing records.
getInMemoryFormat() - Method in class com.hazelcast.config.NearCacheConfig
Returns the data type used to store entries.
getInMemoryFormat() - Method in class com.hazelcast.config.QueryCacheConfig
Returns memory format of values of entries in QueryCache.
getInMemoryFormat() - Method in class com.hazelcast.config.ReplicatedMapConfig
Data type used to store entries.
getInMemoryFormat() - Method in class com.hazelcast.config.RingbufferConfig
Returns the in-memory format.
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
 
getInsertCount() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the number of insert operations performed on the index.
getInstance() - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.JsonStringEncoder
Deprecated.
getInstance() - Static method in class com.hazelcast.jet.server.JetBootstrap
Returns the bootstrapped JetInstance.
getInstanceConfig() - Method in class com.hazelcast.jet.config.JetConfig
Returns the Jet instance config.
getInstanceName() - Method in class com.hazelcast.config.Config
Returns the instance name uniquely identifying the hazelcast instance created by this configuration.
getInstanceName(String, Config) - Static method in class com.hazelcast.instance.HazelcastInstanceFactory
Return real name for the hazelcast instance's instance
getInt(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
Returns a field in a Json object as an int.
getInt(JsonObject, String, int) - Static method in class com.hazelcast.util.JsonUtil
Returns a field in a Json object as an int.
getInt(int) - Static method in class com.hazelcast.util.RandomPicker
Returns a pseudorandom, uniformly distributed int value between 0 (inclusive) and the specified value (exclusive), drawn from this random number generator's sequence.
getInt(int, int) - Static method in class com.hazelcast.util.RandomPicker
Return a pseudorandom, uniformly distributed in value between the low value (inclusive) and the high value (exclusive), drawn from this random number generator's sequence.
getIntAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
 
getIntAttribute(String) - Method in interface com.hazelcast.core.Member
Returns the value of the specified key for this member or null if value is undefined.
getIntAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
 
getInteger(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured int value of a HazelcastProperty.
getIntegerValue(String, String) - Static method in class com.hazelcast.config.DomConfigHelper
 
getIntegerValue(String, String, int) - Static method in class com.hazelcast.config.DomConfigHelper
 
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
 
getInternalHotRestartService() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
getInternalHotRestartService() - Method in interface com.hazelcast.instance.NodeExtension
Returns the internal hot restart service
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.monitor.NearCacheStats
Returns the number of invalidations of Near Cache entries owned by this member.
getInvocationTime() - Method in class com.hazelcast.spi.Operation
Gets the time in milliseconds when this invocation started.
getIoService() - Method in interface com.hazelcast.nio.NetworkingService
Returns the I/O Service
getIoService() - Method in class com.hazelcast.nio.tcp.TcpIpNetworkingService
 
getItem() - Method in class com.hazelcast.core.ItemEvent
Returns the item related to the event.
getItem() - Method in class com.hazelcast.util.collection.WeightedEvictableList.WeightedItem
 
getItemAtPositionOrNull(T[], int) - Static method in class com.hazelcast.util.collection.ArrayUtils
 
getItemAtPositionOrNull(Collection<T>, int) - Static method in class com.hazelcast.util.CollectionUtil
Returns the n-th item or null if collection is smaller.
getItemListenerConfigs() - Method in class com.hazelcast.config.CollectionConfig
Gets the list of ItemListenerConfigs.
getItemListenerConfigs() - Method in class com.hazelcast.config.ListConfigReadOnly
Deprecated.
 
getItemListenerConfigs() - Method in class com.hazelcast.config.QueueConfig
Get the list of item listener configurations for this queue.
getItemListenerConfigs() - Method in class com.hazelcast.config.QueueConfigReadOnly
Deprecated.
 
getItemListenerConfigs() - Method in class com.hazelcast.config.SetConfigReadOnly
Deprecated.
 
getItems() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Returns the array representing this ringbuffer.
getIterationCount() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
getIterationType() - Method in class com.hazelcast.query.PagingPredicate
 
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
 
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.
getJobId() - Method in interface com.hazelcast.mapreduce.JobCompletableFuture
Deprecated.
Returns the unique identifier for this mapreduce job.
getJobId() - Method in interface com.hazelcast.mapreduce.TrackableJob
Deprecated.
Returns the unique job ID of the tracked job
getJobProcessInformation() - Method in interface com.hazelcast.mapreduce.TrackableJob
Deprecated.
Returns an instance of JobProcessInformation to find out the state and statistics of a running task, or returns null if the underlying job ID is not available because the job is already finished or has not yet been submitted.
It returns null if not requested on the job issuing cluster member or client, since those values are not distributed to all clusters for traffic reasons.
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.
getJobTracker(String) - Method in interface com.hazelcast.core.HazelcastInstance
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
getJobTracker(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getJobTracker(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getJobTracker() - Method in interface com.hazelcast.mapreduce.TrackableJob
Deprecated.
Returns the assigned JobTracker
getJobTrackerConfig(String) - Method in class com.hazelcast.config.Config
Returns the JobTrackerConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getJobTrackerConfigs() - Method in class com.hazelcast.config.Config
Returns the map of JobTracker configurations, mapped by config name.
getJoin() - Method in class com.hazelcast.config.AdvancedNetworkConfig
Returns the JoinConfig.
getJoin() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getJoin() - Method in class com.hazelcast.config.NetworkConfig
Returns the JoinConfig.
getJoiner() - Method in class com.hazelcast.instance.Node
 
getJsonFactory() - Method in class com.hazelcast.com.fasterxml.jackson.core.ObjectCodec
Deprecated.
Since 2.1: Use ObjectCodec.getFactory() instead.
getJsonStringEncoder() - Static method in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecyclers
 
getKey() - Method in interface com.hazelcast.cache.CacheEntryView
Gets the key of the cache entry.
getKey() - Method in interface com.hazelcast.cache.journal.EventJournalCacheEvent
Returns the key for the event entry.
getKey() - Method in class com.hazelcast.concurrent.lock.ConditionKey
 
getKey() - Method in class com.hazelcast.concurrent.lock.LockProxy
Deprecated.
getKey() - Method in interface com.hazelcast.concurrent.lock.LockResource
 
getKey() - Method in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
getKey() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
getKey() - Method in class com.hazelcast.core.EntryEvent
Returns the key of the entry event.
getKey() - Method in interface com.hazelcast.core.EntryView
Returns the key of the entry.
getKey() - Method in interface com.hazelcast.core.ILock
Deprecated.
getKey() - Method in class com.hazelcast.core.MemberAttributeEvent
Returns the key for this MemberAttributeEvent.
getKey() - Method in class com.hazelcast.core.PartitionAwareKey
Gets the key (not the partitionKey).
getKey() - Method in class com.hazelcast.jet.datamodel.KeyedWindowResult
Alias for KeyedWindowResult.key, implements Map.Entry.
getKey() - Method in class com.hazelcast.jet.datamodel.Tuple2
 
getKey() - Method in interface com.hazelcast.map.journal.EventJournalMapEvent
Returns the key for the event entry.
getKey() - Method in interface com.hazelcast.spi.merge.MergingEntry
Returns the merging key in the in-memory format of the backing data structure.
getKey() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap.SimpleEntry
 
getKey() - Method in interface com.hazelcast.util.executor.StripedRunnable
 
getKey() - Method in class com.hazelcast.util.scheduler.ScheduledEntry
 
getKey() - Method in interface com.hazelcast.wan.ReplicationEventObject
Returns the key for the entry on which the event occurred.
getKeyClassName() - Method in class com.hazelcast.config.AbstractCacheConfig
 
getKeyData() - Method in class com.hazelcast.concurrent.lock.LockProxy
 
getKeyMetadata() - Method in class com.hazelcast.query.Metadata
 
getKeyNode() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.NodeTuple
Key node.
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.config.JoinConfig
 
getKubernetesConfig() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the KubernetesConfig used by the discovery mechanism for this WAN publisher.
getLabel() - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.LoadSettings
 
getLabels() - Method in interface com.hazelcast.core.Client
 
getLargestSequence() - Method in interface com.hazelcast.core.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.core.EntryView
Returns the last access time for the entry.
getLastAccessTime() - Method in interface com.hazelcast.monitor.LocalCacheStats
Gets the last access time to cache.
getLastAccessTime() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the last access (read) time of the locally owned entries.
getLastAccessTime() - Method in interface com.hazelcast.monitor.LocalRecordStoreStats
Returns the last access (read) time of the locally owned entries of this partition.
getLastAccessTime() - Method in interface com.hazelcast.spi.merge.MergingLastAccessTime
Returns the last access time of the merge data.
getLastCheckedLeafCount() - Method in class com.hazelcast.wan.merkletree.ConsistencyCheckResult
 
getLastCheckedPartitionCount() - Method in class com.hazelcast.wan.merkletree.ConsistencyCheckResult
 
getLastChild() - Method in class com.hazelcast.config.yaml.ElementAdapter
 
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
Method that can be called to get the last token that was cleared using JsonParser.clearCurrentToken().
getLastClearedToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
 
getLastConsistencyCheckResults() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns the last results of the consistency checks, mapped by map name.
getLastDiffLeafCount() - Method in class com.hazelcast.wan.merkletree.ConsistencyCheckResult
 
getLastDiffPartitionCount() - Method in class com.hazelcast.wan.merkletree.ConsistencyCheckResult
 
getLastEntriesToSync() - Method in class com.hazelcast.wan.merkletree.ConsistencyCheckResult
 
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.monitor.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.monitor.NearCacheStats
Returns the failure reason of the last Near Cache persistence (when the pre-load feature is enabled).
getLastPersistenceKeyCount() - Method in interface com.hazelcast.monitor.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.monitor.NearCacheStats
Returns the timestamp of the last Near Cache key persistence (when the pre-load feature is enabled).
getLastPersistenceWrittenBytes() - Method in interface com.hazelcast.monitor.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.
getLastSyncStats() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns the last synchronization statistics, mapped by map name.
getLastUpdateTime() - Method in interface com.hazelcast.cache.CacheStatistics
Gets the last update time to cache.
getLastUpdateTime() - Method in interface com.hazelcast.core.EntryView
Returns the last time the value was updated.
getLastUpdateTime() - Method in interface com.hazelcast.monitor.LocalCacheStats
Gets the last update time to cache.
getLastUpdateTime() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the last update time of the locally owned entries.
getLastUpdateTime() - Method in interface com.hazelcast.monitor.LocalRecordStoreStats
Returns the last update time of the locally owned entries of this partition.
getLastUpdateTime() - Method in interface com.hazelcast.spi.merge.MergingLastUpdateTime
Returns the last update time of the merge data.
getLeader() - 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.
getLeaderElectionTimeoutInMillis() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
getLeaderHeartbeatPeriodInMillis() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
getLeftChildOrder(int) - Static method in class com.hazelcast.wan.merkletree.MerkleTreeUtil
Returns the breadth-first order of the left child node of the node with nodeOrder
getLevel() - Method in interface com.hazelcast.logging.ILogger
Gets the logging level.
getLevel() - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
 
getLevelOfNode(int) - Static method in class com.hazelcast.wan.merkletree.MerkleTreeUtil
Returns the level a node with the given order is on in the tree
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.
getLifecycleService() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getLifecycleService() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getLine() - Method in class com.hazelcast.org.snakeyaml.engine.v1.exceptions.Mark
starts with 0
getLine() - Method in class com.hazelcast.org.snakeyaml.engine.v1.scanner.StreamReader
 
getLineNr() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonLocation
 
getList() - Method in class com.hazelcast.console.ConsoleApp
 
getList(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed list instance with the specified name.
getList(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getList(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
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.
getList() - Method in class com.hazelcast.util.collection.WeightedEvictableList
 
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.
getListener() - Method in interface com.hazelcast.spi.ListenerWrapperEventFilter
Gets the wrapped listener.
getListenerConfigs() - Method in class com.hazelcast.config.Config
Returns the list of EventListener configurations.
getListenerConfigs() - Method in class com.hazelcast.config.QuorumConfig
 
getListenerConfigs() - Method in class com.hazelcast.config.ReplicatedMapConfig
 
getListenerConfigurations() - Method in class com.hazelcast.config.AbstractCacheConfig
 
getListOfEntries(Map<String, String>) - Method in class com.hazelcast.aws.security.EC2RequestSigner
 
getLocalCacheStatistics() - Method in interface com.hazelcast.cache.ICache
Directly access local Cache Statistics.
getLocalCacheStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getLocalCPMember() - Method in interface com.hazelcast.cp.CPSubsystem
Returns the local CP member if this Hazelcast member is part of the 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 the CP subsystem, returns null otherwise.
getLocalEndpoint() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the local Endpoint which this HazelcastInstance belongs to.
getLocalEndpoint() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getLocalEndpoint() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getLocalExecutorStats() - Method in interface com.hazelcast.core.IExecutorService
Returns local statistics related to this executor service.
getLocalExecutorStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getLocalFlakeIdGeneratorStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getLocalMapStats() - Method in interface com.hazelcast.core.IMap
Returns LocalMapStats for this map.
getLocalMapStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getLocalMember() - Method in interface com.hazelcast.core.Cluster
Returns this Hazelcast instance member.
getLocalMember() - Method in class com.hazelcast.instance.Node
 
getLocalMember() - Method in interface com.hazelcast.spi.NodeEngine
Returns the local member.
getLocalMemoryStats() - Method in interface com.hazelcast.monitor.MemberState
 
getLocalMultiMapStats() - Method in interface com.hazelcast.core.MultiMap
Returns LocalMultiMapStats for this map.
getLocalMultiMapStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getLocalName() - Method in class com.hazelcast.config.yaml.ElementAdapter
 
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.
getLocalPNCounterStats(String) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
Returns the PN counter statistics for the counter with the given name
getLocalPNCounterStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getLocalQueueStats() - Method in interface com.hazelcast.core.IQueue
Returns LocalQueueStats for this queue.
getLocalQueueStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getLocalReplicatedMapStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getLocalTopicStats() - Method in interface com.hazelcast.core.ITopic
Returns statistics about this topic, like total number of publishes/receives.
getLocalTopicStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getLocalUpdatePolicy() - Method in class com.hazelcast.config.NearCacheConfig
Returns the NearCacheConfig.LocalUpdatePolicy of this Near Cache.
getLocalWanPublisherStats() - Method in interface com.hazelcast.monitor.LocalWanStats
Returns the statistics of different publisher clusters belongs the scheme on this member
getLocalWanStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getLocation() - Method in exception com.hazelcast.com.fasterxml.jackson.core.JsonProcessingException
 
getLock(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
getLock(String) - Method in interface com.hazelcast.core.HazelcastInstance
Deprecated.
This implementation may lose strong consistency in case of network failures or server failures. Please use CPSubsystem.getLock(String) instead. This method will be removed in Hazelcast 4.0.
getLock(String) - Method in interface com.hazelcast.cp.CPSubsystem
Returns a proxy for an FencedLock instance created on the CP subsystem.
getLock(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getLock(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getLockAcquireLimit() - Method in class com.hazelcast.config.cp.FencedLockConfig
Returns the maximum number of lock acquires a lock holder can perform.
getLockConfig(String) - Method in class com.hazelcast.config.Config
Returns the LockConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getLockConfigs() - Method in class com.hazelcast.config.Config
Returns the map of ILock configurations, mapped by config name.
getLockConfigs() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the map of FencedLock configurations
getLockContainer(int) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
getLockCount() - Method in class com.hazelcast.concurrent.lock.LockProxy
 
getLockCount(NodeEngine, Data) - Method in class com.hazelcast.concurrent.lock.LockProxySupport
 
getLockCount() - Method in interface com.hazelcast.concurrent.lock.LockResource
 
getLockCount(Data) - Method in interface com.hazelcast.concurrent.lock.LockStore
Return the number of times a key was locked by the same owner (re-entered).
getLockCount(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
getLockCount(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
 
getLockCount() - Method in interface com.hazelcast.core.ILock
Deprecated.
Returns re-entrant lock hold count, regardless of lock ownership.
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.
GetLockCountOperation - Class in com.hazelcast.concurrent.lock.operations
 
GetLockCountOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.GetLockCountOperation
 
GetLockCountOperation(ObjectNamespace, Data) - Constructor for class com.hazelcast.concurrent.lock.operations.GetLockCountOperation
 
getLockedEntryCount() - Method in interface com.hazelcast.concurrent.lock.LockStore
Return the number of locks this store holds.
getLockedEntryCount() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
getLockedEntryCount() - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
 
getLockedEntryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the number of currently locked keys.
getLockedKeys() - Method in interface com.hazelcast.concurrent.lock.LockStore
Return all locked keys for this store.
getLockedKeys() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
getLockedKeys() - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
 
getLocks() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
getLockStore(int, ObjectNamespace) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
getLockStore(ObjectNamespace) - Method in class com.hazelcast.concurrent.lock.LockStoreContainer
 
getLockStore() - Method in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
getLockStores() - Method in class com.hazelcast.concurrent.lock.LockStoreContainer
 
getLogger() - Method in class com.hazelcast.instance.AbstractMember
 
getLogger() - Method in class com.hazelcast.instance.MemberImpl
 
getLogger(String) - Method in class com.hazelcast.instance.Node
 
getLogger(Class) - Method in class com.hazelcast.instance.Node
 
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.LoggingServiceImpl
 
getLogger(Class) - Method in class com.hazelcast.logging.LoggingServiceImpl
 
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
 
getLogger(String) - Method in interface com.hazelcast.spi.NodeEngine
Gets the logger for a given name.
getLogger(Class) - Method in interface com.hazelcast.spi.NodeEngine
Gets the logger for a given class.
getLogger() - Method in class com.hazelcast.spi.Operation
 
getLoggingService() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the logging service of this Hazelcast instance.
getLoggingService() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getLoggingService() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getLoggingService() - Method in class com.hazelcast.instance.Node
 
getLoggingService() - Method in interface com.hazelcast.nio.IOService
 
getLoggingService() - Method in class com.hazelcast.nio.NodeIOService
 
getLogRecord() - Method in class com.hazelcast.logging.LogEvent
 
getLong() - Method in class com.hazelcast.jet.accumulator.LongDoubleAccumulator
Returns the long value.
getLong(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured long value of a HazelcastProperty.
getLong(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
Returns a field in a Json object as a long.
getLong(JsonObject, String, long) - Static method in class com.hazelcast.util.JsonUtil
Returns a field in a Json object as a long.
getLongAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
 
getLongAttribute(String) - Method in interface com.hazelcast.core.Member
Returns the value of the specified key for this member or null if value is undefined.
getLongAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
 
getLongContainer(String) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
 
getLongContainer() - Method in class com.hazelcast.concurrent.atomiclong.operations.AbstractAtomicLongOperation
 
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
 
getLongValue(String, String) - Static method in class com.hazelcast.config.DomConfigHelper
 
getLongValue(String, String, long) - Static method in class com.hazelcast.config.DomConfigHelper
 
getLostBackupCount() - Method in class com.hazelcast.partition.PartitionLostEvent
Returns the number of lost backups for the partition.
getLostReplicaIndex() - Method in class com.hazelcast.spi.partition.IPartitionLostEvent
0-based replica index that is lost for the partition.
getMajor() - Method in class com.hazelcast.org.snakeyaml.engine.v1.common.SpecVersion
 
getMajor() - Method in class com.hazelcast.version.MemberVersion
 
getMajor() - Method in class com.hazelcast.version.Version
 
getMajorCollectionCount() - Method in class com.hazelcast.memory.DefaultGarbageCollectorStats
 
getMajorCollectionCount() - Method in interface com.hazelcast.memory.GarbageCollectorStats
Returns major collection count.
getMajorCollectionTime() - Method in class com.hazelcast.memory.DefaultGarbageCollectorStats
 
getMajorCollectionTime() - Method in interface com.hazelcast.memory.GarbageCollectorStats
Returns total major collection time in ms.
getMajorVersion() - Method in class com.hazelcast.com.fasterxml.jackson.core.Version
 
getManagedContext() - Method in class com.hazelcast.config.Config
Returns the external managed context.
getManagedContext() - Method in interface com.hazelcast.spi.serialization.SerializationService
getManagementCenterConfig() - Method in class com.hazelcast.config.Config
Returns the management center configuration for this hazelcast instance.
getManagementCenterConnectionFactory() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
getManagementCenterConnectionFactory() - Method in interface com.hazelcast.instance.NodeExtension
 
getManagementCenterService() - Method in class com.hazelcast.instance.Node
 
getManagementService() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getManagerPrefix() - Method in class com.hazelcast.config.CacheConfig
Gets the manager prefix of the ICache, such as "hz://".
getMap() - Method in class com.hazelcast.console.ConsoleApp
 
getMap(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed map instance with the specified name.
getMap(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getMap(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
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.
getMapAttributeConfigs() - Method in class com.hazelcast.config.MapConfig
 
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.
getMapEventJournalConfig(String) - Method in class com.hazelcast.config.Config
Returns the map event journal config for the given name, creating one if necessary and adding it to the collection of known configurations.
getMapEventJournalConfigs() - Method in class com.hazelcast.config.Config
Returns the map of map event journal configurations, mapped by config name.
getMapEvictionPolicy() - Method in class com.hazelcast.config.MapConfig
Returns custom eviction policy if it is set otherwise returns null.
getMapIndexConfigs() - Method in class com.hazelcast.config.MapConfig
 
getMapIndexConfigs() - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
getMapListener() - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
getMapMerkleTreeConfig(String) - Method in class com.hazelcast.config.Config
Returns the map merkle tree config for the given name, creating one if necessary and adding it to the collection of known configurations.
getMapMerkleTreeConfigs() - Method in class com.hazelcast.config.Config
Returns the map of map merkle tree configurations, mapped by config name.
getMapName() - Method in class com.hazelcast.config.EventJournalConfig
Returns the map name to which this config applies.
getMapName() - Method in class com.hazelcast.config.MerkleTreeConfig
Returns the map name to which this config applies.
getMapper(Supplier<Key, ?, Supplied>) - Method in interface com.hazelcast.mapreduce.aggregation.Aggregation
Deprecated.
Returns the Mapper for this aggregation.
getMapping() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.MappingNode
 
getMapStoreConfig() - Method in class com.hazelcast.config.MapConfig
Returns the map store configuration
getMapStoreConfig() - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
getMark() - Method in class com.hazelcast.org.snakeyaml.engine.v1.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.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
 
getMasterAddress() - Method in class com.hazelcast.instance.Node
 
getMasterAddress() - Method in interface com.hazelcast.spi.NodeEngine
Gets the address of the master member.
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
 
getMatchingIpv4Addresses(AddressUtil.AddressMatcher) - Static method in class com.hazelcast.util.AddressUtil
 
getMatchingProperty() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
 
getMatchStrength() - Method in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatMatcher
Method for accessing strength of the match, if any; if no match, will return MatchStrength.INCONCLUSIVE.
getMaxAge() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns the maximum age of the items in this member.
getMaxAllowedBackupCount() - Method in interface com.hazelcast.spi.partition.IPartitionService
Returns maximum allowed backup count according to current cluster formation and partition group configuration.
getMaxAttempts() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
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.monitor.LocalMapStats
Returns the maximum latency of get operations.
getMaxHeap() - Method in class com.hazelcast.memory.DefaultMemoryStats
 
getMaxHeap() - Method in interface com.hazelcast.memory.MemoryStats
Returns the maximum amount of memory that the JVM will attempt to use in bytes.
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).
getMaximumPoolSize() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
 
getMaximumPoolSize() - Method in interface com.hazelcast.util.executor.ManagedExecutorService
 
getMaximumSizePolicy() - Method in class com.hazelcast.config.EvictionConfig
Returns the EvictionConfig.MaxSizePolicy of this eviction configuration.
getMaxLeaseTimeInMillis() - Method in interface com.hazelcast.concurrent.lock.LockService
 
getMaxLeaseTimeInMillis() - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
getMaxLeaseTimeInMillis(HazelcastProperties) - Static method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
getMaxLineLength() - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
 
getMaxMemory() - Method in interface com.hazelcast.util.MemoryInfoAccessor
Returns the maximum amount of memory that the Java virtual machine will attempt to use in bytes.
getMaxMemory() - Method in class com.hazelcast.util.RuntimeMemoryInfoAccessor
 
getMaxMetadata() - Method in class com.hazelcast.memory.DefaultMemoryStats
 
getMaxMetadata() - Method in interface com.hazelcast.memory.MemoryStats
Returns the amount of native memory reserved for metadata.
getMaxMissedLeaderHeartbeatCount() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
getMaxNative() - Method in class com.hazelcast.memory.DefaultMemoryStats
 
getMaxNative() - Method in interface com.hazelcast.memory.MemoryStats
Returns the maximum amount of native memory that current HazelcastInstance will attempt to use in bytes.
getMaxPutLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the maximum latency of put operations.
getMaxRemoveLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the maximum latency of remove operations.
getMaxSize() - Method in class com.hazelcast.config.CollectionConfig
Gets the maximum size for the Configuration.
getMaxSize() - Method in class com.hazelcast.config.NearCacheConfig
Deprecated.
getMaxSize() - Method in class com.hazelcast.config.QueueConfig
Returns the maximum size of the Queue.
getMaxSizeConfig() - Method in class com.hazelcast.config.MapConfig
 
getMaxSizeConfig() - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
getMaxSizePolicy() - Method in class com.hazelcast.config.CacheEvictionConfig
Deprecated.
getMaxSizePolicy() - Method in class com.hazelcast.config.MaxSizeConfig
Returns the maximum size policy of the map.
getMaxThreadSize() - Method in class com.hazelcast.config.JobTrackerConfig
Gets the maximum thread pool size of this JobTracker.
getMember() - Method in class com.hazelcast.core.AbstractIMapEvent
Returns the member that fired this event.
getMember() - Method in interface com.hazelcast.core.IMapEvent
Returns the member that fired this event.
getMember() - Method in class com.hazelcast.core.ItemEvent
Returns the member that fired this event.
getMember() - Method in class com.hazelcast.core.MemberAttributeEvent
 
getMember() - Method in exception com.hazelcast.core.MemberLeftException
Returns the member that left the cluster
getMember() - Method in class com.hazelcast.core.MembershipEvent
Returns the removed or added member.
getMember() - Method in class com.hazelcast.logging.LogEvent
 
getMember() - Method in class com.hazelcast.map.EventLostEvent
 
getMember() - Method in class com.hazelcast.spi.MembershipServiceEvent
Returns the removed or added member.
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.
getMemberCredentialsConfig() - Method in class com.hazelcast.config.SecurityConfig
 
getMemberGroupConfigs() - Method in class com.hazelcast.config.PartitionGroupConfig
Returns an unmodifiable collection containing all MemberGroupConfig elements.
getMemberGroups() - Method in interface com.hazelcast.spi.partitiongroup.PartitionGroupStrategy
 
getMemberListJoinVersion() - Method in class com.hazelcast.instance.MemberImpl
 
getMemberLoginModuleConfigs() - Method in class com.hazelcast.config.SecurityConfig
 
getMemberPartitions(Address) - Method in interface com.hazelcast.spi.partition.IPartitionService
Returns partition ID list assigned to given target.
getMemberPartitionsMap() - Method in interface com.hazelcast.spi.partition.IPartitionService
Gets member partition IDs.
getMemberPartitionState() - Method in interface com.hazelcast.monitor.MemberState
 
getMembers() - Method in class com.hazelcast.config.TcpIpConfig
Gets a list of all the well known members.
getMembers() - Method in interface com.hazelcast.core.Cluster
Set of the current members in the cluster.
getMembers() - Method in class com.hazelcast.core.InitialMembershipEvent
Returns an immutable set of ordered members at the moment this InitialMembershipListener is registered.
getMembers() - Method in class com.hazelcast.core.MembershipEvent
Returns a consistent view of the the members immediately after this MembershipEvent has been processed.
getMembers() - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
getMemberVersion() - Method in interface com.hazelcast.monitor.NodeState
 
getMemcacheProtocolConfig() - Method in class com.hazelcast.config.NetworkConfig
 
getMemcacheProtocolConfig() - Method in interface com.hazelcast.nio.IOService
Returns initialized MemcacheProtocolConfig for the node.
getMemcacheProtocolConfig() - Method in class com.hazelcast.nio.NodeIOService
 
getMemoryCost() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the memory cost of the index in bytes.
getMemoryStats() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
getMemoryStats() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getMemoryStats() - Method in interface com.hazelcast.instance.NodeExtension
Returns MemoryStats of for the JVM and current HazelcastInstance.
getMergePolicy() - Method in class com.hazelcast.config.CacheConfig
Gets the class name of CacheMergePolicy implementation of this cache config.
getMergePolicy() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the class name of CacheMergePolicy implementation of this cache config.
getMergePolicy() - Method in class com.hazelcast.config.MapConfig
Deprecated.
getMergePolicy() - Method in class com.hazelcast.config.ReplicatedMapConfig
getMergePolicy() - 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.
getMergePolicy(String) - Method in class com.hazelcast.map.merge.MergePolicyProvider
Returns an instance of a merge policy by its classname.
getMergePolicy(String) - Method in class com.hazelcast.replicatedmap.merge.MergePolicyProvider
Returns an instance of a merge policy by its classname.
getMergePolicy(String) - Method in class com.hazelcast.spi.merge.SplitBrainMergePolicyProvider
Resolves the SplitBrainMergePolicy class by its classname.
getMergePolicyConfig() - Method in class com.hazelcast.config.AbstractBasicConfig
Gets the MergePolicyConfig of this data structure.
getMergePolicyConfig() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Gets the MergePolicyConfig for the cardinality estimator.
getMergePolicyConfig() - Method in class com.hazelcast.config.CollectionConfig
Gets the MergePolicyConfig for the collection.
getMergePolicyConfig() - Method in class com.hazelcast.config.MapConfig
Gets the MergePolicyConfig for this map.
getMergePolicyConfig() - Method in class com.hazelcast.config.MultiMapConfig
Gets the MergePolicyConfig for this MultiMap.
getMergePolicyConfig() - Method in class com.hazelcast.config.QueueConfig
Gets the MergePolicyConfig for this queue.
getMergePolicyConfig() - Method in class com.hazelcast.config.ReplicatedMapConfig
Gets the MergePolicyConfig for this replicated map.
getMergePolicyConfig() - Method in class com.hazelcast.config.RingbufferConfig
Gets the MergePolicyConfig for this ringbuffer.
getMergePolicyConfig() - Method in class com.hazelcast.config.ScheduledExecutorConfig
Gets the MergePolicyConfig for the scheduler.
getMergingValue() - Method in class com.hazelcast.core.EntryEvent
Returns the incoming merging value of the entry event.
getMerkleTreesCost() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the heap cost of the Merkle trees
getMessage() - Method in exception com.hazelcast.com.fasterxml.jackson.core.JsonParseException
Overriding the getMessage() to include the request body
getMessage() - Method in exception com.hazelcast.com.fasterxml.jackson.core.JsonProcessingException
Default method overridden so that we can add location information
getMessage() - Method in exception com.hazelcast.org.snakeyaml.engine.v1.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.
getMessageListenerConfigs() - Method in class com.hazelcast.config.TopicConfigReadOnly
Deprecated.
 
getMessageObject() - Method in class com.hazelcast.core.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.
getMetadataPolicy() - Method in class com.hazelcast.config.MapConfig
Returns MetadataPolicy for this map.
getMetadataSpacePercentage() - Method in class com.hazelcast.config.NativeMemoryConfig
Returns the percentage of native memory space to be used to store metadata and internal memory structures by the native memory manager.
getMetaSupplier() - Method in class com.hazelcast.jet.core.Vertex
Returns this vertex's meta-supplier of processors.
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.jet.config.JetConfig
Returns the metrics collection config.
getMigrationEndpoint() - Method in class com.hazelcast.spi.PartitionMigrationEvent
Gets the partition migration endpoint.
getMigrationQueueSize() - Method in interface com.hazelcast.monitor.MemberPartitionState
Returns the migration queue size (this statistic is valid only for master).
getMigrationQueueSize() - Method in interface com.hazelcast.spi.partition.IPartitionService
 
getMillis(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured value of a HazelcastProperty converted to milliseconds.
getMinAge() - Method in interface com.hazelcast.monitor.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.
getMinEvictionCheckMillis() - Method in class com.hazelcast.config.MapConfig
Deprecated.
As of version 3.7, eviction mechanism changed. It uses a probabilistic algorithm based on sampling. Please see documentation for further details.
getMinor() - Method in class com.hazelcast.org.snakeyaml.engine.v1.common.SpecVersion
 
getMinor() - Method in class com.hazelcast.version.MemberVersion
 
getMinor() - Method in class com.hazelcast.version.Version
 
getMinorCollectionCount() - Method in class com.hazelcast.memory.DefaultGarbageCollectorStats
 
getMinorCollectionCount() - Method in interface com.hazelcast.memory.GarbageCollectorStats
Returns minor collection count.
getMinorCollectionTime() - Method in class com.hazelcast.memory.DefaultGarbageCollectorStats
 
getMinorCollectionTime() - Method in interface com.hazelcast.memory.GarbageCollectorStats
Returns total minor collection time in ms.
getMinorVersion() - Method in class com.hazelcast.com.fasterxml.jackson.core.Version
 
getMisses() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the number of misses of Near Cache entries owned by this member.
getMissingCPMemberAutoRemovalSeconds() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns duration to wait before automatically removing a missing CP member from the CP subsystem
getMulticastConfig() - Method in class com.hazelcast.config.JoinConfig
 
getMulticastGroup() - Method in class com.hazelcast.config.MulticastConfig
Gets the multicast group.
getMulticastPort() - Method in class com.hazelcast.config.MulticastConfig
Gets the multicast port.
getMulticastTimeoutSeconds() - Method in class com.hazelcast.config.MulticastConfig
Gets the multicast timeout in seconds.
getMulticastTimeToLive() - Method in class com.hazelcast.config.MulticastConfig
Gets the time to live for the multicast package.
getMultiMap() - Method in class com.hazelcast.console.ConsoleApp
 
getMultiMap(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed multimap instance with the specified name.
getMultiMap(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getMultiMap(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
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.
getMutualAuthConfig() - Method in class com.hazelcast.config.ManagementCenterConfig
Gets a property.
getMXBeans() - Method in interface com.hazelcast.monitor.MemberState
 
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.concurrent.atomiclong.AtomicLongProxy
 
getName() - Method in class com.hazelcast.concurrent.atomiclong.operations.AbstractAtomicLongOperation
 
getName() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
getName() - Method in class com.hazelcast.concurrent.atomicreference.operations.AbstractAtomicReferenceOperation
 
getName() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
 
getName() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
 
getName() - Method in class com.hazelcast.concurrent.idgen.IdGeneratorImpl
 
getName() - Method in class com.hazelcast.concurrent.idgen.IdGeneratorProxy
 
getName() - Method in class com.hazelcast.concurrent.lock.LockProxy
 
getName() - Method in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
getName() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
 
getName() - Method in class com.hazelcast.config.AbstractBasicConfig
Gets the name of this data structure.
getName() - Method in class com.hazelcast.config.CacheConfig
Gets the name of this ICache.
getName() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the name of this ICache.
getName() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Gets the name of the cardinality estimator.
getName() - Method in class com.hazelcast.config.CollectionConfig
Gets the name of this collection.
getName() - Method in class com.hazelcast.config.CountDownLatchConfig
Gets the name of the CountDownLatch.
getName() - Method in class com.hazelcast.config.cp.CPSemaphoreConfig
Returns name of the CP semaphore
getName() - Method in class com.hazelcast.config.cp.FencedLockConfig
Returns name of the FencedLock
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.GroupConfig
Gets the group name of the group.
getName() - Method in class com.hazelcast.config.JobTrackerConfig
Gets the name of this JobTracker.
getName() - Method in class com.hazelcast.config.LockConfig
Returns the name of the lock.
getName() - Method in class com.hazelcast.config.MapAttributeConfig
Gets the name of the attribute extracted by the extractor.
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.QuorumConfig
 
getName() - Method in class com.hazelcast.config.ReliableTopicConfig
Gets the name of the reliable topic.
getName() - Method in class com.hazelcast.config.ReplicatedMapConfig
Returns the name of this ReplicatedMap.
getName() - Method in class com.hazelcast.config.RingbufferConfig
Returns the name of the ringbuffer.
getName() - Method in class com.hazelcast.config.ScheduledExecutorConfig
Gets the name of the executor task.
getName() - Method in class com.hazelcast.config.SemaphoreConfig
Gets the name of the semaphore.
getName() - Method in class com.hazelcast.config.ServiceConfig
 
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 class com.hazelcast.core.AbstractIMapEvent
Returns the name of the map for this event.
getName() - Method in interface com.hazelcast.core.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 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.core.IAtomicLong
Returns the name of this IAtomicLong instance.
getName() - Method in interface com.hazelcast.core.ICollection
Returns the name of this collection.
getName() - Method in interface com.hazelcast.core.IMapEvent
Returns the name of the map for this event.
getName() - Method in interface com.hazelcast.core.ISemaphore
Returns the name of this ISemaphore instance.
getName() - Method in interface com.hazelcast.core.ITopic
Returns the name of this ITopic instance.
getName() - Method in interface com.hazelcast.crdt.CRDTReplicationAwareService
Returns the name of the service
getName() - Method in class com.hazelcast.crdt.pncounter.operations.AbstractPNCounterOperation
 
getName() - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
 
getName() - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
getName() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getName() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
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.EventLostEvent
 
getName() - Method in interface com.hazelcast.map.QueryCache
Returns the name of this QueryCache.
getName() - Method in interface com.hazelcast.mapreduce.TrackableJob
Deprecated.
Returns the name of the underlying JobTracker
getName() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
 
getName() - Method in class com.hazelcast.org.snakeyaml.engine.v1.exceptions.Mark
 
getName() - Method in exception com.hazelcast.org.snakeyaml.engine.v1.exceptions.ReaderException
 
getName() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.DirectiveToken
 
getName() - Method in interface com.hazelcast.scheduledexecutor.NamedTask
Returns the name of the task.
getName() - Method in interface com.hazelcast.spi.NamedOperation
Returns the name of the distributed data structure.
getName() - Method in class com.hazelcast.spi.properties.HazelcastProperty
Returns the property name.
getName() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
 
getName() - Method in interface com.hazelcast.util.executor.ManagedExecutorService
 
getName() - Method in class com.hazelcast.util.executor.NamedThreadPoolExecutor
 
getNameAsPartitionAwareData() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
getNamespace() - Method in class com.hazelcast.concurrent.lock.LockProxySupport
 
getNamespace() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
getNamespaceType() - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
getNamespaceURI() - Method in class com.hazelcast.config.yaml.ElementAdapter
 
getNameWithPrefix() - Method in class com.hazelcast.config.CacheConfig
Gets the full name of the ICache, including the manager scope prefix.
getNanos(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured value of a HazelcastProperty converted to nanoseconds.
getNativeMemoryConfig() - Method in class com.hazelcast.config.Config
Returns the native memory configuration for this hazelcast instance.
getNearCacheConfig() - Method in class com.hazelcast.config.MapConfig
Returns the Near Cache configuration
getNearCacheConfig() - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
getNearCacheStatistics() - Method in interface com.hazelcast.cache.CacheStatistics
Gets the Near Cache statistics.
getNearCacheStats() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns statistics related to the Near Cache.
getNearestAnchorEntry(PagingPredicate) - Static method in class com.hazelcast.query.PagingPredicateAccessor
 
getNetworkConfig() - Method in class com.hazelcast.config.Config
Returns the network configuration for this hazelcast instance.
getNetworking() - Method in interface com.hazelcast.nio.NetworkingService
Returns the Networking engine Shared across the multiple (or not) endpoints
getNetworking() - Method in class com.hazelcast.nio.tcp.TcpIpNetworkingService
 
getNetworkingService() - Method in class com.hazelcast.instance.Node
 
getNetworkingService() - Method in class com.hazelcast.nio.tcp.TcpIpEndpointManager
 
getNewOwner() - Method in class com.hazelcast.core.MigrationEvent
Returns the new owner of the migrating partition
getNewReplicaIndex() - Method in class com.hazelcast.spi.PartitionMigrationEvent
Gets the index of the partition replica that current member will own after migration is committed.
getNewValue() - Method in interface com.hazelcast.cache.journal.EventJournalCacheEvent
Returns the new value for the event entry.
getNewValue() - Method in interface com.hazelcast.map.journal.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.
getNextSibling() - Method in class com.hazelcast.config.yaml.ElementAdapter
 
getNodeEngine() - Method in class com.hazelcast.instance.Node
 
getNodeEngine() - Method in class com.hazelcast.spi.AbstractDistributedObject
Gets the node engine.
getNodeEngine() - Method in class com.hazelcast.spi.Operation
 
getNodeExtension() - Method in class com.hazelcast.instance.Node
 
getNodeFilter() - Method in class com.hazelcast.config.DiscoveryConfig
 
getNodeFilterClass() - Method in class com.hazelcast.config.DiscoveryConfig
 
getNodeHash(int) - Method in class com.hazelcast.wan.merkletree.ArrayMerkleTree
 
getNodeHash(int) - Method in class com.hazelcast.wan.merkletree.RemoteMerkleTreeView
 
getNodeIdOffset() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
getNodeKeyCount(int) - Method in class com.hazelcast.wan.merkletree.ArrayMerkleTree
 
getNodeKeyCount(int) - Method in interface com.hazelcast.wan.merkletree.MerkleTree
Returns the number of the keys under the specified node.
getNodeName() - Method in enum com.hazelcast.config.PermissionConfig.PermissionType
 
getNodeName() - Method in class com.hazelcast.config.yaml.ElementAdapter
 
getNodesOnLevel(int) - Static method in class com.hazelcast.wan.merkletree.MerkleTreeUtil
Returns the number of nodes on the provided level
getNodeState() - Method in interface com.hazelcast.monitor.MemberState
 
getNodeState() - Method in interface com.hazelcast.monitor.NodeState
 
getNodeType() - Method in class com.hazelcast.config.yaml.ElementAdapter
 
getNodeType() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.AnchorNode
 
getNodeType() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.MappingNode
 
getNodeType() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.Node
 
getNodeType() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.ScalarNode
 
getNodeType() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.SequenceNode
 
getNodeValue() - Method in class com.hazelcast.config.yaml.ElementAdapter
 
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.
getNotifiedKey() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
 
getNotifiedKey(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
getNotifiedKey() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
 
getNotifiedKey() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
 
getNotifiedKey() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
 
getNotifiedKey() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDetachMemberOperation
 
getNotifiedKey() - Method in interface com.hazelcast.spi.Notifier
 
getNumberOfEntriesAffected() - Method in class com.hazelcast.core.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
If current token is of type JsonToken.VALUE_NUMBER_INT or JsonToken.VALUE_NUMBER_FLOAT, returns one of JsonParser.NumberType constants; otherwise returns null.
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
 
getObject(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
Returns a field in a Json object as an object.
getObject(JsonObject, String, JsonObject) - Static method in class com.hazelcast.util.JsonUtil
Returns a field in a Json object as an object.
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
 
getObjectId() - Method in class com.hazelcast.core.DistributedObjectEvent
Deprecated.
since 3.5. Please use DistributedObjectEvent.getObjectName() instead.
getObjectName() - Method in class com.hazelcast.concurrent.lock.ConditionKey
 
getObjectName() - Method in class com.hazelcast.concurrent.lock.InternalLockNamespace
 
getObjectName() - Method in class com.hazelcast.concurrent.lock.LockWaitNotifyKey
 
getObjectName() - Method in class com.hazelcast.core.DistributedObjectEvent
Returns the name of related DistributedObject.
getObjectName() - Method in class com.hazelcast.spi.AbstractWaitNotifyKey
 
getObjectName() - Method in class com.hazelcast.spi.DefaultObjectNamespace
Deprecated.
 
getObjectName() - Method in interface com.hazelcast.spi.ObjectNamespace
Gets the object name within the service.
getObjectName() - Method in interface com.hazelcast.spi.WaitNotifyKey
Returns the object name of the wait notify object for this key.
getOfferOperationCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns the number of offer/put/add operations.
getOldOwner() - Method in class com.hazelcast.core.MigrationEvent
Returns the old owner of the migrating partition
getOldValue() - Method in interface com.hazelcast.cache.journal.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.journal.EventJournalMapEvent
Returns the old value for the event entry.
getOnJoinPermissionOperation() - Method in class com.hazelcast.config.SecurityConfig
 
getOp() - Method in class com.hazelcast.spi.InvocationBuilder
Gets the operation to execute.
GetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
GetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetOperation
 
GetOperation(String) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetOperation
 
GetOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
GetOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.GetOperation
 
GetOperation(String) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.GetOperation
 
getOperation() - Method in class com.hazelcast.crdt.CRDTReplicationContainer
Returns the CRDT replication operation.
GetOperation - Class in com.hazelcast.crdt.pncounter.operations
Query operation to retrieve the current value of the PNCounter.
GetOperation(String, VectorClock) - Constructor for class com.hazelcast.crdt.pncounter.operations.GetOperation
Constructs the operation.
GetOperation() - Constructor for class com.hazelcast.crdt.pncounter.operations.GetOperation
 
getOperationResponseHandler() - Method in class com.hazelcast.spi.Operation
Gets the OperationResponseHandler tied to this Operation.
getOperationService() - Method in class com.hazelcast.spi.AbstractDistributedObject
Gets the OperationService.
getOperationService() - Method in interface com.hazelcast.spi.NodeEngine
Gets the OperationService.
getOperationStats() - Method in interface com.hazelcast.monitor.MemberState
Returns the local operation statistics.
getOperationType() - Method in class com.hazelcast.core.MemberAttributeEvent
Returns the type of member attribute change for this MemberAttributeEvent.
getOrConnect(Address) - Method in interface com.hazelcast.nio.EndpointManager
Gets the existing connection for a given address or connects.
getOrConnect(Address, boolean) - Method in interface com.hazelcast.nio.EndpointManager
Gets the existing connection for a given address.
getOrConnect(Address) - Method in class com.hazelcast.nio.tcp.TcpIpEndpointManager
 
getOrConnect(Address, boolean) - Method in class com.hazelcast.nio.tcp.TcpIpEndpointManager
 
getOrCreate(T, ClassLoader, String) - Static method in class com.hazelcast.nio.ClassLoaderUtil
Returns the instance, if not null, or constructs a new instance of the class using ClassLoaderUtil.newInstance(ClassLoader, String).
getOrCreateCallIdsForMember(Address) - Method in class com.hazelcast.spi.CallsPerMember
 
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.
getOrCreateHazelcastInstance(Config) - Static method in class com.hazelcast.instance.HazelcastInstanceFactory
 
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.
getOriginal() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getOriginalMessage() - Method in exception com.hazelcast.com.fasterxml.jackson.core.JsonProcessingException
Method that allows accessing the original "message" argument, without additional decorations (like location information) that overridden JsonProcessingException.getMessage() adds.
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.
getOrPutIfAbsent(ConcurrentMap<K, V>, K, ConstructorFunction<K, V>) - Static method in class com.hazelcast.util.ConcurrencyUtil
 
getOrPutSynchronized(ConcurrentMap<K, V>, K, Object, ConstructorFunction<K, V>) - Static method in class com.hazelcast.util.ConcurrencyUtil
 
getOrPutSynchronized(ConcurrentMap<K, V>, K, ContextMutexFactory, ConstructorFunction<K, V>) - Static method in class com.hazelcast.util.ConcurrencyUtil
 
getOtherOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the total number of Other Operations
getOtherOperationsCount() - Method in interface com.hazelcast.monitor.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.
getOutboundNetworkStats() - Method in interface com.hazelcast.nio.AggregateEndpointManager
Gets network stats for outgoing traffic.
getOutboundNetworkStats() - Method in class com.hazelcast.nio.DefaultAggregateEndpointManager
 
getOutboundNetworkStats() - Method in class com.hazelcast.nio.UnifiedAggregateEndpointManager
 
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.config.AdvancedNetworkConfig.MemberNetworkingView
 
getOutboundPorts() - Method in class com.hazelcast.config.EndpointConfig
 
getOutboundPorts() - Method in class com.hazelcast.config.NetworkConfig
 
getOutboundPorts(EndpointQualifier) - Method in interface com.hazelcast.nio.IOService
 
getOutboundPorts(EndpointQualifier) - Method in class com.hazelcast.nio.NodeIOService
 
getOutboundPorts(Collection<Integer>, Collection<String>) - Static method in class com.hazelcast.util.AddressUtil
 
getOutboundQueueSize() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns the outbound queue size on this member
getOutbox() - Method in class com.hazelcast.jet.core.AbstractProcessor
 
getOutOfMemoryErrorCount() - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
Gets the number of OutOfMemoryErrors that have been reported.
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
 
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.monitor.LocalCacheStats
Returns the owned entry count in the cache.
getOwnedEntryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the number of entries owned by this member.
getOwnedEntryCount() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the number of Near Cache entries owned by this member.
getOwnedEntryMemoryCost() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns memory cost (number of bytes) of owned entries in this member.
getOwnedEntryMemoryCost() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns memory cost (number of bytes) of Near Cache entries owned by this member.
getOwnedItemCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns the number of owned items in this member.
getOwner() - Method in interface com.hazelcast.concurrent.lock.LockResource
 
getOwner() - Method in interface com.hazelcast.core.Partition
Returns the current member that owns this partition.
getOwner() - Method in interface com.hazelcast.mapreduce.JobPartitionState
Deprecated.
Returns the owner of this partition
getOwnerBundle() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Gets the owner Bundle of this instance.
getOwnerDocument() - Method in class com.hazelcast.config.yaml.ElementAdapter
 
getOwnerInfo(Data) - Method in interface com.hazelcast.concurrent.lock.LockStore
Return a string representation of the owner of the lock for a specific key.
getOwnerInfo(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
getOwnerInfo(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
 
getOwnerOrNull() - Method in interface com.hazelcast.spi.partition.IPartition
Returns the address of the owner of this partition.
getOwnerService() - Method in interface com.hazelcast.osgi.HazelcastOSGiInstance
Gets the owner HazelcastOSGiService of this instance.
getPackages() - Method in class com.hazelcast.config.ClassFilter
Returns unmodifiable set of package names.
getPacketSizeLimit() - Method in class com.hazelcast.jet.config.EdgeConfig
Returns the limit on the network packet size, in bytes
getPacketType() - Method in class com.hazelcast.nio.Packet
 
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 class com.hazelcast.query.PagingPredicate
 
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 class com.hazelcast.query.PagingPredicate
 
getParallelism() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Gets the configured number of Hot Restart store instance to create for one Hazelcast instance.
getParameterSource() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
Deprecated.
Since 2.7: does not have meaning as parameters depend on type resolved.
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
Returns the parent GroupProperty of the property.
getParentNode() - Method in class com.hazelcast.config.yaml.ElementAdapter
 
getParentOrder(int) - Static method in class com.hazelcast.wan.merkletree.MerkleTreeUtil
Returns the breadth-first order of the parent node of the node with nodeOrder
getParser(String) - Method in class com.hazelcast.nio.ascii.TextParsers
 
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.core.PartitionService
Returns the partition that the given key belongs to.
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(int) - Method in interface com.hazelcast.spi.partition.IPartitionService
Returns the IPartition for a given partition ID.
getPartition(int, boolean) - Method in interface com.hazelcast.spi.partition.IPartitionService
Returns the IPartition for a given partition ID.
getPartitionCount() - Method in interface com.hazelcast.spi.partition.IPartitionService
Returns the number of partitions.
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
 
getPartitionHash() - Method in interface com.hazelcast.nio.serialization.Data
Returns partition hash calculated for serialized object.
getPartitionId() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
getPartitionId() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
getPartitionId() - Method in class com.hazelcast.concurrent.lock.LockProxy
 
getPartitionId() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
 
getPartitionId() - Method in class com.hazelcast.core.MigrationEvent
Returns the ID of the partition which is (or is being) migrated
getPartitionId() - Method in interface com.hazelcast.core.Partition
Returns the ID of the partition.
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 class com.hazelcast.nio.Packet
Returns the partition ID of this packet.
getPartitionId() - Method in interface com.hazelcast.partition.PartitionEvent
Returns the partition ID that the event is dispatched for.
getPartitionId() - Method in class com.hazelcast.partition.PartitionLostEvent
Returns the lost partition ID.
getPartitionId() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
Returns the partition ID the task is associated with.
getPartitionId(Data) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
getPartitionId() - Method in class com.hazelcast.spi.InvocationBuilder
Returns the partition ID.
getPartitionId() - Method in class com.hazelcast.spi.Operation
Returns the ID of the partition that this Operation will be executed on.
getPartitionId() - Method in interface com.hazelcast.spi.partition.IPartition
Returns the partition ID.
getPartitionId() - Method in class com.hazelcast.spi.partition.IPartitionLostEvent
The partition ID that is lost.
getPartitionId(Data) - Method in interface com.hazelcast.spi.partition.IPartitionService
Returns the partition ID for a Data key.
getPartitionId(Object) - Method in interface com.hazelcast.spi.partition.IPartitionService
Returns the partition ID for a given object.
getPartitionId() - Method in interface com.hazelcast.spi.PartitionAwareOperation
Gets the partition ID.
getPartitionId() - Method in class com.hazelcast.spi.PartitionMigrationEvent
Gets the partition ID.
getPartitionId() - Method in class com.hazelcast.spi.PartitionReplicationEvent
Gets the ID of the partition.
getPartitioningStrategy() - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
getPartitioningStrategy(ClassLoader) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
getPartitioningStrategyClass() - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
getPartitioningStrategyConfig() - Method in class com.hazelcast.config.MapConfig
 
getPartitioningStrategyConfig() - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
getPartitionKey() - Method in class com.hazelcast.concurrent.idgen.IdGeneratorImpl
 
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.core.PartitionAware
The key that will be used by Hazelcast to specify the partition.
getPartitionKey() - Method in class com.hazelcast.core.PartitionAwareKey
 
getPartitionKey(K) - Method in interface com.hazelcast.core.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 class com.hazelcast.query.PartitionPredicate
Returns the partition key that determines the partition the target Predicate is going to execute on.
getPartitionKey() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
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
 
getPartitionLostListenerConfigs() - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
getPartitionOwner(int) - Method in interface com.hazelcast.spi.partition.IPartitionService
Gets the owner of the partition if it's set.
getPartitionOwnerOrWait(int) - Method in interface com.hazelcast.spi.partition.IPartitionService
Gets the owner of the partition.
getPartitions() - Method in interface com.hazelcast.core.PartitionService
Returns a set containing all the Partitions in the cluster.
getPartitions() - Method in interface com.hazelcast.monitor.MemberPartitionState
Returns a list of owned partitions of the member.
getPartitions() - Method in interface com.hazelcast.spi.partition.IPartitionService
Returns an array of IPartition instances.
getPartitionService() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the partition service of this Hazelcast instance.
getPartitionService() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getPartitionService() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getPartitionService() - Method in class com.hazelcast.instance.Node
 
getPartitionService() - Method in interface com.hazelcast.spi.NodeEngine
Gets the IPartitionService.
getPartitionsSynced() - Method in interface com.hazelcast.wan.WanSyncStats
Returns the number of the partitions synchronized
getPartitionStates() - Method in interface com.hazelcast.mapreduce.JobProcessInformation
Deprecated.
Returns an array of JobPartitionStates holding information about the processing state (JobPartitionState.State) and the processing owner of this partition.
The index of the JobPartitionState inside of the array is the number of the processed partition if the KeyValueSource is PartitionIdAware or a randomly assigned ID for the different members of the cluster.
getPartitionStateVersion() - Method in interface com.hazelcast.spi.partition.IPartitionService
 
getPassword() - Method in class com.hazelcast.config.GroupConfig
Deprecated.
since 3.11, password check is removed. Passwords are only checked in default LoginModule when Hazelcast security is enabled (Enterprise edition only).
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.SymmetricEncryptionConfig
 
getPassword() - Method in class com.hazelcast.security.UsernamePasswordCredentials
Gets the password.
getPatch() - Method in class com.hazelcast.version.MemberVersion
 
getPatchLevel() - Method in class com.hazelcast.com.fasterxml.jackson.core.Version
 
getPath(String...) - Static method in class com.hazelcast.nio.IOUtil
Concatenates path parts to a single path using the File.separator where it applies.
getPendingTaskCount() - Method in interface com.hazelcast.monitor.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.monitor.NearCacheStats
Returns the number of Near Cache key persistences (when the pre-load feature is enabled).
getPipeline() - Method in interface com.hazelcast.jet.pipeline.Stage
Returns the Pipeline this stage belongs to.
getPNCounter(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns a PNCounter with the given name.
getPNCounter(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getPNCounter(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
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.v1.exceptions.Mark
 
getPolicy() - Method in class com.hazelcast.config.MergePolicyConfig
Returns the classname of the SplitBrainMergePolicy.
getPollOperationCount() - Method in interface com.hazelcast.monitor.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.
getPoolSize() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
 
getPoolSize() - Method in interface com.hazelcast.util.executor.ManagedExecutorService
 
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.
getPort() - Method in class com.hazelcast.instance.AbstractMember
 
getPort() - Method in class com.hazelcast.nio.Address
 
getPort() - Method in interface com.hazelcast.nio.Connection
The remote port.
getPort() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
getPort() - Method in class com.hazelcast.util.AddressUtil.AddressHolder
 
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.v1.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.
getPossibleInetAddressesFor(Inet6Address) - Static method in class com.hazelcast.util.AddressUtil
 
getPostJoinOperation() - Method in interface com.hazelcast.spi.PostJoinAwareService
Post join operations must be lock free, meaning no locks at all: no partition locks, no key-based locks, no service level locks, no database interaction! The Operation.getPartitionId() method should return a negative value.
getPredicate() - Method in class com.hazelcast.query.PagingPredicate
 
getPredicate() - Method in class com.hazelcast.query.SqlPredicate
 
getPredicateConfig() - Method in class com.hazelcast.config.QueryCacheConfig
Returns the predicate of QueryCache.
getPrefetchCount() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
getPrefetchValidityMillis() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
getPrefix(URI, ClassLoader) - Static method in class com.hazelcast.cache.CacheUtil
Gets the prefix of cache name without Hazelcast's CacheManager specific prefix HazelcastCacheManager.CACHE_MANAGER_PREFIX.
getPrefix() - Method in class com.hazelcast.config.replacer.EncryptionReplacer
 
getPrefix() - Method in class com.hazelcast.config.replacer.PropertyReplacer
 
getPrefix() - Method in interface com.hazelcast.config.replacer.spi.ConfigReplacer
Variable replacer prefix string.
getPrefix() - Method in class com.hazelcast.config.yaml.ElementAdapter
 
getPrefixedCacheName(String, URI, ClassLoader) - Static method in class com.hazelcast.cache.CacheUtil
Gets the cache name with prefix but without Hazelcast's CacheManager specific prefix HazelcastCacheManager.CACHE_MANAGER_PREFIX.
getPrefixedName() - Method in interface com.hazelcast.core.PrefixedDistributedObject
Returns the unique prefixed name for this DistributedObject.
getPrefixes() - Method in class com.hazelcast.config.ClassFilter
Returns unmodifiable set of class name prefixes.
getPreJoinOperation() - Method in interface com.hazelcast.spi.PreJoinAwareService
An operation to be executed on the joining member before it is set as joined.
getPreloaderConfig() - Method in class com.hazelcast.config.NearCacheConfig
Returns the NearCachePreloaderConfig of this Near Cache.
getPreloaderConfig() - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
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
 
getPreviousSibling() - Method in class com.hazelcast.config.yaml.ElementAdapter
 
getPrincipal() - Method in class com.hazelcast.config.PermissionConfig
 
getPrincipal() - Method in class com.hazelcast.security.AbstractCredentials
 
getPrincipal() - Method in interface com.hazelcast.security.Credentials
Returns principal of endpoint.
getPriority() - Method in class com.hazelcast.jet.core.Edge
Returns the value of edge's priority, as explained on Edge.priority(int).
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
 
getPrivateIpAddresses() - Method in class com.hazelcast.aws.AWSClient
 
getProblem() - Method in exception com.hazelcast.org.snakeyaml.engine.v1.exceptions.MarkedYamlEngineException
 
getProblemMark() - Method in exception com.hazelcast.org.snakeyaml.engine.v1.exceptions.MarkedYamlEngineException
 
getProcessedRecords() - Method in interface com.hazelcast.mapreduce.JobProcessInformation
Deprecated.
Returns the number of processed records.
The number of processed records is not a real time value, it is updated on a regular basis (after 1000 processed elements per node).
getProcessingGuarantee() - Method in class com.hazelcast.jet.config.JobConfig
Returns the configured processing guarantee.
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.
getProgress() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
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.MCMutualAuthConfig
Gets all 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
 
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.SSLConfig
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.config.WanPublisherConfig
Returns the WAN publisher properties.
getProperties() - Method in class com.hazelcast.instance.Node
 
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
 
getProperties() - Method in interface com.hazelcast.spi.NodeEngine
Returns the HazelcastProperties.
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.MCMutualAuthConfig
Gets a property.
getProperty(String) - Method in class com.hazelcast.config.QueueStoreConfig
 
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.config.SSLConfig
Gets a property.
getProtocolType() - Method in class com.hazelcast.config.EndpointConfig
 
getProtocolType() - Method in class com.hazelcast.config.RestServerEndpointConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.AtomicLongConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.AtomicReferenceConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.CacheConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.CacheSimpleConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.CollectionConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.MapConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.MultiMapConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.QueueConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.ReplicatedMapConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.RingbufferConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
getProvidedMergeTypes() - Method in interface com.hazelcast.spi.merge.SplitBrainMergeTypeProvider
 
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
getProxyCount() - Method in interface com.hazelcast.spi.ProxyService
 
getProxyService() - Method in interface com.hazelcast.spi.NodeEngine
Gets the ProxyService.
getPublicAddress() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getPublicAddress() - Method in class com.hazelcast.config.NetworkConfig
 
getPublicAddress() - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
getPublicAddress() - Method in interface com.hazelcast.instance.AddressPicker
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.WanPublisherConfig
Returns the publisher ID used for identifying the publisher in a WanReplicationConfig.
getPublisherState() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns the current WanPublisherState of this publisher.
getPublishingMember() - Method in class com.hazelcast.core.Message
Returns the member that published the message.
getPublishOperationCount() - Method in interface com.hazelcast.monitor.LocalTopicStats
Returns the total number of published messages of this topic on this member
getPublishTime() - Method in class com.hazelcast.core.Message
Return the time when the message is published
getPutOperationCount() - Method in interface com.hazelcast.monitor.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.core.IMap
Returns corresponding QueryCache instance for the supplied name or null.
getQueryCache(String, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.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.core.IMap
Creates an always up to date snapshot of this IMap according to the supplied parameters.
getQueryCacheConfigs() - Method in class com.hazelcast.config.MapConfig
Returns all QueryCacheConfig instances defined on this MapConfig.
getQueryCacheConfigs() - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
getQueryCount() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the total number of queries served by the index.
getQueryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the total number of queries performed on the map.
getQueue() - Method in class com.hazelcast.console.ConsoleApp
 
getQueue(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed queue instance with the specified name.
getQueue(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getQueue(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
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.WanPublisherConfig
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.WanPublisherConfig
Returns the configured behaviour of this WAN publisher when the WAN queue is full.
getQueueSize() - Method in class com.hazelcast.config.JobTrackerConfig
Gets the maximum size of the queue; the maximum number of tasks that can wait to be processed.
getQueueSize() - Method in class com.hazelcast.jet.config.EdgeConfig
Returns the size of the SPSC queues used to implement this edge.
getQueueSize() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
 
getQueueSize() - Method in interface com.hazelcast.util.executor.ManagedExecutorService
 
getQueueSize() - Method in class com.hazelcast.util.executor.NamedThreadPoolExecutor
 
getQueueStoreConfig() - Method in class com.hazelcast.config.QueueConfig
Get the QueueStore (load and store queue items from/to a database) configuration.
getQueueStoreConfig() - Method in class com.hazelcast.config.QueueConfigReadOnly
Deprecated.
 
getQuorum(String) - Method in interface com.hazelcast.quorum.QuorumService
Returns the Quorum instance for a given quorum name.
getQuorumConfig(String) - Method in class com.hazelcast.config.Config
Returns the QuorumConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getQuorumConfigs() - Method in class com.hazelcast.config.Config
Returns the map of split brain protection configurations, mapped by config name.
getQuorumFunctionClassName() - Method in class com.hazelcast.config.QuorumConfig
 
getQuorumFunctionImplementation() - Method in class com.hazelcast.config.QuorumConfig
 
getQuorumName(String) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
 
getQuorumName(String) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
 
getQuorumName(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
getQuorumName(String) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
getQuorumName(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
 
getQuorumName() - Method in class com.hazelcast.config.AbstractBasicConfig
Returns the quorum name for operations.
getQuorumName() - Method in class com.hazelcast.config.CacheConfig
Gets the name of the associated quorum if any.
getQuorumName() - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
getQuorumName() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the name of the associated quorum if any.
getQuorumName() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Returns the quorum name for operations.
getQuorumName() - Method in class com.hazelcast.config.CollectionConfig
Returns the quorum name for operations.
getQuorumName() - Method in class com.hazelcast.config.CountDownLatchConfig
 
getQuorumName() - Method in class com.hazelcast.config.DurableExecutorConfig
Returns the quorum name for operations.
getQuorumName() - Method in class com.hazelcast.config.ExecutorConfig
Returns the quorum name for operations.
getQuorumName() - Method in class com.hazelcast.config.LockConfig
Returns the quorum name for lock operations.
getQuorumName() - Method in class com.hazelcast.config.MapConfig
 
getQuorumName() - Method in class com.hazelcast.config.MultiMapConfig
Returns the quorum name for operations.
getQuorumName() - Method in class com.hazelcast.config.PNCounterConfig
Returns the quorum name for operations.
getQuorumName() - Method in class com.hazelcast.config.QueueConfig
Returns the quorum name for queue operations.
getQuorumName() - Method in class com.hazelcast.config.ReplicatedMapConfig
Returns the quorum name for operations.
getQuorumName() - Method in class com.hazelcast.config.RingbufferConfig
Returns the quorum name for operations.
getQuorumName() - Method in class com.hazelcast.config.ScheduledExecutorConfig
Returns the quorum name for operations.
getQuorumName() - Method in class com.hazelcast.config.SemaphoreConfig
 
getQuorumName(String) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
getQuorumName(String) - Method in interface com.hazelcast.spi.QuorumAwareService
Gets the name of the quorum associated with specified operation name.
getQuorumService() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the quorum service of this Hazelcast instance.
getQuorumService() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getQuorumService() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getQuorumService() - Method in interface com.hazelcast.spi.NodeEngine
Gets the QuorumService.
getRaftAlgorithmConfig() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns configuration options for Hazelcast's Raft consensus algorithm implementation
getRandomSamples(int) - Method in class com.hazelcast.util.SampleableConcurrentHashMap
Gets and returns samples as sampleCount.
getRatio() - Method in interface com.hazelcast.monitor.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 write remaining fields in old fashioned way consecutively at the end of stream.
getRawPayload() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.RequestPayload
Returns the raw request payload object i.e, either byte[] or String
getReadBatchSize() - Method in class com.hazelcast.config.ReliableTopicConfig
Gets the maximum number of items to read in a batch.
getRealNode() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.AnchorNode
 
getReceivedEventCounters(String) - Method in interface com.hazelcast.wan.WanReplicationService
Returns a counter of received and processed WAN replication events.
getReceiveOperationCount() - Method in interface com.hazelcast.monitor.LocalTopicStats
Returns the total number of received messages of this topic on this member
getReceiveWindowMultiplier() - Method in class com.hazelcast.jet.config.EdgeConfig
 
getRecordsSynced() - Method in interface com.hazelcast.wan.WanSyncStats
Returns the number of the records synchronized
getReducerFactory() - Method in interface com.hazelcast.mapreduce.aggregation.Aggregation
Deprecated.
Returns the ReducerFactory for this aggregation.
getReferenceCallId() - Method in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
getReferenceContainer(String) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
 
getReferenceContainer() - Method in class com.hazelcast.concurrent.atomicreference.operations.AbstractAtomicReferenceOperation
 
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.
getRegion() - Method in class com.hazelcast.aws.AwsConfig
 
getRegion() - Method in class com.hazelcast.config.AwsConfig
getRegistrations(String, String) - Method in interface com.hazelcast.spi.EventService
Returns all registrations belonging to the given service and topic.
getRegistrationsAsArray(String, String) - Method in interface com.hazelcast.spi.EventService
Returns all registrations belonging to the given service and topic as an array.
getRejectedOfferOperationCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns the number of rejected offers.
getReleaseVersion() - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
getReliableLocalTopicStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getReliableTopic(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the reliable topic instance with the specified name.
getReliableTopic(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getReliableTopic(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
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.
getReliableTopicConfigs() - Method in class com.hazelcast.config.Config
Returns the map of reliable topic configurations, mapped by config name.
getRemainingLeaseTime() - Method in class com.hazelcast.concurrent.lock.LockProxy
 
getRemainingLeaseTime(NodeEngine, Data) - Method in class com.hazelcast.concurrent.lock.LockProxySupport
 
getRemainingLeaseTime() - Method in interface com.hazelcast.concurrent.lock.LockResource
 
getRemainingLeaseTime(Data) - Method in interface com.hazelcast.concurrent.lock.LockStore
Return the remaining lease time for a specific key.
getRemainingLeaseTime(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
getRemainingLeaseTime(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
 
getRemainingLeaseTime() - Method in interface com.hazelcast.core.ILock
Deprecated.
Returns remaining lease time in milliseconds.
GetRemainingLeaseTimeOperation - Class in com.hazelcast.concurrent.lock.operations
 
GetRemainingLeaseTimeOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.GetRemainingLeaseTimeOperation
 
GetRemainingLeaseTimeOperation(ObjectNamespace, Data) - Constructor for class com.hazelcast.concurrent.lock.operations.GetRemainingLeaseTimeOperation
 
getRemainingQueueCapacity() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
 
getRemainingQueueCapacity() - Method in interface com.hazelcast.util.executor.ManagedExecutorService
 
getRemainingQueueCapacity() - Method in class com.hazelcast.util.executor.NamedThreadPoolExecutor
 
getRemoteSocketAddress() - Method in interface com.hazelcast.nio.Connection
Returns the address of the endpoint this Connection is connected to, or null if it is unconnected.
getRemoteSocketAddress() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
getRemoveCount() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the number of remove operations performed on the index.
getRemoveOperationCount() - Method in interface com.hazelcast.monitor.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.
getReplicaAddress(int) - Method in interface com.hazelcast.spi.partition.IPartition
Returns the address of the replica.
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 class com.hazelcast.spi.InvocationBuilder
Gets the replicaIndex.
getReplicaIndex() - Method in class com.hazelcast.spi.Operation
 
getReplicaIndex() - Method in class com.hazelcast.spi.PartitionReplicationEvent
Gets the replica index.
getReplicatedMap(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the replicated map instance with the specified name.
getReplicatedMap(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getReplicatedMap(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
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.core.ReplicatedMap
Returns LocalReplicatedMapStats for this replicated map.
getReplicationDelayMillis() - Method in class com.hazelcast.config.ReplicatedMapConfig
Deprecated.
since new implementation will route puts to the partition owner nodes, caching won't help replication speed because most of the time subsequent puts will end up in different nodes
getReplicationEventCount() - Method in interface com.hazelcast.monitor.LocalReplicatedMapStats
Deprecated.
replication is no more handled by event system.
getReplicationPeriodMillis() - Method in class com.hazelcast.config.CRDTReplicationConfig
Returns the period between two replications of CRDT states in milliseconds.
getReplicatorExecutorService() - Method in class com.hazelcast.config.ReplicatedMapConfig
Deprecated.
new implementation doesn't use executor service for replication
getRepresentation() - Method in class com.hazelcast.org.snakeyaml.engine.v1.common.SpecVersion
 
getRequestPayload() - Method in exception com.hazelcast.com.fasterxml.jackson.core.JsonParseException
Method that may be called to find payload that was being parsed, if one was specified for parser that threw this Exception.
getRequestPayloadAsString() - Method in exception com.hazelcast.com.fasterxml.jackson.core.JsonParseException
The method returns the String representation of the request payload if one was specified for parser that threw this Exception.
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.
getResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
 
getResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
 
getResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.ApplyOperation
 
getResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
 
getResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
 
getResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
 
getResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetOperation
 
getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
 
getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
 
getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
 
getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.ContainsOperation
 
getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
 
getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetOperation
 
getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.IsNullOperation
 
getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetAndGetOperation
 
getResponse() - Method in class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
 
getResponse() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
 
getResponse() - Method in class com.hazelcast.concurrent.countdownlatch.operations.GetCountOperation
 
getResponse() - Method in class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
 
getResponse() - Method in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
getResponse() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
 
getResponse() - Method in class com.hazelcast.crdt.pncounter.operations.AddOperation
 
getResponse() - Method in class com.hazelcast.crdt.pncounter.operations.GetOperation
 
getResponse() - Method in class com.hazelcast.spi.Operation
Called if and only if Operation.returnsResponse() returned true, shortly after Operation.run() returns.
getRestApiConfig() - Method in class com.hazelcast.config.NetworkConfig
 
getRestApiConfig() - Method in interface com.hazelcast.nio.IOService
Returns initialized RestApiConfig for the node.
getRestApiConfig() - Method in class com.hazelcast.nio.NodeIOService
 
getRestEndpointConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig
 
getRetentionSeconds() - Method in class com.hazelcast.jet.config.MetricsConfig
Returns the number of seconds the metrics will be retained on the instance.
getRetryCount() - Method in class com.hazelcast.config.JobTrackerConfig
retry count is currently not used but reserved for later use where the framework will automatically try to restart / retry operations from a available savepoint.
getRevision() - Method in class com.hazelcast.instance.BuildInfo
 
getRevision() - Method in class com.hazelcast.instance.JetBuildInfo
 
getRightChildOrder(int) - Static method in class com.hazelcast.wan.merkletree.MerkleTreeUtil
Returns the breadth-first order of the right child node of the node with nodeOrder
getRingbuffer(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed Ringbuffer instance with the specified name.
getRingbuffer(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getRingbuffer(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
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.
getRootConstructNode() - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.LoadSettings
 
getRootValueSeparator() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
 
getRoutingPolicy() - Method in class com.hazelcast.jet.core.Edge
Returns the Edge.RoutingPolicy in effect on the edge.
getRuntimeProps() - Method in interface com.hazelcast.monitor.MemberState
 
getSalt() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
getScalarResolver() - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.DumpSettings
 
getScalarResolver() - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.LoadSettings
 
getScalarStyle() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.ScalarEvent
Style of the scalar.
getScalarStyle() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.ScalarNode
Get scalar style of this node.
getScaleUpDelayMillis() - Method in class com.hazelcast.jet.config.InstanceConfig
Returns the scale-up delay, see InstanceConfig.setScaleUpDelayMillis(long).
getScheduledDelayMillis() - Method in class com.hazelcast.util.scheduler.ScheduledEntry
 
getScheduledExecutorConfig(String) - Method in class com.hazelcast.config.Config
Returns the ScheduledExecutorConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getScheduledExecutorConfigs() - Method in class com.hazelcast.config.Config
Returns the map of scheduled executor configurations, mapped by config name.
getScheduledExecutorService(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the IScheduledExecutorService scheduled executor service for the given name.
getScheduledExecutorService(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getScheduledExecutorService(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getScheduledFuture(ScheduledTaskHandler) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates a new IScheduledFuture from the given handler.
getScheduleId() - Method in class com.hazelcast.util.scheduler.ScheduledEntry
 
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 parser uses, if any.
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
 
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.
getSchemaTypeInfo() - Method in class com.hazelcast.config.yaml.ElementAdapter
 
getScopedHost() - Method in class com.hazelcast.nio.Address
 
getScopeId() - Method in class com.hazelcast.nio.Address
 
getScopeId() - Method in class com.hazelcast.util.AddressUtil.AddressHolder
 
getSeconds(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured value of a HazelcastProperty converted to seconds.
getSecretKey() - Method in class com.hazelcast.aws.AwsConfig
 
getSecretKey() - Method in class com.hazelcast.config.AwsConfig
getSecurityConfig() - Method in class com.hazelcast.config.Config
Returns the security configuration for this hazelcast instance.
getSecurityContext() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
getSecurityContext() - Method in interface com.hazelcast.instance.NodeExtension
Returns SecurityContext for this Node if available, otherwise returns null.
getSecurityGroupName() - Method in class com.hazelcast.aws.AwsConfig
 
getSecurityGroupName() - Method in class com.hazelcast.config.AwsConfig
getSecurityInterceptorConfigs() - Method in class com.hazelcast.config.SecurityConfig
 
getSecurityService() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
getSecurityService() - Method in class com.hazelcast.instance.Node
 
getSecurityService() - Method in interface com.hazelcast.instance.NodeExtension
 
getSemaphore(String) - Method in interface com.hazelcast.core.HazelcastInstance
Deprecated.
This implementation may lose strong consistency in case of network failures or server failures. Please use CPSubsystem.getSemaphore(String) instead. This method will be removed in Hazelcast 4.0.
getSemaphore(String) - Method in interface com.hazelcast.cp.CPSubsystem
Returns a proxy for an ISemaphore instance created on the CP subsystem.
getSemaphore(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getSemaphore(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getSemaphoreConfig(String) - Method in class com.hazelcast.config.Config
Returns the SemaphoreConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getSemaphoreConfigs() - Method in class com.hazelcast.config.Config
Returns the collection of ISemaphore configs added to this config object.
getSemaphoreConfigs() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the map of CP ISemaphore configurations
getSemaphoreConfigsAsMap() - Method in class com.hazelcast.config.Config
Returns the map of ISemaphore configurations, mapped by config name.
getSemaphoreContainer() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
 
getSemaphoreContainer(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
 
getSentCacheEventCounter() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns the counter for the successfully transfered cache WAN events.
getSentEventCounters(String, String, String) - Method in interface com.hazelcast.wan.WanReplicationService
Returns a counter of sent and processed WAN replication events.
getSentMapEventCounter() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns the counter for the successfully transfered map WAN events.
getSequence() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.SequenceNode
 
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.config.Config
Returns the serialization configuration for this hazelcast instance.
getSerializationService() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getSerializationService() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getSerializationService() - Method in class com.hazelcast.instance.Node
 
getSerializationService() - Method in interface com.hazelcast.nio.IOService
 
getSerializationService() - Method in class com.hazelcast.nio.NodeIOService
 
getSerializationService() - Method in interface com.hazelcast.nio.ObjectDataInput
 
getSerializationService() - Method in interface com.hazelcast.nio.ObjectDataOutput
 
getSerializationService() - Method in interface com.hazelcast.spi.NodeEngine
Gets the SerializationService.
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
 
getServerSocketCardinality() - Method in enum com.hazelcast.instance.ProtocolType
 
getServerSocketChannel() - Method in interface com.hazelcast.instance.AddressPicker
getServerSocketChannel(EndpointQualifier) - Method in interface com.hazelcast.instance.AddressPicker
Returns a server channel.
getServerSocketChannels() - Method in interface com.hazelcast.instance.AddressPicker
Returns all ServerSocketChannels of this member, mapped by corresponding EndpointQualifier
getService() - Method in class com.hazelcast.spi.AbstractDistributedObject
Gets the Service of this AbstractDistributedObject.
getService(String) - Method in interface com.hazelcast.spi.NodeEngine
Gets the service with the given name.
getService() - Method in class com.hazelcast.spi.Operation
 
getServiceConfig(String) - Method in class com.hazelcast.config.ServicesConfig
 
getServiceConfigs() - Method in class com.hazelcast.config.ServicesConfig
 
getServiceImpl() - Method in class com.hazelcast.config.ServiceConfig
Deprecated.
getServiceName() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
getServiceName() - Method in class com.hazelcast.concurrent.atomiclong.operations.AbstractAtomicLongOperation
 
getServiceName() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
 
getServiceName() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
getServiceName() - Method in class com.hazelcast.concurrent.atomicreference.operations.AbstractAtomicReferenceOperation
 
getServiceName() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
 
getServiceName() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
 
getServiceName() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
 
getServiceName() - Method in class com.hazelcast.concurrent.idgen.IdGeneratorImpl
 
getServiceName() - Method in class com.hazelcast.concurrent.idgen.IdGeneratorProxy
 
getServiceName() - Method in class com.hazelcast.concurrent.lock.ConditionKey
 
getServiceName() - Method in class com.hazelcast.concurrent.lock.InternalLockNamespace
 
getServiceName() - Method in class com.hazelcast.concurrent.lock.LockProxy
 
getServiceName() - Method in class com.hazelcast.concurrent.lock.LockWaitNotifyKey
 
getServiceName() - Method in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
getServiceName() - Method in class com.hazelcast.concurrent.lock.operations.LockReplicationOperation
 
getServiceName() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
 
getServiceName() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreReplicationOperation
 
getServiceName() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
 
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 class com.hazelcast.crdt.pncounter.operations.AbstractPNCounterOperation
 
getServiceName() - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
 
getServiceName() - Method in class com.hazelcast.crdt.pncounter.PNCounterReplicationOperation
 
getServiceName() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
getServiceName() - Method in class com.hazelcast.spi.AbstractWaitNotifyKey
 
getServiceName() - Method in class com.hazelcast.spi.DefaultObjectNamespace
Deprecated.
 
getServiceName() - Method in class com.hazelcast.spi.InvocationBuilder
Gets the name of the service.
getServiceName() - Method in class com.hazelcast.spi.Operation
 
getServiceName() - Method in interface com.hazelcast.spi.ServiceNamespace
Name of the service
getServiceName() - Method in interface com.hazelcast.spi.tenantcontrol.DestroyEventContext
 
getServiceName() - Method in interface com.hazelcast.spi.WaitNotifyKey
Returns the service name of the wait notify object for this key.
getServiceName() - Method in class com.hazelcast.wan.WanReplicationEvent
Returns the service name for this event object.
getServiceNamespace() - Method in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
getServiceNamespace() - Method in interface com.hazelcast.spi.ServiceNamespaceAware
Returns the ServiceNamespace which this object belongs to.
getServices(Class<S>) - Method in interface com.hazelcast.spi.NodeEngine
Returns a list of services matching provides service class/interface.
getServicesConfig() - Method in class com.hazelcast.config.Config
Returns the configuration for the user services managed by this hazelcast instance.
getSessionHeartbeatIntervalSeconds() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns interval for the periodically-committed CP session heartbeats
getSessionTimeToLiveSeconds() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns duration for a CP session to be kept alive after the last heartbeat
getSet() - Method in class com.hazelcast.console.ConsoleApp
 
getSet(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed set instance with the specified name.
getSet(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getSet(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
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.
getSharedService(String) - Method in interface com.hazelcast.spi.NodeEngine
Deprecated.
since 3.7, please use NodeEngine.getService(String) instead
getShortAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
 
getShortAttribute(String) - Method in interface com.hazelcast.core.Member
Returns the value of the specified key for this member or null if value is undefined.
getShortAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
 
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
 
getSignedHeaders() - Method in class com.hazelcast.aws.security.EC2RequestSigner
 
getSingleNode() - Method in class com.hazelcast.org.snakeyaml.engine.v1.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
Returns the size which is used by the EvictionConfig.MaxSizePolicy.
getSize() - Method in class com.hazelcast.config.MaxSizeConfig
Returns the size of the map.
getSize() - Method in class com.hazelcast.config.NativeMemoryConfig
Returns size of the native memory region.
getSize() - Method in class com.hazelcast.config.QuorumConfig
 
getSnapshotIntervalMillis() - Method in class com.hazelcast.jet.config.JobConfig
Returns the configured snapshot interval.
getSocketAddress() - Method in interface com.hazelcast.core.Client
Returns the socket address of this client.
getSocketAddress() - Method in interface com.hazelcast.core.Endpoint
Returns the socket address for this endpoint.
getSocketAddress() - Method in interface com.hazelcast.core.Member
Deprecated.
getSocketAddress(EndpointQualifier) - Method in interface com.hazelcast.core.Member
Returns the socket address of this member.
getSocketAddress() - Method in class com.hazelcast.instance.AbstractMember
 
getSocketAddress(EndpointQualifier) - Method in class com.hazelcast.instance.AbstractMember
 
getSocketConnectTimeoutSeconds() - Method in class com.hazelcast.config.EndpointConfig
 
getSocketConnectTimeoutSeconds(EndpointQualifier) - Method in interface com.hazelcast.nio.IOService
 
getSocketConnectTimeoutSeconds(EndpointQualifier) - Method in class com.hazelcast.nio.NodeIOService
 
getSocketInterceptor(EndpointQualifier) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
getSocketInterceptor(EndpointQualifier) - Method in interface com.hazelcast.instance.NodeExtension
Returns MemberSocketInterceptor for this Node if available, otherwise returns null.
getSocketInterceptor(EndpointQualifier) - Method in interface com.hazelcast.nio.IOService
 
getSocketInterceptor(EndpointQualifier) - Method in class com.hazelcast.nio.NodeIOService
 
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
getSocketInterceptorConfig(EndpointQualifier) - Method in class com.hazelcast.nio.NodeIOService
 
getSocketLingerSeconds() - Method in class com.hazelcast.config.EndpointConfig
 
getSocketRcvBufferSizeKb() - Method in class com.hazelcast.config.EndpointConfig
 
getSocketSendBufferSizeKb() - Method in class com.hazelcast.config.EndpointConfig
 
getSortedQueryResultSet(List<Map.Entry>, PagingPredicate, IterationType) - Static method in class com.hazelcast.util.SortingUtil
 
getSortedSubList(List<QueryableEntry>, PagingPredicate, Map.Entry<Integer, Map.Entry>) - Static method in class com.hazelcast.util.SortingUtil
 
getSource() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.DupDetector
 
getSource() - Method in class com.hazelcast.core.AbstractIMapEvent
Returns the object on which the event initially occurred.
getSource() - Method in class com.hazelcast.jet.core.Edge
Returns this edge's source vertex.
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.v1.events.DocumentStartEvent
 
getSpecVersion() - Method in exception com.hazelcast.org.snakeyaml.engine.v1.exceptions.YamlVersionException
 
getSplitBrainMergePolicyProvider() - Method in interface com.hazelcast.spi.NodeEngine
Returns the SplitBrainMergePolicyProvider for this instance.
getSql() - Method in class com.hazelcast.config.PredicateConfig
Returns sql string for this config.
getSSLConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getSSLConfig() - Method in class com.hazelcast.config.EndpointConfig
Returns the current SSLConfig.
getSSLConfig() - Method in class com.hazelcast.config.NetworkConfig
Returns the current SSLConfig.
getSSLConfig(EndpointQualifier) - Method in interface com.hazelcast.nio.IOService
 
getSSLConfig(EndpointQualifier) - Method in class com.hazelcast.nio.NodeIOService
 
getSSLContext() - Method in class com.hazelcast.nio.ssl.BasicSSLContextFactory
 
getSSLContext() - Method in interface com.hazelcast.nio.ssl.SSLContextFactory
 
getStartedTaskCount() - Method in interface com.hazelcast.monitor.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.v1.events.Event
 
getStartMark() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.Node
 
getStartMark() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.Token
 
getStartTime() - Method in interface com.hazelcast.cluster.Joiner
Deprecated.
 
getState() - Method in class com.hazelcast.core.LifecycleEvent
 
getState() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
getState() - Method in class com.hazelcast.instance.Node
Returns the node state.
getState() - Method in interface com.hazelcast.mapreduce.JobPartitionState
Deprecated.
Returns the current processing state of this partition
getStats() - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
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.
getStats() - Method in interface com.hazelcast.spi.StatisticsAwareService
Return the service statistics for the local instance.
getStatus() - Method in class com.hazelcast.core.MigrationEvent
Returns the status of the migration: started, completed or failed
getStatus() - Method in interface com.hazelcast.jet.Job
Returns the current status of this job.
getStatus() - Method in interface com.hazelcast.monitor.WanSyncState
 
getStatus() - Method in enum com.hazelcast.wan.WanSyncStatus
 
getStoreImplementation() - Method in class com.hazelcast.config.QueueStoreConfig
 
getStoreImplementation() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
getStoreInitialDelaySeconds() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
getStoreIntervalSeconds() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
getString(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured value of a HazelcastProperty as String.
getString(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
Returns a field in a Json object as a string.
getString(JsonObject, String, String) - Static method in class com.hazelcast.util.JsonUtil
Returns a field in a Json object as a string.
getStringAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
 
getStringAttribute(String) - Method in interface com.hazelcast.core.Member
Returns the value of the specified key for this member or null if value is undefined.
getStringAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
 
getStyle() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.ScalarToken
 
getSubmissionTime() - Method in interface com.hazelcast.jet.Job
Returns the time when the job was submitted to the cluster.
getSubscriber() - Method in interface com.hazelcast.spi.EventRegistration
Returns the subscriber of this registration.
getSuffix() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.TagTuple
 
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
getSymmetricEncryptionConfig(EndpointQualifier) - Method in interface com.hazelcast.nio.IOService
 
getSymmetricEncryptionConfig(EndpointQualifier) - Method in class com.hazelcast.nio.NodeIOService
 
getSyncBackupCount() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBackupAwareOperation
 
getSyncBackupCount() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBackupAwareOperation
 
getSyncBackupCount() - Method in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
getSyncBackupCount() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreBackupAwareOperation
 
getSyncBackupCount() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDetachMemberOperation
 
getSyncBackupCount() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
 
getSyncBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
Deprecated.
getSyncBackupCount() - Method in interface com.hazelcast.spi.BackupAwareOperation
The synchronous backup count.
getSyncedPartitionCount() - Method in interface com.hazelcast.monitor.WanSyncState
 
getSystemLoadAverage() - Static method in class com.hazelcast.util.OperatingSystemMXBeanSupport
Reads the system load average attribute from OperatingSystemMXBean.
getSystemProperty() - Method in class com.hazelcast.spi.properties.HazelcastProperty
Gets the system property value of the property.
getTag() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
 
getTag(String) - Method in class com.hazelcast.jet.core.metrics.Measurement
Returns the value associated with a specific tag, based on the metric description of this particular Measurement.
getTag() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.CollectionStartEvent
Tag of this collection.
getTag() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.ScalarEvent
Tag of this scalar.
getTag() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.Node
Tag of this node.
getTag(Class<?>, Tag) - Method in class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter
 
getTagConstructors() - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.LoadSettings
 
getTagDirective() - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.DumpSettings
 
getTagKey() - Method in class com.hazelcast.aws.AwsConfig
 
getTagKey() - Method in class com.hazelcast.config.AwsConfig
getTagName() - Method in class com.hazelcast.config.yaml.ElementAdapter
 
getTags() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.DocumentStartEvent
Tag shorthands as defined by the %TAG directive.
getTagValue() - Method in class com.hazelcast.aws.AwsConfig
 
getTagValue() - Method in class com.hazelcast.config.AwsConfig
getTailSequence() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Returns the sequence of the tail.
getTarget() - Method in class com.hazelcast.query.PartitionPredicate
Returns the target Predicate.
getTarget() - Method in exception com.hazelcast.spi.exception.WrongTargetException
 
getTarget() - Method in class com.hazelcast.spi.InvocationBuilder
Returns the target machine.
getTargetExecutionCallback() - Method in class com.hazelcast.spi.InvocationBuilder
 
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.
getTaskQueues() - Method in class com.hazelcast.util.executor.StripedExecutor
 
getTaskScheduler(String) - Method in interface com.hazelcast.spi.ExecutionService
 
getTcpIpConfig() - Method in class com.hazelcast.config.JoinConfig
 
getTenantControl(CacheConfig<K, V>) - Static method in class com.hazelcast.config.CacheConfigAccessor
 
getterIntoProperty(String) - Static method in class com.hazelcast.util.StringUtil
Convert getter into a property name Example: 'getFoo' is converted into 'foo' It's written defensively, when output is not a getter then it returns the original name.
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 in a single char array regardless of whether they were collected in a segmented fashion or not.
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
 
getTextCommandService() - Method in class com.hazelcast.instance.Node
 
getTextCommandService() - Method in interface com.hazelcast.nio.IOService
 
getTextCommandService() - Method in class com.hazelcast.nio.NodeIOService
 
getTextContent(Node) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
getTextContent(Node, boolean) - Static method in class com.hazelcast.config.DomConfigHelper
 
getTextContent() - Method in class com.hazelcast.config.yaml.ElementAdapter
 
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
Accessor used with JsonParser.getTextCharacters(), to know length of String stored in returned buffer.
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
Accessor used with JsonParser.getTextCharacters(), to know offset of the first text content character within buffer.
getTextOffset() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
 
getTextOffset() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
 
getThisAddress() - Method in class com.hazelcast.instance.Node
 
getThisAddress() - Method in interface com.hazelcast.nio.IOService
 
getThisAddress() - Method in class com.hazelcast.nio.NodeIOService
 
getThisAddress() - Method in interface com.hazelcast.spi.NodeEngine
Get the address of this member.
getThisAddresses() - Method in interface com.hazelcast.nio.IOService
 
getThisAddresses() - Method in class com.hazelcast.nio.NodeIOService
 
getThisUuid() - Method in class com.hazelcast.instance.Node
 
getThreadId() - Method in class com.hazelcast.concurrent.lock.ConditionKey
 
getThreadId() - Method in interface com.hazelcast.concurrent.lock.LockResource
 
getThreadId() - Static method in class com.hazelcast.util.ThreadUtil
Get the thread ID.
getThreshold() - Method in class com.hazelcast.quorum.QuorumEvent
Returns the predefined quorum threshold
getTimedExpiryPolicyFactoryConfig() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
getTimeout() - Method in interface com.hazelcast.util.executor.TimeoutRunnable
 
getTimeoutMillis() - Method in class com.hazelcast.transaction.TransactionOptions
Gets the timeout in milliseconds.
getTimeoutMilliseconds() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
getTimestamp() - Method in class com.hazelcast.jet.core.metrics.Measurement
Returns the timestamps associated with this Measurement, the moment when the value was gathered.
getTimeToLiveSeconds() - Method in class com.hazelcast.config.EventJournalConfig
Gets the time to live in seconds.
getTimeToLiveSeconds() - Method in class com.hazelcast.config.MapConfig
Returns the maximum number of seconds for each entry to stay in the map.
getTimeToLiveSeconds() - Method in class com.hazelcast.config.NearCacheConfig
Returns the maximum number of seconds for each entry to stay in the Near Cache (time to live).
getTimeToLiveSeconds() - Method in class com.hazelcast.config.RingbufferConfig
Gets the time to live in seconds.
getTimeUnit() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
getTimeUnit() - Method in class com.hazelcast.spi.properties.HazelcastProperty
Returns the TimeUnit of the property.
getTimeUnit() - Method in interface com.hazelcast.util.executor.TimeoutRunnable
 
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
 
getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.AliasToken
 
getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.AnchorToken
 
getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.BlockEndToken
 
getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.BlockEntryToken
 
getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.BlockMappingStartToken
 
getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.BlockSequenceStartToken
 
getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.DirectiveToken
 
getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.DocumentEndToken
 
getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.DocumentStartToken
 
getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.FlowEntryToken
 
getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.FlowMappingEndToken
 
getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.FlowMappingStartToken
 
getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.FlowSequenceEndToken
 
getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.FlowSequenceStartToken
 
getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.KeyToken
 
getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.ScalarToken
 
getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.StreamEndToken
 
getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.StreamStartToken
 
getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.TagToken
 
getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.Token
For error reporting.
getTokenId() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.ValueToken
 
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.console.ConsoleApp
 
getTopic(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed topic instance with the specified name.
getTopic(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getTopic(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
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.config.ReliableTopicConfig
Gets the TopicOverloadPolicy for this reliable topic.
getTopologyChangedStrategy() - Method in class com.hazelcast.config.JobTrackerConfig
Gets how the map reduce framework will react on topology changes while executing a job.
getTotal() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
getTotalBackupCount() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
getTotalBackupCount() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
 
getTotalBackupCount() - Method in class com.hazelcast.config.CacheConfig
Gets the total backup count (backupCount + asyncBackupCount) of the cache.
getTotalBackupCount() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Returns the total number of backups: backupCount plus asyncBackupCount.
getTotalBackupCount() - Method in class com.hazelcast.config.CollectionConfig
Gets the total number of synchronous and asynchronous backups for this collection.
getTotalBackupCount() - Method in class com.hazelcast.config.MapConfig
Returns the total number of backups: backupCount plus asyncBackupCount.
getTotalBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
Gets the total number of backups (synchronous + asynchronous) for this MultiMap.
getTotalBackupCount() - Method in class com.hazelcast.config.QueueConfig
Get the total number of backups: the backup count plus the asynchronous backup count.
getTotalBackupCount() - Method in class com.hazelcast.config.RingbufferConfig
Returns the total number of backups: backupCount plus asyncBackupCount.
getTotalBackupCount() - Method in class com.hazelcast.config.SemaphoreConfig
Returns the total number of backups (synchronous plus asynchronous); the returned value will always equal or bigger than 0.
getTotalDecrementOperationCount() - Method in interface com.hazelcast.monitor.LocalPNCounterStats
Returns the total number of subtract (including decrement) operations on this PN counter on this member.
getTotalExecutionLatency() - Method in interface com.hazelcast.monitor.LocalExecutorStats
Returns the total execution time of operations finished.
getTotalGetLatency() - Method in interface com.hazelcast.monitor.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.
getTotalIncrementOperationCount() - Method in interface com.hazelcast.monitor.LocalPNCounterStats
Returns the total number of add (including increment) operations on this PN counter on this member.
getTotalInsertLatency() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the total latency (in nanoseconds) of insert operations performed on the index.
getTotalMemory() - Method in interface com.hazelcast.util.MemoryInfoAccessor
Returns total amount allocated memory in the Java virtual machine in bytes.
getTotalMemory() - Method in class com.hazelcast.util.RuntimeMemoryInfoAccessor
 
getTotalPhysical() - Method in class com.hazelcast.memory.DefaultMemoryStats
 
getTotalPhysical() - Method in interface com.hazelcast.memory.MemoryStats
Returns total physical memory available in OS.
getTotalPublishedEventCount() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns the total number of published events from this member
getTotalPublishLatency() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns the total latency of published wan events from this member by millisecond.
getTotalPutLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the total latency of put operations.
getTotalRemoveLatency() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the total latency (in nanoseconds) of remove operations performed on the index.
getTotalRemoveLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the total latency of remove operations.
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.
getTotalStartLatency() - Method in interface com.hazelcast.monitor.LocalExecutorStats
Returns the total start latency of operations started.
getTotalUpdateLatency() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the total latency (in nanoseconds) of update operations performed on the index.
getTrackableJob(String) - Method in interface com.hazelcast.mapreduce.JobTracker
Deprecated.
Returns an implementation of TrackableJob, or null if the job ID is not available or the job is already finished.
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.
getTransactionManagerService() - Method in interface com.hazelcast.spi.NodeEngine
Gets the TransactionManagerService.
getTransactionType() - Method in class com.hazelcast.transaction.TransactionOptions
getTrustedInterfaces() - Method in class com.hazelcast.config.MulticastConfig
Gets the trusted interfaces.
getTryCount() - Method in class com.hazelcast.spi.InvocationBuilder
Gets the try count; the number of times this operation can be retried.
getTryPauseMillis() - Method in class com.hazelcast.spi.InvocationBuilder
Gets the pause time in milliseconds.
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.journal.EventJournalCacheEvent
Returns the event type.
getType() - Method in interface com.hazelcast.cluster.Joiner
Deprecated.
 
getType() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.TypeReference
 
getType() - Method in class com.hazelcast.config.PermissionConfig
 
getType(String) - Static method in enum com.hazelcast.config.PermissionConfig.PermissionType
 
getType() - Method in class com.hazelcast.config.QuorumConfig
 
getType() - Method in enum com.hazelcast.core.EntryEventType
 
getType() - Method in enum com.hazelcast.core.ItemEventType
 
getType() - Method in class com.hazelcast.instance.EndpointQualifier
 
getType() - Method in interface com.hazelcast.map.journal.EventJournalMapEvent
Returns the event type.
getType() - Method in interface com.hazelcast.nio.Connection
Returns the ConnectionType of this Connection.
getType() - Method in interface com.hazelcast.nio.serialization.Data
Returns serialization type of binary form.
getType() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
 
getType() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
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
Deprecated.
Since 2.8 use JsonStreamContext.typeDesc() instead
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
 
getTypeSize() - Method in enum com.hazelcast.nio.serialization.FieldType
 
getUncommittedEntryCountToRejectNewAppends() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
getUnit() - Method in class com.hazelcast.memory.MemorySize
Returns unit of memory size
getUnknownCollectionCount() - Method in class com.hazelcast.memory.DefaultGarbageCollectorStats
 
getUnknownCollectionCount() - Method in interface com.hazelcast.memory.GarbageCollectorStats
Returns collection count which cannot be identified as major or minor.
getUnknownCollectionTime() - Method in class com.hazelcast.memory.DefaultGarbageCollectorStats
 
getUnknownCollectionTime() - Method in interface com.hazelcast.memory.GarbageCollectorStats
Returns total collection time which cannot be identified as major or minor.
getUpdateCount() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the number of update operations performed on the index.
getUpdateInterval() - Method in class com.hazelcast.config.ManagementCenterConfig
Gets the time frequency (in seconds) for which Management Center will take information from the Hazelcast cluster.
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.ManagementCenterConfig
Gets the URL where management center will work.
getUrl() - Method in class com.hazelcast.jet.config.ResourceConfig
Returns the URL at which the resource will be available.
getUsage() - Method in class com.hazelcast.config.LoginModuleConfig
 
getUsedHeap() - Method in class com.hazelcast.memory.DefaultMemoryStats
 
getUsedHeap() - Method in interface com.hazelcast.memory.MemoryStats
Returns the amount of used memory in the JVM in bytes.
getUsedMetadata() - Method in class com.hazelcast.memory.DefaultMemoryStats
 
getUsedMetadata() - Method in interface com.hazelcast.memory.MemoryStats
 
getUsedNative() - Method in class com.hazelcast.memory.DefaultMemoryStats
 
getUsedNative() - Method in interface com.hazelcast.memory.MemoryStats
Returns the amount of used native memory in current HazelcastInstance in bytes.
getUseMarks() - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.LoadSettings
 
getUserCodeDeploymentConfig() - Method in class com.hazelcast.config.Config
Get current configuration of User Code Deployment.
getUserContext() - Method in class com.hazelcast.config.Config
Returns the user supplied context.
getUserContext() - Method in interface com.hazelcast.core.HazelcastInstance
Returns a ConcurrentMap that can be used to add user-context to the HazelcastInstance.
getUserContext() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getUserContext() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getUserData(String) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
getUsername() - Method in class com.hazelcast.security.UsernamePasswordCredentials
Gets the user name.
getUuid() - Method in class com.hazelcast.concurrent.lock.ConditionKey
 
getUuid() - Method in interface com.hazelcast.core.Client
Returns a unique UUID for this client.
getUuid() - Method in interface com.hazelcast.core.Endpoint
Returns the UUID of this endpoint
getUuid() - Method in interface com.hazelcast.core.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.instance.AbstractMember
 
getUuid() - Method in interface com.hazelcast.monitor.MemberState
Returns the UUID of this member.
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(int) - Static method in enum com.hazelcast.cluster.MemberAttributeOperationType
Gets the MemberAttributeOperationType by ID.
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.core.MemberAttributeEvent
Returns the value for this MemberAttributeEvent.
getValue() - Method in class com.hazelcast.crdt.pncounter.operations.CRDTTimestampedLong
 
getValue() - Method in class com.hazelcast.jet.core.metrics.Measurement
Returns the value associated with this Measurement.
getValue() - Method in class com.hazelcast.jet.datamodel.KeyedWindowResult
Alias for WindowResult.result(), implements Map.Entry.
getValue() - Method in class com.hazelcast.jet.datamodel.Tuple2
 
getValue() - Method in class com.hazelcast.memory.MemorySize
Returns value of memory size in its original unit.
getValue() - Method in interface com.hazelcast.monitor.LocalPNCounterStats
Returns the current value of this PN counter
getValue() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.ScalarEvent
String representation of the value.
getValue() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.CollectionNode
Returns the elements in this sequence.
getValue() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.MappingNode
Returns the entries of this map.
getValue() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.ScalarNode
Value of this scalar.
getValue() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.SequenceNode
Returns the elements in this sequence.
getValue() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.Tag
 
getValue() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.AliasToken
 
getValue() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.AnchorToken
 
getValue() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.DirectiveToken
 
getValue() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.ScalarToken
 
getValue() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.TagToken
 
getValue() - Method in interface com.hazelcast.spi.merge.MergingValue
Returns the merging value in the in-memory format of the backing data structure.
getValue() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap.SimpleEntry
 
getValue() - Method in class com.hazelcast.util.scheduler.ScheduledEntry
 
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 int.
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
 
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.
getValueMetadata() - Method in class com.hazelcast.query.Metadata
 
getValueNode() - Method in class com.hazelcast.org.snakeyaml.engine.v1.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.
getVectorClock() - Method in class com.hazelcast.crdt.pncounter.operations.CRDTTimestampedLong
 
getVectorClocks() - Method in class com.hazelcast.crdt.CRDTReplicationContainer
Returns the vector clocks for the CRDTs replicated by the replication operation.
getVersion() - Method in interface com.hazelcast.concurrent.lock.LockResource
 
getVersion(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
getVersion() - Method in interface com.hazelcast.core.EntryView
Returns the version of the entry.
getVersion() - Method in interface com.hazelcast.core.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 class com.hazelcast.instance.AbstractMember
 
getVersion() - Method in class com.hazelcast.instance.BuildInfo
 
getVersion() - Method in class com.hazelcast.instance.JetBuildInfo
 
getVersion() - Method in class com.hazelcast.instance.Node
Returns the codebase version of the node.
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.
getVersion() - Method in interface com.hazelcast.spi.NodeEngine
Returns the codebase version of the node.
getVersionFunction() - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.LoadSettings
 
getVertex(String) - Method in class com.hazelcast.jet.core.DAG
Returns the vertex with the given name.
getWaitKey() - Method in class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
 
getWaitKey() - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
 
getWaitKey() - Method in class com.hazelcast.concurrent.lock.operations.LockOperation
 
getWaitKey() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
 
getWaitKey() - Method in interface com.hazelcast.spi.BlockingOperation
 
getWaitTimeout() - Method in interface com.hazelcast.spi.BlockingOperation
 
getWaitTimeout() - Method in class com.hazelcast.spi.Operation
Returns the wait timeout in millis.
getWanConsumerConfig() - Method in class com.hazelcast.config.WanReplicationConfig
Returns the WAN consumer configuration for this WAN replication.
getWanPublisherConfigs() - Method in class com.hazelcast.config.WanReplicationConfig
Returns the list of configured WAN publisher targets for this WAN replication.
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.
getWanReplicationPublisher(String) - Method in interface com.hazelcast.wan.WanReplicationService
Creates a new WanReplicationPublisher by the given name.
getWanReplicationRef() - Method in class com.hazelcast.config.CacheConfig
 
getWanReplicationRef() - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
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.
getWanReplicationRef() - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
getWanReplicationService() - Method in interface com.hazelcast.spi.NodeEngine
Gets the WanReplicationService.
getWanSyncConfig() - Method in class com.hazelcast.config.WanPublisherConfig
Returns the config for the WAN sync mechanism.
getWanSyncState() - Method in interface com.hazelcast.monitor.MemberState
 
getWanSyncState() - Method in interface com.hazelcast.wan.WanReplicationService
Returns current status of WAN sync operation or null when there is no status.
getWatermark(int) - Method in class com.hazelcast.jet.core.EventTimeMapper
Watermark value to be saved to state snapshot for the given source partition index.
getWeightedItem(int) - Method in class com.hazelcast.util.collection.WeightedEvictableList
 
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.v1.api.DumpSettings
 
getWorkQueueSize() - Method in class com.hazelcast.util.executor.StripedExecutor
Returns the total number of tasks pending to be executed.
getWrappedMutableYamlNode(Node) - Static method in class com.hazelcast.config.yaml.W3cDomUtil
Returns the the wrapped MutableYamlNode instance of the provided Node if the node is an instance of ElementAdapter and the YAML node wrapped by the node is a MutableYamlNode.
getWrappedYamlMapping(Node) - Static method in class com.hazelcast.config.yaml.W3cDomUtil
Returns the the wrapped YamlMapping instance of the provided Node if the node is an instance of ElementAdapter and the YAML node wrapped by the node is a YamlMapping.
getWrappedYamlScalar(Node) - Static method in class com.hazelcast.config.yaml.W3cDomUtil
Returns the the wrapped YamlScalar instance of the provided Node if the node is an instance of ElementAdapter and the YAML node wrapped by the node is a YamlScalar.
getWrappedYamlSequence(Node) - Static method in class com.hazelcast.config.yaml.W3cDomUtil
Returns the the wrapped YamlSequence instance of the provided Node if the node is an instance of ElementAdapter and the YAML node wrapped by the node is a YamlSequence.
getWriteBatchSize() - Method in class com.hazelcast.config.MapStoreConfig
Returns the number of operations to be included in each batch processing round.
getWriteDelaySeconds() - Method in class com.hazelcast.config.MapStoreConfig
Returns the number of seconds to delay the store writes.
getXAResource() - Method in interface com.hazelcast.core.HazelcastInstance
Gets xaResource which will participate in XATransaction.
getXAResource() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
getXAResource() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
getXaResource() - Method in interface com.hazelcast.transaction.TransactionContext
Deprecated.
since 3.5 please use HazelcastInstance.getXAResource()
getYamlDirective() - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.DumpSettings
 
getYamlNode() - Method in class com.hazelcast.config.yaml.ElementAdapter
 
gigaBytes() - Method in class com.hazelcast.memory.MemorySize
Returns value of memory size in giga-bytes.
glob(String) - Method in class com.hazelcast.jet.avro.AvroSourceBuilder
Sets the globbing mask, see getPathMatcher().
glob(String) - Method in class com.hazelcast.jet.pipeline.FileSourceBuilder
Sets the globbing mask, see getPathMatcher().
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
 
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.GroupProperty
 
GracefulShutdownAwareService - Interface in com.hazelcast.spi
An interface that can be implemented by SPI services to participate in graceful shutdown process, such as moving their internal data to another node or releasing their allocated resources gracefully.
greaterEqual(String, Comparable) - Static method in class com.hazelcast.jet.pipeline.GenericPredicates
greaterEqual(Comparable) - Method in class com.hazelcast.query.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(String, Comparable) - Static method in class com.hazelcast.jet.pipeline.GenericPredicates
greaterThan(Comparable) - Method in class com.hazelcast.query.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.
GroupConfig - Class in com.hazelcast.config
Contains the configuration for Hazelcast groups.
GroupConfig() - Constructor for class com.hazelcast.config.GroupConfig
Creates a GroupConfig with default group-name and group-password.
GroupConfig(String) - Constructor for class com.hazelcast.config.GroupConfig
Creates a GroupConfig with the given group-name and default group-password
GroupConfig(String, String) - Constructor for class com.hazelcast.config.GroupConfig
Creates a GroupConfig with the given group-name and group-password
GroupConfig(GroupConfig) - Constructor for class com.hazelcast.config.GroupConfig
Copy constructor
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
 
GroupProperty - Class in com.hazelcast.spi.properties
Defines the name and default value for Hazelcast properties.
growArrayBy(int[], int) - Static method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
 

H

handleAddListener(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleClear(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleCommand(String) - Method in class com.hazelcast.console.ConsoleApp
Handles a command.
handleContains(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleDestroy(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleException(Throwable) - Method in interface com.hazelcast.util.FutureUtil.ExceptionHandler
 
handleExcludedMemberUuids(Address, Set<String>) - Method in interface com.hazelcast.hotrestart.InternalHotRestartService
Handles the UUID set of excluded members only if this member is also excluded, and triggers the member force start process.
handleExcludedMemberUuids(Address, Set<String>) - Method in class com.hazelcast.hotrestart.NoopInternalHotRestartService
 
handleExit() - Method in class com.hazelcast.console.ConsoleApp
 
handleInstances(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleIterator(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleListAdd(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleListAddMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleListContains(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleListRemove(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleListSet(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapDelete(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapEntries() - Method in class com.hazelcast.console.ConsoleApp
 
handleMapEvict(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapGet(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapGetAsync(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapGetMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapGetMapEntry(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapKeys() - Method in class com.hazelcast.console.ConsoleApp
 
handleMapLocalKeys() - Method in class com.hazelcast.console.ConsoleApp
 
handleMapLocalSize() - Method in class com.hazelcast.console.ConsoleApp
 
handleMapLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapPut(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapPutAsync(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapPutIfAbsent(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapPutMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapRemove(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapRemoveMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapReplace(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapTryLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapUnlock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapValues() - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapEntries() - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapGet(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapKeys() - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapPut(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapRemove(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapTryLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapUnlock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapValues() - Method in class com.hazelcast.console.ConsoleApp
 
handlePartitions(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQCapacity(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQOffer(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQOfferMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQPeek(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQPoll(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQPollMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQTake(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handlerAdded() - Method in class com.hazelcast.nio.ascii.TextDecoder
 
handlerAdded() - Method in class com.hazelcast.nio.ascii.TextEncoder
 
handlerAdded() - Method in class com.hazelcast.nio.tcp.MemberProtocolEncoder
 
handlerAdded() - Method in class com.hazelcast.nio.tcp.PacketDecoder
 
handlerAdded() - Method in class com.hazelcast.nio.tcp.PacketEncoder
 
handlerAdded() - Method in class com.hazelcast.nio.tcp.SingleProtocolDecoder
 
handlerAdded() - Method in class com.hazelcast.nio.tcp.UnifiedProtocolDecoder
 
handlerAdded() - Method in class com.hazelcast.nio.tcp.UnifiedProtocolEncoder
 
handleRemoveListener(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleSetAdd(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleSetAddMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleSetRemove(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleSetRemoveMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleShutdown() - Method in class com.hazelcast.console.ConsoleApp
 
handleSize(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleTopicPublish(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
has(int) - Method in class com.hazelcast.org.snakeyaml.engine.v1.common.CharConstants
 
has(int, String) - Method in class com.hazelcast.org.snakeyaml.engine.v1.common.CharConstants
 
hasActiveInvocation(Operation) - Static method in class com.hazelcast.spi.OperationAccessor
 
hasAllBitsSet(BitSet, Iterable<Integer>) - Static method in class com.hazelcast.util.BitSetUtils
Returns true if all bits at given indexes are set.
hasAtLeastOneBitSet(BitSet, Iterable<Integer>) - Static method in class com.hazelcast.util.BitSetUtils
Returns true if at least one bit on a given position is set.
hasAttribute(String) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
hasAttributeNS(String, String) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
hasAttributes() - Method in class com.hazelcast.config.yaml.ElementAdapter
 
hasChildNodes() - Method in class com.hazelcast.config.yaml.ElementAdapter
 
hasCurrentIndex() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
Method that may be called to verify whether this context has valid index: will return `false` before the first entry of Object context or before first element of Array context; otherwise returns `true`.
hasCurrentName() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
 
hasCurrentName() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
 
hasCurrentName() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
 
hasCurrentName() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
 
hasCurrentToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
hasCurrentToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
 
hasCurrentToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Method for checking whether parser currently points to a token (and data for that token is available).
hasCurrentToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
 
hasDefiniteSize() - Method in enum com.hazelcast.nio.serialization.FieldType
 
hasEventRegistration(String, String) - Method in interface com.hazelcast.spi.EventService
Returns true if a listener is registered with the specified service name and topic.
hasField(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
Checks if there exists a FieldDefinition with the given fieldName.
hasField(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
hasFormat(InputAccessor) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
Convenience method for trying to determine whether input via given accessor is of format type supported by this factory.
hasGenericTypes() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
Method that can be used to find out if the type directly declares generic parameters (for its direct super-class and/or super-interfaces).
hash64() - Method in interface com.hazelcast.nio.serialization.Data
Returns 64-bit hash code for this Data object.
HASH_CODE - Static variable in interface com.hazelcast.jet.core.Partitioner
Partitioner which calls Object.hashCode() and coerces it with the modulo operation into the allowed range of partition IDs.
HASH_MULT - Static variable in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
 
hashCode() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
 
hashCode() - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
 
hashCode() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SerializedString
 
hashCode() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonLocation
 
hashCode() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
 
hashCode() - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.Name
 
hashCode() - Method in class com.hazelcast.com.fasterxml.jackson.core.Version
 
hashCode() - Method in class com.hazelcast.concurrent.lock.ConditionKey
 
hashCode() - Method in class com.hazelcast.concurrent.lock.InternalLockNamespace
 
hashCode() - Method in class com.hazelcast.concurrent.lock.LockWaitNotifyKey
 
hashCode() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreWaitNotifyKey
 
hashCode() - Method in class com.hazelcast.config.AbstractCacheConfig
 
hashCode() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
 
hashCode() - Method in class com.hazelcast.config.AtomicLongConfig
 
hashCode() - Method in class com.hazelcast.config.AtomicReferenceConfig
 
hashCode() - Method in class com.hazelcast.config.CacheConfig
 
hashCode() - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
 
hashCode() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
hashCode() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
hashCode() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
hashCode() - Method in class com.hazelcast.config.CacheSimpleConfig
 
hashCode() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
hashCode() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
hashCode() - Method in class com.hazelcast.config.ClassFilter
 
hashCode() - Method in class com.hazelcast.config.CollectionConfig
 
hashCode() - Method in class com.hazelcast.config.CountDownLatchConfig
 
hashCode() - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
hashCode() - Method in class com.hazelcast.config.DiscoveryConfig
 
hashCode() - Method in class com.hazelcast.config.DurableExecutorConfig
 
hashCode() - Method in class com.hazelcast.config.EntryListenerConfig
 
hashCode() - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
hashCode() - Method in class com.hazelcast.config.EventJournalConfig
 
hashCode() - Method in class com.hazelcast.config.EvictionConfig
 
hashCode() - Method in class com.hazelcast.config.ExecutorConfig
 
hashCode() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
hashCode() - Method in class com.hazelcast.config.GlobalSerializerConfig
 
hashCode() - Method in class com.hazelcast.config.GroupConfig
 
hashCode() - Method in class com.hazelcast.config.HotRestartConfig
 
hashCode() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
 
hashCode() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
hashCode() - Method in class com.hazelcast.config.InterfacesConfig
 
hashCode() - Method in class com.hazelcast.config.ItemListenerConfig
 
hashCode() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
hashCode() - Method in class com.hazelcast.config.ListenerConfig
 
hashCode() - Method in class com.hazelcast.config.LockConfig
 
hashCode() - Method in class com.hazelcast.config.LoginModuleConfig
 
hashCode() - Method in class com.hazelcast.config.MapAttributeConfig
 
hashCode() - Method in class com.hazelcast.config.MapConfig
 
hashCode() - Method in class com.hazelcast.config.MapIndexConfig
 
hashCode() - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
 
hashCode() - Method in class com.hazelcast.config.MapStoreConfig
 
hashCode() - Method in class com.hazelcast.config.matcher.LegacyMatchingPointConfigPatternMatcher
Deprecated.
 
hashCode() - Method in class com.hazelcast.config.matcher.LegacyWildcardConfigPatternMatcher
Deprecated.
 
hashCode() - Method in class com.hazelcast.config.matcher.MatchingPointConfigPatternMatcher
 
hashCode() - Method in class com.hazelcast.config.matcher.RegexConfigPatternMatcher
 
hashCode() - Method in class com.hazelcast.config.matcher.WildcardConfigPatternMatcher
 
hashCode() - Method in class com.hazelcast.config.MaxSizeConfig
 
hashCode() - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
hashCode() - Method in class com.hazelcast.config.MemberGroupConfig
 
hashCode() - Method in class com.hazelcast.config.MergePolicyConfig
 
hashCode() - Method in class com.hazelcast.config.MerkleTreeConfig
 
hashCode() - Method in class com.hazelcast.config.MulticastConfig
 
hashCode() - Method in class com.hazelcast.config.MultiMapConfig
 
hashCode() - Method in class com.hazelcast.config.NativeMemoryConfig
 
hashCode() - Method in class com.hazelcast.config.NearCacheConfig
 
hashCode() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
hashCode() - Method in class com.hazelcast.config.PartitionGroupConfig
 
hashCode() - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
hashCode() - Method in class com.hazelcast.config.PermissionConfig
 
hashCode() - Method in class com.hazelcast.config.PermissionPolicyConfig
 
hashCode() - Method in class com.hazelcast.config.PNCounterConfig
 
hashCode() - Method in class com.hazelcast.config.PredicateConfig
 
hashCode() - Method in class com.hazelcast.config.QueryCacheConfig
 
hashCode() - Method in class com.hazelcast.config.QueueConfig
 
hashCode() - Method in class com.hazelcast.config.QueueStoreConfig
 
hashCode() - Method in class com.hazelcast.config.ReliableTopicConfig
 
hashCode() - Method in class com.hazelcast.config.ReplicatedMapConfig
 
hashCode() - Method in class com.hazelcast.config.RingbufferConfig
 
hashCode() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
hashCode() - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
hashCode() - Method in class com.hazelcast.config.SecurityConfig
 
hashCode() - Method in class com.hazelcast.config.SemaphoreConfig
 
hashCode() - Method in class com.hazelcast.config.SerializationConfig
 
hashCode() - Method in class com.hazelcast.config.SerializerConfig
 
hashCode() - Method in class com.hazelcast.config.ServiceConfig
 
hashCode() - Method in class com.hazelcast.config.ServicesConfig
 
hashCode() - Method in class com.hazelcast.config.SocketInterceptorConfig
 
hashCode() - Method in class com.hazelcast.config.SSLConfig
 
hashCode() - Method in class com.hazelcast.config.TcpIpConfig
 
hashCode() - Method in class com.hazelcast.config.TopicConfig
 
hashCode() - Method in class com.hazelcast.config.WanConsumerConfig
 
hashCode() - Method in class com.hazelcast.config.WanPublisherConfig
 
hashCode() - Method in class com.hazelcast.config.WanReplicationConfig
 
hashCode() - Method in class com.hazelcast.config.WanReplicationRef
 
hashCode() - Method in class com.hazelcast.config.WanSyncConfig
 
hashCode() - Method in class com.hazelcast.core.HazelcastJsonValue
 
hashCode() - Method in class com.hazelcast.core.LifecycleEvent
 
hashCode() - Method in class com.hazelcast.core.PartitionAwareKey
 
hashCode() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
hashCode() - Method in class com.hazelcast.instance.AbstractMember
 
hashCode() - Method in class com.hazelcast.instance.EndpointQualifier
 
hashCode() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
hashCode() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
hashCode() - Method in class com.hazelcast.jet.accumulator.DoubleAccumulator
 
hashCode() - Method in class com.hazelcast.jet.accumulator.LinTrendAccumulator
 
hashCode() - Method in class com.hazelcast.jet.accumulator.LongAccumulator
 
hashCode() - Method in class com.hazelcast.jet.accumulator.LongDoubleAccumulator
 
hashCode() - Method in class com.hazelcast.jet.accumulator.LongLongAccumulator
 
hashCode() - Method in class com.hazelcast.jet.accumulator.MutableReference
 
hashCode() - Method in class com.hazelcast.jet.config.JobConfig
 
hashCode() - Method in class com.hazelcast.jet.config.ResourceConfig
 
hashCode() - Method in class com.hazelcast.jet.core.BroadcastKey
 
hashCode() - Method in class com.hazelcast.jet.core.Edge
 
hashCode() - Method in class com.hazelcast.jet.core.metrics.JobMetrics
 
hashCode() - Method in class com.hazelcast.jet.core.metrics.Measurement
 
hashCode() - Method in class com.hazelcast.jet.core.Watermark
 
hashCode() - Method in class com.hazelcast.jet.datamodel.ItemsByTag
 
hashCode() - Method in class com.hazelcast.jet.datamodel.KeyedWindowResult
 
hashCode() - Method in class com.hazelcast.jet.datamodel.Tag
 
hashCode() - Method in class com.hazelcast.jet.datamodel.TimestampedItem
 
hashCode() - Method in class com.hazelcast.jet.datamodel.Tuple2
 
hashCode() - Method in class com.hazelcast.jet.datamodel.Tuple3
 
hashCode() - Method in class com.hazelcast.jet.datamodel.Tuple4
 
hashCode() - Method in class com.hazelcast.jet.datamodel.Tuple5
 
hashCode() - Method in class com.hazelcast.jet.datamodel.WindowResult
 
hashCode() - Method in class com.hazelcast.jet.pipeline.test.SimpleEvent
 
hashCode() - Method in class com.hazelcast.map.eviction.LFUEvictionPolicy
 
hashCode() - Method in class com.hazelcast.map.eviction.LRUEvictionPolicy
 
hashCode() - Method in class com.hazelcast.map.eviction.RandomEvictionPolicy
 
hashCode() - Method in class com.hazelcast.memory.MemorySize
 
hashCode() - Method in class com.hazelcast.nio.Address
 
hashCode() - Method in class com.hazelcast.nio.Packet
 
hashCode() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
hashCode() - Method in class com.hazelcast.org.snakeyaml.engine.v1.common.Anchor
 
hashCode() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.Event
 
hashCode() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.Node
 
hashCode() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.Tag
 
hashCode() - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
hashCode() - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
hashCode() - Method in class com.hazelcast.query.PartitionPredicate
 
hashCode() - Method in class com.hazelcast.query.SqlPredicate
 
hashCode() - Method in class com.hazelcast.query.TruePredicate
 
hashCode() - Method in class com.hazelcast.security.AbstractCredentials
 
hashCode() - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
hashCode() - Method in class com.hazelcast.security.permission.AllPermissions
 
hashCode() - Method in class com.hazelcast.security.permission.ClusterPermission
 
hashCode() - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
 
hashCode() - Method in class com.hazelcast.security.permission.InstancePermission
 
hashCode() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
hashCode() - Method in class com.hazelcast.spi.AbstractWaitNotifyKey
 
hashCode() - Method in class com.hazelcast.spi.DefaultObjectNamespace
Deprecated.
 
hashCode() - Method in class com.hazelcast.spi.PartitionMigrationEvent
 
hashCode() - Method in class com.hazelcast.util.collection.IntHashSet
 
hashCode() - Method in class com.hazelcast.util.collection.LongHashSet
hashCode() - Method in class com.hazelcast.util.collection.OAHashSet
 
hashCode() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap.SimpleEntry
 
hashCode(Object...) - Static method in class com.hazelcast.util.HashUtil
Hash code for multiple objects using Arrays.hashCode(Object[]).
hashCode() - Method in class com.hazelcast.util.ItemCounter
 
hashCode() - Method in class com.hazelcast.util.MutableLong
 
hashCode() - Method in class com.hazelcast.util.SampleableConcurrentHashMap.SamplingEntry
 
hashCode() - Method in class com.hazelcast.util.scheduler.ScheduledEntry
 
hashCode() - Method in class com.hazelcast.version.MemberVersion
 
hashCode() - Method in class com.hazelcast.version.Version
 
Hashing - Class in com.hazelcast.util.collection
Hashcode functions for classes in this package.
hashJoin(BatchStage<T1_IN>, JoinClause<K, ? super T, ? super T1_IN, ? extends T1>, BiFunctionEx<T, T1, R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
 
hashJoin(BatchStage<T1_IN>, JoinClause<K, ? super T, ? super T1_IN, ? extends T1>, BiFunctionEx<T, T1, R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
Attaches to both this and the supplied stage a hash-joining stage and returns it.
hashJoin(BatchStage<T1_IN>, JoinClause<K, ? super T, ? super T1_IN, ? extends T1>, BiFunctionEx<T, T1, R>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
 
hashJoin2(BatchStage<T1_IN>, JoinClause<K1, ? super T, ? super T1_IN, ? extends T1>, BatchStage<T2_IN>, JoinClause<K2, ? super T, ? super T2_IN, ? extends T2>, TriFunction<T, T1, T2, R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
 
hashJoin2(BatchStage<T1_IN>, JoinClause<K1, ? super T, ? super T1_IN, ? extends T1>, BatchStage<T2_IN>, JoinClause<K2, ? super T, ? super T2_IN, ? extends T2>, TriFunction<T, T1, T2, R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
Attaches to this and the two supplied stages a hash-joining stage and returns it.
hashJoin2(BatchStage<T1_IN>, JoinClause<K1, ? super T, ? super T1_IN, ? extends T1>, BatchStage<T2_IN>, JoinClause<K2, ? super T, ? super T2_IN, ? extends T2>, TriFunction<T, T1, T2, R>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
 
hashJoinBuilder() - Method in interface com.hazelcast.jet.pipeline.BatchStage
 
hashJoinBuilder() - Method in interface com.hazelcast.jet.pipeline.GeneralStage
Returns a fluent API builder object to construct a hash join operation with any number of contributing stages.
HashJoinBuilder<T0> - Class in com.hazelcast.jet.pipeline
Offers a step-by-step fluent API to build a hash-join pipeline stage.
hashJoinBuilder() - Method in interface com.hazelcast.jet.pipeline.StreamStage
 
hashSeed() - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
 
hashSeed() - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
 
hashToIndex(int, int) - Static method in class com.hazelcast.util.HashUtil
A function that calculates the index (e.g.
HashUtil - Class in com.hazelcast.util
Utility methods related to hash tables.
hasJSONFormat(InputAccessor) - Static method in class com.hazelcast.com.fasterxml.jackson.core.json.ByteSourceJsonBootstrapper
Current implementation is not as thorough as other functionality (ByteSourceJsonBootstrapper); supports UTF-8, for example.
hasJSONFormat(InputAccessor) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
Helper method that can be called to determine if content accessed using given accessor seems to be JSON content.
hasListenerConfiguration() - Method in class com.hazelcast.config.AbstractCacheConfig
 
hasLocalSharing() - Method in class com.hazelcast.jet.pipeline.ContextFactory
Returns the hasLocalSharing flag.
hasLock() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
hasMatch() - Method in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatMatcher
Accessor to use to see if any formats matched well enough with the input data.
hasMember(Member) - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
hasMember(Member) - Method in interface com.hazelcast.partition.membergroup.MemberGroup
 
hasMember(Member) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
hasMoreBytes() - Method in interface com.hazelcast.com.fasterxml.jackson.core.format.InputAccessor
Method to call to check if more input is available.
hasMoreBytes() - Method in class com.hazelcast.com.fasterxml.jackson.core.format.InputAccessor.Std
 
hasNext() - Method in class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
Called to request if at least one more key-value pair is available from this data source.
hasNext() - Method in class com.hazelcast.org.snakeyaml.engine.v1.composer.Composer
Checks if further documents are available.
hasNext() - Method in class com.hazelcast.org.snakeyaml.engine.v1.parser.ParserImpl
 
hasNext() - Method in class com.hazelcast.org.snakeyaml.engine.v1.scanner.ScannerImpl
 
hasNext() - Method in class com.hazelcast.spi.merge.RingbufferMergeDataReadOnlyIterator
 
hasNext() - Method in class com.hazelcast.util.collection.IntIterator
 
hasNext() - Method in class com.hazelcast.util.collection.LongIterator
 
hasNo(int) - Method in class com.hazelcast.org.snakeyaml.engine.v1.common.CharConstants
 
hasNo(int, String) - Method in class com.hazelcast.org.snakeyaml.engine.v1.common.CharConstants
 
hasOnGoingMigration() - Method in interface com.hazelcast.spi.partition.IPartitionService
Checks if there are any cluster-wide migrations.
hasOnGoingMigrationLocal() - Method in interface com.hazelcast.spi.partition.IPartitionService
Checks if there are any local migrations.
hasOrderedAsyncResponses() - Method in class com.hazelcast.jet.pipeline.ContextFactory
Tells whether the async responses are ordered, see ContextFactory.withUnorderedAsyncResponses().
hasPartitionHash() - Method in interface com.hazelcast.nio.serialization.Data
Returns true if Data has partition hash, false otherwise.
hasPathSegment() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
Method that may be called to check if this context is either: Object, with at least one entry written (partially or completely) Array, with at least one entry written (partially or completely) and if so, return `true`; otherwise return `false`.
hasRawClass(Class<?>) - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
 
hasSignalKey(ConditionKey) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
hasTextAsCharacters() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
Method that can be used to check whether textual contents can be efficiently accessed using TextBuffer.getTextBuffer().
hasTextCharacters() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
 
hasTextCharacters() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
hasTextCharacters() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
 
hasTextCharacters() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
hasTextCharacters() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Method that can be used to determine whether calling of JsonParser.getTextCharacters() would be the most efficient way to access textual content for the event parser currently points to.
hasTextCharacters() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
 
hasToken(JsonToken) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
hasToken(JsonToken) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
 
hasToken(JsonToken) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Method that is functionally equivalent to: return currentToken() == t but may be more efficiently implemented.
hasToken(JsonToken) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
 
hasTokenId(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
hasTokenId(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
 
hasTokenId(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Method that is functionally equivalent to: return currentTokenId() == id but may be more efficiently implemented.
hasTokenId(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
 
hasUnfinishedItem() - Method in interface com.hazelcast.jet.core.Outbox
Returns true if this outbox has an unfinished item and the same item must be offered again.
hasUnfinishedItem() - Method in class com.hazelcast.jet.core.test.TestOutbox
 
Hazelcast - Class in com.hazelcast.core
Factory for HazelcastInstance's, a node in a cluster.
HAZELCAST_ARRAY - Static variable in class com.hazelcast.nio.ClassLoaderUtil
 
HAZELCAST_BASE_PACKAGE - Static variable in class com.hazelcast.nio.ClassLoaderUtil
 
HAZELCAST_CLOCK_IMPL - Static variable in class com.hazelcast.util.ClockProperties
The implementation of Clock.ClockImpl to use.
HAZELCAST_CLOCK_OFFSET - Static variable in class com.hazelcast.util.ClockProperties
Clock offset property in milliseconds.
HAZELCAST_CONFIG_LOCATION - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
Hazelcast config location property
HAZELCAST_INSTANCE_ITSELF - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
Hazelcast instance itself property
HAZELCAST_INSTANCE_NAME - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
Hazelcast instance name property
HAZELCAST_INTERNAL_OVERRIDE_ENTERPRISE - Static variable in class com.hazelcast.instance.BuildInfoProvider
 
HAZELCAST_INTERNAL_OVERRIDE_VERSION - Static variable in class com.hazelcast.instance.BuildInfoProvider
 
HAZELCAST_OSGI_GROUPING_DISABLED - Static variable in interface com.hazelcast.osgi.HazelcastOSGiService
System property for disabling the behaviour that gives different group name to each Hazelcast bundle.
HAZELCAST_OSGI_JSR223_DISABLED - Static variable in interface com.hazelcast.osgi.HazelcastOSGiService
System property for disabling the JSR-223 script engine scan by the Hazelcast OSGI service.
HAZELCAST_OSGI_REGISTER_DISABLED - Static variable in interface com.hazelcast.osgi.HazelcastOSGiService
System property for disabling the behaviour that registers created Hazelcast instances as OSGI service.
HAZELCAST_OSGI_START - Static variable in interface com.hazelcast.osgi.HazelcastOSGiService
System property for starting a default Hazelcast instance per Hazelcast OSGI bundle.
HazelcastCacheManager - Interface in com.hazelcast.cache
Contract point of Hazelcast cache manager implementations (client + server) based on CacheManager.
HazelcastCachingProvider - Class in com.hazelcast.cache
Hazelcast implementation of JCache CachingProvider.
HazelcastCachingProvider() - Constructor for class com.hazelcast.cache.HazelcastCachingProvider
 
HazelcastException - Exception in com.hazelcast.core
Base Hazelcast exception.
HazelcastException() - Constructor for exception com.hazelcast.core.HazelcastException
 
HazelcastException(String) - Constructor for exception com.hazelcast.core.HazelcastException
 
HazelcastException(String, Throwable) - Constructor for exception com.hazelcast.core.HazelcastException
 
HazelcastException(Throwable) - Constructor for exception com.hazelcast.core.HazelcastException
 
HazelcastExpiryPolicy - Class in com.hazelcast.cache
Hazelcast provides overloads of the typical cache operations with a custom ExpiryPolicy parameter.
This class provides a custom implementation of an ExpiryPolicy to react on all three types of policies: Create Access Update
HazelcastExpiryPolicy() - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
Default constructor to serialize/deserialize
HazelcastExpiryPolicy(long, long, long) - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
Constructs an expiry policy with provided values for creation, access and update in milliseconds.
HazelcastExpiryPolicy(long, long, long, TimeUnit) - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
Constructs an expiry policy with provided values for creation, access and update as well as a TimeUnit to convert those values to internally used time unites.
HazelcastExpiryPolicy(ExpiryPolicy) - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
Copy Constructor for an already existing ExpiryPolicy.
HazelcastExpiryPolicy(Duration, Duration, Duration) - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
Constructs an expiry policy with provided values for creation, access and update by providing instances of the Duration class.
HazelcastInstance - Interface in com.hazelcast.core
Hazelcast instance.
hazelcastInstance - Variable in class com.hazelcast.instance.Node
 
HazelcastInstanceAware - Interface in com.hazelcast.core
Used to get HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService.
HazelcastInstanceCacheManager - Class in com.hazelcast.instance
Hazelcast ICacheManager implementation accessible via HazelcastInstance that provides access to JSR-107 (JCache) caches configured on the cluster via Hazelcast API.
HazelcastInstanceCacheManager(HazelcastInstanceImpl) - Constructor for class com.hazelcast.instance.HazelcastInstanceCacheManager
 
HazelcastInstanceFactory - Class in com.hazelcast.instance
Central manager for all Hazelcast members of the JVM.
HazelcastInstanceImpl - Class in com.hazelcast.instance
 
HazelcastInstanceImpl(String, Config, NodeContext) - Constructor for class com.hazelcast.instance.HazelcastInstanceImpl
 
HazelcastInstanceNotActiveException - Exception in com.hazelcast.core
Thrown when HazelcastInstance is not active during an invocation.
HazelcastInstanceNotActiveException() - Constructor for exception com.hazelcast.core.HazelcastInstanceNotActiveException
 
HazelcastInstanceNotActiveException(String) - Constructor for exception com.hazelcast.core.HazelcastInstanceNotActiveException
 
HazelcastInstanceProxy - Class in com.hazelcast.instance
A proxy around the actual HazelcastInstanceImpl.
HazelcastInstanceProxy(HazelcastInstanceImpl) - Constructor for class com.hazelcast.instance.HazelcastInstanceProxy
 
HazelcastJsonValue - Class in com.hazelcast.core
HazelcastJsonValue is a wrapper for Json formatted strings.
HazelcastJsonValue(String) - Constructor for class com.hazelcast.core.HazelcastJsonValue
Creates a HazelcastJsonValue from given string.
HazelcastManagedContext - Class in com.hazelcast.instance
 
HazelcastManagedContext(HazelcastInstanceImpl, ManagedContext) - Constructor for class com.hazelcast.instance.HazelcastManagedContext
 
HazelcastManagedThread - Class in com.hazelcast.util.executor
Base class for all Hazelcast threads to manage them from a single point.
HazelcastManagedThread() - Constructor for class com.hazelcast.util.executor.HazelcastManagedThread
 
HazelcastManagedThread(Runnable) - Constructor for class com.hazelcast.util.executor.HazelcastManagedThread
 
HazelcastManagedThread(String) - Constructor for class com.hazelcast.util.executor.HazelcastManagedThread
 
HazelcastManagedThread(Runnable, String) - Constructor for class com.hazelcast.util.executor.HazelcastManagedThread
 
HazelcastOSGiInstance - Interface in com.hazelcast.osgi
Contract point for HazelcastInstance implementations based on OSGi service.
HazelcastOSGiService - Interface in com.hazelcast.osgi
Contract point for Hazelcast services on top of OSGI.
HazelcastOverloadException - Exception in com.hazelcast.core
A HazelcastException that is thrown when the system won't handle more load due to an overload.
HazelcastOverloadException(String) - Constructor for exception com.hazelcast.core.HazelcastOverloadException
 
HazelcastOverloadException(String, Throwable) - Constructor for exception com.hazelcast.core.HazelcastOverloadException
 
HazelcastProperties - Class in com.hazelcast.spi.properties
Container for configured Hazelcast properties (HazelcastProperty).
HazelcastProperties(Config) - Constructor for class com.hazelcast.spi.properties.HazelcastProperties
Creates a container with configured Hazelcast properties.
HazelcastProperties(Properties) - Constructor for class com.hazelcast.spi.properties.HazelcastProperties
Creates a container with configured Hazelcast properties.
HazelcastProperty - Class in com.hazelcast.spi.properties
Interface for Hazelcast Member and Client properties.
HazelcastProperty(String) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, boolean) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, Integer) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, Byte) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, Integer, TimeUnit) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, Long, TimeUnit) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, HazelcastProperty) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, String) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, String, TimeUnit) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, String, TimeUnit, HazelcastProperty) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastRuntimePermission - Class in com.hazelcast.security.jsm
Class which holds named Hazelcast permissions for Security Manager checks.
HazelcastRuntimePermission(String) - Constructor for class com.hazelcast.security.jsm.HazelcastRuntimePermission
Creates permission with given name.
HazelcastRuntimePermission(String, String) - Constructor for class com.hazelcast.security.jsm.HazelcastRuntimePermission
Creates permission with given name.
HazelcastSerializationException - Exception in com.hazelcast.nio.serialization
This is an exception thrown when an exception occurs while serializing/deserializing objects.
HazelcastSerializationException(String) - Constructor for exception com.hazelcast.nio.serialization.HazelcastSerializationException
 
HazelcastSerializationException(String, Throwable) - Constructor for exception com.hazelcast.nio.serialization.HazelcastSerializationException
 
HazelcastSerializationException(Throwable) - Constructor for exception com.hazelcast.nio.serialization.HazelcastSerializationException
 
HazelcastXAResource - Interface in com.hazelcast.transaction
Interface for providing Hazelcast as an XAResource
hdfs(JobConf, FunctionEx<? super E, K>, FunctionEx<? super E, V>) - Static method in class com.hazelcast.jet.hadoop.HdfsSinks
Returns a sink that writes to Apache Hadoop HDFS.
hdfs(JobConf) - Static method in class com.hazelcast.jet.hadoop.HdfsSinks
Convenience for HdfsSinks.hdfs(JobConf, FunctionEx, FunctionEx) which expects Map.Entry<K, V> as input and extracts its key and value parts to be written to HDFS.
hdfs(JobConf, BiFunctionEx<K, V, E>) - Static method in class com.hazelcast.jet.hadoop.HdfsSources
Returns a source that reads records from Apache Hadoop HDFS and emits the results of transforming each record (a key-value pair) with the supplied mapping function.
hdfs(JobConf) - Static method in class com.hazelcast.jet.hadoop.HdfsSources
Convenience for HdfsSources.hdfs(JobConf, BiFunctionEx) with Map.Entry as its output type.
HdfsProcessors - Class in com.hazelcast.jet.hadoop
Static utility class with factories of Apache Hadoop HDFS source and sink processors.
HdfsSinks - Class in com.hazelcast.jet.hadoop
Factories of Apache Hadoop HDFS sinks.
HdfsSources - Class in com.hazelcast.jet.hadoop
Contains factory methods for Apache Hadoop HDFS sources.
head() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
Accessor for getting a pointer instance that is identical to this instance except that the last segment has been dropped.
headSequence() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Returns the sequence of the head.
HEALTH_MONITORING_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
HEALTH_MONITORING_LEVEL - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
HEALTH_MONITORING_THRESHOLD_CPU_PERCENTAGE - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
HEALTH_MONITORING_THRESHOLD_MEMORY_PERCENTAGE - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
HEARTBEAT_FAILURE_DETECTOR_TYPE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Heartbeat failure detector type.
HEARTBEAT_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The interval at which member heartbeat messages are sent
HeartbeatAware - Interface in com.hazelcast.quorum
QuorumFunctions which implement this interface will be notified of member heartbeats.
HEX_CHARS - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
 
higherFrameTs(long) - Method in class com.hazelcast.jet.core.SlidingWindowPolicy
Returns the lowest frame timestamp greater than the given timestamp.
HigherHitsCacheMergePolicy - Class in com.hazelcast.cache.merge
Merges cache entries from source to destination cache if the source entry has more hits than the destination one.
HigherHitsCacheMergePolicy() - Constructor for class com.hazelcast.cache.merge.HigherHitsCacheMergePolicy
 
HigherHitsMapMergePolicy - Class in com.hazelcast.map.merge
Merges map entries from source to destination map if the source entry has more hits than the destination one.
HigherHitsMapMergePolicy() - Constructor for class com.hazelcast.map.merge.HigherHitsMapMergePolicy
 
HigherHitsMapMergePolicy - Class in com.hazelcast.replicatedmap.merge
Merges replicated map entries from source to destination map if the source entry has more hits than the destination one.
HigherHitsMergePolicy<V,T extends MergingHits<V>> - Class in com.hazelcast.spi.merge
Merges data structure entries from source to destination data structure if the source entry has more hits than the destination one.
HigherHitsMergePolicy() - Constructor for class com.hazelcast.spi.merge.HigherHitsMergePolicy
 
HostAwareMemberGroupFactory - Class in com.hazelcast.partition.membergroup
 
HostAwareMemberGroupFactory() - Constructor for class com.hazelcast.partition.membergroup.HostAwareMemberGroupFactory
 
HOT_RESTART_BASE_DIR_DEFAULT - Static variable in class com.hazelcast.config.HotRestartPersistenceConfig
Default directory name for the Hot Restart store's home
HOT_RESTART_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
HotRestartClusterDataRecoveryPolicy - Enum in com.hazelcast.config
Specifies the policy that will be respected during hot restart cluster start
hotRestartConfig - Variable in class com.hazelcast.config.AbstractCacheConfig
 
HotRestartConfig - Class in com.hazelcast.config
Configures the Hot Restart Persistence per Hazelcast data structure.
HotRestartConfig() - Constructor for class com.hazelcast.config.HotRestartConfig
 
HotRestartConfig(HotRestartConfig) - Constructor for class com.hazelcast.config.HotRestartConfig
 
HotRestartPersistenceConfig - Class in com.hazelcast.config
Configures the Hot Restart stores.
HotRestartPersistenceConfig() - Constructor for class com.hazelcast.config.HotRestartPersistenceConfig
 
HotRestartService - Interface in com.hazelcast.hotrestart
Service for interacting with Hot Restart.
HotRestartState - Interface in com.hazelcast.monitor
Hot Restart statistics to be used by MemberState implementations.
HTTP_HEALTHCHECK_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
Enable or disable the RestEndpointGroup.HEALTH_CHECK group in RestApiConfig instead.
HyperLogLogMergePolicy - Class in com.hazelcast.spi.merge
Only available for HyperLogLog backed CardinalityEstimator.
HyperLogLogMergePolicy() - Constructor for class com.hazelcast.spi.merge.HyperLogLogMergePolicy
 

I

IAM_SECURITY_CREDENTIALS_URI - Static variable in class com.hazelcast.aws.utility.MetadataUtil
Post-fix URI to fetch IAM role details
IAtomicLong - Interface in com.hazelcast.core
IAtomicLong is a redundant and highly available distributed alternative to the AtomicLong.
IAtomicReference<E> - Interface in com.hazelcast.core
IAtomicReference is a redundant and highly available distributed alternative to the AtomicReference.
IBiFunction<T,U,R> - Interface in com.hazelcast.core
Represents a function that accepts two arguments and produces a result.
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.
ICacheJet<K,V> - Interface in com.hazelcast.jet
A distributed, in-memory implementation of JCache specification.
ICacheManager - Interface in com.hazelcast.core
ICacheManager is the entry point to access JSR-107 (JCache) caches via HazelcastInstance interface.
ICMP_ECHO_FAIL_FAST - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
as of 3.10 this can be configured through IcmpFailureDetectorConfig This will be removed in future versions. Until this is done, if the IcmpFailureDetectorConfig is null we will still fall back to this
ICMP_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
as of 3.10 this can be configured through IcmpFailureDetectorConfig This will be removed in future versions. Until this is done, if the IcmpFailureDetectorConfig is null we will still fall back to this
ICMP_INTERVAL - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
as of 3.10 this can be configured through IcmpFailureDetectorConfig This will be removed in future versions. Until this is done, if the IcmpFailureDetectorConfig is null we will still fall back to this
ICMP_MAX_ATTEMPTS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
as of 3.10 this can be configured through IcmpFailureDetectorConfig This will be removed in future versions. Until this is done, if the IcmpFailureDetectorConfig is null we will still fall back to this
ICMP_PARALLEL_MODE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
as of 3.10 this can be configured through IcmpFailureDetectorConfig This will be removed in future versions. Until this is done, if the IcmpFailureDetectorConfig is null we will still fall back to this
ICMP_TIMEOUT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
as of 3.10 this can be configured through IcmpFailureDetectorConfig This will be removed in future versions. Until this is done, if the IcmpFailureDetectorConfig is null we will still fall back to this
ICMP_TTL - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
as of 3.10 this can be configured through IcmpFailureDetectorConfig This will be removed in future versions. Until this is done, if the IcmpFailureDetectorConfig is null we will still fall back to this
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
 
ICMPHelper - Class in com.hazelcast.util
Helper class that uses JNI to check whether the JVM process has enough permission to create raw-sockets.
ICollection<E> - Interface in com.hazelcast.core
Concurrent, distributed, partitioned, listenable collection.
ICompletableFuture<V> - Interface in com.hazelcast.core
A Future where one can asynchronously listen on completion.
IConcurrentMap<K,V> - Interface in com.hazelcast.util
A ConcurrentMap with applyIfAbsent function.
ICondition - Interface in com.hazelcast.core
Distributed implementation of Condition.
ICountDownLatch - Interface in com.hazelcast.core
ICountDownLatch is a backed-up distributed alternative to the java.util.concurrent.CountDownLatch.
ICredentialsFactory - Interface in com.hazelcast.security
ICredentialsFactory is used to create Credentials objects to be used during node authentication before connection is accepted by the master node.
id() - Method in 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 interface com.hazelcast.cp.CPGroupId
Returns unique id of the CP group.
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 used to represent JsonToken.VALUE_EMBEDDED_OBJECT
ID_END_ARRAY - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.JsonTokenId
Id used to represent JsonToken.END_ARRAY
ID_END_OBJECT - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.JsonTokenId
Id used to represent JsonToken.END_OBJECT
ID_FALSE - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.JsonTokenId
Id used to represent JsonToken.VALUE_FALSE
ID_FIELD_NAME - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.JsonTokenId
Id used to represent JsonToken.FIELD_NAME
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 used to represent JsonToken.VALUE_NULL
ID_NUMBER_FLOAT - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.JsonTokenId
Id used to represent JsonToken.VALUE_NUMBER_FLOAT
ID_NUMBER_INT - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.JsonTokenId
Id used to represent JsonToken.VALUE_NUMBER_INT
ID_START_ARRAY - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.JsonTokenId
Id used to represent JsonToken.START_ARRAY
ID_START_OBJECT - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.JsonTokenId
Id used to represent JsonToken.START_OBJECT
ID_STRING - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.JsonTokenId
Id used to represent JsonToken.VALUE_STRING
ID_TRUE - Static variable in interface com.hazelcast.com.fasterxml.jackson.core.JsonTokenId
Id used to represent JsonToken.VALUE_TRUE
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.jet.function.FunctionEx
identity() - Static method in class com.hazelcast.projection.Projections
Returns a projection that does no transformation.
idFromString(String) - Static method in class com.hazelcast.jet.Util
Parses the jobId formatted with Util.idToString(long).
IdGenerator - Interface in com.hazelcast.core
Deprecated.
The implementation can produce duplicate IDs in case of network split, even with split-brain protection enabled (during short window while split-brain is detected). Use HazelcastInstance.getFlakeIdGenerator(String) for an alternative implementation which does not suffer from this problem.
IdGeneratorImpl - Class in com.hazelcast.concurrent.idgen
Generates blocks with the help of an IAtomicLong.
IdGeneratorImpl(IAtomicLong) - Constructor for class com.hazelcast.concurrent.idgen.IdGeneratorImpl
 
IdGeneratorProxy - Class in com.hazelcast.concurrent.idgen
 
IdGeneratorProxy(IAtomicLong, String, NodeEngine, IdGeneratorService) - Constructor for class com.hazelcast.concurrent.idgen.IdGeneratorProxy
 
IdGeneratorService - Class in com.hazelcast.concurrent.idgen
 
IdGeneratorService(NodeEngine) - Constructor for class com.hazelcast.concurrent.idgen.IdGeneratorService
 
idle(long) - Method in class com.hazelcast.util.concurrent.BackoffIdleStrategy
Perform current idle strategy's step n.
idle(long) - Method in class com.hazelcast.util.concurrent.BusySpinIdleStrategy
 
idle(long) - Method in interface com.hazelcast.util.concurrent.IdleStrategy
Perform current idle strategy's step n.
idle(long) - Method in class com.hazelcast.util.concurrent.NoOpIdleStrategy
 
IdleStrategy - Interface in com.hazelcast.util.concurrent
Idle strategy for use by threads when then they don't have work to do.
idleTimeoutMillis() - Method in class com.hazelcast.jet.core.EventTimePolicy
Returns the amount of time allowed to pass without receiving any events from a partition before marking it as "idle".
idToString(long) - Static method in class com.hazelcast.jet.Util
Converts a long job or execution ID to a string representation.
IExecutorService - Interface in com.hazelcast.core
Distributed implementation of ExecutorService.
IFunction<T,R> - Interface in com.hazelcast.core
Represents a function that accepts one argument and produces a result.
ignore(Throwable) - Static method in class com.hazelcast.util.EmptyStatement
Ignores the given exception.
IGNORE_ALL_EXCEPT_LOG_MEMBER_LEFT - Static variable in class com.hazelcast.util.FutureUtil
Ignores all exceptions but still logs MemberLeftException per future and just tries to finish all of the given ones.
IGNORE_ALL_EXCEPTIONS - Static variable in class com.hazelcast.util.FutureUtil
Ignores all exceptions
IgnoreMergingEntryMapMergePolicy - Class in com.hazelcast.map.merge
Ignores the merging entry while collecting merge-needed entries on merging side.
IgnoreMergingEntryMapMergePolicy() - Constructor for class com.hazelcast.map.merge.IgnoreMergingEntryMapMergePolicy
 
ilike(String, String) - Static method in class com.hazelcast.jet.pipeline.GenericPredicates
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.core
Concurrent, distributed implementation of List.
IListJet<E> - Interface in com.hazelcast.jet
A concurrent, in-memory concurrent list implementation.
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
 
ILock - Interface in com.hazelcast.core
Deprecated.
Please use FencedLock instead. This interface will be removed in Hazelcast 4.0.
ILogger - Interface in com.hazelcast.logging
The Hazelcast logging interface.
IMap<K,V> - Interface in com.hazelcast.core
Concurrent, distributed, observable and queryable map.
iMapContext(String) - Static method in class com.hazelcast.jet.pipeline.ContextFactories
Returns a factory that provides an IMapJet as the context.
IMapEvent - Interface in com.hazelcast.core
Map events common contract.
IMapJet<K,V> - Interface in com.hazelcast.jet
A distributed, in-memory concurrent map implementation.
implementation - Variable in class com.hazelcast.config.ListenerConfig
 
implementation - Variable in class com.hazelcast.config.PredicateConfig
 
implementation - Variable in class com.hazelcast.config.SecurityInterceptorConfig
 
implementsInterfaceWithSameName(Class<?>, Class<?>) - Static method in class com.hazelcast.nio.ClassLoaderUtil
Check whether given class implements an interface with the same name.
ImplicitTuple - Class in com.hazelcast.org.snakeyaml.engine.v1.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.v1.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.TransactionPermission
 
importDocuments(YamlNode) - Method in class com.hazelcast.config.AbstractYamlConfigBuilder
Imports external YAML documents into the provided main YAML document.
in(String, Comparable...) - Static method in class com.hazelcast.jet.pipeline.GenericPredicates
in(Comparable...) - Method in class com.hazelcast.query.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.
inboundHandlers - Variable in class com.hazelcast.nio.tcp.SingleProtocolDecoder
 
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.
inboxSize() - Method in class com.hazelcast.jet.core.test.TestSupport.TestMode
Size limit of the inbox.
inc(T) - Method in class com.hazelcast.util.ItemCounter
Increases the count by on for the given item.
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.
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.
increase(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
 
INCREASE_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
INCREASE_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
IncreaseBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
IncreaseBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.IncreaseBackupOperation
 
IncreaseBackupOperation(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.operations.IncreaseBackupOperation
 
increaseHits() - Method in interface com.hazelcast.monitor.LocalRecordStoreStats
Increases the number of hits of the locally owned entries of this partition.
increaseHits(long) - Method in interface com.hazelcast.monitor.LocalRecordStoreStats
Increases the number of hits of the locally owned entries of this partition.
IncreaseOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
IncreaseOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.IncreaseOperation
 
IncreaseOperation(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.operations.IncreaseOperation
 
increasePermits(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
 
increasePermits(int) - Method in interface com.hazelcast.core.ISemaphore
Increases the number of available permits by the indicated amount.
incrementAndGet() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
incrementAndGet() - Method in interface com.hazelcast.core.IAtomicLong
Atomically increments the current value by one.
incrementAndGet() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Increments by one the current value.
incrementAndGet() - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
 
incrementAndGetAsync() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
incrementAndGetAsync() - Method in interface com.hazelcast.core.IAtomicLong
Atomically increments the current value by one.
incrementEventCount(DistributedServiceWanEventCounters) - Method in interface com.hazelcast.wan.ReplicationEventObject
Increments the count for the related event in the counters
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.GroupProperty
Type of Query Index result copying behavior.
IndexAwarePredicate<K,V> - Interface in com.hazelcast.query
Extends the Predicate interface with the ability to support indexes.
indexOf(String, char, int) - Static method in class com.hazelcast.util.StringUtil
Like a String.indexOf but without MIN_SUPPLEMENTARY_CODE_POINT handling
indexOf(String, char) - Static method in class com.hazelcast.util.StringUtil
Like a String.indexOf but without MIN_SUPPLEMENTARY_CODE_POINT handling
InflatableSet<T> - Class in com.hazelcast.util.collection
Provides fast Set implementation for cases where items are known to not contain duplicates.
InflatableSet.Builder<T> - Class in com.hazelcast.util.collection
Builder for InflatableSet.
info(String) - Method in class com.hazelcast.logging.AbstractLogger
 
info(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
info(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
info(String) - Method in interface com.hazelcast.logging.ILogger
Logs a message at the Level.INFO level.
info(Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a throwable at the Level.INFO level.
info(String, Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a message with an associated throwable at the Level.INFO level.
init(NodeEngine, Properties) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
 
init(NodeEngine, Properties) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
 
init(NodeEngine, Properties) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
init(long) - Method in class com.hazelcast.concurrent.idgen.IdGeneratorImpl
 
init(long) - Method in class com.hazelcast.concurrent.idgen.IdGeneratorProxy
 
init(NodeEngine, Properties) - Method in class com.hazelcast.concurrent.idgen.IdGeneratorService
 
init(NodeEngine, Properties) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
init(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
 
init(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
 
init(NodeEngine, Properties) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
 
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(long) - Method in interface com.hazelcast.core.IdGenerator
Deprecated.
Tries to initialize this IdGenerator instance with the given ID.
init(InitialMembershipEvent) - Method in interface com.hazelcast.core.InitialMembershipListener
Called when this listener is registered.
init(int) - Method in interface com.hazelcast.core.ISemaphore
Tries to initialize this ISemaphore instance with the given permit count
init(HazelcastInstance, Properties, String) - Method in interface com.hazelcast.core.MapLoaderLifecycleSupport
Initializes this MapLoader implementation.
init(NodeEngine, Properties) - Method in class com.hazelcast.crdt.CRDTReplicationMigrationService
 
init(NodeEngine, Properties) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
init(long) - Method in interface com.hazelcast.flakeidgen.FlakeIdGenerator
Deprecated.
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
Callback that injects the Hazelcast's default partitioning strategy into this partitioner so it can be consulted by the Partitioner.getPartition(Object, int) method.
init(Outbox, Processor.Context) - Method in 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() - Method in class com.hazelcast.jet.spring.JetNamespaceHandler
 
init(byte[], int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
init(Properties) - Method in interface com.hazelcast.nio.SocketInterceptor
Initializes socket interceptor with properties which is set by Config.setProperty(String, String)
init(Properties) - Method in 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.nio.tcp.DefaultChannelInitializerProvider
 
init() - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.YamlUnicodeReader
Read-ahead four bytes and check for BOM marks.
init(NodeEngine, Properties) - Method in interface com.hazelcast.spi.ManagedService
Initializes this service.
init(NodeEngineImpl, Set<Operation>) - Method in class com.hazelcast.spi.Offload
Initializes the Offload.
init(Node, WanReplicationConfig, WanPublisherConfig) - Method in interface com.hazelcast.wan.WanReplicationEndpoint
Initializes the endpoint using the given arguments.
INIT_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
INIT_CLUSTER_VERSION - Static variable in class com.hazelcast.spi.properties.GroupProperty
Override cluster version to use while node is not yet member of a cluster.
INIT_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
InitBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
InitBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.InitBackupOperation
 
InitBackupOperation(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.operations.InitBackupOperation
 
initChannel(Channel) - Method in class com.hazelcast.nio.ascii.TextChannelInitializer
 
initChannel(Channel) - Method in class com.hazelcast.nio.tcp.ClientChannelInitializer
 
initChannel(Channel) - Method in class com.hazelcast.nio.tcp.MemberChannelInitializer
 
initChannel(Channel) - Method in class com.hazelcast.nio.tcp.UnifiedChannelInitializer
 
initDefaultMaxSizeForOnHeapMaps(NearCacheConfig) - Static method in class com.hazelcast.config.NearCacheConfigAccessor
 
INITIAL_CAPACITY - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
 
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.GroupProperty
 
INITIAL_WAIT_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
initialize(Object) - Method in interface com.hazelcast.core.ManagedContext
Initialize the given object instance.
initialize(Object) - Method in class com.hazelcast.instance.HazelcastManagedContext
 
initialize(Context<KeyOut, ValueOut>) - Method in interface com.hazelcast.mapreduce.LifecycleMapper
Deprecated.
This method is called before the Mapper.map(Object, Object, Context) method is executed for every value and can be used to initialize the internal state of the mapper or to emit a special value.
initialize(Context<KeyOut, ValueOut>) - Method in class com.hazelcast.mapreduce.LifecycleMapperAdapter
Deprecated.
This method is called before the Mapper.map(Object, Object, Context) method is executed for every value and can be used to initialize the internal state of the mapper or to emit a special value.
initialize() - Method in interface com.hazelcast.spi.InitializingObject
 
initializeDistributedObject(String, String) - Method in interface com.hazelcast.spi.ProxyService
 
InitializingObject - Interface in com.hazelcast.spi
Can be implemented by DistributedObject (proxies) to indicate that they want to be initialized.
InitialMembershipEvent - Class in com.hazelcast.core
An event that is sent when a InitialMembershipListener registers itself on a Cluster.
InitialMembershipEvent(Cluster, Set<Member>) - Constructor for class com.hazelcast.core.InitialMembershipEvent
 
InitialMembershipListener - Interface in com.hazelcast.core
The InitializingMembershipListener is a MembershipListener that first receives a InitialMembershipEvent when it is registered so it immediately knows which members are available.
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.MapReducePermission
 
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.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
 
InitOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
InitOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.InitOperation
 
InitOperation(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.operations.InitOperation
 
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
Similar to NumberInput.inLongRange(char[],int,int,boolean), but with String argument
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.
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.
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
 
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.
insertBefore(Node, Node) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
insertMigrationData(Map<String, SemaphoreContainer>) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
 
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.
inspectOutOfMemoryError(Throwable) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
 
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(HazelcastInstanceImpl) - Method in class com.hazelcast.instance.MemberImpl.Builder
 
INSTANCE - Static variable in class com.hazelcast.map.eviction.LFUEvictionPolicy
LFU eviction policy instance.
INSTANCE - Static variable in class com.hazelcast.map.eviction.LRUEvictionPolicy
LRU eviction policy instance.
INSTANCE - Static variable in class com.hazelcast.map.eviction.RandomEvictionPolicy
Random eviction policy instance.
INSTANCE - Static variable in class com.hazelcast.nio.ascii.AllowingTextProtocolFilter
 
INSTANCE - Static variable in class com.hazelcast.partition.strategy.StringAndPartitionAwarePartitioningStrategy
 
INSTANCE - Static variable in class com.hazelcast.partition.strategy.StringPartitioningStrategy
 
INSTANCE - Static variable in class com.hazelcast.query.TruePredicate
An instance of the TruePredicate.
INSTANCE - Static variable in class com.hazelcast.replicatedmap.merge.HigherHitsMapMergePolicy
Single instance of this class.
INSTANCE - Static variable in class com.hazelcast.replicatedmap.merge.LatestUpdateMapMergePolicy
Single instance of this class.
INSTANCE - Static variable in class com.hazelcast.replicatedmap.merge.PassThroughMergePolicy
Single instance of this class.
INSTANCE - Static variable in class com.hazelcast.replicatedmap.merge.PutIfAbsentMapMergePolicy
Single instance of this class.
INSTANCE_METADATA_URI - Static variable in class com.hazelcast.aws.utility.MetadataUtil
This IP is only accessible inside AWS and is used to fetch metadata of running EC2 Instance.
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<? extends V>) - Static method in class com.hazelcast.jet.pipeline.GenericPredicates
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
 
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.v1.nodes.Tag
 
INT - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.resolver.JsonScalarResolver
 
Int2ObjectHashMap<V> - Class in com.hazelcast.util.collection
Map implementation specialized for int keys using open addressing and linear probing for cache-efficient access.
Int2ObjectHashMap() - Constructor for class com.hazelcast.util.collection.Int2ObjectHashMap
 
Int2ObjectHashMap(int) - Constructor for class com.hazelcast.util.collection.Int2ObjectHashMap
 
Int2ObjectHashMap(int, double) - Constructor for class com.hazelcast.util.collection.Int2ObjectHashMap
Construct a new map allowing a configuration for initial capacity and load factor.
Int2ObjectHashMap.KeyIterator - Class in com.hazelcast.util.collection
Adds an unboxed next() method to the standard Iterator interface.
Int2ObjectHashMap.KeySet - Class in com.hazelcast.util.collection
Adds non-boxing methods to the standard Set interface.
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_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
INT_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
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_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
Integer size in bytes
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
 
integerAvg() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to calculate the integer average of all supplied values.
This aggregation is similar to:
integerMax() - Static method in class com.hazelcast.aggregation.Aggregators
 
integerMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
integerMax() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to find the integer maximum of all supplied values.
This aggregation is similar to:
integerMin() - Static method in class com.hazelcast.aggregation.Aggregators
 
integerMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
integerMin() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to find the integer minimum of all supplied values.
This aggregation is similar to:
integerSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
integerSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
integerSum() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to calculate the integer sum of all supplied values.
This aggregation is similar to:
interceptAfter(Credentials, String, String, String) - Method in interface com.hazelcast.security.SecurityContext
intercepts a request after process if any SecurityInterceptor configured Any exception thrown during interception will be ignored
interceptBefore(Credentials, String, String, String, Object[]) - Method in interface com.hazelcast.security.SecurityContext
intercepts a request before process if any SecurityInterceptor configured
interceptGet(Object) - Method in interface com.hazelcast.map.MapInterceptor
Intercepts the get operation before returning value.
interceptLockOperation() - Method in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
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.
interceptSocket(EndpointQualifier, Socket, boolean) - Method in interface com.hazelcast.nio.IOService
 
interceptSocket(EndpointQualifier, Socket, boolean) - Method in class com.hazelcast.nio.NodeIOService
 
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
 
InternalCompletableFuture<E> - Interface in com.hazelcast.spi
A ICompletableFuture with more functionality like getting the result without needing to deal with checked exceptions.
InternalHotRestartService - Interface in com.hazelcast.hotrestart
Internal service for interacting with hot restart related functionalities (e.g.
InternalListMultiMap<K,V> - Class in com.hazelcast.util.collection
Simplistic implementation of MultiMap.
InternalListMultiMap() - Constructor for class com.hazelcast.util.collection.InternalListMultiMap
 
InternalLockNamespace - Class in com.hazelcast.concurrent.lock
A specialization of ObjectNamespace intended to be used by ILock proxies.
InternalLockNamespace() - Constructor for class com.hazelcast.concurrent.lock.InternalLockNamespace
 
InternalLockNamespace(String) - Constructor for class com.hazelcast.concurrent.lock.InternalLockNamespace
 
InternalSetMultimap<K,V> - Class in com.hazelcast.util.collection
Simplistic implementation of MultiMap.
InternalSetMultimap() - Constructor for class com.hazelcast.util.collection.InternalSetMultimap
 
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.
interruptBackupTask() - Method in class com.hazelcast.hotrestart.NoOpHotRestartService
 
interruptLocalBackupTask() - Method in interface com.hazelcast.hotrestart.HotRestartService
Interrupts the local backup task if one is currently running.
interruptLocalBackupTask() - Method in class com.hazelcast.hotrestart.NoOpHotRestartService
 
intersection(String[], String[]) - Static method in class com.hazelcast.util.StringUtil
Returns intersection of given String arrays.
IntFunction<R> - Interface in com.hazelcast.util.function
Represents a function that accepts an int-valued argument and produces a result.
IntHashSet - Class in com.hazelcast.util.collection
Simple fixed-size int hashset.
IntHashSet(int, int) - Constructor for class com.hazelcast.util.collection.IntHashSet
 
IntIterator - Class in com.hazelcast.util.collection
An iterator for a sequence of primitive integers.
IntIterator(int, int[]) - Constructor for class com.hazelcast.util.collection.IntIterator
Construct an Iterator over an array of primitives ints.
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
InvalidAddressException(String) - Constructor for exception com.hazelcast.util.AddressUtil.InvalidAddressException
 
InvalidAddressException(String, boolean) - Constructor for exception com.hazelcast.util.AddressUtil.InvalidAddressException
 
invalidate() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
InvalidConfigurationException - Exception in com.hazelcast.config
A InvalidConfigurationException is thrown when there is 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.
invertBit(byte, int) - Static method in class com.hazelcast.nio.Bits
Inverts n-th bit of the byte value
invertBit(int, int) - Static method in class com.hazelcast.nio.Bits
Inverts n-th bit of the integer value
INVOCATION_MAX_RETRY_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Maximum number of retries for an invocation.
INVOCATION_RETRY_PAUSE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Pause time between each retry cycle of an invocation in milliseconds.
InvocationBuilder - Class in com.hazelcast.spi
The InvocationBuilder is responsible for building an invocation of an operation and invoking it.
InvocationBuilder(String, Operation, int, Address) - Constructor for class com.hazelcast.spi.InvocationBuilder
Creates an InvocationBuilder
invoke() - Method in class com.hazelcast.spi.InvocationBuilder
 
invokeAll(Collection<? extends Callable<T>>) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
 
invokeAny(Collection<? extends Callable<T>>) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
 
invokeOnAllPartitions(String, OperationFactory) - Method in interface com.hazelcast.spi.OperationService
Invokes a set of operations on each partition.
invokeOnAllPartitionsAsync(String, OperationFactory) - Method in interface com.hazelcast.spi.OperationService
Invokes a set of operations on selected set of all partitions in an async way.
invokeOnPartition(Operation) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
invokeOnPartition(String, Operation, int) - Method in interface com.hazelcast.spi.OperationService
 
invokeOnPartition(Operation) - Method in interface com.hazelcast.spi.OperationService
Executes an operation on a partition.
invokeOnPartitions(String, OperationFactory, Collection<Integer>) - Method in interface com.hazelcast.spi.OperationService
Invokes a set of operations on selected set of partitions.
invokeOnPartitions(String, OperationFactory, int[]) - Method in interface com.hazelcast.spi.OperationService
Invokes a set of operations on selected set of partitions.
invokeOnPartitionsAsync(String, OperationFactory, Collection<Integer>) - Method in interface com.hazelcast.spi.OperationService
Invokes a set of operations on selected set of partitions in an async way.
invokeOnTarget(String, Operation, Address) - Method in interface com.hazelcast.spi.OperationService
 
IO_BALANCER_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The interval in seconds between IOBalancer executions.
IO_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
Name of the io executor.
IO_INPUT_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Controls the number of socket input threads.
IO_OUTPUT_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Controls the number of socket output threads.
IO_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
The number of threads doing socket input and the number of threads doing socket output.
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
 
IOService - Interface in com.hazelcast.nio
 
ioService - Variable in class com.hazelcast.nio.tcp.AbstractChannelInitializer
 
ioService - Variable in class com.hazelcast.nio.tcp.DefaultChannelInitializerProvider
 
IOUtil - Class in com.hazelcast.nio
 
IPartition - Interface in com.hazelcast.spi.partition
Represents a Partition.
IPartitionLostEvent - Class in com.hazelcast.spi.partition
IPartitionLostEvent() - Constructor for class com.hazelcast.spi.partition.IPartitionLostEvent
 
IPartitionLostEvent(int, int, Address) - Constructor for class com.hazelcast.spi.partition.IPartitionLostEvent
 
IPartitionService - Interface in com.hazelcast.spi.partition
An SPI service for accessing partition related information.
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.core
Concurrent, blocking, distributed, observable queue.
is(String) - Method in class com.hazelcast.query.EntryObject
 
is(T, T...) - Method in class com.hazelcast.util.StateMachine
Check if current state is one of given states
IS_LOCKED - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
IS_NULL - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
isAbstract() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
 
isActive() - Method in interface com.hazelcast.nio.IOService
 
isActive() - Method in class com.hazelcast.nio.NodeIOService
 
isActive() - Method in interface com.hazelcast.spi.NodeEngine
Deprecated.
isAlive() - Method in interface com.hazelcast.nio.Connection
Checks if the Connection is alive.
isAlive() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
isAllKeysSupported() - Method in class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
If it is possible to collect all clusterwide available keys for this KeyValueSource implementation then this method returns true.
If true is returned, a call to KeyValueSource.getAllKeys() must return all available keys to execute a preselection of interesting partitions / nodes based on returns keys.
isAllowUnsafe() - Method in class com.hazelcast.config.SerializationConfig
Unsafe, it is not public api of java.
isArchive() - Method in class com.hazelcast.jet.config.ResourceConfig
Whether this entry is an Jar archive or a single resource element.
isArray() - Method in interface com.hazelcast.com.fasterxml.jackson.core.TreeNode
Method that returns true if this node is an Array node, false otherwise.
isArrayByteBase64(byte[]) - Static method in class com.hazelcast.util.Base64
 
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.
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
Returns whether auto scaling is enabled, see JobConfig.setAutoScaling(boolean).
isAvailable(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
 
isBase64(String) - Static method in class com.hazelcast.util.Base64
Tests a string to see if it is valid Base64
isBase64(byte) - Static method in class com.hazelcast.util.Base64
 
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.
isBinary() - Method in enum com.hazelcast.nio.ConnectionType
 
isBitSet(int, int) - Static method in class com.hazelcast.nio.Bits
Returns true if n-th bit of the value is set, false otherwise
isBlacklisted(Address) - Method in interface com.hazelcast.cluster.Joiner
Deprecated.
Checks if an address is blacklisted.
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.
isCancelled() - Method in class com.hazelcast.util.executor.CompletedFuture
 
isCancelled() - Method in class com.hazelcast.util.executor.DelegatingFuture
 
isCanonical() - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.DumpSettings
 
isCheckClassDefErrors() - Method in class com.hazelcast.config.SerializationConfig
Default value is true (enabled).
IScheduledExecutorService - Interface in com.hazelcast.scheduledexecutor
Distributed & durable implementation similar to, but not directly inherited ScheduledExecutorService.
IScheduledFuture<V> - Interface in com.hazelcast.scheduledexecutor
A delayed result-bearing action that can be cancelled.
isClassAvailable(ClassLoader, String) - Static method in class com.hazelcast.nio.ClassLoaderUtil
 
isClassDefined(String) - Static method in class com.hazelcast.nio.ClassLoaderUtil
Indicates whether or not the given class exists
isClient() - Method in interface com.hazelcast.nio.Connection
Checks if it is a client connection.
isClient() - Method in enum com.hazelcast.nio.ConnectionType
 
isClient() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
isClientFailoverSupported() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
isClientFailoverSupported() - Method in interface com.hazelcast.instance.NodeExtension
 
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.core.PartitionService
Checks whether the cluster is in a safe state.
isClusterVersionEqualTo(Version) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
isClusterVersionGreaterOrEqual(Version) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
isClusterVersionGreaterThan(Version) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
isClusterVersionLessOrEqual(Version) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
isClusterVersionLessThan(Version) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
isClusterVersionUnknown() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
isClusterVersionUnknownOrGreaterOrEqual(Version) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
isClusterVersionUnknownOrGreaterThan(Version) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
isClusterVersionUnknownOrLessOrEqual(Version) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
isClusterVersionUnknownOrLessThan(Version) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
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
 
isCommandPrefix(String) - Method in class com.hazelcast.nio.ascii.TextParsers
 
isCommunicateStats() - Method in class com.hazelcast.config.JobTrackerConfig
True if statistics (for example, about processed entries) are transmitted to the job emitter, false otherwise.
isConcrete() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
 
isConfigPresent() - Method in class com.hazelcast.config.AbstractConfigLocator
 
isConnected() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns if this member is connected to the Wan publisher
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.ContextFactory
Returns the isCooperative flag.
isData(byte) - Static method in class com.hazelcast.util.Base64
 
isDefaultNamespace(String) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
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 CP discovery process is completed or not.
isDistributed() - Method in class com.hazelcast.jet.core.Edge
Says whether this edge is distributed.
isDone() - Method in enum com.hazelcast.hotrestart.BackupTaskState
Returns true if the backup task completed (successfully or with failure)
isDone() - Method in class com.hazelcast.util.executor.CompletedFuture
 
isDone() - Method in class com.hazelcast.util.executor.DelegatingFuture
 
isDone() - Method in class com.hazelcast.wan.merkletree.ConsistencyCheckResult
 
isDup(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.DupDetector
 
isEarly() - Method in class com.hazelcast.jet.datamodel.WindowResult
Returns whether this is an early window result, to be followed by the final one.
ISemaphore - Interface in com.hazelcast.core
ISemaphore is a fault-tolerant distributed alternative to the Semaphore.
isEmpty(String) - Static method in class com.hazelcast.aws.utility.StringUtil
Checks if a string is empty or not after trim operation
isEmpty() - Method in class com.hazelcast.concurrent.lock.operations.LockReplicationOperation
 
isEmpty() - Method in class com.hazelcast.config.ClassFilter
 
isEmpty() - Method in interface com.hazelcast.core.BaseMap
Returns true if this map contains no entries.
isEmpty() - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of Map.isEmpty().
isEmpty() - Method in class com.hazelcast.jet.core.AppendableTraverser
Returns true, if the next call to AppendableTraverser.next() will return null.
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.map.QueryCache
 
isEmpty() - Method in class com.hazelcast.org.snakeyaml.engine.v1.common.ArrayStack
 
isEmpty() - Method in class com.hazelcast.util.collection.BiInt2ObjectMap
Is map empty or not.
isEmpty() - Method in class com.hazelcast.util.collection.InflatableSet
 
isEmpty() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
 
isEmpty() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.KeySet
 
isEmpty() - Method in class com.hazelcast.util.collection.IntHashSet
 
isEmpty() - Method in class com.hazelcast.util.collection.Long2LongHashMap
 
isEmpty() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
 
isEmpty() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.KeySet
 
isEmpty() - Method in class com.hazelcast.util.collection.LongHashSet
isEmpty() - Method in class com.hazelcast.util.collection.MapDelegatingSet
isEmpty(Collection) - Static method in class com.hazelcast.util.CollectionUtil
Returns true if the given collection is null or empty, otherwise returns false.
isEmpty() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
Returns true if this map contains no key-value mappings.
isEmpty() - Method in class com.hazelcast.util.scheduler.SecondsBasedEntryTaskScheduler
Returns true if there are no scheduled entries.
isEnableCompression() - Method in class com.hazelcast.config.SerializationConfig
Enables compression when default java serialization is used.
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
Checked whether specified parser feature is enabled.
isEnabled(JsonGenerator.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
Check whether specified generator 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(JsonParser.Feature) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Method for checking whether specified JsonParser.Feature is enabled.
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.AdvancedNetworkConfig
 
isEnabled() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
Checks whether the given join mechanism 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.InterfacesConfig
 
isEnabled() - Method in class com.hazelcast.config.ManagementCenterConfig
true if management center is enabled, false if disabled.
isEnabled() - Method in class com.hazelcast.config.MapStoreConfig
Returns if this configuration is enabled
isEnabled() - Method in class com.hazelcast.config.MCMutualAuthConfig
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.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.QueueStoreConfig
 
isEnabled() - Method in class com.hazelcast.config.QuorumConfig
 
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.SSLConfig
Returns if this configuration is enabled.
isEnabled() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
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 when User Code Deployment is enabled
isEnabled() - Method in interface com.hazelcast.hotrestart.InternalHotRestartService
Returns whether hot-restart is enabled or not.
isEnabled() - Method in class com.hazelcast.hotrestart.NoopInternalHotRestartService
 
isEnabled() - Method in class com.hazelcast.jet.config.MetricsConfig
Returns if metrics collection 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.
isEnableDefaults() - Method in class com.hazelcast.config.ServicesConfig
 
isEnableSharedObject() - Method in class com.hazelcast.config.SerializationConfig
Enables shared object when default java serialization is used.
isEnqueueNewEvents() - Method in enum com.hazelcast.config.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.jet.function.PredicateEx
isEqualNode(Node) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
isEquals(Object, Object) - Method in class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
 
isEqualTo(Version) - Method in class com.hazelcast.version.Version
 
ISet<E> - Interface in com.hazelcast.core
Concurrent, distributed implementation of Set
isEvent(Event.ID) - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.Event
 
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
Similar to JsonParser.isExpectedStartArrayToken(), but checks whether stream currently points to JsonToken.START_OBJECT.
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.v1.events.DocumentEndEvent
 
isExplicit() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.DocumentStartEvent
 
isExplicitEnd() - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.DumpSettings
 
isExplicitStart() - Method in class com.hazelcast.org.snakeyaml.engine.v1.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 API calls will fail when result of a replicated operation 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
Checks if the Level.FINE level is enabled.
isFinestEnabled() - Method in class com.hazelcast.logging.AbstractLogger
 
isFinestEnabled() - Method in interface com.hazelcast.logging.ILogger
Checks if the Level.FINEST level is enabled.
isFlagRaised(int) - Method in class com.hazelcast.nio.Packet
Returns true if any of the flags supplied in the argument are set.
isFlow() - Method in class com.hazelcast.org.snakeyaml.engine.v1.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.
isHotBackupEnabled() - Method in class com.hazelcast.hotrestart.NoOpHotRestartService
 
isHotBackupEnabled() - Method in interface com.hazelcast.monitor.HotRestartState
 
isImplicit() - Method in class com.hazelcast.org.snakeyaml.engine.v1.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.QuorumListenerConfig
 
isIndexed(QueryContext) - Method in interface com.hazelcast.query.IndexAwarePredicate
Signals to the query engine that this predicate is able to utilize the indexes available while executing the query in the given query context.
isIndexed(QueryContext) - Method in class com.hazelcast.query.PagingPredicate
Used if inner predicate is instanceof IndexAwarePredicate for checking if indexed.
isIndexed(QueryContext) - Method in class com.hazelcast.query.PredicateBuilder
 
isIndexed(QueryContext) - Method in class com.hazelcast.query.SqlPredicate
 
isInfoEnabled() - Method in class com.hazelcast.logging.AbstractLogger
 
isInfoEnabled() - Method in interface com.hazelcast.logging.ILogger
Checks if the Level.INFO level is enabled.
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
 
isInterface() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
 
isInternalType(Class) - Static method in class com.hazelcast.nio.ClassLoaderUtil
 
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).
isIpAddress(String) - Static method in class com.hazelcast.util.AddressUtil
 
isIPv4() - Method in class com.hazelcast.nio.Address
 
isIPv4() - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
 
isIPv6() - Method in class com.hazelcast.nio.Address
 
isIPv6() - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
 
isJDKCompatible() - Method in class com.hazelcast.config.cp.CPSemaphoreConfig
Returns true if the CP ISemaphore is compatible with its JDK counterpart
isJmxEnabled() - Method in class com.hazelcast.jet.config.MetricsConfig
Returns whether metrics will be exposed through JMX MBeans.
isJoinAllowed() - Method in enum com.hazelcast.cluster.ClusterState
Returns true, if joining of a new member is allowed in this state.
isJson() - Method in interface com.hazelcast.nio.serialization.Data
Returns true if this Data is created from a HazelcastJsonValue object, false otherwise
isKnownServiceNamespace(ServiceNamespace) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
isKnownServiceNamespace(ServiceNamespace) - Method in interface com.hazelcast.spi.FragmentedMigrationAwareService
Returns true if namespace is known by this service, false otherwise
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 class com.hazelcast.config.Config
Returns true if this member is a lite member.
isLiteMember() - Method in interface com.hazelcast.core.Member
Returns true if this member is a lite member.
isLiteMember() - Method in class com.hazelcast.instance.AbstractMember
 
isLiteMember() - Method in class com.hazelcast.instance.Node
 
isLive() - Method in interface com.hazelcast.nio.NetworkingService
Flag indicating the liveness status of the Network
isLive() - Method in class com.hazelcast.nio.tcp.TcpIpNetworkingService
 
isLive() - Method in class com.hazelcast.util.executor.StripedExecutor
Checks if this StripedExecutor is alive (so not shut down).
isLocal() - Method in interface com.hazelcast.concurrent.lock.LockResource
 
isLocal() - Method in class com.hazelcast.config.EntryListenerConfig
 
isLocal() - Method in class com.hazelcast.config.ListenerConfig
 
isLocal() - Method in class com.hazelcast.config.QuorumListenerConfig
 
isLocal() - Method in interface com.hazelcast.spi.partition.IPartition
Checks if the partition is local.
isLocalMemberSafe() - Method in interface com.hazelcast.core.PartitionService
Checks whether local member is in safe state.
isLocalOnly() - Method in interface com.hazelcast.spi.EventRegistration
Returns true if this registration is for locally fired events only.
isLocked() - Method in class com.hazelcast.concurrent.lock.LockProxy
 
isLocked(NodeEngine, Data) - Method in class com.hazelcast.concurrent.lock.LockProxySupport
 
isLocked() - Method in interface com.hazelcast.concurrent.lock.LockResource
 
isLocked(Data) - Method in interface com.hazelcast.concurrent.lock.LockStore
Check if a key is locked by any caller and thread ID.
isLocked(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
isLocked(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
 
isLocked() - Method in interface com.hazelcast.core.ILock
Deprecated.
Returns whether this lock is locked or not.
isLocked(K) - Method in interface com.hazelcast.core.IMap
Checks the lock for the specified key.
isLocked(K) - Method in interface com.hazelcast.core.MultiMap
Checks the lock for the specified key.
isLocked() - Method in interface com.hazelcast.cp.lock.FencedLock
Returns whether this lock is locked or not.
isLocked() - Method in interface com.hazelcast.map.LockAware
 
isLockedBy(String, long) - Method in interface com.hazelcast.concurrent.lock.LockResource
 
isLockedBy(Data, String, long) - Method in interface com.hazelcast.concurrent.lock.LockStore
Check if a key is locked by a specific caller and thread ID.
isLockedBy(Data, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
isLockedBy(Data, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
 
isLockedByCurrentThread() - Method in class com.hazelcast.concurrent.lock.LockProxy
 
isLockedByCurrentThread(NodeEngine, Data) - Method in class com.hazelcast.concurrent.lock.LockProxySupport
 
isLockedByCurrentThread() - Method in interface com.hazelcast.core.ILock
Deprecated.
Returns whether this lock is locked by current thread or not.
isLockedByCurrentThread() - Method in interface com.hazelcast.cp.lock.FencedLock
Returns whether the lock is held by the current thread or not.
IsLockedOperation - Class in com.hazelcast.concurrent.lock.operations
 
IsLockedOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.IsLockedOperation
 
IsLockedOperation(ObjectNamespace, Data) - Constructor for class com.hazelcast.concurrent.lock.operations.IsLockedOperation
 
IsLockedOperation(ObjectNamespace, Data, long) - Constructor for class com.hazelcast.concurrent.lock.operations.IsLockedOperation
 
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
Returns if lossless restart is enabled, see InstanceConfig.setLosslessRestartEnabled(boolean).
isLossTolerant() - Method in interface com.hazelcast.topic.ReliableMessageListener
Checks if this ReliableMessageListener is able to deal with message loss.
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
 
isMaster() - Method in class com.hazelcast.instance.Node
 
isMemberExcluded(Address, String) - Method in interface com.hazelcast.hotrestart.InternalHotRestartService
Checks if the given member has been excluded during the cluster start or not.
isMemberExcluded(Address, String) - Method in class com.hazelcast.hotrestart.NoopInternalHotRestartService
 
isMemberSafe(Member) - Method in interface com.hazelcast.core.PartitionService
Checks whether the given member is in safe state.
isMemberStateSafe() - Method in interface com.hazelcast.monitor.MemberPartitionState
Returns whether member is safe for shutdown.
isMemberStateSafe() - Method in interface com.hazelcast.spi.partition.IPartitionService
Queries and returns if this member in a safe state or not.
isMerged() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.MappingNode
 
isMetricsEnabled() - Method in class com.hazelcast.jet.config.JobConfig
Returns if metrics collection is enabled for the job.
isMetricsForDataStructuresEnabled() - Method in class com.hazelcast.jet.config.MetricsConfig
Returns if statistics for data structures are added to metrics.
isMigrating() - Method in interface com.hazelcast.spi.partition.IPartition
Checks if there currently is a migration going on in this partition.
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.
isMultiLineFlow() - Method in class com.hazelcast.org.snakeyaml.engine.v1.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.
isNodeVersionCompatibleWith(Version) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
isNodeVersionCompatibleWith(Version) - Method in interface com.hazelcast.instance.NodeExtension
Check if this node's codebase version is compatible with given cluster version.
isNot(String) - Method in class com.hazelcast.query.EntryObject
 
isNotEmpty(String) - Static method in class com.hazelcast.aws.utility.StringUtil
Checks if a string is empty or not after trim operation
isNotEmpty(Collection) - Static method in class com.hazelcast.util.CollectionUtil
Returns true if the given collection is not null and not empty, otherwise returns false.
isNotNull() - Method in class com.hazelcast.query.EntryObject
 
isNotNull(E, String) - Static method in class com.hazelcast.util.Preconditions
Tests if a string is not null.
isNull() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceContainer
 
isNull() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
isNull() - Method in interface com.hazelcast.core.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 class com.hazelcast.query.EntryObject
 
isNullAsync() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
isNullAsync() - Method in interface com.hazelcast.core.IAtomicReference
Checks if the stored reference is null.
IsNullOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
IsNullOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.IsNullOperation
 
IsNullOperation(String) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.IsNullOperation
 
isNullOrEmpty(Map) - Static method in class com.hazelcast.util.MapUtil
Test the given map and return true if the map is null or empty.
isNullOrEmpty(String) - Static method in class com.hazelcast.util.StringUtil
Checks if a string is empty or not.
isNullOrEmptyAfterTrim(String) - Static method in class com.hazelcast.util.StringUtil
Checks if a string is empty or not after trim operation
isNumeric() - Method in enum com.hazelcast.com.fasterxml.jackson.core.JsonToken
 
ISO_8859_1 - Static variable in class com.hazelcast.nio.Bits
A reusable instance of the ISO Latin-1 charset
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.
isOptimizeQueries() - Method in class com.hazelcast.config.MapConfig
Deprecated.
isOrdered() - Method in class com.hazelcast.config.MapIndexConfig
Checks if the index should be ordered.
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)
isOwnerOrBackup(Address) - Method in interface com.hazelcast.spi.partition.IPartition
Checks if given address is owner of primary or backup of this partition.
isPad(byte) - Static method in class com.hazelcast.util.Base64
 
isParallelMode() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
isPartitionOwner(int) - Method in interface com.hazelcast.spi.partition.IPartitionService
Check if this node is the owner of a partition.
isPartitionPromotionAllowed() - Method in enum com.hazelcast.cluster.ClusterState
Returns true, if partition promotions are allowed in this state.
isPersistWanReplicatedData() - Method in class com.hazelcast.config.WanConsumerConfig
 
isPlain() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.ScalarEvent
 
isPlain() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.ScalarNode
 
isPlain() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.ScalarToken
 
isPopulate() - Method in class com.hazelcast.config.QueryCacheConfig
Returns true if initial population of QueryCache is enabled, otherwise returns false.
isPortable() - Method in interface com.hazelcast.nio.serialization.Data
Returns true if this Data is created from a Portable object, false otherwise.
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.
isPowerOfTwo(long) - Static method in class com.hazelcast.util.QuickMath
Return true if input argument is power of two.
isPresent() - Method in interface com.hazelcast.quorum.Quorum
Returns true if quorum is present, false if absent.
isPresent() - Method in class com.hazelcast.quorum.QuorumEvent
Returns the presence of the quorum
isPrimitive() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
 
isPrintable(String) - Static method in class com.hazelcast.org.snakeyaml.engine.v1.scanner.StreamReader
 
isPrintable(int) - Static method in class com.hazelcast.org.snakeyaml.engine.v1.scanner.StreamReader
 
isRawSocketPermitted() - Static method in class com.hazelcast.util.ICMPHelper
 
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.
isRecursive() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.Node
Indicates if this node must be constructed in two steps.
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.config.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
 
isResultDeserialized() - Method in class com.hazelcast.spi.InvocationBuilder
Checks if the Future should automatically deserialize the result.
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
 
isRunning() - Method in interface com.hazelcast.core.LifecycleService
Checks whether or not the instance is running.
isRunning() - Method in class com.hazelcast.instance.LifecycleServiceImpl
 
isRunning() - Method in class com.hazelcast.instance.Node
Indicates that node is not shutting down or it has not already shut down
isRunning() - Method in class com.hazelcast.instance.TerminatedLifecycleService
 
isRunning() - Method in interface com.hazelcast.spi.NodeEngine
Indicates that node is not shutting down or it has not already shut down
isRunning() - Method in class com.hazelcast.wan.merkletree.ConsistencyCheckResult
 
isSameNode(Node) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
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
Checks if the Level.SEVERE is enabled.
isShutdown() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
 
isSnapshot() - Method in class com.hazelcast.com.fasterxml.jackson.core.Version
 
isSnapshotsEnabled() - Method in class com.hazelcast.jet.core.test.TestSupport.TestMode
Are snapshots enabled.
isSocketBind() - Method in interface com.hazelcast.nio.IOService
 
isSocketBind() - Method in class com.hazelcast.nio.NodeIOService
 
isSocketBindAny() - Method in interface com.hazelcast.nio.IOService
 
isSocketBindAny() - Method in class com.hazelcast.nio.NodeIOService
 
isSocketBufferDirect() - Method in class com.hazelcast.config.EndpointConfig
 
isSocketInterceptorEnabled(EndpointQualifier) - Method in interface com.hazelcast.nio.IOService
 
isSocketInterceptorEnabled(EndpointQualifier) - Method in class com.hazelcast.nio.NodeIOService
 
isSocketKeepAlive() - Method in class com.hazelcast.config.EndpointConfig
 
isSocketTcpNoDelay() - Method in class com.hazelcast.config.EndpointConfig
 
isSplitBrainProtectionEnabled() - Method in class com.hazelcast.jet.config.JobConfig
Tells whether split brain protection is enabled.
isSplitLines() - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.DumpSettings
 
isStartCompleted() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
isStartCompleted() - Method in interface com.hazelcast.instance.NodeExtension
Returns true if the instance has started
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.ExecutorConfig
Gets if statistics gathering is enabled or disabled on the executor task.
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.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
isSupported(OptionalFeature) - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
isSupported(String, String) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
isSynchronous() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
If true, this cache entry listener implementation will be called in a synchronous manner.
isTerminal(Throwable) - Method in interface com.hazelcast.topic.ReliableMessageListener
Checks if the ReliableMessageListener should be terminated based on an exception thrown while calling MessageListener.onMessage(com.hazelcast.core.Message).
isTerminated() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
 
isThrowable() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
 
isTransactional() - Method in interface com.hazelcast.concurrent.lock.LockResource
 
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
Deprecated.
Since 2.7 use correctly spelled method Version.isUnknownVersion()
isUnixFamily() - Static method in class com.hazelcast.util.OsHelper
Returns true if the system is from Unix family.
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
 
isUrgent() - Method in class com.hazelcast.nio.Packet
 
isUrgent() - Method in class com.hazelcast.spi.Operation
 
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.v1.api.DumpSettings
 
isValidForFetching(V, long) - Method in class com.hazelcast.util.SampleableConcurrentHashMap
 
isValidForSampling(K, V) - Method in class com.hazelcast.util.SampleableConcurrentHashMap
 
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
Checks if the Level.WARNING is enabled.
isWhiteSpace(byte) - Static method in class com.hazelcast.util.Base64
 
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.core.ItemEvent
 
item() - Method in class com.hazelcast.jet.datamodel.TimestampedItem
Returns the item.
ITEM_LISTENER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
itemAdded(ItemEvent) - Method in class com.hazelcast.console.ConsoleApp
 
itemAdded(ItemEvent<E>) - Method in interface com.hazelcast.core.ItemListener
Invoked when an item is added.
ItemCounter<T> - Class in com.hazelcast.util
Non Thread-Safe Counter of things.
ItemCounter() - Constructor for class com.hazelcast.util.ItemCounter
 
ItemEvent<E> - Class in com.hazelcast.core
Event for a collection item.
ItemEvent(String, ItemEventType, E, Member) - Constructor for class com.hazelcast.core.ItemEvent
 
ItemEventType - Enum in com.hazelcast.core
Type of item events.
ItemListener<E> - Interface in com.hazelcast.core
Item listener for IQueue, ISet and IList
ItemListenerConfig - Class in com.hazelcast.config
Contains the configuration for an Item Listener.
ItemListenerConfig() - Constructor for class com.hazelcast.config.ItemListenerConfig
 
ItemListenerConfig(String, boolean) - Constructor for class com.hazelcast.config.ItemListenerConfig
 
ItemListenerConfig(ItemListener, boolean) - Constructor for class com.hazelcast.config.ItemListenerConfig
 
ItemListenerConfig(ItemListenerConfig) - Constructor for class com.hazelcast.config.ItemListenerConfig
 
ItemListenerConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
ItemListenerConfigReadOnly(ItemListenerConfig) - Constructor for class com.hazelcast.config.ItemListenerConfigReadOnly
Deprecated.
 
itemRemoved(ItemEvent) - Method in class com.hazelcast.console.ConsoleApp
 
itemRemoved(ItemEvent<E>) - Method in interface com.hazelcast.core.ItemListener
Invoked when an item is removed.
items(Iterable<? extends T>) - Static method in class com.hazelcast.jet.pipeline.test.TestSources
Returns a batch source which iterates through the supplied iterable and then terminates.
items(T...) - Static method in class com.hazelcast.jet.pipeline.test.TestSources
Returns a batch source which iterates through the supplied items and then terminates.
ItemsByTag - 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.
itemStream(int) - Static method in class com.hazelcast.jet.pipeline.test.TestSources
Returns a streaming source which generates events of type SimpleEvent at the specified rate infinitely.
itemStream(int, GeneratorFunction<? extends T>) - Static method in class com.hazelcast.jet.pipeline.test.TestSources
Returns a streaming source which generates events created by the generatorFn at the specified rate infinitely.
IterableUtil - Class in com.hazelcast.util
Utility functions for working with Iterable
IterationType - Enum in com.hazelcast.util
To differentiate users selection on result collection on map-wide operations like values, keySet, query etc.
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 class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
iterator() - Method in interface com.hazelcast.partition.membergroup.MemberGroup
 
iterator() - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
iterator() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Returns a read-only iterator.
iterator() - Method in class com.hazelcast.util.collection.InflatableSet
 
iterator() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.KeySet
 
iterator() - Method in class com.hazelcast.util.collection.IntHashSet
 
iterator() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.KeySet
 
iterator() - Method in class com.hazelcast.util.collection.LongHashSet
iterator() - Method in class com.hazelcast.util.collection.MapDelegatingSet
iterator() - Method in class com.hazelcast.util.collection.OAHashSet
 
iterator(Class<T>, String, ClassLoader) - Static method in class com.hazelcast.util.ServiceLoader
 
ITopic<E> - Interface in com.hazelcast.core
Hazelcast provides distribution mechanism for publishing messages that are delivered to multiple subscribers, which is also known as a publish/subscribe (pub/sub) messaging model.

J

JavaSerializationFilterConfig - Class in com.hazelcast.config
Configuration for Serialization Filter.
JavaSerializationFilterConfig() - Constructor for class com.hazelcast.config.JavaSerializationFilterConfig
 
JavaSerializationFilterConfig(JavaSerializationFilterConfig) - Constructor for class com.hazelcast.config.JavaSerializationFilterConfig
 
JCACHE_PROVIDER_TYPE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Forces the JCache provider, which can have values client or server, to force the provider type.
jdbc(String, SupplierEx<Connection>, BiConsumerEx<PreparedStatement, T>) - Static method in class com.hazelcast.jet.pipeline.Sinks
Returns a sink that connects to the specified database using the given newConnectionFn, prepares a statement using the given updateQuery and inserts/updates the items.
jdbc(String, String, BiConsumerEx<PreparedStatement, T>) - Static method in class com.hazelcast.jet.pipeline.Sinks
jdbc(SupplierEx<? extends Connection>, ToResultSetFunction, FunctionEx<? super ResultSet, ? extends T>) - Static method in class com.hazelcast.jet.pipeline.Sources
Returns a source which connects to the specified database using the given newConnectionFn, queries the database and creates a result set using the the given resultSetFn.
jdbc(String, String, FunctionEx<? super ResultSet, ? extends T>) - Static method in class com.hazelcast.jet.pipeline.Sources
Jet - Class in com.hazelcast.jet
Entry point to the Jet product.
JET_HOME - Static variable in class com.hazelcast.jet.core.JetProperties
Root of Jet installation.
JET_IDLE_COOPERATIVE_MAX_MICROSECONDS - Static variable in class com.hazelcast.jet.core.JetProperties
The maximum time in microseconds the cooperative worker threads will sleep if none of the tasklets made any progress.
JET_IDLE_COOPERATIVE_MIN_MICROSECONDS - Static variable in class com.hazelcast.jet.core.JetProperties
The minimum time in microseconds the cooperative worker threads will sleep if none of the tasklets made any progress.
JET_IDLE_NONCOOPERATIVE_MAX_MICROSECONDS - Static variable in class com.hazelcast.jet.core.JetProperties
The maximum time in microseconds the non-cooperative worker threads will sleep if none of the tasklets made any progress.
JET_IDLE_NONCOOPERATIVE_MIN_MICROSECONDS - Static variable in class com.hazelcast.jet.core.JetProperties
The minimum time in microseconds the non-cooperative worker threads will sleep if none of the tasklets made any progress.
JET_SHUTDOWNHOOK_ENABLED - Static variable in class com.hazelcast.jet.core.JetProperties
Whether a JVM shutdown hook is registered to shutdown the node gracefully when the process is terminated.
JetAssert - Class in com.hazelcast.jet.core.test
Assert methods that throw exceptions similar to those thrown by JUnit.
JetBootstrap - Class in com.hazelcast.jet.server
A helper class that allows one to create a standalone runnable JAR which contains all the code needed to submit a job to a running Jet cluster.
JetBuildInfo - Class in com.hazelcast.instance
 
JetBuildInfo(String, String, String) - Constructor for class com.hazelcast.instance.JetBuildInfo
 
JetCacheManager - Interface in com.hazelcast.jet
JetCacheManager is the entry point to access JSR-107 (JCache) caches via JetInstance interface.
JetClientBeanDefinitionParser - Class in com.hazelcast.jet.spring
BeanDefinitionParser for Hazelcast Jet Client Configuration.
JetClientBeanDefinitionParser() - Constructor for class com.hazelcast.jet.spring.JetClientBeanDefinitionParser
 
JetClientConfig - Class in com.hazelcast.jet.config
A config object which is used for configuring the Jet client to connect to the Jet cluster.
JetClientConfig() - Constructor for class com.hazelcast.jet.config.JetClientConfig
Creates a new config instance with default group name for Jet
JetCommandLine - Class in com.hazelcast.jet.server
 
JetCommandLine(Function<ClientConfig, JetInstance>, PrintStream, PrintStream) - Constructor for class com.hazelcast.jet.server.JetCommandLine
 
JetCommandLine.JetVersionProvider - Class in com.hazelcast.jet.server
 
JetCommandLine.Verbosity - Class in com.hazelcast.jet.server
 
JetConfig - Class in com.hazelcast.jet.config
Configuration object for a Jet instance.
JetConfig() - Constructor for class com.hazelcast.jet.config.JetConfig
Creates a new, empty JetConfig with the default configuration.
JetConfigDataSerializerHook - Class in com.hazelcast.jet.config
Hazelcast serializer hooks for the classes in the com.hazelcast.jet.config package.
JetConfigDataSerializerHook() - Constructor for class com.hazelcast.jet.config.JetConfigDataSerializerHook
 
JetConfigXmlGenerator - Class in com.hazelcast.jet.config
The JetConfigXmlGenerator is responsible for transforming a JetConfig to a Hazelcast Jet XML string.
JetDataSerializerHook - Class in com.hazelcast.jet.core
A Java Service Provider hook for Hazelcast's Identified Data Serializable mechanism.
JetDataSerializerHook() - Constructor for class com.hazelcast.jet.core.JetDataSerializerHook
 
JetException - Exception in com.hazelcast.jet
Base Jet exception.
JetException() - Constructor for exception com.hazelcast.jet.JetException
 
JetException(String) - Constructor for exception com.hazelcast.jet.JetException
 
JetException(String, Throwable) - Constructor for exception com.hazelcast.jet.JetException
 
JetException(Throwable) - Constructor for exception com.hazelcast.jet.JetException
 
JetHazelcastBeanDefinitionParser - Class in com.hazelcast.jet.spring
BeanDefinitionParser for Hazelcast Instance created via Jet Instance.
JetHazelcastBeanDefinitionParser() - Constructor for class com.hazelcast.jet.spring.JetHazelcastBeanDefinitionParser
 
jetInstance() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
Returns the current Jet instance.
jetInstance() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
 
jetInstance(JetInstance) - Method in class com.hazelcast.jet.core.test.TestSupport
JetInstance - Interface in com.hazelcast.jet
Represents either an instance of a Jet server node or a Jet client instance that connects to a remote cluster.
JetInstanceBeanDefinitionParser - Class in com.hazelcast.jet.spring
BeanDefinitionParser for Hazelcast Jet Instance Configuration.
JetInstanceBeanDefinitionParser() - Constructor for class com.hazelcast.jet.spring.JetInstanceBeanDefinitionParser
 
JetNamespaceHandler - Class in com.hazelcast.jet.spring
Hazelcast Jet Custom Namespace Definitions.
JetNamespaceHandler() - Constructor for class com.hazelcast.jet.spring.JetNamespaceHandler
 
JetProperties - Class in com.hazelcast.jet.core
Defines the names and default values for internal Hazelcast Jet properties.
JetVersionProvider() - Constructor for class com.hazelcast.jet.server.JetCommandLine.JetVersionProvider
 
jmsQueue(SupplierEx<ConnectionFactory>, String) - Static method in class com.hazelcast.jet.pipeline.Sinks
jmsQueue(SupplierEx<? extends ConnectionFactory>, String) - Static method in class com.hazelcast.jet.pipeline.Sources
jmsQueueBuilder(SupplierEx<ConnectionFactory>) - Static method in class com.hazelcast.jet.pipeline.Sinks
Returns a builder object that offers a step-by-step fluent API to build a custom JMS queue sink for the Pipeline API.
jmsQueueBuilder(SupplierEx<? extends ConnectionFactory>) - Static method in class com.hazelcast.jet.pipeline.Sources
Returns a builder object that offers a step-by-step fluent API to build a custom JMS StreamSource for the Pipeline API.
JmsSinkBuilder<T> - Class in com.hazelcast.jet.pipeline
JmsSourceBuilder - Class in com.hazelcast.jet.pipeline
jmsTopic(SupplierEx<ConnectionFactory>, String) - Static method in class com.hazelcast.jet.pipeline.Sinks
jmsTopic(SupplierEx<? extends ConnectionFactory>, String) - Static method in class com.hazelcast.jet.pipeline.Sources
jmsTopicBuilder(SupplierEx<ConnectionFactory>) - Static method in class com.hazelcast.jet.pipeline.Sinks
Returns a builder object that offers a step-by-step fluent API to build a custom JMS topic sink for the Pipeline API.
jmsTopicBuilder(SupplierEx<? extends ConnectionFactory>) - Static method in class com.hazelcast.jet.pipeline.Sources
Returns a builder object that offers a step-by-step fluent API to build a custom JMS StreamSource for the Pipeline API.
JMX_UPDATE_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
JOB - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
Unique ID of the job (sourcing the metric), example value would be a numerical (long) ID encoded in a human readable form, like "2f7f-d88a-4669-6195", see Util.idToString(long))} for details.
Job - Interface in com.hazelcast.jet
A Jet computation job created by submitting a DAG or Pipeline.
Job<KeyIn,ValueIn> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
JOB_CONFIG - Static variable in class com.hazelcast.jet.config.JetConfigDataSerializerHook
Serialization ID of the JobConfig class.
JOB_METRICS - Static variable in class com.hazelcast.jet.core.metrics.MetricsDataSerializerHook
Serialization ID of the JobMetrics class.
JOB_RESULTS_MAX_SIZE - Static variable in class com.hazelcast.jet.core.JetProperties
Maximum number of job results to keep in the cluster, the oldest results will be automatically deleted after this size is reached.
JOB_RESULTS_TTL_SECONDS - Static variable in class com.hazelcast.jet.core.JetProperties
Maximum number of time in seconds the job results will be kept in the cluster.
JOB_SCAN_PERIOD - Static variable in class com.hazelcast.jet.core.JetProperties
Jet will periodically check for new jobs to start and perform cleanup of unused resources.
JobAlreadyExistsException - Exception in com.hazelcast.jet
Thrown when a named job is submitted while there is an active job with the same name.
JobAlreadyExistsException() - Constructor for exception com.hazelcast.jet.JobAlreadyExistsException
Creates the exception
JobAlreadyExistsException(String) - Constructor for exception com.hazelcast.jet.JobAlreadyExistsException
Creates the exception with a message.
JobAlreadyExistsException(String, Throwable) - Constructor for exception com.hazelcast.jet.JobAlreadyExistsException
Creates the exception with a message and a cause.
JobClassLoaderFactory - Interface in com.hazelcast.jet.config
An interface that can be implemented to provide custom class loader for Jet job.
JobCompletableFuture<V> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
JobConfig - Class in com.hazelcast.jet.config
Contains the configuration specific to one Hazelcast Jet job.
JobConfig() - Constructor for class com.hazelcast.jet.config.JobConfig
 
jobConfig() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
Returns the JobConfig.
jobConfig() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
 
jobId() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
Returns the job ID.
jobId() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
 
jobId() - Method in class com.hazelcast.jet.JobStateSnapshot
Returns the job ID of the job the snapshot was originally exported from.
JobMetrics - Class in com.hazelcast.jet.core.metrics
An immutable collection of job-specific metrics, pairs of metric names and sets of associated Measurements.
jobName() - Method in class com.hazelcast.jet.JobStateSnapshot
Returns the job name of the job the snapshot was originally exported from.
JobNotFoundException - Exception in com.hazelcast.jet.core
Thrown when a job could not be found on the master node
JobNotFoundException(long) - Constructor for exception com.hazelcast.jet.core.JobNotFoundException
 
JobNotFoundException(String) - Constructor for exception com.hazelcast.jet.core.JobNotFoundException
 
JobNotFoundException(String, Throwable) - Constructor for exception com.hazelcast.jet.core.JobNotFoundException
 
JobPartitionState - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
JobPartitionState.State - Enum in com.hazelcast.mapreduce
Deprecated.
Definition of the processing states
JobProcessInformation - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
JobStateSnapshot - Class in com.hazelcast.jet
A handle to an exported state snapshot created using Job.exportSnapshot(String).
JobStatus - Enum in com.hazelcast.jet.core
Represents current status of the job from the perspective of the job coordinator.
JobTracker - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
JobTrackerConfig - Class in com.hazelcast.config
Contains the configuration for an JobTracker.
JobTrackerConfig() - Constructor for class com.hazelcast.config.JobTrackerConfig
 
JobTrackerConfig(JobTrackerConfig) - Constructor for class com.hazelcast.config.JobTrackerConfig
 
JobTrackerConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
join() - Method in interface com.hazelcast.cluster.Joiner
Deprecated.
 
join() - Method in class com.hazelcast.instance.Node
 
join() - Method in interface com.hazelcast.jet.Job
Waits for the job to complete and throws an exception if the job completes with an error.
join() - Method in interface com.hazelcast.spi.InternalCompletableFuture
Waits for this future to complete.
join() - Method in class com.hazelcast.util.executor.CompletedFuture
 
join() - Method in class com.hazelcast.util.executor.DelegatingFuture
 
JoinClause<K,T0,T1,T1_OUT> - Class in com.hazelcast.jet.pipeline
Specifies how to join an enriching stream to the primary stream in a hash-join operation.
JoinConfig - Class in com.hazelcast.config
Contains the 3 different join configurations; TCP-IP/multicast/AWS.
JoinConfig() - Constructor for class com.hazelcast.config.JoinConfig
 
Joiner - Interface in com.hazelcast.cluster
Deprecated.
joinMapEntries(FunctionEx<? super T0, ? extends K>) - Static method in class com.hazelcast.jet.pipeline.JoinClause
A shorthand factory for the common case of hash-joining with a stream of map entries.
JournalInitialPosition - Enum in com.hazelcast.jet.pipeline
When passed to an IMap/ICache Event Journal source, specifies which event to start from.
JsonEncoding - Enum in com.hazelcast.com.fasterxml.jackson.core
Enumeration that defines legal encodings that can be used for JSON content, based on list of allowed encodings from JSON specification.
JsonEOFException - Exception in com.hazelcast.com.fasterxml.jackson.core.io
Specialized JsonParseException that is thrown when end-of-input is reached unexpectedly, either within token being decoded, or during skipping of intervening white-space that is not between root-level tokens (that is, is within JSON Object or JSON Array construct).
JsonEOFException(JsonParser, JsonToken, String) - Constructor for exception com.hazelcast.com.fasterxml.jackson.core.io.JsonEOFException
 
JsonFactory - Class in com.hazelcast.com.fasterxml.jackson.core
The main factory class of Jackson package, used to configure and construct reader (aka parser, JsonParser) and writer (aka generator, JsonGenerator) instances.
JsonFactory() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
Default constructor used to create factory instances.
JsonFactory(ObjectCodec) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
 
JsonFactory(JsonFactory, ObjectCodec) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
Constructor used when copy()ing a factory instance.
JsonFactory.Feature - Enum in com.hazelcast.com.fasterxml.jackson.core
Enumeration that defines all on/off features that can only be changed for JsonFactory.
JsonGenerationException - Exception in com.hazelcast.com.fasterxml.jackson.core
Exception type for exceptions during JSON writing, such as trying to output content in wrong context (non-matching end-array or end-object, for example).
JsonGenerationException(Throwable) - Constructor for exception com.hazelcast.com.fasterxml.jackson.core.JsonGenerationException
Deprecated.
JsonGenerationException(String) - Constructor for exception com.hazelcast.com.fasterxml.jackson.core.JsonGenerationException
Deprecated.
JsonGenerationException(String, Throwable) - Constructor for exception com.hazelcast.com.fasterxml.jackson.core.JsonGenerationException
Deprecated.
JsonGenerationException(Throwable, JsonGenerator) - Constructor for exception com.hazelcast.com.fasterxml.jackson.core.JsonGenerationException
 
JsonGenerationException(String, JsonGenerator) - Constructor for exception com.hazelcast.com.fasterxml.jackson.core.JsonGenerationException
 
JsonGenerationException(String, Throwable, JsonGenerator) - Constructor for exception com.hazelcast.com.fasterxml.jackson.core.JsonGenerationException
 
JsonGenerator - Class in com.hazelcast.com.fasterxml.jackson.core
Base class that defines public API for writing JSON content.
JsonGenerator() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
 
JsonGenerator.Feature - Enum in com.hazelcast.com.fasterxml.jackson.core
Enumeration that defines all togglable features for generators.
JsonGeneratorDelegate - Class in com.hazelcast.com.fasterxml.jackson.core.util
 
JsonGeneratorDelegate(JsonGenerator) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
 
JsonGeneratorDelegate(JsonGenerator, boolean) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
 
JsonGeneratorImpl - Class in com.hazelcast.com.fasterxml.jackson.core.json
Intermediate base class shared by JSON-backed generators like UTF8JsonGenerator and WriterBasedJsonGenerator.
JsonGeneratorImpl(IOContext, int, ObjectCodec) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.json.JsonGeneratorImpl
 
JsonLocation - Class in com.hazelcast.com.fasterxml.jackson.core
Object that encapsulates Location information used for reporting parsing (or potentially generation) errors, as well as current location within input streams.
JsonLocation(Object, long, int, int) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.JsonLocation
 
JsonLocation(Object, long, long, int, int) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.JsonLocation
 
JsonParseException - Exception in com.hazelcast.com.fasterxml.jackson.core
Exception type for parsing problems, used when non-well-formed content (content that does not conform to JSON syntax as per specification) is encountered.
JsonParseException(String, JsonLocation) - Constructor for exception com.hazelcast.com.fasterxml.jackson.core.JsonParseException
Deprecated.
JsonParseException(String, JsonLocation, Throwable) - Constructor for exception com.hazelcast.com.fasterxml.jackson.core.JsonParseException
Deprecated.
JsonParseException(JsonParser, String) - Constructor for exception com.hazelcast.com.fasterxml.jackson.core.JsonParseException
Constructor that uses current parsing location as location, and sets processor (accessible via JsonParseException.getProcessor()) to specified parser.
JsonParseException(JsonParser, String, Throwable) - Constructor for exception com.hazelcast.com.fasterxml.jackson.core.JsonParseException
 
JsonParseException(JsonParser, String, JsonLocation) - Constructor for exception com.hazelcast.com.fasterxml.jackson.core.JsonParseException
 
JsonParseException(JsonParser, String, JsonLocation, Throwable) - Constructor for exception com.hazelcast.com.fasterxml.jackson.core.JsonParseException
 
JsonParser - Class in com.hazelcast.com.fasterxml.jackson.core
Base class that defines public API for reading JSON content.
JsonParser() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.JsonParser
 
JsonParser(int) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.JsonParser
 
JsonParser.Feature - Enum in com.hazelcast.com.fasterxml.jackson.core
Enumeration that defines all on/off features for parsers.
JsonParser.NumberType - Enum in com.hazelcast.com.fasterxml.jackson.core
Enumeration of possible "native" (optimal) types that can be used for numbers.
JsonParserDelegate - Class in com.hazelcast.com.fasterxml.jackson.core.util
Helper class that implements delegation pattern for JsonParser, to allow for simple overridability of basic parsing functionality.
JsonParserDelegate(JsonParser) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
 
JsonParserSequence - Class in com.hazelcast.com.fasterxml.jackson.core.util
Helper class that can be used to sequence multiple physical JsonParsers to create a single logical sequence of tokens, as a single JsonParser.
JsonParserSequence(JsonParser[]) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserSequence
Deprecated.
JsonParserSequence(boolean, JsonParser[]) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserSequence
 
JsonpCharacterEscapes - Class in com.hazelcast.com.fasterxml.jackson.core
Convenience CharacterEscapes implementation that escapes Unicode characters `0x2028` and `0x2029` (in addition to characters escaped otherwise), which are apparently considered linefeeds as per newer Javascript specifications, and consequently problematic when using JSONP (see https://en.wikipedia.org/wiki/JSONP).
JsonpCharacterEscapes() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.JsonpCharacterEscapes
 
JsonPointer - Class in com.hazelcast.com.fasterxml.jackson.core
Implementation of JSON Pointer specification.
JsonPointer() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
Constructor used for creating "empty" instance, used to represent state that matches current node.
JsonPointer(String, String, JsonPointer) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
Constructor used for creating non-empty Segments
JsonPointer(String, String, int, JsonPointer) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
 
JsonPointerBasedFilter - Class in com.hazelcast.com.fasterxml.jackson.core.filter
Simple TokenFilter implementation that takes a single JsonPointer and matches a single value accordingly.
JsonPointerBasedFilter(String) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.filter.JsonPointerBasedFilter
 
JsonPointerBasedFilter(JsonPointer) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.filter.JsonPointerBasedFilter
 
JsonProcessingException - Exception in com.hazelcast.com.fasterxml.jackson.core
Intermediate base class for all problems encountered when processing (parsing, generating) JSON content that are not pure I/O problems.
JsonProcessingException(String, JsonLocation, Throwable) - Constructor for exception com.hazelcast.com.fasterxml.jackson.core.JsonProcessingException
 
JsonProcessingException(String) - Constructor for exception com.hazelcast.com.fasterxml.jackson.core.JsonProcessingException
 
JsonProcessingException(String, JsonLocation) - Constructor for exception com.hazelcast.com.fasterxml.jackson.core.JsonProcessingException
 
JsonProcessingException(String, Throwable) - Constructor for exception com.hazelcast.com.fasterxml.jackson.core.JsonProcessingException
 
JsonProcessingException(Throwable) - Constructor for exception com.hazelcast.com.fasterxml.jackson.core.JsonProcessingException
 
JsonReadContext - Class in com.hazelcast.com.fasterxml.jackson.core.json
Extension of JsonStreamContext, which implements core methods needed, and also exposes more complete API to parser implementation classes.
JsonReadContext(JsonReadContext, DupDetector, int, int, int) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.json.JsonReadContext
 
JsonScalarResolver - Class in com.hazelcast.org.snakeyaml.engine.v1.resolver
ScalarResolver for JSON Schema The scherma is NOT the same as in YAML 1.2 but identical to JSON, 1) .inf, -.inf, .nan values are not used, 2) integers may have a leading 0
JsonScalarResolver() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.resolver.JsonScalarResolver
 
JsonStreamContext - Class in com.hazelcast.com.fasterxml.jackson.core
Shared base class for streaming processing contexts used during reading and writing of Json content using Streaming API.
JsonStreamContext() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
 
JsonStreamContext(JsonStreamContext) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
Copy constructor used by sub-classes for creating copies for buffering.
JsonStreamContext(int, int) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
 
JsonStringEncoder - Class in com.hazelcast.com.fasterxml.jackson.core.io
Helper class used for efficient encoding of JSON String values (including JSON field names) into Strings or UTF-8 byte arrays.
JsonStringEncoder() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.io.JsonStringEncoder
 
JsonToken - Enum in com.hazelcast.com.fasterxml.jackson.core
Enumeration for basic token types used for returning results of parsing JSON content.
JsonTokenId - Interface in com.hazelcast.com.fasterxml.jackson.core
Interface defined to contain ids accessible with JsonToken.id().
JsonUtil - Class in com.hazelcast.util
Utility class to deal with Json.
JsonWriteContext - Class in com.hazelcast.com.fasterxml.jackson.core.json
Extension of JsonStreamContext, which implements core methods needed, and also exposes more complete API to generator implementation classes.
JsonWriteContext(int, JsonWriteContext, DupDetector) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
 
JVMUtil - Class in com.hazelcast.util
Helper class for retrieving JVM specific information.

K

kafka(Properties, FunctionEx<? super E, ProducerRecord<K, V>>) - Static method in class com.hazelcast.jet.kafka.KafkaSinks
Returns a source that publishes messages to an Apache Kafka topic.
kafka(Properties, String, FunctionEx<? super E, K>, FunctionEx<? super E, V>) - Static method in class com.hazelcast.jet.kafka.KafkaSinks
Convenience for KafkaSinks.kafka(Properties, FunctionEx) which creates a ProducerRecord using the given topic and the given key and value mapping functions
kafka(Properties, String) - Static method in class com.hazelcast.jet.kafka.KafkaSinks
Convenience for KafkaSinks.kafka(Properties, String, FunctionEx, FunctionEx) which expects Map.Entry<K, V> as input and extracts its key and value parts to be published to Kafka.
kafka(Properties, String...) - Static method in class com.hazelcast.jet.kafka.KafkaSources
Convenience for KafkaSources.kafka(Properties, FunctionEx, String...) wrapping the output in Map.Entry.
kafka(Properties, FunctionEx<ConsumerRecord<K, V>, T>, String...) - Static method in class com.hazelcast.jet.kafka.KafkaSources
Returns a source that consumes one or more Apache Kafka topics and emits items from them as Map.Entry instances.
KafkaProcessors - Class in com.hazelcast.jet.kafka
Static utility class with factories of Apache Kafka source and sink processors.
KafkaSinks - Class in com.hazelcast.jet.kafka
Contains factory methods for Apache Kafka sinks.
KafkaSources - Class in com.hazelcast.jet.kafka
Contains factory methods for Apache Kafka sources.
key - Variable in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
key() - Method in interface com.hazelcast.config.properties.PropertyDefinition
Returns the key (the name) of this property inside the configuration.
key() - Method in class com.hazelcast.config.properties.SimplePropertyDefinition
 
key - Variable in class com.hazelcast.core.EntryEvent
 
key() - Method in class com.hazelcast.jet.core.BroadcastKey
Returns the underlying key
key() - Method in class com.hazelcast.jet.datamodel.KeyedWindowResult
Returns the grouping key.
key() - Method in class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
Returns the current index key for KeyPredicate analysis.
key() - Method in class com.hazelcast.query.EntryObject
 
key() - Method in class com.hazelcast.util.collection.Long2LongHashMap.LongLongCursor
 
key - Variable in class com.hazelcast.util.ConcurrentReferenceHashMap.SimpleEntry
 
key - Variable in class com.hazelcast.util.SampleableConcurrentHashMap.SamplingEntry
 
KeyedWindowResult<K,R> - Class in com.hazelcast.jet.datamodel
Holds the result of a group-and-aggregate operation performed over a time window.
KeyedWindowResult(long, long, K, R, boolean) - Constructor for class com.hazelcast.jet.datamodel.KeyedWindowResult
 
KeyedWindowResult(long, long, K, R) - Constructor for class com.hazelcast.jet.datamodel.KeyedWindowResult
Constructs a keyed window result that is not early.
KeyedWindowResultFunction<K,R,OUT> - Interface in com.hazelcast.jet.core.function
Represents the function you pass to windowing processors such as aggregateToSlidingWindowP() and aggregateToSessionWindowP() as mapToOutputFn.
keyFn() - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
Returns the function that extracts the key from stream items.
keyFn() - Method in interface com.hazelcast.jet.pipeline.StageWithKeyAndWindow
Returns the function that extracts the grouping key from stream items.
KeyIterator() - Constructor for class com.hazelcast.util.collection.Int2ObjectHashMap.KeyIterator
 
KeyIterator() - Constructor for class com.hazelcast.util.collection.Long2ObjectHashMap.KeyIterator
 
keyPredicate(KeyPredicate<? super KeyIn>) - Method in interface com.hazelcast.mapreduce.Job
Deprecated.
Defines the KeyPredicate implementation to preselect keys the MapReduce task will be executed on.
KeyPredicate<Key> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
keyPredicate(KeyPredicate<? super EntryKey>) - Method in interface com.hazelcast.mapreduce.MappingJob
Deprecated.
Defines the KeyPredicate implementation to preselect keys that the MapReduce task will be executed on.
keyPredicate(KeyPredicate<EntryKey>) - Method in interface com.hazelcast.mapreduce.ReducingJob
Deprecated.
Defines the KeyPredicate implementation to preselect keys the MapReduce task will be executed on.
keyPredicate(KeyPredicate<EntryKey>) - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
Deprecated.
Defines the KeyPredicate implementation to preselect keys the MapReduce task will be executed on.
keys() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
Returns an enumeration of the keys in this table.
keySet() - Method in interface com.hazelcast.core.BaseMap
Returns a set clone of the keys contained in this map.
keySet(Predicate) - Method in interface com.hazelcast.core.BaseMap
Queries the map based on the specified predicate and returns the keys of matching entries.
keySet() - Method in interface com.hazelcast.core.IMap
Returns a set clone of the keys contained in this map.
keySet(Predicate) - Method in interface com.hazelcast.core.IMap
Queries the map based on the specified predicate and returns the keys of matching entries.
keySet() - Method in interface com.hazelcast.core.MultiMap
Returns the set of keys in the multimap.
keySet() - Method in interface com.hazelcast.core.ReplicatedMap
Returns a lazy Set view of the key contained in this map.
A LazySet is optimized for querying speed (preventing eager deserialization and hashing on HashSet insertion) and does NOT provide all operations.
keySet() - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.keySet().
keySet(Predicate) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.keySet(com.hazelcast.query.Predicate).
keySet() - Method in interface com.hazelcast.map.QueryCache
 
keySet(Predicate) - Method in interface com.hazelcast.map.QueryCache
 
keySet() - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns an immutable set of all keys in this HazelcastProperties.
keySet() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
 
KeySet() - Constructor for class com.hazelcast.util.collection.Int2ObjectHashMap.KeySet
 
keySet() - Method in class com.hazelcast.util.collection.Long2LongHashMap
 
keySet() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
 
KeySet() - Constructor for class com.hazelcast.util.collection.Long2ObjectHashMap.KeySet
 
keySet() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
Returns a Set view of the keys contained in this map.
keySet() - Method in class com.hazelcast.util.ItemCounter
Returns an iterator over all keys.
KeyToken - Class in com.hazelcast.org.snakeyaml.engine.v1.tokens
 
KeyToken(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.tokens.KeyToken
 
KeyValueSource<K,V> - Class in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
KeyValueSource() - Constructor for class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
 
keyValueTypesEqual(AbstractCacheConfig) - Method in class com.hazelcast.config.AbstractCacheConfig
 
KILO_BYTE - Static variable in interface com.hazelcast.nio.IOService
 
kiloBytes() - Method in class com.hazelcast.memory.MemorySize
Returns value of memory size in kilo-bytes.
KUBERNETES_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
KubernetesConfig - Class in com.hazelcast.config
Configuration for the Kubernetes Discovery Strategy.
KubernetesConfig() - Constructor for class com.hazelcast.config.KubernetesConfig
 
KubernetesConfig(KubernetesConfig) - Constructor for class com.hazelcast.config.KubernetesConfig
 

L

last() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
Returns the leaf of current JSON Pointer expression.
LAST_FORWARDED_WM - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
Tracks the last watermark emitted by a particular Processor, which can be identified based on the MetricTags.PROCESSOR tag.
LAST_FORWARDED_WM_LATENCY - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
Tracks the difference between the last emitted watermark and the system time of a particular Processor.
LAST_VALID_UNICODE_CHAR - Static variable in class com.hazelcast.com.fasterxml.jackson.core.io.UTF32Reader
JSON actually limits available Unicode range in the high end to the same as xml (to basically limit UTF-8 max byte sequence length to 4)
lastForwardedWm() - Method in class com.hazelcast.jet.core.test.TestOutbox
 
lastIndexOf(String, char, int) - Static method in class com.hazelcast.util.StringUtil
Like a String.lastIndexOf but without MIN_SUPPLEMENTARY_CODE_POINT handling
lastIndexOf(String, char) - Static method in class com.hazelcast.util.StringUtil
Like a String.lastIndexOf but without MIN_SUPPLEMENTARY_CODE_POINT handling
lastReadTimeMillis() - Method in interface com.hazelcast.nio.Connection
Returns the clock time in milliseconds of the most recent read using this connection.
lastReadTimeMillis() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
lastWriteTimeMillis() - Method in interface com.hazelcast.nio.Connection
Returns the clock time in milliseconds of the most recent write using this connection.
lastWriteTimeMillis() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
LatchKey - Class in com.hazelcast.concurrent.countdownlatch
 
LatchKey(String) - Constructor for class com.hazelcast.concurrent.countdownlatch.LatchKey
 
LatestAccessCacheMergePolicy - Class in com.hazelcast.cache.merge
Merges cache entries from source to destination cache if the source entry has been accessed more recently than the destination entry.
LatestAccessCacheMergePolicy() - Constructor for class com.hazelcast.cache.merge.LatestAccessCacheMergePolicy
 
LatestAccessMergePolicy<V,T extends MergingLastAccessTime<V>> - Class in com.hazelcast.spi.merge
Merges data structure entries from source to destination data structure if the source entry has been accessed more recently than the destination entry.
LatestAccessMergePolicy() - Constructor for class com.hazelcast.spi.merge.LatestAccessMergePolicy
 
LatestUpdateMapMergePolicy - Class in com.hazelcast.map.merge
Merges map entries from source to destination map if the source entry was updated more recently than the destination entry.
LatestUpdateMapMergePolicy() - Constructor for class com.hazelcast.map.merge.LatestUpdateMapMergePolicy
 
LatestUpdateMapMergePolicy - Class in com.hazelcast.replicatedmap.merge
Merges replicated map entries from source to destination map if the source entry was updated more recently than the destination entry.
LatestUpdateMergePolicy<V,T extends MergingLastUpdateTime<V>> - Class in com.hazelcast.spi.merge
Merges data structure entries from source to destination data structure if the source entry was updated more frequently than the destination entry.
LatestUpdateMergePolicy() - Constructor for class com.hazelcast.spi.merge.LatestUpdateMergePolicy
 
lazy(Supplier<Traverser<T>>) - Static method in class com.hazelcast.jet.Traversers
Flattens a supplier of traverser into a lazy-initialized traverser.
LeaderDemotedException - Exception in com.hazelcast.cp.exception
A CPSubsystemException which is thrown when an appended but not-committed entry is truncated by the new leader.
LeaderDemotedException(Endpoint, Endpoint) - Constructor for exception com.hazelcast.cp.exception.LeaderDemotedException
 
leaseTime - Variable in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
leftKeyFn() - Method in class com.hazelcast.jet.pipeline.JoinClause
Returns the left-hand key extractor function.
LegacyCacheConfig<K,V> - Class in com.hazelcast.config
Contains all the configuration for the ICache (used for backward compatibility).
LegacyCacheConfig() - Constructor for class com.hazelcast.config.LegacyCacheConfig
 
LegacyCacheConfig(CacheConfig<K, V>) - Constructor for class com.hazelcast.config.LegacyCacheConfig
 
LegacyCacheEvictionConfig - Class in com.hazelcast.config
Configuration for cache eviction (used for backward compatibility).
LegacyCacheEvictionConfig() - Constructor for class com.hazelcast.config.LegacyCacheEvictionConfig
 
LegacyCacheEvictionConfig(CacheEvictionConfig) - Constructor for class com.hazelcast.config.LegacyCacheEvictionConfig
 
LegacyMatchingPointConfigPatternMatcher - Class in com.hazelcast.config.matcher
Deprecated.
LegacyMatchingPointConfigPatternMatcher() - Constructor for class com.hazelcast.config.matcher.LegacyMatchingPointConfigPatternMatcher
Deprecated.
 
LegacyWildcardConfigPatternMatcher - Class in com.hazelcast.config.matcher
Deprecated.
LegacyWildcardConfigPatternMatcher() - Constructor for class com.hazelcast.config.matcher.LegacyWildcardConfigPatternMatcher
Deprecated.
 
length() - Method in interface com.hazelcast.security.Parameters
 
lessEqual(String, Comparable) - Static method in class com.hazelcast.jet.pipeline.GenericPredicates
lessEqual(Comparable) - Method in class com.hazelcast.query.EntryObject
 
lessEqual(String, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates a less than or equal to predicate that will pass items if the value stored under the given item attribute is less than or equal to the given value.
lessThan(String, Comparable) - Static method in class com.hazelcast.jet.pipeline.GenericPredicates
lessThan(Comparable) - Method in class com.hazelcast.query.EntryObject
 
lessThan(String, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates a less than predicate that will pass items if the value stored under the given item attribute is less than the given value.
LFU_EVICTION_POLICY - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
LFUEvictionPolicy - Class in com.hazelcast.map.eviction
LFU eviction policy for an IMap
LFUEvictionPolicy() - Constructor for class com.hazelcast.map.eviction.LFUEvictionPolicy
 
LifecycleEvent - Class in com.hazelcast.core
Lifecycle events are fired when the HazelcastInstance state changes.
LifecycleEvent(LifecycleEvent.LifecycleState) - Constructor for class com.hazelcast.core.LifecycleEvent
 
LifecycleEvent.LifecycleState - Enum in com.hazelcast.core
Lifecycle states
LifecycleListener - Interface in com.hazelcast.core
Listener object for listening to lifecycle events of the Hazelcast instance
LifecycleMapper<KeyIn,ValueIn,KeyOut,ValueOut> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
LifecycleMapperAdapter<KeyIn,ValueIn,KeyOut,ValueOut> - Class in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
LifecycleMapperAdapter() - Constructor for class com.hazelcast.mapreduce.LifecycleMapperAdapter
Deprecated.
 
LifecycleService - Interface in com.hazelcast.core
LifecycleService allows you to shutdown, terminate, and listen to LifecycleEvents on HazelcastInstance.
LifecycleServiceImpl - Class in com.hazelcast.instance
 
LifecycleServiceImpl(HazelcastInstanceImpl) - Constructor for class com.hazelcast.instance.LifecycleServiceImpl
 
like(String, String) - Static method in class com.hazelcast.jet.pipeline.GenericPredicates
like(String, String) - Static method in class com.hazelcast.query.Predicates
Creates a like predicate that will pass items if the given pattern matches the value stored under the given item attribute.
limit(Iterator<R>, int) - Static method in class com.hazelcast.util.IterableUtil
 
limitingLag(long) - Static method in interface com.hazelcast.jet.core.WatermarkPolicy
Maintains a watermark that lags behind the top observed timestamp by the given amount.
LINE_SEPARATOR - Static variable in class com.hazelcast.util.StringUtil
Points to the System property 'line.separator'.
linearTrend(ToLongFunctionEx<T>, ToLongFunctionEx<T>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that computes a linear trend over the items.
LINEBR - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.common.CharConstants
 
LineReader - Interface in com.hazelcast.console
Reads a line of input.
LinTrendAccumulator - Class in com.hazelcast.jet.accumulator
Maintains the components needed to compute the linear regression on a set of (long, long) pairs.
LinTrendAccumulator() - Constructor for class com.hazelcast.jet.accumulator.LinTrendAccumulator
Constructs a new accumulator with all components at zero.
LinTrendAccumulator(long, BigInteger, BigInteger, BigInteger, BigInteger) - Constructor for class com.hazelcast.jet.accumulator.LinTrendAccumulator
Creates a new accumulator with the given components.
list(String) - Static method in class com.hazelcast.jet.pipeline.Sinks
Returns a sink that adds the items it receives to a Hazelcast IList with the specified name.
list(IList<? super T>) - Static method in class com.hazelcast.jet.pipeline.Sinks
Returns a sink that adds the items it receives to a Hazelcast IList with the specified name.
list(String) - Static method in class com.hazelcast.jet.pipeline.Sources
Returns a source that emits items retrieved from a Hazelcast IList.
list(IList<? extends T>) - Static method in class com.hazelcast.jet.pipeline.Sources
Returns a source that emits items retrieved from a Hazelcast IList.
LIST_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
ListConfig - Class in com.hazelcast.config
Contains the configuration for an IList.
ListConfig() - Constructor for class com.hazelcast.config.ListConfig
 
ListConfig(String) - Constructor for class com.hazelcast.config.ListConfig
 
ListConfig(ListConfig) - Constructor for class com.hazelcast.config.ListConfig
 
ListConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
ListConfigReadOnly(ListConfig) - Constructor for class com.hazelcast.config.ListConfigReadOnly
Deprecated.
 
LISTENER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
LISTENER_INSTANCE - Static variable in class com.hazelcast.security.permission.ActionConstants
 
LISTENER_MEMBER - Static variable in class com.hazelcast.security.permission.ActionConstants
 
LISTENER_MIGRATION - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ListenerConfig - Class in com.hazelcast.config
Contains the configuration for an EventListener.
ListenerConfig() - Constructor for class com.hazelcast.config.ListenerConfig
Creates a ListenerConfig without className/implementation.
ListenerConfig(String) - Constructor for class com.hazelcast.config.ListenerConfig
Creates a ListenerConfig with the given className.
ListenerConfig(ListenerConfig) - Constructor for class com.hazelcast.config.ListenerConfig
 
ListenerConfig(EventListener) - Constructor for class com.hazelcast.config.ListenerConfig
Creates a ListenerConfig with the given implementation.
ListenerConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
ListenerConfigReadOnly(ListenerConfig) - Constructor for class com.hazelcast.config.ListenerConfigReadOnly
Deprecated.
 
listenerConfigurations - Variable in class com.hazelcast.config.AbstractCacheConfig
The CacheEntryListenerConfigurations for the Configuration.
ListenerWrapperEventFilter - Interface in com.hazelcast.spi
Contract point for EventFilter instances these wrap listeners.
listJobs(JetCommandLine.Verbosity, boolean) - Method in class com.hazelcast.jet.server.JetCommandLine
 
ListPermission - Class in com.hazelcast.security.permission
 
ListPermission(String, String...) - Constructor for class com.hazelcast.security.permission.ListPermission
 
listSnapshots(JetCommandLine.Verbosity, boolean) - Method in class com.hazelcast.jet.server.JetCommandLine
 
LITE_MEMBER_SELECTOR - Static variable in class com.hazelcast.cluster.memberselector.MemberSelectors
A MemberSelector instance that selects only lite members that own no partition
liteMember - Variable in class com.hazelcast.instance.AbstractMember
 
liteMember(boolean) - Method in class com.hazelcast.instance.MemberImpl.Builder
 
LiveOperations - Interface in com.hazelcast.spi
InvocationMonitor passes instances of this type to each LiveOperationsTracker so it can contribute the call IDs of invocations it is responsible for.
LiveOperationsTracker - Interface in com.hazelcast.spi
Can be implemented by a Service to track live operations.
load(String) - Static method in class com.hazelcast.config.ConfigLoader
 
load(K) - Method in interface com.hazelcast.core.MapLoader
Loads the value of a given key.
load(K) - Method in class com.hazelcast.core.MapStoreAdapter
Loads the value of a given key.
load(Long) - Method in interface com.hazelcast.core.QueueStore
Loads the value of a given key.
load(long) - Method in interface com.hazelcast.core.RingbufferStore
Loads the value of a given sequence.
Load - Class in com.hazelcast.org.snakeyaml.engine.v1.api
Common way to load Java instance(s)
Load(LoadSettings) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.api.Load
Create instance to parse the incoming YAML data and create Java instances
Load(LoadSettings, BaseConstructor) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.api.Load
Create instance to parse the incoming YAML data and create Java instances
load(Map<K, V>) - Method in interface com.hazelcast.scheduledexecutor.StatefulTask
Task callback to initialize its inner state, after a replica promotion, from the given map.
load(Class<T>, String, ClassLoader) - Static method in class com.hazelcast.util.ServiceLoader
 
loadAll(boolean) - Method in interface com.hazelcast.core.IMap
Loads all keys into the store.
loadAll(Set<K>, boolean) - Method in interface com.hazelcast.core.IMap
Loads the given keys.
loadAll(Collection<K>) - Method in interface com.hazelcast.core.MapLoader
Loads given keys.
loadAll(Collection<K>) - Method in class com.hazelcast.core.MapStoreAdapter
Loads given keys.
loadAll(Collection<Long>) - Method in interface com.hazelcast.core.QueueStore
Loads the given keys.
loadAllFromInputStream(InputStream) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.Load
Parse all YAML documents in a stream and produce corresponding Java objects.
loadAllFromReader(Reader) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.Load
Parse all YAML documents in a String and produce corresponding Java objects.
loadAllFromString(String) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.Load
Parse all YAML documents in a String and produce corresponding Java objects.
loadAllKeys() - Method in interface com.hazelcast.core.MapLoader
Loads all of the keys from the store.
loadAllKeys() - Method in class com.hazelcast.core.MapStoreAdapter
Loads all of the keys from the store.
loadAllKeys() - Method in interface com.hazelcast.core.QueueStore
Loads all of the keys from the store.
loadClass(ClassLoader, String) - Static method in class com.hazelcast.nio.ClassLoaderUtil
 
loadConfigurationFromClasspath(String) - Method in class com.hazelcast.config.AbstractConfigLocator
 
loadDefault() - Static method in class com.hazelcast.jet.config.JetConfig
Loads JetConfig using the default lookup mechanism to locate the configuration file.
loadDefault(Properties) - Static method in class com.hazelcast.jet.config.JetConfig
Loads JetConfig using the built-in lookup mechanism to locate the configuration file.
loadDefaultConfigurationFromClasspath(String) - Method in class com.hazelcast.config.AbstractConfigLocator
 
loadFactor() - Method in class com.hazelcast.util.collection.BiInt2ObjectMap
Get the load factor beyond which the map will increase size.
loadFactor() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
Get the load factor beyond which the map will increase size.
loadFactor() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
Get the load factor beyond which the map will increase size.
loadFactor() - Method in class com.hazelcast.util.collection.OAHashSet
Returns the load factor of the set
loadFromClasspath(ClassLoader, String) - Static method in class com.hazelcast.jet.config.JetConfig
Creates a JetConfig which is loaded from a classpath resource.
loadFromClasspath(ClassLoader, String, Properties) - Static method in class com.hazelcast.jet.config.JetConfig
Creates a JetConfig which is loaded from a classpath resource.
loadFromClasspath(String) - Static method in class com.hazelcast.jet.config.JetConfig
loadFromClasspath(String, Properties) - Static method in class com.hazelcast.jet.config.JetConfig
loadFromFile(File) - Static method in class com.hazelcast.jet.config.JetConfig
Creates a JetConfig based on a Hazelcast Jet configuration file (XML or YAML) and uses the System.properties to resolve variables in the file.
loadFromFile(File, Properties) - Static method in class com.hazelcast.jet.config.JetConfig
Creates a JetConfig based on a Hazelcast Jet configuration file (XML or YAML).
loadFromInputStream(InputStream) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.Load
Parse the only YAML document in a stream and produce the corresponding Java object.
loadFromReader(Reader) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.Load
Parse a YAML document and create a Java instance
loadFromStream(InputStream) - Static method in class com.hazelcast.jet.config.JetConfig
loadFromStream(InputStream, Properties) - Static method in class com.hazelcast.jet.config.JetConfig
loadFromString(String) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.Load
Parse a YAML document and create a Java instance
loadFromSystemProperty(String, String...) - Method in class com.hazelcast.config.AbstractConfigLocator
 
loadFromWorkingDirectory(String) - Method in class com.hazelcast.config.AbstractConfigLocator
 
loadMore() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
Deprecated.
loadMoreGuaranteed() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
Deprecated.
loadSchemaFile(String) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
LoadSettings - Class in com.hazelcast.org.snakeyaml.engine.v1.api
Fine tuning parsing/loading Description for all the fields can be found in the builder
LoadSettingsBuilder - Class in com.hazelcast.org.snakeyaml.engine.v1.api
Builder pattern implementation for LoadSettings
LoadSettingsBuilder() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.api.LoadSettingsBuilder
Create builder
loadXmlFromStream(InputStream) - Static method in class com.hazelcast.jet.config.JetConfig
Loads JetConfig from the supplied input stream.
loadXmlFromStream(InputStream, Properties) - Static method in class com.hazelcast.jet.config.JetConfig
Loads JetConfig from the supplied input stream.
loadXmlFromString(String) - Static method in class com.hazelcast.jet.config.JetConfig
Creates a JetConfig from the provided XML string and uses the System.properties to resolve variables in the XML.
loadXmlFromString(String, Properties) - Static method in class com.hazelcast.jet.config.JetConfig
Creates a JetConfig from the provided XML string and properties to resolve the variables in the XML.
loadYamlFromStream(InputStream) - Static method in class com.hazelcast.jet.config.JetConfig
Loads JetConfig from the supplied input stream.
loadYamlFromStream(InputStream, Properties) - Static method in class com.hazelcast.jet.config.JetConfig
Loads JetConfig from the supplied input stream.
loadYamlFromString(String) - Static method in class com.hazelcast.jet.config.JetConfig
Creates a JetConfig from the provided YAML string and uses the System.properties to resolve variables in the YAML.
loadYamlFromString(String, Properties) - Static method in class com.hazelcast.jet.config.JetConfig
Creates a JetConfig from the provided YAML string and properties to resolve the variables in the YAML.
LOCAL_MEMBER_SELECTOR - Static variable in class com.hazelcast.cluster.memberselector.MemberSelectors
A MemberSelector instance that selects only local members
LOCAL_PARALLELISM_USE_DEFAULT - Static variable in class com.hazelcast.jet.core.Vertex
The value of Vertex.localParallelism(int) with the meaning "use the default local parallelism".
LocalCacheStats - Interface in com.hazelcast.monitor
Local cache statistics to be used by MemberState implementations.
LOCALE_INTERNAL - Static variable in class com.hazelcast.util.StringUtil
LOCALE_INTERNAL is the default locale for string operations and number formatting.
LocalExecutorStats - Interface in com.hazelcast.monitor
Local executor service statistics to be used by MemberState implementations.
LocalFlakeIdGeneratorStats - Interface in com.hazelcast.monitor
local flake ID statistics to be used by MemberState implementations.
LocalGCStats - Interface in com.hazelcast.monitor
Local GC statistics to be used by MemberState implementations.
LocalIndexStats - Interface in com.hazelcast.monitor
Provides local statistics for an index to be used by MemberState implementations.
LocalInstanceStats - Interface in com.hazelcast.monitor
Base interface for local instance statistics.
localKeySet() - Method in interface com.hazelcast.core.IMap
Returns the locally owned set of keys.
localKeySet(Predicate) - Method in interface com.hazelcast.core.IMap
Returns the keys of matching locally owned entries.
localKeySet() - Method in interface com.hazelcast.core.MultiMap
Returns the locally owned set of keys.
localLock(Data, String, long, long, long) - Method in interface com.hazelcast.concurrent.lock.LockStore
Lock a specific key on a local partition only.
localLock(Data, String, long, long, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
localLock(Data, String, long, long, long) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
 
LocalLockCleanupOperation - Class in com.hazelcast.concurrent.lock.operations
Locally executed operation which unlocks a lock if it is held by a specific owner.
LocalLockCleanupOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.LocalLockCleanupOperation
This constructor should not be used to obtain an instance of this class; it exists to fulfill IdentifiedDataSerializable coding conventions.
LocalLockCleanupOperation(ObjectNamespace, Data, String) - Constructor for class com.hazelcast.concurrent.lock.operations.LocalLockCleanupOperation
 
LocalMapStats - Interface in com.hazelcast.monitor
Local map statistics to be used by MemberState implementations.
localMember() - Method in interface com.hazelcast.core.Member
Returns true if this member is the local member.
localMember(boolean) - Method in class com.hazelcast.instance.MemberImpl.Builder
 
localMember() - Method in class com.hazelcast.instance.MemberImpl
 
LocalMemberResetException - Exception in com.hazelcast.core
An exception provided to MemberLeftException as a cause when the local member is resetting itself
LocalMemberResetException(String) - Constructor for exception com.hazelcast.core.LocalMemberResetException
 
LocalMemoryStats - Interface in com.hazelcast.monitor
Local memory statistics to be used by MemberState implementations.
LocalMultiMapStats - Interface in com.hazelcast.monitor
Local multi map statistics to be used by MemberState implementations.
LocalOperationStats - Interface in com.hazelcast.monitor
Local operation statistics to be used by MemberState implementations.
localParallelism() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
Returns the number of processors that each ProcessorSupplier will be asked to create once deserialized on each member.
localParallelism() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
 
localParallelism(int) - Method in class com.hazelcast.jet.core.Vertex
Sets the number of processors corresponding to this vertex that will be created on each member.
LocalPNCounterStats - Interface in com.hazelcast.monitor
Local statistics of a single PN counter to be used by MemberState implementations.
localProcessorIndex() - Method in interface com.hazelcast.jet.core.Processor.Context
Returns the index of the processor among all the processors created for this vertex on a single node: it's a unique node-wide index.
localProcessorIndex() - Method in class com.hazelcast.jet.core.test.TestProcessorContext
 
LocalQueueStats - Interface in com.hazelcast.monitor
Local queue statistics to be used by MemberState implementations.
LocalRecordStoreStats - Interface in com.hazelcast.monitor
Local record store statistics to be used by MemberState implementations.
LocalReplicatedMapStats - Interface in com.hazelcast.monitor
Local replicated map statistics to be used by MemberState implementations.
LocalTopicStats - Interface in com.hazelcast.monitor
Local topic statistics to be used by MemberState implementations.
LocalWanPublisherStats - Interface in com.hazelcast.monitor
Local WAN publisher statistics to be used by MemberState implementations.
LocalWanStats - Interface in com.hazelcast.monitor
Local WAN statistics to be used by MemberState implementations.
locateConfig(String) - Static method in class com.hazelcast.config.ConfigLoader
 
locateDefault() - Method in class com.hazelcast.config.AbstractConfigLocator
Locates the default configuration file.
locateDefault() - Method in class com.hazelcast.config.XmlConfigLocator
 
locateDefault() - Method in class com.hazelcast.config.YamlConfigLocator
 
locateEverywhere() - Method in class com.hazelcast.config.AbstractConfigLocator
 
locateFromSystemProperty() - Method in class com.hazelcast.config.AbstractConfigLocator
Locates the configuration file in a system property.
locateFromSystemProperty() - Method in class com.hazelcast.config.XmlConfigLocator
 
locateFromSystemProperty() - Method in class com.hazelcast.config.YamlConfigLocator
 
locateInWorkDir() - Method in class com.hazelcast.config.AbstractConfigLocator
Locates the configuration file in the working directory.
locateInWorkDir() - Method in class com.hazelcast.config.XmlConfigLocator
 
locateInWorkDir() - Method in class com.hazelcast.config.YamlConfigLocator
 
locateInWorkDirOrOnClasspath() - Method in class com.hazelcast.config.AbstractConfigLocator
 
locateOnClasspath() - Method in class com.hazelcast.config.AbstractConfigLocator
Locates the configuration file on the classpath.
locateOnClasspath() - Method in class com.hazelcast.config.XmlConfigLocator
 
locateOnClasspath() - Method in class com.hazelcast.config.YamlConfigLocator
 
LOCK - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
lock() - Method in class com.hazelcast.concurrent.lock.LockProxy
 
lock(long, TimeUnit) - Method in class com.hazelcast.concurrent.lock.LockProxy
 
lock(NodeEngine, Data) - Method in class com.hazelcast.concurrent.lock.LockProxySupport
 
lock(NodeEngine, Data, long) - Method in class com.hazelcast.concurrent.lock.LockProxySupport
 
lock(Data, String, long, long, long) - Method in interface com.hazelcast.concurrent.lock.LockStore
Lock a specific key.
lock(Data, String, long, long, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
lock(Data, String, long, long, long) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
 
lock() - Method in interface com.hazelcast.core.ILock
Deprecated.
lock(long, TimeUnit) - Method in interface com.hazelcast.core.ILock
Deprecated.
Acquires the lock for the specified lease time.
lock(K) - Method in interface com.hazelcast.core.IMap
Acquires the lock for the specified key.
lock(K, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Acquires the lock for the specified key for the specified lease time.
lock(K) - Method in interface com.hazelcast.core.MultiMap
Acquires a lock for the specified key.
lock(K, long, TimeUnit) - Method in interface com.hazelcast.core.MultiMap
Acquires the lock for the specified key for the specified lease time.
lock() - Method in interface com.hazelcast.cp.lock.FencedLock
Acquires the lock.
LOCK_BACKUP - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
LOCK_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
LOCK_MAX_LEASE_TIME_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
LOCK_REPLICATION - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
LOCK_RESOURCE - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
LOCK_STORE - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
LockAcquireLimitReachedException - Exception in com.hazelcast.cp.lock.exception
Thrown when the current lock holder could not acquired the lock reentrantly because the configured lock acquire limit is reached.
LockAcquireLimitReachedException() - Constructor for exception com.hazelcast.cp.lock.exception.LockAcquireLimitReachedException
 
LockAcquireLimitReachedException(String) - Constructor for exception com.hazelcast.cp.lock.exception.LockAcquireLimitReachedException
 
lockAndGetFence() - Method in interface com.hazelcast.cp.lock.FencedLock
Acquires the lock and returns the fencing token assigned to the current thread for this lock acquire.
LockAware - Interface in com.hazelcast.map
Determines if the object implementing this interface is locked or not.
LockBackupOperation - Class in com.hazelcast.concurrent.lock.operations
 
LockBackupOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.LockBackupOperation
 
LockBackupOperation(ObjectNamespace, Data, long, long, String) - Constructor for class com.hazelcast.concurrent.lock.operations.LockBackupOperation
 
LockConfig - Class in com.hazelcast.config
Contains the configuration for the ILock.
LockConfig() - Constructor for class com.hazelcast.config.LockConfig
 
LockConfig(String) - Constructor for class com.hazelcast.config.LockConfig
Creates a LockConfig with the provided name.
LockConfig(LockConfig) - Constructor for class com.hazelcast.config.LockConfig
Clones a LockConfig
LockConfig(String, LockConfig) - Constructor for class com.hazelcast.config.LockConfig
Creates a new LockConfig by cloning an existing config and overriding the name.
LockDataSerializerHook - Class in com.hazelcast.concurrent.lock
 
LockDataSerializerHook() - Constructor for class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
LockEvictionProcessor - Class in com.hazelcast.concurrent.lock
 
LockEvictionProcessor(NodeEngine, ObjectNamespace) - Constructor for class com.hazelcast.concurrent.lock.LockEvictionProcessor
 
LockInterceptorService<T> - Interface in com.hazelcast.spi
Interface to be implemented by services that need to intercept lock operation for distributed objects it manages.
lockInterruptibly() - Method in class com.hazelcast.concurrent.lock.LockProxy
 
lockInterruptibly() - Method in interface com.hazelcast.cp.lock.FencedLock
Acquires the lock unless the current thread is interrupted.
lockInterruptly(NodeEngine, Data) - Method in class com.hazelcast.concurrent.lock.LockProxySupport
 
lockInterruptly(NodeEngine, Data, long) - Method in class com.hazelcast.concurrent.lock.LockProxySupport
 
LockOperation - Class in com.hazelcast.concurrent.lock.operations
 
LockOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.LockOperation
 
LockOperation(ObjectNamespace, Data, long, long, long) - Constructor for class com.hazelcast.concurrent.lock.operations.LockOperation
 
LockOperation(ObjectNamespace, Data, long, long, long, long) - Constructor for class com.hazelcast.concurrent.lock.operations.LockOperation
 
LockOwnershipLostException - Exception in com.hazelcast.cp.lock.exception
Thrown when an endpoint (either a Hazelcast server or a client) interacts with a FencedLock instance after its CP session is closed in the underlying CP group and its lock ownership is cancelled.
LockOwnershipLostException() - Constructor for exception com.hazelcast.cp.lock.exception.LockOwnershipLostException
 
LockOwnershipLostException(String) - Constructor for exception com.hazelcast.cp.lock.exception.LockOwnershipLostException
 
LockPermission - Class in com.hazelcast.security.permission
 
LockPermission(String, String...) - Constructor for class com.hazelcast.security.permission.LockPermission
 
LockProxy - Class in com.hazelcast.concurrent.lock
 
LockProxy(NodeEngine, LockServiceImpl, String) - Constructor for class com.hazelcast.concurrent.lock.LockProxy
 
LockProxySupport - Class in com.hazelcast.concurrent.lock
 
LockProxySupport(ObjectNamespace, long) - Constructor for class com.hazelcast.concurrent.lock.LockProxySupport
 
LockReplicationOperation - Class in com.hazelcast.concurrent.lock.operations
 
LockReplicationOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.LockReplicationOperation
 
LockReplicationOperation(LockStoreContainer, int, int) - Constructor for class com.hazelcast.concurrent.lock.operations.LockReplicationOperation
 
LockReplicationOperation(LockStoreContainer, int, int, Collection<ServiceNamespace>) - Constructor for class com.hazelcast.concurrent.lock.operations.LockReplicationOperation
 
LockResource - Interface in com.hazelcast.concurrent.lock
A lock for a specific key in a specific namespace.
LockService - Interface in com.hazelcast.concurrent.lock
 
LockServiceImpl - Class in com.hazelcast.concurrent.lock
 
LockServiceImpl(NodeEngine) - Constructor for class com.hazelcast.concurrent.lock.LockServiceImpl
 
LockStore - Interface in com.hazelcast.concurrent.lock
A container for multiple locks.
LockStoreContainer - Class in com.hazelcast.concurrent.lock
 
LockStoreContainer(LockServiceImpl, int) - Constructor for class com.hazelcast.concurrent.lock.LockStoreContainer
 
LockStoreImpl - Class in com.hazelcast.concurrent.lock
 
LockStoreImpl() - Constructor for class com.hazelcast.concurrent.lock.LockStoreImpl
 
LockStoreImpl(LockService, ObjectNamespace, EntryTaskScheduler<Data, Integer>, int, int) - Constructor for class com.hazelcast.concurrent.lock.LockStoreImpl
 
LockStoreInfo - Interface in com.hazelcast.concurrent.lock
 
LockStoreProxy - Class in com.hazelcast.concurrent.lock
Proxy to a LockStoreImpl.
LockStoreProxy(LockStoreContainer, ObjectNamespace) - Constructor for class com.hazelcast.concurrent.lock.LockStoreProxy
 
LockWaitNotifyKey - Class in com.hazelcast.concurrent.lock
 
LockWaitNotifyKey(ObjectNamespace, Data) - Constructor for class com.hazelcast.concurrent.lock.LockWaitNotifyKey
 
log(Level, String) - Method in interface com.hazelcast.logging.ILogger
Logs a message at the given level.
log(Level, String, Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a message with an associated throwable at the given level.
log(LogEvent) - Method in interface com.hazelcast.logging.ILogger
Logs a LogEvent.
log(LogEvent) - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
 
log(Level, String) - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
 
log(Level, String, Throwable) - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
 
log(LogEvent) - Method in interface com.hazelcast.logging.LogListener
 
log2(int) - Static method in class com.hazelcast.util.QuickMath
Return the log 2 result for this int.
log2(long) - Static method in class com.hazelcast.util.QuickMath
Return the log 2 result for this long.
Log4j2Factory - Class in com.hazelcast.logging
Logging to Log4j 2.x.
Log4j2Factory() - Constructor for class com.hazelcast.logging.Log4j2Factory
 
Log4j2Factory.Log4j2Logger - Class in com.hazelcast.logging
 
Log4j2Logger(ExtendedLogger) - Constructor for class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
 
Log4jFactory - Class in com.hazelcast.logging
 
Log4jFactory() - Constructor for class com.hazelcast.logging.Log4jFactory
 
logAllExceptions(ILogger, String, Level) - Static method in class com.hazelcast.util.FutureUtil
This ExceptionHandler rethrows ExecutionExceptions and logs MemberLeftExceptions to the log.
logAllExceptions(String, Level) - Static method in class com.hazelcast.util.FutureUtil
This ExceptionHandler rethrows ExecutionExceptions and logs MemberLeftExceptions to the log.
logAllExceptions(ILogger, Level) - Static method in class com.hazelcast.util.FutureUtil
This ExceptionHandler rethrows ExecutionExceptions and logs MemberLeftExceptions to the log.
logAllExceptions(Level) - Static method in class com.hazelcast.util.FutureUtil
This ExceptionHandler rethrows ExecutionExceptions and logs MemberLeftExceptions to the log.
logError(Throwable) - Method in class com.hazelcast.spi.Operation
Logs Exception/Error thrown during operation execution.
LogEvent - Class in com.hazelcast.logging
 
LogEvent(LogRecord, Member) - Constructor for class com.hazelcast.logging.LogEvent
 
logger - Variable in class com.hazelcast.instance.DefaultNodeExtension
 
logger() - Method in interface com.hazelcast.jet.core.Processor.Context
Return a logger for the processor
logger() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
Returns a logger for the associated ProcessorMetaSupplier.
logger() - Method in interface com.hazelcast.jet.core.ProcessorSupplier.Context
Returns a logger for the associated ProcessorSupplier.
logger - Variable in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
 
logger() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
 
logger(FunctionEx<? super T, String>) - Static method in class com.hazelcast.jet.pipeline.Sinks
Returns a sink that logs all the data items it receives, at the INFO level to the log category WriteLoggerP.
logger() - Static method in class com.hazelcast.jet.pipeline.Sinks
Convenience for Sinks.logger(FunctionEx) with Object.toString() as the toStringFn.
Logger - Class in com.hazelcast.logging
Provides static utilities to access the global shared logging machinery.
LoggerFactory - Interface in com.hazelcast.logging
 
LoggerFactorySupport - Class in com.hazelcast.logging
 
LoggerFactorySupport() - Constructor for class com.hazelcast.logging.LoggerFactorySupport
 
loggerName() - Method in class com.hazelcast.jet.core.test.TestProcessorContext
 
loggerName() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
 
loggerName() - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
 
LOGGING_TYPE - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
LoggingScheduledExecutor - Class in com.hazelcast.util.executor
LoggingScheduledExecutor(ILogger, int, ThreadFactory) - Constructor for class com.hazelcast.util.executor.LoggingScheduledExecutor
 
LoggingScheduledExecutor(ILogger, int, ThreadFactory, boolean) - Constructor for class com.hazelcast.util.executor.LoggingScheduledExecutor
 
LoggingScheduledExecutor(ILogger, int, ThreadFactory, RejectedExecutionHandler) - Constructor for class com.hazelcast.util.executor.LoggingScheduledExecutor
 
LoggingScheduledExecutor(ILogger, int, ThreadFactory, boolean, RejectedExecutionHandler) - Constructor for class com.hazelcast.util.executor.LoggingScheduledExecutor
 
loggingService - Variable in class com.hazelcast.instance.Node
 
LoggingService - Interface in com.hazelcast.logging
 
LoggingServiceImpl - Class in com.hazelcast.logging
 
LoggingServiceImpl(String, String, BuildInfo) - Constructor for class com.hazelcast.logging.LoggingServiceImpl
 
LoginModuleConfig - Class in com.hazelcast.config
Configuration for Login Module
LoginModuleConfig() - Constructor for class com.hazelcast.config.LoginModuleConfig
 
LoginModuleConfig(String, LoginModuleConfig.LoginModuleUsage) - Constructor for class com.hazelcast.config.LoginModuleConfig
 
LoginModuleConfig.LoginModuleUsage - Enum in com.hazelcast.config
Usage of Login Module
LogListener - Interface in com.hazelcast.logging
 
Long2LongHashMap - Class in com.hazelcast.util.collection
A Probing hashmap specialised for long key and value pairs.
Long2LongHashMap(int, double, long) - Constructor for class com.hazelcast.util.collection.Long2LongHashMap
 
Long2LongHashMap(long) - Constructor for class com.hazelcast.util.collection.Long2LongHashMap
 
Long2LongHashMap(Long2LongHashMap) - Constructor for class com.hazelcast.util.collection.Long2LongHashMap
 
Long2LongHashMap.LongIterator - Class in com.hazelcast.util.collection
Adds an unboxed next() method to the standard Iterator interface.
Long2LongHashMap.LongLongCursor - Class in com.hazelcast.util.collection
Implements the cursor.
Long2ObjectHashMap<V> - Class in com.hazelcast.util.collection
Map implementation specialised for long keys using open addressing and linear probing for cache efficient access.
Long2ObjectHashMap() - Constructor for class com.hazelcast.util.collection.Long2ObjectHashMap
 
Long2ObjectHashMap(int) - Constructor for class com.hazelcast.util.collection.Long2ObjectHashMap
 
Long2ObjectHashMap(int, double) - Constructor for class com.hazelcast.util.collection.Long2ObjectHashMap
Construct a new map allowing a configuration for initial capacity and load factor.
Long2ObjectHashMap.KeyIterator - Class in com.hazelcast.util.collection
Adds an unboxed next() method to the standard Iterator interface.
Long2ObjectHashMap.KeySet - Class in com.hazelcast.util.collection
Adds non-boxing methods to the standard Set interface.
LONG_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
LONG_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
LONG_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
Long size in bytes
LongAccumulator - Class in com.hazelcast.jet.accumulator
Mutable container of a long value.
LongAccumulator() - Constructor for class com.hazelcast.jet.accumulator.LongAccumulator
Creates a new instance with value == 0.
LongAccumulator(long) - Constructor for class com.hazelcast.jet.accumulator.LongAccumulator
Creates a new instance with the specified value.
longAvg() - Static method in class com.hazelcast.aggregation.Aggregators
 
longAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
longAvg() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to calculate the long average of all supplied values.
This aggregation is similar to:
LongDoubleAccumulator - Class in com.hazelcast.jet.accumulator
Mutable container of a long and a double value.
LongDoubleAccumulator() - Constructor for class com.hazelcast.jet.accumulator.LongDoubleAccumulator
Creates a new instance with values equal to 0.
LongDoubleAccumulator(long, double) - Constructor for class com.hazelcast.jet.accumulator.LongDoubleAccumulator
Creates a new instance with the specified values.
longForEach(LongLongConsumer) - Method in class com.hazelcast.util.collection.Long2LongHashMap
Primitive specialised forEach implementation.
LongFunction<R> - Interface in com.hazelcast.util.function
Represents a function that accepts a long-valued argument and produces a result.
LongHashSet - Class in com.hazelcast.util.collection
Simple fixed-size long hashset.
LongHashSet(int, long) - Constructor for class com.hazelcast.util.collection.LongHashSet
 
LongHashSet(long[], long) - Constructor for class com.hazelcast.util.collection.LongHashSet
 
LongIterator - Class in com.hazelcast.util.collection
An iterator for a sequence of primitive integers.
LongIterator(long, long[]) - Constructor for class com.hazelcast.util.collection.LongIterator
Construct an Iterator over an array of primitives longs.
LongLongAccumulator - Class in com.hazelcast.jet.accumulator
Mutable container of two long values.
LongLongAccumulator() - Constructor for class com.hazelcast.jet.accumulator.LongLongAccumulator
Creates a new instance with values equal to 0.
LongLongAccumulator(long, long) - Constructor for class com.hazelcast.jet.accumulator.LongLongAccumulator
Creates a new instance with the specified values.
LongLongConsumer - Interface in com.hazelcast.util.function
This is a (long,long) primitive specialisation of a BiConsumer
LongLongCursor() - Constructor for class com.hazelcast.util.collection.Long2LongHashMap.LongLongCursor
 
longMax() - Static method in class com.hazelcast.aggregation.Aggregators
 
longMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
longMax() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to find the long maximum of all supplied values.
This aggregation is similar to:
longMin() - Static method in class com.hazelcast.aggregation.Aggregators
 
longMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
longMin() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to find the long minimum of all supplied values.
This aggregation is similar to:
longSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
longSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
longSum() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to calculate the long sum of all supplied values.
This aggregation is similar to:
lookupNamespaceURI(String) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
lookupPrefix(String) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
lowerCaseFirstChar(String) - Static method in class com.hazelcast.util.StringUtil
Converts the first character to lower case.
lowerCaseInternal(String) - Static method in class com.hazelcast.util.StringUtil
HC specific settings, operands etc.
LRU_EVICTION_POLICY - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
LRUEvictionPolicy - Class in com.hazelcast.map.eviction
LRU eviction policy for an IMap
LRUEvictionPolicy() - Constructor for class com.hazelcast.map.eviction.LRUEvictionPolicy
 

M

main(String...) - Static method in class com.hazelcast.config.replacer.EncryptionReplacer
 
main(String[]) - Static method in class com.hazelcast.console.ConsoleApp
Starts the test application.
main(String[]) - Static method in class com.hazelcast.core.server.StartServer
Creates a server instance of Hazelcast.
main(String[]) - Static method in class com.hazelcast.jet.server.JetCommandLine
 
main(String[]) - Static method in class com.hazelcast.jet.server.StartServer
Creates a server instance of Hazelcast Jet.
MAJOR_ARRAY_ELEMENT_FIRST - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MAJOR_ARRAY_ELEMENT_NEXT - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MAJOR_CLOSED - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
State after non-blocking input source has indicated that no more input is forthcoming AND we have exhausted all the input
MAJOR_INITIAL - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
State right after parser has been constructed, before seeing the first byte to handle possible (but optional) BOM.
MAJOR_MINOR_VERSION_COMPARATOR - Static variable in class com.hazelcast.version.MemberVersion
Version comparator that takes into account only major & minor version, disregarding patch version number.
MAJOR_OBJECT_FIELD_FIRST - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MAJOR_OBJECT_FIELD_NEXT - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MAJOR_OBJECT_VALUE - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MAJOR_ROOT - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
State right after parser a root value has been finished, but next token has not yet been recognized.
makeChild(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
Factory method used to create actual symbol table instance to use for parsing.
makeChild(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
"Factory" method; will create a new child instance of this symbol table.
ManagedContext - Interface in com.hazelcast.core
Container managed context, such as Spring, Guice and etc.
ManagedExecutorService - Interface in com.hazelcast.util.executor
 
ManagedService - Interface in com.hazelcast.spi
An interface that can be implemented by an SPI Service to receive lifecycle calls: initialization shutdown reset
ManagedThread(Runnable, String, int) - Constructor for class com.hazelcast.util.executor.PoolExecutorThreadFactory.ManagedThread
 
ManagementCenterConfig - Class in com.hazelcast.config
Contains the configuration for a Management Center.
ManagementCenterConfig() - Constructor for class com.hazelcast.config.ManagementCenterConfig
 
ManagementCenterConfig(String, int) - Constructor for class com.hazelcast.config.ManagementCenterConfig
 
map(List<AliasedDiscoveryConfig<?>>) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Maps aliased discovery strategy configs into discovery strategy configs.
map(FunctionEx<? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
 
map(FunctionEx<? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
Attaches a mapping stage which applies the given function to each input item independently and emits the function's result as the output item.
map(String) - Static method in class com.hazelcast.jet.pipeline.Sinks
Returns a sink that puts Map.Entrys it receives into a Hazelcast IMap with the specified name.
map(IMap<? super K, ? super V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
Returns a sink that puts Map.Entrys it receives into the given Hazelcast IMap.
map(String) - Static method in class com.hazelcast.jet.pipeline.Sources
Returns a source that fetches entries from a local Hazelcast IMap with the specified name and emits them as Map.Entry.
map(IMap<? extends K, ? extends V>) - Static method in class com.hazelcast.jet.pipeline.Sources
Returns a source that fetches entries from the given Hazelcast IMap and emits them as Map.Entry.
map(String, Predicate<? super K, ? super V>, Projection<? super Map.Entry<K, V>, ? extends T>) - Static method in class com.hazelcast.jet.pipeline.Sources
Returns a source that fetches entries from a local Hazelcast IMap with the specified name.
map(IMap<? extends K, ? extends V>, Predicate<? super K, ? super V>, Projection<? super Map.Entry<K, V>, ? extends T>) - Static method in class com.hazelcast.jet.pipeline.Sources
Returns a source that fetches entries from the given Hazelcast IMap.
map(String, Predicate<? super K, ? super V>, FunctionEx<? super Map.Entry<K, V>, ? extends T>) - Static method in class com.hazelcast.jet.pipeline.Sources
Convenience for Sources.map(String, Predicate, Projection) which uses a FunctionEx as the projection function.
map(IMap<? extends K, ? extends V>, Predicate<? super K, ? super V>, FunctionEx<? super Map.Entry<K, V>, ? extends T>) - Static method in class com.hazelcast.jet.pipeline.Sources
Convenience for Sources.map(IMap, Predicate, Projection) which uses a FunctionEx as the projection function.
map(FunctionEx<? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
 
map(Function<? super T, ? extends R>) - Method in interface com.hazelcast.jet.Traverser
Returns a traverser that will emit the results of applying mapFn to this traverser's items.
map(KeyIn, ValueIn, Context<KeyOut, ValueOut>) - Method in class com.hazelcast.mapreduce.LifecycleMapperAdapter
Deprecated.
The map method is called for every single key-value pair in the bound KeyValueSource instance on this cluster node and partition.
Due to its nature of a DataGrid, Hazelcast distributes values all over the cluster and so this method is executed on multiple servers at the same time.
If you want to know more about the implementation of MapReduce algorithms read the Google Whitepaper on MapReduce.
map(KeyIn, ValueIn, Context<KeyOut, ValueOut>) - Method in interface com.hazelcast.mapreduce.Mapper
Deprecated.
The map method is called for every single key-value pair in the bound KeyValueSource instance on this cluster node and partition.
Due to its nature of a DataGrid, Hazelcast distributes values all over the cluster and so this method is executed on multiple servers at the same time.
If you want to know more about the implementation of MapReduce algorithms read the Google Whitepaper on MapReduce.
MAP - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.nodes.Tag
 
map(Iterable<T>, IFunction<T, R>) - Static method in class com.hazelcast.util.IterableUtil
Transform the Iterable by applying a function to each element
map(Iterator<T>, IFunction<T, R>) - Static method in class com.hazelcast.util.IterableUtil
Transform the Iterator by applying a function to each element
MAP_ATTRIBUTE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MAP_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MAP_EVICTION_BATCH_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Maximum number of IMap entries Hazelcast will evict during a single eviction cycle.
MAP_EXPIRY_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
You can use MAP_EXPIRY_DELAY_SECONDS to deal with some possible edge cases, such as using EntryProcessor.
MAP_INDEX_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MAP_INVALIDATION_MESSAGE_BATCH_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Defines Near Cache invalidation event batch sending is enabled or not.
MAP_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Defines the Near Cache invalidation event batch sending frequency in seconds.
MAP_INVALIDATION_MESSAGE_BATCH_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Defines the maximum number of Near Cache invalidation events to be drained and sent to the event Near Cache in a batch.
MAP_LISTENER_TO_ENTRY_LISTENER_ADAPTER - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MAP_LOAD_ALL_KEYS_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
The name of the executor that loads the entry keys and dispatches the keys to the partition owners for value loading.
MAP_LOAD_ALL_PUBLISHES_ADDED_EVENT - Static variable in class com.hazelcast.spi.properties.GroupProperty
This property is a switch between old and new event publishing behavior of map#loadAll.
MAP_LOAD_CHUNK_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
The maximum size of the key batch sent to the partition owners for value loading and the maximum size of a key batch for which values are loaded in a single partition.
MAP_LOADER_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
Name of the map-loader executor that loads the entry values for a given key set locally on the member owning the partition which contains the keys.
MAP_PARTITION_LOST_LISTENER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MAP_REPLICA_SCHEDULED_TASK_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
MAP_STORE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MAP_WRITE_BEHIND_QUEUE_CAPACITY - Static variable in class com.hazelcast.spi.properties.GroupProperty
Setting this capacity is valid if you set MapStoreConfig.writeCoalescing to false.
MapAttributeConfig - 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.
MapAttributeConfig() - Constructor for class com.hazelcast.config.MapAttributeConfig
Creates an empty MapAttributeConfig.
MapAttributeConfig(String, String) - Constructor for class com.hazelcast.config.MapAttributeConfig
Creates a MapAttributeConfig with the given attribute and ordered setting.
MapAttributeConfig(MapAttributeConfig) - Constructor for class com.hazelcast.config.MapAttributeConfig
 
MapAttributeConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
MapAttributeConfigReadOnly(MapAttributeConfig) - Constructor for class com.hazelcast.config.MapAttributeConfigReadOnly
Deprecated.
 
mapCleared(MapEvent) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
mapCleared(MapEvent) - Method in class com.hazelcast.console.ConsoleApp
 
mapCleared(MapEvent) - Method in class com.hazelcast.core.EntryAdapter
 
mapCleared(MapEvent) - Method in interface com.hazelcast.map.listener.MapClearedListener
Invoked when all entries are removed by IMap.clear().
MapClearedListener - Interface in com.hazelcast.map.listener
Invoked after all entries are removed by IMap.clear().
MapConfig - Class in com.hazelcast.config
Contains the configuration for an IMap.
MapConfig() - Constructor for class com.hazelcast.config.MapConfig
 
MapConfig(String) - Constructor for class com.hazelcast.config.MapConfig
 
MapConfig(MapConfig) - Constructor for class com.hazelcast.config.MapConfig
 
MapConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
MapDelegatingSet<V> - Class in com.hazelcast.util.collection
Read-only collection which delegates its operations to an underlying map and a couple of functions.
MapDelegatingSet(Map<?, ?>, Supplier<Iterator<V>>, Predicate) - Constructor for class com.hazelcast.util.collection.MapDelegatingSet
 
MapEvent - Class in com.hazelcast.core
Used for map-wide events like EntryEventType.EVICT_ALL and EntryEventType.CLEAR_ALL.
MapEvent(Object, Member, int, int) - Constructor for class com.hazelcast.core.MapEvent
 
mapEventNewValue() - Static method in class com.hazelcast.jet.Util
Returns a projection that extracts the new value from an EventJournalMapEvent.
mapEventToEntry() - Static method in class com.hazelcast.jet.Util
Returns a projection that converts the EventJournalMapEvent to a Map.Entry using the event's new value as a value.
mapEvicted(MapEvent) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
mapEvicted(MapEvent) - Method in class com.hazelcast.console.ConsoleApp
 
mapEvicted(MapEvent) - Method in class com.hazelcast.core.EntryAdapter
 
mapEvicted(MapEvent) - Method in interface com.hazelcast.map.listener.MapEvictedListener
Invoked when all entries are evicted by IMap.evictAll().
MapEvictedListener - Interface in com.hazelcast.map.listener
Invoked after all entries are evicted by IMap.evictAll().
MapEvictionPolicy<K,V> - Class in com.hazelcast.map.eviction
An eviction policy takes its role after the decision that a map needs to free some memory according to one of MaxSizePolicies and it helps to find most appropriate entries to remove.
MapEvictionPolicy() - Constructor for class com.hazelcast.map.eviction.MapEvictionPolicy
 
MapIndexConfig - Class in com.hazelcast.config
Contains the configuration for an index in a map.
MapIndexConfig() - Constructor for class com.hazelcast.config.MapIndexConfig
Creates a MapIndexConfig without an attribute and with ordered set to false.
MapIndexConfig(String, boolean) - Constructor for class com.hazelcast.config.MapIndexConfig
Creates a MapIndexConfig with the given attribute and ordered setting.
MapIndexConfig(MapIndexConfig) - Constructor for class com.hazelcast.config.MapIndexConfig
 
MapIndexConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
MapIndexConfigReadOnly(MapIndexConfig) - Constructor for class com.hazelcast.config.MapIndexConfigReadOnly
Deprecated.
 
MapInterceptor - Interface in com.hazelcast.map
MapInterceptor is used to intercept changes to the map, allowing access to the values before and after adding them to the map.
mapJournal(String, PredicateEx<? super EventJournalMapEvent<K, V>>, FunctionEx<? super EventJournalMapEvent<K, V>, ? extends T>, JournalInitialPosition) - Static method in class com.hazelcast.jet.pipeline.Sources
Returns a source that will stream EventJournalMapEvents of the Hazelcast IMap with the specified name.
mapJournal(IMap<? extends K, ? extends V>, PredicateEx<? super EventJournalMapEvent<K, V>>, FunctionEx<? super EventJournalMapEvent<K, V>, ? extends T>, JournalInitialPosition) - Static method in class com.hazelcast.jet.pipeline.Sources
Returns a source that will stream EventJournalMapEvents of the given Hazelcast IMap.
mapJournal(String, JournalInitialPosition) - Static method in class com.hazelcast.jet.pipeline.Sources
Convenience for Sources.mapJournal(String, PredicateEx, FunctionEx, JournalInitialPosition) which will pass only ADDED and UPDATED events and will project the event's key and new value into a Map.Entry.
mapJournal(IMap<? extends K, ? extends V>, JournalInitialPosition) - Static method in class com.hazelcast.jet.pipeline.Sources
Convenience for Sources.mapJournal(IMap, PredicateEx, FunctionEx, JournalInitialPosition) which will pass only ADDED and UPDATED events and will project the event's key and new value into a Map.Entry.
MapListener - Interface in com.hazelcast.map.listener
A marker interface which is used to get notified upon a map or an entry event.
MapListenerToEntryListenerAdapter() - Constructor for class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
MapListenerToEntryListenerAdapter(MapListener) - Constructor for class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
MapLoader<K,V> - Interface in com.hazelcast.core
Hazelcast distributed map implementation is an in-memory data store but it can be backed by any type of data store such as RDBMS, OODBMS, or simply a file based data store.
MapLoaderLifecycleSupport - Interface in com.hazelcast.core
Provides Lifecycle support for the implementing MapLoader class.
MapMergePolicy - Interface in com.hazelcast.map.merge
Policy for merging map entries after a split-brain has been healed.
mapP(FunctionEx<? super T, ? extends R>) - Static method in class com.hazelcast.jet.core.processor.Processors
Returns a supplier of processors for a vertex which, for each received item, emits the result of applying the given mapping function to it.
MapPartitionLostEvent - Class in com.hazelcast.map
Used for providing information about the lost partition for a map
MapPartitionLostEvent(Object, Member, int, int) - Constructor for class com.hazelcast.map.MapPartitionLostEvent
 
MapPartitionLostListener - Interface in com.hazelcast.map.listener
Invoked when owner and all backups of a partition is lost for a specific map.
MapPartitionLostListenerConfig - Class in com.hazelcast.config
Configuration for MapPartitionLostListener
MapPartitionLostListenerConfig() - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfig
 
MapPartitionLostListenerConfig(String) - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfig
 
MapPartitionLostListenerConfig(MapPartitionLostListener) - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfig
 
MapPartitionLostListenerConfig(MapPartitionLostListenerConfig) - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfig
 
MapPartitionLostListenerConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
MapPartitionLostListenerConfigReadOnly(MapPartitionLostListenerConfig) - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfigReadOnly
Deprecated.
 
mapper(Mapper<KeyIn, ValueIn, KeyOut, ValueOut>) - Method in interface com.hazelcast.mapreduce.Job
Deprecated.
Defines the mapper for this task.
Mapper<KeyIn,ValueIn,KeyOut,ValueOut> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
MapPermission - Class in com.hazelcast.security.permission
 
MapPermission(String, String...) - Constructor for class com.hazelcast.security.permission.MapPermission
 
mapping(FunctionEx<? super T, ? extends U>, AggregateOperation1<? super U, A, ? extends R>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Adapts an aggregate operation that takes items of type U to one that takes items of type T, by applying the given mapping function to each item.
MappingEndEvent - Class in com.hazelcast.org.snakeyaml.engine.v1.events
Marks the end of a mapping node.
MappingEndEvent(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.events.MappingEndEvent
 
MappingEndEvent() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.events.MappingEndEvent
 
MappingJob<EntryKey,KeyIn,ValueIn> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
MappingNode - Class in com.hazelcast.org.snakeyaml.engine.v1.nodes
Represents a map.
MappingNode(Tag, boolean, List<NodeTuple>, FlowStyle, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.nodes.MappingNode
 
MappingNode(Tag, List<NodeTuple>, FlowStyle) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.nodes.MappingNode
 
MappingStartEvent - Class in com.hazelcast.org.snakeyaml.engine.v1.events
Marks the beginning of a mapping node.
MappingStartEvent(Optional<Anchor>, Optional<String>, boolean, FlowStyle, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.events.MappingStartEvent
 
MappingStartEvent(Optional<Anchor>, Optional<String>, boolean, FlowStyle) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.events.MappingStartEvent
 
mapPutEvents() - Static method in class com.hazelcast.jet.Util
MapReducePermission - Class in com.hazelcast.security.permission
To be able to map-reduce from a client in a secure environment
MapReducePermission(String, String...) - Constructor for class com.hazelcast.security.permission.MapReducePermission
 
mapStateful(SupplierEx<? extends S>, BiFunctionEx<? super S, ? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
 
mapStateful(SupplierEx<? extends S>, TriFunction<? super S, ? super K, ? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
 
mapStateful(SupplierEx<? extends S>, BiFunctionEx<? super S, ? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
Attaches a stage that performs a stateful mapping operation.
mapStateful(SupplierEx<? extends S>, TriFunction<? super S, ? super K, ? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
Attaches a stage that performs a stateful mapping operation.
mapStateful(SupplierEx<? extends S>, BiFunctionEx<? super S, ? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
 
mapStateful(long, SupplierEx<? extends S>, TriFunction<? super S, ? super K, ? super T, ? extends R>, TriFunction<? super S, ? super K, ? super Long, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
Attaches a stage that performs a stateful mapping operation.
mapStateful(SupplierEx<? extends S>, TriFunction<? super S, ? super K, ? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
 
mapStatefulP(long, FunctionEx<? super T, ? extends K>, ToLongFunctionEx<? super T>, Supplier<? extends S>, TriFunction<? super S, ? super K, ? super T, ? extends R>, TriFunction<? super S, ? super K, ? super Long, ? extends R>) - Static method in class com.hazelcast.jet.core.processor.Processors
Returns a supplier of processors for a vertex that performs a stateful mapping of its input.
MapStore<K,V> - Interface in com.hazelcast.core
Hazelcast distributed map implementation is an in-memory data store, but it can be backed by any type of data store such as RDBMS, OODBMS, NOSQL, or simply a file-based data store.
MapStoreAdapter<K,V> - Class in com.hazelcast.core
Adapter for MapStore.
MapStoreAdapter() - Constructor for class com.hazelcast.core.MapStoreAdapter
 
MapStoreConfig - Class in com.hazelcast.config
Contains the configuration for a Map Store.
MapStoreConfig() - Constructor for class com.hazelcast.config.MapStoreConfig
 
MapStoreConfig(MapStoreConfig) - Constructor for class com.hazelcast.config.MapStoreConfig
 
MapStoreConfig.InitialLoadMode - Enum in com.hazelcast.config
Initial load module
MapStoreConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
MapStoreConfigReadOnly(MapStoreConfig) - Constructor for class com.hazelcast.config.MapStoreConfigReadOnly
Deprecated.
 
MapStoreFactory<K,V> - Interface in com.hazelcast.core
Factory for MapLoader or MapStore instances, specifiable in MapStoreConfig.
mapUsingContext(ContextFactory<C>, BiFunctionEx<? super C, ? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
 
mapUsingContext(ContextFactory<C>, TriFunction<? super C, ? super K, ? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
 
mapUsingContext(ContextFactory<C>, BiFunctionEx<? super C, ? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
Attaches a mapping stage which applies the supplied function to each input item independently and emits the function's result as the output item.
mapUsingContext(ContextFactory<C>, TriFunction<? super C, ? super K, ? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
Attaches a mapping stage which applies the given function to each input item independently and emits the function's result as the output item.
mapUsingContext(ContextFactory<C>, BiFunctionEx<? super C, ? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
 
mapUsingContext(ContextFactory<C>, TriFunction<? super C, ? super K, ? super T, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
 
mapUsingContextAsync(ContextFactory<C>, BiFunctionEx<? super C, ? super T, ? extends CompletableFuture<R>>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
 
mapUsingContextAsync(ContextFactory<C>, TriFunction<? super C, ? super K, ? super T, CompletableFuture<R>>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
 
mapUsingContextAsync(ContextFactory<C>, BiFunctionEx<? super C, ? super T, ? extends CompletableFuture<R>>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
mapUsingContextAsync(ContextFactory<C>, TriFunction<? super C, ? super K, ? super T, CompletableFuture<R>>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
mapUsingContextAsync(ContextFactory<C>, BiFunctionEx<? super C, ? super T, ? extends CompletableFuture<R>>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
 
mapUsingContextAsync(ContextFactory<C>, TriFunction<? super C, ? super K, ? super T, CompletableFuture<R>>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
 
mapUsingContextAsyncP(ContextFactory<C>, FunctionEx<T, K>, BiFunctionEx<? super C, ? super T, CompletableFuture<R>>) - Static method in class com.hazelcast.jet.core.processor.Processors
mapUsingContextP(ContextFactory<C>, BiFunctionEx<? super C, ? super T, ? extends R>) - Static method in class com.hazelcast.jet.core.processor.Processors
Returns a supplier of processors for a vertex which, for each received item, emits the result of applying the given mapping function to it.
mapUsingIMap(String, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
 
mapUsingIMap(IMap<K, V>, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
 
mapUsingIMap(String, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
 
mapUsingIMap(IMap<K, V>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStageWithKey
 
mapUsingIMap(String, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
Attaches a mapping stage where for each item a lookup in the IMap with the supplied name is performed and the result of the lookup is merged with the item and emitted.
mapUsingIMap(IMap<K, V>, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
Attaches a mapping stage where for each item a lookup in the supplied IMap is performed and the result of the lookup is merged with the item and emitted.
mapUsingIMap(String, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
Attaches a mapping stage where for each item a lookup in the IMap with the supplied name using the grouping key is performed and the result of the lookup is merged with the item and emitted.
mapUsingIMap(IMap<K, V>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStageWithKey
Attaches a mapping stage where for each item a lookup in the supplied IMap using the grouping key is performed and the result of the lookup is merged with the item and emitted.
mapUsingIMap(String, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
 
mapUsingIMap(IMap<K, V>, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
 
mapUsingIMap(String, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
 
mapUsingIMap(IMap<K, V>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
 
mapUsingReplicatedMap(String, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
 
mapUsingReplicatedMap(ReplicatedMap<K, V>, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
 
mapUsingReplicatedMap(String, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
Attaches a mapping stage where for each item a lookup in the ReplicatedMap with the supplied name is performed and the result of the lookup is merged with the item and emitted.
mapUsingReplicatedMap(ReplicatedMap<K, V>, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.GeneralStage
Attaches a mapping stage where for each item a lookup in the supplied ReplicatedMap is performed and the result of the lookup is merged with the item and emitted.
mapUsingReplicatedMap(String, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
 
mapUsingReplicatedMap(ReplicatedMap<K, V>, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super T, ? super V, ? extends R>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
 
MapUtil - Class in com.hazelcast.util
Utility class for Maps
mapWithEntryProcessor(String, FunctionEx<? super E, ? extends K>, FunctionEx<? super E, ? extends EntryProcessor<K, V>>) - Static method in class com.hazelcast.jet.pipeline.Sinks
Returns a sink that uses the items it receives to create EntryProcessors it submits to a Hazelcast IMap with the specified name.
mapWithEntryProcessor(IMap<? super K, ? super V>, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends EntryProcessor<K, V>>) - Static method in class com.hazelcast.jet.pipeline.Sinks
Returns a sink that uses the items it receives to create EntryProcessors it submits to a Hazelcast IMap with the specified name.
mapWithMerging(String, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends V>, BinaryOperatorEx<V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
Returns a sink that uses the supplied functions to extract the key and value with which to update a Hazelcast IMap.
mapWithMerging(IMap<? super K, ? super V>, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends V>, BinaryOperatorEx<V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
Returns a sink that uses the supplied functions to extract the key and value with which to update a Hazelcast IMap.
mapWithMerging(String, BinaryOperatorEx<V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
mapWithMerging(IMap<? super K, V>, BinaryOperatorEx<V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
mapWithUpdating(String, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super V, ? super T, ? extends V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
Returns a sink that uses the supplied key-extracting and value-updating functions to update a Hazelcast IMap.
mapWithUpdating(IMap<? super K, ? super V>, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super V, ? super T, ? extends V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
Returns a sink that uses the supplied key-extracting and value-updating functions to update a Hazelcast IMap.
mapWithUpdating(String, BiFunctionEx<? super V, ? super E, ? extends V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
mapWithUpdating(IMap<? super K, ? super V>, BiFunctionEx<? super V, ? super E, ? extends V>) - Static method in class com.hazelcast.jet.pipeline.Sinks
mark(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.MergedStream
 
Mark - Class in com.hazelcast.org.snakeyaml.engine.v1.exceptions
It's just a record and its only use is producing nice error messages.
Mark(String, int, int, int, int[], int) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.exceptions.Mark
Creates Mark
Mark(String, int, int, int, char[], int) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.exceptions.Mark
This constructor is only for test
MarkedYamlEngineException - Exception in com.hazelcast.org.snakeyaml.engine.v1.exceptions
 
MarkedYamlEngineException(String, Optional<Mark>, String, Optional<Mark>, Throwable) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v1.exceptions.MarkedYamlEngineException
 
MarkedYamlEngineException(String, Optional<Mark>, String, Optional<Mark>) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v1.exceptions.MarkedYamlEngineException
 
markMigrated(VectorClock) - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
Marks this CRDT as migrated.
markMigrated() - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
Unconditionally marks this CRDT as migrated.
markSupported() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.MergedStream
 
mask - Variable in class com.hazelcast.security.permission.InstancePermission
 
MASK_FOR_SENSITIVE_DATA - Static variable in class com.hazelcast.config.ConfigXmlGenerator
 
MASTER_CONFIRMATION_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
since 3.10
MASTERSHIP_CLAIM_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The timeout which defines when master candidate gives up waiting for response to its mastership claim.
match(String[], String[], int) - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
 
match(AddressUtil.AddressMatcher) - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
 
match(String) - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
 
matchAnyDomain(String, Collection<String>) - Static method in class com.hazelcast.util.AddressUtil
 
matchAnyInterface(String, Collection<String>) - Static method in class com.hazelcast.util.AddressUtil
 
matchDomain(String, String) - Static method in class com.hazelcast.util.AddressUtil
 
matchElement(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
 
matches() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
 
matches(Iterable<String>, String) - Method in interface com.hazelcast.config.ConfigPatternMatcher
Returns the best match for an item name out of a list of configuration patterns.
matches(Iterable<String>, String) - Method in class com.hazelcast.config.matcher.LegacyMatchingPointConfigPatternMatcher
Deprecated.
 
matches(Iterable<String>, String) - Method in class com.hazelcast.config.matcher.LegacyWildcardConfigPatternMatcher
Deprecated.
 
matches(String, String) - Method in class com.hazelcast.config.matcher.LegacyWildcardConfigPatternMatcher
Deprecated.
This method is public to be accessible by InstancePermission.
matches(Iterable<String>, String) - Method in class com.hazelcast.config.matcher.MatchingPointConfigPatternMatcher
 
matches(Iterable<String>, String) - Method in class com.hazelcast.config.matcher.RegexConfigPatternMatcher
 
matches(Iterable<String>, String) - Method in class com.hazelcast.config.matcher.WildcardConfigPatternMatcher
 
matches(String, String) - Method in class com.hazelcast.config.matcher.WildcardConfigPatternMatcher
This method is public to be accessible by InstancePermission.
matchesElement(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
Method that may be called to see if the pointer would match array element (of a JSON Array) with given index.
matchesProperty(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
Method that may be called to see if the pointer would match property (of a JSON Object) with given name.
MatchingPointConfigPatternMatcher - Class in com.hazelcast.config.matcher
This ConfigPatternMatcher supports a simplified wildcard matching.
MatchingPointConfigPatternMatcher() - Constructor for class com.hazelcast.config.matcher.MatchingPointConfigPatternMatcher
 
matchInterface(String, String) - Static method in class com.hazelcast.util.AddressUtil
 
matchProperty(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
 
MatchStrength - Enum in com.hazelcast.com.fasterxml.jackson.core.format
Enumeration used to indicate strength of match between data format and piece of data (typically beginning of a data file).
mavenVersionFor(ClassLoader, String, String) - Static method in class com.hazelcast.com.fasterxml.jackson.core.util.VersionUtil
Deprecated.
Since 2.6: functionality not used by any official Jackson component, should be moved out if anyone needs it
MAX_BACKUP_COUNT - Static variable in class com.hazelcast.config.CacheSimpleConfig
The maximum number of backups.
MAX_BACKUP_COUNT - Static variable in class com.hazelcast.config.MapConfig
The maximum number of backups
MAX_BACKUP_COUNT - Static variable in interface com.hazelcast.spi.partition.IPartition
The maximum number of backups.
MAX_BIG_DECIMAL_SCALE - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
This value is the limit of scale allowed for serializing BigDecimal in "plain" (non-engineering) notation; intent is to prevent asymmetric attack whereupon simple eng-notation with big scale is used to generate huge "plain" serialization.
MAX_CAPACITY - Static variable in class com.hazelcast.util.collection.IntHashSet
Maximum supported capacity
MAX_CAPACITY - Static variable in class com.hazelcast.util.collection.LongHashSet
Maximum supported capacity
MAX_CONTENT_SNIPPET - Static variable in class com.hazelcast.com.fasterxml.jackson.core.JsonLocation
Include at most first 500 characters/bytes from contents; should be enough to give context, but not cause unfortunate side effects in things like logs.
MAX_ERROR_TOKEN_LENGTH - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
Maximum number of characters to include in token reported as part of error messages.
MAX_EVICTION_PERCENTAGE - Static variable in class com.hazelcast.config.MapConfig
The number of maximum eviction percentage
MAX_GROUP_SIZE - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
Maximum number of CP members for CP groups.
MAX_INDENT - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.emitter.Emitter
 
MAX_INT_D - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
MAX_INT_L - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
MAX_JOIN_MERGE_TARGET_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
MAX_JOIN_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
MAX_LONG_D - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
MAX_NO_HEARTBEAT_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The timeout which defines when a cluster member is removed because it has not sent any heartbeats.
MAX_NO_MASTER_CONFIRMATION_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
since 3.10
MAX_PENDING_CALLS_DEFAULT - Static variable in class com.hazelcast.jet.pipeline.ContextFactory
MAX_WAIT_SECONDS_BEFORE_JOIN - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
maxBy(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
maxBy(ComparatorEx<? super T>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that computes the greatest item according to the given comparator.
maxBy(Comparator<? super T>) - Static method in interface com.hazelcast.jet.function.BinaryOperatorEx
maxCollisionLength() - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
Method mostly needed by unit tests; calculates length of the longest collision chain.
MAXIMUM_PREFETCH_COUNT - Static variable in class com.hazelcast.config.FlakeIdGeneratorConfig
Maximum value for prefetch count.
maxPendingCallsPerProcessor() - Method in class com.hazelcast.jet.pipeline.ContextFactory
Returns the maximum pending calls per processor, see ContextFactory.withMaxPendingCallsPerProcessor(int).
MaxSizeConfig - Class in com.hazelcast.config
Configuration for map's capacity.
MaxSizeConfig() - Constructor for class com.hazelcast.config.MaxSizeConfig
 
MaxSizeConfig(int, MaxSizeConfig.MaxSizePolicy) - Constructor for class com.hazelcast.config.MaxSizeConfig
 
MaxSizeConfig(MaxSizeConfig) - Constructor for class com.hazelcast.config.MaxSizeConfig
 
MaxSizeConfig.MaxSizePolicy - Enum in com.hazelcast.config
Maximum Size Policy
MaxSizeConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
MaxSizeConfigReadOnly(MaxSizeConfig) - Constructor for class com.hazelcast.config.MaxSizeConfigReadOnly
Deprecated.
 
maxSizePolicy - Variable in class com.hazelcast.config.EvictionConfig
 
maybeDirty() - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
Method called to check to quickly see if a child symbol table may have gotten additional entries.
maybeDirty() - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.CharsToNameCanonicalizer
 
mayMatchElement() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
 
mayMatchProperty() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
 
MC_MAX_VISIBLE_SLOW_OPERATION_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
MC_URL_CHANGE_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
Enable or disable the RestEndpointGroup.CLUSTER_WRITE group in RestApiConfig instead.
MCMutualAuthConfig - Class in com.hazelcast.config
Management Center mutual authentication configuration.
MCMutualAuthConfig() - Constructor for class com.hazelcast.config.MCMutualAuthConfig
 
MD5Util - Class in com.hazelcast.util
Utility class for hashing with MD5
Measurement - Class in com.hazelcast.jet.core.metrics
Immutable data class containing information about one metric measurement, consisting of: metric value metric timestamp, generated when the metric was gathered metric descriptor (set of tag name-value pairs)
MEASUREMENT - Static variable in class com.hazelcast.jet.core.metrics.MetricsDataSerializerHook
Serialization ID of the Measurement class.
MeasurementPredicates - Class in com.hazelcast.jet.core.metrics
Static utility class for creating various Measurement filtering predicates.
megaBytes() - Method in class com.hazelcast.memory.MemorySize
Returns value of memory size in mega-bytes.
MEM_COPY_THRESHOLD - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
Member - Interface in com.hazelcast.core
Cluster member interface.
MEMBER - Static variable in class com.hazelcast.instance.EndpointQualifier
 
MEMBER - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
Unique ID of the cluster member sourcing the metric.
MEMBER_ADDED - Static variable in class com.hazelcast.core.MembershipEvent
This event type is fired when a new member joins the cluster.
MEMBER_ATTRIBUTE_CHANGED - Static variable in class com.hazelcast.core.MembershipEvent
This event type is fired if a member attribute has been changed or removed.
MEMBER_LIST_PUBLISH_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The interval at which the master sends the member lists are sent to other non-master members
MEMBER_REMOVED - Static variable in class com.hazelcast.core.MembershipEvent
This event type is fired if a member left the cluster or was decided to be unresponsive by other members for a extended time.
memberAdded(MembershipServiceEvent) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
memberAdded(MembershipServiceEvent) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
 
memberAdded(MembershipEvent) - Method in class com.hazelcast.core.MembershipAdapter
 
memberAdded(MembershipEvent) - Method in interface com.hazelcast.core.MembershipListener
Invoked when a new member is added to the cluster.
memberAdded(MembershipServiceEvent) - Method in class com.hazelcast.crdt.CRDTReplicationMigrationService
 
memberAdded(MembershipServiceEvent) - Method in interface com.hazelcast.spi.MembershipAwareService
Invoked when a new member is added to the cluster.
MemberAddressProvider - Interface in com.hazelcast.spi
IMPORTANT This interface is not intended to provide addresses of other cluster members with which the hazelcast instance will form a cluster.
MemberAddressProviderConfig - Class in com.hazelcast.config
Configuration for a custom MemberAddressProvider strategy.
MemberAddressProviderConfig() - Constructor for class com.hazelcast.config.MemberAddressProviderConfig
 
memberAttributeChanged(MemberAttributeServiceEvent) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
memberAttributeChanged(MemberAttributeServiceEvent) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
 
memberAttributeChanged(MemberAttributeEvent) - Method in class com.hazelcast.core.MembershipAdapter
 
memberAttributeChanged(MemberAttributeEvent) - Method in interface com.hazelcast.core.MembershipListener
Invoked when an attribute of a member was changed.
memberAttributeChanged(MemberAttributeServiceEvent) - Method in class com.hazelcast.crdt.CRDTReplicationMigrationService
 
memberAttributeChanged(MemberAttributeServiceEvent) - Method in interface com.hazelcast.spi.MembershipAwareService
Invoked when a member attribute is changed.
MemberAttributeConfig - Class in com.hazelcast.config
Contains configuration for attribute of member.
MemberAttributeConfig() - Constructor for class com.hazelcast.config.MemberAttributeConfig
 
MemberAttributeConfig(MemberAttributeConfig) - Constructor for class com.hazelcast.config.MemberAttributeConfig
 
MemberAttributeConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
MemberAttributeEvent - Class in com.hazelcast.core
Event for member attribute changes.
MemberAttributeEvent() - Constructor for class com.hazelcast.core.MemberAttributeEvent
 
MemberAttributeEvent(Cluster, Member, MemberAttributeOperationType, String, Object) - Constructor for class com.hazelcast.core.MemberAttributeEvent
 
MemberAttributeOperationType - Enum in com.hazelcast.cluster
Used to identify the type of member attribute change, either PUT or REMOVED.
MemberAttributeServiceEvent - Class in com.hazelcast.spi
This service event is fired to inform services about a change in a member's attributes collection
MemberAttributeServiceEvent() - Constructor for class com.hazelcast.spi.MemberAttributeServiceEvent
 
MemberAttributeServiceEvent(Cluster, MemberImpl, MemberAttributeOperationType, String, Object) - Constructor for class com.hazelcast.spi.MemberAttributeServiceEvent
 
MemberChannelInitializer - Class in com.hazelcast.nio.tcp
 
memberCount() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
Returns the number of members running this job.
memberCount() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
 
MemberGroup - Interface in com.hazelcast.partition.membergroup
 
MemberGroupConfig - Class in com.hazelcast.config
Contains the configuration for a single member group.
MemberGroupConfig() - Constructor for class com.hazelcast.config.MemberGroupConfig
 
MemberGroupFactory - Interface in com.hazelcast.partition.membergroup
Defines how members will be grouped (e.g.
MemberGroupFactoryFactory - Class in com.hazelcast.partition.membergroup
 
MemberImpl - Class in com.hazelcast.instance
 
MemberImpl() - Constructor for class com.hazelcast.instance.MemberImpl
 
MemberImpl(Address, MemberVersion, boolean) - Constructor for class com.hazelcast.instance.MemberImpl
 
MemberImpl(Address, MemberVersion, boolean, String) - Constructor for class com.hazelcast.instance.MemberImpl
 
MemberImpl(MemberImpl) - Constructor for class com.hazelcast.instance.MemberImpl
 
MemberImpl.Builder - Class in com.hazelcast.instance
 
memberIndex() - Method in interface com.hazelcast.jet.core.ProcessorSupplier.Context
Returns the index of the member among all the members that run this job: it's a unique cluster-wide index.
memberIndex() - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
 
MemberLeftException - Exception in com.hazelcast.core
A ExecutionException thrown when a member left during an invocation or execution.
MemberLeftException() - Constructor for exception com.hazelcast.core.MemberLeftException
 
MemberLeftException(String) - Constructor for exception com.hazelcast.core.MemberLeftException
 
MemberLeftException(Member) - Constructor for exception com.hazelcast.core.MemberLeftException
 
MemberLeftException(Throwable) - Constructor for exception com.hazelcast.core.MemberLeftException
 
memberListJoinVersion(int) - Method in class com.hazelcast.instance.MemberImpl.Builder
 
MemberPartitionState - Interface in com.hazelcast.monitor
Partition related statistics to be used by MemberState implementations.
MemberProtocolEncoder - Class in com.hazelcast.nio.tcp
 
MemberProtocolEncoder(OutboundHandler[]) - Constructor for class com.hazelcast.nio.tcp.MemberProtocolEncoder
Decodes first 3 incoming bytes, validates against supportedProtocol and, when matching, replaces itself in the inbound pipeline with the next InboundHandler.
memberRemoved(MembershipServiceEvent) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
memberRemoved(MembershipServiceEvent) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
 
memberRemoved(MembershipEvent) - Method in class com.hazelcast.core.MembershipAdapter
 
memberRemoved(MembershipEvent) - Method in interface com.hazelcast.core.MembershipListener
Invoked when an existing member leaves the cluster.
memberRemoved(MembershipServiceEvent) - Method in class com.hazelcast.crdt.CRDTReplicationMigrationService
 
memberRemoved(MembershipServiceEvent) - Method in interface com.hazelcast.spi.MembershipAwareService
Invoked when an existing member leaves the cluster.
members() - Method in interface com.hazelcast.cp.CPGroup
Returns current members of the CP group
MemberSelector - Interface in com.hazelcast.core
Implementations of this interface select members that are capable of executing a special kind of task.
The MemberSelector.select(Member) method is called for every available member in the cluster and it is up to the implementation to decide if the member is going to be used or not.
MemberSelectors - Class in com.hazelcast.cluster.memberselector
A utility class to get MemberSelector instances.
MembershipAdapter - Class in com.hazelcast.core
Adapter for MembershipListener.
MembershipAdapter() - Constructor for class com.hazelcast.core.MembershipAdapter
 
MembershipAwareService - Interface in com.hazelcast.spi
An interface that can be implemented by a SPI service that needs to be notified members joining and leaving the cluster.
MembershipEvent - Class in com.hazelcast.core
Membership event fired when a new member is added to the cluster and/or when a member leaves the cluster or when there is a member attribute change via Member.setBooleanAttribute(String, boolean) and similar methods.
MembershipEvent(Cluster, Member, int, Set<Member>) - Constructor for class com.hazelcast.core.MembershipEvent
 
MembershipListener - Interface in com.hazelcast.core
Cluster membership listener.
MembershipServiceEvent - Class in com.hazelcast.spi
Membership event fired when a new member is added to the cluster and/or when a member leaves the cluster.
MembershipServiceEvent(MembershipEvent) - Constructor for class com.hazelcast.spi.MembershipServiceEvent
 
MemberSocketInterceptor - Interface in com.hazelcast.nio
Member Socket Interceptor can be registered via see SocketInterceptorConfig Warning: a MemberSocketInterceptor provides access to the socket and will bypass any TLS encryption.
MemberState - Interface in com.hazelcast.monitor
Local statistics for a Hazelcast member.
MemberVersion - Class in com.hazelcast.version
Determines the Hazelcast codebase version in terms of major.minor.patch version.
MemberVersion() - Constructor for class com.hazelcast.version.MemberVersion
 
MemberVersion(int, int, int) - Constructor for class com.hazelcast.version.MemberVersion
 
MemberVersion(String) - Constructor for class com.hazelcast.version.MemberVersion
 
MEMCACHE - Static variable in class com.hazelcast.instance.EndpointQualifier
 
MEMCACHE - Static variable in class com.hazelcast.nio.Protocols
Protocol that is used by Memcached
MEMCACHE_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
MemcacheProtocolConfig - Class in com.hazelcast.config
This class allows to enable MEMCACHE text protocol support in Hazelcast.
MemcacheProtocolConfig() - Constructor for class com.hazelcast.config.MemcacheProtocolConfig
 
MemcacheTextDecoder - Class in com.hazelcast.nio.ascii
 
MemcacheTextDecoder(TcpIpConnection, TextEncoder, boolean) - Constructor for class com.hazelcast.nio.ascii.MemcacheTextDecoder
 
MemoryInfoAccessor - Interface in com.hazelcast.util
Used for providing runtime memory information of Java virtual machine.
MemorySize - Class in com.hazelcast.memory
MemorySize represents a memory size with given value and MemoryUnit.
MemorySize(long) - Constructor for class com.hazelcast.memory.MemorySize
 
MemorySize(long, MemoryUnit) - Constructor for class com.hazelcast.memory.MemorySize
 
MemoryStats - Interface in com.hazelcast.memory
Memory statistics for the JVM which current HazelcastInstance belongs to.
MemoryStatsSupport - Class in com.hazelcast.memory
This class provides heap usage statistics
MemoryUnit - Enum in com.hazelcast.memory
MemoryUnit represents memory size at a given unit of granularity and provides utility methods to convert across units.
merge(String, CacheEntryView, CacheEntryView) - Method in interface com.hazelcast.cache.CacheMergePolicy
Selects one of the merging and existing cache entries to be merged.
merge(String, CacheEntryView, CacheEntryView) - Method in class com.hazelcast.cache.merge.HigherHitsCacheMergePolicy
 
merge(String, CacheEntryView, CacheEntryView) - Method in class com.hazelcast.cache.merge.LatestAccessCacheMergePolicy
 
merge(String, CacheEntryView, CacheEntryView) - Method in class com.hazelcast.cache.merge.PassThroughCacheMergePolicy
 
merge(String, CacheEntryView, CacheEntryView) - Method in class com.hazelcast.cache.merge.PutIfAbsentCacheMergePolicy
 
MERGE - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
MERGE - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
merge(T) - Method in interface com.hazelcast.crdt.CRDT
Merges the state of a different replica into this CRDT.
merge(String, T) - Method in interface com.hazelcast.crdt.CRDTReplicationAwareService
Performs a merge of the local name CRDT with the provided state.
merge(PNCounterImpl) - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
 
merge(String, PNCounterImpl) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
merge(BatchStage<? extends T>) - Method in interface com.hazelcast.jet.pipeline.BatchStage
Attaches a stage that emits all the items from this stage as well as all the items from the supplied stage.
merge(StreamStage<? extends T>) - Method in interface com.hazelcast.jet.pipeline.StreamStage
Attaches a stage that emits all the items from this stage as well as all the items from the supplied stage.
merge(String, EntryView, EntryView) - Method in class com.hazelcast.map.merge.HigherHitsMapMergePolicy
 
merge(String, EntryView, EntryView) - Method in class com.hazelcast.map.merge.IgnoreMergingEntryMapMergePolicy
 
merge(String, EntryView, EntryView) - Method in class com.hazelcast.map.merge.LatestUpdateMapMergePolicy
 
merge(String, EntryView, EntryView) - Method in interface com.hazelcast.map.merge.MapMergePolicy
Selects one of the merging and existing map entries to be merged.
merge(String, EntryView, EntryView) - Method in class com.hazelcast.map.merge.PassThroughMergePolicy
 
merge(String, EntryView, EntryView) - Method in class com.hazelcast.map.merge.PutIfAbsentMapMergePolicy
 
MERGE - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.nodes.Tag
 
MERGE - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.resolver.JsonScalarResolver
 
merge(String, ReplicatedMapEntryView, ReplicatedMapEntryView) - Method in class com.hazelcast.replicatedmap.merge.HigherHitsMapMergePolicy
 
merge(String, ReplicatedMapEntryView, ReplicatedMapEntryView) - Method in class com.hazelcast.replicatedmap.merge.LatestUpdateMapMergePolicy
 
merge(String, ReplicatedMapEntryView, ReplicatedMapEntryView) - Method in class com.hazelcast.replicatedmap.merge.PassThroughMergePolicy
 
merge(String, ReplicatedMapEntryView, ReplicatedMapEntryView) - Method in class com.hazelcast.replicatedmap.merge.PutIfAbsentMapMergePolicy
 
merge(String, ReplicatedMapEntryView, ReplicatedMapEntryView) - Method in interface com.hazelcast.replicatedmap.merge.ReplicatedMapMergePolicy
Selects one of the merging and existing map entries to be merged.
merge(T, T) - Method in class com.hazelcast.spi.merge.DiscardMergePolicy
 
merge(T, T) - Method in class com.hazelcast.spi.merge.ExpirationTimeMergePolicy
 
merge(T, T) - Method in class com.hazelcast.spi.merge.HigherHitsMergePolicy
 
merge(SplitBrainMergeTypes.CardinalityEstimatorMergeTypes, SplitBrainMergeTypes.CardinalityEstimatorMergeTypes) - Method in class com.hazelcast.spi.merge.HyperLogLogMergePolicy
 
merge(T, T) - Method in class com.hazelcast.spi.merge.LatestAccessMergePolicy
 
merge(T, T) - Method in class com.hazelcast.spi.merge.LatestUpdateMergePolicy
 
merge(T, T) - Method in class com.hazelcast.spi.merge.PassThroughMergePolicy
 
merge(T, T) - Method in class com.hazelcast.spi.merge.PutIfAbsentMergePolicy
 
merge(T, T) - Method in interface com.hazelcast.spi.merge.SplitBrainMergePolicy
Selects the value of either the merging or the existing MergingValue which should be merged.
MERGE_BACKUP - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
MERGE_BACKUP - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
MERGE_FIRST_RUN_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The delay until the first run of the SplitBrainHandler
MERGE_NEXT_RUN_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The interval between invocations of the SplitBrainHandler
MERGE_POLICY_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MergeBackupOperation - Class in com.hazelcast.concurrent.atomiclong.operations
Creates backups for merged atomic longs after split-brain healing with a SplitBrainMergePolicy.
MergeBackupOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.MergeBackupOperation
 
MergeBackupOperation(String, Long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.MergeBackupOperation
 
MergeBackupOperation - Class in com.hazelcast.concurrent.atomicreference.operations
Creates backups for merged atomic references after split-brain healing with a SplitBrainMergePolicy.
MergeBackupOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.MergeBackupOperation
 
MergeBackupOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.MergeBackupOperation
 
MergedStream - Class in com.hazelcast.com.fasterxml.jackson.core.io
Simple InputStream implementation that is used to "unwind" some data previously read from an input stream; so that as long as some of that data remains, it's returned; but as long as it's read, we'll just use data from the underlying original stream.
MergedStream(IOContext, InputStream, byte[], int, int) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.io.MergedStream
 
mergeMapP(String, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends V>, BinaryOperatorEx<V>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
MergeOperation - Class in com.hazelcast.concurrent.atomiclong.operations
Merges a SplitBrainMergeTypes.AtomicLongMergeTypes for split-brain healing with a SplitBrainMergePolicy.
MergeOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.MergeOperation
 
MergeOperation(String, SplitBrainMergePolicy<Long, SplitBrainMergeTypes.AtomicLongMergeTypes>, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.MergeOperation
 
MergeOperation - Class in com.hazelcast.concurrent.atomicreference.operations
MergeOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.MergeOperation
 
MergeOperation(String, SplitBrainMergePolicy<Object, SplitBrainMergeTypes.AtomicReferenceMergeTypes>, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.MergeOperation
 
mergePolicyConfig - Variable in class com.hazelcast.config.AbstractBasicConfig
 
MergePolicyConfig - Class in com.hazelcast.config
Configuration for SplitBrainMergePolicy.
MergePolicyConfig() - Constructor for class com.hazelcast.config.MergePolicyConfig
 
MergePolicyConfig(String, int) - Constructor for class com.hazelcast.config.MergePolicyConfig
 
MergePolicyConfig(MergePolicyConfig) - Constructor for class com.hazelcast.config.MergePolicyConfig
 
MergePolicyProvider - Class in com.hazelcast.map.merge
A provider for MapMergePolicy instances.
MergePolicyProvider(NodeEngine) - Constructor for class com.hazelcast.map.merge.MergePolicyProvider
 
MergePolicyProvider - Class in com.hazelcast.replicatedmap.merge
A provider for ReplicatedMapMergePolicy instances.
MergePolicyProvider(NodeEngine) - Constructor for class com.hazelcast.replicatedmap.merge.MergePolicyProvider
 
mergeRemoteMapP(String, ClientConfig, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends V>, BinaryOperatorEx<V>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
MergingCosts<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of memory costs for the merging process after a split-brain.
MergingCreationTime<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view a creation time for the merging process after a split-brain.
MergingEntry<K,V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a data structure key/value-pair for the merging process after a split-brain.
MergingExpirationTime<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of an expiration time for the merging process after a split-brain.
MergingHits<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view access hits for the merging process after a split-brain.
MergingLastAccessTime<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a last access time for the merging process after a split-brain.
MergingLastStoredTime<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a last stored time for the merging process after a split-brain.
MergingLastUpdateTime<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a last update time for the merging process after a split-brain.
MergingMaxIdle<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a MaxIdle for the merging process after a split-brain.
MergingTTL<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a TTL for the merging process after a split-brain.
mergingValue - Variable in class com.hazelcast.core.EntryEvent
 
MergingValue<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a data structure value for the merging process after a split-brain.
MergingVersion<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a version for the merging process after a split-brain.
MERKLE_TREE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MerkleTree - Interface in com.hazelcast.wan.merkletree
Interface defining methods for Merkle tree implementations
MerkleTreeConfig - Class in com.hazelcast.config
Configuration for a merkle tree.
MerkleTreeConfig() - Constructor for class com.hazelcast.config.MerkleTreeConfig
 
MerkleTreeConfig(MerkleTreeConfig) - Constructor for class com.hazelcast.config.MerkleTreeConfig
MerkleTreeUtil - Class in com.hazelcast.wan.merkletree
Utility methods for Merkle tree implementation
Message<E> - Class in com.hazelcast.core
Message for ITopic.
Message(String, E, long, Member) - Constructor for class com.hazelcast.core.Message
 
messageFn(BiFunctionEx<Session, T, Message>) - Method in class com.hazelcast.jet.pipeline.JmsSinkBuilder
Sets the function which creates the message from the item.
MessageListener<E> - Interface in com.hazelcast.core
Message listener for ITopic.
messageObject - Variable in class com.hazelcast.core.Message
 
Metadata - Class in com.hazelcast.query
Keeps generic metadata for a key value pair.
Metadata() - Constructor for class com.hazelcast.query.Metadata
 
METADATA_CP_GROUP_NAME - Static variable in interface com.hazelcast.cp.CPGroup
Name of the internal CP group that is used for maintaining CP groups and CP members
MetadataPolicy - Enum in com.hazelcast.config
Hazelcast may process objects of supported types ahead of time to create additional metadata about them.
MetadataUtil - Class in com.hazelcast.aws.utility
 
METRIC - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
The name of the metric.
MetricNames - Class in com.hazelcast.jet.core.metrics
Each metric provided by Jet has a specific name which conceptually identifies what it's being used to measure.
metrics() - Method in class com.hazelcast.jet.core.metrics.JobMetrics
Returns all metrics present.
MetricsConfig - Class in com.hazelcast.jet.config
Configuration options specific to metrics collection.
MetricsConfig() - Constructor for class com.hazelcast.jet.config.MetricsConfig
 
MetricsDataSerializerHook - Class in com.hazelcast.jet.core.metrics
A Java Service Provider hook for Hazelcast's Identified Data Serializable mechanism.
MetricsDataSerializerHook() - Constructor for class com.hazelcast.jet.core.metrics.MetricsDataSerializerHook
 
MetricTags - Class in com.hazelcast.jet.core.metrics
Metric descriptors are formed from a comma separated list of tag_name=tag_value pairs.
MigrationAwareService - Interface in com.hazelcast.spi
An interface that can be implemented by SPI services to get notified of partition changes; for example, if a MapService starts moving its data around because partitions are moving to a different machine.
migrationCompleted(MigrationEvent) - Method in interface com.hazelcast.core.MigrationListener
Invoked when a partition migration is completed.
MigrationEndpoint - Enum in com.hazelcast.spi.partition
Denotes endpoint of a migration.
MigrationEvent - Class in com.hazelcast.core
An event fired when a partition migration starts, completes or fails.
MigrationEvent() - Constructor for class com.hazelcast.core.MigrationEvent
 
MigrationEvent(int, Member, Member, MigrationEvent.MigrationStatus) - Constructor for class com.hazelcast.core.MigrationEvent
 
MigrationEvent.MigrationStatus - Enum in com.hazelcast.core
Migration status: Started, completed or failed
migrationFailed(MigrationEvent) - Method in interface com.hazelcast.core.MigrationListener
Invoked when a partition migration is failed.
MigrationListener - Interface in com.hazelcast.core
MigrationListener provides the ability to listen to partition migration events.
migrationStarted(MigrationEvent) - Method in interface com.hazelcast.core.MigrationListener
Invoked when a partition migration is started.
MIME - Static variable in class com.hazelcast.com.fasterxml.jackson.core.Base64Variants
This variant is what most people would think of "the standard" Base64 encoding.
MIME_NO_LINEFEEDS - Static variable in class com.hazelcast.com.fasterxml.jackson.core.Base64Variants
Slightly non-standard modification of Base64Variants.MIME which does not use linefeeds (max line length set to infinite).
MIN_BACKUP_COUNT - Static variable in class com.hazelcast.config.CacheSimpleConfig
The minimum number of backups.
MIN_BACKUP_COUNT - Static variable in class com.hazelcast.config.MapConfig
The minimum number of backups
MIN_EVICTION_PERCENTAGE - Static variable in class com.hazelcast.config.MapConfig
The number of minimum eviction percentage
MIN_GROUP_SIZE - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
Minimum number of CP members for CP groups.
MIN_INDENT - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.emitter.Emitter
 
MIN_INITIAL_MEMORY_SIZE - Static variable in class com.hazelcast.config.NativeMemoryConfig
Minimum initial memory size in megabytes
MIN_INT_D - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
MIN_INT_L - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
MIN_LONG_D - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
minBy(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
minBy(ComparatorEx<? super T>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that computes the least item according to the given comparator.
minBy(Comparator<? super T>) - Static method in interface com.hazelcast.jet.function.BinaryOperatorEx
MinimalPrettyPrinter - Class in com.hazelcast.com.fasterxml.jackson.core.util
PrettyPrinter implementation that adds no indentation, just implements everything necessary for value output to work as expected, and provide simpler extension points to allow for creating simple custom implementations that add specific decoration or overrides.
MinimalPrettyPrinter() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.MinimalPrettyPrinter
 
MinimalPrettyPrinter(String) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.MinimalPrettyPrinter
 
MINOR_COMMENT_C - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_COMMENT_CLOSING_ASTERISK - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_COMMENT_CPP - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_COMMENT_LEADING_SLASH - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_COMMENT_YAML - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_FIELD_APOS_NAME - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_FIELD_LEADING_COMMA - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_FIELD_LEADING_WS - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_FIELD_NAME - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_FIELD_NAME_ESCAPE - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_FIELD_UNQUOTED_NAME - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_NUMBER_EXPONENT_DIGITS - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_NUMBER_EXPONENT_MARKER - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_NUMBER_FRACTION_DIGITS - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_NUMBER_INTEGER_DIGITS - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_NUMBER_MINUS - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_NUMBER_MINUSZERO - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_NUMBER_ZERO - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_ROOT_BOM - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
State in which part of (UTF-8) BOM has been detected, but not yet completely.
MINOR_ROOT_GOT_SEPARATOR - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
State between root-level value, having processed at least one white-space character, and expecting either more, start of a value, or end of input stream.
MINOR_ROOT_NEED_SEPARATOR - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
State between root-level value, waiting for at least one white-space character as separator
MINOR_VALUE_APOS_STRING - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_VALUE_EXPECTING_COLON - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_VALUE_EXPECTING_COMMA - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_VALUE_LEADING_WS - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_VALUE_STRING - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_VALUE_STRING_ESCAPE - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_VALUE_STRING_UTF8_2 - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_VALUE_STRING_UTF8_3 - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_VALUE_STRING_UTF8_4 - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_VALUE_TOKEN_ERROR - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
Special state at which point decoding of a non-quoted token has encountered a problem; that is, either not matching fully (like "truf" instead of "true", at "tru"), or not having trailing separator (or end of input), like "trueful".
MINOR_VALUE_TOKEN_FALSE - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_VALUE_TOKEN_NON_STD - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_VALUE_TOKEN_NULL - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_VALUE_TOKEN_TRUE - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MINOR_VALUE_WS_AFTER_COMMA - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
MODIFIED_FOR_URL - Static variable in class com.hazelcast.com.fasterxml.jackson.core.Base64Variants
This non-standard variant is usually used when encoded data needs to be passed via URLs (such as part of GET request).
modPowerOfTwo(int, int) - Static method in class com.hazelcast.util.QuickMath
Computes the remainder of the division of a by b.
modPowerOfTwo(long, int) - Static method in class com.hazelcast.util.QuickMath
Computes the remainder of the division of a by b.
MODULE - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
Source system or module, value is always "jet".
multiAttribute(String...) - Static method in class com.hazelcast.projection.Projections
Returns a projection that extracts the value of the given attributePaths.
MulticastConfig - Class in com.hazelcast.config
Contains the configuration for the multicast discovery mechanism.
MulticastConfig() - Constructor for class com.hazelcast.config.MulticastConfig
 
MulticastDiscoveryStrategy - Class in com.hazelcast.spi.discovery.multicast
The multicast DiscoveryStrategy.
MulticastDiscoveryStrategy(DiscoveryNode, ILogger, Map<String, Comparable>) - Constructor for class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategy
 
MulticastDiscoveryStrategyFactory - Class in com.hazelcast.spi.discovery.multicast
Factory class which returns MulticastDiscoveryStrategy to Discovery SPI
MulticastDiscoveryStrategyFactory() - Constructor for class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategyFactory
 
MulticastProperties - Class in com.hazelcast.spi.discovery.multicast
Defines the name and default value for the Multicast Discovery Strategy.
multicastService - Variable in class com.hazelcast.instance.Node
 
MultiExecutionCallback - Interface in com.hazelcast.core
MultiExecutionCallback provides notification for when an execution is completed on each member that a task is submitted to.
multiline - Variable in class com.hazelcast.org.snakeyaml.engine.v1.emitter.ScalarAnalysis
 
MULTILINE_PATTERN - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter
 
MultiMap<K,V> - Interface in com.hazelcast.core
A specialized map whose keys can be associated with multiple values.
MULTIMAP_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MultiMapConfig - Class in com.hazelcast.config
Configuration for MultiMap.
MultiMapConfig() - Constructor for class com.hazelcast.config.MultiMapConfig
 
MultiMapConfig(String) - Constructor for class com.hazelcast.config.MultiMapConfig
 
MultiMapConfig(MultiMapConfig) - Constructor for class com.hazelcast.config.MultiMapConfig
 
MultiMapConfig.ValueCollectionType - Enum in com.hazelcast.config
Type of value collection
MultiMapConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
MultiMapConfigReadOnly(MultiMapConfig) - Constructor for class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
MultiMapPermission - Class in com.hazelcast.security.permission
 
MultiMapPermission(String, String...) - Constructor for class com.hazelcast.security.permission.MultiMapPermission
 
multiRepresenters - Variable in class com.hazelcast.org.snakeyaml.engine.v1.representer.BaseRepresenter
 
MurmurHash3_fmix(int) - Static method in class com.hazelcast.util.HashUtil
 
MurmurHash3_fmix(long) - Static method in class com.hazelcast.util.HashUtil
 
MurmurHash3_x64_64(byte[], int, int) - Static method in class com.hazelcast.util.HashUtil
Returns the MurmurHash3_x86_32 hash of a block inside a byte array.
MurmurHash3_x64_64_direct(long, int, int) - Static method in class com.hazelcast.util.HashUtil
 
MurmurHash3_x64_64_direct(MemoryAccessor, long, int, int) - Static method in class com.hazelcast.util.HashUtil
Returns the MurmurHash3_x64_64 hash of a memory block accessed by the provided MemoryAccessor.
MurmurHash3_x86_32(byte[], int, int) - Static method in class com.hazelcast.util.HashUtil
Returns the MurmurHash3_x86_32 hash of a block inside a byte array.
MurmurHash3_x86_32_direct(long, int, int) - Static method in class com.hazelcast.util.HashUtil
 
MurmurHash3_x86_32_direct(MemoryAccessor, long, int, int) - Static method in class com.hazelcast.util.HashUtil
Returns the MurmurHash3_x86_32 hash of a memory block accessed by the provided MemoryAccessor.
MutableInteger - Class in com.hazelcast.util
Mutable integer which can be used for counting purposes.
MutableInteger() - Constructor for class com.hazelcast.util.MutableInteger
 
MutableLong - Class in com.hazelcast.util
Mutable long which can be used for counting purposes.
MutableLong() - Constructor for class com.hazelcast.util.MutableLong
 
MutableReference<T> - Class in com.hazelcast.jet.accumulator
Mutable container of an object reference.
MutableReference() - Constructor for class com.hazelcast.jet.accumulator.MutableReference
Creates a new instance with a null value.
MutableReference(T) - Constructor for class com.hazelcast.jet.accumulator.MutableReference
Creates a new instance with the specified value.
MutationDisallowedException - Exception in com.hazelcast.crdt
Exception that indicates that the state found on this replica disallows mutation.
MutationDisallowedException(String) - Constructor for exception com.hazelcast.crdt.MutationDisallowedException
 
mutexFor(Object) - Method in class com.hazelcast.util.ContextMutexFactory
 

N

NA - Static variable in class com.hazelcast.com.fasterxml.jackson.core.JsonLocation
Shared immutable "N/A location" that can be returned to indicate that no location information is available.
NA_MEMBER_LIST_JOIN_VERSION - Static variable in class com.hazelcast.instance.MemberImpl
Denotes that member list join version of a member is not known yet.
Name - Class in com.hazelcast.com.fasterxml.jackson.core.sym
Base class for tokenized names (key strings in objects) that have been tokenized from byte-based input sources (like InputStream.
Name(String, int) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.sym.Name
 
name - Variable in class com.hazelcast.concurrent.atomiclong.operations.AbstractAtomicLongOperation
 
name - Variable in class com.hazelcast.concurrent.atomicreference.operations.AbstractAtomicReferenceOperation
 
name - Variable in class com.hazelcast.config.AbstractBasicConfig
 
name - Variable in class com.hazelcast.config.EndpointConfig
 
name - Variable in class com.hazelcast.core.AbstractIMapEvent
 
name() - Method in interface com.hazelcast.cp.CPGroupId
Returns name of the CP group.
name - Variable in class com.hazelcast.crdt.pncounter.operations.AbstractPNCounterOperation
 
name() - Method in class com.hazelcast.jet.JobStateSnapshot
Returns the snapshot name.
name() - Method in interface com.hazelcast.jet.pipeline.BatchSource
Returns a descriptive name of this source.
name() - Method in interface com.hazelcast.jet.pipeline.Sink
Returns a descriptive name for this sink.
name() - Method in interface com.hazelcast.jet.pipeline.Stage
Returns the name of this stage.
name() - Method in interface com.hazelcast.jet.pipeline.StreamSource
Returns a descriptive name of this source.
Name1 - Class in com.hazelcast.com.fasterxml.jackson.core.sym
Specialized implementation of PName: can be used for short Strings that consists of at most 4 bytes.
Name2 - Class in com.hazelcast.com.fasterxml.jackson.core.sym
Specialized implementation of PName: can be used for short Strings that consists of 5 to 8 bytes.
Name3 - Class in com.hazelcast.com.fasterxml.jackson.core.sym
Specialized implementation of PName: can be used for short Strings that consists of 9 to 12 bytes.
named(String, Runnable) - Static method in class com.hazelcast.scheduledexecutor.TaskUtils
Decorate any Runnable with a NamedTask to provide naming information to scheduler.
named(String, Callable<V>) - Static method in class com.hazelcast.scheduledexecutor.TaskUtils
Decorate any Callable with a NamedTask to provide naming information to scheduler.
NamedConfig - Interface in com.hazelcast.config
Interface for hazelcast data structures with name
NamedOperation - Interface in com.hazelcast.spi
Indicates that Operation carries the distributed data structure name that is going to work on.
NamedTask - Interface in com.hazelcast.scheduledexecutor
The NamedTask interface should be implemented by any task that needs to have an identification and enhanced atomicity upon scheduling the task.
NamedThreadPoolExecutor - Class in com.hazelcast.util.executor
 
NamedThreadPoolExecutor(String, int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory) - Constructor for class com.hazelcast.util.executor.NamedThreadPoolExecutor
 
NameN - Class in com.hazelcast.com.fasterxml.jackson.core.sym
Generic implementation of PName used for "long" names, where long means that its byte (UTF-8) representation is 13 bytes or more.
namespace - Variable in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
NASTY_SMALL_DOUBLE - Static variable in class com.hazelcast.com.fasterxml.jackson.core.io.NumberInput
Textual representation of a double constant that can cause nasty problems with JDK (see http://www.exploringbinary.com/java-hangs-when-converting-2-2250738585072012e-308).
NativeMemoryConfig - Class in com.hazelcast.config
Configures native memory region.
NativeMemoryConfig() - Constructor for class com.hazelcast.config.NativeMemoryConfig
 
NativeMemoryConfig(NativeMemoryConfig) - Constructor for class com.hazelcast.config.NativeMemoryConfig
 
NativeMemoryConfig.MemoryAllocatorType - Enum in com.hazelcast.config
Type of memory allocator: STANDARD: allocate/free memory using default OS memory manager POOLED: manage memory blocks in pool
NativeOutOfMemoryError - Error in com.hazelcast.memory
Thrown when Hazelcast cannot allocate required native memory.
NativeOutOfMemoryError() - Constructor for error com.hazelcast.memory.NativeOutOfMemoryError
 
NativeOutOfMemoryError(String) - Constructor for error com.hazelcast.memory.NativeOutOfMemoryError
 
NativeOutOfMemoryError(String, Throwable) - Constructor for error com.hazelcast.memory.NativeOutOfMemoryError
 
naturalOrder() - Static method in interface com.hazelcast.jet.function.ComparatorEx
Serializable variant of java.util.Comparator#naturalOrder().
NC - Static variable in class com.hazelcast.com.fasterxml.jackson.core.io.UTF32Reader
 
NEAR_CACHE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
NEAR_CACHE_PRELOADER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
NearCacheConfig - Class in com.hazelcast.config
Contains the configuration for a Near Cache.
NearCacheConfig() - Constructor for class com.hazelcast.config.NearCacheConfig
 
NearCacheConfig(String) - Constructor for class com.hazelcast.config.NearCacheConfig
 
NearCacheConfig(int, int, boolean, InMemoryFormat) - Constructor for class com.hazelcast.config.NearCacheConfig
 
NearCacheConfig(int, int, boolean, InMemoryFormat, EvictionConfig) - Constructor for class com.hazelcast.config.NearCacheConfig
 
NearCacheConfig(int, int, String, int, boolean, InMemoryFormat) - Constructor for class com.hazelcast.config.NearCacheConfig
NearCacheConfig(int, int, String, int, boolean, InMemoryFormat, EvictionConfig) - Constructor for class com.hazelcast.config.NearCacheConfig
NearCacheConfig(NearCacheConfig) - Constructor for class com.hazelcast.config.NearCacheConfig
 
NearCacheConfig.LocalUpdatePolicy - Enum in com.hazelcast.config
Defines how to reflect local updates to the Near Cache.
NearCacheConfigAccessor - Class in com.hazelcast.config
Accessor for the EvictionConfig of a NearCacheConfig to initialize the old default max size, if no size was configured by the user.
NearCacheConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
NearCacheConfigReadOnly() - Constructor for class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
NearCacheConfigReadOnly(NearCacheConfig) - Constructor for class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
NearCachePreloaderConfig - Class in com.hazelcast.config
Configuration for storing and pre-loading Near Cache keys.
NearCachePreloaderConfig() - Constructor for class com.hazelcast.config.NearCachePreloaderConfig
 
NearCachePreloaderConfig(NearCachePreloaderConfig) - Constructor for class com.hazelcast.config.NearCachePreloaderConfig
 
NearCachePreloaderConfig(String) - Constructor for class com.hazelcast.config.NearCachePreloaderConfig
 
NearCachePreloaderConfig(boolean, String) - Constructor for class com.hazelcast.config.NearCachePreloaderConfig
 
NearCacheStats - Interface in com.hazelcast.monitor
Near Cache statistics to be used by MemberState implementations.
needMoreInput() - Method in interface com.hazelcast.com.fasterxml.jackson.core.async.NonBlockingInputFeeder
Method called to check whether it is ok to feed more data: parser returns true if it has no more content to parse (and it is ok to feed more); otherwise false (and no data should yet be fed).
needMoreInput() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
 
negate() - Method in interface com.hazelcast.jet.function.BiPredicateEx
negate() - Method in interface com.hazelcast.jet.function.PredicateEx
Serializable variant of Predicate.negate().
negate() - Method in interface com.hazelcast.jet.function.TriPredicate
Returns a composite predicate which evaluates the equivalent of !this.test(t, u, v).
NetworkConfig - Class in com.hazelcast.config
Contains configuration for Network.
NetworkConfig() - Constructor for class com.hazelcast.config.NetworkConfig
 
networkingService - Variable in class com.hazelcast.instance.Node
 
NetworkingService<T extends Connection> - Interface in com.hazelcast.nio
Networking service, it initializes the endpoints, the acceptor and the reactive networking stack Given an EndpointQualifier an EndpointManager can be retrieved by NetworkingService.getEndpointManager(EndpointQualifier) to create or get connections on that end.
newBuilder(int) - Static method in class com.hazelcast.util.collection.InflatableSet
 
newBuilder(List<T>) - Static method in class com.hazelcast.util.collection.InflatableSet
 
newByteBuffer(int, boolean) - Static method in class com.hazelcast.nio.IOUtil
 
newClientTransactionContext(TransactionOptions, String) - Method in interface com.hazelcast.transaction.TransactionManagerService
 
newCombiner(KeyIn) - Method in interface com.hazelcast.mapreduce.CombinerFactory
Deprecated.
Build a new Combiner instance specific to the supplied key.
newComparator(Comparator<Map.Entry>, IterationType) - Static method in class com.hazelcast.util.SortingUtil
 
newCondition() - Method in class com.hazelcast.concurrent.lock.LockProxy
 
newCondition(String) - Method in class com.hazelcast.concurrent.lock.LockProxy
 
newCondition() - Method in interface com.hazelcast.core.ILock
Deprecated.
This method is not implemented! Use ILock.newCondition(String) instead.
newCondition(String) - Method in interface com.hazelcast.core.ILock
Deprecated.
Returns a new ICondition instance that is bound to this ILock instance with given name.
newCondition() - Method in interface com.hazelcast.cp.lock.FencedLock
NOT IMPLEMENTED.
newConfigFor(String) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Creates new AliasedDiscoveryConfig by the given tag.
newCredentials() - Method in interface com.hazelcast.security.ICredentialsFactory
Creates new Credentials object.
newDiscoveryService(DiscoveryServiceSettings) - Method in interface com.hazelcast.spi.discovery.integration.DiscoveryServiceProvider
Instantiates a new instance of the DiscoveryService.
newDiscoveryStrategy(DiscoveryNode, ILogger, Map<String, Comparable>) - Method in class com.hazelcast.aws.AwsDiscoveryStrategyFactory
 
newDiscoveryStrategy(DiscoveryNode, ILogger, Map<String, Comparable>) - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategyFactory
Instantiates a new instance of the DiscoveryStrategy with the given configuration properties.
newDiscoveryStrategy(DiscoveryNode, ILogger, Map<String, Comparable>) - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategyFactory
 
newHazelcastInstance(Config) - Static method in class com.hazelcast.core.Hazelcast
Creates a new HazelcastInstance (a new node in a cluster).
newHazelcastInstance() - Static method in class com.hazelcast.core.Hazelcast
Creates a new HazelcastInstance (a new node in a cluster).
newHazelcastInstance(Config) - Static method in class com.hazelcast.instance.HazelcastInstanceFactory
Creates a new Hazelcast instance.
newHazelcastInstance(Config, String, NodeContext) - Static method in class com.hazelcast.instance.HazelcastInstanceFactory
Creates a new Hazelcast instance.
newHazelcastInstance(Config) - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Creates a new HazelcastOSGiInstance on the owner bundle with specified configuration.
newHazelcastInstance() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Creates a new HazelcastOSGiInstance on the owner bundle with default configuration.
newId() - Method in class com.hazelcast.concurrent.idgen.IdGeneratorImpl
 
newId() - Method in class com.hazelcast.concurrent.idgen.IdGeneratorProxy
 
newId() - Method in interface com.hazelcast.core.IdGenerator
Deprecated.
Generates and returns a cluster-wide unique ID.
newId() - Method in interface com.hazelcast.flakeidgen.FlakeIdGenerator
Generates and returns a cluster-wide unique ID.
newInputStream(ByteBuffer) - Static method in class com.hazelcast.nio.IOUtil
 
newInstance() - Method in enum com.hazelcast.cache.BuiltInCacheMergePolicies
Create a new instance of CacheMergePolicy.
newInstance(ClassLoader, String) - Static method in class com.hazelcast.nio.ClassLoaderUtil
Creates a new instance of class with className, using the no-arg constructor.
newJetClient() - Static method in class com.hazelcast.jet.Jet
Creates a Jet client with the default configuration.
newJetClient(ClientConfig) - Static method in class com.hazelcast.jet.Jet
Creates a Jet client with the given Hazelcast client configuration.
newJetInstance() - Static method in class com.hazelcast.jet.Jet
Creates a member of the Jet cluster with the configuration loaded from default location.
newJetInstance(JetConfig) - Static method in class com.hazelcast.jet.Jet
Creates a member of the Jet cluster with the given configuration.
newJob(DAG) - Method in interface com.hazelcast.jet.JetInstance
Creates and returns a Jet job based on the supplied DAG.
newJob(Pipeline) - Method in interface com.hazelcast.jet.JetInstance
Creates and returns an executable job based on the supplied pipeline.
newJob(DAG, JobConfig) - Method in interface com.hazelcast.jet.JetInstance
Creates and returns a Jet job based on the supplied DAG and job configuration.
newJob(Pipeline, JobConfig) - Method in interface com.hazelcast.jet.JetInstance
Creates and returns a Jet job based on the supplied pipeline and job configuration.
newJob(KeyValueSource<K, V>) - Method in interface com.hazelcast.mapreduce.JobTracker
Deprecated.
Builds a Job instance for the given KeyValueSource instance.
newJobIfAbsent(DAG, JobConfig) - Method in interface com.hazelcast.jet.JetInstance
Creates and returns a Jet job based on the supplied DAG and job configuration.
newJobIfAbsent(Pipeline, JobConfig) - Method in interface com.hazelcast.jet.JetInstance
Creates and returns a Jet job based on the supplied pipeline and job configuration.
newLoggerFactory(String) - Static method in class com.hazelcast.logging.Logger
Creates a logger factory instance of the given preferred type.
newMapStore(String, Properties) - Method in interface com.hazelcast.core.MapStoreFactory
Produces a MapLoader or a MapStore for the given map name and properties.
newMemberGroupFactory(PartitionGroupConfig, DiscoveryService) - Static method in class com.hazelcast.partition.membergroup.MemberGroupFactoryFactory
 
newObjectInputStream(ClassLoader, ClassNameFilter, InputStream) - Static method in class com.hazelcast.nio.IOUtil
 
newOutputStream(ByteBuffer) - Static method in class com.hazelcast.nio.IOUtil
 
newPermissionCollection() - Method in class com.hazelcast.security.permission.AllPermissions
 
newPermissionCollection() - Method in class com.hazelcast.security.permission.ClusterPermission
 
newProbabilisticQuorumConfigBuilder(String, int) - Static method in class com.hazelcast.config.QuorumConfig
Returns a builder for QuorumConfig with the given name using a probabilistic quorum function, for the given quorum size that is enabled by default.
newQueueStore(String, Properties) - Method in interface com.hazelcast.core.QueueStoreFactory
 
newRecentlyActiveQuorumConfigBuilder(String, int, int) - Static method in class com.hazelcast.config.QuorumConfig
Returns a builder for a QuorumConfig with the given name using a recently-active quorum function for the given quorum size that is enabled by default.
newReducer(KeyIn) - Method in interface com.hazelcast.mapreduce.ReducerFactory
Deprecated.
Build a new Reducer instance specific to the supplied key.
newRingbufferStore(String, Properties) - Method in interface com.hazelcast.core.RingbufferStoreFactory
 
newScheduler(TaskScheduler, ScheduledEntryProcessor<K, V>, ScheduleType) - Static method in class com.hazelcast.util.scheduler.EntryTaskSchedulerFactory
Creates a new EntryTaskScheduler that will run all second operations in bulk.
newSecureUUID() - Static method in class com.hazelcast.util.UuidUtil
Static factory to retrieve a type 4 (pseudo randomly generated) UUID.
newSecureUuidString() - Static method in class com.hazelcast.util.UuidUtil
Static factory to retrieve a type 4 (pseudo randomly generated) UUID based string.
newThread(Runnable) - Method in class com.hazelcast.util.executor.AbstractExecutorThreadFactory
 
newTransactionContext() - Method in interface com.hazelcast.core.HazelcastInstance
Creates a new TransactionContext associated with the current thread using default options.
newTransactionContext(TransactionOptions) - Method in interface com.hazelcast.core.HazelcastInstance
Creates a new TransactionContext associated with the current thread with given options.
newTransactionContext() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
newTransactionContext(TransactionOptions) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
newTransactionContext() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
newTransactionContext(TransactionOptions) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
newTransactionContext(TransactionOptions) - Method in interface com.hazelcast.transaction.TransactionManagerService
 
newUnsecureUUID() - Static method in class com.hazelcast.util.UuidUtil
Static factory to retrieve a type 4 (pseudo randomly generated) UUID.
newUnsecureUuidString() - Static method in class com.hazelcast.util.UuidUtil
Static factory to retrieve a type 4 (pseudo randomly generated) UUID based string.
newVertex(String, SupplierEx<? extends Processor>) - Method in class com.hazelcast.jet.core.DAG
Creates a vertex from a Supplier<Processor> and adds it to this DAG.
newVertex(String, ProcessorSupplier) - Method in class com.hazelcast.jet.core.DAG
Creates a vertex from a ProcessorSupplier and adds it to this DAG.
newVertex(String, ProcessorMetaSupplier) - Method in class com.hazelcast.jet.core.DAG
Creates a vertex from a ProcessorMetaSupplier and adds it to this DAG.
newWmPolicyFn() - Method in class com.hazelcast.jet.core.EventTimePolicy
Returns the factory of the watermark policy objects.
next() - Method in class com.hazelcast.jet.core.AppendableTraverser
 
next() - Method in class com.hazelcast.jet.core.ResettableSingletonTraverser
 
next() - Method in interface com.hazelcast.jet.Traverser
Returns the next item, removing it from this traverser.
next() - Method in class com.hazelcast.org.snakeyaml.engine.v1.composer.Composer
Reads and composes the next document.
next() - Method in interface com.hazelcast.org.snakeyaml.engine.v1.parser.Parser
Returns the next event.
next() - Method in class com.hazelcast.org.snakeyaml.engine.v1.parser.ParserImpl
Get the next event and proceed further.
next() - Method in interface com.hazelcast.org.snakeyaml.engine.v1.scanner.Scanner
Returns the next token.
next() - Method in class com.hazelcast.org.snakeyaml.engine.v1.scanner.ScannerImpl
Return the next token, removing it from the queue.
next() - Method in class com.hazelcast.spi.merge.RingbufferMergeDataReadOnlyIterator
 
next() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.KeyIterator
 
next() - Method in class com.hazelcast.util.collection.IntIterator
 
next() - Method in class com.hazelcast.util.collection.Long2LongHashMap.LongIterator
 
next() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.KeyIterator
 
next() - Method in class com.hazelcast.util.collection.LongIterator
 
next(T) - Method in class com.hazelcast.util.StateMachine
Transition to next state
nextAnchor(Node) - Method in interface com.hazelcast.org.snakeyaml.engine.v1.serializer.AnchorGenerator
 
nextAnchor(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v1.serializer.NumberAnchorGenerator
 
nextBooleanValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
 
nextBooleanValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
 
nextBooleanValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
 
nextBooleanValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Method that fetches next token (as if calling JsonParser.nextToken()) and if it is JsonToken.VALUE_TRUE or JsonToken.VALUE_FALSE returns matching Boolean value; otherwise return null.
nextByte() - Method in interface com.hazelcast.com.fasterxml.jackson.core.format.InputAccessor
Returns next byte available, if any; if no more bytes are available, will throw EOFException.
nextByte() - Method in class com.hazelcast.com.fasterxml.jackson.core.format.InputAccessor.Std
 
nextEscapeIndex(CharSequence, int, int) - Method in class com.hazelcast.org.snakeyaml.engine.external.com.google.gdata.util.common.base.PercentEscaper
 
nextEscapeIndex(CharSequence, int, int) - Method in class com.hazelcast.org.snakeyaml.engine.external.com.google.gdata.util.common.base.UnicodeEscaper
Scans a sub-sequence of characters from a given CharSequence, returning the index of the next character that requires escaping.
nextFieldName(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
 
nextFieldName() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
 
nextFieldName() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
 
nextFieldName(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
 
nextFieldName() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
 
nextFieldName(SerializableString) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Method that fetches next token (as if calling JsonParser.nextToken()) and verifies whether it is JsonToken.FIELD_NAME with specified name and returns result of that comparison.
nextFieldName() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Method that fetches next token (as if calling JsonParser.nextToken()) and verifies whether it is JsonToken.FIELD_NAME; if it is, returns same as JsonParser.getCurrentName(), otherwise null.
nextInt() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.KeyIterator
Non-boxing variant of next().
nextIntValue(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
 
nextIntValue(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
 
nextIntValue(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
 
nextIntValue(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Method that fetches next token (as if calling JsonParser.nextToken()) and if it is JsonToken.VALUE_NUMBER_INT returns 32-bit int value; otherwise returns specified default value It is functionally equivalent to:
nextLong() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.KeyIterator
Non-boxing variant of next().
nextLongValue(long) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
 
nextLongValue(long) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
 
nextLongValue(long) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
 
nextLongValue(long) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Method that fetches next token (as if calling JsonParser.nextToken()) and if it is JsonToken.VALUE_NUMBER_INT returns 64-bit long value; otherwise returns specified default value It is functionally equivalent to:
nextOrStay(T) - Method in class com.hazelcast.util.StateMachine
Transition to next state if not already there
nextPage() - Method in class com.hazelcast.query.PagingPredicate
sets the page value to next page
nextPowerOfTwo(int) - Static method in class com.hazelcast.util.QuickMath
Fast method of finding the next power of 2 greater than or equal to the supplied value.
nextPowerOfTwo(long) - Static method in class com.hazelcast.util.QuickMath
Fast method of finding the next power of 2 greater than or equal to the supplied value.
nextTextValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
 
nextTextValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
 
nextTextValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
 
nextTextValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Method that fetches next token (as if calling JsonParser.nextToken()) and if it is JsonToken.VALUE_STRING returns contained String value; otherwise returns null.
nextToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
nextToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
 
nextToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
 
nextToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
 
nextToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
 
nextToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
 
nextToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Main iteration method, which will advance stream enough to determine type of the next token, if any.
nextToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
 
nextToken() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserSequence
 
nextTokenToRead() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
 
nextValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
nextValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
 
nextValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Iteration method that will advance stream enough to determine type of the next token that is a value type (including JSON Array and Object start/end markers).
nextValue() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
 
nextValue() - Method in class com.hazelcast.util.collection.IntIterator
Strongly typed alternative of Iterator.next() to avoid boxing.
nextValue() - Method in class com.hazelcast.util.collection.Long2LongHashMap.LongIterator
Non-boxing variant of next().
nextValue() - Method in class com.hazelcast.util.collection.LongIterator
Strongly typed alternative of Iterator.next() not to avoid boxing.
NO_BYTES - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
NO_BYTES - Static variable in class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
 
NO_INTS - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
NO_NATIVE_TIME - Static variable in class com.hazelcast.jet.core.EventTimeMapper
Value to use as the nativeEventTime argument when calling EventTimeMapper.flatMapEvent(Object, int, long) when there's no native event time to supply.
NO_OFFLOADING - Static variable in interface com.hazelcast.core.Offloadable
Constant meaning that there will be no off-loading if returned from the Offloadable.getExecutorName() method.
NoDataMemberInClusterException - Exception in com.hazelcast.partition
Thrown when there is no data member in the cluster to assign partitions.
NoDataMemberInClusterException(String) - Constructor for exception com.hazelcast.partition.NoDataMemberInClusterException
 
node(String, Object, Object...) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
node - Variable in class com.hazelcast.instance.DefaultNodeExtension
 
node - Variable in class com.hazelcast.instance.HazelcastInstanceImpl
 
Node - Class in com.hazelcast.instance
 
Node(HazelcastInstanceImpl, Config, NodeContext) - Constructor for class com.hazelcast.instance.Node
 
Node - Class in com.hazelcast.org.snakeyaml.engine.v1.nodes
Base class for all nodes.
Node(Tag, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.nodes.Node
Create Node to be parsed
Node.NodeShutdownHookThread - Class in com.hazelcast.instance
 
NodeAware - Interface in com.hazelcast.spi
A 'capability' that can be implemented by object to get the Node injected.
NodeContext - Interface in com.hazelcast.instance
A context for node to provide its dependencies.
nodeEngine - Variable in class com.hazelcast.instance.Node
 
NodeEngine - Interface in com.hazelcast.spi
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a ManagedService.
nodeEngine - Variable in class com.hazelcast.spi.Offload
 
NodeEvent - Class in com.hazelcast.org.snakeyaml.engine.v1.events
Base class for all events that mark the beginning of a node.
NodeEvent(Optional<Anchor>, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.events.NodeEvent
 
NodeExtension - Interface in com.hazelcast.instance
NodeExtension is a Node extension mechanism to be able to plug different implementations of some modules, like; SerializationService, ChannelFactory etc.
NodeExtensionFactory - Class in com.hazelcast.instance
 
NodeFilter - Interface in com.hazelcast.spi.discovery
The NodeFilter, if supplied, will retrieve all discovered nodes and might apply additional filtering based on vendor provided metadata.
NodeIOService - Class in com.hazelcast.nio
 
NodeIOService(Node, NodeEngineImpl) - Constructor for class com.hazelcast.nio.NodeIOService
 
NodeShutdownHelper - Class in com.hazelcast.instance
Helper methods for node shutdown scenarios.
NodeState - Enum in com.hazelcast.instance
Possible states of a Node during its lifecycle.
NodeState - Interface in com.hazelcast.monitor
Local node statistics to be used by MemberState implementations.
NodeTuple - Class in com.hazelcast.org.snakeyaml.engine.v1.nodes
Stores one key value pair used in a map.
NodeTuple(Node, Node) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.nodes.NodeTuple
 
NodeType - Enum in com.hazelcast.org.snakeyaml.engine.v1.nodes
Enum for the basic YAML types: scalar, sequence and mapping.
noEventTime() - Static method in class com.hazelcast.jet.core.EventTimePolicy
Returns an event time policy that results in no timestamping.
NoLogFactory - Class in com.hazelcast.logging
 
NoLogFactory() - Constructor for class com.hazelcast.logging.NoLogFactory
 
noLogger() - Static method in class com.hazelcast.logging.Logger
 
NON_LOCAL_MEMBER_SELECTOR - Static variable in class com.hazelcast.cluster.memberselector.MemberSelectors
A MemberSelector instance that selects only remote members
NON_STD_TOKEN_INFINITY - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
NON_STD_TOKEN_MINUS_INFINITY - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
NON_STD_TOKEN_NAN - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
NON_STD_TOKEN_PLUS_INFINITY - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
NON_STD_TOKEN_VALUES - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
NON_STD_TOKENS - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
NonBlockingInputFeeder - Interface in com.hazelcast.com.fasterxml.jackson.core.async
Interface used by non-blocking JsonParser implementations to feed input to parse.
NonBlockingJsonParser - Class in com.hazelcast.com.fasterxml.jackson.core.json.async
 
NonBlockingJsonParser(IOContext, int, ByteQuadsCanonicalizer) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
 
NonBlockingJsonParserBase - Class in com.hazelcast.com.fasterxml.jackson.core.json.async
Intermediate base class for non-blocking JSON parsers.
NonBlockingJsonParserBase(IOContext, int, ByteQuadsCanonicalizer) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParserBase
 
NONE - Static variable in class com.hazelcast.security.permission.InstancePermission
 
noop() - Static method in interface com.hazelcast.jet.function.ConsumerEx
Returns a consumer that does nothing.
noop() - Static method in class com.hazelcast.jet.pipeline.Sinks
Returns a sink which discards all received items.
NOOP_TENANT_CONTROL - Static variable in interface com.hazelcast.spi.tenantcontrol.TenantControl
Default no-op tenant control
NOOP_TENANT_CONTROL_FACTORY - Static variable in interface com.hazelcast.spi.tenantcontrol.TenantControlFactory
Default tenant control factory.
NoOpHotRestartService - Class in com.hazelcast.hotrestart
Empty implementation of HotRestartService to avoid null checks.
NoOpHotRestartService() - Constructor for class com.hazelcast.hotrestart.NoOpHotRestartService
 
NoOpIdleStrategy - Class in com.hazelcast.util.concurrent
Low-latency idle strategy to be employed in loops that do significant work on each iteration such that any work in the idle strategy would be wasteful.
NoOpIdleStrategy() - Constructor for class com.hazelcast.util.concurrent.NoOpIdleStrategy
 
NoopInternalHotRestartService - Class in com.hazelcast.hotrestart
Empty implementation of InternalHotRestartService to avoid null checks.
NoopInternalHotRestartService() - Constructor for class com.hazelcast.hotrestart.NoopInternalHotRestartService
 
noopP() - Static method in class com.hazelcast.jet.core.processor.Processors
Returns a supplier of a processor that swallows all its normal input (if any), does nothing with it, forwards the watermarks, produces no output and completes immediately.
NopIndenter() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.DefaultPrettyPrinter.NopIndenter
 
normalize() - Method in class com.hazelcast.config.yaml.ElementAdapter
 
normalize(int, int) - Static method in class com.hazelcast.util.QuickMath
Divide value by factor, take the smallest integer greater than or equal to the result, multiply that integer by factor, and return it.
normalize(long, int) - Static method in class com.hazelcast.util.QuickMath
Divide value by factor, take the smallest integer greater than or equal to the result, multiply that integer by factor, and return it.
not(Predicate<K, V>) - Static method in class com.hazelcast.jet.pipeline.GenericPredicates
not(Predicate) - Static method in class com.hazelcast.query.Predicates
Creates a not predicate that will negate the result of the given predicate.
notEqual(String, Comparable) - Static method in class com.hazelcast.jet.pipeline.GenericPredicates
notEqual(Comparable) - Method in class com.hazelcast.query.EntryObject
 
notEqual(String, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates a not equal predicate that will pass items if the given value and the value stored under the given item attribute are not equal.
NotifiableEventListener<S> - Interface in com.hazelcast.spi
Contract point for event listeners to be notified by EventService.
Notifier - Interface in com.hazelcast.spi
A component used in wait/notify systems like Condition.
notifyExcludedMember(Address) - Method in interface com.hazelcast.hotrestart.InternalHotRestartService
Notifies the excluded member and triggers the member force start process.
notifyExcludedMember(Address) - Method in class com.hazelcast.hotrestart.NoopInternalHotRestartService
 
notifyShutdownInitiated() - Method in class com.hazelcast.util.executor.LoggingScheduledExecutor
 
NotLeaderException - Exception in com.hazelcast.cp.exception
A CPSubsystemException which is thrown when a leader-only request is received by a non-leader member.
NotLeaderException(CPGroupId, Endpoint, Endpoint) - Constructor for exception com.hazelcast.cp.exception.NotLeaderException
 
NR_BIGDECIMAL - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
NR_BIGINT - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
NR_DOUBLE - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
NR_FLOAT - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
NOTE! Not used by JSON implementation but used by many of binary codecs
NR_INT - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
NR_LONG - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
NR_UNKNOWN - Static variable in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
NULL - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.nodes.Tag
 
NULL - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.resolver.JsonScalarResolver
 
NULL_ARRAY_LENGTH - Static variable in class com.hazelcast.nio.Bits
for null arrays, this value is written to the stream to represent null array size.
NULL_BL_LINEBR - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.common.CharConstants
 
NULL_BL_T - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.common.CharConstants
 
NULL_BL_T_LINEBR - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.common.CharConstants
 
NULL_OR_LINEBR - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.common.CharConstants
 
nullRepresenter - Variable in class com.hazelcast.org.snakeyaml.engine.v1.representer.BaseRepresenter
in Java 'null' is not a type.
nullsFirst(Comparator<? super T>) - Static method in interface com.hazelcast.jet.function.ComparatorEx
nullsFirst(ComparatorEx<? super T>) - Static method in interface com.hazelcast.jet.function.ComparatorEx
nullsLast(Comparator<? super T>) - Static method in interface com.hazelcast.jet.function.ComparatorEx
nullsLast(ComparatorEx<? super T>) - Static method in interface com.hazelcast.jet.function.ComparatorEx
nullToEmpty(Collection<T>) - Static method in class com.hazelcast.util.CollectionUtil
Returns an empty Collection if argument is null.
nullToEmpty(Iterable<T>) - Static method in class com.hazelcast.util.IterableUtil
Return empty Iterable if argument is null
NumberAnchorGenerator - Class in com.hazelcast.org.snakeyaml.engine.v1.serializer
 
NumberAnchorGenerator(int) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.serializer.NumberAnchorGenerator
 
numberAvg() - Static method in class com.hazelcast.aggregation.Aggregators
 
numberAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
NumberInput - Class in com.hazelcast.com.fasterxml.jackson.core.io
 
NumberInput() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.io.NumberInput
 
NumberOutput - Class in com.hazelcast.com.fasterxml.jackson.core.io
 
NumberOutput() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.io.NumberOutput
 
numberType() - Method in interface com.hazelcast.com.fasterxml.jackson.core.TreeNode
If this node is a numeric type (as per JsonToken.isNumeric()), returns native type that node uses to store the numeric value; otherwise returns null.

O

OAHashSet<E> - Class in com.hazelcast.util.collection
Not thread-safe open-addressing hash Set implementation with linear probing for CPU cache efficiency.
OAHashSet() - Constructor for class com.hazelcast.util.collection.OAHashSet
Constructs an OAHashSet instance with default initial capacity and default load factor
OAHashSet(int) - Constructor for class com.hazelcast.util.collection.OAHashSet
Constructs an OAHashSet instance with the specified initial capacity and with the default load factor
OAHashSet(int, float) - Constructor for class com.hazelcast.util.collection.OAHashSet
Constructs an OAHashSet instance with the specified initial capacity and load factor
ObjectCodec - Class in com.hazelcast.com.fasterxml.jackson.core
Abstract class that defines the interface that JsonParser and JsonGenerator use to serialize and deserialize regular Java objects (POJOs aka Beans).
ObjectCodec() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.ObjectCodec
 
ObjectDataInput - Interface in com.hazelcast.nio
Provides serialization methods for arrays of primitive types.
ObjectDataOutput - Interface in com.hazelcast.nio
Provides serialization methods for arrays by extending DataOutput
objectName - Variable in class com.hazelcast.spi.DefaultObjectNamespace
Deprecated.
 
ObjectNamespace - Interface in com.hazelcast.spi
An ObjectNamespace that makes identification of object within a service possible.
ObjectNamespaceSerializationHelper - Class in com.hazelcast.concurrent.lock
Serialization helper to serialize/deserialize DistributedObjectNamespace and DefaultObjectNamespace between 3.8 and 3.9 members compatibly.
objectToDataCollection(Collection<C>, SerializationService) - Static method in class com.hazelcast.util.CollectionUtil
Converts a collection of any type to a collection of Data.
objectToDataCollection(Collection<C>, Collection<Data>, SerializationService, String) - Static method in class com.hazelcast.util.CollectionUtil
Converts a collection of any type to a collection of Data.
objectToRepresent - Variable in class com.hazelcast.org.snakeyaml.engine.v1.representer.BaseRepresenter
 
ObjLongBiFunction<T,R> - Interface in com.hazelcast.jet.core.function
Represents a specialization of BiFunction where the second argument is a long.
occurrenceSet - Variable in class com.hazelcast.config.AbstractDomConfigProcessor
Set collecting already seen elements.
of(Stream<Measurement>) - Static method in class com.hazelcast.jet.core.metrics.JobMetrics
Builds a JobMetrics object based on a stream of Measurements.
of(long, long, Map<String, String>) - Static method in class com.hazelcast.jet.core.metrics.Measurement
Builds a Measurement instance based on timestamp, value and the metric descriptor in map form.
of(int, ProcessorSupplier) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
Factory method that wraps the given ProcessorSupplier and returns the same instance for each given Address.
of(ProcessorSupplier) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
Wraps the provided ProcessorSupplier into a meta-supplier that will always return it.
of(SupplierEx<? extends Processor>, int) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
Factory method that wraps the given Supplier<Processor> and uses it as the supplier of all Processor instances.
of(SupplierEx<? extends Processor>) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
Factory method that wraps the given Supplier<Processor> and uses it as the supplier of all Processor instances.
of(FunctionEx<? super Address, ? extends ProcessorSupplier>, int) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
Factory method that creates a ProcessorMetaSupplier from the supplied function that maps a cluster member address to a ProcessorSupplier.
of(FunctionEx<? super Address, ? extends ProcessorSupplier>) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
Factory method that creates a ProcessorMetaSupplier from the supplied function that maps a cluster member address to a ProcessorSupplier.
of(SupplierEx<? extends Processor>) - Static method in interface com.hazelcast.jet.core.ProcessorSupplier
Returns a ProcessorSupplier which will delegate to the given Supplier<Processor> to create all Processor instances.
of(String) - Static method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
Reconstructs a ScheduledTaskHandler from a URN String.
of(T) - Static method in class com.hazelcast.util.StateMachine
 
of(int, int, int) - Static method in class com.hazelcast.version.MemberVersion
 
of(String) - Static method in class com.hazelcast.version.MemberVersion
 
of(int, int) - Static method in class com.hazelcast.version.Version
 
of(String) - Static method in class com.hazelcast.version.Version
Parse the given string to a Version.
offer(E) - Method in interface com.hazelcast.core.BaseQueue
Inserts the specified element into this queue if it is possible to do so immediately without violating capacity restrictions.
offer(E, long, TimeUnit) - Method in interface com.hazelcast.core.BaseQueue
Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to become available.
offer(E) - Method in interface com.hazelcast.core.TransactionalQueue
Inserts the specified element into this queue if it is possible to do so immediately without violating capacity restrictions.
offer(E, long, TimeUnit) - Method in interface com.hazelcast.core.TransactionalQueue
Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to become available.
offer(int, Object) - Method in interface com.hazelcast.jet.core.Outbox
Offers the supplied item to the bucket with the supplied ordinal.
offer(int[], Object) - Method in interface com.hazelcast.jet.core.Outbox
Offers the item to all supplied edge ordinals.
offer(Object) - Method in interface com.hazelcast.jet.core.Outbox
Offers the item to all edges.
offer(int, Object) - Method in class com.hazelcast.jet.core.test.TestOutbox
 
offer(Object) - Method in class com.hazelcast.jet.core.test.TestOutbox
 
offer(int[], Object) - Method in class com.hazelcast.jet.core.test.TestOutbox
 
offerToSnapshot(Object, Object) - Method in interface com.hazelcast.jet.core.Outbox
Offers the given key and value pair to the processor's snapshot storage.
offerToSnapshot(Object, Object) - Method in class com.hazelcast.jet.core.test.TestOutbox
 
Offload - Class in com.hazelcast.spi
This is an internal class.
Offload(Operation) - Constructor for class com.hazelcast.spi.Offload
Creates a new Offload instance.
OFFLOAD_ORDINAL - Static variable in class com.hazelcast.spi.CallStatus
The ordinal value for an Offload.
Offloadable - Interface in com.hazelcast.core
Allows off-loading the processing unit implementing this interface to the specified or default Executor.
OFFLOADABLE_EXECUTOR - Static variable in interface com.hazelcast.core.Offloadable
Constant meaning that processing will be off-loaded to the default OFFLOADABLE_EXECUTOR executor.
OFFLOADABLE_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
Name of the offloadable executor.
offloadedOperation() - Method in class com.hazelcast.spi.Offload
Returns the Operation that created this Offload.
oldValue - Variable in class com.hazelcast.core.EntryEvent
 
onAccept(Socket) - Method in interface com.hazelcast.nio.MemberSocketInterceptor
This method will be called when a connection to a member node is accepted meaning security requirements and clusters are matching.
onAccumulationFinished() - Method in class com.hazelcast.aggregation.Aggregator
Called after the last call to combine on a specific instance.
onBeforeLock(String, T) - Method in interface com.hazelcast.spi.LockInterceptorService
 
onChange(QuorumEvent) - Method in interface com.hazelcast.quorum.QuorumListener
Called when quorum presence state is changed.
onClusterStateChange(ClusterState, boolean) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
onClusterStateChange(ClusterState, boolean) - Method in interface com.hazelcast.instance.NodeExtension
Called during the commit phase of the cluster state change transaction, just after updating the value of the cluster state on the local member, while still holding the cluster lock.
onClusterVersionChange(Version) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
onClusterVersionChange(Version) - Method in interface com.hazelcast.instance.NodeExtension
Called after cluster version is changed.
onCombinationFinished() - Method in class com.hazelcast.aggregation.Aggregator
Called after the last call to combine on a specific instance.
onComplete(Map<Member, Object>) - Method in interface com.hazelcast.core.MultiExecutionCallback
Called after all executions are completed.
onConnect(Socket) - Method in interface com.hazelcast.nio.SocketInterceptor
Called when a connection is established.
onConnectionClose(T, Throwable, boolean) - Method in interface com.hazelcast.nio.ConnectionLifecycleListener
Deals with cleaning up a closed connection.
onConnectionClose(TcpIpConnection, Throwable, boolean) - Method in class com.hazelcast.nio.tcp.TcpIpEndpointManager.EndpointConnectionLifecycleListener
 
onDeregister(S, String, String, EventRegistration) - Method in interface com.hazelcast.spi.NotifiableEventListener
Called when this listener deregistered from EventService.
onDisconnect(Address, Throwable) - Method in interface com.hazelcast.nio.IOService
 
onDisconnect(Address, Throwable) - Method in class com.hazelcast.nio.NodeIOService
 
onEntryEvent(EntryEvent<K, V>) - Method in class com.hazelcast.core.EntryAdapter
This method is called when an one of the methods of the EntryListener is not overridden.
onError(Channel, Throwable) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionChannelErrorHandler
 
onError(Throwable) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionErrorHandler
 
onEvent(T) - Method in interface com.hazelcast.partition.PartitionEventListener
 
onExecutionFailure(Throwable) - Method in class com.hazelcast.spi.Operation
Called when an Exception/Error is thrown during operation execution.
onFailedConnection(Address) - Method in interface com.hazelcast.nio.IOService
 
onFailedConnection(Address) - Method in class com.hazelcast.nio.NodeIOService
 
onFailure(Throwable) - Method in interface com.hazelcast.core.ExecutionCallback
Called when an execution is completed with an error.
onFatalError(Exception) - Method in interface com.hazelcast.nio.IOService
 
onFatalError(Exception) - Method in class com.hazelcast.nio.NodeIOService
 
onFirstNull(Runnable) - Method in interface com.hazelcast.jet.Traverser
Returns a traverser that will emit the same items as this traverser and additionally run the supplied action the first time this traverser returns null.
onHeartbeat(Member, long) - Method in interface com.hazelcast.quorum.HeartbeatAware
Notifies of a received heartbeat.
onInitialClusterState(ClusterState) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
onInitialClusterState(ClusterState) - Method in interface com.hazelcast.instance.NodeExtension
Called when initial cluster state is received while joining the cluster.
onInvocationException(Throwable) - Method in class com.hazelcast.spi.Operation
Called when an Exception/Error is thrown during an invocation.
OnJoinPermissionOperationName - Enum in com.hazelcast.config
Enum of operation names for handling client permissions when the member is joining into the cluster.
onKeys(FunctionEx<? super T0, ? extends K>, FunctionEx<? super T1, ? extends K>) - Static method in class com.hazelcast.jet.pipeline.JoinClause
Constructs and returns a join clause with the supplied left-hand and right-hand key extractor functions, and with an identity right-hand projection function.
onKeys(Iterable<? extends KeyIn>) - Method in interface com.hazelcast.mapreduce.Job
Deprecated.
Defines keys to execute the mapper and a possibly defined reducer against.
onKeys(KeyIn...) - Method in interface com.hazelcast.mapreduce.Job
Deprecated.
Defines keys to execute the mapper and a possibly defined reducer against.
onKeys(Iterable<? extends EntryKey>) - Method in interface com.hazelcast.mapreduce.MappingJob
Deprecated.
Defines keys to execute the mapper and a possibly defined reducer against.
onKeys(EntryKey...) - Method in interface com.hazelcast.mapreduce.MappingJob
Deprecated.
Defines keys to execute the mapper and a possibly defined reducer against.
onKeys(Iterable<EntryKey>) - Method in interface com.hazelcast.mapreduce.ReducingJob
Deprecated.
Defines keys to execute the mapper and a possibly defined reducer against.
onKeys(EntryKey...) - Method in interface com.hazelcast.mapreduce.ReducingJob
Deprecated.
Defines keys to execute the mapper and a possibly defined reducer against.
onKeys(Iterable<EntryKey>) - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
Deprecated.
Defines keys to execute the mapper and a possibly defined reducer against.
onKeys(EntryKey...) - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
Deprecated.
Defines keys to execute the mapper and a possibly defined reducer against.
onMapEvent(MapEvent) - Method in class com.hazelcast.core.EntryAdapter
This method is called when an one of the methods of the EntryListener is not overridden.
onMemberListChange() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
onMemberListChange() - Method in interface com.hazelcast.instance.NodeExtension
Called synchronously when member list changes
onMessage(Message) - Method in class com.hazelcast.console.ConsoleApp
 
onMessage(Message<E>) - Method in interface com.hazelcast.core.MessageListener
Invoked when a message is received for the added topic.
onOutOfMemory(OutOfMemoryError, HazelcastInstance[]) - Method in class com.hazelcast.core.OutOfMemoryHandler
When an OutOfMemoryError is caught by Hazelcast threads, this method is called for ALL HazelcastInstances knows by current JVM (actually ClassLoader).
onOutOfMemory(OutOfMemoryError, HazelcastInstance[]) - Method in class com.hazelcast.instance.DefaultOutOfMemoryHandler
 
onOutOfMemory(OutOfMemoryError) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
Signals the OutOfMemoryErrorDispatcher that an OutOfMemoryError happened.
onPacketComplete(Packet) - Method in class com.hazelcast.nio.tcp.PacketDecoder
 
onPartitionLost(IPartitionLostEvent) - Method in interface com.hazelcast.spi.PartitionAwareService
Invoked when a partition lost is detected
onPartitionStateChange() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
onPartitionStateChange() - Method in interface com.hazelcast.instance.NodeExtension
Called synchronously when partition state (partition assignments, version etc) changes
onPingLost(Member) - Method in interface com.hazelcast.quorum.PingAware
Notifies the QuorumFunction of ping loss.
onPingRestored(Member) - Method in interface com.hazelcast.quorum.PingAware
Notifies the QuorumFunction of a successful ping after one or more pings to that member were lost.
onRead() - Method in class com.hazelcast.nio.ascii.TextDecoder
 
onRead() - Method in class com.hazelcast.nio.tcp.PacketDecoder
 
onRead() - Method in class com.hazelcast.nio.tcp.SingleProtocolDecoder
 
onRead() - Method in class com.hazelcast.nio.tcp.UnifiedProtocolDecoder
 
onRegister(S, String, String, EventRegistration) - Method in interface com.hazelcast.spi.NotifiableEventListener
Called when this listener registered to EventService.
onReplicationEvent(WanReplicationEvent) - Method in interface com.hazelcast.spi.ReplicationSupportingService
Processes a WAN replication event
onResponse(V) - Method in interface com.hazelcast.core.ExecutionCallback
Called when an execution is completed successfully.
onResponse(Member, Object) - Method in interface com.hazelcast.core.MultiExecutionCallback
Called when an execution is completed on a member.
onResult(T) - Method in class com.hazelcast.query.extractor.ValueCallback
Notifies about a value passed as an argument
onSetCallId(long) - Method in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
onSetCallId(long) - Method in class com.hazelcast.spi.Operation
Called every time a new callId is set on the operation.
onShutdown(long, TimeUnit) - Method in class com.hazelcast.crdt.CRDTReplicationMigrationService
Attempts to replicate only the unreplicated CRDT state to any non-local member in the cluster.
onShutdown(long, TimeUnit) - Method in interface com.hazelcast.spi.GracefulShutdownAwareService
A hook method that's called during graceful shutdown to provide safety for data managed by this service.
onSuccessfulConnection(Address) - Method in interface com.hazelcast.nio.IOService
 
onSuccessfulConnection(Address) - Method in class com.hazelcast.nio.NodeIOService
 
onThreadStart(Thread) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
onThreadStart(Thread) - Method in interface com.hazelcast.instance.NodeExtension
Called on thread start to inject/intercept extension specific logic, like; registering thread in some service, executing a special method before thread starts to do its own task.
onThreadStop(Thread) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
onThreadStop(Thread) - Method in interface com.hazelcast.instance.NodeExtension
Called before a thread stops to clean/release injected by NodeExtension.onThreadStart(Thread).
onWaitExpire() - Method in class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
 
onWaitExpire() - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
 
onWaitExpire() - Method in class com.hazelcast.concurrent.lock.operations.LockOperation
 
onWaitExpire() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
 
onWaitExpire() - Method in interface com.hazelcast.spi.BlockingOperation
 
onWrite() - Method in class com.hazelcast.nio.ascii.TextEncoder
 
onWrite() - Method in class com.hazelcast.nio.tcp.MemberProtocolEncoder
 
onWrite() - Method in class com.hazelcast.nio.tcp.PacketEncoder
 
onWrite() - Method in class com.hazelcast.nio.tcp.UnifiedProtocolEncoder
 
op - Variable in class com.hazelcast.spi.InvocationBuilder
 
open(String, Object...) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
open(NodeEngine) - Method in class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
This method is called before accessing the key-value pairs of this KeyValueSource.
open() - Method in class com.hazelcast.org.snakeyaml.engine.v1.serializer.Serializer
 
OperatingSystemMXBeanSupport - Class in com.hazelcast.util
Support class for reading attributes from OperatingSystemMXBean.
Operation - Class in com.hazelcast.spi
An operation could be compared to a Runnable.
Operation() - Constructor for class com.hazelcast.spi.Operation
 
OPERATION_BACKUP_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.GroupProperty
If an operation has backups, this property specifies how long the invocation will wait for acks from the backup replicas.
OPERATION_CALL_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
OperationAccessor - Class in com.hazelcast.spi
Allows access to certain attributes on an Operation.
OperationControl - Class in com.hazelcast.spi
Content of an Operation Control packet: a list of operations the remote member started on this member which are still running; a list of operations this member wants to cancel on the remote member. Operations are identified by their call ID.
OperationControl() - Constructor for class com.hazelcast.spi.OperationControl
 
OperationControl(long[], long[]) - Constructor for class com.hazelcast.spi.OperationControl
 
OperationFactory - Interface in com.hazelcast.spi
A Factory for creating Operation instances.
OperationResponseHandler<O extends Operation> - Interface in com.hazelcast.spi
A handler for the OperationService when it has calculated a response.
operationService - Variable in class com.hazelcast.spi.Offload
 
OperationService - Interface in com.hazelcast.spi
The OperationService is responsible for executing operations.
operationsToCancel() - Method in class com.hazelcast.spi.OperationControl
 
OperationTimeoutException - Exception in com.hazelcast.core
An unchecked version of TimeoutException.
OperationTimeoutException() - Constructor for exception com.hazelcast.core.OperationTimeoutException
 
OperationTimeoutException(String) - Constructor for exception com.hazelcast.core.OperationTimeoutException
 
OperationTimeoutException(String, String) - Constructor for exception com.hazelcast.core.OperationTimeoutException
 
OperationTimeoutException(String, Throwable) - Constructor for exception com.hazelcast.core.OperationTimeoutException
 
optional() - Method in interface com.hazelcast.config.properties.PropertyDefinition
Defines if this property is optional or not.
optional() - Method in class com.hazelcast.config.properties.SimplePropertyDefinition
 
or(MemberSelector...) - Static method in class com.hazelcast.cluster.memberselector.MemberSelectors
Selects a member when one of the selectors succeed
or(BiPredicateEx<? super T, ? super U>) - Method in interface com.hazelcast.jet.function.BiPredicateEx
or(PredicateEx<? super T>) - Method in interface com.hazelcast.jet.function.PredicateEx
or(TriPredicate<? super T, ? super U, ? super V>) - Method in interface com.hazelcast.jet.function.TriPredicate
Returns a composite predicate which evaluates the equivalent of this.test(t, u, v) || other.test(t, u, v).
or(Predicate<K, V>...) - Static method in class com.hazelcast.jet.pipeline.GenericPredicates
or(Predicate) - Method in class com.hazelcast.query.PredicateBuilder
 
or(Predicate...) - Static method in class com.hazelcast.query.Predicates
Creates an or predicate that will perform the logical or operation on the given predicates.
ORDERED_ASYNC_RESPONSES_DEFAULT - Static variable in class com.hazelcast.jet.pipeline.ContextFactory
ORDINAL - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
Index of the vertex input or output edges sourcing the metric.
ordinal() - Method in class com.hazelcast.spi.CallStatus
Returns the ordinal value (useful for doing a switch case based on the type of CallStatus).
original - Variable in class com.hazelcast.instance.HazelcastInstanceProxy
 
OS - Static variable in class com.hazelcast.util.OsHelper
OS name in lower case.
OsHelper - Class in com.hazelcast.util
Helper methods related to operating system on which the code is actually running.
Outbox - Interface in com.hazelcast.jet.core
Data sink for a Processor.
OutOfMemoryErrorDispatcher - Class in com.hazelcast.instance
 
OutOfMemoryHandler - Class in com.hazelcast.core
Handler for OutOfMemoryError.
OutOfMemoryHandler() - Constructor for class com.hazelcast.core.OutOfMemoryHandler
 
OutOfMemoryHandlerHelper - Class in com.hazelcast.instance
Helper class for OutOfMemoryHandlers to close sockets, stop threads, release allocated resources of an HazelcastInstanceImpl.
outputChecker(BiPredicate<? super List<?>, ? super List<?>>) - Method in class com.hazelcast.jet.core.test.TestSupport
Predicate to compare expected and actual output.
OutputDecorator - Class in com.hazelcast.com.fasterxml.jackson.core.io
Handler class that can be used to decorate output destinations.
OutputDecorator() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.io.OutputDecorator
 
outputInt(int, char[], int) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.NumberOutput
 
outputInt(int, byte[], int) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.NumberOutput
 
outputLong(long, char[], int) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.NumberOutput
 
outputLong(long, byte[], int) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.NumberOutput
 
OverflowPolicy - Enum in com.hazelcast.ringbuffer
Using this policy one can control the behavior what should to be done when an item is about to be added to the ringbuffer, but there is 0 remaining capacity.
overrideCurrentName(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
 
overrideCurrentName(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
overrideCurrentName(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
 
overrideCurrentName(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Method that can be used to change what is considered to be the current (field) name.
overrideCurrentName(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
 
overrideFormatFeatures(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
Bulk set method for (re)setting states of FormatFeatures, by specifying values (set / clear) along with a mask, to determine which features to change, if any.
overrideFormatFeatures(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Bulk set method for (re)setting states of FormatFeatures, by specifying values (set / clear) along with a mask, to determine which features to change, if any.
overrideFormatFeatures(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
 
overrideFormatFeatures(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
 
overrideStdFeatures(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
 
overrideStdFeatures(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserBase
 
overrideStdFeatures(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
Bulk set method for (re)setting states of features specified by mask.
overrideStdFeatures(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Bulk set method for (re)setting states of features specified by mask.
overrideStdFeatures(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
 
overrideStdFeatures(int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
 

P

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
Loads version information by introspecting a class named "PackageVersion" in the same package as the given class.
Packet - Class in com.hazelcast.nio
A Packet is a piece of data sent over the wire.
Packet() - Constructor for class com.hazelcast.nio.Packet
 
Packet(byte[]) - Constructor for class com.hazelcast.nio.Packet
 
Packet(byte[], int) - Constructor for class com.hazelcast.nio.Packet
 
Packet.Type - Enum in com.hazelcast.nio
 
PacketDecoder - Class in com.hazelcast.nio.tcp
The InboundHandler for member to member communication.
PacketDecoder(TcpIpConnection, Consumer<Packet>) - Constructor for class com.hazelcast.nio.tcp.PacketDecoder
 
PacketEncoder - Class in com.hazelcast.nio.tcp
A OutboundHandler that for member to member communication.
PacketEncoder() - Constructor for class com.hazelcast.nio.tcp.PacketEncoder
 
PacketIOHelper - Class in com.hazelcast.nio
Responsible for writing or reading an Packet.
PacketIOHelper() - Constructor for class com.hazelcast.nio.PacketIOHelper
 
PagingPredicate<K,V> - Class in com.hazelcast.query
This class is a special Predicate which helps to get a page-by-page result of a query.
PagingPredicate() - Constructor for class com.hazelcast.query.PagingPredicate
Used for serialization internally
PagingPredicate(int) - Constructor for class com.hazelcast.query.PagingPredicate
Construct with a pageSize results will not be filtered results will be natural ordered throws IllegalArgumentException if pageSize is not greater than 0
PagingPredicate(Predicate, int) - Constructor for class com.hazelcast.query.PagingPredicate
Construct with an inner predicate and pageSize results will be filtered via inner predicate results will be natural ordered throws IllegalArgumentException if pageSize is not greater than 0 throws IllegalArgumentException if inner predicate is also PagingPredicate
PagingPredicate(Comparator<Map.Entry<K, V>>, int) - Constructor for class com.hazelcast.query.PagingPredicate
Construct with a comparator and pageSize results will not be filtered results will be ordered via comparator throws IllegalArgumentException if pageSize is not greater than 0
PagingPredicate(Predicate<K, V>, Comparator<Map.Entry<K, V>>, int) - Constructor for class com.hazelcast.query.PagingPredicate
Construct with an inner predicate, comparator and pageSize results will be filtered via inner predicate results will be ordered via comparator throws IllegalArgumentException if pageSize is not greater than 0 throws IllegalArgumentException if inner predicate is also PagingPredicate
PagingPredicateAccessor - Class in com.hazelcast.query
This class provides paging accessor of predicate.
Parameters - Interface in com.hazelcast.security
This interface is used to pass parameters of a method call to a SecurityInterceptor.
parse(InputStream) - Method in class com.hazelcast.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.v1.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.v1.api.lowlevel.Parse
Create instance with provided LoadSettings
parse(I) - Method in class com.hazelcast.query.extractor.ArgumentParser
This method takes the unparsed argument object as an input and returns the parsed output that will be used by the ValueExtractor.
parse(Element) - Method in interface com.hazelcast.spi.ServiceConfigurationParser
 
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
 
parseClassFilterList(Node) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
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.v1.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 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.
parseInternal(Element, ParserContext) - Method in class com.hazelcast.jet.spring.JetClientBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class com.hazelcast.jet.spring.JetHazelcastBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class com.hazelcast.jet.spring.JetInstanceBeanDefinitionParser
 
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.v1.composer.Composer
 
Parser - Interface in com.hazelcast.org.snakeyaml.engine.v1.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.v1.api.lowlevel.Parse
Parse a YAML stream and produce parsing events.
ParserException - Exception in com.hazelcast.org.snakeyaml.engine.v1.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.v1.exceptions.ParserException
Constructs an instance.
ParserException(String, Optional<Mark>) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v1.exceptions.ParserException
 
ParserImpl - Class in com.hazelcast.org.snakeyaml.engine.v1.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.v1.parser.ParserImpl
 
ParserImpl(Scanner, LoadSettings) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.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
 
parseSerialization(Node) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
parseSocketInterceptorConfig(Node) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
parseSslConfig(Node) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
parseString(String) - Static method in enum com.hazelcast.config.CacheDeserializedValues
Create instance from String
parseString(String) - Method in class com.hazelcast.org.snakeyaml.engine.v1.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
 
Partition - Interface in com.hazelcast.core
In Hazelcast the data is split up in partitions: by default, 271 and configurable through the 'hazelcast.partition.count' GroupProperty.
PARTITION_BACKUP_SYNC_INTERVAL - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
PARTITION_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Total number of partitions in the Hazelcast cluster.
PARTITION_FRAGMENTED_MIGRATION_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
PARTITION_GROUP_HOST - Static variable in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
Metadata key definition for a low-latency link on a shared physical node, in case of virtualization being used
PARTITION_GROUP_RACK - Static variable in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
Metadata key definition for a low-latency link inside the same data center but for different racks
PARTITION_GROUP_ZONE - Static variable in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
Metadata key definition for a low-latency link between (virtual) data centers in the same area
PARTITION_MAX_PARALLEL_REPLICATIONS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
PARTITION_MIGRATION_INTERVAL - Static variable in class com.hazelcast.spi.properties.GroupProperty
Time in seconds to sleep after a migration task.
PARTITION_MIGRATION_TIMEOUT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Timeout in seconds for all migration operations.
PARTITION_OPERATION_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
The number of partition operation handler threads per member.
PARTITION_STRATEGY_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
PARTITION_TABLE_SEND_INTERVAL - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
PartitionAware<T> - Interface in com.hazelcast.core
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.core
PartitionAwareKey(K, P) - Constructor for class com.hazelcast.core.PartitionAwareKey
Creates a new PartitionAwareKey.
PartitionAwareOperation - Interface in com.hazelcast.spi
An interface that can be implemented by an operation to indicate that it should be invoked on a particular partition.
PartitionAwareService - Interface in com.hazelcast.spi
An interface that can be implemented by SPI services to get notified of when a partition-related event occurs; for example, if a MapService notifies its map listeners when partition is lost for a map.
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.
PartitionEventListener<T extends PartitionEvent> - Interface in com.hazelcast.partition
PartitionEventListener is a base interface for partition-related event listeners.
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 backup strategies based on cloud or service discovery provided information.
PartitionGroupStrategy - Interface in com.hazelcast.spi.partitiongroup
A PartitionGroupStrategy implementation defines a strategy how backup groups are designed.
partitionId - Variable in class com.hazelcast.spi.InvocationBuilder
 
PartitionIdAware - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
partitionIdleTimeout() - Method in interface com.hazelcast.jet.pipeline.StreamSource
PARTITIONING_STRATEGY - Static variable in class com.hazelcast.spi.AbstractDistributedObject
 
PARTITIONING_STRATEGY_CLASS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
PartitioningStrategy<K> - Interface in com.hazelcast.core
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
 
PartitioningStrategyConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
PartitioningStrategyConfigReadOnly(PartitioningStrategyConfig) - Constructor for class com.hazelcast.config.PartitioningStrategyConfigReadOnly
Deprecated.
 
partitionLost(MapPartitionLostEvent) - Method in interface com.hazelcast.map.listener.MapPartitionLostListener
Invoked when owner and all backups of a partition is lost for a specific map.
partitionLost(PartitionLostEvent) - Method in interface com.hazelcast.partition.PartitionLostListener
Invoked when a partition loses its owner and all backups.
PartitionLostEvent - Class in com.hazelcast.partition
The event that is fired when a partition lost its owner and all backups.
PartitionLostEvent() - Constructor for class com.hazelcast.partition.PartitionLostEvent
 
PartitionLostEvent(int, int, Address) - Constructor for class com.hazelcast.partition.PartitionLostEvent
 
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
 
PartitionMigrationEvent - Class in com.hazelcast.spi
An EventObject for a partition migration.
PartitionMigrationEvent(MigrationEndpoint, int, int, int) - Constructor for class com.hazelcast.spi.PartitionMigrationEvent
 
PartitionPredicate<K,V> - Class in com.hazelcast.query
A Predicate that restricts the execution of a Predicate to a single Partition.
PartitionPredicate() - Constructor for class com.hazelcast.query.PartitionPredicate
 
PartitionPredicate(Object, Predicate<K, V>) - Constructor for class com.hazelcast.query.PartitionPredicate
Creates a new PartitionPredicate.
PartitionReplicationEvent - Class in com.hazelcast.spi
An event send to MigrationAwareService when partition changes happen.
PartitionReplicationEvent(int, int) - Constructor for class com.hazelcast.spi.PartitionReplicationEvent
Creates a PartitionReplicationEvent
PartitionService - Interface in com.hazelcast.core
PartitionService allows you to query Partitions and attach/detach MigrationListeners to listen to partition migration events.
partitionService - Variable in class com.hazelcast.instance.Node
 
PassThroughCacheMergePolicy - Class in com.hazelcast.cache.merge
Merges cache entries from source to destination directly unless the merging entry is null.
PassThroughCacheMergePolicy() - Constructor for class com.hazelcast.cache.merge.PassThroughCacheMergePolicy
 
PassThroughMergePolicy - Class in com.hazelcast.map.merge
Merges map entries from source to destination directly unless the merging entry is null.
PassThroughMergePolicy() - Constructor for class com.hazelcast.map.merge.PassThroughMergePolicy
 
PassThroughMergePolicy - Class in com.hazelcast.replicatedmap.merge
Merges replicated map entries from source to destination directly unless the merging entry is null.
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
 
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"
pause(String, String) - Method in interface com.hazelcast.wan.WanReplicationService
Pauses WAN replication for the given wanReplicationName and targetGroupName on this hazelcast instance.
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.core.TransactionalQueue
peek(long, TimeUnit) - Method in interface com.hazelcast.core.TransactionalQueue
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.v1.scanner.StreamReader
 
peek(int) - Method in class com.hazelcast.org.snakeyaml.engine.v1.scanner.StreamReader
Peek the next index-th code point
peekEvent() - Method in interface com.hazelcast.org.snakeyaml.engine.v1.parser.Parser
Return the next event, but do not delete it from the stream.
peekEvent() - Method in class com.hazelcast.org.snakeyaml.engine.v1.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
Same as peekInput(toStringFn, shouldLogFn, metaSupplier), but accepts a ProcessorSupplier instead of a meta-supplier.
peekInputP(FunctionEx<T, ? extends CharSequence>, PredicateEx<T>, SupplierEx<Processor>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
Same as peekInput(toStringFn, shouldLogFn, metaSupplier), but accepts a SupplierEx of processors instead of a meta-supplier.
peekInputP(ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
Convenience for peekInput(toStringFn, shouldLogFn, metaSupplier) with a pass-through filter and Object#toString as the formatting function.
peekInputP(ProcessorSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
Convenience for peekInput(toStringFn, shouldLogFn, metaSupplier) with a pass-through filter and Object#toString as the formatting function.
peekInputP(SupplierEx<Processor>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
Convenience for peekInput(toStringFn, shouldLogFn, metaSupplier) with a pass-through filter and Object#toString as the formatting function.
peekOutputP(FunctionEx<? super T, ? extends CharSequence>, PredicateEx<? super T>, ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
Returns a meta-supplier that wraps the provided one and adds a logging layer to each processor it creates.
peekOutputP(FunctionEx<? super T, ? extends CharSequence>, PredicateEx<? super T>, ProcessorSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
Same as peekOutput(toStringFn, shouldLogFn, metaSupplier), but accepts a ProcessorSupplier instead of a meta-supplier.
peekOutputP(FunctionEx<? super T, ? extends CharSequence>, PredicateEx<? super T>, SupplierEx<Processor>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
Same as peekOutput(toStringFn, shouldLogFn, metaSupplier), but accepts a SupplierEx of processors instead of a meta-supplier.
peekOutputP(ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
Convenience for peekOutput(toStringFn, shouldLogFn, metaSupplier with a pass-through filter and Object#toString as the formatting function.
peekOutputP(ProcessorSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
Convenience for peekOutput(toStringFn, shouldLogFn, metaSupplier with a pass-through filter and Object#toString as the formatting function.
peekOutputP(SupplierEx<Processor>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
Convenience for peekOutput(toStringFn, shouldLogFn, metaSupplier with a pass-through filter and Object#toString as the formatting function.
peekSnapshotP(FunctionEx<? super Map.Entry<K, V>, ? extends CharSequence>, PredicateEx<? super Map.Entry<K, V>>, ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
Returns a meta-supplier that wraps the provided one and adds a logging layer to each processor it creates.
peekSnapshotP(FunctionEx<? super Map.Entry<K, V>, ? extends CharSequence>, PredicateEx<? super Map.Entry<K, V>>, ProcessorSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
Same as peekSnapshot(toStringFn, shouldLogFn, metaSupplier), but accepts a ProcessorSupplier instead of a meta-supplier.
peekSnapshotP(FunctionEx<? super Map.Entry<K, V>, ? extends CharSequence>, PredicateEx<? super Map.Entry<K, V>>, SupplierEx<Processor>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
Same as peekSnapshot(toStringFn, shouldLogFn, metaSupplier), but accepts a SupplierEx of processors instead of a meta-supplier.
peekSnapshotP(SupplierEx<Processor>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
Convenience for peekSnapshot(toStringFn, shouldLogFn, metaSupplier with a pass-through filter and Object#toString as the formatting function.
peekSnapshotP(ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
Convenience for peekSnapshot(toStringFn, shouldLogFn, metaSupplier with a pass-through filter and Object#toString as the formatting function.
peekSnapshotP(ProcessorSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
Convenience for peekSnapshot(toStringFn, shouldLogFn, metaSupplier with a pass-through filter and Object#toString as the formatting function.
peekToken() - Method in interface com.hazelcast.org.snakeyaml.engine.v1.scanner.Scanner
Return the next token, but do not delete it from the stream.
peekToken() - Method in class com.hazelcast.org.snakeyaml.engine.v1.scanner.ScannerImpl
Return the next token, but do not delete it from the queue.
peel(Throwable) - Static method in class com.hazelcast.util.ExceptionUtil
 
peel(Throwable, Class<T>, String) - Static method in class com.hazelcast.util.ExceptionUtil
Processes Throwable t so that the returned Throwable's type matches allowedType or RuntimeException.
peel(Throwable, Class<T>, String, ExceptionUtil.RuntimeExceptionFactory) - Static method in class com.hazelcast.util.ExceptionUtil
Processes Throwable t so that the returned Throwable's type matches allowedType or RuntimeException.
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
 
permitCount - Variable in class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
 
PHONE_HOME_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
phoneHome - Variable in class com.hazelcast.instance.DefaultNodeExtension
 
PhoneHome - Class in com.hazelcast.util
Pings phone home server with cluster info daily.
PhoneHome(Node) - Constructor for class com.hazelcast.util.PhoneHome
 
phoneHome(Node) - Method in class com.hazelcast.util.PhoneHome
 
PhoneHome.PhoneHomeParameterCreator - Class in com.hazelcast.util
Util class for parameters of OS and EE PhoneHome pings.
PhoneHomeParameterCreator() - Constructor for class com.hazelcast.util.PhoneHome.PhoneHomeParameterCreator
 
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.
PingAware - Interface in com.hazelcast.quorum
Quorum 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.
PN_COUNTER - Static variable in class com.hazelcast.crdt.CRDTDataSerializerHook
The (de)serialization constant for a PNCounter implementation
PN_COUNTER_ADD_OPERATION - Static variable in class com.hazelcast.crdt.CRDTDataSerializerHook
The constant for the PNCounter AddOperation
PN_COUNTER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
PN_COUNTER_GET_OPERATION - Static variable in class com.hazelcast.crdt.CRDTDataSerializerHook
The constant for the PNCounter GetOperation
PN_COUNTER_REPLICATION - Static variable in class com.hazelcast.crdt.CRDTDataSerializerHook
The (de)serialization constant for a PNCounter replication operation
PNCounter - Interface in com.hazelcast.crdt.pncounter
PN (Positive-Negative) CRDT counter.
PNCounterConfig - Class in com.hazelcast.config
Configuration for a PNCounter
PNCounterConfig() - Constructor for class com.hazelcast.config.PNCounterConfig
 
PNCounterConfig(String, int, String, boolean) - Constructor for class com.hazelcast.config.PNCounterConfig
 
PNCounterConfig(String) - Constructor for class com.hazelcast.config.PNCounterConfig
 
PNCounterConfig(PNCounterConfig) - Constructor for class com.hazelcast.config.PNCounterConfig
 
PNCounterImpl - Class in com.hazelcast.crdt.pncounter
PN (Positive-Negative) CRDT counter where each replica is identified by a String.
PNCounterImpl() - Constructor for class com.hazelcast.crdt.pncounter.PNCounterImpl
 
PNCounterPermission - Class in com.hazelcast.security.permission
 
PNCounterPermission(String, String...) - Constructor for class com.hazelcast.security.permission.PNCounterPermission
 
PNCounterProxy - Class in com.hazelcast.crdt.pncounter
Member proxy implementation for a PNCounter.
PNCounterReplicationOperation - Class in com.hazelcast.crdt.pncounter
CRDT replication operation for a PNCounter.
PNCounterReplicationOperation() - Constructor for class com.hazelcast.crdt.pncounter.PNCounterReplicationOperation
 
PNCounterService - Class in com.hazelcast.crdt.pncounter
Service responsible for PNCounter proxies and replication operation.
PNCounterService() - Constructor for class com.hazelcast.crdt.pncounter.PNCounterService
 
poll() - Method in interface com.hazelcast.core.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.core.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.core.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.core.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.core.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.core.TransactionalQueue
Retrieves and removes the head of this queue, waiting up to the specified wait time if necessary for an element to become available.
poll() - 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
 
pollExpiredAwaitOp(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
PoolExecutorThreadFactory - Class in com.hazelcast.util.executor
 
PoolExecutorThreadFactory(String, ClassLoader) - Constructor for class com.hazelcast.util.executor.PoolExecutorThreadFactory
 
PoolExecutorThreadFactory.ManagedThread - Class in com.hazelcast.util.executor
 
pop() - Method in class com.hazelcast.org.snakeyaml.engine.v1.common.ArrayStack
 
populate(LiveOperations) - Method in interface com.hazelcast.spi.LiveOperationsTracker
Populate the LiveOperations
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 - 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 a mean of reading portable fields from a binary in form of java primitives arrays of java primitives, nested portable fields and array of portable fields.
PortableWriter - Interface in com.hazelcast.nio.serialization
Provides a mean of writing portable fields to a binary in form of java primitives arrays of java primitives, nested portable fields and array of portable fields.
position() - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
position(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
position() - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
position(int) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
postDestroy() - Method in class com.hazelcast.concurrent.idgen.IdGeneratorProxy
 
postDestroy() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
PostJoinAwareService - Interface in com.hazelcast.spi
Marker interface for services that want to return operations to be executed on the cluster members after a join has been finalized.
PostProcessingMapStore - Interface in com.hazelcast.core
Implement this interface if you modify the value in MapStore.store(K key, V value) method.
Preconditions - Class in com.hazelcast.util
A utility class for validating arguments and state.
preDestroy() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
Predicate<K,V> - Interface in com.hazelcast.query
Represents a map entry predicate.
Predicate<T> - Interface in com.hazelcast.util.function
Represents a predicate (boolean-valued function) of one argument.
PREDICATE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
PredicateBuilder - Class in com.hazelcast.query
This class provides functionality to build predicate.
PredicateBuilder() - Constructor for class com.hazelcast.query.PredicateBuilder
 
PredicateConfig - Class in com.hazelcast.config
Contains the configuration for an Predicate.
PredicateConfig() - Constructor for class com.hazelcast.config.PredicateConfig
Creates a PredicateConfig without className/implementation.
PredicateConfig(String) - Constructor for class com.hazelcast.config.PredicateConfig
Creates a PredicateConfig with the given className.
PredicateConfig(PredicateConfig) - Constructor for class com.hazelcast.config.PredicateConfig
 
PredicateConfig(Predicate) - Constructor for class com.hazelcast.config.PredicateConfig
Creates a PredicateConfig with the given implementation.
PredicateEx<T> - Interface in com.hazelcast.jet.function
Serializable variant of java.util.function.Predicate which declares checked exception.
Predicates - Class in com.hazelcast.query
A utility class to create Predicate instances.
PREFER_IPv4_STACK - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
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
Variant of ProcessorMetaSupplier.preferLocalParallelismOne(ProcessorSupplier) where the supplied SupplierEx<Processor> will be wrapped into a ProcessorSupplier.
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.v1.nodes.Tag
 
prefix(int) - Method in class com.hazelcast.org.snakeyaml.engine.v1.scanner.StreamReader
peek the next length code points
PrefixedDistributedObject - Interface in com.hazelcast.core
Contact point for special DistributedObject's which has prefixed name.
prefixForward(int) - Method in class com.hazelcast.org.snakeyaml.engine.v1.scanner.StreamReader
prefix(length) immediately followed by forward(length)
PreJoinAwareService - Interface in com.hazelcast.spi
Services which need to perform operations on a joining member just before the member is set as joined must implement this interface.
prepareMergeRunnable() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
 
prepareMergeRunnable() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
 
prepareMergeRunnable() - Method in interface com.hazelcast.spi.SplitBrainHandlerService
When the two separate clusters merge (resolve a split-brain), this method is called to return a Runnable, that will merge the clusters.
prepareMigrationOperation(int) - Method in interface com.hazelcast.crdt.CRDTReplicationAwareService
Returns a migration operation for all of the CRDT states not owned by this member.
prepareMigrationOperation(int) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
 
prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
 
prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
prepareReplicationOperation(PartitionReplicationEvent, Collection<ServiceNamespace>) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
 
prepareReplicationOperation(Map<String, VectorClock>, int) - Method in interface com.hazelcast.crdt.CRDTReplicationAwareService
Returns a replication operation for the provided vector clocks.
prepareReplicationOperation(Map<String, VectorClock>, int) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
prepareReplicationOperation(PartitionReplicationEvent, Collection<ServiceNamespace>) - Method in interface com.hazelcast.spi.FragmentedMigrationAwareService
Returns an operation to replicate service data and/or state for a specific partition replica and namespaces on another cluster member.
prepareReplicationOperation(PartitionReplicationEvent) - Method in interface com.hazelcast.spi.MigrationAwareService
Returns an operation to replicate service data and/or state for a specific partition replica on another cluster member.
prepareToSafeShutdown() - Method in interface com.hazelcast.crdt.CRDTReplicationAwareService
Prepares the service for replication and shutdown.
prepareToSafeShutdown() - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
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.v1.api.lowlevel
Emit the events into a data stream (opposite for Parse)
Present(DumpSettings) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.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 class 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.
PRIMITIVE_TYPE_BOOLEAN - Static variable in class com.hazelcast.nio.IOUtil
 
PRIMITIVE_TYPE_BYTE - Static variable in class com.hazelcast.nio.IOUtil
 
PRIMITIVE_TYPE_DOUBLE - Static variable in class com.hazelcast.nio.IOUtil
 
PRIMITIVE_TYPE_FLOAT - Static variable in class com.hazelcast.nio.IOUtil
 
PRIMITIVE_TYPE_INTEGER - Static variable in class com.hazelcast.nio.IOUtil
 
PRIMITIVE_TYPE_LONG - Static variable in class com.hazelcast.nio.IOUtil
 
PRIMITIVE_TYPE_SHORT - Static variable in class com.hazelcast.nio.IOUtil
 
PRIMITIVE_TYPE_UTF - Static variable in class com.hazelcast.nio.IOUtil
 
print(Object) - Method in class com.hazelcast.console.ConsoleApp
 
println(Object) - Method in class com.hazelcast.console.ConsoleApp
 
printNodeInfo() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
printNodeInfo() - Method in interface com.hazelcast.instance.NodeExtension
Called to print node information during startup
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.GroupProperty
The number of priority generic operation handler threads per member.
PrivateApi - Annotation Type in com.hazelcast.spi.annotation
Marker for private api.
ProbabilisticQuorumConfigBuilder - Class in com.hazelcast.config
Builder for a QuorumConfig configured with ProbabilisticQuorumFunction that considers members present in the context of a quorum using a probabilistic, adaptive quorum function.
process(EntryTaskScheduler<Data, Integer>, Collection<ScheduledEntry<Data, Integer>>) - Method in class com.hazelcast.concurrent.lock.LockEvictionProcessor
 
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.
process(byte[]) - Method in interface com.hazelcast.util.ByteArrayProcessor
 
process(byte[], int, int) - Method in interface com.hazelcast.util.ByteArrayProcessor
 
process(byte[], int, int, byte[]) - Method in interface com.hazelcast.util.ByteArrayProcessor
 
process(EntryTaskScheduler<K, V>, Collection<ScheduledEntry<K, V>>) - Method in interface com.hazelcast.util.scheduler.ScheduledEntryProcessor
Processes all entries.
processBackup(Map.Entry<K, V>) - Method in interface com.hazelcast.map.EntryBackupProcessor
 
processDuplicateKeys(MappingNode) - Method in class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor
 
processedCount() - Method in class com.hazelcast.util.executor.StripedExecutor
Returns the total number of processed events.
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
 
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
Factory of ProcessorSupplier instances.
ProcessorMetaSupplier.Context - Interface in com.hazelcast.jet.core
Context passed to the meta-supplier at init time on the member that received a job request from the client.
Processors - Class in com.hazelcast.jet.core.processor
Static utility class with factory methods for Jet processors.
ProcessorSupplier - Interface in com.hazelcast.jet.core
Factory of Processor instances.
ProcessorSupplier.Context - Interface in com.hazelcast.jet.core
Context passed to the supplier in the init() call.
project(Projection<Map.Entry<K, V>, R>) - Method in interface com.hazelcast.core.IMap
Applies the projection logic on all map entries and returns the result
project(Projection<Map.Entry<K, V>, R>, Predicate<K, V>) - Method in interface com.hazelcast.core.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> - Class in com.hazelcast.projection
Enables transforming object into other objects.
Projection() - Constructor for class com.hazelcast.projection.Projection
 
Projections - Class in com.hazelcast.projection
A utility class to create basic Projection instances.
promoteLocalLiteMember() - Method in interface com.hazelcast.core.Cluster
Promotes local lite member to data member.
promoteToCPMember() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Promotes the local Hazelcast member to a CP member.
properties() - Method in interface com.hazelcast.nio.IOService
 
properties() - Method in class com.hazelcast.nio.NodeIOService
 
propertiesByInstanceItself(HazelcastInstance) - Static method in class com.hazelcast.cache.HazelcastCachingProvider
Create the Properties with the provided instance itself.
propertiesByInstanceName(String) - Static method in class com.hazelcast.cache.HazelcastCachingProvider
Create the Properties with the provided instance name.
propertiesByLocation(String) - Static method in class com.hazelcast.cache.HazelcastCachingProvider
Create the Properties with the provided config file location.
PROPERTY_CIPHER_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Replacer property name to configure Cipher algorithm name.
PROPERTY_KEY_LENGTH_BITS - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Replacer property name to configure key length (in bits).
PROPERTY_PASSWORD_FILE - Static variable in class com.hazelcast.config.replacer.EncryptionReplacer
Replacer property name to configure path to a password file which content should be used as part of the encryption password.
PROPERTY_PASSWORD_NETWORK_INTERFACE - Static variable in class com.hazelcast.config.replacer.EncryptionReplacer
Replacer property name to configure network interface name used to retrieve MAC address used as part of the encryption password.
PROPERTY_PASSWORD_USER_PROPERTIES - Static variable in class com.hazelcast.config.replacer.EncryptionReplacer
Replacer property name to configure true/false flag contolling if users properties should be used as part of the encryption password.
PROPERTY_SALT_LENGTH_BYTES - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Replacer property name to configure salt length (in bytes).
PROPERTY_SECRET_KEY_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Replacer property name to configure SecretKeySpec algorithm name.
PROPERTY_SECRET_KEY_FACTORY_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Replacer property name to configure SecretKeyFactory algorithm name.
PROPERTY_SECURITY_PROVIDER - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Replacer property name to configure Java Security provider name used for Cipher and SecretKeyFactory selection.
PropertyDefinition - Interface in com.hazelcast.config.properties
This interface describes an extended approach of the currently available pure property based configuration inside Hazelcast and helps implementing an automatic and transparent way to verify configuration as well as converting types based on provided validators and converters.
PropertyExtractor<ValueIn,ValueOut> - Interface in com.hazelcast.mapreduce.aggregation
Deprecated.
Use fast-aggregations Aggregator
PropertyReplacer - Class in com.hazelcast.config.replacer
ConfigReplacer for replacing property names with property values for properties provided in PropertyReplacer.init(Properties) method.
PropertyReplacer() - Constructor for class com.hazelcast.config.replacer.PropertyReplacer
 
PropertyTypeConverter - Enum in com.hazelcast.config.properties
This enum class contains basic TypeConverter implementations to convert strings to all common basic Java types.
PROTOCOL_LENGTH - Static variable in class com.hazelcast.nio.Protocols
The length in bytes of the of the protocol-string
Protocols - Class in com.hazelcast.nio
First bytes to send a node that defines selected protocol
protocolType - Variable in class com.hazelcast.config.EndpointConfig
 
ProtocolType - Enum in com.hazelcast.instance
Types of server sockets.
provide(EndpointQualifier) - Method in class com.hazelcast.nio.tcp.DefaultChannelInitializerProvider
 
provideClientChannelInitializer(EndpointConfig) - Method in class com.hazelcast.nio.tcp.DefaultChannelInitializerProvider
 
provideMemberChannelInitializer(EndpointConfig) - Method in class com.hazelcast.nio.tcp.DefaultChannelInitializerProvider
 
provideMetrics(MetricsRegistry) - Method in class com.hazelcast.nio.tcp.TcpIpAcceptor
 
provideTextChannelInitializer(EndpointConfig, boolean) - Method in class com.hazelcast.nio.tcp.DefaultChannelInitializerProvider
 
provideUnifiedChannelInitializer() - Method in class com.hazelcast.nio.tcp.DefaultChannelInitializerProvider
 
provideWanChannelInitializer(EndpointConfig) - Method in class com.hazelcast.nio.tcp.DefaultChannelInitializerProvider
 
ProxyService - Interface in com.hazelcast.spi
A CoreService responsible for managing the DistributedObject proxies.
publish(E) - Method in interface com.hazelcast.core.ITopic
Publishes the message to all subscribers of this topic.
publishEvent(String, String, Object, int) - Method in interface com.hazelcast.spi.EventService
Publishes an event for all event registrations belonging to the specified service name and topic.
publishEvent(String, EventRegistration, Object, int) - Method in interface com.hazelcast.spi.EventService
Publishes an event for a specific event registration.
publishEvent(String, Collection<EventRegistration>, Object, int) - Method in interface com.hazelcast.spi.EventService
Publishes an event for multiple event registrations.
publishRemoteEvent(String, Collection<EventRegistration>, Object, int) - Method in interface com.hazelcast.spi.EventService
Publishes an event for multiple event registrations, excluding local ones.
publishReplicationEvent(String, ReplicationEventObject) - Method in interface com.hazelcast.wan.WanReplicationPublisher
Publish the eventObject WAN replication event.
publishReplicationEvent(WanReplicationEvent) - Method in interface com.hazelcast.wan.WanReplicationPublisher
Publishes the wanReplicationEvent on this publisher.
publishReplicationEventBackup(String, ReplicationEventObject) - Method in interface com.hazelcast.wan.WanReplicationPublisher
Publish the eventObject WAN replication event backup.
publishRequest(TextCommand) - Method in class com.hazelcast.nio.ascii.TextDecoder
 
purgeStaleEntries() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
Removes any stale entries whose keys have been finalized.
push(T) - Method in class com.hazelcast.org.snakeyaml.engine.v1.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(LockStoreImpl) - Method in class com.hazelcast.concurrent.lock.LockStoreContainer
 
put(K, V) - Method in interface com.hazelcast.core.BaseMap
Associates the specified value with the specified key in this map.
put(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.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.core.BaseMultiMap
Stores a key-value pair in the multimap.
put(K, V) - Method in interface com.hazelcast.core.IMap
Associates the specified value with the specified key in this map.
put(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.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.core.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.core.MultiMap
Stores a key-value pair in the multimap.
put(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.ReplicatedMap
Associates a given value to the specified key and replicates it to the cluster.
put(K, V) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.put(Object, Object).
put(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.put(Object, Object, long, TimeUnit).
put(K, V) - Method in interface com.hazelcast.core.TransactionalMultiMap
Stores a key-value pair in the multimap.
put(Tag<E>, E) - Method in class com.hazelcast.jet.datamodel.ItemsByTag
Associates the supplied value with the supplied tag.
put(int, int, V) - Method in class com.hazelcast.util.collection.BiInt2ObjectMap
Put a value into the map.
put(K1, K2, V) - Method in class com.hazelcast.util.collection.ComposedKeyMap
 
put(Integer, V) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
 
put(int, V) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
Overloaded version of Map.put(Object, Object) that takes a primitive int key.
put(K, V) - Method in class com.hazelcast.util.collection.InternalListMultiMap
Put value to a given key.
put(K, V) - Method in class com.hazelcast.util.collection.InternalSetMultimap
Associate value to a given key.
put(long, long) - Method in class com.hazelcast.util.collection.Long2LongHashMap
 
put(Long, Long) - Method in class com.hazelcast.util.collection.Long2LongHashMap
 
put(Long, V) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
 
put(long, V) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
Overloaded version of Map.put(Object, Object) that takes a primitive long key.
put(K, V) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
Maps the specified key to the specified value in this table.
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.core.IMap
putAll(Map<? extends Integer, ? extends V>) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
 
putAll(Map<? extends Long, ? extends Long>) - Method in class com.hazelcast.util.collection.Long2LongHashMap
 
putAll(Map<? extends Long, ? extends V>) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
 
putAll(Map<? extends K, ? extends V>) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
Copies all of the mappings from the specified map to this one.
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.core.IMap
Asynchronously puts the given key and value.
putAsync(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.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.core.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.core.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.core.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.core.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.core.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.core.TransactionalMap
Transactional implementation of IMap.putIfAbsent(Object, Object).
putIfAbsent(K, V) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
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.
PutIfAbsentCacheMergePolicy - Class in com.hazelcast.cache.merge
Merges cache entries from source to destination if they don't exist in the destination cache.
PutIfAbsentCacheMergePolicy() - Constructor for class com.hazelcast.cache.merge.PutIfAbsentCacheMergePolicy
 
PutIfAbsentMapMergePolicy - Class in com.hazelcast.map.merge
Merges map entries from source to destination if they don't exist in the destination map.
PutIfAbsentMapMergePolicy() - Constructor for class com.hazelcast.map.merge.PutIfAbsentMapMergePolicy
 
PutIfAbsentMapMergePolicy - Class in com.hazelcast.replicatedmap.merge
Merges replicated map entries from source to destination if they don't exist in the destination map.
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
 
putTransient(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Same as #put(K, V, long, java.util.concurrent.TimeUnit) except that the map store, if defined, will not be called to load/store/persist the entry.
putTransient(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Same as #put(K, V, long, java.util.concurrent.TimeUnit) except that the map store, if defined, will not be called to load/store/persist the entry.
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
 

Q

QuadFunction<T0,T1,T2,T3,R> - Interface in com.hazelcast.jet.function
Represents a four-arity function that accepts four arguments and produces a result.
QUERY_CACHE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
QUERY_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
Name of the query executor.
QUERY_MAX_LOCAL_PARTITION_LIMIT_FOR_PRE_CHECK - Static variable in class com.hazelcast.spi.properties.GroupProperty
Maximum value of local partitions to trigger local pre-check for TruePredicate query operations on maps.
QUERY_OPTIMIZER_TYPE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Type of Query Optimizer.
QUERY_PREDICATE_PARALLEL_EVALUATION - Static variable in class com.hazelcast.spi.properties.GroupProperty
Run Query Evaluations for multiple partitions in parallel.
QUERY_RESULT_SIZE_LIMIT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Result size limit for query operations on maps.
QueryCache<K,V> - Interface in com.hazelcast.map
A concurrent, queryable data structure which is used to cache results of a continuous query executed on an IMap.
QueryCacheConfig - Class in com.hazelcast.config
Contains configuration for QueryCache.
QueryCacheConfig() - Constructor for class com.hazelcast.config.QueryCacheConfig
 
QueryCacheConfig(String) - Constructor for class com.hazelcast.config.QueryCacheConfig
 
QueryCacheConfig(QueryCacheConfig) - Constructor for class com.hazelcast.config.QueryCacheConfig
 
QueryConstants - Enum in com.hazelcast.query
Contains constants for Query.
QueryException - Exception in com.hazelcast.query
Exception class for the Query.
QueryException() - Constructor for exception com.hazelcast.query.QueryException
 
QueryException(String) - Constructor for exception com.hazelcast.query.QueryException
 
QueryException(String, Throwable) - Constructor for exception com.hazelcast.query.QueryException
 
QueryException(Throwable) - Constructor for exception com.hazelcast.query.QueryException
 
QueryResultSizeExceededException - Exception in com.hazelcast.map
This exception is thrown when a query exceeds a configurable result size limit.
QueryResultSizeExceededException(String) - Constructor for exception com.hazelcast.map.QueryResultSizeExceededException
 
QueryResultSizeExceededException() - Constructor for exception com.hazelcast.map.QueryResultSizeExceededException
 
QueryResultSizeExceededException(int, String) - Constructor for exception com.hazelcast.map.QueryResultSizeExceededException
 
queue() - Method in class com.hazelcast.jet.core.test.TestInbox
Retrieves the queue backing the inbox.
queue(int) - Method in class com.hazelcast.jet.core.test.TestOutbox
Exposes individual output queues to the testing code.
QUEUE_CAPACITY - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
Tracks the total capacity of all input queues of a particular Vertex on a particular Processor.
QUEUE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
QUEUE_SIZES - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
Tracks the total size of all input queues of a particular Vertex on a particular Processor.
QUEUE_STORE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
QueueConfig - Class in com.hazelcast.config
Contains the configuration for an IQueue.
QueueConfig() - Constructor for class com.hazelcast.config.QueueConfig
 
QueueConfig(String) - Constructor for class com.hazelcast.config.QueueConfig
 
QueueConfig(QueueConfig) - Constructor for class com.hazelcast.config.QueueConfig
 
QueueConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
QueuePermission - Class in com.hazelcast.security.permission
 
QueuePermission(String, String...) - Constructor for class com.hazelcast.security.permission.QueuePermission
 
QueueStore<T> - Interface in com.hazelcast.core
QueueStore makes a queue backed by a central data store; such as database, disk, etc.
QueueStoreConfig - Class in com.hazelcast.config
Configuration for the QueueStore.
QueueStoreConfig() - Constructor for class com.hazelcast.config.QueueStoreConfig
 
QueueStoreConfig(QueueStoreConfig) - Constructor for class com.hazelcast.config.QueueStoreConfig
 
QueueStoreConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
QueueStoreConfigReadOnly(QueueStoreConfig) - Constructor for class com.hazelcast.config.QueueStoreConfigReadOnly
Deprecated.
 
QueueStoreFactory<T> - Interface in com.hazelcast.core
Creates a new QueueStore.
QueueUtil - Class in com.hazelcast.util
Utility class for Queues
QuickMath - Class in com.hazelcast.util
The class QuickMath contains methods to perform optimized mathematical operations.
Quorum - Interface in com.hazelcast.quorum
Quorum provides access to the current status of a quorum.
QUORUM_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
QUORUM_LISTENER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
QuorumAwareService - Interface in com.hazelcast.spi
Quorum service can ask for quorum information to the QuorumAwareService to decide whether operation participates into a quorum or not.
QuorumConfig - Class in com.hazelcast.config
Configuration for cluster quorum, a means to protect consistency of data from network partitions.
QuorumConfig() - Constructor for class com.hazelcast.config.QuorumConfig
 
QuorumConfig(String, boolean) - Constructor for class com.hazelcast.config.QuorumConfig
 
QuorumConfig(String, boolean, int) - Constructor for class com.hazelcast.config.QuorumConfig
 
QuorumConfig(QuorumConfig) - Constructor for class com.hazelcast.config.QuorumConfig
 
QuorumConfigBuilder - Class in com.hazelcast.config
Commons for quorum config builders.
QuorumConfigBuilder() - Constructor for class com.hazelcast.config.QuorumConfigBuilder
 
QuorumEvent - Class in com.hazelcast.quorum
An Event that is send when a Quorum changes.
QuorumEvent(Object, int, Collection<Member>, boolean) - Constructor for class com.hazelcast.quorum.QuorumEvent
 
QuorumException - Exception in com.hazelcast.quorum
An exception thrown when the cluster size is below the defined threshold.
QuorumException(String) - Constructor for exception com.hazelcast.quorum.QuorumException
 
QuorumFunction - Interface in com.hazelcast.quorum
A function that can be used to conclude absence/presence of quorum.
QuorumListener - Interface in com.hazelcast.quorum
Listener to get notified when a quorum state is changed IMPORTANT: The term "quorum" simply refers to the count of members in the cluster required for an operation to succeed.
QuorumListenerConfig - Class in com.hazelcast.config
Confiquration class for QuorumListener IMPORTANT: The term "quorum" simply refers to the count of members in the cluster required for an operation to succeed.
QuorumListenerConfig() - Constructor for class com.hazelcast.config.QuorumListenerConfig
 
QuorumListenerConfig(String) - Constructor for class com.hazelcast.config.QuorumListenerConfig
 
QuorumListenerConfig(QuorumListener) - Constructor for class com.hazelcast.config.QuorumListenerConfig
 
quorumName - Variable in class com.hazelcast.config.AbstractBasicConfig
 
QuorumService - Interface in com.hazelcast.quorum
Quorum service can be used to trigger cluster quorums at any time.
QuorumType - Enum in com.hazelcast.quorum
Represents a cluster quorum type
quoteAsJsonText(String) - Static method in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecyclers
 
quoteAsJsonText(CharSequence, StringBuilder) - Static method in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecyclers
 
quoteAsJsonUTF8(String) - Static method in class com.hazelcast.com.fasterxml.jackson.core.util.BufferRecyclers
 
quoteAsString(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.JsonStringEncoder
Method that will quote text contents using JSON standard quoting, and return results as a character array
quoteAsString(CharSequence, StringBuilder) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.JsonStringEncoder
Method that will quote text contents using JSON standard quoting, and append results to a supplied StringBuilder.
quoteAsUTF8(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.JsonStringEncoder
Will quote given JSON String value using standard quoting, encode results as UTF-8, and return result as a byte array.

R

RaftAlgorithmConfig - Class in com.hazelcast.config.cp
Configuration for Hazelcast's implementation of the Raft consensus algorithm
RaftAlgorithmConfig() - Constructor for class com.hazelcast.config.cp.RaftAlgorithmConfig
 
RaftAlgorithmConfig(RaftAlgorithmConfig) - Constructor for class com.hazelcast.config.cp.RaftAlgorithmConfig
 
raiseFlags(int) - Method in class com.hazelcast.nio.Packet
Raises all the flags raised in the argument.
RANDOM_EVICTION_POLICY - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
RandomEvictionPolicy - Class in com.hazelcast.map.eviction
Random eviction policy for an IMap
RandomEvictionPolicy() - Constructor for class com.hazelcast.map.eviction.RandomEvictionPolicy
 
randomPartitionKey() - Method in interface com.hazelcast.core.PartitionService
Deprecated.
RandomPicker - Class in com.hazelcast.util
User: ahmetmircik Date: 10/7/13 Time: 12:27 PM
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(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
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.v1.api.YamlUnicodeReader
 
read(String, ValueCallback<T>) - Method in class 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 class 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.
readAttributeValue(ObjectDataInput) - Static method in class com.hazelcast.nio.IOUtil
 
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
Method that can be used as an alternative to JsonParser.getBigIntegerValue(), especially when value can be large.
readBinaryValue(Base64Variant, OutputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Similar to JsonParser.readBinaryValue(OutputStream) but allows explicitly specifying base64 variant to use.
readBinaryValue(Base64Variant, OutputStream) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonParserDelegate
 
readBoolean(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
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(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readByte(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readByteArray(ObjectDataInput) - Static method in class com.hazelcast.nio.IOUtil
 
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
Returns a supplier of processors for Sources.cache(String).
readChar(byte[], int, boolean) - Static method in class com.hazelcast.nio.Bits
 
readChar(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
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
 
readCharB(byte[], int) - Static method in class com.hazelcast.nio.Bits
 
readCharL(byte[], int) - Static method in class com.hazelcast.nio.Bits
 
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.concurrent.countdownlatch.CountDownLatchContainer
 
readData(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.InternalLockNamespace
 
readData(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.AtomicLongConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.AtomicReferenceConfig
 
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.CountDownLatchConfig
 
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.MapListenerToEntryListenerAdapter
 
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.ItemListenerConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.LegacyCacheConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.LegacyCacheEvictionConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.ListenerConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.LockConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.MapAttributeConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.MapConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.MapIndexConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.MapStoreConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.MaxSizeConfig
 
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.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.QuorumConfig
 
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.SemaphoreConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.TopicConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.WanConsumerConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.WanPublisherConfig
 
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.core.MemberAttributeEvent
 
readData(ObjectDataInput) - Method in class com.hazelcast.core.MigrationEvent
 
readData(ObjectDataInput) - Method in class com.hazelcast.core.PartitionAwareKey
 
readData(ObjectDataInput) - Method in class com.hazelcast.crdt.pncounter.operations.CRDTTimestampedLong
 
readData(ObjectDataInput) - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.instance.AbstractMember
 
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 class com.hazelcast.map.eviction.LFUEvictionPolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.eviction.LRUEvictionPolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.eviction.RandomEvictionPolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.merge.HigherHitsMapMergePolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.merge.IgnoreMergingEntryMapMergePolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.merge.LatestUpdateMapMergePolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.merge.PassThroughMergePolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.merge.PutIfAbsentMapMergePolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.nio.Address
 
readData() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readData(ObjectDataInput) - Method in interface com.hazelcast.nio.serialization.DataSerializable
Reads fields from the input stream
readData(ObjectDataInput) - Method in class com.hazelcast.partition.PartitionLostEvent
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.PagingPredicate
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.PartitionPredicate
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.PredicateBuilder
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.SqlPredicate
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.TruePredicate
 
readData(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.merge.HigherHitsMapMergePolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.merge.LatestUpdateMapMergePolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.merge.PassThroughMergePolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.merge.PutIfAbsentMapMergePolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.DefaultObjectNamespace
Deprecated.
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.DistributedObjectNamespace
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.Operation
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.OperationControl
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.partition.IPartitionLostEvent
 
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
 
readData(ObjectDataInput) - Method in class com.hazelcast.wan.WanReplicationEvent
 
readDataAsObject() - Method in interface com.hazelcast.nio.ObjectDataInput
Reads to stored Data as an object instead of a Data instance.
readDouble(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readDouble(ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readDouble(int, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
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.v1.exceptions
 
ReaderException(String, int, int, String) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v1.exceptions.ReaderException
 
readFactories(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
 
readFilesP(String, String, boolean, SupplierEx<? extends DatumReader<D>>, BiFunctionEx<String, ? super D, T>) - Static method in class com.hazelcast.jet.avro.AvroProcessors
readFilesP(String, Charset, String, boolean, BiFunctionEx<? super String, ? super String, ? extends R>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
Returns a supplier of processors for Sources.filesBuilder(java.lang.String).
readFloat(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readFloat(ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readFloat(int, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
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(DataInput) - Static method in enum com.hazelcast.core.MigrationEvent.MigrationStatus
 
readFrom(ByteBuffer) - Method in class com.hazelcast.nio.PacketIOHelper
Reads the packet data from the supplied ByteBuffer.
readFrom(DataInput) - Static method in enum com.hazelcast.spi.partition.MigrationEndpoint
 
readFully(InputStream, byte[]) - Static method in class com.hazelcast.nio.IOUtil
Fills a buffer from an InputStream.
readFullyOrNothing(InputStream, byte[]) - Static method in class com.hazelcast.nio.IOUtil
Fills a buffer from an InputStream.
readHdfsP(JobConf, BiFunctionEx<K, V, R>) - Static method in class com.hazelcast.jet.hadoop.HdfsProcessors
Returns a supplier of processors for HdfsSources.hdfs(JobConf, BiFunctionEx).
readInt(byte[], int, boolean) - Static method in class com.hazelcast.nio.Bits
 
readInt(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readInt(ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readInt(int, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
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
 
readIntB(byte[], int) - Static method in class com.hazelcast.nio.Bits
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.AbstractAtomicLongOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.AddBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.ApplyOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.MergeBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.MergeOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.SetBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.SetOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.AbstractAtomicReferenceOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.ContainsOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.MergeBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.MergeOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.SetAndGetOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.SetBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.SetOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.AwaitBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.LocalLockCleanupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.LockBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.LockReplicationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.UnlockBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.UnlockIfLeaseExpiredOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDetachMemberOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreReplicationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.crdt.AbstractCRDTReplicationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.crdt.pncounter.operations.AbstractPNCounterOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.crdt.pncounter.operations.AddOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.crdt.pncounter.operations.GetOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.AbstractLocalOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.Operation
 
readIntL(byte[], int) - Static method in class com.hazelcast.nio.Bits
 
readIntL(ByteBuffer) - Static method in class com.hazelcast.nio.Bits
 
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
Returns a supplier of processors for Sources.jdbc(String, String, FunctionEx).
readKeyValueTypes(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
 
readLine() - Method in interface com.hazelcast.console.LineReader
 
readListenerConfigurations(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
 
readListP(String) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
Returns a supplier of processors for Sources.list(String).
readLong(byte[], int, boolean) - Static method in class com.hazelcast.nio.Bits
 
readLong(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readLong(ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readLong(int, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
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
 
readLongAttribute(String, long) - Static method in class com.hazelcast.util.OperatingSystemMXBeanSupport
Reads a long attribute from OperatingSystemMXBean.
readLongB(byte[], int) - Static method in class com.hazelcast.nio.Bits
 
readLongL(byte[], int) - Static method in class com.hazelcast.nio.Bits
 
readManyAsync(long, int, int, IFunction<E, Boolean>) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Reads a batch of items from the Ringbuffer.
readMapP(String) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
Returns a supplier of processors for Sources.map(String).
readMapP(String, Predicate<? super K, ? super V>, Projection<? super Map.Entry<K, V>, ? extends T>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
Returns a supplier of processors for Sources.map(String, Predicate, Projection).
readMapP(String, Predicate<? super K, ? super V>, FunctionEx<? super Map.Entry<K, V>, ? extends T>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
Returns a supplier of processors for Sources.map(String, Predicate, FunctionEx).
readNamespaceCompatibly(ObjectDataInput) - Static method in class com.hazelcast.concurrent.lock.ObjectNamespaceSerializationHelper
 
readObject(ObjectDataInput) - Static method in class com.hazelcast.nio.IOUtil
 
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 - Variable in class com.hazelcast.config.EvictionConfig
 
ReadOnly - Interface in com.hazelcast.core
Allows notifying Hazelcast that the processing unit implementing this interface will not do any modifications.
ReadonlyOperation - Interface in com.hazelcast.spi
Read-only operations are allowed to run during migration and passive state.
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
 
readPortable(PortableReader) - Method in class com.hazelcast.security.AbstractCredentials
 
readPortableArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readPortableInternal(PortableReader) - Method in class com.hazelcast.security.AbstractCredentials
 
readPortableInternal(PortableReader) - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
readRemoteCacheP(String, ClientConfig) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
Returns a supplier of processors for Sources.remoteCache(String, ClientConfig).
readRemoteListP(String, ClientConfig) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
Returns a supplier of processors for Sources.remoteList(String, ClientConfig).
readRemoteMapP(String, ClientConfig) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
Returns a supplier of processors for Sources.remoteMap(String, ClientConfig).
readRemoteMapP(String, ClientConfig, Predicate<? super K, ? super V>, Projection<? super Map.Entry<K, V>, ? extends T>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
readRemoteMapP(String, ClientConfig, Predicate<? super K, ? super V>, FunctionEx<? 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
Method used to "demote" deserialized instances back to canonical ones
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.
ReadResultSet<E> - Interface in com.hazelcast.ringbuffer
readShort(byte[], int, boolean) - Static method in class com.hazelcast.nio.Bits
 
readShort(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readShort(ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
readShort(int, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
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
 
readShortB(byte[], int) - Static method in class com.hazelcast.nio.Bits
 
readShortL(byte[], int) - Static method in class com.hazelcast.nio.Bits
 
readTenant(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
 
readTree(JsonParser) - Method in class com.hazelcast.com.fasterxml.jackson.core.ObjectCodec
Method to deserialize JSON content as tree expressed using set of TreeNode instances.
readTree(JsonParser) - Method in class com.hazelcast.com.fasterxml.jackson.core.TreeCodec
 
readUTF(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readUtf8Char(byte[], int, char[], int) - Static method in class com.hazelcast.nio.Bits
 
readUtf8Char(DataInput, byte) - Static method in class com.hazelcast.nio.Bits
 
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<?>) - 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<?>) - 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<?>) - 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.
RECEIVED_BATCHES - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
Counts incoming data item batches on input Edges of particular Vertex instances running on various Processors.
RECEIVED_COUNT - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
Counts incoming data items on input Edges of particular Vertex instances running on various Processors.
receiveFn(BiConsumerEx<? super W, ? 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.
RecentlyActiveQuorumConfigBuilder - Class in com.hazelcast.config
Builder for a QuorumConfig configured with RecentlyActiveQuorumFunction that considers members present in the context of a quorum if the last received heartbeat is within a recent window of time.
reduce(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
 
reduce(ValueIn) - Method in class com.hazelcast.mapreduce.Reducer
Deprecated.
This method is called to supply values to be reduced into a final reduced result.
The reduce method might be called multiple times so the eventually reduced value needs to be held internally in a member state of the Reducer.
REDUCE_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
REDUCE_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
ReduceBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
ReduceBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.ReduceBackupOperation
 
ReduceBackupOperation(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.operations.ReduceBackupOperation
 
ReduceOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
ReduceOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.ReduceOperation
 
ReduceOperation(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.operations.ReduceOperation
 
reducePermits(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
 
reducePermits(int) - Method in interface com.hazelcast.core.ISemaphore
Reduces the number of available permits by the indicated amount.
reducer(ReducerFactory<? super KeyIn, ? super ValueIn, ? extends ValueOut>) - Method in interface com.hazelcast.mapreduce.MappingJob
Deprecated.
Defines the ReducerFactory for this task.
Reducer<ValueIn,ValueOut> - Class in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
Reducer() - Constructor for class com.hazelcast.mapreduce.Reducer
Deprecated.
 
reducer(ReducerFactory<KeyIn, ValueIn, ValueOut>) - Method in interface com.hazelcast.mapreduce.ReducingJob
Deprecated.
Defines the ReducerFactory for this task.
ReducerFactory<KeyIn,ValueIn,ValueOut> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
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.
ReducingJob<EntryKey,KeyIn,ValueIn> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
ReducingSubmittableJob<EntryKey,KeyIn,ValueIn> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
REFERENCE_COST_IN_BYTES - Static variable in class com.hazelcast.util.JVMUtil
Defines the costs for a reference in Bytes.
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.jet.pipeline.GenericPredicates
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
 
register(String, int, int, ExecutorType) - Method in interface com.hazelcast.spi.ExecutionService
 
register(String, int, int, ThreadFactory) - Method in interface com.hazelcast.spi.ExecutionService
This register method creates the executor only on @ExecutorType.CONCRETE type.
registerClient(HazelcastInstance) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
 
registerConnection(Address, T) - Method in interface com.hazelcast.nio.EndpointManager
Registers (ie.
registerConnection(Address, TcpIpConnection) - Method in class com.hazelcast.nio.tcp.TcpIpEndpointManager
 
registerExpiredAwaitOp(AwaitOperation) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
registerListener(Object) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
registerListener(Object) - Method in interface com.hazelcast.instance.NodeExtension
Registers given listener if it's a known type.
registerListener(String, String, Object) - Method in interface com.hazelcast.spi.EventService
Registers a listener on all cluster nodes.
registerListener(String, String, EventFilter, Object) - Method in interface com.hazelcast.spi.EventService
Registers a listener on all cluster nodes with an event filter.
registerLocalListener(String, String, Object) - Method in interface com.hazelcast.spi.EventService
Registers a local only listener.
registerLocalListener(String, String, EventFilter, Object) - Method in interface com.hazelcast.spi.EventService
Registers a local only listener with an event filter.
registerLockStoreConstructor(String, ConstructorFunction<ObjectNamespace, LockStoreInfo>) - Method in interface com.hazelcast.concurrent.lock.LockService
 
registerLockStoreConstructor(String, ConstructorFunction<ObjectNamespace, LockStoreInfo>) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
registerPlugins(Diagnostics) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
registerPlugins(Diagnostics) - Method in interface com.hazelcast.instance.NodeExtension
Register the node extension specific diagnostics plugins on the provided diagnostics.
registerServer(HazelcastInstance) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
 
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(String, int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
 
release() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
 
release(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
 
release() - Method in interface com.hazelcast.core.ISemaphore
Releases a permit and increases the number of available permits by one.
release(int) - Method in interface com.hazelcast.core.ISemaphore
Releases the given number of permits and increases the number of available permits by that amount.
RELEASE_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
RELEASE_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
ReleaseBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
ReleaseBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.ReleaseBackupOperation
 
ReleaseBackupOperation(String, int, String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.ReleaseBackupOperation
 
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
Specialized method that will release all recycled BufferRecycler if (and only if) recycler tracking has been enabled (see BufferRecyclers.SYSTEM_PROPERTY_TRACK_REUSABLE_BUFFERS).
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
 
ReleaseOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
ReleaseOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
 
ReleaseOperation(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
 
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
 
RELIABLE_TOPIC_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
ReliableMessageListener<E> - Interface in com.hazelcast.topic
A MessageListener to better integrate with the reliable topic.
ReliableTopicConfig - Class in com.hazelcast.config
Configuration for a reliable ITopic.
ReliableTopicConfig() - Constructor for class com.hazelcast.config.ReliableTopicConfig
 
ReliableTopicConfig(String) - Constructor for class com.hazelcast.config.ReliableTopicConfig
Creates a new ReliableTopicConfig with default settings.
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.Entrys 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, PredicateEx<? super EventJournalCacheEvent<K, V>>, FunctionEx<? super EventJournalCacheEvent<K, V>, ? extends T>, JournalInitialPosition) - 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
Convenience for Sources.remoteCacheJournal(String, ClientConfig, PredicateEx, FunctionEx, JournalInitialPosition) which will pass only CREATED and UPDATED events and will project the event's key and new value into a Map.Entry.
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.Entrys it receives into a Hazelcast IMap with the specified name 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<? super K, ? super 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.
remoteMap(String, ClientConfig, Predicate<? super K, ? super V>, FunctionEx<? super Map.Entry<K, V>, ? extends T>) - Static method in class com.hazelcast.jet.pipeline.Sources
Convenience for Sources.remoteMap(String, ClientConfig, Predicate, Projection) which use a FunctionEx as the projection function.
remoteMapJournal(String, ClientConfig, PredicateEx<? super EventJournalMapEvent<K, V>>, FunctionEx<? super EventJournalMapEvent<K, V>, ? extends T>, JournalInitialPosition) - 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
Convenience for Sources.remoteMapJournal(String, ClientConfig, PredicateEx, FunctionEx, JournalInitialPosition) which will pass only ADDED and UPDATED events and will project the event's key and new value into a Map.Entry.
RemoteMapReduceException - Exception in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
RemoteMapReduceException(String, List<Exception>) - Constructor for exception com.hazelcast.mapreduce.RemoteMapReduceException
Deprecated.
 
remoteMapWithEntryProcessor(String, ClientConfig, FunctionEx<? super E, ? extends K>, FunctionEx<? super E, ? extends EntryProcessor<K, V>>) - 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
Returns a sink equivalent to Sinks.mapWithMerging(String, BinaryOperatorEx), but for a map in a remote Hazelcast cluster identified by the supplied ClientConfig.
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
RemoteMerkleTreeView - Class in com.hazelcast.wan.merkletree
Represents the readonly view of a remote Merkle Tree.
RemoteService - Interface in com.hazelcast.spi
An interface that can be implemented by SPI-Services to give them the ability to create proxies to distributed objects.
remove(Object) - Method in interface com.hazelcast.core.BaseMap
Removes the mapping for a key from this map if it is present.
remove(Object, Object) - Method in interface com.hazelcast.core.BaseMap
Removes the entry for a key only if currently mapped to a given value.
remove(Object, Object) - Method in interface com.hazelcast.core.BaseMultiMap
Removes the given key value pair from the multimap.
remove(Object) - Method in interface com.hazelcast.core.BaseMultiMap
Removes all the entries associated with the given key.
remove(Object) - Method in interface com.hazelcast.core.IMap
Removes the mapping for a key from this map if it is present.
remove(Object, Object) - Method in interface com.hazelcast.core.IMap
Removes the entry for a key only if currently mapped to a given value.
remove(Object, Object) - Method in interface com.hazelcast.core.MultiMap
Removes the given key value pair from the multimap.
remove(Object) - Method in interface com.hazelcast.core.MultiMap
Removes all the entries with the given key.
remove(E) - Method in interface com.hazelcast.core.TransactionalList
Removes an item from the transactional list.
remove(Object) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.remove(Object).
remove(Object, Object) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.remove(Object, Object).
remove(Object, Object) - Method in interface com.hazelcast.core.TransactionalMultiMap
Removes the given key value pair from the multimap.
remove(Object) - Method in interface com.hazelcast.core.TransactionalMultiMap
Removes all the entries associated with the given key.
remove(E) - Method in interface com.hazelcast.core.TransactionalSet
Remove item from transactional set.
remove(HazelcastInstanceImpl) - Static method in class com.hazelcast.instance.HazelcastInstanceFactory
 
remove() - Method in interface com.hazelcast.jet.core.Inbox
Removes the head of this inbox.
remove() - Method in class com.hazelcast.jet.core.test.TestInbox
 
remove() - Method in class com.hazelcast.spi.merge.RingbufferMergeDataReadOnlyIterator
 
remove(T[], T) - Static method in class com.hazelcast.util.collection.ArrayUtils
Removes an item from the array.
remove(int, int) - Method in class com.hazelcast.util.collection.BiInt2ObjectMap
Remove a value from the map and return the value.
remove(Object) - Method in class com.hazelcast.util.collection.InflatableSet
 
remove(Object) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.KeySet
 
remove(int) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.KeySet
Non-boxing variant of remove().
remove(Object) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
 
remove(int) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
Overloaded version of Map.remove(Object) that takes a primitive int key.
remove(Object) - Method in class com.hazelcast.util.collection.IntHashSet
 
remove(int) - Method in class com.hazelcast.util.collection.IntHashSet
An int specialised version of {this#remove(Object)}.
remove() - Method in class com.hazelcast.util.collection.IntIterator
 
remove(Object) - Method in class com.hazelcast.util.collection.Long2LongHashMap
 
remove(long) - Method in class com.hazelcast.util.collection.Long2LongHashMap
 
remove(Object) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.KeySet
 
remove(long) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.KeySet
Non-boxing variant of remove().
remove(Object) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
 
remove(long) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
Overloaded version of Map.remove(Object) that takes a primitive long key.
remove(Object) - Method in class com.hazelcast.util.collection.LongHashSet
remove(long) - Method in class com.hazelcast.util.collection.LongHashSet
An long specialised version of {this#remove(Object)}.
remove() - Method in class com.hazelcast.util.collection.LongIterator
 
remove(Object) - Method in class com.hazelcast.util.collection.OAHashSet
 
remove(Object, int) - Method in class com.hazelcast.util.collection.OAHashSet
Removes the specified element from this set if it is present with the hash provided in parameter.
remove(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
Removes the key (and its corresponding value) from this map.
remove(Object, Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
remove(T) - Method in class com.hazelcast.util.ItemCounter
 
remove() - Method in class com.hazelcast.util.UnmodifiableIterator
 
removeAll(Predicate<K, V>) - Method in interface com.hazelcast.core.IMap
Removes all entries which match with the supplied predicate.
removeAll(Collection<?>) - Method in class com.hazelcast.util.collection.IntHashSet
 
removeAll(Collection<?>) - Method in class com.hazelcast.util.collection.LongHashSet
removeAll(Collection<?>) - Method in class com.hazelcast.util.collection.OAHashSet
 
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.core.IMap
Asynchronously removes the given key, returning an ICompletableFuture on which the caller can provide an ExecutionCallback to be invoked upon remove operation completion or block waiting for the operation to complete with Future.get().
removeAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
 
removeAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
Deprecated.
 
removeAttribute(String) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
removeAttribute(String) - Method in interface com.hazelcast.core.Member
Removes a key-value pair attribute for this member if given key was previously assigned as an attribute.
If key wasn't assigned to a value this method does nothing.
removeAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
 
removeAttributeNode(Attr) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
removeAttributeNS(String, String) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
removeAwait(Data, String, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
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 class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
removeCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in interface com.hazelcast.config.CacheConfiguration
Remove a configuration for a CacheEntryListener.
removeChild(Node) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
removeClientListener(String) - Method in interface com.hazelcast.core.ClientService
Removes a ClientListener.
removeCPMember(String) - 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(String) - Method in interface com.hazelcast.core.HazelcastInstance
Removes the specified Distributed Object listener.
removeDistributedObjectListener(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
removeDistributedObjectListener(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
removeEndpoint(Address) - Method in interface com.hazelcast.nio.IOService
 
removeEndpoint(Address) - Method in class com.hazelcast.nio.NodeIOService
 
removeEntryListener(String) - Method in interface com.hazelcast.core.IMap
Removes the specified entry listener.
removeEntryListener(String) - Method in interface com.hazelcast.core.MultiMap
Removes the specified entry listener.
removeEntryListener(String) - Method in interface com.hazelcast.core.ReplicatedMap
Removes the specified entry listener.
removeEntryListener(String) - Method in interface com.hazelcast.map.QueryCache
 
removeInterceptor(String) - Method in interface com.hazelcast.core.IMap
Removes the given interceptor for this map, so it will not intercept operations anymore.
removeItemListener(String) - Method in interface com.hazelcast.core.ICollection
Removes the specified item listener.
removeLifecycleListener(String) - Method in interface com.hazelcast.core.LifecycleService
Removes a lifecycle listener.
removeLifecycleListener(String) - Method in class com.hazelcast.instance.LifecycleServiceImpl
 
removeLifecycleListener(String) - Method in class com.hazelcast.instance.TerminatedLifecycleService
 
removeLocalLocks() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
removeLogListener(LogListener) - Method in interface com.hazelcast.logging.LoggingService
 
removeLogListener(LogListener) - Method in class com.hazelcast.logging.LoggingServiceImpl
 
removeMember(Member) - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
removeMember(Member) - Method in interface com.hazelcast.partition.membergroup.MemberGroup
 
removeMember(Member) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
removeMembershipListener(String) - Method in interface com.hazelcast.core.Cluster
Removes the specified MembershipListener.
removeMessageListener(String) - Method in interface com.hazelcast.core.ITopic
Stops receiving messages for the given message listener.
removeMigrationListener(String) - Method in interface com.hazelcast.core.PartitionService
Removes a MigrationListener.
removeMigrationListener(String) - Method in interface com.hazelcast.spi.partition.IPartitionService
 
removePartition(int) - Method in class com.hazelcast.jet.core.EventTimeMapper
Removes a partition that will no longer have events.
removePartitionLostListener(String) - Method in interface com.hazelcast.cache.ICache
Removes the specified cache partition lost listener.
removePartitionLostListener(String) - Method in interface com.hazelcast.core.IMap
Removes the specified map partition lost listener.
removePartitionLostListener(String) - Method in interface com.hazelcast.core.PartitionService
Removes a PartitionLostListener.
removePartitionLostListener(String) - Method in interface com.hazelcast.spi.partition.IPartitionService
 
removeProperty(String) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
removeProxyListener(String) - Method in interface com.hazelcast.spi.ProxyService
 
removeSignalKey(ConditionKey) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
removeThreadId() - Static method in class com.hazelcast.util.ThreadUtil
Remove the thread ID.
removeWanEventCounters(String, String) - Method in interface com.hazelcast.wan.WanReplicationService
Removes all WAN event counters for the given serviceName and dataStructureName.
removeWhiteSpace(byte[]) - Static method in class com.hazelcast.util.Base64
remove WhiteSpace from MIME containing encoded Base64 data.
rename(File, File) - Static method in class com.hazelcast.nio.IOUtil
Ensures that the file described by fileNow is renamed to file described by fileToBe.
replace(K, V, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Atomically replaces the currently assigned value for the given key with the specified newValue if and only if the currently assigned value equals the value of oldValue using a custom ExpiryPolicy.
replace(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Atomically replaces the assigned value of the given key by the specified value using a custom ExpiryPolicy.
replace(K, V) - Method in interface com.hazelcast.core.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.core.BaseMap
Replaces the entry for a key only if currently mapped to a given value.
replace(K, V, V) - Method in interface com.hazelcast.core.IMap
Replaces the entry for a key only if currently mapped to a given value.
replace(K, V) - Method in interface com.hazelcast.core.IMap
Replaces the entry for a key only if it is currently mapped to some value.
replace(K, V) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.replace(Object, Object).
replace(K, V, V) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.replace(Object, Object, Object).
replace(K, V, V) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
replace(K, V) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
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.
replaceChild(Node, Node) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
replaceFirst(T[], T, T[]) - Static method in class com.hazelcast.util.collection.ArrayUtils
Replaces the first occurrence of the oldValue by the newValue.
replaceVariables(Node) - Method in class com.hazelcast.config.AbstractYamlConfigBuilder
 
replicaIndex - Variable in class com.hazelcast.spi.InvocationBuilder
 
REPLICATED_MAP_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
ReplicatedMap<K,V> - Interface in com.hazelcast.core
A ReplicatedMap is a map-like data structure with weak consistency and values locally stored on every node of the cluster.
ReplicatedMapCantBeCreatedOnLiteMemberException - Exception in com.hazelcast.replicatedmap
Thrown when HazelcastInstance.getReplicatedMap(String) is invoked on a lite member.
ReplicatedMapCantBeCreatedOnLiteMemberException(Address) - Constructor for exception com.hazelcast.replicatedmap.ReplicatedMapCantBeCreatedOnLiteMemberException
 
ReplicatedMapCantBeCreatedOnLiteMemberException(String) - Constructor for exception com.hazelcast.replicatedmap.ReplicatedMapCantBeCreatedOnLiteMemberException
 
ReplicatedMapConfig - Class in com.hazelcast.config
Contains the configuration for an ReplicatedMap
ReplicatedMapConfig() - Constructor for class com.hazelcast.config.ReplicatedMapConfig
 
ReplicatedMapConfig(String) - Constructor for class com.hazelcast.config.ReplicatedMapConfig
Creates a ReplicatedMapConfig with the given name.
ReplicatedMapConfig(ReplicatedMapConfig) - Constructor for class com.hazelcast.config.ReplicatedMapConfig
 
replicatedMapContext(String) - Static method in class com.hazelcast.jet.pipeline.ContextFactories
Returns a factory that provides a ReplicatedMap as the context object.
ReplicatedMapMergePolicy - Interface in com.hazelcast.replicatedmap.merge
Policy for merging replicated map entries after a split-brain has been healed.
ReplicatedMapPermission - Class in com.hazelcast.security.permission
 
ReplicatedMapPermission(String, String...) - Constructor for class com.hazelcast.security.permission.ReplicatedMapPermission
 
REPLICATION - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
REPLICATION - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
ReplicationEventObject - Interface in com.hazelcast.wan
Interface for all WAN replication messages
ReplicationSupportingService - Interface in com.hazelcast.spi
An interface that can be implemented by SPI services to give them the ability to listen to WAN replication events.
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
 
reportOverflowInt() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
reportOverflowLong() - 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.v1.representer.BaseRepresenter
 
RepresentArray() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentArray
 
RepresentBoolean() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentBoolean
 
RepresentByteArray() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentByteArray
 
representData(Object) - Method in interface com.hazelcast.org.snakeyaml.engine.v1.api.RepresentToNode
Create a Node
representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v1.representer.BaseRepresenter
 
representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentArray
 
representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentBoolean
 
representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentByteArray
 
representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentEnum
 
representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentIterator
 
representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentList
 
representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentMap
 
representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentNull
 
representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentNumber
 
representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentOptional
 
representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentPrimitiveArray
 
representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentSet
 
representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentString
 
representData(Object) - Method in class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentUuid
 
representedObjects - Variable in class com.hazelcast.org.snakeyaml.engine.v1.representer.BaseRepresenter
 
RepresentEnum() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentEnum
 
representers - Variable in class com.hazelcast.org.snakeyaml.engine.v1.representer.BaseRepresenter
 
RepresentIterator() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentIterator
 
RepresentList() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentList
 
RepresentMap() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentMap
 
representMapping(Tag, Map<?, ?>, FlowStyle) - Method in class com.hazelcast.org.snakeyaml.engine.v1.representer.BaseRepresenter
 
RepresentNull() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentNull
 
RepresentNumber() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentNumber
 
RepresentOptional() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentOptional
 
RepresentPrimitiveArray() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentPrimitiveArray
 
representScalar(Tag, String, ScalarStyle) - Method in class com.hazelcast.org.snakeyaml.engine.v1.representer.BaseRepresenter
 
representScalar(Tag, String) - Method in class com.hazelcast.org.snakeyaml.engine.v1.representer.BaseRepresenter
 
representSequence(Tag, Iterable<?>, FlowStyle) - Method in class com.hazelcast.org.snakeyaml.engine.v1.representer.BaseRepresenter
 
RepresentSet() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentSet
 
RepresentString() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentString
 
RepresentToNode - Interface in com.hazelcast.org.snakeyaml.engine.v1.api
Create a Node Graph out of the provided Native Data Structure (Java instance).
RepresentUuid() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter.RepresentUuid
 
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
 
requiresExplicitServiceName() - Method in class com.hazelcast.spi.Operation
Returns true to force the explicit service name serialization for this operation, false otherwise.
requiresObjectContext() - Method in enum com.hazelcast.com.fasterxml.jackson.core.type.WritableTypeId.Inclusion
 
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.
reset() - Method in interface com.hazelcast.cluster.Joiner
Deprecated.
 
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
 
reset(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonWriteContext
 
reset() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
 
reset() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
 
reset() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
 
reset() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
reset() - Method in class com.hazelcast.concurrent.idgen.IdGeneratorService
 
reset() - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
reset() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
 
reset() - Method in class com.hazelcast.crdt.CRDTReplicationMigrationService
 
reset() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Resets the observed state by this PN counter.
reset() - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
 
reset() - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
reset() - Method in class com.hazelcast.instance.Node
Resets the internal cluster-state of the Node to be able to make it ready to join a new cluster.
reset() - Method in class com.hazelcast.jet.core.test.TestOutbox
 
reset() - Method in class com.hazelcast.mapreduce.Combiner
Deprecated.
This method is always called after a chunk of data is retrieved.
reset() - Method in class com.hazelcast.mapreduce.KeyValueSource
Deprecated.
This method resets all internal state to be a new instance.
reset() - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
reset() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionErrorHandler
 
reset(boolean) - Method in class com.hazelcast.nio.tcp.TcpIpEndpointManager
 
reset(boolean) - Method in class com.hazelcast.nio.UnifiedAggregateEndpointManager
 
reset() - Method in class com.hazelcast.query.PagingPredicate
resets for reuse
reset() - Method in interface com.hazelcast.spi.ManagedService
Resets this service back to its initial state.
reset() - Method in class com.hazelcast.util.collection.Long2LongHashMap.LongIterator
Makes this iterator reusable.
reset() - Method in class com.hazelcast.util.ItemCounter
Reset state of the counter to 0.
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
 
resetFlagsTo(int) - Method in class com.hazelcast.nio.Packet
Resets the entire flags bitfield to the supplied value.
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
 
resetService(boolean) - Method in interface com.hazelcast.hotrestart.InternalHotRestartService
Resets local service data, removes hot restart directories and recreates them.
resetService(boolean) - Method in class com.hazelcast.hotrestart.NoopInternalHotRestartService
 
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
 
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
 
resizeThreshold() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
Get the actual threshold which when reached the map resize.
resizeThreshold() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
Get the actual threshold which when reached the map resize.
resolve(ProtocolType, String) - Static method in class com.hazelcast.instance.EndpointQualifier
 
resolve(String, Boolean) - Method in class com.hazelcast.org.snakeyaml.engine.v1.resolver.JsonScalarResolver
 
resolve(String, Boolean) - Method in interface com.hazelcast.org.snakeyaml.engine.v1.resolver.ScalarResolver
Resolve (detect) the tag of the scalar node of the given type.
resolved - Variable in class com.hazelcast.org.snakeyaml.engine.v1.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
 
ResourceConfig - Class in com.hazelcast.jet.config
Describes a single resource to deploy to the Jet cluster.
response - Variable in class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
 
response - Variable in class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
 
response - Variable in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
response - Variable in class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
 
RESPONSE_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
The number of threads that process responses.
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
 
REST - Static variable in class com.hazelcast.nio.Protocols
Protocol that is used by REST
REST_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
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
 
RestApiFilter - Class in com.hazelcast.nio.ascii
This class is a policy enforcement point for HTTP REST API.
RestApiTextDecoder - Class in com.hazelcast.nio.ascii
 
RestApiTextDecoder(TcpIpConnection, TextEncoder, boolean) - Constructor for class com.hazelcast.nio.ascii.RestApiTextDecoder
 
restart() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Wipes and resets the whole CP subsystem and initializes it as if the Hazelcast cluster is starting up initially.
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, 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.
resultDeserialized - Variable in class com.hazelcast.spi.InvocationBuilder
 
results() - Method in class com.hazelcast.core.Pipelining
Returns the results.
resume() - Method in interface com.hazelcast.jet.Job
Resumes a suspended job.
resume(JetCommandLine.Verbosity, String) - Method in class com.hazelcast.jet.server.JetCommandLine
 
resume(String, String) - Method in interface com.hazelcast.wan.WanReplicationService
Resumes WAN replication for the given wanReplicationName and targetGroupName on this hazelcast instance.
retainAll(Collection<?>) - Method in class com.hazelcast.util.collection.IntHashSet
 
retainAll(Collection<?>) - Method in class com.hazelcast.util.collection.LongHashSet
 
retainAll(Collection<?>) - Method in class com.hazelcast.util.collection.OAHashSet
 
rethrow(Throwable) - Static method in class com.hazelcast.util.ExceptionUtil
 
rethrow(Throwable, ExceptionUtil.RuntimeExceptionFactory) - Static method in class com.hazelcast.util.ExceptionUtil
 
rethrow(Throwable, Class<T>) - Static method in class com.hazelcast.util.ExceptionUtil
 
RETHROW_ALL_EXCEPT_MEMBER_LEFT - Static variable in class com.hazelcast.util.FutureUtil
This ExceptionHandler rethrows ExecutionExceptions and logs MemberLeftExceptions to the log.
RETHROW_EVERYTHING - Static variable in class com.hazelcast.util.FutureUtil
Just rethrows all exceptions
RETHROW_EXECUTION_EXCEPTION - Static variable in class com.hazelcast.util.FutureUtil
This ExceptionHandler rethrows ExecutionExceptions and logs MemberLeftExceptions to the log.
RETHROW_TRANSACTION_EXCEPTION - Static variable in class com.hazelcast.util.FutureUtil
Handler for transaction specific rethrown of exceptions.
rethrowAllowedTypeFirst(Throwable, Class<T>) - Static method in class com.hazelcast.util.ExceptionUtil
This rethrow the exception providing an allowed Exception in first priority, even it is a Runtime exception
rethrowAllowInterrupted(Throwable) - Static method in class com.hazelcast.util.ExceptionUtil
 
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.
retrieveMetadataFromURI(String, int) - Static method in class com.hazelcast.aws.utility.MetadataUtil
Performs the HTTP request to retrieve AWS Instance Metadata from the given URI.
retrieveMetadataFromURI(String, int, int) - Static method in class com.hazelcast.aws.utility.MetadataUtil
Performs the HTTP request to retrieve AWS Instance Metadata from the given URI.
retrieveResult(long) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Retrieves the result with the given taskId
retry(Callable<T>, int) - Static method in class com.hazelcast.aws.utility.RetryUtils
Calls callable.call() until it does not throw an exception (but no more than retries times).
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
 
RetryUtils - Class in com.hazelcast.aws.utility
Static utility class to retry operations related to connecting to AWS Services.
returnsResponse() - Method in class com.hazelcast.spi.Operation
Method is intended to be overridden.
returnValue - Variable in class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
 
returnWithDeadline(Collection<Future<V>>, long, TimeUnit) - Static method in class com.hazelcast.util.FutureUtil
 
returnWithDeadline(Collection<Future<V>>, long, TimeUnit, FutureUtil.ExceptionHandler) - Static method in class com.hazelcast.util.FutureUtil
 
returnWithDeadline(Collection<Future<V>>, long, TimeUnit, long, TimeUnit) - Static method in class com.hazelcast.util.FutureUtil
 
returnWithDeadline(Collection<Future<V>>, long, TimeUnit, long, TimeUnit, FutureUtil.ExceptionHandler) - Static method in class com.hazelcast.util.FutureUtil
 
reversed() - Method in interface com.hazelcast.jet.function.ComparatorEx
Serializable variant of java.util.Comparator#reversed()
reverseOrder() - Static method in interface com.hazelcast.jet.function.ComparatorEx
Serializable variant of java.util.Comparator#reverseOrder().
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.
RINGBUFFER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
RINGBUFFER_STORE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
RingbufferConfig - Class in com.hazelcast.config
Contains the configuration for the Ringbuffer.
RingbufferConfig() - Constructor for class com.hazelcast.config.RingbufferConfig
 
RingbufferConfig(String) - Constructor for class com.hazelcast.config.RingbufferConfig
Creates a RingbufferConfig with the provided name.
RingbufferConfig(RingbufferConfig) - Constructor for class com.hazelcast.config.RingbufferConfig
Clones a RingbufferConfig
RingbufferConfig(String, RingbufferConfig) - Constructor for class com.hazelcast.config.RingbufferConfig
Creates a new RingbufferConfig by cloning an existing config and overriding the name.
RingbufferMergeData - Class in com.hazelcast.spi.merge
A ringbuffer implementation holding data involved in split-brain healing.
RingbufferMergeData(int) - Constructor for class com.hazelcast.spi.merge.RingbufferMergeData
 
RingbufferMergeData(Ringbuffer<Object>) - Constructor for class com.hazelcast.spi.merge.RingbufferMergeData
 
RingbufferMergeDataReadOnlyIterator<E> - Class in com.hazelcast.spi.merge
Read-only iterator over items in a provided RingbufferMergeData.
RingBufferPermission - Class in com.hazelcast.security.permission
 
RingBufferPermission(String, String...) - Constructor for class com.hazelcast.security.permission.RingBufferPermission
 
RingbufferStore<T> - Interface in com.hazelcast.core
Ringbuffer store makes a ring buffer backed by a central data store; such as database, disk, etc.
RingbufferStoreConfig - Class in com.hazelcast.config
Configuration for the RingbufferStore.
RingbufferStoreConfig() - Constructor for class com.hazelcast.config.RingbufferStoreConfig
 
RingbufferStoreConfig(RingbufferStoreConfig) - Constructor for class com.hazelcast.config.RingbufferStoreConfig
 
RingbufferStoreFactory<T> - Interface in com.hazelcast.core
Creates a new RingbufferStore.
rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
 
rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
 
rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
 
rollbackMigration(PartitionMigrationEvent) - Method in interface com.hazelcast.spi.MigrationAwareService
Rollback the migration process for this service, on both source and destination members.
rollbackTransaction(String) - Method in interface com.hazelcast.spi.TransactionalService
 
rollbackTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
Rollback of the current transaction.
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.
run() - Method in class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
 
run() - Method in class com.hazelcast.concurrent.atomiclong.operations.AddBackupOperation
 
run() - Method in class com.hazelcast.concurrent.atomiclong.operations.AlterAndGetOperation
 
run() - Method in class com.hazelcast.concurrent.atomiclong.operations.AlterOperation
 
run() - Method in class com.hazelcast.concurrent.atomiclong.operations.ApplyOperation
 
run() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
 
run() - Method in class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
 
run() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
 
run() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAlterOperation
 
run() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
 
run() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetOperation
 
run() - Method in class com.hazelcast.concurrent.atomiclong.operations.MergeBackupOperation
 
run() - Method in class com.hazelcast.concurrent.atomiclong.operations.MergeOperation
 
run() - Method in class com.hazelcast.concurrent.atomiclong.operations.SetBackupOperation
 
run() - Method in class com.hazelcast.concurrent.atomiclong.operations.SetOperation
 
run() - Method in class com.hazelcast.concurrent.atomicreference.operations.AlterAndGetOperation
 
run() - Method in class com.hazelcast.concurrent.atomicreference.operations.AlterOperation
 
run() - Method in class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
 
run() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
 
run() - Method in class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
 
run() - Method in class com.hazelcast.concurrent.atomicreference.operations.ContainsOperation
 
run() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndAlterOperation
 
run() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
 
run() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetOperation
 
run() - Method in class com.hazelcast.concurrent.atomicreference.operations.IsNullOperation
 
run() - Method in class com.hazelcast.concurrent.atomicreference.operations.MergeBackupOperation
 
run() - Method in class com.hazelcast.concurrent.atomicreference.operations.MergeOperation
 
run() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetAndGetOperation
 
run() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetBackupOperation
 
run() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetOperation
 
run() - Method in class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
 
run() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
 
run() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
 
run() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
 
run() - Method in class com.hazelcast.concurrent.countdownlatch.operations.GetCountOperation
 
run() - Method in class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
 
run() - Method in class com.hazelcast.concurrent.lock.operations.AwaitBackupOperation
 
run() - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
 
run() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitBackupOperation
 
run() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
 
run() - Method in class com.hazelcast.concurrent.lock.operations.GetLockCountOperation
 
run() - Method in class com.hazelcast.concurrent.lock.operations.GetRemainingLeaseTimeOperation
 
run() - Method in class com.hazelcast.concurrent.lock.operations.IsLockedOperation
 
run() - Method in class com.hazelcast.concurrent.lock.operations.LocalLockCleanupOperation
 
run() - Method in class com.hazelcast.concurrent.lock.operations.LockBackupOperation
 
run() - Method in class com.hazelcast.concurrent.lock.operations.LockOperation
 
run() - Method in class com.hazelcast.concurrent.lock.operations.LockReplicationOperation
 
run() - Method in class com.hazelcast.concurrent.lock.operations.UnlockBackupOperation
 
run() - Method in class com.hazelcast.concurrent.lock.operations.UnlockIfLeaseExpiredOperation
 
run() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
 
run() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireBackupOperation
 
run() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
 
run() - Method in class com.hazelcast.concurrent.semaphore.operations.AvailableOperation
 
run() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainBackupOperation
 
run() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainOperation
 
run() - Method in class com.hazelcast.concurrent.semaphore.operations.IncreaseBackupOperation
 
run() - Method in class com.hazelcast.concurrent.semaphore.operations.IncreaseOperation
 
run() - Method in class com.hazelcast.concurrent.semaphore.operations.InitBackupOperation
 
run() - Method in class com.hazelcast.concurrent.semaphore.operations.InitOperation
 
run() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceBackupOperation
 
run() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceOperation
 
run() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseBackupOperation
 
run() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
 
run() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDetachMemberBackupOperation
 
run() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDetachMemberOperation
 
run() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreReplicationOperation
 
run() - Method in class com.hazelcast.crdt.AbstractCRDTReplicationOperation
 
run() - Method in class com.hazelcast.crdt.pncounter.operations.AddOperation
 
run() - Method in class com.hazelcast.crdt.pncounter.operations.GetOperation
 
run() - Method in class com.hazelcast.instance.Node.NodeShutdownHookThread
 
run() - Method in class com.hazelcast.jet.server.JetCommandLine
 
run() - Method in class com.hazelcast.spi.Operation
Runs the operation.
run(Operation) - Method in interface com.hazelcast.spi.OperationService
Runs an operation in the calling thread.
run() - Method in class com.hazelcast.util.executor.CompletableFutureTask
 
run() - Method in class com.hazelcast.util.executor.HazelcastManagedThread
Manages the thread lifecycle and can be overridden to customize if needed.
runningOperations() - Method in class com.hazelcast.spi.OperationControl
 
RuntimeInterruptedException - Exception in com.hazelcast.core
An unchecked version of InterruptedException.
RuntimeInterruptedException() - Constructor for exception com.hazelcast.core.RuntimeInterruptedException
 
RuntimeInterruptedException(String) - Constructor for exception com.hazelcast.core.RuntimeInterruptedException
 
RuntimeMemoryInfoAccessor - Class in com.hazelcast.util
Provides memory information using Runtime.
RuntimeMemoryInfoAccessor() - Constructor for class com.hazelcast.util.RuntimeMemoryInfoAccessor
 
runUnderLifecycleLock(Runnable) - Method in class com.hazelcast.instance.LifecycleServiceImpl
 
runUntilOutputMatches(long, long) - Method in class com.hazelcast.jet.core.test.TestSupport
Normally, the complete() method is run repeatedly until it returns true.

S

s3(String, SupplierEx<? extends S3Client>) - Static method in class com.hazelcast.jet.s3.S3Sinks
Convenience for S3Sinks.s3(String, String, Charset, SupplierEx, FunctionEx) Uses Object.toString() to convert the items to lines.
s3(String, String, Charset, SupplierEx<? extends S3Client>, FunctionEx<? super T, String>) - Static method in class com.hazelcast.jet.s3.S3Sinks
Creates an AWS S3 Sink which writes items to files into the given bucket.
s3(List<String>, String, SupplierEx<? extends S3Client>) - Static method in class com.hazelcast.jet.s3.S3Sources
s3(List<String>, String, Charset, SupplierEx<? extends S3Client>, BiFunctionEx<String, String, ? extends T>) - Static method in class com.hazelcast.jet.s3.S3Sources
Creates an AWS S3 BatchSource which lists all the objects in the bucket-list using given prefix, reads them line by line, transforms each line to the desired output object using given mapFn and emits them to downstream.
S3Sinks - Class in com.hazelcast.jet.s3
Contains factory methods for creating AWS S3 sinks.
S3Sources - Class in com.hazelcast.jet.s3
Contains factory methods for creating AWS S3 sources.
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.
SampleableConcurrentHashMap<K,V> - Class in com.hazelcast.util
ConcurrentHashMap to extend iterator capability.
SampleableConcurrentHashMap(int) - Constructor for class com.hazelcast.util.SampleableConcurrentHashMap
 
SampleableConcurrentHashMap(int, ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType) - Constructor for class com.hazelcast.util.SampleableConcurrentHashMap
 
SampleableConcurrentHashMap.SamplingEntry<K,V> - Class in com.hazelcast.util
Entry to define keys and values for sampling.
SamplingEntry(K, V) - Constructor for class com.hazelcast.util.SampleableConcurrentHashMap.SamplingEntry
 
save(Map<K, V>) - Method in interface com.hazelcast.scheduledexecutor.StatefulTask
Task callback to capture its state on the provided map.
saveCurrentTenant(DestroyEventContext) - Method in interface com.hazelcast.spi.tenantcontrol.TenantControlFactory
To be called from the application's thread to connect a Hazelcast object with a particular tenant, e.g.
saveSnapshot(JetCommandLine.Verbosity, String, String, boolean) - Method in class com.hazelcast.jet.server.JetCommandLine
 
saveToSnapshot() - Method in interface com.hazelcast.jet.core.Processor
Stores its snapshotted state by adding items to the outbox's snapshot bucket.
scalar - Variable in class com.hazelcast.org.snakeyaml.engine.v1.emitter.ScalarAnalysis
 
ScalarAnalysis - Class in com.hazelcast.org.snakeyaml.engine.v1.emitter
 
ScalarAnalysis(String, boolean, boolean, boolean, boolean, boolean, boolean) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.emitter.ScalarAnalysis
 
ScalarEvent - Class in com.hazelcast.org.snakeyaml.engine.v1.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.v1.events.ScalarEvent
 
ScalarEvent(Optional<Anchor>, Optional<String>, ImplicitTuple, String, ScalarStyle) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.events.ScalarEvent
 
ScalarNode - Class in com.hazelcast.org.snakeyaml.engine.v1.nodes
Represents a scalar node.
ScalarNode(Tag, boolean, String, ScalarStyle, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.nodes.ScalarNode
 
ScalarNode(Tag, String, ScalarStyle) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.nodes.ScalarNode
 
ScalarResolver - Interface in com.hazelcast.org.snakeyaml.engine.v1.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.v1.common
YAML provides a rich set of scalar styles.
ScalarToken - Class in com.hazelcast.org.snakeyaml.engine.v1.tokens
 
ScalarToken(String, boolean, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.tokens.ScalarToken
 
ScalarToken(String, boolean, ScalarStyle, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.tokens.ScalarToken
 
scanner - Variable in class com.hazelcast.org.snakeyaml.engine.v1.parser.ParserImpl
 
Scanner - Interface in com.hazelcast.org.snakeyaml.engine.v1.scanner
This interface represents an input stream of Tokens.
ScannerException - Exception in com.hazelcast.org.snakeyaml.engine.v1.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.v1.exceptions.ScannerException
Constructs an instance.
ScannerException(String, Optional<Mark>) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v1.exceptions.ScannerException
 
ScannerImpl - Class in com.hazelcast.org.snakeyaml.engine.v1.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.v1.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.
schedule(Runnable, long, TimeUnit) - Method in interface com.hazelcast.spi.ExecutionService
 
schedule(String, Runnable, long, TimeUnit) - Method in interface com.hazelcast.spi.ExecutionService
 
schedule(Runnable, long, TimeUnit) - Method in interface com.hazelcast.spi.TaskScheduler
Creates and executes a one-shot action that becomes enabled after the given delay.
schedule(Callable<V>, long, TimeUnit) - Method in interface com.hazelcast.spi.TaskScheduler
Creates and executes a one-shot action that becomes enabled after the given delay.
schedule(long, K, V) - Method in interface com.hazelcast.util.scheduler.EntryTaskScheduler
Schedules (or reschedules) the execution of given entry.
schedule(long, K, V) - Method in class com.hazelcast.util.scheduler.SecondsBasedEntryTaskScheduler
 
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.
scheduleClusterVersionAutoUpgrade() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
scheduleClusterVersionAutoUpgrade() - Method in interface com.hazelcast.instance.NodeExtension
Cluster version auto upgrade is done asynchronously.
SCHEDULED_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
Name of the scheduled executor.
SCHEDULED_EXECUTOR_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
scheduleDeferred(Runnable, long, TimeUnit) - Method in interface com.hazelcast.nio.NetworkingService
Global scheduler for all Endpoints responsible of message retransmission
scheduleDeferred(Runnable, long, TimeUnit) - Method in class com.hazelcast.nio.tcp.TcpIpNetworkingService
 
ScheduledEntry<K,V> - Class in com.hazelcast.util.scheduler
Entry wrapper with schedule time information to be used in SecondsBasedEntryTaskScheduler.
ScheduledEntry(K, V, long, int, long) - Constructor for class com.hazelcast.util.scheduler.ScheduledEntry
 
ScheduledEntryProcessor<K,V> - Interface in com.hazelcast.util.scheduler
 
ScheduledExecutorConfig - Class in com.hazelcast.config
Configuration options for the IScheduledExecutorService.
ScheduledExecutorConfig() - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
 
ScheduledExecutorConfig(String) - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
 
ScheduledExecutorConfig(String, int, int, int) - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
 
ScheduledExecutorConfig(String, int, int, int, String, MergePolicyConfig) - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
 
ScheduledExecutorConfig(ScheduledExecutorConfig) - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
 
ScheduledExecutorPermission - Class in com.hazelcast.security.permission
 
ScheduledExecutorPermission(String, String...) - Constructor for class com.hazelcast.security.permission.ScheduledExecutorPermission
 
ScheduledTaskHandler - Class in com.hazelcast.scheduledexecutor
Resource handler pointing to a IScheduledFuture.
ScheduledTaskHandler() - Constructor for class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
 
ScheduledTaskStatistics - Interface in com.hazelcast.scheduledexecutor
Statistics and timing info for a IScheduledFuture accessible through IScheduledFuture.getStats()
scheduleOnAllMembers(Runnable, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay on all cluster Members.
scheduleOnAllMembers(Callable<V>, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay on all cluster Members.
scheduleOnAllMembersAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period on all cluster Members.
scheduleOnKeyOwner(Runnable, Object, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay on the partition owner of the given key.
scheduleOnKeyOwner(Callable<V>, Object, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay on the partition owner of the given key.
scheduleOnKeyOwnerAtFixedRate(Runnable, Object, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period on the partition owner of the given key.
scheduleOnMember(Runnable, Member, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay at the given Member.
scheduleOnMember(Callable<V>, Member, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay at the given Member.
scheduleOnMemberAtFixedRate(Runnable, Member, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period at the given Member.
scheduleOnMembers(Runnable, Collection<Member>, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay on all Members given.
scheduleOnMembers(Callable<V>, Collection<Member>, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay on all Members given.
scheduleOnMembersAtFixedRate(Runnable, Collection<Member>, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period on all Members given.
ScheduleType - Enum in com.hazelcast.util.scheduler
Controls behaviour of SecondsBasedEntryTaskScheduler when a new entry is added under already existing key.
scheduleWithRepetition(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.spi.ExecutionService
 
scheduleWithRepetition(String, Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.spi.ExecutionService
 
scheduleWithRepetition(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.spi.TaskScheduler
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period.
schemaValidation(Document) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
SEARCH_DYNAMIC_CONFIG_FIRST - Static variable in class com.hazelcast.spi.properties.GroupProperty
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.
searchForOtherClusters() - Method in interface com.hazelcast.cluster.Joiner
Deprecated.
 
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
SecondsBasedEntryTaskScheduler<K,V> - Class in com.hazelcast.util.scheduler
Schedule execution of an entry for seconds later.
SecureCallable<V> - Interface in com.hazelcast.security
A secure callable that runs in a sandbox.
SecurityConfig - Class in com.hazelcast.config
Contains configuration for Security
SecurityConfig() - Constructor for class com.hazelcast.config.SecurityConfig
 
securityContext - Variable in class com.hazelcast.instance.Node
 
SecurityContext - Interface in com.hazelcast.security
SecurityContext is responsible for managing lifecycle of security object such as ICredentialsFactory, IPermissionPolicy etc, to creating LoginContextes for member and client authentications and checking permissions for client operations.
SecurityInterceptor - Interface in com.hazelcast.security
This interface allows to intercept requests which were produced by an API call like map.put, queue.offer...
SecurityInterceptorConfig - Class in com.hazelcast.config
This class is used to configure SecurityInterceptor
SecurityInterceptorConfig() - Constructor for class com.hazelcast.config.SecurityInterceptorConfig
 
SecurityInterceptorConfig(String) - Constructor for class com.hazelcast.config.SecurityInterceptorConfig
 
SecurityInterceptorConfig(SecurityInterceptor) - Constructor for class com.hazelcast.config.SecurityInterceptorConfig
 
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.core.MemberSelector
Decides if the given member will be part of an operation or not.
SEMAPHORE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
SEMAPHORE_REPLICATION_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
SemaphoreBackupAwareOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
SemaphoreBackupAwareOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreBackupAwareOperation
 
SemaphoreBackupAwareOperation(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreBackupAwareOperation
 
SemaphoreBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
SemaphoreBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreBackupOperation
 
SemaphoreBackupOperation(String, int, String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreBackupOperation
 
SemaphoreConfig - Class in com.hazelcast.config
Contains the configuration for an ISemaphore.
SemaphoreConfig() - Constructor for class com.hazelcast.config.SemaphoreConfig
Creates a default configured SemaphoreConfig.
SemaphoreConfig(SemaphoreConfig) - Constructor for class com.hazelcast.config.SemaphoreConfig
Creates a SemaphoreConfig by cloning another one.
SemaphoreConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
SemaphoreConfigReadOnly(SemaphoreConfig) - Constructor for class com.hazelcast.config.SemaphoreConfigReadOnly
Deprecated.
 
SemaphoreContainer - Class in com.hazelcast.concurrent.semaphore
 
SemaphoreContainer() - Constructor for class com.hazelcast.concurrent.semaphore.SemaphoreContainer
 
SemaphoreContainer(int, SemaphoreConfig) - Constructor for class com.hazelcast.concurrent.semaphore.SemaphoreContainer
 
SemaphoreDataSerializerHook - Class in com.hazelcast.concurrent.semaphore
 
SemaphoreDataSerializerHook() - Constructor for class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
SemaphoreDetachMemberBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
SemaphoreDetachMemberBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreDetachMemberBackupOperation
 
SemaphoreDetachMemberBackupOperation(String, String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreDetachMemberBackupOperation
 
SemaphoreDetachMemberOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
SemaphoreDetachMemberOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreDetachMemberOperation
 
SemaphoreDetachMemberOperation(String, String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreDetachMemberOperation
 
SemaphoreOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
SemaphoreOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
 
SemaphoreOperation(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
 
SemaphorePermission - Class in com.hazelcast.security.permission
 
SemaphorePermission(String, String...) - Constructor for class com.hazelcast.security.permission.SemaphorePermission
 
SemaphoreProxy - Class in com.hazelcast.concurrent.semaphore
 
SemaphoreProxy(String, SemaphoreService, NodeEngine) - Constructor for class com.hazelcast.concurrent.semaphore.SemaphoreProxy
 
SemaphoreReplicationOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
SemaphoreReplicationOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreReplicationOperation
 
SemaphoreReplicationOperation(Map<String, SemaphoreContainer>) - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreReplicationOperation
 
SemaphoreService - Class in com.hazelcast.concurrent.semaphore
 
SemaphoreService(NodeEngine) - Constructor for class com.hazelcast.concurrent.semaphore.SemaphoreService
 
SemaphoreWaitNotifyKey - Class in com.hazelcast.concurrent.semaphore
 
SemaphoreWaitNotifyKey(String, String) - Constructor for class com.hazelcast.concurrent.semaphore.SemaphoreWaitNotifyKey
 
send() - Method in class com.hazelcast.nio.tcp.BindRequest
 
send(Operation, Address) - Method in interface com.hazelcast.spi.OperationService
Executes an operation remotely.
sendFn(BiConsumerEx<MessageProducer, Message>) - Method in class com.hazelcast.jet.pipeline.JmsSinkBuilder
Sets the function which sends the message via message producer.
sendPhoneHome() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
sendPhoneHome() - Method in interface com.hazelcast.instance.NodeExtension
Send PhoneHome ping from OS or EE instance to PhoneHome application
sendResponse(TextCommand) - Method in class com.hazelcast.nio.ascii.TextDecoder
 
sendResponse(Object) - Method in class com.hazelcast.spi.Operation
 
sendResponse(O, Object) - Method in interface com.hazelcast.spi.OperationResponseHandler
Sends a response.
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
Value class used with some PrettyPrinter implements
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.v1.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.v1.events
Marks the end of a sequence.
SequenceEndEvent(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.events.SequenceEndEvent
 
SequenceEndEvent() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.events.SequenceEndEvent
 
SequenceNode - Class in com.hazelcast.org.snakeyaml.engine.v1.nodes
Represents a sequence.
SequenceNode(Tag, boolean, List<Node>, FlowStyle, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.nodes.SequenceNode
 
SequenceNode(Tag, List<Node>, FlowStyle) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.nodes.SequenceNode
 
SequenceStartEvent - Class in com.hazelcast.org.snakeyaml.engine.v1.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.v1.events.SequenceStartEvent
 
SequenceStartEvent(Optional<Anchor>, Optional<String>, boolean, FlowStyle) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.events.SequenceStartEvent
 
SerializableByConvention - Annotation Type in com.hazelcast.nio.serialization
Indicates that the annotated class cannot be converted to IdentifiedDataSerializable due to other conventions.
SerializableByConvention.Reason - Enum in com.hazelcast.nio.serialization
 
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.GroupProperty
Hazelcast serialization version.
SerializationClassNameFilter - Class in com.hazelcast.nio
Implementation of basic protection against untrusted deserialization.
SerializationClassNameFilter(JavaSerializationFilterConfig) - Constructor for class com.hazelcast.nio.SerializationClassNameFilter
 
SerializationConfig - Class in com.hazelcast.config
Contains the serialization configuration of HazelcastInstance.
SerializationConfig() - Constructor for class com.hazelcast.config.SerializationConfig
 
SerializationConfig(SerializationConfig) - Constructor for class com.hazelcast.config.SerializationConfig
 
serializationService - Variable in class com.hazelcast.config.AbstractCacheConfig
 
serializationService - Variable in class com.hazelcast.spi.Offload
 
SerializationService - Interface in com.hazelcast.spi.serialization
SPI to serialize user objects to Data and back to Object Data is the internal representation of binary data in hazelcast.
SerializationServiceAware - Interface in com.hazelcast.spi.serialization
Used to get a SerializationService reference injected.
Serialize - Class in com.hazelcast.org.snakeyaml.engine.v1.api.lowlevel
 
Serialize(DumpSettings) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.api.lowlevel.Serialize
Create instance with provided DumpSettings
serialize(Node) - Method in class com.hazelcast.org.snakeyaml.engine.v1.serializer.Serializer
 
serializeAll(List<Node>) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.lowlevel.Serialize
Serialize Nodes 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.v1.api.lowlevel.Serialize
Serialize a Node and produce events.
Serializer - Interface in com.hazelcast.nio.serialization
Base interface of custom serialization interfaces

see ByteArraySerializer see StreamSerializer

Serializer - Class in com.hazelcast.org.snakeyaml.engine.v1.serializer
 
Serializer(DumpSettings, Emitable) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.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
This interface is used to automatically register serializers from external Hazelcast or user modules.
Both types of Serializers are supported (StreamSerializer and ByteArraySerializer).
ServerSocketEndpointConfig - Class in com.hazelcast.config
Endpoint configuration that defines a listening side (server)
ServerSocketEndpointConfig() - Constructor for class com.hazelcast.config.ServerSocketEndpointConfig
 
service - Variable in class com.hazelcast.spi.DefaultObjectNamespace
Deprecated.
 
SERVICE_NAME - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongService
 
SERVICE_NAME - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
 
SERVICE_NAME - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
SERVICE_NAME - Static variable in class com.hazelcast.concurrent.idgen.IdGeneratorService
 
SERVICE_NAME - Static variable in interface com.hazelcast.concurrent.lock.LockService
 
SERVICE_NAME - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreService
 
SERVICE_NAME - Static variable in class com.hazelcast.crdt.CRDTReplicationMigrationService
The name of this service
SERVICE_NAME - Static variable in class com.hazelcast.crdt.pncounter.PNCounterService
The name under which this service is registered
SERVICE_NAME - Static variable in interface com.hazelcast.spi.partition.IPartitionService
The name of the service.
SERVICE_NAME - Static variable in interface com.hazelcast.wan.WanReplicationService
Service name.
ServiceConfig - Class in com.hazelcast.config
Configuration for a single service.
ServiceConfig() - Constructor for class com.hazelcast.config.ServiceConfig
 
ServiceConfigurationParser<T> - Interface in com.hazelcast.spi
A hook into the parsing system.
ServiceLoader - Class in com.hazelcast.util
Support class for loading Hazelcast services and hooks based on the Java ServiceLoader specification, but changed to the fact of class loaders to test for given services to work in multi classloader environments like application or OSGi servers.
serviceName - Variable in class com.hazelcast.spi.InvocationBuilder
 
ServiceNamespace - Interface in com.hazelcast.spi
ServiceNamespace is a namespace to group objects, structures, fragments within a service.
ServiceNamespaceAware - Interface in com.hazelcast.spi
An object which is aware of ServiceNamespace which object itself belongs to.
ServiceNotFoundException - Exception in com.hazelcast.spi.exception
A HazelcastException that indicates that a requested service is not exist.
ServiceNotFoundException(String) - Constructor for exception com.hazelcast.spi.exception.ServiceNotFoundException
 
ServicesConfig - Class in com.hazelcast.config
Configuration for the Services.
ServicesConfig() - Constructor for class com.hazelcast.config.ServicesConfig
 
session(long) - Static method in class com.hazelcast.jet.pipeline.WindowDefinition
Returns a window definition that aggregates events into session windows.
sessionFn(FunctionEx<Connection, Session>) - Method in class com.hazelcast.jet.pipeline.JmsSinkBuilder
Sets the function which creates a session from a connection.
sessionFn(FunctionEx<? super Connection, ? extends Session>) - Method in class com.hazelcast.jet.pipeline.JmsSourceBuilder
Sets the function which creates the session from connection.
sessionParams(boolean, int) - Method in class com.hazelcast.jet.pipeline.JmsSinkBuilder
Sets the session parameters.
sessionParams(boolean, int) - Method in class com.hazelcast.jet.pipeline.JmsSourceBuilder
Sets the session parameters.
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 class com.hazelcast.concurrent.atomiclong.AtomicLongContainer
 
set(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
set(Data) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceContainer
 
SET - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
set(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
set(K, V) - Method in interface com.hazelcast.core.BaseMap
Associates the specified value with the specified key in this map.
set(long) - Method in interface com.hazelcast.core.IAtomicLong
Atomically sets the given value.
set(E) - Method in interface com.hazelcast.core.IAtomicReference
Atomically sets the given value.
set(K, V) - Method in interface com.hazelcast.core.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.core.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.core.IMap
Puts an entry into this map with a given TTL (time to live) value and max idle time value.
set(K, V) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.set(Object, Object).
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 - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.nodes.Tag
 
set(long, Object) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Sets the item at the given sequence.
set(T, long) - Method in class com.hazelcast.util.ItemCounter
Set counter of item to value
set(E) - Method in class com.hazelcast.util.UnmodifiableListIterator
 
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.
SET_AND_GET - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
SET_BACKUP - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
SET_BACKUP - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
SET_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
SET_COUNT_OPERATION - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
 
SET_OPERATION - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
setAccessKey(String) - Method in class com.hazelcast.aws.AwsConfig.Builder
 
setAccessKey(String) - Method in class com.hazelcast.aws.AwsConfig
Deprecated.
It violates the immutability of AwsConfig.
setAccessKey(String) - Method in class com.hazelcast.config.AwsConfig
setAcknowledgeType(WanAcknowledgeType) - Method in class com.hazelcast.wan.WanReplicationEvent
 
setActions(Set<String>) - Method in class com.hazelcast.config.PermissionConfig
 
setAddress(String[]) - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
 
setAdvancedNetworkConfig(AdvancedNetworkConfig) - Method in class com.hazelcast.config.Config
 
setAlgorithm(String) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
setAliasedDiscoveryConfigs(List<DiscoveryStrategyConfig>) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
setAllocatorType(NativeMemoryConfig.MemoryAllocatorType) - Method in class com.hazelcast.config.NativeMemoryConfig
Sets the NativeMemoryConfig.MemoryAllocatorType to be used while allocating native memory.
setAllowDuplicateKeys(boolean) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.LoadSettingsBuilder
YAML 1.2 does require unique keys.
setAllowUnsafe(boolean) - Method in class com.hazelcast.config.SerializationConfig
Unsafe, it is not public api of java.
setAnchor(PagingPredicate, int, Map.Entry) - Static method in class com.hazelcast.query.PagingPredicateAccessor
 
setAnchorGenerator(AnchorGenerator) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.DumpSettingsBuilder
Define anchor name generator (by default 'id' + number)
setAndGet(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
setAndGet(E) - Method in interface com.hazelcast.core.IAtomicReference
Deprecated.
will be removed from Hazelcast 3.4 since it doesn't really serve a purpose
SetAndGetOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
SetAndGetOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.SetAndGetOperation
 
SetAndGetOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.SetAndGetOperation
 
setAppendRequestBackoffTimeoutInMillis(long) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
setAppendRequestMaxEntryCount(int) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
setAsync(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
setAsync(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
setAsync(long) - Method in interface com.hazelcast.core.IAtomicLong
Atomically sets the given value.
setAsync(E) - Method in interface com.hazelcast.core.IAtomicReference
Atomically sets the given value.
setAsync(K, V) - Method in interface com.hazelcast.core.IMap
Asynchronously puts the given key and value.
setAsync(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.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.core.IMap
Asynchronously puts an entry into this map with a given TTL (time to live) value and max idle time value.
setAsyncBackup(boolean) - Method in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
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.CacheConfigReadOnly
Deprecated.
 
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.CacheSimpleConfigReadOnly
Deprecated.
 
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.ListConfigReadOnly
Deprecated.
 
setAsyncBackupCount(int) - Method in class com.hazelcast.config.MapConfig
Sets the number of asynchronous backups.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setAsyncBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfig
Sets the number of asynchronous backups.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
setAsyncBackupCount(int) - Method in class com.hazelcast.config.QueueConfig
Sets the number of asynchronous backups.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.QueueConfigReadOnly
Deprecated.
 
setAsyncBackupCount(int) - Method in class com.hazelcast.config.RingbufferConfig
Sets the number of asynchronous backups.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.SemaphoreConfig
Sets the number of asynchronous backups.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.SemaphoreConfigReadOnly
Deprecated.
 
setAsyncBackupCount(int) - Method in class com.hazelcast.config.SetConfigReadOnly
Deprecated.
 
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.
setAtomicLongConfigs(Map<String, AtomicLongConfig>) - Method in class com.hazelcast.config.Config
Sets the map of AtomicLong configurations, mapped by config name.
setAtomicReferenceConfigs(Map<String, AtomicReferenceConfig>) - Method in class com.hazelcast.config.Config
Sets the map of AtomicReference configurations, mapped by config name.
setAttribute(String) - Method in class com.hazelcast.config.MapIndexConfig
Sets the attribute that is going to be indexed.
setAttribute(String) - Method in class com.hazelcast.config.MapIndexConfigReadOnly
Deprecated.
 
setAttribute(String, String) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
setAttribute(String) - Method in class com.hazelcast.query.PredicateBuilder
 
setAttributeNode(Attr) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
setAttributeNodeNS(Attr) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
setAttributeNS(String, String, String) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
setAttributes(Map<String, Object>) - Method in class com.hazelcast.config.MemberAttributeConfig
 
setAttributes(Map<String, Object>) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
Deprecated.
 
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.config.JoinConfig
 
setAwsConfig(AwsConfig) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the AwsConfig used by the discovery mechanism for this WAN publisher.
setAzureConfig(AzureConfig) - Method in class com.hazelcast.config.JoinConfig
 
setAzureConfig(AzureConfig) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the AzureConfig used by the discovery mechanism for this WAN publisher.
setBackupCount(int) - Method in class com.hazelcast.config.CacheConfig
Sets the number of synchronous backups.
setBackupCount(int) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
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.CacheSimpleConfigReadOnly
Deprecated.
 
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.ListConfigReadOnly
Deprecated.
 
setBackupCount(int) - Method in class com.hazelcast.config.MapConfig
Number of synchronous backups.
setBackupCount(int) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfig
Sets the number of synchronous backups.
setBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
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.QueueConfigReadOnly
Deprecated.
 
setBackupCount(int) - Method in class com.hazelcast.config.RingbufferConfig
Sets the number of synchronous backups.
setBackupCount(int) - Method in class com.hazelcast.config.SemaphoreConfig
Sets the number of synchronous backups.
setBackupCount(int) - Method in class com.hazelcast.config.SemaphoreConfigReadOnly
Deprecated.
 
setBackupCount(int) - Method in class com.hazelcast.config.SetConfigReadOnly
Deprecated.
 
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.
SetBackupOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
SetBackupOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.SetBackupOperation
 
SetBackupOperation(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.SetBackupOperation
 
SetBackupOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
SetBackupOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.SetBackupOperation
 
SetBackupOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.SetBackupOperation
 
setBaseDir(File) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets base directory for all Hot Restart stores.
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
setBestLineBreak(String) - Method in class com.hazelcast.org.snakeyaml.engine.v1.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.
setBinary(boolean) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
setBinding() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
setBit(byte, int) - Static method in class com.hazelcast.nio.Bits
Sets n-th bit of the byte value
setBit(int, int) - Static method in class com.hazelcast.nio.Bits
Sets n-th bit of the integer value
setBits(BitSet, Iterable<Integer>) - Static method in class com.hazelcast.util.BitSetUtils
Set all bits on a given positions.
setBlacklist(ClassFilter) - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
setBlacklistedPrefixes(String) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Comma separated list of prefixes of classes which will never be loaded remotely.
setBooleanAttribute(String, boolean) - Method in class com.hazelcast.config.MemberAttributeConfig
 
setBooleanAttribute(String, boolean) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
Deprecated.
 
setBooleanAttribute(String, boolean) - Method in interface com.hazelcast.core.Member
Defines a key-value pair boolean attribute for this member that is available to other cluster members.
setBooleanAttribute(String, boolean) - Method in class com.hazelcast.instance.MemberImpl
 
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.v1.api.LoadSettingsBuilder
Buffer size for incoming data stream.
setByteAttribute(String, byte) - Method in class com.hazelcast.config.MemberAttributeConfig
 
setByteAttribute(String, byte) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
Deprecated.
 
setByteAttribute(String, byte) - Method in interface com.hazelcast.core.Member
Defines a key-value pair byte attribute for this member available to other cluster members.
setByteAttribute(String, byte) - Method in class com.hazelcast.instance.MemberImpl
 
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.
setCacheDeserializedValues(CacheDeserializedValues) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setCacheEntryEventFilterFactory(String) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
setCacheEntryEventFilterFactory(String) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfigReadOnly
Deprecated.
 
setCacheEntryListenerFactory(String) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
setCacheEntryListenerFactory(String) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfigReadOnly
Deprecated.
 
setCacheEntryListeners(List<CacheSimpleEntryListenerConfig>) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets a list of CacheSimpleEntryListenerConfig for this ICache.
setCacheEntryListeners(List<CacheSimpleEntryListenerConfig>) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setCacheEventJournalConfigs(Map<String, EventJournalConfig>) - Method in class com.hazelcast.config.Config
Sets the map of cache event journal configurations, mapped by config name.
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 class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
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.
setCacheLoaderFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setCacheLocalEntries(boolean) - Method in class com.hazelcast.config.NearCacheConfig
Sets if local entries are also cached in the Near Cache.
setCacheLocalEntries(boolean) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
setCacheName(String) - Method in class com.hazelcast.config.EventJournalConfig
Sets the cache name to which this config applies.
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 class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
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.
setCacheWriterFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setCallerAddress(Operation, Address) - Static method in class com.hazelcast.spi.OperationAccessor
 
setCallerUuid(String) - Method in class com.hazelcast.spi.Operation
 
setCallId(Operation, long) - Static method in class com.hazelcast.spi.OperationAccessor
Assigns the supplied call ID to the supplied operation, thereby activating it.
setCallTimeout(long) - Method in class com.hazelcast.spi.InvocationBuilder
 
setCallTimeout(Operation, long) - Static method in class com.hazelcast.spi.OperationAccessor
Sets the call timeout in milliseconds for the Operation.
setCanonical(boolean) - Method in class com.hazelcast.org.snakeyaml.engine.v1.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.
setCardinalityEstimatorConfigs(Map<String, CardinalityEstimatorConfig>) - Method in class com.hazelcast.config.Config
Sets the map of cardinality estimator configurations, mapped by config name.
setChannelOptions(Channel, EndpointConfig) - Static method in class com.hazelcast.nio.IOUtil
Sets configured channel options on given Channel.
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 JsonGenerators it creates.
setCharacterEscapes(CharacterEscapes) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
Method for defining custom escapes factory uses for JsonGenerators it creates.
setCharacterEscapes(CharacterEscapes) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
 
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.
setChunkSize(int) - Method in class com.hazelcast.config.JobTrackerConfig
Sets the number of emitted values before a chunk is send to the reducers.
setChunkSize(int) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
Deprecated.
 
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.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
Sets a custom JobClassLoaderFactory that will be used to load job classes and resources on Jet members.
setClassName(String) - Method in class com.hazelcast.config.CachePartitionLostListenerConfigReadOnly
Deprecated.
 
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.EntryListenerConfigReadOnly
Deprecated.
 
setClassName(String) - Method in class com.hazelcast.config.GlobalSerializerConfig
 
setClassName(String) - Method in class com.hazelcast.config.ItemListenerConfigReadOnly
Deprecated.
 
setClassName(String) - Method in class com.hazelcast.config.ListenerConfig
Sets the class name of the EventListener.
setClassName(String) - Method in class com.hazelcast.config.ListenerConfigReadOnly
Deprecated.
 
setClassName(String) - Method in class com.hazelcast.config.LoginModuleConfig
 
setClassName(String) - Method in class com.hazelcast.config.MapPartitionLostListenerConfigReadOnly
Deprecated.
 
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.MapStoreConfigReadOnly
Deprecated.
 
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
 
setClassName(String) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
Deprecated.
 
setClassName(String) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
setClassName(String) - Method in class com.hazelcast.config.SecurityInterceptorConfig
 
setClassName(String) - Method in class com.hazelcast.config.SerializerConfig
Sets the class name of the serializer implementation.
setClassName(String) - Method in class com.hazelcast.config.ServiceConfig
 
setClassName(String) - Method in class com.hazelcast.config.SocketInterceptorConfig
Sets the name for the SocketInterceptor implementation class.
setClassName(String) - Method in class com.hazelcast.config.WanConsumerConfig
Sets the fully qualified class name of the class implementing WanReplicationConsumer.
setClassName(String) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the name of the class implementing the WanReplicationEndpoint.
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.
setClientEndpointConfig(ServerSocketEndpointConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
Sets the server socket endpoint config for CLIENT protocol.
setClientHandler(OutOfMemoryHandler) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
 
setClientLoginModuleConfigs(List<LoginModuleConfig>) - Method in class com.hazelcast.config.SecurityConfig
 
setClientPermissionConfigs(Set<PermissionConfig>) - Method in class com.hazelcast.config.SecurityConfig
 
setClientPolicyConfig(PermissionPolicyConfig) - Method in class com.hazelcast.config.SecurityConfig
 
setClusterDataRecoveryPolicy(HotRestartClusterDataRecoveryPolicy) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets the policy to be used when the cluster is started
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
Method that can be called to set or reset the object to use for writing Java objects as JsonContent (using method JsonGenerator.writeObject(java.lang.Object)).
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
 
setCollectionIntervalSeconds(int) - Method in class com.hazelcast.jet.config.MetricsConfig
Sets the metrics collection interval in seconds.
setCommitIndexAdvanceCountToSnapshot(int) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
setCommunicateStats(boolean) - Method in class com.hazelcast.config.JobTrackerConfig
Set to true if statistics (for example, about processed entries) should be transmitted to the job emitter, false otherwise.
setCommunicateStats(boolean) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
Deprecated.
 
setComparator(EvictionPolicyComparator) - Method in class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
setComparator(EvictionPolicyComparator) - Method in class com.hazelcast.config.CacheEvictionConfigReadOnly
Deprecated.
 
setComparator(EvictionPolicyComparator) - Method in class com.hazelcast.config.EvictionConfig
Sets the instance of the configured EvictionPolicyComparator implementation.
setComparator(EvictionPolicyComparator) - Method in class com.hazelcast.config.EvictionConfigReadOnly
Deprecated.
 
setComparatorClassName(String) - Method in class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
setComparatorClassName(String) - Method in class com.hazelcast.config.CacheEvictionConfigReadOnly
Deprecated.
 
setComparatorClassName(String) - Method in class com.hazelcast.config.EvictionConfig
Sets the class name of the configured EvictionPolicyComparator implementation.
setComparatorClassName(String) - Method in class com.hazelcast.config.EvictionConfigReadOnly
Deprecated.
 
setConcurrencyLevel(int) - Method in class com.hazelcast.config.ReplicatedMapConfig
Deprecated.
new implementation doesn't use mutexes
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.config.Config
Sets the pattern matcher which is used to match item names to configuration objects.
SetConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
SetConfigReadOnly(SetConfig) - Constructor for class com.hazelcast.config.SetConfigReadOnly
Deprecated.
 
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.
setConn(Connection) - Method in class com.hazelcast.nio.Packet
Sets the Connection this Packet is send with.
setConnection(Operation, Connection) - Static method in class com.hazelcast.spi.OperationAccessor
 
setConnectionRetries(int) - Method in class com.hazelcast.aws.AwsConfig.Builder
 
setConnectionTimeoutSeconds(int) - Method in class com.hazelcast.aws.AwsConfig.Builder
 
setConnectionTimeoutSeconds(int) - Method in class com.hazelcast.config.AwsConfig
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.
setConstruct(ConstructNode) - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.Node
 
setContextClassLoader(ClassLoader) - Method in class com.hazelcast.util.executor.HazelcastManagedThread
 
setCooperativeThreadCount(int) - Method in class com.hazelcast.jet.config.InstanceConfig
Sets the number of threads each cluster member will use to execute Jet jobs.
setCount(int) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
 
setCount(String, int) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
setCountDirect(int) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
 
setCountDirect(String, int) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
setCountDownLatchConfigs(Map<String, CountDownLatchConfig>) - Method in class com.hazelcast.config.Config
Sets the map of CountDownLatch configurations, mapped by config name.
SetCountOperation - Class in com.hazelcast.concurrent.countdownlatch.operations
 
SetCountOperation() - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
 
SetCountOperation(String, int) - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
 
setCPMemberCount(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets the CP member count.
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.
setCurrentAndReturn(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
 
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
Method to call to pass value to be returned via JsonStreamContext.getCurrentValue(); typically called indirectly through JsonParser.setCurrentValue(java.lang.Object) or JsonGenerator.setCurrentValue(java.lang.Object)).
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
 
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
 
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.v1.api.DumpSettingsBuilder
Define flow style
setDefaultList(Function<Integer, List>) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.LoadSettingsBuilder
Provide default List implementation.
setDefaultMap(Function<Integer, Map>) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.LoadSettingsBuilder
Provide default Map implementation.
setDefaultScalarStyle(ScalarStyle) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.DumpSettingsBuilder
Define default scalar style
setDefaultsDisabled(boolean) - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
setDefaultSet(Function<Integer, Set>) - Method in class com.hazelcast.org.snakeyaml.engine.v1.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
 
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.CacheConfigReadOnly
Deprecated.
 
setDisablePerEntryInvalidationEvents(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets invalidation events disabled status for per entry.
setDisablePerEntryInvalidationEvents(boolean) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setDiscoveryConfig(DiscoveryConfig) - Method in class com.hazelcast.config.JoinConfig
Sets a custom defined DiscoveryConfig
setDiscoveryConfig(DiscoveryConfig) - Method in class com.hazelcast.config.WanPublisherConfig
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
 
setDiscoveryServiceProvider(DiscoveryServiceProvider) - Method in class com.hazelcast.config.DiscoveryConfig
 
setDiscoveryServiceProvider(DiscoveryServiceProvider) - Method in class com.hazelcast.config.DiscoveryConfigReadOnly
Deprecated.
 
setDiscoveryStrategyConfigs(List<DiscoveryStrategyConfig>) - Method in class com.hazelcast.config.DiscoveryConfig
Sets the strategy configurations for this discovery config.
setDiscoveryStrategyConfigs(List<DiscoveryStrategyConfig>) - Method in class com.hazelcast.config.DiscoveryConfigReadOnly
Deprecated.
 
setDiscoveryStrategyFactory(DiscoveryStrategyFactory) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
setDoneCallback(Runnable) - Method in class com.hazelcast.spi.InvocationBuilder
Sets a callback that will respond to the "task done" event for the invocation this builder is about to create.
setDouble(double) - Method in class com.hazelcast.jet.accumulator.LongDoubleAccumulator
Sets the double value.
setDoubleAttribute(String, double) - Method in class com.hazelcast.config.MemberAttributeConfig
 
setDoubleAttribute(String, double) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
Deprecated.
 
setDoubleAttribute(String, double) - Method in interface com.hazelcast.core.Member
Defines a key-value pair double attribute for this member available to other cluster members.
setDoubleAttribute(String, double) - Method in class com.hazelcast.instance.MemberImpl
 
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.
setEmptyQueueTtl(int) - Method in class com.hazelcast.config.QueueConfig
Sets the TTL (time to live) for emptying the Queue.
setEmptyQueueTtl(int) - Method in class com.hazelcast.config.QueueConfigReadOnly
Deprecated.
 
setEnableCompression(boolean) - Method in class com.hazelcast.config.SerializationConfig
Enables compression when default java serialization is used.
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.AwsConfig
Enables or disables the AWS join mechanism.
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.InterfacesConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.ManagementCenterConfig
Set to true to enable management center, false to disable.
setEnabled(boolean) - Method in class com.hazelcast.config.MapStoreConfig
Enables and disables this configuration
setEnabled(boolean) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
Deprecated.
 
setEnabled(boolean) - Method in class com.hazelcast.config.MCMutualAuthConfig
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.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.QueueStoreConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
Deprecated.
 
setEnabled(boolean) - Method in class com.hazelcast.config.QuorumConfig
 
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.SSLConfig
Enables and disables this configuration.
setEnabled(boolean) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
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.
setEnabled(boolean) - Method in class com.hazelcast.jet.config.MetricsConfig
Sets whether metrics collection should be enabled for the node.
setEnableDefaults(boolean) - Method in class com.hazelcast.config.ServicesConfig
 
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
 
setEndMark(Optional<Mark>) - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.CollectionNode
 
setEndpoint(String) - Method in class com.hazelcast.aws.AWSClient
 
setEndpoint(String) - Method in class com.hazelcast.config.WanPublisherConfig
 
setEndPoint(Address) - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
setEndpoint(String) - Method in class com.hazelcast.security.AbstractCredentials
 
setEndpoint(String) - Method in interface com.hazelcast.security.Credentials
Sets IP address of endpoint.
setEndpointConfigs(Map<EndpointQualifier, EndpointConfig>) - Method in class com.hazelcast.config.AdvancedNetworkConfig
 
setEndpointManager(EndpointManager) - Method in class com.hazelcast.spi.InvocationBuilder
 
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.MapConfigReadOnly
Deprecated.
 
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.MultiMapConfigReadOnly
Deprecated.
 
setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.config.QueryCacheConfig
 
setError(Throwable) - Method in class com.hazelcast.util.executor.DelegatingFuture
 
setErrorHandler(TcpIpConnectionErrorHandler) - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
setEurekaConfig(EurekaConfig) - Method in class com.hazelcast.config.JoinConfig
 
setEurekaConfig(EurekaConfig) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the EurekaConfig used by the discovery mechanism for this WAN publisher.
setEventObject(ReplicationEventObject) - Method in class com.hazelcast.wan.WanReplicationEvent
Sets the event object.
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.CacheConfig
Sets the EvictionConfig instance for eviction configuration for this ICache.
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the eviction configuration for this ICache.
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
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.NearCacheConfigReadOnly
Deprecated.
 
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.QueryCacheConfig
Sets the EvictionConfig instance for this QueryCache
setEvictionPercentage(int) - Method in class com.hazelcast.config.MapConfig
Deprecated.
As of version 3.7, eviction mechanism changed. It uses a probabilistic algorithm based on sampling. Please see documentation for further details
setEvictionPercentage(int) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.CacheEvictionConfigReadOnly
Deprecated.
 
setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.EvictionConfig
Sets the EvictionPolicy of this eviction configuration.
setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.EvictionConfigReadOnly
Deprecated.
 
setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.MapConfig
Sets the EvictionPolicy.
setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setEvictionPolicy(String) - Method in class com.hazelcast.config.NearCacheConfig
setEvictionPolicy(String) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
setExecutionCallback(ExecutionCallback<Object>) - Method in class com.hazelcast.spi.InvocationBuilder
Sets the ExecutionCallback.
setExecutionId(long) - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
Sets the execution ID.
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.
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 class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
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.
setExpiryPolicyFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setExpiryPolicyFactoryConfig(CacheSimpleConfig.ExpiryPolicyFactoryConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the factory configuration for this ExpiryPolicy.
setExpiryPolicyFactoryConfig(CacheSimpleConfig.ExpiryPolicyFactoryConfig) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setExplicitEnd(boolean) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.DumpSettingsBuilder
Add '...' in the end of the document
setExplicitRootTag(Optional<Tag>) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.DumpSettingsBuilder
Define root Tag or let the tag to be detected automatically
setExplicitStart(boolean) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.DumpSettingsBuilder
Add '---' in the beginning of the document
setExtractor(String) - Method in class com.hazelcast.config.MapAttributeConfig
Sets the full class name of the extractor in a String format, e.g.
setExtractor(String) - Method in class com.hazelcast.config.MapAttributeConfigReadOnly
Deprecated.
 
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.MapStoreConfigReadOnly
Deprecated.
 
setFactoryClassName(String) - Method in class com.hazelcast.config.MCMutualAuthConfig
Sets the name for the implementation class.
setFactoryClassName(String) - Method in class com.hazelcast.config.QueueStoreConfig
 
setFactoryClassName(String) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
Deprecated.
 
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.
setFactoryImplementation(Object) - Method in class com.hazelcast.config.MapStoreConfig
Sets the map store factory implementation object.
setFactoryImplementation(Object) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
Deprecated.
 
setFactoryImplementation(Object) - Method in class com.hazelcast.config.MCMutualAuthConfig
Sets the implementation object.
setFactoryImplementation(QueueStoreFactory) - Method in class com.hazelcast.config.QueueStoreConfig
 
setFactoryImplementation(QueueStoreFactory) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
Deprecated.
 
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 API calls will fail when result of a replicated operation becomes indeterminate
setFailOnIndeterminateOperationState(boolean) - Method in class com.hazelcast.spi.InvocationBuilder
Enables / disables throwing IndeterminateOperationStateException for this invocation.
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
Deprecated.
Since 2.7, use JsonGenerator.overrideStdFeatures(int, int) instead -- remove from 2.9
setFeatureMask(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Deprecated.
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
 
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.
setFilters(List<String>) - Method in class com.hazelcast.config.WanReplicationRefReadOnly
Deprecated.
 
setFlakeIdGeneratorConfigs(Map<String, FlakeIdGeneratorConfig>) - Method in class com.hazelcast.config.Config
Sets the map of FlakeIdGenerator configurations, mapped by config name.
setFloatAttribute(String, float) - Method in class com.hazelcast.config.MemberAttributeConfig
 
setFloatAttribute(String, float) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
Deprecated.
 
setFloatAttribute(String, float) - Method in interface com.hazelcast.core.Member
Defines a key-value pair float attribute for this member available to other cluster members.
setFloatAttribute(String, float) - Method in class com.hazelcast.instance.MemberImpl
 
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.v1.nodes.CollectionNode
 
setFsync(boolean) - Method in class com.hazelcast.config.HotRestartConfig
Sets whether disk write should be followed by an fsync() system call.
setGcpConfig(GcpConfig) - Method in class com.hazelcast.config.JoinConfig
 
setGcpConfig(GcpConfig) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the GcpConfig used by the discovery mechanism for this WAN publisher.
setGlobalOrderingEnabled(boolean) - Method in class com.hazelcast.config.TopicConfig
Enable global ordering (all nodes listening to the same topic get their messages in the same order), or disable it (nodes get the messages in the order that the messages are published).
setGlobalOrderingEnabled(boolean) - Method in class com.hazelcast.config.TopicConfigReadOnly
Deprecated.
 
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
 
setGroupConfig(GroupConfig) - Method in class com.hazelcast.config.Config
Sets the configuration for hazelcast groups.
setGroupName(String) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the group name used as an endpoint group name for authentication on the target endpoint.
setGroupSize(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets group size.
setGroupType(PartitionGroupConfig.MemberGroupType) - Method in class com.hazelcast.config.PartitionGroupConfig
Sets the MemberGroupType.
setHazelcast(HazelcastInstance) - Method in class com.hazelcast.console.ConsoleApp
 
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.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
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.instance.MemberImpl
 
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
 
setHostHeader(String) - Method in class com.hazelcast.aws.AwsConfig.Builder
 
setHostHeader(String) - Method in class com.hazelcast.config.AwsConfig
setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.AbstractCacheConfig
Sets the HotRestartConfig for this CacheConfiguration
setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the HotRestartConfig for this CacheSimpleConfig
setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.MapConfig
Sets the HotRestartConfig for this MapConfig
setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setHotRestartPersistenceConfig(HotRestartPersistenceConfig) - Method in class com.hazelcast.config.Config
Sets the Hot Restart configuration.
setHzPort(PortRange) - Method in class com.hazelcast.aws.AwsConfig.Builder
 
setIamRole(String) - Method in class com.hazelcast.aws.AwsConfig.Builder
 
setIamRole(String) - Method in class com.hazelcast.aws.AwsConfig
Deprecated.
It violates the immutability of AwsConfig.
setIamRole(String) - Method in class com.hazelcast.config.AwsConfig
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
setIdAttribute(String, boolean) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
setIdAttributeNode(Attr, boolean) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
setIdAttributeNS(String, String, boolean) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
setIdOffset(long) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Sets the offset that will be added to the returned IDs.
setIdOffset(long) - Method in class com.hazelcast.config.FlakeIdGeneratorConfigReadOnly
Deprecated.
 
setIfEqualOrGreaterThan(AtomicLong, long) - Static method in class com.hazelcast.util.ConcurrencyUtil
 
setImplementation(CachePartitionLostListener) - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
 
setImplementation(EventListener) - Method in class com.hazelcast.config.CachePartitionLostListenerConfigReadOnly
Deprecated.
 
setImplementation(CachePartitionLostListener) - Method in class com.hazelcast.config.CachePartitionLostListenerConfigReadOnly
Deprecated.
 
setImplementation(ICredentialsFactory) - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
setImplementation(EventListener) - Method in class com.hazelcast.config.EntryListenerConfig
 
setImplementation(EntryListener) - Method in class com.hazelcast.config.EntryListenerConfig
 
setImplementation(EntryListener) - Method in class com.hazelcast.config.EntryListenerConfigReadOnly
Deprecated.
 
setImplementation(EventListener) - Method in class com.hazelcast.config.EntryListenerConfigReadOnly
Deprecated.
 
setImplementation(Serializer) - Method in class com.hazelcast.config.GlobalSerializerConfig
 
setImplementation(ItemListener) - Method in class com.hazelcast.config.ItemListenerConfig
 
setImplementation(ItemListener) - Method in class com.hazelcast.config.ItemListenerConfigReadOnly
Deprecated.
 
setImplementation(EventListener) - Method in class com.hazelcast.config.ItemListenerConfigReadOnly
Deprecated.
 
setImplementation(EventListener) - Method in class com.hazelcast.config.ListenerConfig
Sets the EventListener implementation.
setImplementation(EventListener) - Method in class com.hazelcast.config.ListenerConfigReadOnly
Deprecated.
 
setImplementation(Object) - Method in class com.hazelcast.config.LoginModuleConfig
Deprecated.
setImplementation(MapPartitionLostListener) - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
 
setImplementation(EventListener) - Method in class com.hazelcast.config.MapPartitionLostListenerConfigReadOnly
Deprecated.
 
setImplementation(MapPartitionLostListener) - Method in class com.hazelcast.config.MapPartitionLostListenerConfigReadOnly
Deprecated.
 
setImplementation(Object) - Method in class com.hazelcast.config.MapStoreConfig
Sets the map store implementation object
setImplementation(Object) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
Deprecated.
 
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(QuorumListener) - Method in class com.hazelcast.config.QuorumListenerConfig
 
setImplementation(SecurityInterceptor) - Method in class com.hazelcast.config.SecurityInterceptorConfig
 
setImplementation(Serializer) - Method in class com.hazelcast.config.SerializerConfig
Sets the serializer implementation instance.
setImplementation(Object) - Method in class com.hazelcast.config.ServiceConfig
 
setImplementation(Object) - Method in class com.hazelcast.config.SocketInterceptorConfig
Sets the SocketInterceptor implementation object.
setImplementation(Object) - Method in class com.hazelcast.config.WanConsumerConfig
Sets the implementation for this WAN consumer.
setImplementation(Object) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the implementation of the WanReplicationEndpoint.
setIncludeValue(boolean) - Method in class com.hazelcast.config.EntryListenerConfig
 
setIncludeValue(boolean) - Method in class com.hazelcast.config.EntryListenerConfigReadOnly
Deprecated.
 
setIncludeValue(boolean) - Method in class com.hazelcast.config.ItemListenerConfig
 
setIncludeValue(boolean) - Method in class com.hazelcast.config.ItemListenerConfigReadOnly
Deprecated.
 
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.v1.api.DumpSettingsBuilder
Define the amount of the spaces for the indent in the block flow style.
setIndexConfigs(List<MapIndexConfig>) - Method in class com.hazelcast.config.QueryCacheConfig
 
setIndicatorIndent(int) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.DumpSettingsBuilder
Default is 0.
setInitialized() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
 
setInitialLoadMode(MapStoreConfig.InitialLoadMode) - Method in class com.hazelcast.config.MapStoreConfig
Sets the initial load mode.
setInitialLoadMode(MapStoreConfig.InitialLoadMode) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
Deprecated.
 
setInitialPermits(int) - Method in class com.hazelcast.config.SemaphoreConfig
Sets the initial number of permits.
setInitialPermits(int) - Method in class com.hazelcast.config.SemaphoreConfigReadOnly
Deprecated.
 
setInitialPublisherState(WanPublisherState) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the initial publisher state.
setInitialSnapshotName(String) - Method in class com.hazelcast.jet.config.JobConfig
Sets the exported state snapshot name to restore the initial job state from.
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.CacheConfig
Data type that will be used to store records in this ICache.
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the InMemory Format for this ICache.
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
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.MapConfigReadOnly
Deprecated.
 
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.NearCacheConfigReadOnly
Deprecated.
 
setInMemoryFormat(String) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
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
Method for overriding currently configured input decorator
setInstanceConfig(InstanceConfig) - Method in class com.hazelcast.jet.config.JetConfig
Sets the Jet instance config.
setInstanceName(String) - Method in class com.hazelcast.config.Config
Sets the instance name uniquely identifying the hazelcast instance created by this configuration.
setIntAttribute(String, int) - Method in class com.hazelcast.config.MemberAttributeConfig
 
setIntAttribute(String, int) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
Deprecated.
 
setIntAttribute(String, int) - Method in interface com.hazelcast.core.Member
Defines a key-value pair int attribute for this member available to other cluster members.
setIntAttribute(String, int) - Method in class com.hazelcast.instance.MemberImpl
 
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.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).
setInvalidateOnChange(boolean) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
setInvocationTime(Operation, long) - Static method in class com.hazelcast.spi.OperationAccessor
Sets the invocation time for the Operation.
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.ListConfigReadOnly
Deprecated.
 
setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.config.QueueConfig
Set the list of item listener configurations for this queue.
setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.config.QueueConfigReadOnly
Deprecated.
 
setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.config.SetConfigReadOnly
Deprecated.
 
setIterationCount(int) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
setIterationType(IterationType) - Method in class com.hazelcast.query.PagingPredicate
 
setJavaSerializationFilterConfig(JavaSerializationFilterConfig) - Method in class com.hazelcast.config.SerializationConfig
Allows to configure deserialization protection filter.
setJDKCompatible(boolean) - Method in class com.hazelcast.config.cp.CPSemaphoreConfig
Sets JDK compatibility mode of the 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
 
setJmxEnabled(boolean) - Method in class com.hazelcast.jet.config.MetricsConfig
Enables metrics exposure through JMX.
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.
setJobTrackerConfigs(Map<String, JobTrackerConfig>) - Method in class com.hazelcast.config.Config
Sets the map of job tracker configurations, mapped by config name.
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
 
setKey(byte[]) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
setKeyClassName(String) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setKeyMetadata(Object) - Method in class com.hazelcast.query.Metadata
 
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.
setKeyType(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setKubernetesConfig(KubernetesConfig) - Method in class com.hazelcast.config.JoinConfig
 
setKubernetesConfig(KubernetesConfig) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the KubernetesConfig used by the discovery mechanism for this WAN publisher.
setLabel(String) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.LoadSettingsBuilder
Label for the input data.
setLastAccessTime(long) - Method in interface com.hazelcast.monitor.LocalRecordStoreStats
Increases the number of hits of the locally owned entries of this partition.
setLastUpdateTime(long) - Method in interface com.hazelcast.monitor.LocalRecordStoreStats
Increases the number of hits of the locally owned entries of this partition.
setLeaderElectionTimeoutInMillis(long) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
setLeaderHeartbeatPeriodInMillis(long) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
setLicenseKey(String) - Method in class com.hazelcast.config.Config
Sets the license key for this hazelcast instance.
setLicenseKey(String) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
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.config.Config
Sets the list of EventListener configurations.
setListenerConfigs(List<QuorumListenerConfig>) - Method in class com.hazelcast.config.QuorumConfig
 
setListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.ReplicatedMapConfig
 
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.
setLocal(boolean) - Method in class com.hazelcast.config.EntryListenerConfig
 
setLocal(boolean) - Method in class com.hazelcast.config.EntryListenerConfigReadOnly
Deprecated.
 
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.SinkStage
 
setLocalParallelism(int) - Method in interface com.hazelcast.jet.pipeline.Stage
Sets the preferred local parallelism (number of processors per Jet cluster member) this stage will configure its DAG vertices with.
setLocalParallelism(int) - Method in interface com.hazelcast.jet.pipeline.StreamStage
 
setLocalProcessorIndex(int) - Method in class com.hazelcast.jet.core.test.TestProcessorContext
Set the local processor index
setLocalUpdatePolicy(NearCacheConfig.LocalUpdatePolicy) - Method in class com.hazelcast.config.NearCacheConfig
Sets the NearCacheConfig.LocalUpdatePolicy of this Near Cache.
setLocalUpdatePolicy(NearCacheConfig.LocalUpdatePolicy) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
setLockAcquireLimit(int) - Method in class com.hazelcast.config.cp.FencedLockConfig
Sets the number of lock acquires a lock holder can perform
setLockConfigs(Map<String, LockConfig>) - Method in class com.hazelcast.config.Config
Sets the map of ILock configurations, mapped by config name.
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
 
setLong(long) - Method in class com.hazelcast.jet.accumulator.LongDoubleAccumulator
Sets the long value.
setLongAttribute(String, long) - Method in class com.hazelcast.config.MemberAttributeConfig
 
setLongAttribute(String, long) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
Deprecated.
 
setLongAttribute(String, long) - Method in interface com.hazelcast.core.Member
Defines a key-value pair long attribute for this member available to other cluster members.
setLongAttribute(String, long) - Method in class com.hazelcast.instance.MemberImpl
 
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.config.Config
Sets the external managed context.
setManagementCenterConfig(ManagementCenterConfig) - Method in class com.hazelcast.config.Config
Sets the management center configuration for this hazelcast instance.
setManagementEnabled(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
Sets whether or not management is enabled on this cache.
setManagementEnabled(boolean) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
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.
setManagementEnabled(boolean) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setManagerPrefix(String) - Method in class com.hazelcast.config.CacheConfig
Sets the manager prefix of the ICache.
setManagerPrefix(String) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setMapAttributeConfigs(List<MapAttributeConfig>) - Method in class com.hazelcast.config.MapConfig
 
setMapAttributeConfigs(List<MapAttributeConfig>) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setMapConfigs(Map<String, MapConfig>) - Method in class com.hazelcast.config.Config
Sets the map of IMap configurations, mapped by config name.
setMapEventJournalConfigs(Map<String, EventJournalConfig>) - Method in class com.hazelcast.config.Config
Sets the map of map event journal configurations, mapped by config name.
setMapEvictionPolicy(MapEvictionPolicy) - Method in class com.hazelcast.config.MapConfig
Sets custom eviction policy implementation for this map.
setMapEvictionPolicy(MapEvictionPolicy) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setMapIndexConfigs(List<MapIndexConfig>) - Method in class com.hazelcast.config.MapConfig
 
setMapIndexConfigs(List<MapIndexConfig>) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setMapMerkleTreeConfigs(Map<String, MerkleTreeConfig>) - Method in class com.hazelcast.config.Config
Sets the map of map merkle configurations, mapped by config name.
setMapName(String) - Method in class com.hazelcast.config.EventJournalConfig
Sets the map name to which this config applies.
setMapName(String) - Method in class com.hazelcast.config.MerkleTreeConfig
Sets the map name to which this config applies.
setMapStoreConfig(MapStoreConfig) - Method in class com.hazelcast.config.MapConfig
Sets the map store configuration
setMapStoreConfig(MapStoreConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setMax(E, AtomicLongFieldUpdater<E>, long) - Static method in class com.hazelcast.util.ConcurrencyUtil
Atomically sets the max value.
setMaxAttempts(int) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
Set the max ping attempts before suspecting a member
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.MapConfigReadOnly
Deprecated.
 
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).
setMaxIdleSeconds(int) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
setMaximumSizePolicy(EvictionConfig.MaxSizePolicy) - Method in class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
setMaximumSizePolicy(EvictionConfig.MaxSizePolicy) - Method in class com.hazelcast.config.CacheEvictionConfigReadOnly
Deprecated.
 
setMaximumSizePolicy(EvictionConfig.MaxSizePolicy) - Method in class com.hazelcast.config.EvictionConfig
Sets the EvictionConfig.MaxSizePolicy of this eviction configuration.
setMaximumSizePolicy(EvictionConfig.MaxSizePolicy) - Method in class com.hazelcast.config.EvictionConfigReadOnly
Deprecated.
 
setMaxMissedLeaderHeartbeatCount(int) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
setMaxSize(int) - Method in class com.hazelcast.config.CollectionConfig
Sets the maximum size for the collection.
setMaxSize(int) - Method in class com.hazelcast.config.ListConfigReadOnly
Deprecated.
 
setMaxSize(int) - Method in class com.hazelcast.config.NearCacheConfig
setMaxSize(int) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
setMaxSize(int) - Method in class com.hazelcast.config.QueueConfig
Sets the maximum size of the Queue.
setMaxSize(int) - Method in class com.hazelcast.config.QueueConfigReadOnly
Deprecated.
 
setMaxSize(int) - Method in class com.hazelcast.config.SetConfigReadOnly
Deprecated.
 
setMaxSizeConfig(MaxSizeConfig) - Method in class com.hazelcast.config.MapConfig
 
setMaxSizeConfig(MaxSizeConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setMaxSizePolicy(CacheEvictionConfig.CacheMaxSizePolicy) - Method in class com.hazelcast.config.CacheEvictionConfig
setMaxSizePolicy(CacheEvictionConfig.CacheMaxSizePolicy) - Method in class com.hazelcast.config.CacheEvictionConfigReadOnly
Deprecated.
 
setMaxSizePolicy(MaxSizeConfig.MaxSizePolicy) - Method in class com.hazelcast.config.MaxSizeConfig
Ses the maximum size policy of the map.
setMaxSizePolicy(MaxSizeConfig.MaxSizePolicy) - Method in class com.hazelcast.config.MaxSizeConfigReadOnly
Deprecated.
 
setMaxThreadSize(int) - Method in class com.hazelcast.config.JobTrackerConfig
Sets the maximum thread pool size of this JobTracker.
setMaxThreadSize(int) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
Deprecated.
 
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.
setMemberCredentialsConfig(CredentialsFactoryConfig) - Method in class com.hazelcast.config.SecurityConfig
 
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
Set the member index.
setMemberListJoinVersion(int) - Method in class com.hazelcast.instance.MemberImpl
 
setMemberLoginModuleConfigs(List<LoginModuleConfig>) - 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.v1.nodes.MappingNode
 
setMergePolicy(String) - Method in class com.hazelcast.config.CacheConfig
Sets the class name of CacheMergePolicy implementation to this cache config.
setMergePolicy(String) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setMergePolicy(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the class name of CacheMergePolicy implementation to this cache config.
setMergePolicy(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setMergePolicy(String) - Method in class com.hazelcast.config.MapConfig
Deprecated.
setMergePolicy(String) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setMergePolicy(String) - Method in class com.hazelcast.config.ReplicatedMapConfig
setMergePolicy(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.
setMergePolicy(String) - Method in class com.hazelcast.config.WanReplicationRefReadOnly
Deprecated.
 
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.AbstractBasicConfig
Sets the MergePolicyConfig for this data structure.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Sets the MergePolicyConfig for the scheduler.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.CollectionConfig
Sets the MergePolicyConfig for the collection.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.ListConfigReadOnly
Deprecated.
 
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.MapConfig
Sets the MergePolicyConfig for this map.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.MultiMapConfig
Sets the MergePolicyConfig for this MultiMap.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.QueueConfig
Sets the MergePolicyConfig for this queue.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.QueueConfigReadOnly
Deprecated.
 
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.ReplicatedMapConfig
Sets the MergePolicyConfig for this replicated map.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.RingbufferConfig
Sets the MergePolicyConfig for this ringbuffer.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.ScheduledExecutorConfig
Sets the MergePolicyConfig for the scheduler.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.SetConfigReadOnly
Deprecated.
 
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.
setMessageListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.TopicConfigReadOnly
Deprecated.
 
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(MetricsConfig) - Method in class com.hazelcast.jet.config.JetConfig
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.
setMetricsForDataStructuresEnabled(boolean) - Method in class com.hazelcast.jet.config.MetricsConfig
Sets whether statistics for data structures are added to metrics.
setMinBlockSize(int) - Method in class com.hazelcast.config.NativeMemoryConfig
Sets the minimum memory block size, in bytes, to be served by native memory manager.
setMinEvictionCheckMillis(long) - Method in class com.hazelcast.config.MapConfig
Deprecated.
As of version 3.7, eviction mechanism changed. It uses a probabilistic algorithm based on sampling. Please see documentation for further details.
setMinEvictionCheckMillis(long) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setMissingCPMemberAutoRemovalSeconds(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets duration to wait before automatically removing a missing CP member from the CP subsystem
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.v1.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.
setMultiThreadingEnabled(boolean) - Method in class com.hazelcast.config.TopicConfig
Enable multi-threaded message handling.
setMultiThreadingEnabled(boolean) - Method in class com.hazelcast.config.TopicConfigReadOnly
Deprecated.
 
setMutualAuthConfig(MCMutualAuthConfig) - Method in class com.hazelcast.config.ManagementCenterConfig
Sets the management center mutual auth config
setName(String) - Method in class com.hazelcast.config.AbstractBasicConfig
Sets the name of this data structure.
setName(String) - Method in class com.hazelcast.config.CacheConfig
Sets the name of this ICache.
setName(String) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setName(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the name of this ICache.
setName(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
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.CountDownLatchConfig
Sets the name of the CountDownLatch.
setName(String) - Method in class com.hazelcast.config.cp.CPSemaphoreConfig
Sets name of the semaphore
setName(String) - Method in class com.hazelcast.config.cp.FencedLockConfig
Sets name of the semaphore
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.ExecutorConfigReadOnly
Deprecated.
 
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.FlakeIdGeneratorConfigReadOnly
Deprecated.
 
setName(String) - Method in class com.hazelcast.config.GroupConfig
Sets the group name of the group.
setName(String) - Method in class com.hazelcast.config.JobTrackerConfig
Sets the name of this JobTracker.
setName(String) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
Deprecated.
 
setName(String) - Method in class com.hazelcast.config.ListConfigReadOnly
Deprecated.
 
setName(String) - Method in class com.hazelcast.config.LockConfig
Sets the name of the lock.
setName(String) - Method in class com.hazelcast.config.MapAttributeConfig
Sets the name of the attribute extracted by the extractor.
setName(String) - Method in class com.hazelcast.config.MapAttributeConfigReadOnly
Deprecated.
 
setName(String) - Method in class com.hazelcast.config.MapConfig
Sets the name of the IMap
setName(String) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setName(String) - Method in class com.hazelcast.config.MultiMapConfig
Sets the name of this MultiMap.
setName(String) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
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.NearCacheConfigReadOnly
Deprecated.
 
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.QueueConfigReadOnly
Deprecated.
 
setName(String) - Method in class com.hazelcast.config.QuorumConfig
 
setName(String) - Method in class com.hazelcast.config.ReliableTopicConfig
Sets the name of the reliable topic.
setName(String) - Method in class com.hazelcast.config.ReplicatedMapConfig
Sets the name of this ReplicatedMap.
setName(String) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setName(String) - Method in class com.hazelcast.config.RingbufferConfig
Sets the name of the ringbuffer.
setName(String) - Method in class com.hazelcast.config.ScheduledExecutorConfig
Sets the name of the executor task.
setName(String) - Method in class com.hazelcast.config.SemaphoreConfig
Sets the name of the semaphore.
setName(String) - Method in class com.hazelcast.config.SemaphoreConfigReadOnly
Deprecated.
 
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.SetConfigReadOnly
Deprecated.
 
setName(String) - Method in class com.hazelcast.config.TopicConfig
Sets the name of the topic.
setName(String) - Method in class com.hazelcast.config.TopicConfigReadOnly
Deprecated.
 
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.config.WanReplicationRefReadOnly
Deprecated.
 
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
 
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
setNearCacheConfig(NearCacheConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setNetworkConfig(NetworkConfig) - Method in class com.hazelcast.config.Config
Sets the network configuration for this hazelcast instance.
setNode(Node) - Method in interface com.hazelcast.spi.NodeAware
 
setNodeEngine(NodeEngine) - Method in class com.hazelcast.spi.Operation
 
setNodeFilter(NodeFilter) - Method in class com.hazelcast.config.DiscoveryConfig
 
setNodeFilter(NodeFilter) - Method in class com.hazelcast.config.DiscoveryConfigReadOnly
Deprecated.
 
setNodeFilterClass(String) - Method in class com.hazelcast.config.DiscoveryConfig
 
setNodeFilterClass(String) - Method in class com.hazelcast.config.DiscoveryConfigReadOnly
Deprecated.
 
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.
setNodeIdOffset(long) - Method in class com.hazelcast.config.FlakeIdGeneratorConfigReadOnly
Deprecated.
 
setNodeValue(String) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
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.
setOldValueRequired(boolean) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfigReadOnly
Deprecated.
 
setOnJoinPermissionOperation(OnJoinPermissionOperationName) - Method in class com.hazelcast.config.SecurityConfig
 
SetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
SetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.SetOperation
 
SetOperation(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.SetOperation
 
SetOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
SetOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.SetOperation
 
SetOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.SetOperation
 
setOperationResponseHandler(OperationResponseHandler) - Method in class com.hazelcast.spi.Operation
setOperationTryCount(int) - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
Sets the operation retry count for PN counter operations.
setOptimizeQueries(boolean) - Method in class com.hazelcast.config.MapConfig
setOptimizeQueries(boolean) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setOrdered(boolean) - Method in class com.hazelcast.config.MapIndexConfig
Configures the index to be ordered or not ordered.
setOrdered(boolean) - Method in class com.hazelcast.config.MapIndexConfigReadOnly
Deprecated.
 
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.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.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
Method for overriding currently configured output decorator
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.
setPacketType(Packet.Type) - Method in class com.hazelcast.nio.Packet
Sets the packet type by updating the packet type bits in the flags bitfield.
setPage(int) - Method in class com.hazelcast.query.PagingPredicate
 
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.
setPartitionGroupConfig(PartitionGroupConfig) - Method in class com.hazelcast.config.Config
Sets the partition group configuration for this hazelcast instance.
setPartitionId(int) - Method in interface com.hazelcast.mapreduce.PartitionIdAware
Deprecated.
Sets the partition ID to the implementing instance it is executed against
setPartitionId(int) - Method in class com.hazelcast.spi.Operation
Sets the partition ID.
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
 
setPartitioningStrategy(PartitioningStrategy) - Method in class com.hazelcast.config.PartitioningStrategyConfigReadOnly
Deprecated.
 
setPartitioningStrategyClass(String) - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
setPartitioningStrategyClass(String) - Method in class com.hazelcast.config.PartitioningStrategyConfigReadOnly
Deprecated.
 
setPartitioningStrategyConfig(PartitioningStrategyConfig) - Method in class com.hazelcast.config.MapConfig
 
setPartitioningStrategyConfig(PartitioningStrategyConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
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.CacheConfigReadOnly
Deprecated.
 
setPartitionLostListenerConfigs(List<CachePartitionLostListenerConfig>) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the PartitionLostListenerConfigs.
setPartitionLostListenerConfigs(List<CachePartitionLostListenerConfig>) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setPartitionLostListenerConfigs(List<MapPartitionLostListenerConfig>) - Method in class com.hazelcast.config.MapConfig
 
setPartitionLostListenerConfigs(List<MapPartitionLostListenerConfig>) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setPartitionStrategy(PartitioningStrategy) - Method in class com.hazelcast.config.PartitioningStrategyConfig
Deprecated.
setPartitionStrategy(PartitioningStrategy) - Method in class com.hazelcast.config.PartitioningStrategyConfigReadOnly
Deprecated.
 
setPassword(String) - Method in class com.hazelcast.config.GroupConfig
Deprecated.
since 3.11, password check is removed. Passwords are only checked in default LoginModule when Hazelcast security is enabled (Enterprise edition only).
setPassword(String) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
setPassword(String) - Method in class com.hazelcast.security.UsernamePasswordCredentials
Sets the password.
SetPermission - Class in com.hazelcast.security.permission
 
SetPermission(String, String...) - Constructor for class com.hazelcast.security.permission.SetPermission
 
setPersistWanReplicatedData(boolean) - Method in class com.hazelcast.config.WanConsumerConfig
 
setPNCounterConfigs(Map<String, PNCounterConfig>) - Method in class com.hazelcast.config.Config
Sets the map of PN counter configurations, mapped by config name.
setPolicy(String) - Method in class com.hazelcast.config.MergePolicyConfig
Sets the classname of your SplitBrainMergePolicy.
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.ExecutorConfigReadOnly
Deprecated.
 
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.config.FlakeIdGeneratorConfig
Sets how many IDs are pre-fetched on the background when one call to FlakeIdGenerator.newId() is made.
setPrefetchCount(int) - Method in class com.hazelcast.config.FlakeIdGeneratorConfigReadOnly
Deprecated.
 
setPrefetchValidityMillis(long) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Sets for how long the pre-fetched IDs can be used.
setPrefetchValidityMillis(long) - Method in class com.hazelcast.config.FlakeIdGeneratorConfigReadOnly
Deprecated.
 
setPrefix(String) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
setPrefixes(Collection<String>) - Method in class com.hazelcast.config.ClassFilter
 
setPreloaderConfig(NearCachePreloaderConfig) - Method in class com.hazelcast.config.NearCacheConfig
Sets the NearCachePreloaderConfig of this Near Cache.
setPreloaderConfig(NearCachePreloaderConfig) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
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.security.AbstractCredentials
 
setProcessingGuarantee(ProcessingGuarantee) - Method in class com.hazelcast.jet.config.JobConfig
Set the processing guarantee for the job.
setProcessingGuarantee(ProcessingGuarantee) - Method in class com.hazelcast.jet.core.test.TestProcessorContext
 
setProcessingGuarantee(ProcessingGuarantee) - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
Sets the processing guarantee.
setProcessingGuarantee(ProcessingGuarantee) - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
 
setProperties(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.MapStoreConfigReadOnly
Deprecated.
 
setProperties(Properties) - Method in class com.hazelcast.config.MCMutualAuthConfig
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
 
setProperties(Properties) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
Deprecated.
 
setProperties(Properties) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
setProperties(Properties) - Method in class com.hazelcast.config.ServiceConfig
 
setProperties(Properties) - Method in class com.hazelcast.config.SocketInterceptorConfig
Sets the properties.
setProperties(Properties) - Method in class com.hazelcast.config.SSLConfig
Sets the properties.
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.WanPublisherConfig
Sets the WAN publisher properties.
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.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.MapStoreConfig
 
setProperty(String, String) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
Deprecated.
 
setProperty(String, String) - Method in class com.hazelcast.config.MCMutualAuthConfig
Sets a property.
setProperty(String, String) - Method in class com.hazelcast.config.QueueStoreConfig
 
setProperty(String, String) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
Deprecated.
 
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.config.SSLConfig
Sets a property.
setProperty(String, String) - Method in class com.hazelcast.jet.config.JetConfig
Sets the value of the specified property.
setProviderFilter(String) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Filter to constraint members to 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.
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.WanPublisherConfig
Sets the publisher ID used for identifying the publisher in a WanReplicationConfig.
setQueryCacheConfigs(List<QueryCacheConfig>) - Method in class com.hazelcast.config.MapConfig
Sets QueryCacheConfig instances to this MapConfig.
setQueryCacheConfigs(List<QueryCacheConfig>) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
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.ExecutorConfigReadOnly
Deprecated.
 
setQueueCapacity(int) - Method in class com.hazelcast.config.WanPublisherConfig
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.WanPublisherConfig
Sets the configured behaviour of this WAN publisher when the WAN queue is full.
setQueueSize(int) - Method in class com.hazelcast.config.JobTrackerConfig
Sets the maximum size of the queue; the maximum number of tasks that can wait to be processed.
setQueueSize(int) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
Deprecated.
 
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.
setQueueStoreConfig(QueueStoreConfig) - Method in class com.hazelcast.config.QueueConfigReadOnly
Deprecated.
 
setQuorumConfigs(Map<String, QuorumConfig>) - Method in class com.hazelcast.config.Config
Sets the map of split-brain protection configurations, mapped by config name.
setQuorumFunctionClassName(String) - Method in class com.hazelcast.config.QuorumConfig
 
setQuorumFunctionImplementation(QuorumFunction) - Method in class com.hazelcast.config.QuorumConfig
 
setQuorumName(String) - Method in class com.hazelcast.config.AbstractBasicConfig
Sets the quorum name for operations.
setQuorumName(String) - Method in class com.hazelcast.config.CacheConfig
Associates this cache configuration to a quorum.
setQuorumName(String) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setQuorumName(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Associates this cache configuration to a quorum.
setQuorumName(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setQuorumName(String) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Sets the quorum name for operations.
setQuorumName(String) - Method in class com.hazelcast.config.CollectionConfig
Sets the quorum name for operations.
setQuorumName(String) - Method in class com.hazelcast.config.CountDownLatchConfig
 
setQuorumName(String) - Method in class com.hazelcast.config.DurableExecutorConfig
Sets the quorum name for operations.
setQuorumName(String) - Method in class com.hazelcast.config.ExecutorConfig
Sets the quorum name for operations.
setQuorumName(String) - Method in class com.hazelcast.config.ExecutorConfigReadOnly
Deprecated.
 
setQuorumName(String) - Method in class com.hazelcast.config.ListConfigReadOnly
Deprecated.
 
setQuorumName(String) - Method in class com.hazelcast.config.LockConfig
Sets the quorum name for lock operations.
setQuorumName(String) - Method in class com.hazelcast.config.MapConfig
 
setQuorumName(String) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setQuorumName(String) - Method in class com.hazelcast.config.MultiMapConfig
Sets the quorum name for operations.
setQuorumName(String) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
setQuorumName(String) - Method in class com.hazelcast.config.PNCounterConfig
Sets the quorum name for operations.
setQuorumName(String) - Method in class com.hazelcast.config.QueueConfig
Sets the quorum name for queue operations.
setQuorumName(String) - Method in class com.hazelcast.config.QueueConfigReadOnly
Deprecated.
 
setQuorumName(String) - Method in class com.hazelcast.config.ReplicatedMapConfig
Sets the quorum name for operations.
setQuorumName(String) - Method in class com.hazelcast.config.RingbufferConfig
Sets the quorum name for operations.
setQuorumName(String) - Method in class com.hazelcast.config.ScheduledExecutorConfig
Sets the quorum name for operations.
setQuorumName(String) - Method in class com.hazelcast.config.SemaphoreConfig
 
setQuorumName(String) - Method in class com.hazelcast.config.SemaphoreConfigReadOnly
Deprecated.
 
setQuorumName(String) - Method in class com.hazelcast.config.SetConfigReadOnly
Deprecated.
 
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.
setReadBackupData(boolean) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
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 class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
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.
setReadThrough(boolean) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setReceiveWindowMultiplier(int) - Method in class com.hazelcast.jet.config.EdgeConfig
Sets the scaling factor used by the adaptive receive window sizing function.
setRecursive(boolean) - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.Node
 
setReferenceCallId(long) - Method in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
setRegion(String) - Method in class com.hazelcast.aws.AwsConfig.Builder
 
setRegion(String) - Method in class com.hazelcast.config.AwsConfig
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.
setReplicaIndex(int) - Method in class com.hazelcast.spi.InvocationBuilder
Sets the replicaIndex.
setReplicaIndex(int) - Method in class com.hazelcast.spi.Operation
 
setReplicatedMapConfigs(Map<String, ReplicatedMapConfig>) - Method in class com.hazelcast.config.Config
Sets the map of ReplicatedMap configurations, mapped by config name.
setReplicationDelayMillis(long) - Method in class com.hazelcast.config.ReplicatedMapConfig
Deprecated.
since new implementation will route puts to the partition owner nodes, caching won't help replication speed because most of the time subsequent puts will end up in different nodes
setReplicationPeriodMillis(int) - Method in class com.hazelcast.config.CRDTReplicationConfig
Sets the period between two replications of CRDT states in milliseconds.
setReplicatorExecutorService(ScheduledExecutorService) - Method in class com.hazelcast.config.ReplicatedMapConfig
Deprecated.
new implementation doesn't use executor service for replication
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.
setRepublishingEnabled(boolean) - Method in class com.hazelcast.config.WanReplicationRefReadOnly
Deprecated.
 
setRequestPayloadOnError(RequestPayload) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Sets the payload to be passed if JsonParseException is thrown.
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.
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.
setResultDeserialized(boolean) - Method in class com.hazelcast.spi.InvocationBuilder
Sets the automatic deserialized option for the result.
setRetentionSeconds(int) - Method in class com.hazelcast.jet.config.MetricsConfig
Returns the number of seconds the metrics will be retained on the instance.
setRetryCount(int) - Method in class com.hazelcast.config.JobTrackerConfig
retry count is currently not used but reserved for later use where the framework will automatically try to restart / retry operations from a available savepoint.
setRetryCount(int) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
Deprecated.
 
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.
setRootConstructNode(Optional<ConstructNode>) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.LoadSettingsBuilder
Provide the factory to create Nodes.
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.SymmetricEncryptionConfig
 
setScalarResolver(ScalarResolver) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.DumpSettingsBuilder
Define ScalarResolver or use JSON resolver by default
setScalarResolver(ScalarResolver) - Method in class com.hazelcast.org.snakeyaml.engine.v1.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
 
setScopeId(String) - Method in class com.hazelcast.nio.Address
 
setScriptingEnabled(boolean) - Method in class com.hazelcast.config.ManagementCenterConfig
Enables/disables scripting on the member.
setSecretKey(String) - Method in class com.hazelcast.aws.AwsConfig.Builder
 
setSecretKey(String) - Method in class com.hazelcast.aws.AwsConfig
Deprecated.
It violates the immutability of AwsConfig.
setSecretKey(String) - Method in class com.hazelcast.config.AwsConfig
setSecurityConfig(SecurityConfig) - Method in class com.hazelcast.config.Config
Sets the security configuration for this hazelcast instance.
setSecurityGroupName(String) - Method in class com.hazelcast.aws.AwsConfig.Builder
 
setSecurityGroupName(String) - Method in class com.hazelcast.config.AwsConfig
setSecurityInterceptorConfigs(List<SecurityInterceptorConfig>) - Method in class com.hazelcast.config.SecurityConfig
 
setSemaphoreConfigs(Map<String, SemaphoreConfig>) - Method in class com.hazelcast.config.Config
Sets the map of semaphore configurations, mapped by config name.
setSemaphoreConfigs(Map<String, CPSemaphoreConfig>) - 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.config.Config
Sets the serialization configuration for this hazelcast instance.
setSerializationService(SerializationService) - Method in interface com.hazelcast.spi.serialization.SerializationServiceAware
Gets the SerializationService reference injected.
setSerializeKeys(boolean) - Method in class com.hazelcast.config.NearCacheConfig
Sets if the Near Cache key is stored in serialized format or by-reference.
setSerializeKeys(boolean) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
Deprecated.
 
setSerializerConfigs(Collection<SerializerConfig>) - Method in class com.hazelcast.config.SerializationConfig
 
setServerHandler(OutOfMemoryHandler) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
 
setService(Object) - Method in class com.hazelcast.spi.Operation
 
setServiceConfigs(Collection<ServiceConfig>) - Method in class com.hazelcast.config.ServicesConfig
 
setServiceImpl(Object) - Method in class com.hazelcast.config.ServiceConfig
setServiceName(String) - Method in class com.hazelcast.spi.Operation
 
setServiceName(String) - Method in class com.hazelcast.wan.WanReplicationEvent
Sets the service name for this event object.
setServicesConfig(ServicesConfig) - Method in class com.hazelcast.config.Config
Sets the configuration for the user services managed by this hazelcast instance.
setSessionHeartbeatIntervalSeconds(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets interval for the periodically-committed CP session heartbeats
setSessionTimeToLiveSeconds(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets duration for a CP session to be kept alive after the last heartbeat
setSetConfigs(Map<String, SetConfig>) - Method in class com.hazelcast.config.Config
Sets the map of ISet configurations, mapped by config name.
setShortAttribute(String, short) - Method in class com.hazelcast.config.MemberAttributeConfig
 
setShortAttribute(String, short) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
Deprecated.
 
setShortAttribute(String, short) - Method in interface com.hazelcast.core.Member
Defines a key-value pair short attribute for this member available to other cluster members.
setShortAttribute(String, short) - Method in class com.hazelcast.instance.MemberImpl
 
setShuttingDown() - Method in class com.hazelcast.instance.Node
 
setSize(int) - Method in class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
setSize(int) - Method in class com.hazelcast.config.CacheEvictionConfigReadOnly
Deprecated.
 
setSize(int) - Method in class com.hazelcast.config.EvictionConfig
Sets the size which is used by the EvictionConfig.MaxSizePolicy.
setSize(int) - Method in class com.hazelcast.config.EvictionConfigReadOnly
Deprecated.
 
setSize(int) - Method in class com.hazelcast.config.MaxSizeConfig
Sets the maximum size of the map.
setSize(int) - Method in class com.hazelcast.config.MaxSizeConfigReadOnly
Deprecated.
 
setSize(MemorySize) - Method in class com.hazelcast.config.NativeMemoryConfig
Sets size of the native memory region.
setSize(int) - Method in class com.hazelcast.config.QuorumConfig
 
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
 
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
 
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.
setSplitLines(boolean) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.DumpSettingsBuilder
Define whether to split long lines
setSql(String) - Method in class com.hazelcast.config.PredicateConfig
Sets sql string for this config.
setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.EndpointConfig
Sets the SSLConfig.
setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.NetworkConfig
Sets the SSLConfig.
setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
Sets whether or not statistics gathering is enabled on this cache.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
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.CacheSimpleConfigReadOnly
Deprecated.
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.CollectionConfig
Sets collection statistics to enabled or disabled.
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.ExecutorConfigReadOnly
Deprecated.
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Enables or disables statistics gathering of LocalFlakeIdGeneratorStats.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.FlakeIdGeneratorConfigReadOnly
Deprecated.
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ListConfigReadOnly
Deprecated.
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.MapConfig
Sets statistics to enabled or disabled for this map.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.MultiMapConfig
Enables or disables statistics for this MultiMap.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
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.QueueConfigReadOnly
Deprecated.
 
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.SetConfigReadOnly
Deprecated.
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.TopicConfig
Enables or disables statistics for this topic.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.TopicConfigReadOnly
Deprecated.
 
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 class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
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
 
setStoreImplementation(QueueStore) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
Deprecated.
 
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.
setStringAttribute(String, String) - Method in class com.hazelcast.config.MemberAttributeConfig
 
setStringAttribute(String, String) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
Deprecated.
 
setStringAttribute(String, String) - Method in interface com.hazelcast.core.Member
Defines a key-value pair string attribute for this member available to other cluster members.
setStringAttribute(String, String) - Method in class com.hazelcast.instance.MemberImpl
 
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
 
setSyncBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfig
Deprecated.
setSyncBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
setSynchronous(boolean) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
If true, this cache entry listener implementation will be called in a synchronous manner.
setSynchronous(boolean) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfigReadOnly
Deprecated.
 
setSystemProperty(String) - Method in class com.hazelcast.spi.properties.HazelcastProperty
Sets the system property value of the property.
setTag(Tag) - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.Node
 
setTagConstructors(Map<Tag, ConstructNode>) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.LoadSettingsBuilder
Provide constructors for the specified tags.
setTagDirective(Map<String, String>) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.DumpSettingsBuilder
Add TAG directive (http://yaml.org/spec/1.2/spec.html#id2782090)
setTagKey(String) - Method in class com.hazelcast.aws.AwsConfig.Builder
 
setTagKey(String) - Method in class com.hazelcast.config.AwsConfig
setTagValue(String) - Method in class com.hazelcast.aws.AwsConfig.Builder
 
setTagValue(String) - Method in class com.hazelcast.config.AwsConfig
setTailSequence(long) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Sets the tail sequence.
setTargetAddress(Address) - Method in interface com.hazelcast.cluster.Joiner
Deprecated.
 
setTcpIpConfig(TcpIpConfig) - Method in class com.hazelcast.config.JoinConfig
 
setTenant(boolean) - Method in interface com.hazelcast.spi.tenantcontrol.TenantControl
Establish this tenant's thread-local context Particular TenantControl implementation will control the details of how createRequestScope parameter is handled, but in general, if createRequestScope = false, only ClassLoader is set up, if createRequestScope = true, in addition to ClassLoader, other things like invocation, EJB/JPA/CDI context should be set up as well In other words, if only app class needs to be resolved, set createRequestScope to false If actually calling into user's code, set createRequestScope to true
setTenantControl(CacheConfig<K, V>, TenantControl) - Static method in class com.hazelcast.config.CacheConfigAccessor
 
setTextContent(String) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
setThisMember(MemberImpl) - Method in class com.hazelcast.logging.LoggingServiceImpl
 
setThreadId(long) - Static method in class com.hazelcast.util.ThreadUtil
Set the thread ID.
setTimeout(long, TimeUnit) - Method in class com.hazelcast.transaction.TransactionOptions
Sets the timeout.
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.
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.MapConfigReadOnly
Deprecated.
 
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.NearCacheConfigReadOnly
Deprecated.
 
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.
settings - Variable in class com.hazelcast.org.snakeyaml.engine.v1.constructor.BaseConstructor
 
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.config.ReliableTopicConfig
Sets the TopicOverloadPolicy for this reliable topic.
setTopologyChangedStrategy(TopologyChangedStrategy) - Method in class com.hazelcast.config.JobTrackerConfig
Sets how the map reduce framework will react on topology changes while executing a job.
setTopologyChangedStrategy(TopologyChangedStrategy) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
Deprecated.
 
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.MulticastConfig
Sets the trusted interfaces.
setTryCount(int) - Method in class com.hazelcast.spi.InvocationBuilder
Sets the try count; the number of times this operation can be retried.
setTryPauseMillis(long) - Method in class com.hazelcast.spi.InvocationBuilder
Sets the pause time in milliseconds.
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.core.IMap
Updates TTL (time to live) value of the entry specified by key with a new TTL value.
setType(PermissionConfig.PermissionType) - Method in class com.hazelcast.config.PermissionConfig
 
setType(QuorumType) - Method in class com.hazelcast.config.QuorumConfig
 
setType(ConnectionType) - Method in interface com.hazelcast.nio.Connection
Sets the type of the connection
setType(ConnectionType) - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
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 class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
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
 
setUpdateInterval(int) - Method in class com.hazelcast.config.ManagementCenterConfig
Sets the time frequency (in seconds) for which Management Center will take information from the Hazelcast cluster.
setupNextDecoder() - Method in class com.hazelcast.nio.tcp.SingleProtocolDecoder
 
setupNextDecoder() - Method in class com.hazelcast.nio.tcp.TextHandshakeDecoder
 
setUriString(String) - Method in class com.hazelcast.config.CacheConfig
Sets the URI string, which is the global identifier of the ICache.
setUriString(String) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
setUrl(String) - Method in class com.hazelcast.config.ManagementCenterConfig
Sets the URL where management center will work.
setUsage(LoginModuleConfig.LoginModuleUsage) - Method in class com.hazelcast.config.LoginModuleConfig
 
setUseMarks(boolean) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.LoadSettingsBuilder
Marks are only used for error messages.
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(UserCodeDeploymentConfig) - Method in class com.hazelcast.config.Config
Set User Code Deployment configuration
setUserContext(ConcurrentMap<String, Object>) - Method in class com.hazelcast.config.Config
Sets the user supplied context.
setUserData(String, Object, UserDataHandler) - Method in class com.hazelcast.config.yaml.ElementAdapter
 
setUsername(String) - Method in class com.hazelcast.security.UsernamePasswordCredentials
Sets the user name.
setUseUnicodeEncoding(boolean) - Method in class com.hazelcast.org.snakeyaml.engine.v1.api.DumpSettingsBuilder
Define whether Unicode char or escape sequence starting with '\\u'
SetUtil - Class in com.hazelcast.util
Utility class for Sets.
setValidateTarget(boolean) - Method in class com.hazelcast.spi.Operation
 
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(long) - Method in class com.hazelcast.crdt.pncounter.operations.CRDTTimestampedLong
 
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(List<NodeTuple>) - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.MappingNode
 
setValue(V) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap.SimpleEntry
 
setValue(V) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap.WriteThroughEntry
Set our entry's value and writes it through to the map.
setValue(V) - Method in class com.hazelcast.util.scheduler.ScheduledEntry
 
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.
setValueCollectionType(String) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
setValueCollectionType(MultiMapConfig.ValueCollectionType) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
setValueMetadata(Object) - Method in class com.hazelcast.query.Metadata
 
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.
setValueType(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setVectorClock(VectorClock) - Method in class com.hazelcast.crdt.pncounter.operations.CRDTTimestampedLong
 
setVersion(Version) - Method in interface com.hazelcast.nio.BufferObjectDataInput
 
setVersion(Version) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
setVersionFunction(Function<SpecVersion, SpecVersion>) - Method in class com.hazelcast.org.snakeyaml.engine.v1.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
 
setWaitTimeout(long) - Method in class com.hazelcast.spi.Operation
Sets the wait timeout in millis.
setWanConsumerConfig(WanConsumerConfig) - Method in class com.hazelcast.config.WanReplicationConfig
Sets the WAN consumer configuration for this WAN replication.
setWanPublisherConfigs(List<WanPublisherConfig>) - Method in class com.hazelcast.config.WanReplicationConfig
Sets the list of configured WAN publisher targets for this WAN replication.
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.CacheConfigReadOnly
Deprecated.
 
setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the WAN target replication reference.
setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.MapConfig
Sets the WAN target replication reference.
setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
setWanSyncConfig(WanSyncConfig) - Method in class com.hazelcast.config.WanPublisherConfig
Sets the config for the WAN sync mechanism.
setWhitelist(ClassFilter) - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
setWhitelistedPrefixes(String) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Comma separated list of prefixes of classes which will be loaded remotely.
setWidth(int) - Method in class com.hazelcast.org.snakeyaml.engine.v1.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.
setWriteBatchSize(int) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
Deprecated.
 
setWriteCoalescing(boolean) - Method in class com.hazelcast.config.MapStoreConfig
Setting MapStoreConfig.writeCoalescing is meaningful if you are using write-behind MapStore.
setWriteCoalescing(boolean) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
Deprecated.
 
setWriteDelaySeconds(int) - Method in class com.hazelcast.config.MapStoreConfig
Sets the number of seconds to delay before writing (storing) the dirty records
setWriteDelaySeconds(int) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
Deprecated.
 
setWriteThrough(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setWriteThrough(boolean) - Method in class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
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.
setWriteThrough(boolean) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
setYamlDirective(Optional<SpecVersion>) - Method in class com.hazelcast.org.snakeyaml.engine.v1.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
Logs a message at Level.SEVERE.
severe(Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a throwable at the Level.SEVERE level.
severe(String, Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a message with an associated throwable at the Level.SEVERE level.
SHARE_LOCALLY_DEFAULT - Static variable in class com.hazelcast.jet.pipeline.ContextFactory
sharedFileSystem(boolean) - Method in class com.hazelcast.jet.avro.AvroSourceBuilder
Sets if files are in a shared storage visible to all members.
sharedFileSystem(boolean) - Method in class com.hazelcast.jet.pipeline.FileSourceBuilder
Sets if files are in a shared storage visible to all members.
SharedService - Interface in com.hazelcast.spi
Deprecated.
since 3.7. A service can be retrieved using NodeEngine.getService(String)
SHORT_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
SHORT_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
SHORT_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
Short size in bytes
SHORT_WRITE - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
 
shouldBackup - Variable in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBackupAwareOperation
 
shouldBackup() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBackupAwareOperation
 
shouldBackup - Variable in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBackupAwareOperation
 
shouldBackup() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBackupAwareOperation
 
shouldBackup() - Method in class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
 
shouldBackup() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
 
shouldBackup() - Method in class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
 
shouldBackup() - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
 
shouldBackup() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
 
shouldBackup() - Method in class com.hazelcast.concurrent.lock.operations.LocalLockCleanupOperation
 
shouldBackup() - Method in class com.hazelcast.concurrent.lock.operations.LockOperation
 
shouldBackup() - Method in class com.hazelcast.concurrent.lock.operations.SignalOperation
 
shouldBackup() - Method in class com.hazelcast.concurrent.lock.operations.UnlockIfLeaseExpiredOperation
This operation runs on both primary and backup If it is running on backup we should not send a backup operation
shouldBackup() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
 
shouldBackup() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
 
shouldBackup() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainOperation
 
shouldBackup() - Method in class com.hazelcast.concurrent.semaphore.operations.IncreaseOperation
 
shouldBackup() - Method in class com.hazelcast.concurrent.semaphore.operations.InitOperation
 
shouldBackup() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceOperation
 
shouldBackup() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
 
shouldBackup() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDetachMemberOperation
 
shouldBackup() - Method in interface com.hazelcast.spi.BackupAwareOperation
Checks if a backup needs to be made.
shouldBlockReads() - Method in interface com.hazelcast.concurrent.lock.LockResource
 
shouldBlockReads(Data) - Method in interface com.hazelcast.concurrent.lock.LockStore
Return whether the reads for the specific key should be blocked (see LockStore.txnLock(Data, String, long, long, long, boolean)).
shouldBlockReads(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
shouldBlockReads(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
 
shouldCheckQuorum() - Method in class com.hazelcast.concurrent.lock.operations.LocalLockCleanupOperation
 
shouldCheckQuorum() - Method in class com.hazelcast.concurrent.lock.operations.UnlockIfLeaseExpiredOperation
 
shouldConnectTo(Address) - Method in interface com.hazelcast.nio.IOService
 
shouldConnectTo(Address) - Method in class com.hazelcast.nio.NodeIOService
 
shouldFailOnIndeterminateOperationState() - Method in class com.hazelcast.spi.InvocationBuilder
Returns true if IndeterminateOperationStateException is enabled for this invocation
shouldHandle(OutOfMemoryError) - Method in class com.hazelcast.core.OutOfMemoryHandler
Decides if the OutOfMemoryError thrown will be handled by this OutOfMemoryHandler or not.
shouldHandle(OutOfMemoryError) - Method in class com.hazelcast.instance.DefaultOutOfMemoryHandler
 
shouldNotify() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
 
shouldNotify() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
 
shouldNotify() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
 
shouldNotify() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
 
shouldNotify() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDetachMemberOperation
 
shouldNotify() - Method in interface com.hazelcast.spi.Notifier
 
shouldWait(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
shouldWait() - Method in class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
 
shouldWait() - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
 
shouldWait() - Method in class com.hazelcast.concurrent.lock.operations.LockOperation
 
shouldWait() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
 
shouldWait() - Method in interface com.hazelcast.spi.BlockingOperation
 
shutdown(boolean) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
 
shutdown(boolean) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
 
shutdown(boolean) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
shutdown(boolean) - Method in class com.hazelcast.concurrent.idgen.IdGeneratorService
 
shutdown(boolean) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
shutdown(boolean) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
 
shutdown() - Method in interface com.hazelcast.core.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.core.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(boolean) - Method in class com.hazelcast.crdt.CRDTReplicationMigrationService
 
shutdown(boolean) - Method in class com.hazelcast.crdt.pncounter.PNCounterService
 
shutdown() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
shutdown() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
shutdown() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
shutdown() - Method in class com.hazelcast.instance.LifecycleServiceImpl
 
shutdown(boolean) - Method in class com.hazelcast.instance.Node
 
shutdown() - Method in interface com.hazelcast.instance.NodeExtension
Shutdowns NodeExtension.
shutdown() - Method in class com.hazelcast.instance.TerminatedLifecycleService
 
shutdown() - Method in interface com.hazelcast.jet.JetInstance
Shuts down the current instance.
shutdown() - Method in interface com.hazelcast.nio.NetworkingService
Shutdowns the service completely.
shutdown() - Method in class com.hazelcast.nio.tcp.TcpIpAcceptor
 
shutdown() - Method in class com.hazelcast.nio.tcp.TcpIpNetworkingService
 
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(boolean) - Method in interface com.hazelcast.spi.ManagedService
Shuts down this service.
shutdown() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
 
shutdown() - Method in class com.hazelcast.util.executor.StripedExecutor
Shuts down this StripedExecutor.
shutdown() - Method in class com.hazelcast.util.PhoneHome
 
shutdown() - Method in interface com.hazelcast.wan.WanReplicationEndpoint
Closes the endpoint and its internal connections and shuts down other internal states
shutdown() - Method in interface com.hazelcast.wan.WanReplicationService
Starts the shutdown process of the WAN replication service.
shutdownAll() - Static method in class com.hazelcast.core.Hazelcast
Shuts down all member HazelcastInstances running on this JVM.
shutdownAll() - Static method in class com.hazelcast.instance.HazelcastInstanceFactory
 
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
Shuts down all running HazelcastOSGiInstances on the owner bundle.
shutdownExecutor(String) - Method in interface com.hazelcast.spi.ExecutionService
 
shutdownHazelcastInstance(HazelcastOSGiInstance) - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Shuts down the given HazelcastOSGiInstance on the owner bundle.
SHUTDOWNHOOK_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SHUTDOWNHOOK_POLICY - Static variable in class com.hazelcast.spi.properties.GroupProperty
Behaviour when JVM is about to exit while Hazelcast instance is still running.
shutdownNodeByFiringEvents(Node, boolean) - Static method in class com.hazelcast.instance.NodeShutdownHelper
Shutdowns a node by firing lifecycle events.
shutdownNow() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
 
sign(String, Map<String, String>) - Method in class com.hazelcast.aws.security.EC2RequestSigner
 
SIGNAL - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
signal(Data, String, int, String) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
SIGNAL_BACKUP - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
SignalBackupOperation - Class in com.hazelcast.concurrent.lock.operations
 
SignalBackupOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.SignalBackupOperation
 
SignalBackupOperation(ObjectNamespace, Data, long, String, boolean) - Constructor for class com.hazelcast.concurrent.lock.operations.SignalBackupOperation
 
SignalOperation - Class in com.hazelcast.concurrent.lock.operations
 
SignalOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.SignalOperation
 
SignalOperation(ObjectNamespace, Data, long, String, boolean) - Constructor for class com.hazelcast.concurrent.lock.operations.SignalOperation
 
signalProtocolLoaded() - Method in class com.hazelcast.nio.tcp.MemberProtocolEncoder
 
SilentException - Interface in com.hazelcast.spi.exception
Marked interface for exceptions.
SIMPLE_CACHE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
SIMPLE_CACHE_CONFIG_DURATION_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
SIMPLE_CACHE_CONFIG_EXPIRY_POLICY_FACTORY_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
SIMPLE_CACHE_CONFIG_TIMED_EXPIRY_POLICY_FACTORY_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
SIMPLE_CACHE_ENTRY_LISTENER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
SimpleDiscoveryNode - Class in com.hazelcast.spi.discovery
Simple immutable implementation of the DiscoveryNode interface for convenience when implementing a DiscoveryStrategy.
SimpleDiscoveryNode(Address) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
This constructor will set private and public addresses to the same value and no properties are available.
SimpleDiscoveryNode(Address, Map<String, Object>) - 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, Object>) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
This constructor will set private and public addresses separately.
SimpleEntry(K, V) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap.SimpleEntry
 
SimpleEntry(Map.Entry<? extends K, ? extends V>) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap.SimpleEntry
 
SimpleEvent - Class in com.hazelcast.jet.pipeline.test
A simple event with a timestamp and a sequence number.
SimpleEvent(long, long) - Constructor for class com.hazelcast.jet.pipeline.test.SimpleEvent
Create an event with the given timestamp and sequence number
SimplePropertyDefinition - Class in com.hazelcast.config.properties
Simple immutable implementation of PropertyDefinition for convenience of implementors.
SimplePropertyDefinition(String, 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
 
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.
SingleExecutorThreadFactory - Class in com.hazelcast.util.executor
 
SingleExecutorThreadFactory(ClassLoader, String) - Constructor for class com.hazelcast.util.executor.SingleExecutorThreadFactory
 
SingleMemberGroup - Class in com.hazelcast.partition.membergroup
 
SingleMemberGroup() - Constructor for class com.hazelcast.partition.membergroup.SingleMemberGroup
 
SingleMemberGroup(Member) - Constructor for class com.hazelcast.partition.membergroup.SingleMemberGroup
 
SingleMemberGroupFactory - Class in com.hazelcast.partition.membergroup
Arranges members in single-member groups (every member is its own group).
SingleMemberGroupFactory() - Constructor for class com.hazelcast.partition.membergroup.SingleMemberGroupFactory
 
SingleProtocolDecoder - Class in com.hazelcast.nio.tcp
 
SingleProtocolDecoder(ProtocolType, InboundHandler) - Constructor for class com.hazelcast.nio.tcp.SingleProtocolDecoder
 
SingleProtocolDecoder(ProtocolType, InboundHandler[], MemberProtocolEncoder) - Constructor for class com.hazelcast.nio.tcp.SingleProtocolDecoder
Decodes first 3 incoming bytes, validates against supportedProtocol and, when matching, replaces itself in the inbound pipeline with the next InboundHandlers.
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<W,T> - Class in com.hazelcast.jet.pipeline
sinkBuilder(String, FunctionEx<Processor.Context, ? extends W>) - 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.
size() - Method in interface com.hazelcast.cache.ICache
Total entry count.
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 - Variable in class com.hazelcast.config.QuorumConfigBuilder
Quorum size: expected number of live members in cluster for quorum to be present.
size() - Method in interface com.hazelcast.core.BaseMap
Returns the number of entries in this map.
size() - Method in interface com.hazelcast.core.BaseMultiMap
Returns the number of key-value pairs in the multimap.
size() - Method in interface com.hazelcast.core.BaseQueue
Returns the number of elements in this collection.
size() - Method in interface com.hazelcast.core.MultiMap
Returns the number of key-value pairs in the multimap.
size() - Method in interface com.hazelcast.core.TransactionalList
Returns the size of the list.
size() - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of Map.size().
size() - Method in interface com.hazelcast.core.TransactionalMultiMap
Returns the number of key-value pairs in the multimap.
size() - Method in interface com.hazelcast.core.TransactionalQueue
Returns the number of elements in this collection.
size() - Method in interface com.hazelcast.core.TransactionalSet
Returns the size of the set.
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.QueryCache
 
size() - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
size() - Method in interface com.hazelcast.partition.membergroup.MemberGroup
 
size() - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
size() - Method in interface com.hazelcast.ringbuffer.ReadResultSet
Return the result set size.
size() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Returns number of items in the Ringbuffer.
size() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Returns number of items in the ringbuffer (meaning the number of items between the RingbufferMergeData.getHeadSequence() and RingbufferMergeData.getTailSequence()).
size() - Method in class com.hazelcast.util.collection.BiInt2ObjectMap
Return the number of unique entries in the map.
size() - Method in class com.hazelcast.util.collection.InflatableSet.Builder
 
size() - Method in class com.hazelcast.util.collection.InflatableSet
 
size() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.KeySet
 
size() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
 
size() - Method in class com.hazelcast.util.collection.IntHashSet
 
size() - Method in class com.hazelcast.util.collection.Long2LongHashMap
 
size() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.KeySet
 
size() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
 
size() - Method in class com.hazelcast.util.collection.LongHashSet
size() - Method in class com.hazelcast.util.collection.MapDelegatingSet
size() - Method in class com.hazelcast.util.collection.OAHashSet
 
size() - Method in class com.hazelcast.util.collection.WeightedEvictableList
 
size() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
Returns the number of key-value mappings in this map.
skip(long) - Method in class com.hazelcast.com.fasterxml.jackson.core.io.MergedStream
 
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
Method that will skip all child tokens of an array or object token that the parser currently points to, iff stream points to JsonToken.START_OBJECT or JsonToken.START_ARRAY.
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_INVOCATION_DETECTOR_THRESHOLD_MILLIS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
SLOW_OPERATION_DETECTOR_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Enables or disables the SlowOperationDetector.
SLOW_OPERATION_DETECTOR_LOG_PURGE_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Purge interval for slow operation logs.
SLOW_OPERATION_DETECTOR_LOG_RETENTION_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
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.GroupProperty
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.GroupProperty
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.
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.
sneakyThrow(Throwable) - Static method in class com.hazelcast.util.ExceptionUtil
 
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
Convenience for Sinks.socket(String, int, FunctionEx, Charset) with UTF-8 as the charset.
socket(String, int) - Static method in class com.hazelcast.jet.pipeline.Sinks
Convenience for Sinks.socket(String, int, FunctionEx, Charset) with Object.toString as the conversion function and UTF-8 as the charset.
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
Convenience for socket(host, port, charset) with UTF-8 as the charset.
SOCKET_BIND_ANY - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_BUFFER_DIRECT - Static variable in class com.hazelcast.spi.properties.GroupProperty
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.GroupProperty
 
SOCKET_CLIENT_BIND_ANY - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_CLIENT_BUFFER_DIRECT - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_CLIENT_RECEIVE_BUFFER_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Overrides receive buffer size for connections opened by clients.
SOCKET_CLIENT_SEND_BUFFER_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Overrides send buffer size for connections opened by clients.
SOCKET_CONNECT_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_KEEP_ALIVE - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_LINGER_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_NO_DELAY - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_RECEIVE_BUFFER_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_SEND_BUFFER_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_SERVER_BIND_ANY - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
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
 
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.
SortingUtil - Class in com.hazelcast.util
Utility class for generating Comparators to be used in sort methods specific to hazelcast classes.
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.
SourceBuilder<C> - Class in com.hazelcast.jet.pipeline
Top-level class for Jet custom source builders.
SourceBuilder.Batch<T> - Class in com.hazelcast.jet.pipeline
SourceBuilder.FaultTolerant<B,S> - Class in com.hazelcast.jet.pipeline
Represents a step in building a custom source where you add a SourceBuilder.FaultTolerant.restoreSnapshotFn(com.hazelcast.jet.function.BiConsumerEx<? super C, ? super java.util.List<S>>) after adding a createSnapshotFn.
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
Accessor for getting a textual description of source reference (Object returned by JsonLocation.getSourceRef()), as included in description returned by JsonLocation.toString().
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.
SpecVersion - Class in com.hazelcast.org.snakeyaml.engine.v1.common
 
SpecVersion(int, int) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.common.SpecVersion
 
SPIAwareMemberGroupFactory - Class in com.hazelcast.partition.membergroup
SPIAwareMemberGroupFactory is responsible for providing custom MemberGroups implemented by the user in DiscoveryStrategy.getPartitionGroupStrategy() to the PartitionStateManager.
SPIAwareMemberGroupFactory(DiscoveryService) - Constructor for class com.hazelcast.partition.membergroup.SPIAwareMemberGroupFactory
 
spilloverCount() - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
Method mostly needed by unit tests; calculates number of entries in shared spillover area
SplitBrainHandlerService - Interface in com.hazelcast.spi
An interface that can be implemented by SPI services that want to be able to resolve a split-brain.
SplitBrainMergePolicy<V,T extends MergingValue<V>> - Interface in com.hazelcast.spi.merge
Policy for merging data structure values after a split-brain has been healed.
SplitBrainMergePolicyProvider - Class in com.hazelcast.spi.merge
A provider for SplitBrainMergePolicy instances.
SplitBrainMergePolicyProvider(NodeEngine) - Constructor for class com.hazelcast.spi.merge.SplitBrainMergePolicyProvider
Constructs a new provider for SplitBrainMergePolicy classes.
SplitBrainMergeTypeProvider<T extends MergingValue> - Interface in com.hazelcast.spi.merge
Returns a class with the provided merge value types.
SplitBrainMergeTypes - Class in com.hazelcast.spi.merge
Collection of interfaces which define the provided merge types for each data structure.
SplitBrainMergeTypes() - Constructor for class com.hazelcast.spi.merge.SplitBrainMergeTypes
 
SplitBrainMergeTypes.AtomicLongMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of IAtomicLong.
SplitBrainMergeTypes.AtomicReferenceMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of IAtomicReference.
SplitBrainMergeTypes.CacheMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of ICache.
SplitBrainMergeTypes.CardinalityEstimatorMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of CardinalityEstimator.
SplitBrainMergeTypes.CollectionMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of collections (ISet and IList).
SplitBrainMergeTypes.MapMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of IMap.
SplitBrainMergeTypes.MultiMapMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of MultiMap.
SplitBrainMergeTypes.QueueMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of IQueue.
SplitBrainMergeTypes.ReplicatedMapMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of ReplicatedMap.
SplitBrainMergeTypes.RingbufferMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of Ringbuffer.
SplitBrainMergeTypes.ScheduledExecutorMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of IScheduledExecutorService.
splitByComma(String, boolean) - Static method in class com.hazelcast.util.StringUtil
Splits String value with comma "," used as a separator.
sql - Variable in class com.hazelcast.config.PredicateConfig
 
SqlPredicate - Class in com.hazelcast.query
This class contains methods related to conversion of sql query to predicate.
SqlPredicate(String) - Constructor for class com.hazelcast.query.SqlPredicate
 
SqlPredicate() - Constructor for class com.hazelcast.query.SqlPredicate
 
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
Factory class for creating SSLContext
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(Endpoint) - 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.
StaleTaskException - Exception in com.hazelcast.scheduledexecutor
Exception thrown by the IScheduledFuture during any operation on a stale (=previously destroyed) task.
StaleTaskException(String) - Constructor for exception com.hazelcast.scheduledexecutor.StaleTaskException
 
StaleTaskIdException - Exception in com.hazelcast.durableexecutor
An RuntimeException that is thrown when retrieving the result of a task via DurableExecutorService if the result of the task is overwritten.
StaleTaskIdException(String) - Constructor for exception com.hazelcast.durableexecutor.StaleTaskIdException
 
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.v1.constructor
Construct standard Java classes
StandardConstructor(LoadSettings) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.constructor.StandardConstructor
 
StandardConstructor.ConstructOptionalClass - Class in com.hazelcast.org.snakeyaml.engine.v1.constructor
 
StandardConstructor.ConstructUndefined - Class in com.hazelcast.org.snakeyaml.engine.v1.constructor
 
StandardConstructor.ConstructUuidClass - Class in com.hazelcast.org.snakeyaml.engine.v1.constructor
 
StandardConstructor.ConstructYamlBinary - Class in com.hazelcast.org.snakeyaml.engine.v1.constructor
 
StandardConstructor.ConstructYamlBool - Class in com.hazelcast.org.snakeyaml.engine.v1.constructor
 
StandardConstructor.ConstructYamlFloat - Class in com.hazelcast.org.snakeyaml.engine.v1.constructor
 
StandardConstructor.ConstructYamlInt - Class in com.hazelcast.org.snakeyaml.engine.v1.constructor
 
StandardConstructor.ConstructYamlMap - Class in com.hazelcast.org.snakeyaml.engine.v1.constructor
 
StandardConstructor.ConstructYamlNull - Class in com.hazelcast.org.snakeyaml.engine.v1.constructor
 
StandardConstructor.ConstructYamlOmap - Class in com.hazelcast.org.snakeyaml.engine.v1.constructor
 
StandardConstructor.ConstructYamlSeq - Class in com.hazelcast.org.snakeyaml.engine.v1.constructor
 
StandardConstructor.ConstructYamlSet - Class in com.hazelcast.org.snakeyaml.engine.v1.constructor
 
StandardConstructor.ConstructYamlStr - Class in com.hazelcast.org.snakeyaml.engine.v1.constructor
 
StandardLoggerFactory - Class in com.hazelcast.logging
 
StandardLoggerFactory() - Constructor for class com.hazelcast.logging.StandardLoggerFactory
 
StandardRepresenter - Class in com.hazelcast.org.snakeyaml.engine.v1.representer
Represent standard Java classes
StandardRepresenter(DumpSettings) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.representer.StandardRepresenter
 
StandardRepresenter.RepresentArray - Class in com.hazelcast.org.snakeyaml.engine.v1.representer
 
StandardRepresenter.RepresentBoolean - Class in com.hazelcast.org.snakeyaml.engine.v1.representer
 
StandardRepresenter.RepresentByteArray - Class in com.hazelcast.org.snakeyaml.engine.v1.representer
 
StandardRepresenter.RepresentEnum - Class in com.hazelcast.org.snakeyaml.engine.v1.representer
 
StandardRepresenter.RepresentIterator - Class in com.hazelcast.org.snakeyaml.engine.v1.representer
 
StandardRepresenter.RepresentList - Class in com.hazelcast.org.snakeyaml.engine.v1.representer
 
StandardRepresenter.RepresentMap - Class in com.hazelcast.org.snakeyaml.engine.v1.representer
 
StandardRepresenter.RepresentNull - Class in com.hazelcast.org.snakeyaml.engine.v1.representer
 
StandardRepresenter.RepresentNumber - Class in com.hazelcast.org.snakeyaml.engine.v1.representer
 
StandardRepresenter.RepresentOptional - Class in com.hazelcast.org.snakeyaml.engine.v1.representer
 
StandardRepresenter.RepresentPrimitiveArray - Class in com.hazelcast.org.snakeyaml.engine.v1.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.v1.representer
 
StandardRepresenter.RepresentString - Class in com.hazelcast.org.snakeyaml.engine.v1.representer
 
StandardRepresenter.RepresentUuid - Class in com.hazelcast.org.snakeyaml.engine.v1.representer
 
start() - Method in class com.hazelcast.console.ConsoleApp
 
start() - Method in class com.hazelcast.jet.datamodel.WindowResult
Returns the starting timestamp of the window.
start() - Method in interface com.hazelcast.nio.NetworkingService
Starts the service, initializes its endpoints, starts threads, etc.
start() - Method in class com.hazelcast.nio.tcp.TcpIpAcceptor
 
start() - Method in class com.hazelcast.nio.tcp.TcpIpNetworkingService
 
start() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
 
start() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategy
The start method is used to initialize internal state and perform any kind of startup procedure like multicast socket creation.
start() - Method in interface com.hazelcast.spi.discovery.integration.DiscoveryService
The start method is called on system startup to implement simple lifecycle management.
start() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategy
 
start() - Method in class com.hazelcast.spi.Offload
Starts the actual offloading.
StartServer - Class in com.hazelcast.core.server
Starts a Hazelcast server.
StartServer - Class in com.hazelcast.jet.server
Main class that starts a Hazelcast Jet instance.
STAT_NOT_AVAILABLE - Static variable in interface com.hazelcast.monitor.LocalInstanceStats
Default value for unavailable statistics.
stateChanged(LifecycleEvent) - Method in interface com.hazelcast.core.LifecycleListener
Called when instance's state changes.
StatefulTask<K,V> - Interface in com.hazelcast.scheduledexecutor
An interface to provide means for saving & loading state for Runnable and Callable tasks scheduled with an IScheduledExecutorService.
StateMachine<T extends Enum<T>> - Class in com.hazelcast.util
Simple state machine using an Enum as possible states.
StateMachine(T) - Constructor for class com.hazelcast.util.StateMachine
 
StatisticsAwareService<T extends LocalInstanceStats> - Interface in com.hazelcast.spi
A service implementating this interface provides local instance statistics.
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.console.ConsoleApp
 
stop() - Method in interface com.hazelcast.nio.NetworkingService
Stops the service, releases its resources, stops threads, etc.
stop() - Method in class com.hazelcast.nio.tcp.TcpIpNetworkingService
 
stop(String, String) - Method in interface com.hazelcast.wan.WanReplicationService
Stops WAN replication for the given wanReplicationName and targetGroupName on this hazelcast instance.
StorageTypeAwareCacheMergePolicy - Interface in com.hazelcast.cache
Marker interface for indicating that key and value wrapped by CacheEntryView will be not converted to their original types.
store(K, V) - Method in interface com.hazelcast.core.MapStore
Stores the key-value pair.
store(K, V) - Method in class com.hazelcast.core.MapStoreAdapter
Stores the key-value pair.
store(Long, T) - Method in interface com.hazelcast.core.QueueStore
Stores the key-value pair.
store(long, T) - Method in interface com.hazelcast.core.RingbufferStore
Stores one item with it's corresponding sequence.
storeAll(Map<K, V>) - Method in interface com.hazelcast.core.MapStore
Stores multiple entries.
storeAll(Map<K, V>) - Method in class com.hazelcast.core.MapStoreAdapter
Stores multiple entries.
storeAll(Map<Long, T>) - Method in interface com.hazelcast.core.QueueStore
Stores multiple entries.
storeAll(long, T[]) - Method in interface com.hazelcast.core.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.v1.nodes.Tag
 
stream(String, FunctionEx<? super Processor.Context, ? extends C>) - Static method in class com.hazelcast.jet.pipeline.SourceBuilder
Returns a fluent-API builder with which you can create an unbounded stream source for a Jet pipeline.
streamCacheP(String, JournalInitialPosition, EventTimePolicy<? super Map.Entry<K, V>>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
Returns a supplier of processors for Sources.cacheJournal(String, JournalInitialPosition).
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.v1.api
Writer with the same methods as in Writer but without throwing IOExceptions
StreamEndEvent - Class in com.hazelcast.org.snakeyaml.engine.v1.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.v1.events.StreamEndEvent
 
StreamEndEvent() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.events.StreamEndEvent
 
StreamEndToken - Class in com.hazelcast.org.snakeyaml.engine.v1.tokens
 
StreamEndToken(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.tokens.StreamEndToken
 
streamFilesP(String, Charset, String, boolean, BiFunctionEx<? super String, ? super String, ?>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
Returns a supplier of processors for Sources.filesBuilder(java.lang.String).
streamFromProcessor(String, ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.pipeline.Sources
Returns an unbounded (event stream) source constructed directly from the given Core API processor meta-supplier.
streamFromProcessorWithWatermarks(String, Function<EventTimePolicy<? super T>, ProcessorMetaSupplier>, boolean) - 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 Connection, ? extends Session>, FunctionEx<? super Session, ? extends MessageConsumer>, ConsumerEx<? super Session>, FunctionEx<? super Message, ? extends T>, EventTimePolicy<? super T>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
streamJmsTopicP(SupplierEx<? extends Connection>, FunctionEx<? super Connection, ? extends Session>, FunctionEx<? super Session, ? extends MessageConsumer>, ConsumerEx<? super Session>, FunctionEx<? super Message, ? extends T>, EventTimePolicy<? super T>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
streamKafkaP(Properties, FunctionEx<? super ConsumerRecord<K, V>, ? extends T>, EventTimePolicy<? super T>, String...) - Static method in class com.hazelcast.jet.kafka.KafkaProcessors
Returns a supplier of processors for KafkaSources.kafka(Properties, FunctionEx, String...).
streamMapP(String, JournalInitialPosition, EventTimePolicy<? super Map.Entry<K, V>>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
Returns a supplier of processors for Sources.mapJournal(String, JournalInitialPosition) )}.
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
StreamReader - Class in com.hazelcast.org.snakeyaml.engine.v1.scanner
Reader: checks if code points are in allowed range.
StreamReader(Reader, LoadSettings) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.scanner.StreamReader
 
StreamReader(String, LoadSettings) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.scanner.StreamReader
 
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
Returns a supplier of processors for Sources.socket(String, int, Charset).
StreamSource<T> - Interface in com.hazelcast.jet.pipeline
An infinite source of data for a Jet pipeline.
StreamSourceStage<T> - Interface in com.hazelcast.jet.pipeline
A source stage in a distributed computation pipeline that will observe an unbounded amount of data (i.e., an event stream).
streamStage() - Method in interface com.hazelcast.jet.pipeline.StageWithWindow
Returns the pipeline stage associated with this object.
StreamStage<T> - Interface in com.hazelcast.jet.pipeline
A stage in a distributed computation pipeline that will observe an unbounded amount of data (i.e., an event stream).
StreamStageWithKey<T,K> - Interface in com.hazelcast.jet.pipeline
An intermediate step while constructing a pieline transform that involves a grouping key, such as windowed group-and-aggregate.
StreamStartEvent - Class in com.hazelcast.org.snakeyaml.engine.v1.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.v1.events.StreamStartEvent
 
StreamStartEvent() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.events.StreamStartEvent
 
StreamStartToken - Class in com.hazelcast.org.snakeyaml.engine.v1.tokens
 
StreamStartToken(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.tokens.StreamStartToken
 
StringAndPartitionAwarePartitioningStrategy - Class in com.hazelcast.partition.strategy
 
StringPartitioningStrategy - Class in com.hazelcast.partition.strategy
 
StringPartitioningStrategy() - Constructor for class com.hazelcast.partition.strategy.StringPartitioningStrategy
 
stringToBytes(String) - Static method in class com.hazelcast.util.StringUtil
Creates a byte array from a string.
StringUtil - Class in com.hazelcast.aws.utility
 
StringUtil - Class in com.hazelcast.util
Utility class for Strings.
StripedExecutor - Class in com.hazelcast.util.executor
The StripedExecutor internally uses a stripe of queues and each queue has its own private worker-thread.
StripedExecutor(ILogger, String, int, int) - Constructor for class com.hazelcast.util.executor.StripedExecutor
 
StripedExecutor(ILogger, String, int, int, boolean) - Constructor for class com.hazelcast.util.executor.StripedExecutor
 
StripedRunnable - Interface in com.hazelcast.util.executor
Striped Runnable is used in StripedExecutor.
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, String, String, File, List<String>) - Method in class com.hazelcast.jet.server.JetCommandLine
 
submit() - Method in interface com.hazelcast.mapreduce.MappingJob
Deprecated.
Submits the task to Hazelcast and executes the defined mapper and reducer on all cluster nodes.
submit(Collator<Map.Entry<KeyIn, List<ValueIn>>, ValueOut>) - Method in interface com.hazelcast.mapreduce.MappingJob
Deprecated.
Submits the task to Hazelcast, executes the defined mapper and reducer on all cluster nodes, and executes the collator before returning the final result.
submit() - Method in interface com.hazelcast.mapreduce.ReducingJob
Deprecated.
Submits the task to Hazelcast and executes the defined mapper and reducer on all cluster nodes
submit(Collator<Map.Entry<KeyIn, List<ValueIn>>, ValueOut>) - Method in interface com.hazelcast.mapreduce.ReducingJob
Deprecated.
Submits the task to Hazelcast and executes the defined mapper and reducer on all cluster nodes and executes the collator before returning the final result.
submit() - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
Deprecated.
Submits the task to Hazelcast and executes the defined mapper and reducer on all cluster nodes.
submit(Collator<Map.Entry<KeyIn, ValueIn>, ValueOut>) - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
Deprecated.
Submits the task to Hazelcast and executes the defined mapper and reducer on all cluster nodes and executes the collator before returning the final result.
submit(String, Runnable) - Method in interface com.hazelcast.spi.ExecutionService
 
submit(String, Callable<T>) - Method in interface com.hazelcast.spi.ExecutionService
 
submit(Callable<T>) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
 
submit(Runnable, T) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
 
submit(Runnable) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
 
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, ExecutionCallback) - Method in interface com.hazelcast.core.IMap
Applies the user defined EntryProcessor to the entry mapped by the key with specified ExecutionCallback to listen event status and returns immediately.
submitToKey(K, EntryProcessor) - Method in interface com.hazelcast.core.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.
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.
subtractAndGet(long, VectorClock) - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
Subtracts the given value from the current value.
subtractAndGet(long) - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
 
subtraction(String[], String[]) - Static method in class com.hazelcast.util.StringUtil
Returns subtraction between given String arrays.
sumHash(int, int) - Static method in class com.hazelcast.wan.merkletree.MerkleTreeUtil
Sums the hash of the left and the right children
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.
Supplier<KeyIn,ValueIn,ValueOut> - Class in com.hazelcast.mapreduce.aggregation
Deprecated.
Use fast-aggregations Aggregator
Supplier() - Constructor for class com.hazelcast.mapreduce.aggregation.Supplier
Deprecated.
 
Supplier<T> - Interface in com.hazelcast.util.function
Represents a supplier of results.
SupplierEx<T> - Interface in com.hazelcast.jet.function
Serializable variant of java.util.function.Supplier which declares checked exception.
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.
supportedProtocol - Variable in class com.hazelcast.nio.tcp.SingleProtocolDecoder
 
supports(String) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Checks whether the given XML tag is supported.
supportsNativeTimestamps() - Method in interface com.hazelcast.jet.pipeline.StreamSource
Returns true if this source supports native timestamps.
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, 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
Contains configuration for symmetric encryption
SymmetricEncryptionConfig() - Constructor for class com.hazelcast.config.SymmetricEncryptionConfig
 
syncAllMaps(String, String) - Method in interface com.hazelcast.wan.WanReplicationService
Initiate wan sync for all maps.
syncMap(String, String, String) - Method in interface com.hazelcast.wan.WanReplicationService
Initiate wan sync for a specific map.
SYS_LF - Static variable in class com.hazelcast.com.fasterxml.jackson.core.util.DefaultIndenter
 
SYSTEM_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
Name of the system executor.
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.
systemLogger - Variable in class com.hazelcast.instance.DefaultNodeExtension
 

T

Tag<T> - Class in com.hazelcast.jet.datamodel
A tag object useful as a key in heterogeneous maps.
tag(int) - Static method in class com.hazelcast.jet.datamodel.Tag
Returns a tag object associated with the specified index.
Tag - Class in com.hazelcast.org.snakeyaml.engine.v1.nodes
 
Tag(String) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.nodes.Tag
 
Tag(Class<? extends Object>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.nodes.Tag
Create a global tag to dump the fully qualified class name
tag0() - Static method in class com.hazelcast.jet.datamodel.Tag
Returns the tag constant Tag.TAG_0.
tag0() - Method in class com.hazelcast.jet.pipeline.AggregateBuilder
Returns the tag corresponding to the pipeline stage this builder was obtained from.
tag0() - Method in class com.hazelcast.jet.pipeline.AggregateBuilder1
Returns the tag corresponding to the pipeline stage this builder was obtained from.
tag0() - Method in class com.hazelcast.jet.pipeline.GroupAggregateBuilder
Returns the tag corresponding to the pipeline stage this builder was obtained from.
tag0() - Method in class com.hazelcast.jet.pipeline.GroupAggregateBuilder1
Returns the tag corresponding to the pipeline stage this builder was obtained from.
tag0() - Method in class com.hazelcast.jet.pipeline.WindowAggregateBuilder
Returns the tag corresponding to the pipeline stage this builder was obtained from.
tag0() - Method in class com.hazelcast.jet.pipeline.WindowAggregateBuilder1
Returns the tag corresponding to the pipeline stage this builder was obtained from.
tag0() - Method in class com.hazelcast.jet.pipeline.WindowGroupAggregateBuilder
Returns the tag corresponding to the pipeline stage this builder was obtained from.
tag0() - Method in class com.hazelcast.jet.pipeline.WindowGroupAggregateBuilder1
Returns the tag corresponding to the pipeline stage this builder was obtained from.
tag1() - Static method in class com.hazelcast.jet.datamodel.Tag
Returns the tag constant Tag.TAG_1.
tag2() - Static method in class com.hazelcast.jet.datamodel.Tag
Returns the tag constant Tag.TAG_2.
TAG_DIRECTIVE - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.tokens.DirectiveToken
 
tagConstructors - Variable in class com.hazelcast.org.snakeyaml.engine.v1.constructor.BaseConstructor
It maps the (explicit or implicit) tag to the Construct implementation.
tagFor(AliasedDiscoveryConfig) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Returns an XML tag (e.g.
TagToken - Class in com.hazelcast.org.snakeyaml.engine.v1.tokens
 
TagToken(TagTuple, Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.tokens.TagToken
 
TagTuple - Class in com.hazelcast.org.snakeyaml.engine.v1.tokens
 
TagTuple(String, String) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.tokens.TagTuple
 
tagValueEquals(String, String) - Static method in class com.hazelcast.jet.core.metrics.MeasurementPredicates
Matches a Measurement which contains the specified tag and the tag has the specified value.
tagValueMatches(String, String) - Static method in class com.hazelcast.jet.core.metrics.MeasurementPredicates
Matches a Measurement which has this exact tag with a value matching the provided regular expression.
tail() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
Accessor for getting a "sub-pointer", instance where current segment has been removed and pointer includes rest of segments.
tailSequence() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Returns the sequence of the tail.
take() - Method in interface com.hazelcast.core.BaseQueue
Retrieves and removes the head of this queue, waiting if necessary until an element becomes available.
take() - Method in interface com.hazelcast.core.IQueue
Retrieves and removes the head of this queue, waiting if necessary until an element becomes available.
take() - Method in interface com.hazelcast.core.TransactionalQueue
Retrieves and removes the head of this queue, waiting if necessary until an element becomes available.
takeWhile(Predicate<? super T>) - Method in interface com.hazelcast.jet.Traverser
Returns a traverser that will emit a prefix of the original traverser, up to the item for which the predicate fails (exclusive).
target - Variable in class com.hazelcast.spi.InvocationBuilder
 
TargetDisconnectedException - Exception in com.hazelcast.spi.exception
Thrown when a client invocation is failed because related target is disconnected and whether the invocation is run or not, is indeterminate
TargetDisconnectedException(String) - Constructor for exception com.hazelcast.spi.exception.TargetDisconnectedException
 
TargetDisconnectedException(String, Throwable) - Constructor for exception com.hazelcast.spi.exception.TargetDisconnectedException
 
TargetNotMemberException - Exception in com.hazelcast.spi.exception
A RetryableHazelcastException that indicates operation is send to a machine that isn't member of the cluster.
TargetNotMemberException(String) - Constructor for exception com.hazelcast.spi.exception.TargetNotMemberException
 
TargetNotMemberException(Object, int, String, String) - Constructor for exception com.hazelcast.spi.exception.TargetNotMemberException
 
TargetNotReplicaException - Exception in com.hazelcast.crdt
Exception that indicates that the receiver of a CRDT operation is not a CRDT replica.
TargetNotReplicaException(String) - Constructor for exception com.hazelcast.crdt.TargetNotReplicaException
 
TASK_SCHEDULER_REMOVE_ON_CANCEL - Static variable in class com.hazelcast.spi.properties.GroupProperty
This is a Java 6 specific property.
TaskScheduler - Interface in com.hazelcast.spi
ExecutorService can schedule a command to run after a given delay or execute periodically.
TaskUtils - Class in com.hazelcast.scheduledexecutor
A helper class with utilities to act upon Runnable and/or Callable tasks.
TCP_JOIN_PORT_TRY_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
The number of incremental ports, starting with port number defined in network configuration, that will be used to connect to a host which is defined without a port in the TCP-IP member list while a node is searching for a cluster.
TcpIpAcceptor - Class in com.hazelcast.nio.tcp
Contains the logic for accepting TcpIpConnections.
TcpIpConfig - Class in com.hazelcast.config
Contains the configuration for the Tcp/Ip join mechanism.
TcpIpConfig() - Constructor for class com.hazelcast.config.TcpIpConfig
 
TcpIpConnection - Class in com.hazelcast.nio.tcp
The Tcp/Ip implementation of the Connection.
TcpIpConnection(TcpIpEndpointManager, ConnectionLifecycleListener, int, Channel) - Constructor for class com.hazelcast.nio.tcp.TcpIpConnection
 
TcpIpConnectionChannelErrorHandler - Class in com.hazelcast.nio.tcp
 
TcpIpConnectionChannelErrorHandler(ILogger) - Constructor for class com.hazelcast.nio.tcp.TcpIpConnectionChannelErrorHandler
 
TcpIpConnectionErrorHandler - Class in com.hazelcast.nio.tcp
 
TcpIpEndpointManager - Class in com.hazelcast.nio.tcp
 
TcpIpEndpointManager.EndpointConnectionLifecycleListener - Class in com.hazelcast.nio.tcp
 
TcpIpNetworkingService - Class in com.hazelcast.nio.tcp
 
TcpIpNetworkingService(Config, IOService, ServerSocketRegistry, LoggingService, MetricsRegistry, Networking, ChannelInitializerProvider) - Constructor for class com.hazelcast.nio.tcp.TcpIpNetworkingService
 
TcpIpNetworkingService(Config, IOService, ServerSocketRegistry, LoggingService, MetricsRegistry, Networking, ChannelInitializerProvider, HazelcastProperties) - Constructor for class com.hazelcast.nio.tcp.TcpIpNetworkingService
 
TenantControl - Interface in com.hazelcast.spi.tenantcontrol
Hooks for multi-tenancy for application servers Hazelcast uses separate threads to invoke operations this interface acts a hook to establish a thread-local tenant context so that operation invocations into application servers are handled correctly This is used by application servers to establish thread context for class loading, CDI, EJB and JPA invocations
TenantControlFactory - Interface in com.hazelcast.spi.tenantcontrol
A TenantControlFactory supplies TenantControl objects when Hazelcast service attaches the tenant control to a distributed object.
terminate() - Method in interface com.hazelcast.core.LifecycleService
Terminate HazelcastInstance ungracefully.
terminate() - Method in class com.hazelcast.instance.LifecycleServiceImpl
 
terminate() - Method in class com.hazelcast.instance.TerminatedLifecycleService
 
terminateAll() - Static method in class com.hazelcast.instance.HazelcastInstanceFactory
 
TerminatedLifecycleService - Class in com.hazelcast.instance
 
TerminatedLifecycleService() - Constructor for class com.hazelcast.instance.TerminatedLifecycleService
 
tertiaryCount() - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
Method mostly needed by unit tests; calculates number of entries in tertiary buckets
test(T, U) - Method in interface com.hazelcast.jet.function.BiPredicateEx
 
test(T) - Method in interface com.hazelcast.jet.function.PredicateEx
 
test(T, U, V) - Method in interface com.hazelcast.jet.function.TriPredicate
Evaluates this predicate with the given arguments.
test(DiscoveryNode) - Method in interface com.hazelcast.spi.discovery.NodeFilter
Accepts or denies a DiscoveryNode based on the implemented rules.
test(T) - Method in interface com.hazelcast.util.function.Predicate
Evaluates this predicate on the given argument.
testEx(T, U) - Method in interface com.hazelcast.jet.function.BiPredicateEx
Exception-declaring version of BiPredicate.test(T, U).
testEx(T) - Method in interface com.hazelcast.jet.function.PredicateEx
Exception-declaring version of Predicate.test(T).
testEx(T, U, V) - Method in interface com.hazelcast.jet.function.TriPredicate
Exception-declaring version of TriPredicate.test(T, U, V).
TestInbox - Class in com.hazelcast.jet.core.test
Inbox implementation suitable to be used in tests.
TestInbox() - Constructor for class com.hazelcast.jet.core.test.TestInbox
 
TestOutbox - Class in com.hazelcast.jet.core.test
Outbox implementation suitable to be used in tests.
TestOutbox(int...) - Constructor for class com.hazelcast.jet.core.test.TestOutbox
 
TestOutbox(int[], int) - Constructor for class com.hazelcast.jet.core.test.TestOutbox
 
TestProcessorContext - Class in com.hazelcast.jet.core.test
Processor.Context implementation suitable to be used in tests.
TestProcessorContext() - Constructor for class com.hazelcast.jet.core.test.TestProcessorContext
Constructor with default values.
TestProcessorMetaSupplierContext - Class in com.hazelcast.jet.core.test
ProcessorMetaSupplier.Context implementation suitable to be used in tests.
TestProcessorMetaSupplierContext() - Constructor for class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
 
TestProcessorSupplierContext - Class in com.hazelcast.jet.core.test
ProcessorSupplier.Context implementation suitable to be used in tests.
TestProcessorSupplierContext() - Constructor for class com.hazelcast.jet.core.test.TestProcessorSupplierContext
 
TestSources - Class in com.hazelcast.jet.pipeline.test
Contains factory methods for various mock sources which can be used for pipeline testing and development.
TestSupport - Class in com.hazelcast.jet.core.test
A utility to test processors.
TestSupport.TestMode - Class in com.hazelcast.jet.core.test
Describes the current test mode.
TEXT_ENCODER - Static variable in class com.hazelcast.nio.ascii.TextEncoder
 
TEXT_PARSERS - Static variable in class com.hazelcast.nio.ascii.MemcacheTextDecoder
 
TEXT_PARSERS - Static variable in class com.hazelcast.nio.ascii.RestApiTextDecoder
 
TextBuffer - Class in com.hazelcast.com.fasterxml.jackson.core.util
TextBuffer is a class similar to StringBuffer, with following differences: TextBuffer uses segments character arrays, to avoid having to do additional array copies when array is not big enough.
TextBuffer(BufferRecycler) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
 
TextChannelInitializer - Class in com.hazelcast.nio.ascii
 
TextChannelInitializer(IOService, EndpointConfig, boolean) - Constructor for class com.hazelcast.nio.ascii.TextChannelInitializer
 
textCommandService - Variable in class com.hazelcast.instance.Node
 
TextDecoder - Class in com.hazelcast.nio.ascii
 
TextDecoder(TcpIpConnection, TextEncoder, TextProtocolFilter, TextParsers, boolean) - Constructor for class com.hazelcast.nio.ascii.TextDecoder
 
TextEncoder - Class in com.hazelcast.nio.ascii
 
TextEncoder(TcpIpConnection) - Constructor for class com.hazelcast.nio.ascii.TextEncoder
 
TextHandshakeDecoder - Class in com.hazelcast.nio.tcp
 
TextHandshakeDecoder(ProtocolType, InboundHandler) - Constructor for class com.hazelcast.nio.tcp.TextHandshakeDecoder
 
TextParsers - Class in com.hazelcast.nio.ascii
 
TextParsers(Map<String, CommandParser>) - Constructor for class com.hazelcast.nio.ascii.TextParsers
 
thenComparing(Comparator<? super T>) - Method in interface com.hazelcast.jet.function.ComparatorEx
thenComparing(ComparatorEx<? super T>) - Method in interface com.hazelcast.jet.function.ComparatorEx
thenComparing(Function<? super T, ? extends U>, Comparator<? super U>) - Method in interface com.hazelcast.jet.function.ComparatorEx
thenComparing(FunctionEx<? super T, ? extends U>, ComparatorEx<? super U>) - Method in interface com.hazelcast.jet.function.ComparatorEx
thenComparing(Function<? super T, ? extends U>) - Method in interface com.hazelcast.jet.function.ComparatorEx
thenComparing(FunctionEx<? super T, ? extends U>) - Method in interface com.hazelcast.jet.function.ComparatorEx
thenComparingDouble(ToDoubleFunction<? super T>) - Method in interface com.hazelcast.jet.function.ComparatorEx
thenComparingDouble(ToDoubleFunctionEx<? super T>) - Method in interface com.hazelcast.jet.function.ComparatorEx
thenComparingInt(ToIntFunction<? super T>) - Method in interface com.hazelcast.jet.function.ComparatorEx
thenComparingInt(ToIntFunctionEx<? super T>) - Method in interface com.hazelcast.jet.function.ComparatorEx
thenComparingLong(ToLongFunction<? super T>) - Method in interface com.hazelcast.jet.function.ComparatorEx
thenComparingLong(ToLongFunctionEx<? super T>) - Method in interface com.hazelcast.jet.function.ComparatorEx
THREAD_ID_GENERATOR - Static variable in class com.hazelcast.util.executor.StripedExecutor
 
threadId - Variable in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
ThreadUtil - Class in com.hazelcast.util
Utility class to manipulate and query thread ID.
throwInternal() - Static method in class com.hazelcast.com.fasterxml.jackson.core.util.VersionUtil
 
throwNotActiveException() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
TIME - Static variable in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
 
TimedExpiryPolicyFactoryConfig() - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
TimedExpiryPolicyFactoryConfig(CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType, CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
timeInMsOrOneIfResultIsZero(long, TimeUnit) - Static method in class com.hazelcast.util.TimeUtil
Convert time to milliseconds based on the given time unit.
timeInMsOrTimeIfNullUnit(long, TimeUnit) - Static method in class com.hazelcast.util.TimeUtil
Convert time to milliseconds based on the given time unit.
TimeoutRunnable - Interface in com.hazelcast.util.executor
Interface for runnable with timeout value
timerFn(ConsumerEx<? super S>) - Method in class com.hazelcast.jet.pipeline.test.AssertionSinkBuilder
Sets the function that will be called periodically.
timestamp() - Method in class com.hazelcast.jet.core.Watermark
Returns the timestamp of this watermark item.
timestamp() - Method in class com.hazelcast.jet.datamodel.TimestampedItem
Returns the timestamp.
timestamp() - Method in class com.hazelcast.jet.pipeline.test.SimpleEvent
Timestamp of the event in milliseconds
TimestampedItem<T> - Class in com.hazelcast.jet.datamodel
Mutable wrapper around an item that adds a timestamp.
TimestampedItem(long, T) - Constructor for class com.hazelcast.jet.datamodel.TimestampedItem
Creates a new timestamped item.
timestampedStream(String, FunctionEx<? super Processor.Context, ? extends C>) - Static method in class com.hazelcast.jet.pipeline.SourceBuilder
Returns a fluent-API builder with which you can create an unbounded stream source for a Jet pipeline.
timestampFn() - Method in class com.hazelcast.jet.core.EventTimePolicy
Returns the function that extracts the timestamp from the event.
TimestampKind - Enum in com.hazelcast.jet.core
Enumerates the two possible kinds of timestamp: event timestamp and frame timestamp.
timeToString(long) - Static method in class com.hazelcast.util.StringUtil
Returns a String representation of the time.
timeToStringFriendly(long) - Static method in class com.hazelcast.util.StringUtil
Returns a String representation of the time.
TimeUtil - Class in com.hazelcast.util
Utility class for Time & unit conversions
to(Vertex) - Method in class com.hazelcast.jet.core.Edge
Sets the destination vertex of this edge, with ordinal 0.
to(Vertex, int) - Method in class com.hazelcast.jet.core.Edge
Sets the destination vertex and ordinal of this edge.
toAggregator(AggregateOperation1<? super T, A, ? extends R>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Adapts this aggregate operation to be used for IMap.aggregate(Aggregator) calls.
toArray() - Method in class com.hazelcast.util.collection.IntHashSet
 
toArray(T[]) - Method in class com.hazelcast.util.collection.IntHashSet
 
toArray() - Method in class com.hazelcast.util.collection.LongHashSet
toArray(T[]) - Method in class com.hazelcast.util.collection.LongHashSet
toArray() - Method in class com.hazelcast.util.collection.OAHashSet
 
toArray(T[]) - Method in class com.hazelcast.util.collection.OAHashSet
 
toByteArray() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.ByteArrayBuilder
Method called when results are finalized and we can get the full aggregated result buffer to return to the caller
toByteArray(InputStream) - Static method in class com.hazelcast.nio.IOUtil
 
toByteArray() - Method in interface com.hazelcast.nio.ObjectDataOutput
 
toByteArray(int) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
toByteArray() - Method in interface com.hazelcast.nio.serialization.Data
Returns byte array representation of internal binary format.
toBytes(long) - Method in enum com.hazelcast.memory.MemoryUnit
 
toCanonical() - Method in class com.hazelcast.com.fasterxml.jackson.core.type.ResolvedType
Method that can be used to serialize type into form from which it can be fully deserialized from at a later point (using TypeFactory from mapper package).
toCollection(SupplierEx<C>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that accumulates the items into a Collection.
toCollector() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation1
toCollector(AggregateOperation1<? super T, A, ? extends R>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Adapts this aggregate operation to a collector which can be passed to Stream.collect(Collector).
toCompletableFuture(ICompletableFuture<T>) - Static method in class com.hazelcast.jet.Util
Wraps Hazelcast IMDG's ICompletableFuture into Java's standard CompletableFuture.
toDag() - Method in interface com.hazelcast.jet.pipeline.Pipeline
Transforms the pipeline into a Jet DAG, which can be submitted for execution to a Jet instance.
toData(Object) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
toData(Object) - Method in interface com.hazelcast.spi.NodeEngine
Serializes an object to a Data.
toData(Object) - Method in interface com.hazelcast.spi.serialization.SerializationService
Serializes an object to a Data.
toData(Object, PartitioningStrategy) - Method in interface com.hazelcast.spi.serialization.SerializationService
Serializes an object to a Data.
toDebugString(String, ByteBuffer) - Static method in class com.hazelcast.nio.IOUtil
Creates a debug String for te given ByteBuffer.
toDotString() - Method in class com.hazelcast.jet.core.DAG
Returns a DOT format (graphviz) representation of the DAG.
toDotString(int) - Method in class com.hazelcast.jet.core.DAG
Returns a DOT format (graphviz) representation of the DAG and annotates the vertices using default parallelism with the supplied value.
toDotString() - Method in interface com.hazelcast.jet.pipeline.Pipeline
Returns a DOT format (graphviz) representation of the Pipeline.
ToDoubleFunctionEx<T> - Interface in com.hazelcast.jet.function
Serializable variant of java.util.function.ToDoubleFunction which declares checked exception.
toFileName(String) - Static method in class com.hazelcast.nio.IOUtil
 
toFullString() - Method in class com.hazelcast.com.fasterxml.jackson.core.Version
 
toGigaBytes(long) - Method in enum com.hazelcast.memory.MemoryUnit
 
toIntArray(Collection<Integer>) - Static method in class com.hazelcast.util.CollectionUtil
Converts a Collection to a primitive int[] array.
toIntegerList(int[]) - Static method in class com.hazelcast.util.CollectionUtil
Converts an int array to an Integer List.
ToIntFunctionEx<T> - Interface in com.hazelcast.jet.function
Serializable variant of java.util.function.ToIntFunction which declares checked exception.
toJson(int) - Method in class com.hazelcast.jet.core.DAG
Returns a JSON representation of the DAG.
toJson(Object) - Static method in class com.hazelcast.util.JsonUtil
Returns the JSON representation of the provided value
toJsonObject(Map<String, ?>) - Static method in class com.hazelcast.util.JsonUtil
Transforms the provided map of name/value pairs into a JsonObject.
Token - Class in com.hazelcast.org.snakeyaml.engine.v1.tokens
 
Token(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.tokens.Token
 
Token.ID - Enum in com.hazelcast.org.snakeyaml.engine.v1.tokens
 
TokenFilter - Class in com.hazelcast.com.fasterxml.jackson.core.filter
Strategy class that can be implemented to specify actual inclusion/exclusion criteria for filtering, used by FilteringGeneratorDelegate.
TokenFilter() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
 
TokenFilterContext - Class in com.hazelcast.com.fasterxml.jackson.core.filter
Alternative variant of JsonStreamContext, used when filtering content being read or written (based on TokenFilter).
TokenFilterContext(int, TokenFilterContext, TokenFilter, boolean) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
 
tokenizeVersionString(String) - Static method in class com.hazelcast.util.StringUtil
Tokenizes a version string and returns the tokens with the following grouping: (1) major version, eg "3" (2) minor version, eg "8" (3) patch version prefixed with ".", if exists, otherwise null (eg ".0") (4) patch version, eg "0" (5) 1st -qualifier, if exists (6) -SNAPSHOT qualifier, if exists
toKiloBytes(long) - Method in enum com.hazelcast.memory.MemoryUnit
 
toList() - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that accumulates the items into an ArrayList.
toLongArray(Collection<Long>) - Static method in class com.hazelcast.util.CollectionUtil
Converts a Collection to a primitive long[] array.
ToLongFunctionEx<T> - Interface in com.hazelcast.jet.function
Serializable variant of java.util.function.ToLongFunction which declares checked exception.
toMap(FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends U>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that accumulates the items into a HashMap whose keys and values are the result of applying the provided mapping functions.
toMap(FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends U>, BinaryOperatorEx<U>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that accumulates the items into a HashMap whose keys and values are the result of applying the provided mapping functions.
toMap(FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends U>, BinaryOperatorEx<U>, SupplierEx<M>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that accumulates elements into a user-supplied Map instance.
toMaxSizePolicy() - Method in enum com.hazelcast.config.CacheEvictionConfig.CacheMaxSizePolicy
Deprecated.
 
toMD5String(String) - Static method in class com.hazelcast.util.MD5Util
Converts given string to MD5 hash
toMegaBytes(long) - Method in enum com.hazelcast.memory.MemoryUnit
 
toMetricsPrefixString() - Method in class com.hazelcast.instance.EndpointQualifier
 
toNonCooperative() - Method in class com.hazelcast.jet.pipeline.ContextFactory
Returns a copy of this ContextFactory with the isCooperative flag set to false.
toObject(Object) - Method in interface com.hazelcast.spi.NodeEngine
Deserializes an object.
toObject(Object, Class) - Method in interface com.hazelcast.spi.NodeEngine
Deserializes an object.
toObject(Object) - Method in interface com.hazelcast.spi.serialization.SerializationService
Deserializes an object.
toObject(Object, Class) - Method in interface com.hazelcast.spi.serialization.SerializationService
Deserializes an object.
toObjectIfNeeded(Object) - Method in class com.hazelcast.spi.TransactionalDistributedObject
 
toOpControl(Address) - Method in class com.hazelcast.spi.CallsPerMember
 
TOP_OBSERVED_WM - Static variable in class com.hazelcast.jet.core.metrics.MetricNames
Tracks the highest coalesced watermark observed on all input Edges of a particular Vertex (ie.
TOPIC_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
TopicConfig - Class in com.hazelcast.config
Contains the configuration for a ITopic.
TopicConfig() - Constructor for class com.hazelcast.config.TopicConfig
Creates a TopicConfig.
TopicConfig(String) - Constructor for class com.hazelcast.config.TopicConfig
Creates a TopicConfig with the given name.
TopicConfig(TopicConfig) - Constructor for class com.hazelcast.config.TopicConfig
Creates a TopicConfig by cloning another TopicConfig.
TopicConfigReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
TopicConfigReadOnly(TopicConfig) - Constructor for class com.hazelcast.config.TopicConfigReadOnly
Deprecated.
 
TopicOverloadException - Exception in com.hazelcast.topic
A HazelcastException thrown when a publisher wants to write to a topic, but there is not sufficient storage to deal with the event.
TopicOverloadException(String) - Constructor for exception com.hazelcast.topic.TopicOverloadException
Creates a TopicOverloadException.
TopicOverloadPolicy - Enum in com.hazelcast.topic
A policy to deal with an overloaded topic; so topic where there is no place to store new messages.
TopicPermission - Class in com.hazelcast.security.permission
 
TopicPermission(String, String...) - Constructor for class com.hazelcast.security.permission.TopicPermission
 
topN(int, ComparatorEx<? super T>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that finds the top n items according to the given comparator.
TopologyChangedException - Exception in com.hazelcast.jet.core
Thrown when a topology change causes a job to abort.
TopologyChangedException() - Constructor for exception com.hazelcast.jet.core.TopologyChangedException
Creates the exception
TopologyChangedException(String) - Constructor for exception com.hazelcast.jet.core.TopologyChangedException
Creates the exception with a message.
TopologyChangedException(String, Throwable) - Constructor for exception com.hazelcast.jet.core.TopologyChangedException
Creates the exception with a message and a cause.
TopologyChangedException - Exception in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
TopologyChangedException() - Constructor for exception com.hazelcast.mapreduce.TopologyChangedException
Deprecated.
Creates a new instance of the TopologyChangedException
TopologyChangedException(String) - Constructor for exception com.hazelcast.mapreduce.TopologyChangedException
Deprecated.
Creates a new instance of the TopologyChangedException
topologyChangedStrategy(TopologyChangedStrategy) - Method in interface com.hazelcast.mapreduce.Job
Deprecated.
Defines the strategy to handle topology changes while executing the map reduce job.
topologyChangedStrategy(TopologyChangedStrategy) - Method in interface com.hazelcast.mapreduce.MappingJob
Deprecated.
Defines the strategy to handle topology changes while executing the map reduce job.
topologyChangedStrategy(TopologyChangedStrategy) - Method in interface com.hazelcast.mapreduce.ReducingJob
Deprecated.
Defines the strategy to handle topology changes while executing the map reduce job.
topologyChangedStrategy(TopologyChangedStrategy) - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
Deprecated.
Defines the strategy to handle topology changes while executing the map reduce job.
TopologyChangedStrategy - Enum in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
toPrettyString() - Method in class com.hazelcast.memory.MemorySize
Returns a pretty format String representation of this memory size.
toPrettyString(long) - Static method in class com.hazelcast.memory.MemorySize
Utility method to create a pretty format representation of given value in bytes.
toPrettyString(long, MemoryUnit) - Static method in class com.hazelcast.memory.MemorySize
Utility method to create a pretty format representation of given value in given unit.
ToResultSetFunction - Interface in com.hazelcast.jet.function
A function that accepts a JDBC connection to the database, the total parallelism and processor index as arguments and produces a result set.
toSet() - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that accumulates the items into a HashSet.
toString() - Method in class com.hazelcast.aws.AwsConfig
 
toString() - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
toString() - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
 
toString() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.JsonPointerBasedFilter
 
toString() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilter
 
toString() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
Overridden to provide developer writeable "JsonPath" representation of the context.
toString() - Method in class com.hazelcast.com.fasterxml.jackson.core.format.DataFormatDetector
 
toString(int) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.NumberOutput
 
toString(long) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.NumberOutput
 
toString(double) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.NumberOutput
 
toString(float) - Static method in class com.hazelcast.com.fasterxml.jackson.core.io.NumberOutput
 
toString() - Method in class com.hazelcast.com.fasterxml.jackson.core.io.SerializedString
 
toString() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonLocation
 
toString() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonPointer
 
toString() - Method in exception com.hazelcast.com.fasterxml.jackson.core.JsonProcessingException
 
toString() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
Overridden to provide developer readable "JsonPath" representation of the context.
toString() - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
 
toString() - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.Name
 
toString() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.RequestPayload
 
toString() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.TextBuffer
Note: calling this method may not be as efficient as calling TextBuffer.contentsAsString(), since it's not guaranteed that resulting String is cached.
toString() - Method in class com.hazelcast.com.fasterxml.jackson.core.Version
 
toString() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
toString(StringBuilder) - Method in class com.hazelcast.concurrent.atomiclong.operations.AbstractAtomicLongOperation
 
toString() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
toString(StringBuilder) - Method in class com.hazelcast.concurrent.atomicreference.operations.AbstractAtomicReferenceOperation
 
toString() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
 
toString() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
 
toString() - Method in class com.hazelcast.concurrent.lock.ConditionKey
 
toString() - Method in class com.hazelcast.concurrent.lock.InternalLockNamespace
 
toString() - Method in class com.hazelcast.concurrent.lock.LockProxy
 
toString() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
toString() - Method in class com.hazelcast.concurrent.lock.LockWaitNotifyKey
 
toString(StringBuilder) - Method in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
toString() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
 
toString() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
 
toString() - Method in class com.hazelcast.config.AbstractBasicConfig
 
toString() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
toString() - Method in class com.hazelcast.config.AdvancedNetworkConfig
 
toString() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
 
toString() - Method in class com.hazelcast.config.CacheConfig
 
toString() - Method in class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
toString() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
toString() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
toString() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
toString() - Method in class com.hazelcast.config.CacheSimpleConfig
 
toString() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
toString() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
toString() - Method in class com.hazelcast.config.ClassFilter
 
toString() - Method in class com.hazelcast.config.Config
 
toString() - Method in class com.hazelcast.config.CountDownLatchConfig
 
toString() - Method in class com.hazelcast.config.cp.CPSemaphoreConfig
 
toString() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
 
toString() - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
toString() - Method in class com.hazelcast.config.DiscoveryConfig
 
toString() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
toString() - Method in class com.hazelcast.config.DurableExecutorConfig
 
toString() - Method in class com.hazelcast.config.EntryListenerConfig
 
toString() - Method in class com.hazelcast.config.EventJournalConfig
 
toString() - Method in class com.hazelcast.config.EvictionConfig
 
toString() - Method in class com.hazelcast.config.ExecutorConfig
 
toString() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
toString() - Method in class com.hazelcast.config.GlobalSerializerConfig
 
toString() - Method in class com.hazelcast.config.GroupConfig
 
toString() - Method in class com.hazelcast.config.HotRestartConfig
 
toString() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
 
toString() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
toString() - Method in class com.hazelcast.config.InterfacesConfig
 
toString() - Method in class com.hazelcast.config.ItemListenerConfig
 
toString() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
toString() - Method in class com.hazelcast.config.JoinConfig
 
toString() - Method in class com.hazelcast.config.ListConfig
 
toString() - Method in class com.hazelcast.config.ListenerConfig
 
toString() - Method in class com.hazelcast.config.LockConfig
 
toString() - Method in class com.hazelcast.config.LoginModuleConfig
 
toString() - Method in class com.hazelcast.config.ManagementCenterConfig
 
toString() - Method in class com.hazelcast.config.MapAttributeConfig
 
toString() - Method in class com.hazelcast.config.MapConfig
 
toString() - Method in class com.hazelcast.config.MapIndexConfig
 
toString() - Method in class com.hazelcast.config.MapStoreConfig
 
toString() - Method in class com.hazelcast.config.MaxSizeConfig
 
toString() - Method in class com.hazelcast.config.MCMutualAuthConfig
 
toString() - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
toString() - Method in class com.hazelcast.config.MemberGroupConfig
 
toString() - Method in class com.hazelcast.config.MemcacheProtocolConfig
 
toString() - Method in class com.hazelcast.config.MergePolicyConfig
 
toString() - Method in class com.hazelcast.config.MerkleTreeConfig
 
toString() - Method in class com.hazelcast.config.MulticastConfig
 
toString() - Method in class com.hazelcast.config.MultiMapConfig
 
toString() - Method in class com.hazelcast.config.NativeMemoryConfig
 
toString() - Method in class com.hazelcast.config.NearCacheConfig
 
toString() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
toString() - Method in class com.hazelcast.config.NetworkConfig
 
toString() - Method in class com.hazelcast.config.PartitionGroupConfig
 
toString() - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
toString() - Method in class com.hazelcast.config.PermissionConfig
 
toString() - Method in class com.hazelcast.config.PermissionPolicyConfig
 
toString() - Method in class com.hazelcast.config.PredicateConfig
 
toString() - Method in class com.hazelcast.config.QueryCacheConfig
 
toString() - Method in class com.hazelcast.config.QueueConfig
 
toString() - Method in class com.hazelcast.config.QueueStoreConfig
 
toString() - Method in class com.hazelcast.config.QuorumConfig
 
toString() - Method in class com.hazelcast.config.ReliableTopicConfig
 
toString() - Method in class com.hazelcast.config.ReplicatedMapConfig
 
toString() - Method in class com.hazelcast.config.RestApiConfig
 
toString() - Method in class com.hazelcast.config.RestServerEndpointConfig
 
toString() - Method in class com.hazelcast.config.RingbufferConfig
 
toString() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
toString() - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
toString() - Method in class com.hazelcast.config.SecurityConfig
 
toString() - Method in class com.hazelcast.config.SemaphoreConfig
 
toString() - Method in class com.hazelcast.config.SerializationConfig
 
toString() - Method in class com.hazelcast.config.SerializerConfig
 
toString() - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
toString() - Method in class com.hazelcast.config.ServiceConfig
 
toString() - Method in class com.hazelcast.config.ServicesConfig
 
toString() - Method in class com.hazelcast.config.SetConfig
 
toString() - Method in class com.hazelcast.config.SocketInterceptorConfig
 
toString() - Method in class com.hazelcast.config.SSLConfig
 
toString() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
toString() - Method in class com.hazelcast.config.TcpIpConfig
 
toString() - Method in class com.hazelcast.config.TopicConfig
 
toString() - Method in class com.hazelcast.config.WanConsumerConfig
 
toString() - Method in class com.hazelcast.config.WanPublisherConfig
 
toString() - Method in class com.hazelcast.config.WanReplicationConfig
 
toString() - Method in class com.hazelcast.config.WanReplicationRef
 
toString() - Method in class com.hazelcast.config.WanSyncConfig
 
toString() - Method in class com.hazelcast.core.AbstractIMapEvent
Returns a String representation of this event.
toString() - Method in class com.hazelcast.core.DistributedObjectEvent
 
toString() - Method in class com.hazelcast.core.EntryEvent
 
toString() - Method in class com.hazelcast.core.HazelcastJsonValue
Returns unaltered string that was used to create this object.
toString() - Method in class com.hazelcast.core.InitialMembershipEvent
 
toString() - Method in class com.hazelcast.core.ItemEvent
 
toString() - Method in class com.hazelcast.core.LifecycleEvent
 
toString() - Method in class com.hazelcast.core.MapEvent
 
toString() - Method in class com.hazelcast.core.MembershipEvent
 
toString() - Method in class com.hazelcast.core.MigrationEvent
 
toString() - Method in class com.hazelcast.core.PartitionAwareKey
 
toString() - Method in class com.hazelcast.crdt.CRDTReplicationMigrationService
 
toString(StringBuilder) - Method in class com.hazelcast.crdt.pncounter.operations.AbstractPNCounterOperation
 
toString() - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
 
toString() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
toString() - Method in class com.hazelcast.instance.AbstractMember
 
toString() - Method in class com.hazelcast.instance.BuildInfo
 
toString() - Method in class com.hazelcast.instance.EndpointQualifier
 
toString() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
toString() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
toString() - Method in class com.hazelcast.instance.JetBuildInfo
 
toString() - Method in class com.hazelcast.instance.Node
 
toString() - Method in class com.hazelcast.jet.accumulator.DoubleAccumulator
 
toString() - Method in class com.hazelcast.jet.accumulator.LongAccumulator
 
toString() - Method in class com.hazelcast.jet.accumulator.LongDoubleAccumulator
 
toString() - Method in class com.hazelcast.jet.accumulator.LongLongAccumulator
 
toString() - Method in class com.hazelcast.jet.accumulator.MutableReference
 
toString() - Method in class com.hazelcast.jet.config.ResourceConfig
 
toString() - Method in class com.hazelcast.jet.core.BroadcastKey
 
toString() - Method in class com.hazelcast.jet.core.DAG
 
toString(int) - Method in class com.hazelcast.jet.core.DAG
Returns a string representation of the DAG.
toString() - Method in class com.hazelcast.jet.core.Edge
 
toString() - Method in class com.hazelcast.jet.core.metrics.JobMetrics
 
toString() - Method in class com.hazelcast.jet.core.metrics.Measurement
 
toString() - Method in class com.hazelcast.jet.core.test.TestInbox
 
toString() - Method in class com.hazelcast.jet.core.test.TestOutbox
 
toString() - Method in class com.hazelcast.jet.core.test.TestSupport.TestMode
 
toString() - Method in class com.hazelcast.jet.core.Vertex
 
toString() - Method in class com.hazelcast.jet.core.Watermark
 
toString() - Method in class com.hazelcast.jet.datamodel.ItemsByTag
 
toString() - Method in class com.hazelcast.jet.datamodel.KeyedWindowResult
 
toString() - Method in class com.hazelcast.jet.datamodel.Tag
 
toString() - Method in class com.hazelcast.jet.datamodel.TimestampedItem
 
toString() - Method in class com.hazelcast.jet.datamodel.Tuple2
 
toString() - Method in class com.hazelcast.jet.datamodel.Tuple3
 
toString() - Method in class com.hazelcast.jet.datamodel.Tuple4
 
toString() - Method in class com.hazelcast.jet.datamodel.Tuple5
 
toString() - Method in class com.hazelcast.jet.datamodel.WindowResult
 
toString() - Method in class com.hazelcast.jet.pipeline.test.SimpleEvent
 
toString() - Method in class com.hazelcast.map.EventLostEvent
 
toString() - Method in class com.hazelcast.map.MapPartitionLostEvent
 
toString() - Method in class com.hazelcast.memory.DefaultGarbageCollectorStats
 
toString() - Method in class com.hazelcast.memory.DefaultMemoryStats
 
toString() - Method in class com.hazelcast.memory.MemorySize
 
toString() - Method in class com.hazelcast.nio.Address
 
toString() - Method in class com.hazelcast.nio.Packet
 
toString() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
toString() - Method in class com.hazelcast.nio.tcp.TcpIpEndpointManager
 
toString() - Method in class com.hazelcast.org.snakeyaml.engine.v1.common.Anchor
 
toString() - Method in enum com.hazelcast.org.snakeyaml.engine.v1.common.ScalarStyle
 
toString() - Method in class com.hazelcast.org.snakeyaml.engine.v1.common.SpecVersion
 
toString() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.AliasEvent
 
toString() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.CollectionStartEvent
 
toString() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.DocumentEndEvent
 
toString() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.DocumentStartEvent
 
toString() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.ImplicitTuple
 
toString() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.MappingEndEvent
 
toString() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.MappingStartEvent
 
toString() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.ScalarEvent
 
toString() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.SequenceEndEvent
 
toString() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.SequenceStartEvent
 
toString() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.StreamEndEvent
 
toString() - Method in class com.hazelcast.org.snakeyaml.engine.v1.events.StreamStartEvent
 
toString() - Method in class com.hazelcast.org.snakeyaml.engine.v1.exceptions.Mark
 
toString() - Method in exception com.hazelcast.org.snakeyaml.engine.v1.exceptions.MarkedYamlEngineException
 
toString() - Method in exception com.hazelcast.org.snakeyaml.engine.v1.exceptions.ReaderException
 
toString() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.MappingNode
 
toString() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.NodeTuple
 
toString() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.ScalarNode
 
toString() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.SequenceNode
 
toString() - Method in class com.hazelcast.org.snakeyaml.engine.v1.nodes.Tag
 
toString() - Method in enum com.hazelcast.org.snakeyaml.engine.v1.tokens.Token.ID
 
toString() - Method in class com.hazelcast.org.snakeyaml.engine.v1.tokens.Token
 
toString() - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
toString() - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
toString() - Method in class com.hazelcast.partition.PartitionLostEvent
 
toString() - Method in class com.hazelcast.query.PartitionPredicate
 
toString() - Method in class com.hazelcast.query.PredicateBuilder
 
toString() - Method in class com.hazelcast.query.SqlPredicate
 
toString() - Method in class com.hazelcast.query.TruePredicate
 
toString() - Method in class com.hazelcast.quorum.QuorumEvent
 
toString() - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
toString() - Method in class com.hazelcast.security.permission.AllPermissions
 
toString() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
 
toString() - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
 
toString() - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
toString() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
toString() - Method in class com.hazelcast.spi.DefaultObjectNamespace
Deprecated.
 
toString(StringBuilder) - Method in class com.hazelcast.spi.Operation
A template method allows for additional information to be passed into the Operation.toString() method.
toString() - Method in class com.hazelcast.spi.Operation
 
toString() - Method in class com.hazelcast.spi.partition.IPartitionLostEvent
 
toString() - Method in class com.hazelcast.spi.PartitionMigrationEvent
 
toString() - Method in class com.hazelcast.spi.PartitionReplicationEvent
 
toString() - Method in class com.hazelcast.spi.properties.HazelcastProperty
 
toString() - Method in class com.hazelcast.transaction.TransactionOptions
 
toString() - Method in class com.hazelcast.util.AddressUtil.AddressHolder
 
toString() - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
 
toString() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
 
toString() - Method in class com.hazelcast.util.collection.IntHashSet
 
toString() - Method in class com.hazelcast.util.collection.Long2LongHashMap
 
toString() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
 
toString() - Method in class com.hazelcast.util.collection.LongHashSet
toString() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap.SimpleEntry
 
toString(Throwable) - Static method in class com.hazelcast.util.ExceptionUtil
Converts a Throwable stacktrace to a String.
toString() - Method in class com.hazelcast.util.executor.CompletableFutureTask
 
toString() - Method in class com.hazelcast.util.executor.NamedThreadPoolExecutor
 
toString() - Method in class com.hazelcast.util.ItemCounter
 
toString() - Method in class com.hazelcast.util.MutableLong
 
toString() - Method in class com.hazelcast.util.SampleableConcurrentHashMap.SamplingEntry
 
toString() - Method in class com.hazelcast.util.scheduler.ScheduledEntry
 
toString() - Method in class com.hazelcast.util.scheduler.SecondsBasedEntryTaskScheduler
 
toString() - Method in class com.hazelcast.util.StateMachine
 
toString() - Method in class com.hazelcast.version.MemberVersion
 
toString() - Method in class com.hazelcast.version.Version
 
toStringFn(FunctionEx<? super T, String>) - Method in class com.hazelcast.jet.pipeline.FileSinkBuilder
Sets the function which converts the item to its string representation.
total() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the total number of total operations
total() - Method in class com.hazelcast.util.ItemCounter
Returns the total counts.
totalCount() - Method in class com.hazelcast.com.fasterxml.jackson.core.sym.ByteQuadsCanonicalizer
 
totalParallelism() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
Returns the total number of Processors that will be created across the cluster.
totalParallelism() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
 
totalPhysicalMemory() - Static method in class com.hazelcast.memory.MemoryStatsSupport
Returns the total available physical memory on the system in bytes or -1 if not available.
totalSize() - Method in interface com.hazelcast.nio.serialization.Data
Returns the total size of Data in bytes.
totalSwapSpace() - Static method in class com.hazelcast.memory.MemoryStatsSupport
Returns the total amount of swap space in bytes or -1 if not available.
toTumblingByFrame() - Method in class com.hazelcast.jet.core.SlidingWindowPolicy
Converts this definition to one defining a tumbling window of the same length as this definition's frame.
touch(File) - Static method in class com.hazelcast.nio.IOUtil
Simulates a Linux touch command, by setting the last modified time of given file.
toUrn() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
Returns the String representation of the handler.
toUserFriendlyString(String) - Static method in class com.hazelcast.nio.Protocols
 
TrackableJob<V> - Interface in com.hazelcast.mapreduce
Deprecated.
MapReduce is deprecated and will be removed in 4.0. For map aggregations, you can use Aggregator on IMap. For general data processing, it is superseded by Hazelcast Jet.
TransactionalDistributedObject<S extends RemoteService> - Class in com.hazelcast.spi
To centralize de-serialization for transactional proxies
TransactionalDistributedObject(NodeEngine, S, Transaction) - Constructor for class com.hazelcast.spi.TransactionalDistributedObject
 
TransactionalList<E> - Interface in com.hazelcast.core
Transactional implementation of IList.
TransactionalMap<K,V> - Interface in com.hazelcast.core
Transactional implementation of BaseMap.
TransactionalMultiMap<K,V> - Interface in com.hazelcast.core
Transactional implementation of BaseMultiMap.
TransactionalObject - Interface in com.hazelcast.transaction
Marker interface for all transactional distributed objects.
TransactionalQueue<E> - Interface in com.hazelcast.core
Transactional implementation of BaseQueue.
TransactionalService - Interface in com.hazelcast.spi
An interface that can be implemented by SPI services that want to deal with transactions.
TransactionalSet<E> - Interface in com.hazelcast.core
Transactional implementation of ISet.
TransactionalTask<T> - Interface in com.hazelcast.transaction
Contains the logic that is going to be executed within a transaction.
TransactionalTaskContext - Interface in com.hazelcast.transaction
Provides a context to access transactional data-structures, like the TransactionalMap.
TransactionContext - Interface in com.hazelcast.transaction
Provides a context to perform transactional operations: beginning/committing transactions, but also retrieving transactional data-structures like the TransactionalMap.
TransactionException - Exception in com.hazelcast.transaction
A HazelcastException that is thrown when something goes wrong while dealing with transactions and transactional data-structures.
TransactionException() - Constructor for exception com.hazelcast.transaction.TransactionException
 
TransactionException(String) - Constructor for exception com.hazelcast.transaction.TransactionException
 
TransactionException(String, Throwable) - Constructor for exception com.hazelcast.transaction.TransactionException
 
TransactionException(Throwable) - Constructor for exception com.hazelcast.transaction.TransactionException
 
TransactionManagerService - Interface in com.hazelcast.transaction
 
TransactionNotActiveException - Exception in com.hazelcast.transaction
A HazelcastException thrown when an a transactional operation is executed without an active transaction.
TransactionNotActiveException() - Constructor for exception com.hazelcast.transaction.TransactionNotActiveException
 
TransactionNotActiveException(String) - Constructor for exception com.hazelcast.transaction.TransactionNotActiveException
 
TransactionOptions - Class in com.hazelcast.transaction
Contains the configuration for a Hazelcast transaction.
TransactionOptions() - Constructor for class com.hazelcast.transaction.TransactionOptions
Creates a new default configured TransactionsOptions.
TransactionOptions.TransactionType - Enum in com.hazelcast.transaction
The type of transaction.
TransactionPermission - Class in com.hazelcast.security.permission
 
TransactionPermission() - Constructor for class com.hazelcast.security.permission.TransactionPermission
 
TransactionTimedOutException - Exception in com.hazelcast.transaction
Thrown when a transaction has timed out.
TransactionTimedOutException() - Constructor for exception com.hazelcast.transaction.TransactionTimedOutException
 
TransactionTimedOutException(String) - Constructor for exception com.hazelcast.transaction.TransactionTimedOutException
 
TransactionTimedOutException(String, Throwable) - Constructor for exception com.hazelcast.transaction.TransactionTimedOutException
 
TransactionTimedOutException(Throwable) - Constructor for exception com.hazelcast.transaction.TransactionTimedOutException
 
transform(I) - Method in class com.hazelcast.projection.Projection
Transforms the input object into the output object.
transmit(Packet, T) - Method in interface com.hazelcast.nio.EndpointManager
Transmits a packet to a certain connection.
transmit(Packet, Address) - Method in interface com.hazelcast.nio.EndpointManager
Transmits a packet to a certain address.
transmit(Packet, TcpIpConnection) - Method in class com.hazelcast.nio.tcp.TcpIpEndpointManager
 
transmit(Packet, Address) - Method in class com.hazelcast.nio.tcp.TcpIpEndpointManager
 
traverse() - Method in interface com.hazelcast.com.fasterxml.jackson.core.TreeNode
Method for constructing a JsonParser instance for iterating over contents of the tree that this node is root of.
traverse(ObjectCodec) - Method in interface com.hazelcast.com.fasterxml.jackson.core.TreeNode
Same as TreeNode.traverse(), but additionally passes ObjectCodec to use if JsonParser.readValueAs(Class) is used (otherwise caller must call JsonParser.setCodec(com.hazelcast.com.fasterxml.jackson.core.ObjectCodec) on response explicitly).
traverseArray(T[]) - Static method in class com.hazelcast.jet.Traversers
Returns a traverser over the given array.
traverseEnumeration(Enumeration<T>) - Static method in class com.hazelcast.jet.Traversers
Returns an adapter from Enumeration to Traverser.
traverseItems(T...) - Static method in class com.hazelcast.jet.Traversers
Returns a traverser over the supplied arguments (or item array).
traverseIterable(Iterable<? extends T>) - Static method in class com.hazelcast.jet.Traversers
Returns a traverser over the given iterable.
traverseIterator(Iterator<? extends T>) - Static method in class com.hazelcast.jet.Traversers
Returns an adapter from Iterator to Traverser.
traverseIterator(Iterator<? extends T>, boolean) - Static method in class com.hazelcast.jet.Traversers
Returns an adapter from Iterator to Traverser.
Traverser<T> - Interface in com.hazelcast.jet
Traverses a potentially infinite sequence of non-null items.
Traversers - Class in com.hazelcast.jet
Utility class with several Traversers useful in Processor implementations.
traverseSpliterator(Spliterator<T>) - Static method in class com.hazelcast.jet.Traversers
Returns an adapter from Spliterator to Traverser.
traverseStream(Stream<T>) - Static method in class com.hazelcast.jet.Traversers
Returns a traverser over the given stream.
treeAsTokens(TreeNode) - Method in class com.hazelcast.com.fasterxml.jackson.core.ObjectCodec
Method for constructing a JsonParser for reading contents of a JSON tree, as if it was external serialized JSON content.
treeAsTokens(TreeNode) - Method in class com.hazelcast.com.fasterxml.jackson.core.TreeCodec
 
TreeCodec - Class in com.hazelcast.com.fasterxml.jackson.core
Interface that defines objects that can read and write TreeNode instances using Streaming API.
TreeCodec() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.TreeCodec
 
TreeNode - Interface in com.hazelcast.com.fasterxml.jackson.core
Marker interface used to denote JSON Tree nodes, as far as the core package knows them (which is very little): mostly needed to allow ObjectCodec to have some level of interoperability.
treeToValue(TreeNode, Class<T>) - Method in class com.hazelcast.com.fasterxml.jackson.core.ObjectCodec
Convenience method for converting given JSON tree into instance of specified value type.
TriFunction<T0,T1,T2,R> - Interface in com.hazelcast.jet.function
Represents a three-arity function that accepts three arguments and produces a result.
triggerForceStart() - Method in interface com.hazelcast.hotrestart.InternalHotRestartService
Forces node to start by skipping hot-restart completely and removing all hot-restart data even if node is still on validation phase or loading hot-restart data.
triggerForceStart() - Method in class com.hazelcast.hotrestart.NoopInternalHotRestartService
 
triggerPartialStart() - Method in interface com.hazelcast.hotrestart.InternalHotRestartService
Triggers partial start if the cluster cannot be started with full recovery and HotRestartPersistenceConfig.clusterDataRecoveryPolicy is set accordingly.
triggerPartialStart() - Method in class com.hazelcast.hotrestart.NoopInternalHotRestartService
 
trim(String) - Static method in class com.hazelcast.util.StringUtil
Trim whitespaces.
TriPredicate<T,U,V> - Interface in com.hazelcast.jet.function
Represents a predicate which accepts three arguments.
TruePredicate<K,V> - Class in com.hazelcast.query
A Predicate which always returns true.
TruePredicate() - Constructor for class com.hazelcast.query.TruePredicate
 
truePredicate() - Static method in class com.hazelcast.query.TruePredicate
 
tryAcquire() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
 
tryAcquire(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
 
tryAcquire(long, TimeUnit) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
 
tryAcquire(int, long, TimeUnit) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
 
tryAcquire() - Method in interface com.hazelcast.core.ISemaphore
Acquires a permit if one is available, and returns true immediately.
tryAcquire(int) - Method in interface com.hazelcast.core.ISemaphore
Acquires the given number of permits if they are available, and returns true immediately.
tryAcquire(long, TimeUnit) - Method in interface com.hazelcast.core.ISemaphore
Acquires a permit and returns true, if one becomes available during the given waiting time and the current thread has not been interrupted.
tryAcquire(int, long, TimeUnit) - Method in interface com.hazelcast.core.ISemaphore
Acquires the given number of permits and returns true, if they become available during the given waiting time.
tryCloseConnections(HazelcastInstance) - Method in class com.hazelcast.core.OutOfMemoryHandler
Tries to close the server socket and connections to other HazelcastInstances.
tryCloseConnections(HazelcastInstance) - Static method in class com.hazelcast.instance.OutOfMemoryHandlerHelper
 
tryCount - Variable in class com.hazelcast.spi.InvocationBuilder
 
tryEmit(int, Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
Offers the item to the outbox bucket at the supplied ordinal.
tryEmit(Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
Offers the item to all the outbox buckets (except the snapshot outbox).
tryEmit(int[], Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
Offers the item to the outbox buckets identified in the supplied array.
tryEmitToSnapshot(Object, Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
Offers one key-value pair to the snapshot bucket.
tryLoadClass(String) - Static method in class com.hazelcast.nio.ClassLoaderUtil
Tries to load the given class.
tryLock() - Method in class com.hazelcast.concurrent.lock.LockProxy
 
tryLock(long, TimeUnit) - Method in class com.hazelcast.concurrent.lock.LockProxy
 
tryLock(long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.concurrent.lock.LockProxy
 
tryLock(NodeEngine, Data) - Method in class com.hazelcast.concurrent.lock.LockProxySupport
 
tryLock(NodeEngine, Data, long, TimeUnit) - Method in class com.hazelcast.concurrent.lock.LockProxySupport
 
tryLock(NodeEngine, Data, long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.concurrent.lock.LockProxySupport
 
tryLock() - Method in interface com.hazelcast.core.ILock
Deprecated.
tryLock(long, TimeUnit) - Method in interface com.hazelcast.core.ILock
Deprecated.
tryLock(long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.core.ILock
Deprecated.
Tries to acquire the lock for the specified lease time.
tryLock(K) - Method in interface com.hazelcast.core.IMap
Tries to acquire the lock for the specified key.
tryLock(K, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Tries to acquire the lock for the specified key.
tryLock(K, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Tries to acquire the lock for the specified key for the specified lease time.
tryLock(K) - Method in interface com.hazelcast.core.MultiMap
Tries to acquire the lock for the specified key.
tryLock(K, long, TimeUnit) - Method in interface com.hazelcast.core.MultiMap
Tries to acquire the lock for the specified key.
tryLock(K, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.core.MultiMap
Tries to acquire the lock for the specified key for the specified lease time.
tryLock() - Method in interface com.hazelcast.cp.lock.FencedLock
Acquires the lock if it is available or already held by the current thread at the time of invocation & the acquire limit is not exceeded, and immediately returns with the value true.
tryLock(long, TimeUnit) - Method in interface com.hazelcast.cp.lock.FencedLock
Acquires the lock if it is free within the given waiting time, or already held by the current thread.
tryLockAndGetFence() - Method in interface com.hazelcast.cp.lock.FencedLock
Acquires the lock only if it is free or already held by the current thread at the time of invocation & the acquire limit is not exceeded, and returns the fencing token assigned to the current thread for this lock acquire.
tryLockAndGetFence(long, TimeUnit) - Method in interface com.hazelcast.cp.lock.FencedLock
Acquires the lock if it is free within the given waiting time, or already held by the current thread at the time of invocation & the acquire limit is not exceeded, and returns the fencing token assigned to the current thread for this lock acquire.
tryPauseMillis - Variable in class com.hazelcast.spi.InvocationBuilder
 
tryProcess(T) - Method in class com.hazelcast.jet.core.AbstractProcessor.FlatMapper
Method designed to be called from one of AbstractProcessor#tryProcessX() methods.
tryProcess(int, Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
Tries to process the supplied input item, which was received from the edge with the supplied ordinal.
tryProcess() - Method in interface com.hazelcast.jet.core.Processor
This method will be called periodically and only when the current batch of items in the inbox has been exhausted.
tryProcess0(Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
Tries to process the supplied input item, which was received from the edge with ordinal 0.
tryProcess1(Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
Tries to process the supplied input item, which was received from the edge with ordinal 1.
tryProcess2(Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
Tries to process the supplied input item, which was received from the edge with ordinal 2.
tryProcess3(Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
Tries to process the supplied input item, which was received from the edge with ordinal 3.
tryProcess4(Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
Tries to process the supplied input item, which was received from the edge with ordinal 4.
tryProcessWatermark(Watermark) - Method in class com.hazelcast.jet.core.AbstractProcessor
This basic implementation only forwards the passed watermark.
tryProcessWatermark(Watermark) - Method in interface com.hazelcast.jet.core.Processor
Tries to process the supplied watermark.
tryPut(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Tries to put the given key and value into this map within a specified timeout value.
tryRecover() - Method in interface com.hazelcast.map.QueryCache
This method can be used to recover from a possible event loss situation.
tryRemove(K, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Tries to remove the entry with the given key from this map within the specified timeout value.
trySetCount(int) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
 
trySetCount(int) - Method in interface com.hazelcast.core.ICountDownLatch
Sets the count to the given value if the current count is zero.
tryShutdown(HazelcastInstance) - Method in class com.hazelcast.core.OutOfMemoryHandler
Tries to shutdown HazelcastInstance forcefully; including closing sockets and connections, stopping threads, etc.
tryShutdown(HazelcastInstance) - Static method in class com.hazelcast.instance.OutOfMemoryHandlerHelper
 
tumbling(long) - Static method in class com.hazelcast.jet.pipeline.WindowDefinition
Returns a tumbling window definition with the given parameters.
tumblingWinPolicy(long) - Static method in class com.hazelcast.jet.core.SlidingWindowPolicy
Returns the definition of a tumbling window of length windowSize.
Tuple2<E0,E1> - Class in com.hazelcast.jet.datamodel
An immutable 2-tuple (pair) of statically typed fields.
tuple2(E0, E1) - Static method in class com.hazelcast.jet.datamodel.Tuple2
Returns a new 2-tuple with the supplied values.
Tuple3<E0,E1,E2> - Class in com.hazelcast.jet.datamodel
An immutable 3-tuple (triple) of statically typed fields.
tuple3(E0, E1, E2) - Static method in class com.hazelcast.jet.datamodel.Tuple3
Returns a new 3-tuple with the supplied values.
Tuple4<E0,E1,E2,E3> - Class in com.hazelcast.jet.datamodel
An immutable 4-tuple of statically typed fields.
tuple4(E0, E1, E2, E3) - Static method in class com.hazelcast.jet.datamodel.Tuple4
Returns a new 5-tuple with the supplied values.
Tuple5<E0,E1,E2,E3,E4> - Class in com.hazelcast.jet.datamodel
An immutable 5-tuple of statically typed fields.
tuple5(E0, E1, E2, E3, E4) - Static method in class com.hazelcast.jet.datamodel.Tuple5
Returns a new 5-tuple with the supplied values.
tx - Variable in class com.hazelcast.spi.TransactionalDistributedObject
 
txnLock(Data, String, long, long, long, boolean) - Method in interface com.hazelcast.concurrent.lock.LockStore
Lock a specific key for use inside a transaction.
txnLock(Data, String, long, long, long, boolean) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
txnLock(Data, String, long, long, long, boolean) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
 
TYPE_ARRAY - Static variable in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
 
TYPE_OBJECT - Static variable in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
 
TYPE_ROOT - Static variable in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
 
typeConverter() - Method in interface com.hazelcast.config.properties.PropertyDefinition
The TypeConverter to be used to convert the string value read from XML to the expected type automatically.
typeConverter() - Method in class com.hazelcast.config.properties.SimplePropertyDefinition
 
TypeConverter - Interface in com.hazelcast.core
Implementations of this interface define a certain type conversation.
TypedByteArrayDeserializer<T> - Interface in com.hazelcast.nio.serialization
This interface allows deserialization of a binary data with a provided class type.
TypedDataSerializable - Interface in com.hazelcast.nio.serialization
This interface adds the possibility for the class to act as if it is another class when being deserialized using DataSerializable
typeDesc() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
 
TypedStreamDeserializer<T> - Interface in com.hazelcast.nio.serialization
This interface allows deserialization of a binary data with a provided class type.
TypeReference<T> - Class in com.hazelcast.com.fasterxml.jackson.core.type
This generic abstract class is used for obtaining full generics type information by sub-classing; it must be converted to ResolvedType implementation (implemented by JavaType from "databind" bundle) to be used.
TypeReference() - Constructor for class com.hazelcast.com.fasterxml.jackson.core.type.TypeReference
 

U

unblacklist(Address) - Method in interface com.hazelcast.cluster.Joiner
Deprecated.
Removes an address from the blacklist if it is temporarily blacklisted.
unblock() - Method in class com.hazelcast.jet.core.test.TestOutbox
 
UnicodeEscaper - Class in com.hazelcast.org.snakeyaml.engine.external.com.google.gdata.util.common.base
An Escaper that converts literal text into a format safe for inclusion in a particular context (such as an XML document).
UnicodeEscaper() - Constructor for class com.hazelcast.org.snakeyaml.engine.external.com.google.gdata.util.common.base.UnicodeEscaper
 
UnifiedAggregateEndpointManager - Class in com.hazelcast.nio
 
UnifiedAggregateEndpointManager(TcpIpEndpointManager, Map<EndpointQualifier, EndpointManager<TcpIpConnection>>) - Constructor for class com.hazelcast.nio.UnifiedAggregateEndpointManager
 
UnifiedChannelInitializer - Class in com.hazelcast.nio.tcp
A ChannelInitializer that runs on a member and used for unencrypted channels.
UnifiedChannelInitializer(IOService) - Constructor for class com.hazelcast.nio.tcp.UnifiedChannelInitializer
 
UnifiedProtocolDecoder - Class in com.hazelcast.nio.tcp
A InboundHandler that reads the protocol bytes Protocols and based on the protocol it creates the appropriate handlers.
UnifiedProtocolDecoder(IOService, UnifiedProtocolEncoder) - Constructor for class com.hazelcast.nio.tcp.UnifiedProtocolDecoder
 
UnifiedProtocolEncoder - Class in com.hazelcast.nio.tcp
The ProtocolEncoder is responsible for writing the protocol and once the protocol has been written, the ProtocolEncoder is replaced by the appropriate handler.
UnifiedProtocolEncoder(IOService) - Constructor for class com.hazelcast.nio.tcp.UnifiedProtocolEncoder
 
UNIT - Static variable in class com.hazelcast.jet.core.metrics.MetricTags
Unit of metric value, for details see ProbeUnit.
UNKNOWN - Static variable in class com.hazelcast.version.MemberVersion
UNKNOWN version.
UNKNOWN - Static variable in class com.hazelcast.version.Version
Version 0.0 is UNKNOWN constant
UNKNOWN_HAZELCAST_VERSION - Static variable in class com.hazelcast.instance.BuildInfo
 
UNKNOWN_VERSION - Static variable in class com.hazelcast.version.Version
Use 0 as major & minor values for UNKNOWN version
unknownVersion() - Static method in class com.hazelcast.com.fasterxml.jackson.core.Version
Method returns canonical "not known" version, which is used as version in cases where actual version information is not known (instead of null).
UNLOCK - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
unlock() - Method in class com.hazelcast.concurrent.lock.LockProxy
 
unlock(NodeEngine, Data) - Method in class com.hazelcast.concurrent.lock.LockProxySupport
 
unlock(Data, String, long, long) - Method in interface com.hazelcast.concurrent.lock.LockStore
Unlock a specific key.
unlock(Data, String, long, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
unlock(Data, String, long, long) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
 
unlock() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
 
unlock() - Method in interface com.hazelcast.core.ILock
Deprecated.
Releases the lock.
unlock(K) - Method in interface com.hazelcast.core.IMap
Releases the lock for the specified key.
unlock(K) - Method in interface com.hazelcast.core.MultiMap
Releases the lock for the specified key.
unlock() - Method in interface com.hazelcast.cp.lock.FencedLock
Releases the lock if the lock is currently held by the current thread.
UNLOCK_BACKUP - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
UNLOCK_IF_LEASE_EXPIRED - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
UnlockBackupOperation - Class in com.hazelcast.concurrent.lock.operations
 
UnlockBackupOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.UnlockBackupOperation
 
UnlockBackupOperation(ObjectNamespace, Data, long, String, boolean) - Constructor for class com.hazelcast.concurrent.lock.operations.UnlockBackupOperation
 
UnlockIfLeaseExpiredOperation - Class in com.hazelcast.concurrent.lock.operations
 
UnlockIfLeaseExpiredOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.UnlockIfLeaseExpiredOperation
 
UnlockIfLeaseExpiredOperation(ObjectNamespace, Data, int) - Constructor for class com.hazelcast.concurrent.lock.operations.UnlockIfLeaseExpiredOperation
 
UnlockOperation - Class in com.hazelcast.concurrent.lock.operations
 
UnlockOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.UnlockOperation
 
UnlockOperation(ObjectNamespace, Data, long) - Constructor for class com.hazelcast.concurrent.lock.operations.UnlockOperation
 
UnlockOperation(ObjectNamespace, Data, long, boolean) - Constructor for class com.hazelcast.concurrent.lock.operations.UnlockOperation
 
UnlockOperation(ObjectNamespace, Data, long, boolean, long) - Constructor for class com.hazelcast.concurrent.lock.operations.UnlockOperation
 
unmarshalTheResponse(InputStream) - Static method in class com.hazelcast.aws.utility.CloudyUtility
Unmarshal the response from DescribeInstances and return the discovered node map.
UnmodifiableIterator<E> - Class in com.hazelcast.util
An iterator where items cannot be removed
UnmodifiableIterator() - Constructor for class com.hazelcast.util.UnmodifiableIterator
 
UnmodifiableListIterator<E> - Class in com.hazelcast.util
A listiterator where items cannot be removed
UnmodifiableListIterator() - Constructor for class com.hazelcast.util.UnmodifiableListIterator
 
unregister() - Method in interface com.hazelcast.spi.tenantcontrol.TenantControl
To be called when the Hazelcast object attached to this tenant is destroyed.
UNSAFE - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
GlobalMemoryAccessorRegistry.MEM instead
UNSAFE_AVAILABLE - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
GlobalMemoryAccessorRegistry.MEM_AVAILABLE instead
UnsafeHelper - Class in com.hazelcast.nio
Deprecated.
Use MemoryAccessor instead due to following reasons:

Deprecated to MemoryAccessor due to following reasons:

  • Preventing hard-dependency to Unsafe/
  • Some platforms (such as SPARC) don't support unaligned memory access. So on these platforms memory access alignments must be checked and handled if possible.

unsetBits(BitSet, Iterable<Integer>) - Static method in class com.hazelcast.util.BitSetUtils
Unsets all bits on a given positions.
updateAdd(Object, Object) - Method in class com.hazelcast.wan.merkletree.ArrayMerkleTree
 
updateAdd(Object, Object) - Method in interface com.hazelcast.wan.merkletree.MerkleTree
Updating the tree with adding a new entry to the tree
updateAttribute(MemberAttributeOperationType, String, Object) - Method in class com.hazelcast.instance.AbstractMember
 
updateMapP(String, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super V, ? super T, ? extends V>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
updateMapP(String, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends EntryProcessor<K, V>>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
updateMetaSupplier(UnaryOperator<ProcessorMetaSupplier>) - Method in class com.hazelcast.jet.core.Vertex
Applies the provided operator function to the current processor meta-supplier and replaces it with the one it returns.
updateRemoteMapP(String, ClientConfig, FunctionEx<? super T, ? extends K>, BiFunctionEx<? super V, ? super T, ? extends V>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
updateRemoteMapP(String, ClientConfig, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends EntryProcessor<K, V>>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
updateRemove(Object, Object) - Method in class com.hazelcast.wan.merkletree.ArrayMerkleTree
 
updateRemove(Object, Object) - Method in interface com.hazelcast.wan.merkletree.MerkleTree
Updating the tree with removing an entry
updateReplace(Object, Object, Object) - Method in class com.hazelcast.wan.merkletree.ArrayMerkleTree
 
updateReplace(Object, Object, Object) - Method in interface com.hazelcast.wan.merkletree.MerkleTree
Updating the tree with replacing an old value with a new one
upperCaseInternal(String) - Static method in class com.hazelcast.util.StringUtil
HC specific settings, operands etc.
UrgentSystemOperation - Interface in com.hazelcast.spi
An Marker interface that signals that an operation is an urgent System Operation.
URI_CHARS - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.common.CharConstants
 
UriEncoder - Class in com.hazelcast.org.snakeyaml.engine.v1.common
 
UriEncoder() - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.common.UriEncoder
 
urlEncode(String) - Static method in class com.hazelcast.aws.utility.AwsURLEncoder
 
UrlXmlConfig - Class in com.hazelcast.config
A Config which is loaded using some url pointing to a Hazelcast XML file.
UrlXmlConfig(String) - Constructor for class com.hazelcast.config.UrlXmlConfig
Creates new Config which is loaded from the given url and uses the System.properties to replace variables in the XML.
UrlXmlConfig(String, Properties) - Constructor for class com.hazelcast.config.UrlXmlConfig
Creates new Config which is loaded from the given url.
UrlXmlConfig(URL) - Constructor for class com.hazelcast.config.UrlXmlConfig
Creates new Config which is loaded from the given url and uses the System.properties to replace variables in the XML.
UrlXmlConfig(URL, Properties) - Constructor for class com.hazelcast.config.UrlXmlConfig
Creates new Config which is loaded from the given url.
UrlYamlConfig - Class in com.hazelcast.config
A Config which is loaded using some url pointing to a Hazelcast YAML file.
UrlYamlConfig(String) - Constructor for class com.hazelcast.config.UrlYamlConfig
Creates new Config which is loaded from the given url and uses the System.properties to replace variables in the YAML.
UrlYamlConfig(String, Properties) - Constructor for class com.hazelcast.config.UrlYamlConfig
Creates new Config which is loaded from the given url.
UrlYamlConfig(URL) - Constructor for class com.hazelcast.config.UrlYamlConfig
Creates new Config which is loaded from the given url and uses the System.properties to replace variables in the YAML.
UrlYamlConfig(URL, Properties) - Constructor for class com.hazelcast.config.UrlYamlConfig
Creates new Config which is loaded from the given url.
USE_LEGACY_MEMBER_LIST_FORMAT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Enables legacy (pre-3.9) member list format which is printed in logs.
useDefaultPrettyPrinter() - Method in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
 
useDefaultPrettyPrinter() - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
Convenience method for enabling pretty-printing using the default pretty printer (DefaultPrettyPrinter).
useDefaultPrettyPrinter() - Method in class com.hazelcast.com.fasterxml.jackson.core.util.JsonGeneratorDelegate
 
UserCodeDeploymentConfig - Class in com.hazelcast.config
Configuration of User Code Deployment.
UserCodeDeploymentConfig() - Constructor for class com.hazelcast.config.UserCodeDeploymentConfig
 
UserCodeDeploymentConfig.ClassCacheMode - Enum in com.hazelcast.config
Controls caching of caches loaded from remote members
UserCodeDeploymentConfig.ProviderMode - Enum in com.hazelcast.config
Controls how to react on receiving a classloading request from a remote member
UserCodeDeploymentPermission - Class in com.hazelcast.security.permission
 
UserCodeDeploymentPermission(String...) - Constructor for class com.hazelcast.security.permission.UserCodeDeploymentPermission
 
UsernamePasswordCredentials - Class in com.hazelcast.security
Simple implementation of Credentials using username and password as security attributes.
UsernamePasswordCredentials() - Constructor for class com.hazelcast.security.UsernamePasswordCredentials
 
UsernamePasswordCredentials(String, String) - Constructor for class com.hazelcast.security.UsernamePasswordCredentials
 
usesPadding() - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
 
usesPaddingChar(char) - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
 
usesPaddingChar(int) - Method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variant
 
UTF32Reader - Class in com.hazelcast.com.fasterxml.jackson.core.io
Since JDK does not come with UTF-32/UCS-4, let's implement a simple decoder to use.
UTF32Reader(IOContext, InputStream, byte[], int, int, boolean) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.io.UTF32Reader
 
UTF8_BOM_1 - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.ByteSourceJsonBootstrapper
 
UTF8_BOM_2 - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.ByteSourceJsonBootstrapper
 
UTF8_BOM_3 - Static variable in class com.hazelcast.com.fasterxml.jackson.core.json.ByteSourceJsonBootstrapper
 
UTF8_CHARSET - Static variable in class com.hazelcast.util.StringUtil
UTF-8 Charset
UTF8DataInputJsonParser - Class in com.hazelcast.com.fasterxml.jackson.core.json
This is a concrete implementation of JsonParser, which is based on a DataInput as the input source.
UTF8DataInputJsonParser(IOContext, int, DataInput, ObjectCodec, ByteQuadsCanonicalizer, int) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.json.UTF8DataInputJsonParser
 
UTF8JsonGenerator - Class in com.hazelcast.com.fasterxml.jackson.core.json
 
UTF8JsonGenerator(IOContext, int, ObjectCodec, OutputStream) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
 
UTF8JsonGenerator(IOContext, int, ObjectCodec, OutputStream, byte[], int, boolean) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
 
UTF8StreamJsonParser - Class in com.hazelcast.com.fasterxml.jackson.core.json
This is a concrete implementation of JsonParser, which is based on a InputStream as the input source.
UTF8StreamJsonParser(IOContext, int, InputStream, ObjectCodec, ByteQuadsCanonicalizer, byte[], int, int, boolean) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
 
UTF8Writer - Class in com.hazelcast.com.fasterxml.jackson.core.io
 
UTF8Writer(IOContext, OutputStream) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.io.UTF8Writer
 
UTF_8 - Static variable in class com.hazelcast.nio.Bits
A reusable instance of the UTF-8 charset
UTF_BUFFER_SIZE - Static variable in interface com.hazelcast.nio.BufferObjectDataInput
 
UTF_BUFFER_SIZE - Static variable in interface com.hazelcast.nio.BufferObjectDataOutput
 
Util - Class in com.hazelcast.jet
Miscellaneous utility methods useful in DAG building logic.
uuid - Variable in class com.hazelcast.instance.AbstractMember
 
uuid(String) - Method in class com.hazelcast.instance.MemberImpl.Builder
 
UuidUtil - Class in com.hazelcast.util
Util class to generate type 4 (pseudo randomly generated) UUID.

V

validate() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
validate(T) - Method in interface com.hazelcast.config.properties.ValueValidator
Validates the given value according to the defined validation logic and throws a ValidationException if configuration does not meet the requirements or logical errors are spotted.
validateIndexAttribute(String) - Static method in class com.hazelcast.config.MapIndexConfig
Validates index attribute content.
validateJoinRequest(JoinMessage) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
validateJoinRequest(JoinMessage) - Method in interface com.hazelcast.instance.NodeExtension
Executed on the master node before allowing a new member to join from ClusterJoinManager.handleJoinRequest(JoinRequest, Connection).
validatesTarget() - Method in class com.hazelcast.spi.Operation
 
ValidationException - Exception in com.hazelcast.config.properties
This exception is thrown from ValueValidator implementations whenever the validation has not succeed for any reason.
ValidationException(String) - Constructor for exception com.hazelcast.config.properties.ValidationException
 
ValidationException(String, Throwable) - Constructor for exception com.hazelcast.config.properties.ValidationException
 
ValidationException(Throwable) - Constructor for exception com.hazelcast.config.properties.ValidationException
 
validator() - Method in interface com.hazelcast.config.properties.PropertyDefinition
Returns an optional validator to validate a value before finalizing the configuration.
validator() - Method in class com.hazelcast.config.properties.SimplePropertyDefinition
 
value - Variable in class com.hazelcast.core.EntryEvent
 
value() - Method in enum com.hazelcast.query.QueryConstants
 
value() - Method in class com.hazelcast.util.collection.Long2LongHashMap.LongLongCursor
 
value - Variable in class com.hazelcast.util.ConcurrentReferenceHashMap.SimpleEntry
 
value - Variable in class com.hazelcast.util.MutableInteger
Mutable integer value of this instance.
value - Variable in class com.hazelcast.util.MutableLong
Mutable long value of this instance.
value - Variable in class com.hazelcast.util.SampleableConcurrentHashMap.SamplingEntry
 
ValueCallback<T> - Class in com.hazelcast.query.extractor
Enables notifying about values extracted in a ValueExtractor
ValueCallback() - Constructor for class com.hazelcast.query.extractor.ValueCallback
 
ValueCollector<T> - Class in com.hazelcast.query.extractor
Enables collecting values extracted in a ValueExtractor
ValueCollector() - Constructor for class com.hazelcast.query.extractor.ValueCollector
 
valueCount(K) - Method in interface com.hazelcast.core.BaseMultiMap
Returns the number of values matching the given key in the multimap.
valueCount(K) - Method in interface com.hazelcast.core.MultiMap
Returns the number of values that match the given key in the multimap.
valueCount(K) - Method in interface com.hazelcast.core.TransactionalMultiMap
Returns the number of values matching the given key in the multimap.
ValueExtractor<T,A> - Class in com.hazelcast.query.extractor
Common superclass for all extractors that enable the user to define custom attributes and extract their values.
ValueExtractor() - Constructor for class com.hazelcast.query.extractor.ValueExtractor
 
valueOf(String) - Static method in enum com.hazelcast.aws.AwsProperties
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.cache.BuiltInCacheMergePolicies
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.cluster.ClusterState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.cluster.MemberAttributeOperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class com.hazelcast.com.fasterxml.jackson.core.Base64Variants
 
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.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
Alias for JsonPointer.compile(java.lang.String); added to make instances automatically deserializable by Jackson databind.
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.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.CacheDeserializedValues
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.CacheEvictionConfig.CacheMaxSizePolicy
Deprecated.
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.EvictionConfig.MaxSizePolicy
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.InMemoryFormat
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.MaxSizeConfig.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.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.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.WanPublisherState
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.ClientType
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.core.MigrationEvent.MigrationStatus
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.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.NodeState
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.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.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.mapreduce.JobPartitionState.State
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.mapreduce.TopologyChangedStrategy
Deprecated.
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.ConnectionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.nio.Packet.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.nio.serialization.DataType
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.nio.serialization.SerializableByConvention.Reason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.org.snakeyaml.engine.v1.common.FlowStyle
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.org.snakeyaml.engine.v1.common.ScalarStyle
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.org.snakeyaml.engine.v1.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.v1.nodes.NodeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.org.snakeyaml.engine.v1.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.quorum.QuorumType
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.integration.DiscoveryMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.spi.ExceptionAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.spi.partition.MigrationEndpoint
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.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.util.ConcurrentReferenceHashMap.Option
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.util.ConcurrentReferenceHashMap.ReferenceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.util.executor.ExecutorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.util.IterationType
Returns the enum constant of this type with the specified name.
valueOf(long) - Static method in class com.hazelcast.util.MutableLong
 
valueOf(String) - Static method in enum com.hazelcast.util.scheduler.ScheduleType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.wan.WanSyncStatus
Returns the enum constant of this type with the specified name.
ValueReader - Class in com.hazelcast.query.extractor
Enables reading the value of the attribute specified by the path
ValueReader() - Constructor for class com.hazelcast.query.extractor.ValueReader
 
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.aws.AwsProperties
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.cache.BuiltInCacheMergePolicies
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.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.cluster.MemberAttributeOperationType
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.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.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.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.CacheEvictionConfig.CacheMaxSizePolicy
Deprecated.
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.EvictionConfig.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.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.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.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.MaxSizeConfig.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.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.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.WanPublisherState
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() - Method in interface com.hazelcast.core.BaseMap
Returns a collection clone of the values contained in this map.
values(Predicate) - Method in interface com.hazelcast.core.BaseMap
Queries the map based on the specified predicate and returns the values of matching entries.
values() - Static method in enum com.hazelcast.core.ClientType
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() - Method in interface com.hazelcast.core.IMap
Returns a collection clone of the values contained in this map.
values(Predicate) - Method in interface com.hazelcast.core.IMap
Queries the map based on the specified predicate and returns the values of matching entries.
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.core.MigrationEvent.MigrationStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface com.hazelcast.core.MultiMap
Returns the collection of values in the multimap.
values() - Method in interface com.hazelcast.core.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.core.ReplicatedMap
Returns an eagerly populated Collection view of the values contained in this map.
values() - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.values().
values(Predicate) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.values(com.hazelcast.query.Predicate).
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.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.NodeState
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.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.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.QueryCache
 
values(Predicate) - Method in interface com.hazelcast.map.QueryCache
 
values() - Static method in enum com.hazelcast.mapreduce.JobPartitionState.State
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.mapreduce.TopologyChangedStrategy
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
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() - Static method in enum com.hazelcast.nio.ConnectionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.nio.Packet.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.nio.serialization.DataType
Returns an array containing the constants of this enum type, in the order they are declared.
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.nio.serialization.SerializableByConvention.Reason
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.v1.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.v1.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.v1.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.v1.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.v1.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() - Static method in enum com.hazelcast.quorum.QuorumType
Returns an array containing the constants of this enum type, in the order they are declared.
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.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.ExceptionAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.spi.partition.MigrationEndpoint
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.topic.TopicOverloadPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
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() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
 
values() - Method in class com.hazelcast.util.collection.Long2LongHashMap
 
values() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
 
values() - Static method in enum com.hazelcast.util.ConcurrentReferenceHashMap.Option
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.util.ConcurrentReferenceHashMap.ReferenceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
Returns a Collection view of the values contained in this map.
values() - Static method in enum com.hazelcast.util.executor.ExecutorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.util.IterationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.util.scheduler.ScheduleType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.wan.WanSyncStatus
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.v1.tokens
 
ValueToken(Optional<Mark>, Optional<Mark>) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.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.
Verbosity() - Constructor for class com.hazelcast.jet.server.JetCommandLine.Verbosity
 
verify() - Method in class com.hazelcast.config.JoinConfig
Verifies this JoinConfig is valid.
verifyProcessor(SupplierEx<Processor>) - Static method in class com.hazelcast.jet.core.test.TestSupport
 
verifyProcessor(ProcessorSupplier) - Static method in class com.hazelcast.jet.core.test.TestSupport
 
verifyProcessor(ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.test.TestSupport
 
verifyProtocol(String) - Method in class com.hazelcast.nio.tcp.SingleProtocolDecoder
 
verifyProtocol(String) - Method in class com.hazelcast.nio.tcp.TextHandshakeDecoder
 
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
Deprecated.
Use variant that takes group and artifact ids
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 - Variable in class com.hazelcast.instance.AbstractMember
 
VERSION - Static variable in class com.hazelcast.instance.GeneratedBuildProperties
 
version(MemberVersion) - Method in class com.hazelcast.instance.MemberImpl.Builder
 
VERSION - Static variable in class com.hazelcast.nio.Packet
 
Version - Class in com.hazelcast.version
A generic version to be used with VersionAware classes.
Version() - Constructor for class com.hazelcast.version.Version
 
VERSION_CHECK_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
VERSION_PATTERN - Static variable in class com.hazelcast.util.StringUtil
Pattern used to tokenize version strings.
VersionAware - Interface in com.hazelcast.nio
Enables getting the version from the implementing object.
VersionAwareConstructorFunction<K,V> - Interface in com.hazelcast.util
VersionAware version of the ConstructorFunction.
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
VersionedPortable is an extension to Portable to support per class version instead of a global serialization version.
versionFor(Class<?>) - Static method in class com.hazelcast.com.fasterxml.jackson.core.util.VersionUtil
Helper method that will try to load version information for specified class.
VersionUtil - Class in com.hazelcast.com.fasterxml.jackson.core.util
Functionality for supporting exposing of component Versions.
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
 
VisitablePredicate - Interface in com.hazelcast.query
Predicates which can be visited by optimizer.
voteFor(WeightedEvictableList.WeightedItem<T>) - Method in class com.hazelcast.util.collection.WeightedEvictableList
Casts a vote for given list node.

W

W3cDomUtil - Class in com.hazelcast.config.yaml
Utility methods for YAML to W3C adaptors
WAIT - Static variable in class com.hazelcast.spi.CallStatus
Indicates that the call could not complete because waiting is required.
WAIT_ORDINAL - Static variable in class com.hazelcast.spi.CallStatus
The ordinal value for a CallStatus.WAIT.
WAIT_SECONDS_BEFORE_JOIN - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
WAITERS_INFO - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
waitForever(Collection<? extends Future>, FutureUtil.ExceptionHandler) - Static method in class com.hazelcast.util.FutureUtil
 
waitForever(Collection<? extends Future>) - Static method in class com.hazelcast.util.FutureUtil
 
WaitNotifyKey - Interface in com.hazelcast.spi
A key for a wait notify object e.g.
waitPartitionReplicaSyncOnCluster(long, TimeUnit) - Method in interface com.hazelcast.hotrestart.InternalHotRestartService
Waits until partition replicas (primaries and backups) get in sync.
waitPartitionReplicaSyncOnCluster(long, TimeUnit) - Method in class com.hazelcast.hotrestart.NoopInternalHotRestartService
 
waitUntilAllResponded(Collection<? extends Future>) - Static method in class com.hazelcast.util.FutureUtil
 
waitUntilAllRespondedWithDeadline(Collection<? extends Future>, long, TimeUnit, FutureUtil.ExceptionHandler) - Static method in class com.hazelcast.util.FutureUtil
 
waitWithDeadline(Collection<? extends Future>, long, TimeUnit) - Static method in class com.hazelcast.util.FutureUtil
 
waitWithDeadline(Collection<? extends Future>, long, TimeUnit, FutureUtil.ExceptionHandler) - Static method in class com.hazelcast.util.FutureUtil
 
waitWithDeadline(Collection<? extends Future>, long, TimeUnit, long, TimeUnit) - Static method in class com.hazelcast.util.FutureUtil
 
waitWithDeadline(Collection<? extends Future>, long, TimeUnit, long, TimeUnit, FutureUtil.ExceptionHandler) - Static method in class com.hazelcast.util.FutureUtil
 
WAN_CONSUMER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
WAN_PUBLISHER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
WAN_REPLICATION_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
WAN_SYNC_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
WanAcknowledgeType - Enum in com.hazelcast.config
Determines acknowledge waiting type of wan replication operation invocation.
WanConsumerConfig - Class in com.hazelcast.config
Config for processing WAN events received from a target cluster.
WanConsumerConfig() - Constructor for class com.hazelcast.config.WanConsumerConfig
 
WanPublisherConfig - Class in com.hazelcast.config
Configuration object for a WAN publisher.
WanPublisherConfig() - Constructor for class com.hazelcast.config.WanPublisherConfig
 
WanPublisherState - Enum in com.hazelcast.config
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.
WanReplicationConfig - Class in com.hazelcast.config
Configuration for WAN replication.
WanReplicationConfig() - Constructor for class com.hazelcast.config.WanReplicationConfig
 
WanReplicationEndpoint - Interface in com.hazelcast.wan
Implementations of this interface represent a replication endpoint, normally another Hazelcast cluster only reachable over a wide area network.
WanReplicationEvent - Class in com.hazelcast.wan
Event class used to transmit the actual event object
WanReplicationEvent() - Constructor for class com.hazelcast.wan.WanReplicationEvent
 
WanReplicationEvent(String, ReplicationEventObject) - Constructor for class com.hazelcast.wan.WanReplicationEvent
 
WanReplicationPublisher - 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
WANReplicationQueueFullException - Exception in com.hazelcast.wan
A HazelcastException that is thrown when the wan replication queues are full This exception is only thrown when WAN is configured with WANQueueFullBehavior.THROW_EXCEPTION
WANReplicationQueueFullException(String) - Constructor for exception com.hazelcast.wan.WANReplicationQueueFullException
 
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
 
WanReplicationRefReadOnly - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
WanReplicationRefReadOnly(WanReplicationRef) - Constructor for class com.hazelcast.config.WanReplicationRefReadOnly
Deprecated.
 
WanReplicationService - Interface in com.hazelcast.wan
This is the WAN replications service API core interface.
WanSyncConfig - Class in com.hazelcast.config
Configuration object for the WAN sync mechanism.
WanSyncConfig() - Constructor for class com.hazelcast.config.WanSyncConfig
 
WanSyncState - Interface in com.hazelcast.monitor
Local WAN sync statistics to be used by MemberState implementations.
WanSyncStats - Interface in com.hazelcast.wan
WAN Synchronization statistics
WanSyncStatus - Enum in com.hazelcast.wan
WanSyncStatus shows the current status of WAN sync.
warning(String) - Method in class com.hazelcast.logging.AbstractLogger
 
warning(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
warning(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
warning(String) - Method in interface com.hazelcast.logging.ILogger
Logs a message at the Level.WARNING level.
warning(Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a throwable at the Level.WARNING level.
warning(String, Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a message with an associated throwable at the Level.WARNING level.
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
This value together with EventTimePolicy.watermarkThrottlingFrameOffset() specify the frame size the watermarks are throttled to.
WeightedEvictableList<T> - Class in com.hazelcast.util.collection
This list keeps the items as long as its size is less than maximum capacity.
WeightedEvictableList(int, int) - Constructor for class com.hazelcast.util.collection.WeightedEvictableList
 
WeightedEvictableList.WeightedItem<T> - Class in com.hazelcast.util.collection
A node that contains an item and its weight
wholeItem() - Static method in class com.hazelcast.jet.function.Functions
Synonym for FunctionEx.identity(), to be used as a projection function (e.g., key extractor).
WildcardConfigPatternMatcher - Class in com.hazelcast.config.matcher
This ConfigPatternMatcher supports a simplified wildcard matching.
WildcardConfigPatternMatcher() - Constructor for class com.hazelcast.config.matcher.WildcardConfigPatternMatcher
 
window(WindowDefinition) - Method in interface com.hazelcast.jet.pipeline.StreamStage
Adds the given window definition to this stage, as the first step in the construction of a pipeline stage that performs windowed aggregation.
window(WindowDefinition) - Method in interface com.hazelcast.jet.pipeline.StreamStageWithKey
Adds the definition of the window to use in the group-and-aggregate pipeline stage being constructed.
WindowAggregateBuilder<R0> - Class in com.hazelcast.jet.pipeline
Offers a step-by-step fluent API to build a pipeline stage that performs a windowed co-aggregation of the data from several input stages.
WindowAggregateBuilder1<T0> - Class in com.hazelcast.jet.pipeline
Offers a step-by-step fluent API to build a pipeline stage that performs a windowed co-aggregation of the data from several input stages.
windowDefinition() - Method in interface com.hazelcast.jet.pipeline.StageWithKeyAndWindow
Returns the definition of the window for the windowed aggregation operation that you are about to construct using this object.
windowDefinition() - Method in interface com.hazelcast.jet.pipeline.StageWithWindow
Returns the definition of the window for the windowed aggregation operation that you are about to construct using this object.
WindowDefinition - Class in com.hazelcast.jet.pipeline
The definition of the window for a windowed aggregation operation.
WindowDefinition() - Constructor for class com.hazelcast.jet.pipeline.WindowDefinition
 
WindowGroupAggregateBuilder<K,R0> - Class in com.hazelcast.jet.pipeline
Offers a step-by-step API to build a pipeline stage that performs a windowed co-grouping and aggregation of the data from several input stages.
WindowGroupAggregateBuilder1<T0,K> - Class in com.hazelcast.jet.pipeline
Offers a step-by-step API to build a pipeline stage that performs a windowed co-grouping and aggregation of the data from several input stages.
WindowResult<R> - Class in com.hazelcast.jet.datamodel
Holds the result of an aggregate operation performed over a time window.
WindowResult(long, long, R, 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).
withAcceptableHeartbeatPauseMillis(long) - Method in class com.hazelcast.config.ProbabilisticQuorumConfigBuilder
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
 
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.
withCreateFn(FunctionEx<JetInstance, ? extends C>) - Static method in class com.hazelcast.jet.pipeline.ContextFactory
Creates a new ContextFactory with the given create-function.
withDestroyFn(ConsumerEx<? super C>) - Method in class com.hazelcast.jet.pipeline.ContextFactory
Returns a copy of this ContextFactory with the destroy-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
Fluent method that may be used to assign originating JsonGenerator, to be accessed using JsonGenerationException.getProcessor().
withHeartbeatIntervalMillis(long) - Method in class com.hazelcast.config.ProbabilisticQuorumConfigBuilder
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
 
withLocalSharing() - Method in class com.hazelcast.jet.pipeline.ContextFactory
Returns a copy of this ContextFactory with the localSharing flag set.
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.
withMaxPendingCallsPerProcessor(int) - Method in class com.hazelcast.jet.pipeline.ContextFactory
Returns a copy of this ContextFactory with the maxPendingCallsPerProcessor property set to the given value.
withMaxSampleSize(int) - Method in class com.hazelcast.config.ProbabilisticQuorumConfigBuilder
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.ProbabilisticQuorumConfigBuilder
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).
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.
withParser(JsonParser) - Method in exception com.hazelcast.com.fasterxml.jackson.core.JsonParseException
Fluent method that may be used to assign originating JsonParser, to be accessed using JsonParseException.getProcessor().
withQuorumSize(int) - Method in class com.hazelcast.config.QuorumConfigBuilder
 
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
 
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.
withSuspicionThreshold(double) - Method in class com.hazelcast.config.ProbabilisticQuorumConfigBuilder
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.
withTransition(T, T, T...) - Method in class com.hazelcast.util.StateMachine
Add a valid transition from one state to one or more states
withUnorderedAsyncResponses() - Method in class com.hazelcast.jet.pipeline.ContextFactory
Returns a copy of this ContextFactory with the unorderedAsyncResponses flag set to true.
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(int, int) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
write(OutboundFrame) - Method in interface com.hazelcast.nio.Connection
Writes a outbound frame so it can be received by the other side of the connection.
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(OutboundFrame) - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
write(String) - Method in interface com.hazelcast.org.snakeyaml.engine.v1.api.StreamDataWriter
 
write(String, int, int) - Method in interface com.hazelcast.org.snakeyaml.engine.v1.api.StreamDataWriter
 
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
Value write method that can be called to write a single array (sequence of JsonToken.START_ARRAY, zero or more JsonToken.VALUE_NUMBER_INT, JsonToken.END_ARRAY)
writeArray(long[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
Value write method that can be called to write a single array (sequence of JsonToken.START_ARRAY, zero or more JsonToken.VALUE_NUMBER_INT, JsonToken.END_ARRAY)
writeArray(double[], int, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
Value write method that can be called to write a single array (sequence of JsonToken.START_ARRAY, zero or more JsonToken.VALUE_NUMBER_FLOAT, JsonToken.END_ARRAY)
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
 
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.
writeAttributeValue(Object, ObjectDataOutput) - Static method in class com.hazelcast.nio.IOUtil
 
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
Similar to JsonGenerator.writeBinary(Base64Variant,byte[],int,int), but default to using the Jackson default Base64 variant (which is Base64Variants.MIME_NO_LINEFEEDS).
writeBinary(byte[]) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
Similar to JsonGenerator.writeBinary(Base64Variant,byte[],int,int), but assumes default to using the Jackson default Base64 variant (which is Base64Variants.MIME_NO_LINEFEEDS).
writeBinary(InputStream, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
Similar to JsonGenerator.writeBinary(Base64Variant,InputStream,int), but assumes default to using the Jackson default Base64 variant (which is Base64Variants.MIME_NO_LINEFEEDS).
writeBinary(Base64Variant, InputStream, int) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonGenerator
Method similar to JsonGenerator.writeBinary(Base64Variant,byte[],int,int), but where input is provided through a stream, allowing for incremental writes without holding the whole input in memory.
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(int, boolean) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
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(int, int) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeByte(String, byte) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive byte.
writeByteArray(ObjectDataOutput, byte[]) - Static method in class com.hazelcast.nio.IOUtil
 
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
Returns a supplier of processors for Sinks.cache(String).
writeChar(byte[], int, char, boolean) - Static method in class com.hazelcast.nio.Bits
 
writeChar(int, int) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
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.
writeCharB(byte[], int, char) - Static method in class com.hazelcast.nio.Bits
 
writeCharL(byte[], int, char) - Static method in class com.hazelcast.nio.Bits
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.concurrent.lock.InternalLockNamespace
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.AtomicLongConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.AtomicReferenceConfig
 
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.CountDownLatchConfig
 
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.MapListenerToEntryListenerAdapter
 
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.ItemListenerConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.LegacyCacheConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.LegacyCacheEvictionConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ListenerConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.LockConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MapAttributeConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MapConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MapIndexConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MapStoreConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MaxSizeConfig
 
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.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.QuorumConfig
 
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.SemaphoreConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.TopicConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanConsumerConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanPublisherConfig
 
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.core.MemberAttributeEvent
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.core.MigrationEvent
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.core.PartitionAwareKey
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.crdt.pncounter.operations.CRDTTimestampedLong
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.instance.AbstractMember
 
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 class com.hazelcast.map.eviction.LFUEvictionPolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.eviction.LRUEvictionPolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.eviction.RandomEvictionPolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.merge.HigherHitsMapMergePolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.merge.IgnoreMergingEntryMapMergePolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.merge.LatestUpdateMapMergePolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.merge.PassThroughMergePolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.merge.PutIfAbsentMapMergePolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.nio.Address
 
writeData(Data) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeData(ObjectDataOutput) - Method in interface com.hazelcast.nio.serialization.DataSerializable
Writes object fields to output stream
writeData(ObjectDataOutput) - Method in class com.hazelcast.partition.PartitionLostEvent
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.PagingPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.PartitionPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.PredicateBuilder
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.SqlPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.TruePredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.merge.HigherHitsMapMergePolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.merge.LatestUpdateMapMergePolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.merge.PassThroughMergePolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.merge.PutIfAbsentMapMergePolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.DefaultObjectNamespace
Deprecated.
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.DistributedObjectNamespace
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.Operation
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.OperationControl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.partition.IPartitionLostEvent
 
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
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.wan.WanReplicationEvent
 
writeDouble(int, double) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeDouble(double, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeDouble(int, double, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
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 datatypes of non-JSON 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 a JSON 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.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, FunctionEx<? super T, ? extends String>, Charset, boolean) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
Returns a supplier of processors for Sinks.filesBuilder(java.lang.String).
writeFilesP(String, SupplierEx<Schema>, SupplierEx<DatumWriter<D>>) - Static method in class com.hazelcast.jet.avro.AvroProcessors
writeFloat(int, float) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeFloat(float, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeFloat(int, float, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
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.
writeHdfsP(JobConf, FunctionEx<? super E, K>, FunctionEx<? super E, V>) - Static method in class com.hazelcast.jet.hadoop.HdfsProcessors
Returns a supplier of processors for HdfsSinks.hdfs(JobConf, FunctionEx, FunctionEx).
writeImmediatePath(JsonGenerator) - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.TokenFilterContext
Variant of TokenFilterContext.writePath(JsonGenerator) called when all we need is immediately surrounding Object.
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(byte[], int, int, boolean) - Static method in class com.hazelcast.nio.Bits
 
writeInt(int, int) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeInt(int, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeInt(int, int, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
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.
writeIntB(byte[], int, int) - Static method in class com.hazelcast.nio.Bits
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomiclong.operations.AbstractAtomicLongOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomiclong.operations.AddBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomiclong.operations.ApplyOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomiclong.operations.MergeBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomiclong.operations.MergeOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomiclong.operations.SetBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomiclong.operations.SetOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomicreference.operations.AbstractAtomicReferenceOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomicreference.operations.ContainsOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomicreference.operations.MergeBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomicreference.operations.MergeOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomicreference.operations.SetAndGetOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomicreference.operations.SetBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.atomicreference.operations.SetOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.lock.operations.AwaitBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.lock.operations.LocalLockCleanupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.lock.operations.LockBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.lock.operations.LockReplicationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.lock.operations.UnlockBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.lock.operations.UnlockIfLeaseExpiredOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDetachMemberOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreReplicationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.crdt.AbstractCRDTReplicationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.crdt.pncounter.operations.AbstractPNCounterOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.crdt.pncounter.operations.AddOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.crdt.pncounter.operations.GetOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.spi.AbstractLocalOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.spi.Operation
 
writeIntL(byte[], int, int) - Static method in class com.hazelcast.nio.Bits
 
writeJdbcP(String, SupplierEx<? extends Connection>, BiConsumerEx<? super PreparedStatement, ? super T>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
Returns a supplier of processors for Sinks.jdbc(String, SupplierEx, BiConsumerEx).
writeJmsQueueP(SupplierEx<? extends Connection>, FunctionEx<? super Connection, ? extends Session>, BiFunctionEx<? super Session, ? super T, ? extends Message>, BiConsumerEx<? super MessageProducer, ? super Message>, ConsumerEx<? super Session>, String) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
writeJmsTopicP(SupplierEx<? extends Connection>, FunctionEx<? super Connection, ? extends Session>, BiFunctionEx<? super Session, ? super T, ? extends Message>, BiConsumerEx<? super MessageProducer, ? super Message>, ConsumerEx<? super Session>, String) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
writeKafkaP(Properties, String, FunctionEx<? super T, ? extends K>, FunctionEx<? super T, ? extends V>) - Static method in class com.hazelcast.jet.kafka.KafkaProcessors
writeKafkaP(Properties, FunctionEx<? super T, ? extends ProducerRecord<K, V>>) - Static method in class com.hazelcast.jet.kafka.KafkaProcessors
Returns a supplier of processors for KafkaSinks.kafka(Properties, FunctionEx).
writeKeyValueTypes(ObjectDataOutput) - Method in class com.hazelcast.config.CacheConfig
 
writeLeaves(DataOutput, MerkleTreeView) - Static method in class com.hazelcast.wan.merkletree.MerkleTreeUtil
Writes the hashes of the leaves of a Merkle tree into the provided DataOutput
writeListenerConfigurations(ObjectDataOutput) - Method in class com.hazelcast.config.CacheConfig
 
writeListP(String) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
Returns a supplier of processors for Sinks.list(String).
writeLoggerP(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
Convenience for DiagnosticProcessors.writeLoggerP(FunctionEx) that uses toString() as toStringFn.
writeLong(byte[], int, long, boolean) - Static method in class com.hazelcast.nio.Bits
 
writeLong(int, long) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeLong(long, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeLong(int, long, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
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.
writeLongB(byte[], int, long) - Static method in class com.hazelcast.nio.Bits
 
writeLongL(byte[], int, long) - Static method in class com.hazelcast.nio.Bits
 
writeMapP(String) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
Returns a supplier of processors for Sinks.map(String).
writeNamespaceCompatibly(ObjectNamespace, ObjectDataOutput) - Static method in class com.hazelcast.concurrent.lock.ObjectNamespaceSerializationHelper
 
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(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(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(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(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
 
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, 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, 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, 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(ObjectDataOutput, Object) - Static method in class com.hazelcast.nio.IOUtil
 
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 a JSON 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
 
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.
writePortable(PortableWriter) - Method in class com.hazelcast.security.AbstractCredentials
 
writePortableArray(String, Portable[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a an array of Portables.
writePortableInternal(PortableWriter) - Method in class com.hazelcast.security.AbstractCredentials
 
writePortableInternal(PortableWriter) - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
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
 
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
Method similar to JsonGenerator.writeRawValue(String), but potentially more efficient as it may be able to use pre-encoded content (similar to JsonGenerator.writeRaw(SerializableString).
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
JsonGenerator that outputs JSON content using a Writer which handles character encoding.
WriterBasedJsonGenerator(IOContext, int, ObjectCodec, Writer) - Constructor for class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
 
writeRemoteCacheP(String, ClientConfig) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
Returns a supplier of processors for Sinks.remoteCache(String, ClientConfig).
writeRemoteListP(String, ClientConfig) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
Returns a supplier of processors for Sinks.remoteList(String, ClientConfig).
writeRemoteMapP(String, ClientConfig) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
Returns a supplier of processors for Sinks.remoteMap(String, ClientConfig).
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(byte[], int, short, boolean) - Static method in class com.hazelcast.nio.Bits
 
writeShort(int, int) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeShort(int, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
writeShort(int, int, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
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.
writeShortB(byte[], int, short) - Static method in class com.hazelcast.nio.Bits
 
writeShortL(byte[], int, short) - Static method in class com.hazelcast.nio.Bits
 
writeSocketP(String, int, FunctionEx<? super T, ? extends String>, Charset) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
Returns a supplier of processors for Sinks.socket(String, int).
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() - Method in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8JsonGenerator
 
writeStartArray() - 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
Method for writing start marker of an Array value, similar to JsonGenerator.writeStartArray(), but also specifying how many elements will be written for the array before calling JsonGenerator.writeEndArray().
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(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() - 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(Object) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
 
writeStartObject() - 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 a JSON 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 a JSON Object value (character '{'; plus possible white space decoration if pretty-printing is enabled), to represent Java given as the argument.
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(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(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
Method similar to JsonGenerator.writeString(String), but that takes SerializableString which can make this potentially more efficient to call as generator may be able to reuse quoted and/or encoded representation.
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
 
writeStringField(String, String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.JsonGeneratorImpl
 
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
 
WriteThroughEntry(K, V) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap.WriteThroughEntry
 
writeTo(MigrationEvent.MigrationStatus, DataOutput) - Static method in enum com.hazelcast.core.MigrationEvent.MigrationStatus
 
writeTo(Packet, ByteBuffer) - Method in class com.hazelcast.nio.PacketIOHelper
Writes the packet data to the supplied ByteBuffer, up to the buffer's limit.
writeTo(MigrationEndpoint, DataOutput) - Static method in enum com.hazelcast.spi.partition.MigrationEndpoint
 
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
 
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
 
writeUTF(String, String) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes an UTF string.
writeUtf8Char(byte[], int, int) - Static method in class com.hazelcast.nio.Bits
 
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
Writes a String-array.
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.
writeZeroBytes(int) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
WrongTargetException - Exception in com.hazelcast.spi.exception
A RetryableHazelcastException indicating that an operation is executed on a wrong member.
WrongTargetException(Member, Member, int, int, String) - Constructor for exception com.hazelcast.spi.exception.WrongTargetException
 
WrongTargetException(Member, Member, int, int, String, String) - Constructor for exception com.hazelcast.spi.exception.WrongTargetException
 
WrongTargetException(String) - Constructor for exception com.hazelcast.spi.exception.WrongTargetException
 

X

XmlConfigBuilder - Class in com.hazelcast.config
A XML ConfigBuilder implementation.
XmlConfigBuilder(String) - Constructor for class com.hazelcast.config.XmlConfigBuilder
Constructs a XmlConfigBuilder that reads from the provided XML file.
XmlConfigBuilder(InputStream) - Constructor for class com.hazelcast.config.XmlConfigBuilder
Constructs a XmlConfigBuilder that reads from the given InputStream.
XmlConfigBuilder(URL) - Constructor for class com.hazelcast.config.XmlConfigBuilder
Constructs a XMLConfigBuilder that reads from the given URL.
XmlConfigBuilder() - Constructor for class com.hazelcast.config.XmlConfigBuilder
Constructs a XmlConfigBuilder that tries to find a usable XML configuration file.
XmlConfigBuilder(XmlConfigLocator) - Constructor for class com.hazelcast.config.XmlConfigBuilder
Constructs a XmlConfigBuilder that loads the configuration with the provided XmlConfigLocator.
XmlConfigLocator - Class in com.hazelcast.config
Support class for the XmlConfigBuilder that locates the XML configuration: system property working directory classpath default
XmlConfigLocator() - Constructor for class com.hazelcast.config.XmlConfigLocator
 
XmlGenerator(StringBuilder) - Constructor for class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
xmlToJavaName(String) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 

Y

YAML_DIRECTIVE - Static variable in class com.hazelcast.org.snakeyaml.engine.v1.tokens.DirectiveToken
 
YamlConfigBuilder - Class in com.hazelcast.config
A YAML ConfigBuilder implementation.
YamlConfigBuilder(String) - Constructor for class com.hazelcast.config.YamlConfigBuilder
Constructs a YamlConfigBuilder that reads from the provided YAML file.
YamlConfigBuilder(InputStream) - Constructor for class com.hazelcast.config.YamlConfigBuilder
Constructs a YAMLConfigBuilder that reads from the given InputStream.
YamlConfigBuilder(URL) - Constructor for class com.hazelcast.config.YamlConfigBuilder
Constructs a YamlConfigBuilder that reads from the given URL.
YamlConfigBuilder() - Constructor for class com.hazelcast.config.YamlConfigBuilder
Constructs a YamlConfigBuilder that tries to find a usable YAML configuration file.
YamlConfigBuilder(YamlConfigLocator) - Constructor for class com.hazelcast.config.YamlConfigBuilder
Constructs a YamlConfigBuilder that loads the configuration with the provided YamlConfigLocator.
YamlConfigLocator - Class in com.hazelcast.config
Support class for the YamlConfigBuilder that locates the YAML configuration: system property working directory classpath default
YamlConfigLocator() - Constructor for class com.hazelcast.config.YamlConfigLocator
 
YamlConfigLocator(boolean) - Constructor for class com.hazelcast.config.YamlConfigLocator
 
YamlDomChecker - Class in com.hazelcast.config.yaml
Utility class for checking the provided YAML DOM for null scalar values and mappings or sequences with null child nodes.
YamlEngineException - Exception in com.hazelcast.org.snakeyaml.engine.v1.exceptions
 
YamlEngineException(String) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v1.exceptions.YamlEngineException
 
YamlEngineException(Throwable) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v1.exceptions.YamlEngineException
 
YamlEngineException(String, Throwable) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v1.exceptions.YamlEngineException
 
yamlImplicitResolvers - Variable in class com.hazelcast.org.snakeyaml.engine.v1.resolver.JsonScalarResolver
 
YamlUnicodeReader - Class in com.hazelcast.org.snakeyaml.engine.v1.api
Generic unicode textreader, which will use BOM mark to identify the encoding to be used.
YamlUnicodeReader(InputStream) - Constructor for class com.hazelcast.org.snakeyaml.engine.v1.api.YamlUnicodeReader
 
YamlVersionException - Exception in com.hazelcast.org.snakeyaml.engine.v1.exceptions
 
YamlVersionException(SpecVersion) - Constructor for exception com.hazelcast.org.snakeyaml.engine.v1.exceptions.YamlVersionException
 

Z

zeroOutMs(long) - Static method in class com.hazelcast.util.TimeUtil
Cleans the milliseconds info from the timestamp
ZoneAwareMemberGroupFactory - Class in com.hazelcast.partition.membergroup
ZoneAwareMemberGroupFactory is responsible for MemberGroups creation according to the host metadata provided by DiscoveryStrategy.discoverLocalMetadata()
ZoneAwareMemberGroupFactory() - Constructor for class com.hazelcast.partition.membergroup.ZoneAwareMemberGroupFactory
 

_

_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
 
_asciiBytes(String) - Static method in class com.hazelcast.com.fasterxml.jackson.core.base.ParserMinimalBase
 
_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
We will hold on to decoded binary data, for duration of current event, so that multiple calls to ParserBase.getBinaryValue(com.hazelcast.com.fasterxml.jackson.core.Base64Variant) will not need to decode data more than once.
_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
_bytes - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.JsonStringEncoder
Lazily-constructed builder used for UTF-8 encoding of text values (quoted and unquoted)
_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.
_cfgNumbersAsStrings - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
Flag set to indicate that implicit conversion from number to JSON String is needed (as per JsonGenerator.Feature.WRITE_NUMBERS_AS_STRINGS).
_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.
_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.
_charBuffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
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
Configuration that determines whether state of parsers is first verified to see if parser already points to a token (that is, JsonParser.hasCurrentToken() returns true), and if so that token is first return before JsonParser.nextToken() is called.
_checkInvalidCopy(Class<?>) - Method in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
 
_checkParentPath() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
 
_checkPropertyParentPath() - Method in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
Specialized variant of FilteringGeneratorDelegate._checkParentPath() used when checking parent for a property name to be included with value: rules are slightly different.
_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
Overridable factory method called to instantiate an appropriate PrettyPrinter for case of "just use the default one", when GeneratorBase.useDefaultPrettyPrinter() is called.
_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
Helper method for constructing JsonParseExceptions based on current state of the parser
_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
 
_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.JsonFactory
 
_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
Last token retrieved via ParserMinimalBase.nextToken(), if any.
_currToken - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
Last token retrieved via FilteringParserDelegate.nextToken(), if any.
_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
 
_encoderRef - 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.
_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
In cases where FilteringParserDelegate._headContext is "ahead" of context exposed to caller, this context points to what is currently exposed to caller.
_factoryFeatures - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonFactory
Currently enabled factory features.
_features - Variable in class com.hazelcast.com.fasterxml.jackson.core.base.GeneratorBase
Bit flag composed of bits that indicate which JsonGenerator.Features are enabled.
_features - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonParser
Bit flag composed of bits that indicate which JsonParser.Features are enabled.
_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
Method similar to NonBlockingJsonParser._finishToken(), but called when no more input is available, and end-of-input has been detected.
_firstName - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.DupDetector
 
_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
 
_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.ParserMinimalBase
 
_hashCode - Variable in class com.hazelcast.com.fasterxml.jackson.core.sym.Name
 
_hashSeed - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.ReaderBasedJsonParser
 
_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
During traversal this is the actual "open" parse tree, which sometimes is the same as FilteringParserDelegate._exposedContext, and at other times is ahead of it.
_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
 
_includeImmediateParent - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringGeneratorDelegate
Deprecated.
_includeImmediateParent - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
Deprecated.
_includePath - 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.
_includePath - 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.
_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.
_index - Variable in class com.hazelcast.com.fasterxml.jackson.core.JsonStreamContext
Index of the currently processed entry.
_inputBuffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
This buffer is actually provided via NonBlockingInputFeeder
_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.
_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
 
_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
Last cleared token, if any: that is, value that was in effect when ParserMinimalBase.clearCurrentToken() was called.
_lastClearedToken - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
Last cleared token, if any: that is, value that was in effect when FilteringParserDelegate.clearCurrentToken() was called.
_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
 
_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
Value of NonBlockingJsonParserBase._majorState after completing a scalar value
_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
Number of tokens for which TokenFilter.INCLUDE_ALL has been returned
_matchCount - Variable in class com.hazelcast.com.fasterxml.jackson.core.filter.FilteringParserDelegate
Number of tokens for which TokenFilter.INCLUDE_ALL has been returned.
_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
Strength of match with DataFormatMatcher._match
_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.
_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
Temporary buffer that is needed if field name is accessed using ParserMinimalBase.getTextCharacters() method (instead of String returning alternatives)
_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.
_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
Value of ParserBase._inputPtr at the time when the first character of name token was read.
_nameStartOffset - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.UTF8StreamJsonParser
Value of ParserBase._inputPtr at the time when the first character of name token was read.
_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
Index of the next parser in JsonParserSequence._parsers.
_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.JsonFactory
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
Intermediate buffer in which contents are buffered before being written using UTF8JsonGenerator._outputStream.
_outputBuffer - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.WriterBasedJsonGenerator
Intermediate buffer in which contents are buffered before being written using WriterBasedJsonGenerator._writer.
_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.
_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 chars 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)
_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.
_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
 
_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.JsonGenerationException
 
_processor - Variable in exception com.hazelcast.com.fasterxml.jackson.core.JsonParseException
 
_ptr - Variable in class com.hazelcast.com.fasterxml.jackson.core.format.InputAccessor.Std
Pointer to next available buffered byte in InputAccessor.Std._buffer.
_ptr - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.UTF32Reader
 
_qbuf - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.JsonStringEncoder
Temporary buffer used for composing quote/escape sequences
_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.
_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
 
_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
Helper method used for constructing and throwing JsonGenerationException with given base message.
_reportErrorToken(String) - Method in class com.hazelcast.com.fasterxml.jackson.core.json.async.NonBlockingJsonParser
 
_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
 
_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.JsonParseException
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.util.MinimalPrettyPrinter
 
_secondName - Variable in class com.hazelcast.com.fasterxml.jackson.core.json.DupDetector
 
_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
 
_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.
_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
 
_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
 
_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
_text - Variable in class com.hazelcast.com.fasterxml.jackson.core.io.JsonStringEncoder
Lazily constructed text buffer used to produce JSON encoded Strings as characters (without UTF-8 encoding)
_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)
_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.ParserMinimalBase
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
 
_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
 
_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.
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
Skip navigation links

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