Hazelcast Root 3.7 API

Packages 
Package Description
com.hazelcast
This package contains PlaceHolder
com.hazelcast.buildutils
This module contains Maven and other build additions that are used by Hazelcast to build bundle modules
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.client
Hazelcast JSR-107 aka JCache implementation Client Requests
com.hazelcast.cache.impl.event
Event classes to define listenters for JCache other than EntryListener
com.hazelcast.cache.impl.maxsize
Max-Size policy interfaces for cache.
com.hazelcast.cache.impl.maxsize.impl
Max-Size policy implementations for cache.
com.hazelcast.cache.impl.merge
This package contains merge functionality for Hazelcast cache.
com.hazelcast.cache.impl.merge.entry
This package contains merge entry internal interfaces and functionality for Hazelcast cache.
com.hazelcast.cache.impl.merge.policy
This package contains merge policy internal interfaces and functionality for Hazelcast cache.
com.hazelcast.cache.impl.nearcache
Near cache support.
com.hazelcast.cache.impl.nearcache.impl
Near cache implementations.
com.hazelcast.cache.impl.nearcache.impl.maxsize
Max-Size policy implementations for near-cache.
com.hazelcast.cache.impl.nearcache.impl.record
Near cache record implementations.
com.hazelcast.cache.impl.nearcache.impl.store
Near cache store implementations.
com.hazelcast.cache.impl.operation
Hazelcast JSR-107 aka JCache implementation
com.hazelcast.cache.impl.record
Hazelcast JSR-107 aka JCache implementation Internal record store
com.hazelcast.cache.merge
This package contains out of the box merge policies.
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.config
Contains classes related to config for com.hazelcast.client
com.hazelcast.client.connection
Provides connection interfaces/classes for com.hazelcast.client
com.hazelcast.client.connection.nio
Contains classes related to New IO for com.hazelcast.client.connection
com.hazelcast.client.console
This package contains ClientConsoleApp
com.hazelcast.client.impl
Contains most of the client side HazelcastInstance implementation functionality.
com.hazelcast.client.impl.client
This contains the Requests and other DTO's exchanged between client/server
com.hazelcast.client.impl.operations
Contains client operations
com.hazelcast.client.impl.protocol
Client protocol related private implementation classes
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.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.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.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.protocol.task.transactionallist
Client protocol tasks implementations for Transactional List
com.hazelcast.client.impl.protocol.task.transactionalmap
Client protocol tasks implementations for Transactional Map
com.hazelcast.client.impl.protocol.task.transactionalmultimap
Client protocol tasks implementations for Transactional MultiMap
com.hazelcast.client.impl.protocol.task.transactionalqueue
Client protocol tasks implementations for Transactional Queue
com.hazelcast.client.impl.protocol.task.transactionalset
Client protocol tasks implementations for Transactional Set
com.hazelcast.client.impl.protocol.util
Protocol utils
com.hazelcast.client.map.impl  
com.hazelcast.client.map.impl.nearcache
Contains classes/interfaces related to com.hazelcast.client.map.impl.nearcache
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 Service Provider Interface such as ClientProxy , ClientClusterService
com.hazelcast.client.spi.impl
Provides util classes for com.hazelcast.client
com.hazelcast.client.spi.impl.discovery  
com.hazelcast.client.spi.impl.listener  
com.hazelcast.client.spi.properties
Contains the Hazelcast client properties implementation.
com.hazelcast.client.util
This package contains some utility classes and the base implementations of the loadbalancer implementations
com.hazelcast.cluster
This package contains the cluster functionality.
com.hazelcast.cluster.impl  
com.hazelcast.cluster.memberselector
This package contains several MemberSelector implementations.
com.hazelcast.collection.impl  
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.list.operations  
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.set.operations  
com.hazelcast.collection.impl.txncollection  
com.hazelcast.collection.impl.txncollection.operations  
com.hazelcast.collection.impl.txnlist  
com.hazelcast.collection.impl.txnqueue  
com.hazelcast.collection.impl.txnqueue.operations  
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.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.idgen
This package contains IdGenerator functionality for Hazelcast.
With the IdGenerator it is very simple to create cluster wide id's.
com.hazelcast.concurrent.lock
This package contains Lock for Hazelcast.
The ILock is the distributed version of the 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.config.matcher
Provides implementations for ConfigPatternMatcher.
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.core.server
This package contains classes to launch standalone Hazelcast Instance
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.durableexecutor.impl.operations
This package contains operations for the DurableExecutorService.
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.executor.impl.operations
This package contains operations for the IExecutorService.
com.hazelcast.instance
This package contains Hazelcast Instance functionality.
com.hazelcast.internal
Contains the internal packages of Hazelcast.
com.hazelcast.internal.ascii
This package contains Ascii functionality for Hazelcast.
This is required for Memcached and the REST api.
com.hazelcast.internal.ascii.memcache
This package contains MemoryCache functionality for Hazelcast.
com.hazelcast.internal.ascii.rest
This package contains Reset functionality for Hazelcast.
com.hazelcast.internal.cluster
Contains the internals for cluster management like discovery, joining etc.
com.hazelcast.internal.cluster.impl
This package contains the implementation of the cluster functionality.
com.hazelcast.internal.cluster.impl.operations
This package contains operations for the com.hazelcast.cluster.impl package.
com.hazelcast.internal.diagnostics
Contains functionality what is happening in a HazelcastInstance.
com.hazelcast.internal.eviction
Eviction policy implementations.
com.hazelcast.internal.eviction.impl
Eviction implementations.
com.hazelcast.internal.eviction.impl.comparator
EvictionPolicyComparator implementations.
com.hazelcast.internal.eviction.impl.evaluator
EvictionPolicyEvaluator implementations.
com.hazelcast.internal.eviction.impl.strategy
EvictionStrategy implementations.
com.hazelcast.internal.eviction.impl.strategy.sampling
Sampling based EvictionStrategy implementations for cache.
com.hazelcast.internal.jmx
Contains Hazelcast management bean classes.
com.hazelcast.internal.jmx.suppliers
Contains Hazelcast management bean stat providers.
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.operation
Contains operations that are called from Management Center.
com.hazelcast.internal.management.request
Contains requests that made from Management Center.
com.hazelcast.internal.memory
SPI that deals with memory operations.
com.hazelcast.internal.memory.impl
Internal memory management API implementations
com.hazelcast.internal.metrics
Contains the Hazelcast Metrics.
com.hazelcast.internal.metrics.impl
Contains the MetricsRegistry implementation.
com.hazelcast.internal.metrics.metricsets
Contains all kinds of metric packs.
com.hazelcast.internal.metrics.renderers
Contains the ProbeRenderer API.
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.partition.operation
Contains the operations for partition package.
com.hazelcast.internal.serialization
Contains the private serialization API + implementation.
com.hazelcast.internal.serialization.impl  
com.hazelcast.internal.serialization.impl.bufferpool
Contains the logic for the BufferPool.
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.collection
Primitive-typed collections.
com.hazelcast.internal.util.counters
Provides various counter implementations.
com.hazelcast.internal.util.hashslot
Contains a family of interfaces that provide a common base for various kinds of open-addressed hashtable implementations.
com.hazelcast.internal.util.hashslot.impl  
com.hazelcast.internal.util.sort
General API for sorting.
com.hazelcast.logging
This package contains logging functionality for Hazelcast.
Since Hazelcast has a zero dependency policy, Hazelcast provides a logging abstraction like commongs 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.mapstore
Contains map store operations.
com.hazelcast.map.impl.mapstore.writebehind
Package for processing write behind store operations.
com.hazelcast.map.impl.mapstore.writebehind.entry  
com.hazelcast.map.impl.mapstore.writethrough
Package for processing write through store operations.
com.hazelcast.map.impl.nearcache
Contains near-cache specific classes.
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.query  
com.hazelcast.map.impl.querycache.event
This package contains classes for query cache events.
com.hazelcast.map.impl.querycache.event.sequence
This package contains classes which are used to give sequence numbers to events.
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.listener
Contains various MapListener interfaces.
com.hazelcast.map.merge
Contains 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.aggregation
This package contains the aggregation API and the convenience helper classes to retrieve predefined aggregation implementations.
com.hazelcast.mapreduce.aggregation.impl
This package contains a set of predefined aggregation implementations
com.hazelcast.mapreduce.impl
This package contains the default implementation for the map reduce framework internals.
com.hazelcast.mapreduce.impl.notification
This package contains all remote node notifications
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.memory
Provides classes/interfaces for memory utilities, heap/native memory storage support.
com.hazelcast.monitor
Contains Hazelcast statistics interfaces related to map, queue, topic, multimap, executor service etc.
com.hazelcast.monitor.impl
Contains Hazelcast statistics implementations related to map, queue, topic, multimap, executor service etc.
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
This package contains classes related to New IO
com.hazelcast.nio.ascii
Contains SocketTextReader and SocketTextWriter classes;
com.hazelcast.nio.serialization
Contains interfaces/classes related to serialization; such as serializer interfaces, input/output streams.
com.hazelcast.nio.ssl
Contains interfaces/classes related to SSL for New IO
com.hazelcast.nio.tcp
Contains functionality for the TCP/IP Networking between cluster members
This whole package is internal and no compatibility will be provided.
com.hazelcast.nio.tcp.nonblocking
Contains the non blocking TcpIpConnectionMonitor.
com.hazelcast.nio.tcp.nonblocking.iobalancer
Contains Handler Migration classes
com.hazelcast.nio.tcp.spinning
Contains the implementation of the SpinningIOThreadingModel.
com.hazelcast.osgi
This package contains the OSGI functionality contract points for Hazelcast.
com.hazelcast.osgi.impl
This package contains the OSGI functionality implementations 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.extractor
Contains classes related to custom attributes and the extraction of their values.
com.hazelcast.query.impl
Contains the implementation classes of the query functionality.
com.hazelcast.query.impl.getters
Helper classes for extractions of values from object instances.
com.hazelcast.query.impl.predicates  
com.hazelcast.quorum
Contains classes related to cluster quorum.
com.hazelcast.quorum.impl
Contains cluster quorum implementation classes.
com.hazelcast.quorum.impl.operation
Contains cluster quorum operation classes.
com.hazelcast.replicatedmap
Contains classes related to cluster quorum.
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.operation
This package contains replicated map operations which are executed on remote nodes
com.hazelcast.replicatedmap.impl.record
This package contains the implementation of the backing data storage for the replicated map implementation
com.hazelcast.replicatedmap.merge
Contains merge policies for ReplicatedMap
com.hazelcast.ringbuffer
Contains the API for the Ringbuffer.
com.hazelcast.ringbuffer.impl
Contains the Ringbuffer implementation classes.
com.hazelcast.ringbuffer.impl.client  
com.hazelcast.ringbuffer.impl.operations  
com.hazelcast.security
Provides interfaces/classes for Hazelcast security implementation.
com.hazelcast.security.permission
Contains all the security permissions
com.hazelcast.spi
Provides interfaces/classes for the Hazelcast SPI for building distributed data structures and services.
com.hazelcast.spi.annotation
Contains annotations for Hazelcast SPI.
com.hazelcast.spi.discovery
This package contains the public SPI for vendors and users to implement their custom node / IP discovery strategy.
com.hazelcast.spi.discovery.impl  
com.hazelcast.spi.discovery.integration
This package contains the public part of the integrators SPI and is meant for people that integrate Hazelcast into their own systems or frameworks and cannot use the default discovery service implementation (for example using a different DiscoveryStrategy lookup strategy like OSGi).
com.hazelcast.spi.discovery.multicast
Contains the hazelcast multicast plugin classes
com.hazelcast.spi.discovery.multicast.impl  
com.hazelcast.spi.exception
Contains exceptions for Hazelcast SPI.
com.hazelcast.spi.impl
Contains implementations for Hazelcast SPI.
com.hazelcast.spi.impl.eventservice
Contains the code for the InternalEventService.
com.hazelcast.spi.impl.eventservice.impl
Contains the code for the InternalEventService implementation.
com.hazelcast.spi.impl.eventservice.impl.operations
Contains the operations for the EventServiceImpl.
com.hazelcast.spi.impl.executionservice
Contains the API for the InternalExecutionService.
com.hazelcast.spi.impl.executionservice.impl
Contains the implementation of the InternalExecutionService.
com.hazelcast.spi.impl.operationexecutor
Contains the OperationRunner code.
com.hazelcast.spi.impl.operationexecutor.impl
Contains the OperationExecutorImpl code.
com.hazelcast.spi.impl.operationexecutor.slowoperationdetector
Contains the functionality to detect slow running operations using the OperationRunner instances from the OperationExecutor.
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.operationservice.impl.operations
Contains the Operations being used by the OperationServiceImpl.
com.hazelcast.spi.impl.operationservice.impl.responses
Contains the different responses that can be send as a consequence of an Operation invocation.
com.hazelcast.spi.impl.operationutil
Contains utiliy classes related to Operation
com.hazelcast.spi.impl.packetdispatcher
Contains the API for the dispatching packets to the appropriate internal services.
com.hazelcast.spi.impl.packetdispatcher.impl
Contains the implementation of the PacketDispatcher.
com.hazelcast.spi.impl.proxyservice
Contains the API for the InternalProxyService.
com.hazelcast.spi.impl.proxyservice.impl
Contains the implementation of the InternalProxyService.
com.hazelcast.spi.impl.proxyservice.impl.operations
Contains the operations for the ProxyServiceImpl.
com.hazelcast.spi.impl.servicemanager
Contains the API for the ServiceManager.
com.hazelcast.spi.impl.servicemanager.impl
Contains the ServiceManager implementation.
com.hazelcast.spi.impl.waitnotifyservice
Contains the internal API code for the WaitNotifyService.
com.hazelcast.spi.impl.waitnotifyservice.impl
Contains the implementation code for the WaitNotifyService.
com.hazelcast.spi.partition
Contains the SPI for partition logic for Hazelcast.
com.hazelcast.spi.partitiongroup
This package contains the basic SPI for the Partition Group SPI to define or configure how Hazelcast will configure and distribute backups in the cluster.
com.hazelcast.spi.properties
Contains the Hazelcast properties implementation.
com.hazelcast.spi.serialization
Contains SPI related to serialization
com.hazelcast.spring
Provides Spring interfaces/classes for Hazelcast.
com.hazelcast.spring.cache
Contains Hazelcast cache classes related to Spring.
com.hazelcast.spring.context
Contains context classes for Spring.
com.hazelcast.spring.hibernate
Contains class related to Hibernate.
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.operations  
com.hazelcast.transaction.impl.xa
Provides implementation for Hazelcast XA transaction support.
com.hazelcast.transaction.impl.xa.operations  
com.hazelcast.util
This package contains classes to support the inner workings of Hazelcast as well as some backports of newer Java features / data structures to support older Java versions in a clean and nice way.
com.hazelcast.util.collection
The Agrona project backport: collections.
com.hazelcast.util.concurrent
Abstractions that deal with common needs in concurrent programming.
com.hazelcast.util.executor
This package contains classes related to Util.Executor
com.hazelcast.util.function
Backport of Java 8 functional interfaces which Agrona depends on.
com.hazelcast.util.scheduler
This package contains scheduler classes for Util
com.hazelcast.wan
This package contains the WAN replication API
com.hazelcast.wan.impl
This package contains the opensource implementation of WAN replication

Copyright © 2016 Hazelcast, Inc.. All Rights Reserved.