Package | Description |
---|---|
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.concurrent.atomiclong.operations |
This package contains the operations on the IAtomicLong.
|
com.hazelcast.concurrent.atomicreference.operations |
This package contains the operations on the IAtomicReference.
|
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 |
This package contains the operations on the ICountDownLatch.
|
com.hazelcast.concurrent.lock | |
com.hazelcast.concurrent.lock.operations |
This package contains the operations on the ILock.
|
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 |
This package contains the operations on the ISemaphore.
|
com.hazelcast.config |
Provides classes for configuring HazelcastInstance.
|
com.hazelcast.crdt |
This package contains CRDT (conflict-free replicated data type)
implementations based on the Hazelcast infrastructure.
|
com.hazelcast.crdt.pncounter |
This package contains the PN (Positive-Negative) CRDT counter
implementation.
|
com.hazelcast.crdt.pncounter.operations |
Contains the operations for the
PNCounter member-side
implementation. |
com.hazelcast.instance |
This package contains Hazelcast Instance functionality.
|
com.hazelcast.jet.core |
Jet's Core API.
|
com.hazelcast.map.eviction |
This package contains eviction specific classes.
|
com.hazelcast.map.merge |
Contains out-of-the-box merge policies for
IMap . |
com.hazelcast.nio |
This package contains classes related to New IO
|
com.hazelcast.nio.serialization |
Contains interfaces/classes related to serialization;
such as serializer interfaces, input/output streams.
|
com.hazelcast.query |
Contains interfaces/classes related to Hazelcast query and indexing support.
|
com.hazelcast.scheduledexecutor |
This package contains ScheduledExecutorService functionality for Hazelcast.
|
com.hazelcast.spi |
Provides interfaces/classes for the Hazelcast SPI for building distributed data structures and services.
|
com.hazelcast.spi.impl | |
com.hazelcast.spi.impl.merge | |
com.hazelcast.spi.merge |
This package contains interfaces and classes of the split-brain merging SPI.
|
com.hazelcast.version |
This package contains classes to support the versioning API.
|
com.hazelcast.wan |
This package contains the WAN replication API
|
Modifier and Type | Class and Description |
---|---|
class |
HazelcastExpiryPolicy
Hazelcast provides overloads of the typical cache operations with a custom
ExpiryPolicy parameter.This class provides a custom implementation of an ExpiryPolicy to
react on all three types of policies:
Create
Access
Update
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractAtomicLongOperation |
class |
AddAndGetOperation |
class |
AddBackupOperation |
class |
AtomicLongBackupAwareOperation |
class |
AtomicLongReplicationOperation |
class |
GetAndAddOperation |
Modifier and Type | Class and Description |
---|---|
class |
AbstractAlterOperation |
class |
AbstractAtomicReferenceOperation |
class |
AlterAndGetOperation |
class |
AlterOperation |
class |
ApplyOperation |
class |
AtomicReferenceBackupAwareOperation |
class |
AtomicReferenceReplicationOperation |
class |
CompareAndSetOperation |
class |
ContainsOperation |
class |
GetAndAlterOperation |
class |
GetAndSetOperation |
class |
IsNullOperation |
class |
MergeBackupOperation
Creates backups for merged atomic references after split-brain healing with a
SplitBrainMergePolicy . |
class |
MergeOperation
Merges a
SplitBrainMergeTypes.AtomicReferenceMergeTypes for split-brain healing with a SplitBrainMergePolicy . |
class |
SetAndGetOperation |
class |
SetBackupOperation |
class |
SetOperation |
Modifier and Type | Class and Description |
---|---|
class |
CountDownLatchContainer |
Modifier and Type | Class and Description |
---|---|
class |
AwaitOperation |
class |
CountDownLatchBackupOperation |
class |
CountDownLatchReplicationOperation |
class |
CountDownOperation |
class |
GetCountOperation |
class |
SetCountOperation |
Modifier and Type | Class and Description |
---|---|
class |
LockStoreImpl |
Modifier and Type | Class and Description |
---|---|
class |
AbstractLockOperation |
class |
AwaitBackupOperation |
class |
BeforeAwaitBackupOperation |
class |
BeforeAwaitOperation |
class |
GetLockCountOperation |
class |
GetRemainingLeaseTimeOperation |
class |
IsLockedOperation |
class |
LocalLockCleanupOperation |
class |
LockBackupOperation |
class |
LockOperation |
class |
LockReplicationOperation |
class |
SignalBackupOperation |
class |
SignalOperation |
class |
UnlockBackupOperation |
class |
UnlockIfLeaseExpiredOperation |
class |
UnlockOperation |
Modifier and Type | Class and Description |
---|---|
class |
SemaphoreContainer |
Modifier and Type | Class and Description |
---|---|
class |
AcquireBackupOperation |
class |
AcquireOperation |
class |
AvailableOperation |
class |
DrainBackupOperation |
class |
DrainOperation |
class |
IncreaseBackupOperation |
class |
IncreaseOperation |
class |
InitBackupOperation |
class |
InitOperation |
class |
ReduceBackupOperation |
class |
ReduceOperation |
class |
ReleaseBackupOperation |
class |
ReleaseOperation |
class |
SemaphoreBackupAwareOperation |
class |
SemaphoreBackupOperation |
class |
SemaphoreDetachMemberBackupOperation |
class |
SemaphoreDetachMemberOperation |
class |
SemaphoreOperation |
class |
SemaphoreReplicationOperation |
Modifier and Type | Class and Description |
---|---|
class |
AbstractBasicConfig<T extends AbstractBasicConfig>
Provides a basic configuration for a split-brain aware data structure.
|
class |
AtomicLongConfig
Contains the configuration for an
AtomicLong . |
class |
AtomicReferenceConfig
Contains the configuration for an
AtomicReference . |
class |
CachePartitionLostListenerConfig
Configuration for CachePartitionLostListener
|
class |
CachePartitionLostListenerConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
CacheSimpleConfig
Simple configuration to hold parsed XML configuration.
|
static class |
CacheSimpleConfig.ExpiryPolicyFactoryConfig
Represents configuration for "ExpiryPolicyFactory".
|
static class |
CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
Represents duration configuration with duration amount and time unit
for the "TimedExpiryPolicyFactoryConfig".
|
static class |
CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
Represents configuration for time based "ExpiryPolicyFactory" with duration and time unit.
|
class |
CacheSimpleConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
CacheSimpleEntryListenerConfig
Simple configuration to hold parsed listener config.
|
class |
CacheSimpleEntryListenerConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
CardinalityEstimatorConfig
Configuration options for the
CardinalityEstimator |
class |
CollectionConfig<T extends CollectionConfig>
Provides configuration service for Collection.
|
class |
CountDownLatchConfig
Contains the configuration for an
ICountDownLatch . |
class |
DurableExecutorConfig
Contains the configuration for an
DurableExecutorService . |
class |
EntryListenerConfig
Configuration for EntryListener
|
static class |
EntryListenerConfig.MapListenerToEntryListenerAdapter
Wraps a MapListener into an EntryListener.
|
class |
EntryListenerConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
EventJournalConfig
Configuration for an event journal.
|
class |
ExecutorConfig
Contains the configuration for an
IExecutorService . |
class |
ExecutorConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
FlakeIdGeneratorConfig
The
FlakeIdGeneratorConfig contains the configuration for the member
regarding Flake ID Generator . |
class |
FlakeIdGeneratorConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
HotRestartConfig
Configures the Hot Restart Persistence per Hazelcast data structure.
|
class |
ItemListenerConfig
Contains the configuration for an Item Listener.
|
class |
ItemListenerConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
ListConfig
Contains the configuration for an
IList . |
class |
ListConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
ListenerConfig
Contains the configuration for an
EventListener . |
class |
ListenerConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
LockConfig
Contains the configuration for the
ILock . |
class |
MapAttributeConfig
Contains the configuration of a custom attribute that will be extracted from a Map's entry using a given ValueExtractor.
|
class |
MapAttributeConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
MapConfig
Contains the configuration for an
IMap . |
class |
MapConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
MapIndexConfig
Contains the configuration for an index in a map.
|
class |
MapIndexConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
MapPartitionLostListenerConfig
Configuration for MapPartitionLostListener
|
class |
MapPartitionLostListenerConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
MapStoreConfig
Contains the configuration for a Map Store.
|
class |
MapStoreConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
MergePolicyConfig
Configuration for
SplitBrainMergePolicy . |
class |
MultiMapConfig
Configuration for MultiMap.
|
class |
MultiMapConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
NearCacheConfig
Contains the configuration for a Near Cache.
|
class |
NearCacheConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
NearCachePreloaderConfig
Configuration for eviction.
|
class |
PartitioningStrategyConfig
Contains the configuration for partitioning strategy.
|
class |
PartitioningStrategyConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
PNCounterConfig
Configuration for a
PNCounter |
class |
PredicateConfig
Contains the configuration for an
Predicate . |
class |
QueryCacheConfig
Contains configuration for
QueryCache . |
class |
QueueConfig
Contains the configuration for an
IQueue . |
class |
QueueConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
QueueStoreConfig
Configuration for the
QueueStore . |
class |
QueueStoreConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
QuorumConfig
Configuration for cluster quorum, a means to protect consistency of data from network partitions.
|
class |
QuorumListenerConfig
Confiquration class for
QuorumListener
IMPORTANT: The term "quorum" simply refers to the count of members in the cluster required for an operation to succeed. |
class |
ReliableTopicConfig
Configuration for a reliable
ITopic . |
class |
ReplicatedMapConfig
Contains the configuration for an
ReplicatedMap |
class |
RingbufferConfig
Contains the configuration for the
Ringbuffer . |
class |
RingbufferStoreConfig
Configuration for the
RingbufferStore . |
class |
ScheduledExecutorConfig
Configuration options for the
IScheduledExecutorService . |
class |
SemaphoreConfig
Contains the configuration for an
ISemaphore . |
class |
SemaphoreConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
SetConfig
Contains the configuration for an
ISet . |
class |
SetConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
TopicConfig
Contains the configuration for a
ITopic . |
class |
TopicConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
WanConsumerConfig
Config to be used by WanReplicationConsumer instances (EE only).
|
class |
WanPublisherConfig
Configuration object for WAN publishers.
|
class |
WanReplicationConfig
Configuration for WAN replication.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractCRDTReplicationOperation<T extends IdentifiedDataSerializable>
Base class for CRDT replication operations.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractCRDTReplicationOperation<T extends IdentifiedDataSerializable>
Base class for CRDT replication operations.
|
Modifier and Type | Class and Description |
---|---|
class |
PNCounterImpl
PN (Positive-Negative) CRDT counter where each replica is identified by
a String.
|
class |
PNCounterReplicationOperation
CRDT replication operation for a
PNCounter . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractPNCounterOperation
Base class for
PNCounter query and
mutation operation implementations. |
class |
AddOperation
Addition/subtraction operation for a
PNCounter . |
class |
CRDTTimestampedLong
Response for CRDT PN counter operations which contains the PN counter
value as well as the current replica vector clock.
|
class |
GetOperation
Query operation to retrieve the current value of the
PNCounter . |
Modifier and Type | Class and Description |
---|---|
class |
MemberImpl |
Modifier and Type | Class and Description |
---|---|
class |
DAG
Describes a computation to be performed by the Jet computation engine.
|
class |
Edge
|
class |
Vertex
Represents a unit of data processing in a Jet computation job.
|
Modifier and Type | Class and Description |
---|---|
class |
LFUEvictionPolicy
LFU eviction policy for an
IMap |
class |
LRUEvictionPolicy
LRU eviction policy for an
IMap |
class |
RandomEvictionPolicy
Random eviction policy for an
IMap |
Modifier and Type | Class and Description |
---|---|
class |
HigherHitsMapMergePolicy
Merges map entries from source to destination map if the source entry
has more hits than the destination one.
|
class |
IgnoreMergingEntryMapMergePolicy
Ignores the merging entry while collecting merge-needed entries on merging side.
|
class |
LatestUpdateMapMergePolicy
Merges map entries from source to destination map if the source entry
was updated more recently than the destination entry.
|
class |
PassThroughMergePolicy
Merges map entries from source to destination directly unless the merging entry is
null . |
class |
PutIfAbsentMapMergePolicy
Merges map entries from source to destination if they don't exist in the destination map.
|
Modifier and Type | Class and Description |
---|---|
class |
Address
Represents an address of a member in the cluster.
|
Modifier and Type | Method and Description |
---|---|
IdentifiedDataSerializable |
DataSerializableFactory.create(int typeId)
Creates an IdentifiedDataSerializable instance using given type ID
|
Modifier and Type | Class and Description |
---|---|
class |
PagingPredicate<K,V>
This class is a special Predicate which helps to get a page-by-page result of a query.
|
class |
PartitionPredicate<K,V>
A
Predicate that restricts the execution of a Predicate to a single Partition. |
class |
SqlPredicate
This class contains methods related to conversion of sql query to predicate.
|
class |
TruePredicate<K,V>
A
Predicate which always returns true. |
Modifier and Type | Interface and Description |
---|---|
interface |
ScheduledTaskStatistics
Statistics and timing info for a
IScheduledFuture accessible through IScheduledFuture.getStats() |
Modifier and Type | Class and Description |
---|---|
class |
ScheduledTaskHandler
Resource handler pointing to a
IScheduledFuture . |
Modifier and Type | Interface and Description |
---|---|
interface |
OperationFactory
A Factory for creating
Operation instances. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractLocalOperation
Abstract class for local operations, which should not be serializable.
|
class |
DistributedObjectNamespace
Default
ObjectNamespace implementation for DistributedObject . |
class |
OperationControl
Content of an Operation Control packet:
a list of operations the remote member started on this member which are still running;
a list of operations this member wants to cancel on the remote member.
Operations are identified by their call ID.
|
Modifier and Type | Class and Description |
---|---|
class |
com.hazelcast.spi.impl.AbstractNamedOperation |
Modifier and Type | Class and Description |
---|---|
class |
com.hazelcast.spi.impl.merge.AbstractSplitBrainMergePolicy<V,T extends MergingValue<V>>
Abstract implementation of
SplitBrainMergePolicy for the out-of-the-box merge policies. |
Modifier and Type | Class and Description |
---|---|
class |
DiscardMergePolicy<V,T extends MergingValue<V>>
Merges only entries from the destination data structure and discards all entries from the source data structure.
|
class |
ExpirationTimeMergePolicy<V,T extends MergingExpirationTime<V>>
Merges data structure entries from source to destination data structure if the source entry
will expire later than the destination entry.
|
class |
HigherHitsMergePolicy<V,T extends MergingHits<V>>
Merges data structure entries from source to destination data structure if the source entry
has more hits than the destination one.
|
class |
HyperLogLogMergePolicy
Only available for HyperLogLog backed
CardinalityEstimator . |
class |
LatestAccessMergePolicy<V,T extends MergingLastAccessTime<V>>
Merges data structure entries from source to destination data structure if the source entry
has been accessed more recently than the destination entry.
|
class |
LatestUpdateMergePolicy<V,T extends MergingLastUpdateTime<V>>
Merges data structure entries from source to destination data structure if the source entry
was updated more frequently than the destination entry.
|
class |
PutIfAbsentMergePolicy<V,T extends MergingValue<V>>
Merges data structure entries from source to destination if they don't exist in the destination data structure.
|
Modifier and Type | Class and Description |
---|---|
class |
MemberVersion
Determines the Hazelcast codebase version in terms of major.minor.patch version.
|
class |
Version
A generic version to be used with
VersionAware classes. |
Modifier and Type | Class and Description |
---|---|
class |
WanReplicationEvent
Event class used to transmit the actual event object
|
Copyright © 2018 Hazelcast, Inc.. All rights reserved.