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.cache.impl |
Hazelcast JSR-107 aka JCache implementation
|
com.hazelcast.cache.impl.event |
Event classes to define listenters for JCache other than EntryListener
|
com.hazelcast.cache.impl.eviction | |
com.hazelcast.cache.impl.journal | |
com.hazelcast.cardinality |
This package contains Cardinality Estimator functionality for Hazelcast.
|
com.hazelcast.cardinality.impl | |
com.hazelcast.client |
Contains classes/interfaces related to Client
|
com.hazelcast.client.cache.impl |
Hazelcast JSR-107 aka JCache implementation client side
|
com.hazelcast.client.cache.impl.nearcache.invalidation | |
com.hazelcast.client.config |
Contains classes related to config for com.hazelcast.client
|
com.hazelcast.client.console |
This package contains ClientConsoleApp
|
com.hazelcast.client.cp.internal.session |
Contains client-side impl of the Raft proxy session manager
|
com.hazelcast.client.impl |
Implementation classes of the com.hazelcast.client interfaces
|
com.hazelcast.client.impl.clientside |
Contains most of the client side HazelcastInstance implementation functionality.
|
com.hazelcast.client.impl.protocol.exception | |
com.hazelcast.client.impl.protocol.task |
Client tasks associated with requests.
|
com.hazelcast.client.impl.protocol.task.atomiclong |
Client protocol tasks implementations for AtomicLong
|
com.hazelcast.client.impl.protocol.task.atomicreference |
Client protocol tasks implementations for AtomicReference
|
com.hazelcast.client.impl.protocol.task.cache |
Client protocol tasks implementations for JCache
|
com.hazelcast.client.impl.protocol.task.cardinality | |
com.hazelcast.client.impl.protocol.task.condition |
Client protocol tasks implementations for Condition
|
com.hazelcast.client.impl.protocol.task.countdownlatch |
Client protocol tasks implementations for CountDownLatch
|
com.hazelcast.client.impl.protocol.task.crdt.pncounter | |
com.hazelcast.client.impl.protocol.task.dynamicconfig | |
com.hazelcast.client.impl.protocol.task.executorservice |
Client protocol tasks implementations for ExecutorService
|
com.hazelcast.client.impl.protocol.task.executorservice.durable | |
com.hazelcast.client.impl.protocol.task.list |
Client protocol tasks implementations for List
|
com.hazelcast.client.impl.protocol.task.lock |
Client protocol tasks implementations for ILock
|
com.hazelcast.client.impl.protocol.task.map |
Client protocol tasks implementations for map
|
com.hazelcast.client.impl.protocol.task.mapreduce |
Client protocol tasks implementations for map reduce
|
com.hazelcast.client.impl.protocol.task.multimap |
Client protocol tasks implementations for multi map
|
com.hazelcast.client.impl.protocol.task.queue |
Client protocol tasks implementations for Queue
|
com.hazelcast.client.impl.protocol.task.replicatedmap |
Client protocol tasks implementations for ReplicatedMap
|
com.hazelcast.client.impl.protocol.task.ringbuffer |
Client protocol tasks implementations for Ringbuffer
|
com.hazelcast.client.impl.protocol.task.scheduledexecutor | |
com.hazelcast.client.impl.protocol.task.semaphore |
Client protocol tasks implementations for Semaphore
|
com.hazelcast.client.impl.protocol.task.set |
Client protocol tasks implementations for set
|
com.hazelcast.client.impl.protocol.task.topic |
Client protocol tasks implementations for Topic
|
com.hazelcast.client.impl.protocol.task.transaction |
Client protocol tasks implementations for Transaction related
|
com.hazelcast.client.impl.querycache |
Contains query cache internal implementations for client side.
|
com.hazelcast.client.map.impl.nearcache.invalidation | |
com.hazelcast.client.proxy |
This package contains client side proxy implementations of the different Hazelcast data structures
and operation types
|
com.hazelcast.client.proxy.txn |
Contains classes related to proxy for client transactions
|
com.hazelcast.client.proxy.txn.xa |
Contains classes related to proxy for XA
|
com.hazelcast.client.spi |
Contains classes/interfaces related to the Hazelcast client Service Provider Interface.
|
com.hazelcast.client.spi.impl |
Provides util classes for the Hazelcast client SPI.
|
com.hazelcast.client.spi.impl.listener | |
com.hazelcast.client.util |
This package contains some utility classes and the base implementations of the
loadbalancer implementations
|
com.hazelcast.cluster.memberselector |
This package contains several
MemberSelector implementations. |
com.hazelcast.collection.impl.collection | |
com.hazelcast.collection.impl.collection.operations | |
com.hazelcast.collection.impl.common | |
com.hazelcast.collection.impl.list |
This package contains IList functionality for Hazelcast.
|
com.hazelcast.collection.impl.queue | |
com.hazelcast.collection.impl.queue.operations |
This package contains the IQueue operations
|
com.hazelcast.collection.impl.set |
This package contains ISet functionality for Hazelcast.
|
com.hazelcast.collection.impl.txncollection | |
com.hazelcast.collection.impl.txnlist | |
com.hazelcast.collection.impl.txnqueue | |
com.hazelcast.collection.impl.txnset | |
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 |
This package contains the operations on the IAtomicLong.
|
com.hazelcast.concurrent.atomicreference |
This package contains IAtomicReferece functionality for Hazelcast.
The IAtomicReference is the distributed version of the AtomicReference . |
com.hazelcast.concurrent.countdownlatch |
This package contains ICountDownLatch functionality for Hazelcast.
The ICountDownLatch is the distributed version of the CountDownLatch . |
com.hazelcast.concurrent.idgen |
This package contains IdGenerator functionality for Hazelcast.
|
com.hazelcast.concurrent.lock | |
com.hazelcast.concurrent.semaphore |
This package contains ISemaphore functionality for Hazelcast.
The ISemaphore is the distributed version of the Semaphore . |
com.hazelcast.config |
Provides classes for configuring HazelcastInstance.
|
com.hazelcast.config.properties |
This package contains the public API for properties defined in the XML configuration.
|
com.hazelcast.console |
This package contains classes related to ConsoleApp
|
com.hazelcast.core |
Provides core API interfaces/classes.
|
com.hazelcast.cp |
Contains public APIs of the CP subsystem
|
com.hazelcast.cp.exception |
Contains exceptions that can be thrown by APIs of the CP subsystem
|
com.hazelcast.cp.internal |
Contains implementation of the CP subsystem
|
com.hazelcast.cp.internal.datastructures.atomiclong |
Contains service classes for the Raft-based
IAtomicLong implementation |
com.hazelcast.cp.internal.datastructures.atomiclong.client |
Client protocol tasks for the Raft-based AtomicLong implementation
|
com.hazelcast.cp.internal.datastructures.atomiclong.operation |
Contains operations for the Raft-based
IAtomicLong implementation |
com.hazelcast.cp.internal.datastructures.atomiclong.proxy |
Contains
IAtomicLong functionality
based on the Raft algorithm. |
com.hazelcast.cp.internal.datastructures.atomicref |
Contains service classes for the Raft-based
IAtomicReference implementation |
com.hazelcast.cp.internal.datastructures.atomicref.client |
Client protocol tasks for the Raft-based AtomicReference implementation
|
com.hazelcast.cp.internal.datastructures.atomicref.proxy |
Contains
IAtomicReference functionality
based on the Raft algorithm. |
com.hazelcast.cp.internal.datastructures.countdownlatch |
Contains service classes for the Raft-based
ICountDownLatch implementation |
com.hazelcast.cp.internal.datastructures.countdownlatch.client |
Client protocol tasks for the Raft-based CountDownLatch implementation
|
com.hazelcast.cp.internal.datastructures.countdownlatch.proxy |
Contains
IAtomicLong functionality
based on the Raft algorithm. |
com.hazelcast.cp.internal.datastructures.exception |
Contains internal exceptions related to Raft-based data structure
implementations
|
com.hazelcast.cp.internal.datastructures.lock |
Contains service classes for the Raft-based
ILock
and FencedLock implementation |
com.hazelcast.cp.internal.datastructures.lock.client |
Client protocol tasks for the Raft-based Lock implementation
|
com.hazelcast.cp.internal.datastructures.lock.proxy |
Contains
ILock functionality
based on the Raft algorithm. |
com.hazelcast.cp.internal.datastructures.semaphore |
Contains service classes for the Raft-based
ISemaphore implementation |
com.hazelcast.cp.internal.datastructures.semaphore.client |
Client protocol tasks for the Raft-based Semaphore implementation
|
com.hazelcast.cp.internal.datastructures.semaphore.proxy |
Contains
ISemaphore functionality
based on the Raft algorithm. |
com.hazelcast.cp.internal.datastructures.spi.client |
Contains utilities for creating Raft groups and fetching Raft group ids
from clients
|
com.hazelcast.cp.internal.exception |
Contains internal exceptions that are being used
by the CP subsystem implementation
|
com.hazelcast.cp.internal.operation |
Contains operations for the Raft Invocation SPI
|
com.hazelcast.cp.internal.raft.exception |
Contains exception classes that can be thrown by the CP subsystem
|
com.hazelcast.cp.internal.raft.impl |
Contains implementation classes of the Raft algorithm
|
com.hazelcast.cp.internal.raft.impl.command |
Contains
RaftGroupCmd
implementations that are used by the core Raft algorithm implementation |
com.hazelcast.cp.internal.raft.impl.dto |
Contains structs that are used in Raft RPCs
|
com.hazelcast.cp.internal.raft.impl.handler |
Contains request/response handler tasks.
|
com.hazelcast.cp.internal.raft.impl.log |
Contains the log abstraction which is maintained by the Raft algorithm
|
com.hazelcast.cp.internal.raft.impl.state |
Contains classes that keep state of Raft nodes
|
com.hazelcast.cp.internal.raft.impl.task |
Contains tasks running on leader or leader-candidates.
|
com.hazelcast.cp.internal.raftop |
Contains operations that are used in Hazelcast's Raft implementation
|
com.hazelcast.cp.internal.session |
Contains service classes
for the Raft-based
ISemaphore implementation |
com.hazelcast.cp.internal.session.client |
Client protocol tasks for the Raft-based Session implementation
|
com.hazelcast.cp.lock |
Contains locking APIs of the CP subsystem
|
com.hazelcast.cp.lock.exception |
Contains exception classes related to the locking API of the CP subsystem
|
com.hazelcast.cp.session |
Contains session abstractions of the CP subsystem
|
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.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.durableexecutor.impl |
Contains the
DurableExecutorService implementation classes. |
com.hazelcast.executor.impl |
This package contains IExecutorService functionality for Hazelcast.
The IExecutorService extends the ExecutorService and provides all kinds
of additional methods related to distributed systems. |
com.hazelcast.flakeidgen |
This package contains Flake ID Generator functionality for Hazelcast.
|
com.hazelcast.flakeidgen.impl | |
com.hazelcast.instance |
This package contains Hazelcast Instance functionality.
|
com.hazelcast.internal.adapter |
Data structure adapters for Near Cache.
|
com.hazelcast.internal.cluster |
Contains the internals for cluster management like discovery, joining etc.
|
com.hazelcast.internal.cluster.fd |
Contains failure detector mechanism and its implementations.
|
com.hazelcast.internal.cluster.impl |
This package contains the implementation of the cluster functionality.
|
com.hazelcast.internal.diagnostics |
Contains functionality what is happening in a HazelcastInstance.
|
com.hazelcast.internal.dynamicconfig |
Classes related to Dynamic Configuration.
|
com.hazelcast.internal.eviction |
Eviction policy implementations.
|
com.hazelcast.internal.jmx |
Contains Hazelcast management bean classes.
|
com.hazelcast.internal.jmx.suppliers |
Contains Hazelcast management bean stat providers.
|
com.hazelcast.internal.journal |
This package contains supporting classes for data structure specific event journals.
|
com.hazelcast.internal.management |
Contains classes to provide data/operation interface for Management Center.
|
com.hazelcast.internal.management.dto |
These contain the DTO object to exchange information with the management center.
|
com.hazelcast.internal.management.request |
Contains requests that made from Management Center.
|
com.hazelcast.internal.nearcache.impl.invalidation |
Invalidations for Near Cache.
|
com.hazelcast.internal.nearcache.impl.store |
Near Cache store implementations.
|
com.hazelcast.internal.partition |
Contains the internals for partition assignment/management, migration, replication etc.
|
com.hazelcast.internal.partition.impl |
Contains the actual implementation of the
InternalPartitionService . |
com.hazelcast.internal.serialization |
Contains the private serialization API + implementation.
|
com.hazelcast.internal.serialization.impl | |
com.hazelcast.internal.usercodedeployment.impl | |
com.hazelcast.internal.usercodedeployment.impl.filter | |
com.hazelcast.internal.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.internal.util.futures |
Re-usable implementations of Futures.
|
com.hazelcast.internal.util.iterator |
Re-usable implementations of Iterators.
|
com.hazelcast.internal.yaml |
Contains classes for loading, parsing YAML documents and building a
YAML specific DOM of
YamlNode instances
The YAML documents are loaded and parsed with the external SnakeYaml
parser, which supports YAML 1.2 documents, and the JSON schema. |
com.hazelcast.json |
Contains Json interface
|
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 |
Contains Hazelcast map module classes.
|
com.hazelcast.map.eviction |
This package contains eviction specific classes.
|
com.hazelcast.map.impl |
Contains implementation specific classes of
com.hazelcast.map package. |
com.hazelcast.map.impl.event | |
com.hazelcast.map.impl.eviction |
This package contains eviction classes.
|
com.hazelcast.map.impl.iterator | |
com.hazelcast.map.impl.journal | |
com.hazelcast.map.impl.nearcache.invalidation | |
com.hazelcast.map.impl.operation |
Package for map operations.
|
com.hazelcast.map.impl.proxy |
Contains map proxy implementation and support classes.
|
com.hazelcast.map.impl.querycache |
Contains query cache internal implementation classes.
|
com.hazelcast.map.impl.querycache.event |
This package contains classes for query cache events.
|
com.hazelcast.map.impl.querycache.publisher |
This package contains classes which are used for
QueryCache
event publishing side. |
com.hazelcast.map.impl.querycache.subscriber |
This package contains classes which are used for
QueryCache
event subscription side. |
com.hazelcast.map.impl.record |
Contains record specific classes.
|
com.hazelcast.map.impl.recordstore | |
com.hazelcast.map.impl.tx |
Contains implementation classes for
TransactionalMap |
com.hazelcast.map.impl.wan |
Contains wan replication event classes
|
com.hazelcast.map.journal |
Contains
EventJournal event interface for IMap. |
com.hazelcast.map.listener |
Contains various
MapListener interfaces. |
com.hazelcast.map.merge |
Contains out-of-the-box merge policies for
IMap . |
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.impl |
This package contains the default implementation for the map reduce framework
internals.
|
com.hazelcast.mapreduce.impl.operation |
This package contains all remote operations that are needed to control work on
supervising or worker nodes.
|
com.hazelcast.mapreduce.impl.task |
This package contains the base implementation for a standard map reduce job.
|
com.hazelcast.multimap.impl |
Contains classes for Hazelcast MultiMap module.
|
com.hazelcast.multimap.impl.operations |
Contains operations for Hazelcast MultiMap module.
|
com.hazelcast.multimap.impl.txn |
This package contains the Transaction behavior for the Multimap.
|
com.hazelcast.nio.serialization |
Contains interfaces/classes related to serialization;
such as serializer interfaces, input/output streams.
|
com.hazelcast.osgi |
This package contains the OSGI functionality contract points for Hazelcast.
|
com.hazelcast.partition |
Contains the partition logic for Hazelcast.
|
com.hazelcast.partition.membergroup |
todo
|
com.hazelcast.partition.strategy |
Packages contains different partitioning strategies.
|
com.hazelcast.query |
Contains interfaces/classes related to Hazelcast query and indexing support.
|
com.hazelcast.query.impl |
Contains the implementation classes of the query functionality.
|
com.hazelcast.quorum |
Contains classes related to cluster quorum.
|
com.hazelcast.quorum.impl |
Contains cluster quorum implementation classes.
|
com.hazelcast.replicatedmap |
Classes for replicated map.
|
com.hazelcast.replicatedmap.impl |
This package contains the implementation of the replicated map service itself and some connection interfaces only used
internally.
|
com.hazelcast.replicatedmap.impl.client |
This package contains classes for client communication on replicated map implementation
|
com.hazelcast.replicatedmap.impl.record |
This package contains the implementation of the backing data storage for the replicated map implementation
|
com.hazelcast.ringbuffer |
Contains the API for the
Ringbuffer . |
com.hazelcast.ringbuffer.impl |
Contains the
Ringbuffer implementation classes. |
com.hazelcast.ringbuffer.impl.operations | |
com.hazelcast.scheduledexecutor |
This package contains ScheduledExecutorService functionality for Hazelcast.
|
com.hazelcast.scheduledexecutor.impl | |
com.hazelcast.security |
Provides interfaces/classes for Hazelcast security implementation.
|
com.hazelcast.spi |
Provides interfaces/classes for the Hazelcast SPI for building distributed data structures and services.
|
com.hazelcast.spi.exception |
Contains exceptions for Hazelcast SPI.
|
com.hazelcast.spi.impl |
Contains implementations for Hazelcast SPI.
|
com.hazelcast.spi.impl.executionservice.impl |
Contains the implementation of the
InternalExecutionService . |
com.hazelcast.spi.impl.merge |
This package contains split-brain related classes.
|
com.hazelcast.spi.impl.operationservice |
Contains the
InternalOperationService API. |
com.hazelcast.spi.impl.operationservice.impl |
Contains the code for the
InternalOperationService implementation. |
com.hazelcast.spi.impl.proxyservice.impl |
Contains the implementation of the
InternalProxyService . |
com.hazelcast.spi.partition |
Contains the SPI for partition logic for Hazelcast.
|
com.hazelcast.spi.serialization |
Contains SPI related to serialization
|
com.hazelcast.spring.cache |
Contains Hazelcast cache classes related to Spring.
|
com.hazelcast.spring.context |
Contains context classes for Spring.
|
com.hazelcast.spring.transaction |
Contains Hazelcast transaction classes for Spring Transaction API.
|
com.hazelcast.topic |
Contains the API for the
ITopic . |
com.hazelcast.topic.impl |
This package contains ITopic functionality for Hazelcast.
With the ITopic it is possible to create publish subscribe solutions similar to JMS Topics. |
com.hazelcast.topic.impl.reliable | |
com.hazelcast.transaction |
Provides interfaces/classes for Hazelcast transaction support.
|
com.hazelcast.transaction.impl |
Provides implementation for Hazelcast transaction support.
|
com.hazelcast.transaction.impl.xa |
Provides implementation for Hazelcast XA transaction support.
|
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.executor |
This package contains classes related to Util.Executor
|
com.hazelcast.wan |
This package contains the WAN replication API
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
HazelcastInstance
Hazelcast instance.
|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
PrefixedDistributedObject
Contact point for special
DistributedObject 's which has prefixed name. |
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
HazelcastInstance
Hazelcast instance.
|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
Member
Cluster member interface.
|
PrefixedDistributedObject
Contact point for special
DistributedObject 's which has prefixed name. |
Class and Description |
---|
Member
Cluster member interface.
|
Class and Description |
---|
IBiFunction
Represents a function that accepts two arguments and produces a result.
|
Class and Description |
---|
HazelcastInstance
Hazelcast instance.
|
HazelcastInstanceAware
Used to get HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
Class and Description |
---|
Cluster
Hazelcast cluster interface.
|
HazelcastException
Base Hazelcast exception.
|
HazelcastInstance
Hazelcast instance.
|
Member
Cluster member interface.
|
OutOfMemoryHandler
Handler for
OutOfMemoryError . |
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
HazelcastInstance
Hazelcast instance.
|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
PrefixedDistributedObject
Contact point for special
DistributedObject 's which has prefixed name. |
Class and Description |
---|
Member
Cluster member interface.
|
Class and Description |
---|
ManagedContext
Container managed context, such as Spring, Guice and etc.
|
Class and Description |
---|
EntryEvent
Map Entry event.
|
EntryListener
Map Entry listener to get notified when a map entry
is added, removed, updated or evicted.
|
HazelcastInstance
Hazelcast instance.
|
IAtomicLong
IAtomicLong is a redundant and highly available distributed alternative to
the
AtomicLong . |
IList
Concurrent, distributed implementation of
List . |
IMap
Concurrent, distributed, observable and queryable map.
|
IQueue
Concurrent, blocking, distributed, observable queue.
|
ISet
Concurrent, distributed implementation of
Set |
ItemEvent
Event for a collection item.
|
ItemListener |
ITopic
Hazelcast provides distribution mechanism for publishing messages that are
delivered to multiple subscribers, which is also known as a publish/subscribe
(pub/sub) messaging model.
|
MapEvent
Used for map-wide events like
EntryEventType.EVICT_ALL
and EntryEventType.CLEAR_ALL . |
Message
Message for
ITopic . |
MessageListener
Message listener for
ITopic . |
MultiMap
A specialized map whose keys can be associated with multiple values.
|
Class and Description |
---|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
Class and Description |
---|
Client
The Client interface allows to get information about
a connected client's socket address, type and UUID.
|
ClientListener
The ClientListener provides the ability to listen to clients connecting and disconnecting from the member.
|
ClientService
ClientService allows you to query connected
Client s and
attach/detach ClientListener s to listen to connection events. |
ClientType
Type of a Hazelcast client.
|
Endpoint
Endpoint represents a peer in the cluster.
|
Class and Description |
---|
Client
The Client interface allows to get information about
a connected client's socket address, type and UUID.
|
ClientService
ClientService allows you to query connected
Client s and
attach/detach ClientListener s to listen to connection events. |
Cluster
Hazelcast cluster interface.
|
DistributedObject
Base interface for all distributed objects.
|
DistributedObjectListener
DistributedObjectListener notifies when a
DistributedObject
is created or destroyed cluster-wide. |
HazelcastInstance
Hazelcast instance.
|
IAtomicLong
IAtomicLong is a redundant and highly available distributed alternative to
the
AtomicLong . |
IAtomicReference
IAtomicReference is a redundant and highly available distributed alternative
to the
AtomicReference . |
ICacheManager
ICacheManager is the entry point to access JSR-107 (JCache) caches via HazelcastInstance interface. |
ICountDownLatch
ICountDownLatch is a backed-up distributed alternative to the
java.util.concurrent.CountDownLatch . |
IdGenerator
Deprecated.
The implementation can produce duplicate IDs in case of network split, even with split-brain
protection enabled (during short window while split-brain is detected). Use
HazelcastInstance.getFlakeIdGenerator(String) for an alternative implementation which does not suffer
from this problem. |
IExecutorService
Distributed implementation of
ExecutorService . |
IList
Concurrent, distributed implementation of
List . |
ILock
Deprecated.
Please use
FencedLock instead.
This interface will be removed in Hazelcast 4.0. |
IMap
Concurrent, distributed, observable and queryable map.
|
IQueue
Concurrent, blocking, distributed, observable queue.
|
ISemaphore
ISemaphore is a fault-tolerant distributed alternative to the
Semaphore . |
ISet
Concurrent, distributed implementation of
Set |
ITopic
Hazelcast provides distribution mechanism for publishing messages that are
delivered to multiple subscribers, which is also known as a publish/subscribe
(pub/sub) messaging model.
|
LifecycleService
LifecycleService allows you to shutdown, terminate, and listen to
LifecycleEvent s
on HazelcastInstance. |
ManagedContext
Container managed context, such as Spring, Guice and etc.
|
MultiMap
A specialized map whose keys can be associated with multiple values.
|
PartitioningStrategy
PartitioningStrategy allows keys to be located on the same member.
|
PartitionService
PartitionService allows you to query
Partition s and attach/detach MigrationListener s to listen to partition
migration events. |
ReplicatedMap
A ReplicatedMap is a map-like data structure with weak consistency
and values locally stored on every node of the cluster.
|
Class and Description |
---|
HazelcastException
Base Hazelcast exception.
|
Class and Description |
---|
DistributedObjectEvent
DistributedObjectEvent is fired when a
DistributedObject
is created or destroyed cluster-wide. |
DistributedObjectListener
DistributedObjectListener notifies when a
DistributedObject
is created or destroyed cluster-wide. |
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Member
Cluster member interface.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
IMapEvent
Map events common contract.
|
Member
Cluster member interface.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
EntryEvent
Map Entry event.
|
EntryListener
Map Entry listener to get notified when a map entry
is added, removed, updated or evicted.
|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
MapEvent
Used for map-wide events like
EntryEventType.EVICT_ALL
and EntryEventType.CLEAR_ALL . |
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Message
Message for
ITopic . |
MessageListener
Message listener for
ITopic . |
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Member
Cluster member interface.
|
Class and Description |
---|
Member
Cluster member interface.
|
Class and Description |
---|
Member
Cluster member interface.
|
Class and Description |
---|
BaseMap
Base interface for Hazelcast distributed maps.
|
BaseMultiMap
Base interface for Hazelcast distributed multi-maps.
|
BaseQueue
Base interface for Hazelcast distributed queues.
|
Cluster
Hazelcast cluster interface.
|
DistributedObject
Base interface for all distributed objects.
|
EntryListener
Map Entry listener to get notified when a map entry
is added, removed, updated or evicted.
|
EntryView
Represents a read-only view of a data structure entry.
|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
IAtomicLong
IAtomicLong is a redundant and highly available distributed alternative to
the
AtomicLong . |
IAtomicReference
IAtomicReference is a redundant and highly available distributed alternative
to the
AtomicReference . |
ICollection
Concurrent, distributed, partitioned, listenable collection.
|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
ICondition
Distributed implementation of
Condition . |
ICountDownLatch
ICountDownLatch is a backed-up distributed alternative to the
java.util.concurrent.CountDownLatch . |
IdGenerator
Deprecated.
The implementation can produce duplicate IDs in case of network split, even with split-brain
protection enabled (during short window while split-brain is detected). Use
HazelcastInstance.getFlakeIdGenerator(String) for an alternative implementation which does not suffer
from this problem. |
IExecutorService
Distributed implementation of
ExecutorService . |
IFunction
Represents a function that accepts one argument and produces a result.
|
IList
Concurrent, distributed implementation of
List . |
ILock
Deprecated.
Please use
FencedLock instead.
This interface will be removed in Hazelcast 4.0. |
IMap
Concurrent, distributed, observable and queryable map.
|
IQueue
Concurrent, blocking, distributed, observable queue.
|
ISemaphore
ISemaphore is a fault-tolerant distributed alternative to the
Semaphore . |
ISet
Concurrent, distributed implementation of
Set |
ItemListener |
ITopic
Hazelcast provides distribution mechanism for publishing messages that are
delivered to multiple subscribers, which is also known as a publish/subscribe
(pub/sub) messaging model.
|
Member
Cluster member interface.
|
MemberSelector
Implementations of this interface select members
that are capable of executing a special kind of task.
The MemberSelector.select(Member) method is called for every available
member in the cluster and it is up to the implementation to decide
if the member is going to be used or not. |
MembershipListener
Cluster membership listener.
|
MessageListener
Message listener for
ITopic . |
MultiExecutionCallback
MultiExecutionCallback provides notification for when an execution is completed on each member
that a task is submitted to.
|
MultiMap
A specialized map whose keys can be associated with multiple values.
|
ReplicatedMap
A ReplicatedMap is a map-like data structure with weak consistency
and values locally stored on every node of the cluster.
|
Class and Description |
---|
BaseMap
Base interface for Hazelcast distributed maps.
|
BaseMultiMap
Base interface for Hazelcast distributed multi-maps.
|
BaseQueue
Base interface for Hazelcast distributed queues.
|
DistributedObject
Base interface for all distributed objects.
|
TransactionalList
Transactional implementation of
IList . |
TransactionalMap
Transactional implementation of
BaseMap . |
TransactionalMultiMap
Transactional implementation of
BaseMultiMap . |
TransactionalQueue
Transactional implementation of
BaseQueue . |
TransactionalSet
Transactional implementation of
ISet . |
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
TransactionalList
Transactional implementation of
IList . |
TransactionalMap
Transactional implementation of
BaseMap . |
TransactionalMultiMap
Transactional implementation of
BaseMultiMap . |
TransactionalQueue
Transactional implementation of
BaseQueue . |
TransactionalSet
Transactional implementation of
ISet . |
Class and Description |
---|
Client
The Client interface allows to get information about
a connected client's socket address, type and UUID.
|
DistributedObject
Base interface for all distributed objects.
|
DistributedObjectListener
DistributedObjectListener notifies when a
DistributedObject
is created or destroyed cluster-wide. |
HazelcastInstance
Hazelcast instance.
|
LifecycleService
LifecycleService allows you to shutdown, terminate, and listen to
LifecycleEvent s
on HazelcastInstance. |
Member
Cluster member interface.
|
MemberSelector
Implementations of this interface select members
that are capable of executing a special kind of task.
The MemberSelector.select(Member) method is called for every available
member in the cluster and it is up to the implementation to decide
if the member is going to be used or not. |
MembershipListener
Cluster membership listener.
|
Partition
In Hazelcast the data is split up in partitions: by default, 271 and configurable through the 'hazelcast.partition.count'
GroupProperty.
|
Class and Description |
---|
Client
The Client interface allows to get information about
a connected client's socket address, type and UUID.
|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
Member
Cluster member interface.
|
MemberSelector
Implementations of this interface select members
that are capable of executing a special kind of task.
The MemberSelector.select(Member) method is called for every available
member in the cluster and it is up to the implementation to decide
if the member is going to be used or not. |
MembershipListener
Cluster membership listener.
|
Partition
In Hazelcast the data is split up in partitions: by default, 271 and configurable through the 'hazelcast.partition.count'
GroupProperty.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
DistributedObjectEvent
DistributedObjectEvent is fired when a
DistributedObject
is created or destroyed cluster-wide. |
DistributedObjectEvent.EventType
Type of the DistributedObjectEvent.
|
Class and Description |
---|
Cluster
Hazelcast cluster interface.
|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
InitialMembershipEvent
An event that is sent when a
InitialMembershipListener registers itself on a Cluster . |
InitialMembershipListener
The InitializingMembershipListener is a
MembershipListener that first receives a
InitialMembershipEvent when it is registered so it immediately knows which members are available. |
LifecycleEvent
Lifecycle events are fired when the HazelcastInstance state changes.
|
LifecycleEvent.LifecycleState
Lifecycle states
|
LifecycleListener
Listener object for listening to lifecycle events of the Hazelcast instance
|
Member
Cluster member interface.
|
MemberAttributeEvent
Event for member attribute changes.
|
MembershipEvent
Membership event fired when a new member is added to the cluster and/or when a member leaves the cluster
or when there is a member attribute change via
Member.setBooleanAttribute(String, boolean)
and similar methods. |
MembershipListener
Cluster membership listener.
|
Class and Description |
---|
MemberSelector
Implementations of this interface select members
that are capable of executing a special kind of task.
The MemberSelector.select(Member) method is called for every available
member in the cluster and it is up to the implementation to decide
if the member is going to be used or not. |
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
ItemEventType
Type of item events.
|
ItemListener |
Class and Description |
---|
ItemEventType
Type of item events.
|
Class and Description |
---|
ItemEvent
Event for a collection item.
|
ItemEventType
Type of item events.
|
Member
Cluster member interface.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
ICollection
Concurrent, distributed, partitioned, listenable collection.
|
IList
Concurrent, distributed implementation of
List . |
Class and Description |
---|
BaseQueue
Base interface for Hazelcast distributed queues.
|
DistributedObject
Base interface for all distributed objects.
|
ICollection
Concurrent, distributed, partitioned, listenable collection.
|
IQueue
Concurrent, blocking, distributed, observable queue.
|
ItemEventType
Type of item events.
|
ItemListener |
QueueStore
QueueStore makes a queue backed by a central data store; such as database, disk, etc.
|
Class and Description |
---|
ItemEventType
Type of item events.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
ICollection
Concurrent, distributed, partitioned, listenable collection.
|
ISet
Concurrent, distributed implementation of
Set |
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
TransactionalList
Transactional implementation of
IList . |
Class and Description |
---|
BaseQueue
Base interface for Hazelcast distributed queues.
|
DistributedObject
Base interface for all distributed objects.
|
TransactionalQueue
Transactional implementation of
BaseQueue . |
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
TransactionalSet
Transactional implementation of
ISet . |
Class and Description |
---|
AsyncAtomicLong
Deprecated.
|
DistributedObject
Base interface for all distributed objects.
|
IAtomicLong
IAtomicLong is a redundant and highly available distributed alternative to
the
AtomicLong . |
IFunction
Represents a function that accepts one argument and produces a result.
|
Class and Description |
---|
IFunction
Represents a function that accepts one argument and produces a result.
|
Class and Description |
---|
AsyncAtomicReference
Deprecated.
|
DistributedObject
Base interface for all distributed objects.
|
IAtomicReference
IAtomicReference is a redundant and highly available distributed alternative
to the
AtomicReference . |
IFunction
Represents a function that accepts one argument and produces a result.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
ICountDownLatch
ICountDownLatch is a backed-up distributed alternative to the
java.util.concurrent.CountDownLatch . |
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
IAtomicLong
IAtomicLong is a redundant and highly available distributed alternative to
the
AtomicLong . |
IdGenerator
Deprecated.
The implementation can produce duplicate IDs in case of network split, even with split-brain
protection enabled (during short window while split-brain is detected). Use
HazelcastInstance.getFlakeIdGenerator(String) for an alternative implementation which does not suffer
from this problem. |
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
ICondition
Distributed implementation of
Condition . |
ILock
Deprecated.
Please use
FencedLock instead.
This interface will be removed in Hazelcast 4.0. |
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
ISemaphore
ISemaphore is a fault-tolerant distributed alternative to the
Semaphore . |
Class and Description |
---|
EntryEvent
Map Entry event.
|
EntryListener
Map Entry listener to get notified when a map entry
is added, removed, updated or evicted.
|
HazelcastException
Base Hazelcast exception.
|
HazelcastInstance
Hazelcast instance.
|
HazelcastInstanceAware
Used to get HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService.
|
ItemListener |
ManagedContext
Container managed context, such as Spring, Guice and etc.
|
MapEvent
Used for map-wide events like
EntryEventType.EVICT_ALL
and EntryEventType.CLEAR_ALL . |
PartitioningStrategy
PartitioningStrategy allows keys to be located on the same member.
|
QueueStore
QueueStore makes a queue backed by a central data store; such as database, disk, etc.
|
QueueStoreFactory
Creates a new
QueueStore . |
RingbufferStore
Ringbuffer store makes a ring buffer backed by a central data store; such as database, disk, etc.
|
RingbufferStoreFactory
Creates a new
RingbufferStore . |
Class and Description |
---|
HazelcastException
Base Hazelcast exception.
|
TypeConverter
Implementations of this interface define a certain type conversation.
|
Class and Description |
---|
EntryEvent
Map Entry event.
|
EntryListener
Map Entry listener to get notified when a map entry
is added, removed, updated or evicted.
|
HazelcastInstance
Hazelcast instance.
|
HazelcastInstanceAware
Used to get HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService.
|
IAtomicLong
IAtomicLong is a redundant and highly available distributed alternative to
the
AtomicLong . |
IList
Concurrent, distributed implementation of
List . |
IMap
Concurrent, distributed, observable and queryable map.
|
IQueue
Concurrent, blocking, distributed, observable queue.
|
ISet
Concurrent, distributed implementation of
Set |
ItemEvent
Event for a collection item.
|
ItemListener |
ITopic
Hazelcast provides distribution mechanism for publishing messages that are
delivered to multiple subscribers, which is also known as a publish/subscribe
(pub/sub) messaging model.
|
MapEvent
Used for map-wide events like
EntryEventType.EVICT_ALL
and EntryEventType.CLEAR_ALL . |
Message
Message for
ITopic . |
MessageListener
Message listener for
ITopic . |
MultiMap
A specialized map whose keys can be associated with multiple values.
|
Class and Description |
---|
AbstractIMapEvent
The abstract class for a map event
IMapEvent . |
BaseMap
Base interface for Hazelcast distributed maps.
|
BaseMultiMap
Base interface for Hazelcast distributed multi-maps.
|
BaseQueue
Base interface for Hazelcast distributed queues.
|
Client
The Client interface allows to get information about
a connected client's socket address, type and UUID.
|
ClientListener
The ClientListener provides the ability to listen to clients connecting and disconnecting from the member.
|
ClientService
ClientService allows you to query connected
Client s and
attach/detach ClientListener s to listen to connection events. |
ClientType
Type of a Hazelcast client.
|
Cluster
Hazelcast cluster interface.
|
DistributedObject
Base interface for all distributed objects.
|
DistributedObjectEvent
DistributedObjectEvent is fired when a
DistributedObject
is created or destroyed cluster-wide. |
DistributedObjectEvent.EventType
Type of the DistributedObjectEvent.
|
DistributedObjectListener
DistributedObjectListener notifies when a
DistributedObject
is created or destroyed cluster-wide. |
Endpoint
Endpoint represents a peer in the cluster.
|
EntryEvent
Map Entry event.
|
EntryEventType
Type of entry event.
|
EntryListener
Map Entry listener to get notified when a map entry
is added, removed, updated or evicted.
|
EntryView
Represents a read-only view of a data structure entry.
|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
HazelcastException
Base Hazelcast exception.
|
HazelcastInstance
Hazelcast instance.
|
IAtomicLong
IAtomicLong is a redundant and highly available distributed alternative to
the
AtomicLong . |
IAtomicReference
IAtomicReference is a redundant and highly available distributed alternative
to the
AtomicReference . |
ICacheManager
ICacheManager is the entry point to access JSR-107 (JCache) caches via HazelcastInstance interface. |
ICollection
Concurrent, distributed, partitioned, listenable collection.
|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
ICondition
Distributed implementation of
Condition . |
ICountDownLatch
ICountDownLatch is a backed-up distributed alternative to the
java.util.concurrent.CountDownLatch . |
IdGenerator
Deprecated.
The implementation can produce duplicate IDs in case of network split, even with split-brain
protection enabled (during short window while split-brain is detected). Use
HazelcastInstance.getFlakeIdGenerator(String) for an alternative implementation which does not suffer
from this problem. |
IExecutorService
Distributed implementation of
ExecutorService . |
IFunction
Represents a function that accepts one argument and produces a result.
|
IList
Concurrent, distributed implementation of
List . |
ILock
Deprecated.
Please use
FencedLock instead.
This interface will be removed in Hazelcast 4.0. |
IMap
Concurrent, distributed, observable and queryable map.
|
IMapEvent
Map events common contract.
|
IndeterminateOperationState
A marker interface for exceptions to denote that execution status of an invocation is not known
|
InitialMembershipEvent
An event that is sent when a
InitialMembershipListener registers itself on a Cluster . |
IQueue
Concurrent, blocking, distributed, observable queue.
|
ISemaphore
ISemaphore is a fault-tolerant distributed alternative to the
Semaphore . |
ISet
Concurrent, distributed implementation of
Set |
ItemEvent
Event for a collection item.
|
ItemEventType
Type of item events.
|
ItemListener |
ITopic
Hazelcast provides distribution mechanism for publishing messages that are
delivered to multiple subscribers, which is also known as a publish/subscribe
(pub/sub) messaging model.
|
LifecycleEvent
Lifecycle events are fired when the HazelcastInstance state changes.
|
LifecycleEvent.LifecycleState
Lifecycle states
|
LifecycleListener
Listener object for listening to lifecycle events of the Hazelcast instance
|
LifecycleService
LifecycleService allows you to shutdown, terminate, and listen to
LifecycleEvent s
on HazelcastInstance. |
MapEvent
Used for map-wide events like
EntryEventType.EVICT_ALL
and EntryEventType.CLEAR_ALL . |
MapLoader
Hazelcast distributed map implementation is an in-memory data store but
it can be backed by any type of data store such as RDBMS, OODBMS, or simply
a file based data store.
|
MapStore
Hazelcast distributed map implementation is an in-memory data store, but
it can be backed by any type of data store such as RDBMS, OODBMS, NOSQL,
or simply a file-based data store.
|
Member
Cluster member interface.
|
MemberAttributeEvent
Event for member attribute changes.
|
MemberSelector
Implementations of this interface select members
that are capable of executing a special kind of task.
The MemberSelector.select(Member) method is called for every available
member in the cluster and it is up to the implementation to decide
if the member is going to be used or not. |
MembershipEvent
Membership event fired when a new member is added to the cluster and/or when a member leaves the cluster
or when there is a member attribute change via
Member.setBooleanAttribute(String, boolean)
and similar methods. |
MembershipListener
Cluster membership listener.
|
Message
Message for
ITopic . |
MessageListener
Message listener for
ITopic . |
MigrationEvent
An event fired when a partition migration starts, completes or fails.
|
MigrationEvent.MigrationStatus
Migration status: Started, completed or failed
|
MigrationListener
MigrationListener provides the ability to listen to partition migration events.
|
MultiExecutionCallback
MultiExecutionCallback provides notification for when an execution is completed on each member
that a task is submitted to.
|
MultiMap
A specialized map whose keys can be associated with multiple values.
|
OutOfMemoryHandler
Handler for
OutOfMemoryError . |
Partition
In Hazelcast the data is split up in partitions: by default, 271 and configurable through the 'hazelcast.partition.count'
GroupProperty.
|
PartitionAware
PartitionAware means that data will be based in the same member based on the partition key
and implementing tasks will be executed on the
PartitionAware.getPartitionKey() 's owner member. |
PartitionService
PartitionService allows you to query
Partition s and attach/detach MigrationListener s to listen to partition
migration events. |
QueueStore
QueueStore makes a queue backed by a central data store; such as database, disk, etc.
|
ReplicatedMap
A ReplicatedMap is a map-like data structure with weak consistency
and values locally stored on every node of the cluster.
|
RingbufferStore
Ringbuffer store makes a ring buffer backed by a central data store; such as database, disk, etc.
|
Class and Description |
---|
Endpoint
Endpoint represents a peer in the cluster.
|
IAtomicLong
IAtomicLong is a redundant and highly available distributed alternative to
the
AtomicLong . |
IAtomicReference
IAtomicReference is a redundant and highly available distributed alternative
to the
AtomicReference . |
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
ICountDownLatch
ICountDownLatch is a backed-up distributed alternative to the
java.util.concurrent.CountDownLatch . |
ISemaphore
ISemaphore is a fault-tolerant distributed alternative to the
Semaphore . |
Class and Description |
---|
Endpoint
Endpoint represents a peer in the cluster.
|
HazelcastException
Base Hazelcast exception.
|
IndeterminateOperationState
A marker interface for exceptions to denote that execution status of an invocation is not known
|
Class and Description |
---|
Endpoint
Endpoint represents a peer in the cluster.
|
IAtomicLong
IAtomicLong is a redundant and highly available distributed alternative to
the
AtomicLong . |
IAtomicReference
IAtomicReference is a redundant and highly available distributed alternative
to the
AtomicReference . |
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
ICountDownLatch
ICountDownLatch is a backed-up distributed alternative to the
java.util.concurrent.CountDownLatch . |
ISemaphore
ISemaphore is a fault-tolerant distributed alternative to the
Semaphore . |
Member
Cluster member interface.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
IFunction
Represents a function that accepts one argument and produces a result.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
IAtomicLong
IAtomicLong is a redundant and highly available distributed alternative to
the
AtomicLong . |
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
IFunction
Represents a function that accepts one argument and produces a result.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
IAtomicReference
IAtomicReference is a redundant and highly available distributed alternative
to the
AtomicReference . |
IFunction
Represents a function that accepts one argument and produces a result.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
ICountDownLatch
ICountDownLatch is a backed-up distributed alternative to the
java.util.concurrent.CountDownLatch . |
Class and Description |
---|
HazelcastException
Base Hazelcast exception.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
ISemaphore
ISemaphore is a fault-tolerant distributed alternative to the
Semaphore . |
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
HazelcastException
Base Hazelcast exception.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
Endpoint
Endpoint represents a peer in the cluster.
|
HazelcastException
Base Hazelcast exception.
|
Class and Description |
---|
Endpoint
Endpoint represents a peer in the cluster.
|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
Class and Description |
---|
Endpoint
Endpoint represents a peer in the cluster.
|
Class and Description |
---|
Endpoint
Endpoint represents a peer in the cluster.
|
Class and Description |
---|
Endpoint
Endpoint represents a peer in the cluster.
|
Class and Description |
---|
Endpoint
Endpoint represents a peer in the cluster.
|
Class and Description |
---|
Endpoint
Endpoint represents a peer in the cluster.
|
Class and Description |
---|
Endpoint
Endpoint represents a peer in the cluster.
|
Class and Description |
---|
Endpoint
Endpoint represents a peer in the cluster.
|
Class and Description |
---|
HazelcastException
Base Hazelcast exception.
|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
Class and Description |
---|
HazelcastException
Base Hazelcast exception.
|
Class and Description |
---|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
Class and Description |
---|
HazelcastException
Base Hazelcast exception.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
HazelcastException
Base Hazelcast exception.
|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
HazelcastInstance
Hazelcast instance.
|
HazelcastInstanceAware
Used to get HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService.
|
IExecutorService
Distributed implementation of
ExecutorService . |
Member
Cluster member interface.
|
MemberSelector
Implementations of this interface select members
that are capable of executing a special kind of task.
The MemberSelector.select(Member) method is called for every available
member in the cluster and it is up to the implementation to decide
if the member is going to be used or not. |
MultiExecutionCallback
MultiExecutionCallback provides notification for when an execution is completed on each member
that a task is submitted to.
|
PartitionAware
PartitionAware means that data will be based in the same member based on the partition key
and implementing tasks will be executed on the
PartitionAware.getPartitionKey() 's owner member. |
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
IdGenerator
Deprecated.
The implementation can produce duplicate IDs in case of network split, even with split-brain
protection enabled (during short window while split-brain is detected). Use
HazelcastInstance.getFlakeIdGenerator(String) for an alternative implementation which does not suffer
from this problem. |
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
HazelcastException
Base Hazelcast exception.
|
IdGenerator
Deprecated.
The implementation can produce duplicate IDs in case of network split, even with split-brain
protection enabled (during short window while split-brain is detected). Use
HazelcastInstance.getFlakeIdGenerator(String) for an alternative implementation which does not suffer
from this problem. |
Class and Description |
---|
ClientService
ClientService allows you to query connected
Client s and
attach/detach ClientListener s to listen to connection events. |
Cluster
Hazelcast cluster interface.
|
DistributedObject
Base interface for all distributed objects.
|
DistributedObjectListener
DistributedObjectListener notifies when a
DistributedObject
is created or destroyed cluster-wide. |
Endpoint
Endpoint represents a peer in the cluster.
|
HazelcastInstance
Hazelcast instance.
|
HazelcastInstanceAware
Used to get HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService.
|
IAtomicLong
IAtomicLong is a redundant and highly available distributed alternative to
the
AtomicLong . |
IAtomicReference
IAtomicReference is a redundant and highly available distributed alternative
to the
AtomicReference . |
ICacheManager
ICacheManager is the entry point to access JSR-107 (JCache) caches via HazelcastInstance interface. |
ICountDownLatch
ICountDownLatch is a backed-up distributed alternative to the
java.util.concurrent.CountDownLatch . |
IdGenerator
Deprecated.
The implementation can produce duplicate IDs in case of network split, even with split-brain
protection enabled (during short window while split-brain is detected). Use
HazelcastInstance.getFlakeIdGenerator(String) for an alternative implementation which does not suffer
from this problem. |
IExecutorService
Distributed implementation of
ExecutorService . |
IList
Concurrent, distributed implementation of
List . |
ILock
Deprecated.
Please use
FencedLock instead.
This interface will be removed in Hazelcast 4.0. |
IMap
Concurrent, distributed, observable and queryable map.
|
IQueue
Concurrent, blocking, distributed, observable queue.
|
ISemaphore
ISemaphore is a fault-tolerant distributed alternative to the
Semaphore . |
ISet
Concurrent, distributed implementation of
Set |
ITopic
Hazelcast provides distribution mechanism for publishing messages that are
delivered to multiple subscribers, which is also known as a publish/subscribe
(pub/sub) messaging model.
|
LifecycleEvent
Lifecycle events are fired when the HazelcastInstance state changes.
|
LifecycleEvent.LifecycleState
Lifecycle states
|
LifecycleListener
Listener object for listening to lifecycle events of the Hazelcast instance
|
LifecycleService
LifecycleService allows you to shutdown, terminate, and listen to
LifecycleEvent s
on HazelcastInstance. |
ManagedContext
Container managed context, such as Spring, Guice and etc.
|
Member
Cluster member interface.
|
MultiMap
A specialized map whose keys can be associated with multiple values.
|
OutOfMemoryHandler
Handler for
OutOfMemoryError . |
PartitioningStrategy
PartitioningStrategy allows keys to be located on the same member.
|
PartitionService
PartitionService allows you to query
Partition s and attach/detach MigrationListener s to listen to partition
migration events. |
ReplicatedMap
A ReplicatedMap is a map-like data structure with weak consistency
and values locally stored on every node of the cluster.
|
Class and Description |
---|
HazelcastInstance
Hazelcast instance.
|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
IMap
Concurrent, distributed, observable and queryable map.
|
ReplicatedMap
A ReplicatedMap is a map-like data structure with weak consistency
and values locally stored on every node of the cluster.
|
Class and Description |
---|
Cluster
Hazelcast cluster interface.
|
Member
Cluster member interface.
|
MemberSelector
Implementations of this interface select members
that are capable of executing a special kind of task.
The MemberSelector.select(Member) method is called for every available
member in the cluster and it is up to the implementation to decide
if the member is going to be used or not. |
Class and Description |
---|
Member
Cluster member interface.
|
Class and Description |
---|
Cluster
Hazelcast cluster interface.
|
HazelcastException
Base Hazelcast exception.
|
Member
Cluster member interface.
|
MemberSelector
Implementations of this interface select members
that are capable of executing a special kind of task.
The MemberSelector.select(Member) method is called for every available
member in the cluster and it is up to the implementation to decide
if the member is going to be used or not. |
MembershipEvent
Membership event fired when a new member is added to the cluster and/or when a member leaves the cluster
or when there is a member attribute change via
Member.setBooleanAttribute(String, boolean)
and similar methods. |
MembershipListener
Cluster membership listener.
|
Class and Description |
---|
HazelcastInstance
Hazelcast instance.
|
Class and Description |
---|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
ManagedContext
Container managed context, such as Spring, Guice and etc.
|
Class and Description |
---|
HazelcastInstance
Hazelcast instance.
|
IBiFunction
Represents a function that accepts two arguments and produces a result.
|
LifecycleEvent
Lifecycle events are fired when the HazelcastInstance state changes.
|
LifecycleListener
Listener object for listening to lifecycle events of the Hazelcast instance
|
Class and Description |
---|
DistributedObjectEvent
DistributedObjectEvent is fired when a
DistributedObject
is created or destroyed cluster-wide. |
DistributedObjectListener
DistributedObjectListener notifies when a
DistributedObject
is created or destroyed cluster-wide. |
HazelcastInstance
Hazelcast instance.
|
IAtomicLong
IAtomicLong is a redundant and highly available distributed alternative to
the
AtomicLong . |
IAtomicReference
IAtomicReference is a redundant and highly available distributed alternative
to the
AtomicReference . |
ICountDownLatch
ICountDownLatch is a backed-up distributed alternative to the
java.util.concurrent.CountDownLatch . |
IExecutorService
Distributed implementation of
ExecutorService . |
IList
Concurrent, distributed implementation of
List . |
ILock
Deprecated.
Please use
FencedLock instead.
This interface will be removed in Hazelcast 4.0. |
IMap
Concurrent, distributed, observable and queryable map.
|
IQueue
Concurrent, blocking, distributed, observable queue.
|
ISemaphore
ISemaphore is a fault-tolerant distributed alternative to the
Semaphore . |
ISet
Concurrent, distributed implementation of
Set |
ITopic
Hazelcast provides distribution mechanism for publishing messages that are
delivered to multiple subscribers, which is also known as a publish/subscribe
(pub/sub) messaging model.
|
MultiMap
A specialized map whose keys can be associated with multiple values.
|
Class and Description |
---|
IMap
Concurrent, distributed, observable and queryable map.
|
IQueue
Concurrent, blocking, distributed, observable queue.
|
MultiMap
A specialized map whose keys can be associated with multiple values.
|
Class and Description |
---|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
Class and Description |
---|
HazelcastInstance
Hazelcast instance.
|
Member
Cluster member interface.
|
MemberAttributeEvent
Event for member attribute changes.
|
MembershipEvent
Membership event fired when a new member is added to the cluster and/or when a member leaves the cluster
or when there is a member attribute change via
Member.setBooleanAttribute(String, boolean)
and similar methods. |
MembershipListener
Cluster membership listener.
|
Class and Description |
---|
Client
The Client interface allows to get information about
a connected client's socket address, type and UUID.
|
Class and Description |
---|
ReadOnly
Allows notifying Hazelcast that the processing unit implementing this interface will not do any modifications.
|
Class and Description |
---|
EntryEventType
Type of entry event.
|
IFunction
Represents a function that accepts one argument and produces a result.
|
IMapEvent
Map events common contract.
|
Member
Cluster member interface.
|
Class and Description |
---|
IFunction
Represents a function that accepts one argument and produces a result.
|
Class and Description |
---|
HazelcastException
Base Hazelcast exception.
|
Member
Cluster member interface.
|
MigrationListener
MigrationListener provides the ability to listen to partition migration events.
|
Partition
In Hazelcast the data is split up in partitions: by default, 271 and configurable through the 'hazelcast.partition.count'
GroupProperty.
|
PartitionService
PartitionService allows you to query
Partition s and attach/detach MigrationListener s to listen to partition
migration events. |
Class and Description |
---|
Member
Cluster member interface.
|
MigrationListener
MigrationListener provides the ability to listen to partition migration events.
|
Class and Description |
---|
HazelcastInstance
Hazelcast instance.
|
ManagedContext
Container managed context, such as Spring, Guice and etc.
|
PartitioningStrategy
PartitioningStrategy allows keys to be located on the same member.
|
Class and Description |
---|
HazelcastInstance
Hazelcast instance.
|
HazelcastJsonValue
HazelcastJsonValue is a wrapper for Json formatted strings.
|
ManagedContext
Container managed context, such as Spring, Guice and etc.
|
PartitioningStrategy
PartitioningStrategy allows keys to be located on the same member.
|
Class and Description |
---|
Member
Cluster member interface.
|
Class and Description |
---|
Member
Cluster member interface.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
Class and Description |
---|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
Class and Description |
---|
Member
Cluster member interface.
|
Class and Description |
---|
HazelcastException
Base Hazelcast exception.
|
Class and Description |
---|
HazelcastJsonValue
HazelcastJsonValue is a wrapper for Json formatted strings.
|
Class and Description |
---|
Member
Cluster member interface.
|
Class and Description |
---|
AbstractIMapEvent
The abstract class for a map event
IMapEvent . |
EntryEventType
Type of entry event.
|
HazelcastException
Base Hazelcast exception.
|
IMapEvent
Map events common contract.
|
Member
Cluster member interface.
|
Class and Description |
---|
EntryView
Represents a read-only view of a data structure entry.
|
Class and Description |
---|
AbstractIMapEvent
The abstract class for a map event
IMapEvent . |
BaseMap
Base interface for Hazelcast distributed maps.
|
DistributedObject
Base interface for all distributed objects.
|
EntryEvent
Map Entry event.
|
EntryEventType
Type of entry event.
|
EntryListener
Map Entry listener to get notified when a map entry
is added, removed, updated or evicted.
|
EntryView
Represents a read-only view of a data structure entry.
|
HazelcastInstance
Hazelcast instance.
|
IFunction
Represents a function that accepts one argument and produces a result.
|
IMapEvent
Map events common contract.
|
MapEvent
Used for map-wide events like
EntryEventType.EVICT_ALL
and EntryEventType.CLEAR_ALL . |
MapLoader
Hazelcast distributed map implementation is an in-memory data store but
it can be backed by any type of data store such as RDBMS, OODBMS, or simply
a file based data store.
|
MapLoaderLifecycleSupport
Provides Lifecycle support for the implementing MapLoader class.
|
MapStore
Hazelcast distributed map implementation is an in-memory data store, but
it can be backed by any type of data store such as RDBMS, OODBMS, NOSQL,
or simply a file-based data store.
|
Member
Cluster member interface.
|
PartitioningStrategy
PartitioningStrategy allows keys to be located on the same member.
|
Class and Description |
---|
EntryEventType
Type of entry event.
|
EntryView
Represents a read-only view of a data structure entry.
|
Class and Description |
---|
EntryView
Represents a read-only view of a data structure entry.
|
Class and Description |
---|
IMap
Concurrent, distributed, observable and queryable map.
|
Class and Description |
---|
EntryEventType
Type of entry event.
|
HazelcastInstance
Hazelcast instance.
|
HazelcastInstanceAware
Used to get HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService.
|
Class and Description |
---|
Member
Cluster member interface.
|
Class and Description |
---|
EntryEventType
Type of entry event.
|
EntryView
Represents a read-only view of a data structure entry.
|
HazelcastException
Base Hazelcast exception.
|
Class and Description |
---|
BaseMap
Base interface for Hazelcast distributed maps.
|
DistributedObject
Base interface for all distributed objects.
|
EntryListener
Map Entry listener to get notified when a map entry
is added, removed, updated or evicted.
|
EntryView
Represents a read-only view of a data structure entry.
|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
IMap
Concurrent, distributed, observable and queryable map.
|
Class and Description |
---|
Member
Cluster member interface.
|
Class and Description |
---|
EntryEventType
Type of entry event.
|
IMapEvent
Map events common contract.
|
Member
Cluster member interface.
|
Class and Description |
---|
IFunction
Represents a function that accepts one argument and produces a result.
|
Class and Description |
---|
EntryEventType
Type of entry event.
|
IMap
Concurrent, distributed, observable and queryable map.
|
IMapEvent
Map events common contract.
|
Member
Cluster member interface.
|
Class and Description |
---|
PartitioningStrategy
PartitioningStrategy allows keys to be located on the same member.
|
Class and Description |
---|
EntryView
Represents a read-only view of a data structure entry.
|
Class and Description |
---|
BaseMap
Base interface for Hazelcast distributed maps.
|
DistributedObject
Base interface for all distributed objects.
|
PartitioningStrategy
PartitioningStrategy allows keys to be located on the same member.
|
TransactionalMap
Transactional implementation of
BaseMap . |
Class and Description |
---|
EntryView
Represents a read-only view of a data structure entry.
|
Class and Description |
---|
EntryEventType
Type of entry event.
|
Class and Description |
---|
EntryEvent
Map Entry event.
|
MapEvent
Used for map-wide events like
EntryEventType.EVICT_ALL
and EntryEventType.CLEAR_ALL . |
Class and Description |
---|
EntryView
Represents a read-only view of a data structure entry.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
HazelcastException
Base Hazelcast exception.
|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
IList
Concurrent, distributed implementation of
List . |
IMap
Concurrent, distributed, observable and queryable map.
|
ISet
Concurrent, distributed implementation of
Set |
MultiMap
A specialized map whose keys can be associated with multiple values.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
Member
Cluster member interface.
|
Class and Description |
---|
MemberSelector
Implementations of this interface select members
that are capable of executing a special kind of task.
The MemberSelector.select(Member) method is called for every available
member in the cluster and it is up to the implementation to decide
if the member is going to be used or not. |
Class and Description |
---|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
Class and Description |
---|
BaseMultiMap
Base interface for Hazelcast distributed multi-maps.
|
DistributedObject
Base interface for all distributed objects.
|
EntryEventType
Type of entry event.
|
EntryListener
Map Entry listener to get notified when a map entry
is added, removed, updated or evicted.
|
MultiMap
A specialized map whose keys can be associated with multiple values.
|
Class and Description |
---|
EntryEventType
Type of entry event.
|
Class and Description |
---|
BaseMultiMap
Base interface for Hazelcast distributed multi-maps.
|
DistributedObject
Base interface for all distributed objects.
|
TransactionalMultiMap
Transactional implementation of
BaseMultiMap . |
Class and Description |
---|
HazelcastException
Base Hazelcast exception.
|
Class and Description |
---|
HazelcastInstance
Hazelcast instance.
|
Class and Description |
---|
HazelcastException
Base Hazelcast exception.
|
Class and Description |
---|
Member
Cluster member interface.
|
Class and Description |
---|
PartitioningStrategy
PartitioningStrategy allows keys to be located on the same member.
|
Class and Description |
---|
HazelcastException
Base Hazelcast exception.
|
Class and Description |
---|
TypeConverter
Implementations of this interface define a certain type conversation.
|
Class and Description |
---|
HazelcastException
Base Hazelcast exception.
|
Member
Cluster member interface.
|
Class and Description |
---|
HazelcastInstance
Hazelcast instance.
|
HazelcastInstanceAware
Used to get HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService.
|
Member
Cluster member interface.
|
MemberAttributeEvent
Event for member attribute changes.
|
MembershipEvent
Membership event fired when a new member is added to the cluster and/or when a member leaves the cluster
or when there is a member attribute change via
Member.setBooleanAttribute(String, boolean)
and similar methods. |
MembershipListener
Cluster membership listener.
|
Class and Description |
---|
HazelcastException
Base Hazelcast exception.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
EntryEventType
Type of entry event.
|
EntryListener
Map Entry listener to get notified when a map entry
is added, removed, updated or evicted.
|
ReplicatedMap
A ReplicatedMap is a map-like data structure with weak consistency
and values locally stored on every node of the cluster.
|
Class and Description |
---|
EntryEventType
Type of entry event.
|
Class and Description |
---|
EntryView
Represents a read-only view of a data structure entry.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
IFunction
Represents a function that accepts one argument and produces a result.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
HazelcastInstance
Hazelcast instance.
|
HazelcastInstanceAware
Used to get HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService.
|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
IFunction
Represents a function that accepts one argument and produces a result.
|
RingbufferStore
Ringbuffer store makes a ring buffer backed by a central data store; such as database, disk, etc.
|
Class and Description |
---|
IFunction
Represents a function that accepts one argument and produces a result.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
HazelcastException
Base Hazelcast exception.
|
Member
Cluster member interface.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
HazelcastInstance
Hazelcast instance.
|
HazelcastInstanceAware
Used to get HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService.
|
Member
Cluster member interface.
|
PartitionAware
PartitionAware means that data will be based in the same member based on the partition key
and implementing tasks will be executed on the
PartitionAware.getPartitionKey() 's owner member. |
Class and Description |
---|
HazelcastInstanceAware
Used to get HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService.
|
Class and Description |
---|
Cluster
Hazelcast cluster interface.
|
DistributedObject
Base interface for all distributed objects.
|
DistributedObjectListener
DistributedObjectListener notifies when a
DistributedObject
is created or destroyed cluster-wide. |
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
HazelcastInstance
Hazelcast instance.
|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
Member
Cluster member interface.
|
MemberAttributeEvent
Event for member attribute changes.
|
MembershipEvent
Membership event fired when a new member is added to the cluster and/or when a member leaves the cluster
or when there is a member attribute change via
Member.setBooleanAttribute(String, boolean)
and similar methods. |
PartitioningStrategy
PartitioningStrategy allows keys to be located on the same member.
|
Class and Description |
---|
HazelcastException
Base Hazelcast exception.
|
Member
Cluster member interface.
|
Class and Description |
---|
DistributedObjectEvent.EventType
Type of the DistributedObjectEvent.
|
EntryEventType
Type of entry event.
|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
HazelcastInstance
Hazelcast instance.
|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
ItemEventType
Type of item events.
|
Class and Description |
---|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
Class and Description |
---|
EntryView
Represents a read-only view of a data structure entry.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
DistributedObjectEvent.EventType
Type of the DistributedObjectEvent.
|
DistributedObjectListener
DistributedObjectListener notifies when a
DistributedObject
is created or destroyed cluster-wide. |
Class and Description |
---|
MigrationListener
MigrationListener provides the ability to listen to partition migration events.
|
Class and Description |
---|
ManagedContext
Container managed context, such as Spring, Guice and etc.
|
PartitioningStrategy
PartitioningStrategy allows keys to be located on the same member.
|
Class and Description |
---|
HazelcastInstance
Hazelcast instance.
|
IMap
Concurrent, distributed, observable and queryable map.
|
Class and Description |
---|
ManagedContext
Container managed context, such as Spring, Guice and etc.
|
Class and Description |
---|
HazelcastInstance
Hazelcast instance.
|
TransactionalList
Transactional implementation of
IList . |
TransactionalMap
Transactional implementation of
BaseMap . |
TransactionalMultiMap
Transactional implementation of
BaseMultiMap . |
TransactionalQueue
Transactional implementation of
BaseQueue . |
TransactionalSet
Transactional implementation of
ISet . |
Class and Description |
---|
HazelcastException
Base Hazelcast exception.
|
MessageListener
Message listener for
ITopic . |
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
ITopic
Hazelcast provides distribution mechanism for publishing messages that are
delivered to multiple subscribers, which is also known as a publish/subscribe
(pub/sub) messaging model.
|
Member
Cluster member interface.
|
Message
Message for
ITopic . |
MessageListener
Message listener for
ITopic . |
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
ITopic
Hazelcast provides distribution mechanism for publishing messages that are
delivered to multiple subscribers, which is also known as a publish/subscribe
(pub/sub) messaging model.
|
Member
Cluster member interface.
|
Message
Message for
ITopic . |
MessageListener
Message listener for
ITopic . |
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
HazelcastException
Base Hazelcast exception.
|
TransactionalList
Transactional implementation of
IList . |
TransactionalMap
Transactional implementation of
BaseMap . |
TransactionalMultiMap
Transactional implementation of
BaseMultiMap . |
TransactionalQueue
Transactional implementation of
BaseQueue . |
TransactionalSet
Transactional implementation of
ISet . |
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
Class and Description |
---|
DistributedObject
Base interface for all distributed objects.
|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
TransactionalList
Transactional implementation of
IList . |
TransactionalMap
Transactional implementation of
BaseMap . |
TransactionalMultiMap
Transactional implementation of
BaseMultiMap . |
TransactionalQueue
Transactional implementation of
BaseQueue . |
TransactionalSet
Transactional implementation of
ISet . |
Class and Description |
---|
IBiFunction
Represents a function that accepts two arguments and produces a result.
|
IFunction
Represents a function that accepts one argument and produces a result.
|
Class and Description |
---|
ExecutionCallback
ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
|
ICompletableFuture
A Future where one can asynchronously listen on completion.
|
Class and Description |
---|
HazelcastException
Base Hazelcast exception.
|
Copyright © 2019 Hazelcast, Inc.. All Rights Reserved.