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
 
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.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
 
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 - 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(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 HazelcastWriters.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
assertRunningOnPartitionThread() - Static method in class com.hazelcast.util.ThreadUtil
 
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
 
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 computes the arithmetic mean of the double values it obtains by applying getDoubleValueFn to each item.
averagingLong(ToLongFunctionEx<? super T>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that computes the arithmetic mean of the long values it obtains by applying getLongValueFn to each item.
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.config
The AWSConfig contains the configuration for AWS join mechanism.
AwsConfig() - Constructor for class com.hazelcast.config.AwsConfig
 
AwsConfig(AwsConfig) - Constructor for class com.hazelcast.config.AwsConfig
 
AwsDiscoveryStrategy - Class in com.hazelcast.aws
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.
AwsProperties.PortValueValidator - Class in com.hazelcast.aws
Validator for valid network ports
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 S>) - 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 computes the bottom n items calculated 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 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
Creates and returns a pipeline stage that performs the co-grouping and aggregation of pipeline stages registered with this builder object.
build(AggregateOperation<?, R>) - Method in class com.hazelcast.jet.pipeline.GroupAggregateBuilder1
Convenience for build(aggrOp, mapToOutputFn) which emits Map.Entrys as output.
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.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(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.jet.server.JetCommandLine
 
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.
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.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.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.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.
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 concatenates the input items into a string.
concatenating(CharSequence) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that concatenates the input items into a string with the given delimiter.
concatenating(CharSequence, CharSequence, CharSequence) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
Returns an aggregate operation that concatenates the input items into a string with the given delimiter.
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
 
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 S>, BiConsumerEx<? super S, ? super SourceBuilder.SourceBuffer<T>>, ConsumerEx<? super S>, 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.
convenientTimestampedSourceP(FunctionEx<? super Processor.Context, ? extends S>, BiConsumerEx<? super S, ? super SourceBuilder.TimestampedSourceBuffer<T>>, EventTimePolicy<? super T>, ConsumerEx<? super S>, 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.
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 computes the number of items.
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
 
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.
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 give