Package | Description |
---|---|
com.hazelcast.cache.impl |
Hazelcast JSR-107 aka JCache implementation
|
com.hazelcast.client.connection |
Provides connection interfaces/classes for com.hazelcast.client
Everything in this package and its subpackages is private.
|
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.task |
Client tasks associated with requests.
|
com.hazelcast.client.spi.impl |
Provides util classes for the Hazelcast client SPI.
|
com.hazelcast.collection.impl.collection | |
com.hazelcast.cp.internal |
Contains implementation of the CP subsystem
|
com.hazelcast.cp.internal.datastructures.spi.blocking |
Contains the interfaces and abstractions that are implemented / extended
by blocking Raft services, such as Lock, Semaphore, and CountDownLatch
|
com.hazelcast.cp.internal.raft.impl |
Contains implementation classes of the Raft algorithm
|
com.hazelcast.cp.internal.raft.impl.task |
Contains tasks running on leader or leader-candidates.
|
com.hazelcast.instance |
This package contains Hazelcast Instance functionality.
|
com.hazelcast.internal.ascii.memcache |
This package contains MemoryCache functionality for Hazelcast.
|
com.hazelcast.internal.cluster.impl |
This package contains the implementation of the cluster functionality.
|
com.hazelcast.internal.config |
Contains functionality for Hazelcast configurations.
|
com.hazelcast.internal.diagnostics |
Contains functionality what is happening in a HazelcastInstance.
|
com.hazelcast.internal.metrics.impl |
Contains the
MetricsRegistry implementation. |
com.hazelcast.internal.nearcache.impl.invalidation |
Invalidations for Near Cache.
|
com.hazelcast.internal.networking |
Contains the socket connection functionality.
|
com.hazelcast.internal.networking.nio |
Contains the non blocking
Networking functionality. |
com.hazelcast.internal.partition |
Contains the internals for partition assignment/management, migration, replication etc.
|
com.hazelcast.internal.usercodedeployment.impl | |
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.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.impl.mapstore |
Contains map store operations.
|
com.hazelcast.map.impl.nearcache.invalidation | |
com.hazelcast.map.impl.query | |
com.hazelcast.map.impl.querycache.accumulator |
Contains
Accumulator
specific classes. |
com.hazelcast.map.impl.querycache.subscriber |
This package contains classes which are used for
QueryCache
event subscription side. |
com.hazelcast.map.impl.recordstore | |
com.hazelcast.nio.tcp |
Contains functionality for the TCP/IP Networking for cluster members
This whole package is internal and no compatibility will be provided. |
com.hazelcast.spi |
Provides interfaces/classes for the Hazelcast SPI for building distributed data structures and services.
|
com.hazelcast.spi.discovery |
This package contains the public SPI for vendors and users to implement their
custom node / IP discovery strategy.
|
com.hazelcast.spi.discovery.integration |
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.impl |
Contains implementations for Hazelcast SPI.
|
com.hazelcast.spi.impl.eventservice.impl |
Contains the code for the
InternalEventService implementation. |
com.hazelcast.spi.impl.operationexecutor.impl |
Contains the
OperationExecutorImpl code. |
com.hazelcast.spi.impl.operationparker.impl |
Contains the implementation code for the
OperationParker . |
com.hazelcast.spi.impl.operationservice.impl |
Contains the code for the
InternalOperationService implementation. |
com.hazelcast.topic.impl.reliable | |
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
|
Modifier and Type | Field and Description |
---|---|
protected ILogger |
AbstractCacheService.logger |
protected static ILogger |
AbstractHazelcastCachingProvider.LOGGER |
Modifier and Type | Method and Description |
---|---|
static boolean |
JCacheDetector.isJCacheAvailable(ClassLoader classLoader,
ILogger logger) |
Modifier and Type | Field and Description |
---|---|
protected ILogger |
ClientConnectionStrategy.logger |
Modifier and Type | Method and Description |
---|---|
protected ILogger |
MemberImpl.getLogger() |
ILogger |
ClientEngineImpl.getLogger(Class clazz) |
ILogger |
ClientEngine.getLogger(Class clazz) |
ILogger |
NoOpClientEngine.getLogger(Class clazz) |
Constructor and Description |
---|
ClientHeartbeatMonitor(ClientEndpointManager clientEndpointManager,
ILogger logger,
ExecutionService executionService,
HazelcastProperties hazelcastProperties) |
Modifier and Type | Field and Description |
---|---|
protected static ILogger |
DefaultClientExtension.LOGGER |
Modifier and Type | Method and Description |
---|---|
ILogger |
ClientLoggingService.getLogger(Class clazz) |
ILogger |
ClientLoggingService.getLogger(String name) |
Modifier and Type | Field and Description |
---|---|
protected ILogger |
AbstractMessageTask.logger |
Modifier and Type | Method and Description |
---|---|
static void |
ClientExecutionServiceImpl.shutdownExecutor(String name,
ExecutorService executor,
ILogger logger) |
Constructor and Description |
---|
ClientInvocationFuture(ClientInvocation invocation,
Executor internalExecutor,
ClientMessage request,
ILogger logger,
CallIdSequence callIdSequence) |
Modifier and Type | Field and Description |
---|---|
protected ILogger |
CollectionContainer.logger |
Modifier and Type | Method and Description |
---|---|
protected ILogger |
RaftOp.getLogger() |
Modifier and Type | Field and Description |
---|---|
protected ILogger |
AbstractBlockingService.logger |
Modifier and Type | Method and Description |
---|---|
ILogger |
RaftNodeImpl.getLogger(Class clazz) |
ILogger |
RaftIntegration.getLogger(String name)
Returns an
ILogger instance for given name. |
Modifier and Type | Field and Description |
---|---|
protected ILogger |
RaftNodeStatusAwareTask.logger |
Modifier and Type | Field and Description |
---|---|
protected ILogger |
DefaultNodeExtension.logger |
protected ILogger |
DefaultNodeExtension.systemLogger |
Modifier and Type | Method and Description |
---|---|
protected ILogger |
MemberImpl.getLogger() |
protected abstract ILogger |
AbstractMember.getLogger() |
ILogger |
Node.getLogger(Class clazz) |
ILogger |
Node.getLogger(String name) |
Constructor and Description |
---|
EntryConverter(TextCommandService textCommandService,
ILogger logger) |
Modifier and Type | Field and Description |
---|---|
protected ILogger |
AbstractJoiner.logger |
Modifier and Type | Method and Description |
---|---|
static MulticastService |
MulticastService.createMulticastService(Address bindAddress,
Node node,
Config config,
ILogger logger) |
Constructor and Description |
---|
ClusterClockImpl(ILogger logger) |
Modifier and Type | Method and Description |
---|---|
static boolean |
MergePolicyValidator.checkMergePolicySupportsInMemoryFormat(String name,
Object mergePolicy,
InMemoryFormat inMemoryFormat,
boolean failFast,
ILogger logger)
Checks if the given
InMemoryFormat can be merged by the given
mergePolicy instance. |
Modifier and Type | Field and Description |
---|---|
protected ILogger |
DiagnosticsPlugin.logger |
Constructor and Description |
---|
MetricsRegistryImpl(ILogger logger,
ProbeLevel minimumLevel)
Creates a MetricsRegistryImpl instance.
|
MetricsRegistryImpl(String name,
ILogger logger,
ProbeLevel minimumLevel)
Creates a MetricsRegistryImpl instance.
|
Modifier and Type | Field and Description |
---|---|
protected ILogger |
InvalidationMetaDataFetcher.logger |
protected ILogger |
Invalidator.logger |
Constructor and Description |
---|
InvalidationMetaDataFetcher(ILogger logger) |
RepairingHandler(ILogger logger,
String localUuid,
String name,
NearCache nearCache,
SerializationService serializationService,
MinimalPartitionService partitionService) |
RepairingTask(HazelcastProperties properties,
InvalidationMetaDataFetcher invalidationMetaDataFetcher,
TaskScheduler scheduler,
SerializationService serializationService,
MinimalPartitionService partitionService,
String localUuid,
ILogger logger) |
Modifier and Type | Field and Description |
---|---|
protected ILogger |
AbstractChannel.logger |
Modifier and Type | Field and Description |
---|---|
protected ILogger |
NioPipeline.logger |
Constructor and Description |
---|
NioThread(String threadName,
ILogger logger,
ChannelErrorHandler errorHandler) |
NioThread(String threadName,
ILogger logger,
ChannelErrorHandler errorHandler,
SelectorMode selectMode,
IdleStrategy idleStrategy) |
NioThread(String threadName,
ILogger logger,
ChannelErrorHandler errorHandler,
SelectorMode selectMode,
Selector selector,
IdleStrategy idleStrategy) |
Modifier and Type | Method and Description |
---|---|
static void |
ReplicaErrorLogger.log(Throwable e,
ILogger logger) |
Constructor and Description |
---|
ClassDataProvider(UserCodeDeploymentConfig.ProviderMode providerMode,
ClassLoader parent,
ConcurrentMap<String,ClassSource> classSourceMap,
ConcurrentMap<String,ClassSource> clientClassSourceMap,
ILogger logger) |
Modifier and Type | Method and Description |
---|---|
static void |
ModularJavaUtils.checkJavaInternalAccess(ILogger logger)
Prints warning to given
ILogger if Hazelcast is not provided a sufficient access to Java internal packages on
Java 9 and newer. |
Constructor and Description |
---|
SimpleCompletableFuture(Executor executor,
ILogger logger) |
Constructor and Description |
---|
ChainingFuture(Iterator<ICompletableFuture<T>> futuresToChain,
Executor executor,
ChainingFuture.ExceptionHandler exceptionHandler,
ILogger logger) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractLogger
Abstract
ILogger implementation that provides implementations for convenience methods like
finest, info, warning and severe. |
static class |
Log4j2Factory.Log4j2Logger |
Modifier and Type | Method and Description |
---|---|
protected ILogger |
Log4j2Factory.createLogger(String name) |
protected ILogger |
Slf4jFactory.createLogger(String name) |
protected ILogger |
Log4jFactory.createLogger(String name) |
protected ILogger |
StandardLoggerFactory.createLogger(String name) |
protected abstract ILogger |
LoggerFactorySupport.createLogger(String name) |
static ILogger |
Logger.getLogger(Class clazz)
Obtains a
logger for the given clazz . |
ILogger |
LoggingService.getLogger(Class type) |
ILogger |
LoggingServiceImpl.getLogger(Class clazz) |
ILogger |
LoggerFactory.getLogger(String name) |
static ILogger |
Logger.getLogger(String name)
Obtains a
logger of the given name . |
ILogger |
NoLogFactory.getLogger(String name) |
ILogger |
LoggerFactorySupport.getLogger(String name) |
ILogger |
LoggingService.getLogger(String name) |
ILogger |
LoggingServiceImpl.getLogger(String name) |
static ILogger |
Logger.noLogger() |
Modifier and Type | Method and Description |
---|---|
ILogger |
MapStoreContext.getLogger(Class clazz) |
Constructor and Description |
---|
MemberMapInvalidationMetaDataFetcher(ClusterService clusterService,
OperationService operationService,
ILogger logger) |
Modifier and Type | Field and Description |
---|---|
protected ILogger |
QueryRunner.logger |
protected ILogger |
PartitionScanRunner.logger |
Constructor and Description |
---|
QueryResultSizeLimiter(MapServiceContext mapServiceContext,
ILogger logger) |
Modifier and Type | Field and Description |
---|---|
protected ILogger |
BasicAccumulator.logger |
Modifier and Type | Field and Description |
---|---|
protected ILogger |
AbstractQueryCacheEndToEndConstructor.logger |
Modifier and Type | Field and Description |
---|---|
protected ILogger |
DefaultRecordStore.logger |
Constructor and Description |
---|
DefaultRecordStore(MapContainer mapContainer,
int partitionId,
MapKeyLoader keyLoader,
ILogger logger) |
Constructor and Description |
---|
TcpIpConnectionChannelErrorHandler(ILogger logger) |
Modifier and Type | Method and Description |
---|---|
protected ILogger |
Operation.getLogger() |
ILogger |
NodeEngine.getLogger(Class clazz)
Gets the logger for a given class.
|
ILogger |
NodeEngine.getLogger(String name)
Gets the logger for a given name.
|
Modifier and Type | Method and Description |
---|---|
protected ILogger |
AbstractDiscoveryStrategy.getLogger()
Returns a
ILogger instance bound to the current class. |
Modifier and Type | Method and Description |
---|---|
DiscoveryStrategy |
DiscoveryStrategyFactory.newDiscoveryStrategy(DiscoveryNode discoveryNode,
ILogger logger,
Map<String,Comparable> properties)
Instantiates a new instance of the
DiscoveryStrategy with the given configuration
properties. |
Constructor and Description |
---|
AbstractDiscoveryStrategy(ILogger logger,
Map<String,Comparable> properties) |
Modifier and Type | Method and Description |
---|---|
ILogger |
DiscoveryServiceSettings.getLogger() |
Modifier and Type | Method and Description |
---|---|
DiscoveryServiceSettings |
DiscoveryServiceSettings.setLogger(ILogger logger) |
Modifier and Type | Method and Description |
---|---|
DiscoveryStrategy |
MulticastDiscoveryStrategyFactory.newDiscoveryStrategy(DiscoveryNode discoveryNode,
ILogger logger,
Map<String,Comparable> prop) |
Constructor and Description |
---|
MulticastDiscoveryStrategy(DiscoveryNode discoveryNode,
ILogger logger,
Map<String,Comparable> properties) |
Constructor and Description |
---|
MulticastDiscoveryReceiver(MulticastSocket multicastSocket,
ILogger logger) |
MulticastDiscoverySender(DiscoveryNode discoveryNode,
MulticastSocket multicastSocket,
ILogger logger,
String group,
int port) |
Modifier and Type | Field and Description |
---|---|
protected ILogger |
AbstractInvocationFuture.logger |
Modifier and Type | Method and Description |
---|---|
ILogger |
NodeEngineImpl.getLogger(Class clazz) |
ILogger |
NodeEngineImpl.getLogger(String name) |
Modifier and Type | Method and Description |
---|---|
static OperationResponseHandler |
OperationResponseHandlerFactory.createErrorLoggingResponseHandler(ILogger logger) |
Constructor and Description |
---|
AbstractCompletableFuture(Executor defaultExecutor,
ILogger logger) |
AbstractCompletableFuture(NodeEngine nodeEngine,
ILogger logger) |
AbstractInvocationFuture(Executor defaultExecutor,
ILogger logger) |
PacketDispatcher(ILogger logger,
Consumer<Packet> operationExecutor,
Consumer<Packet> responseHandler,
Consumer<Packet> invocationMonitor,
Consumer<Packet> eventService,
Consumer<Packet> jetPacketConsumer) |
Constructor and Description |
---|
FutureUtilExceptionHandler(ILogger logger,
String message) |
Constructor and Description |
---|
GenericOperationThread(String name,
int threadId,
OperationQueue queue,
ILogger logger,
NodeExtension nodeExtension,
OperationRunner operationRunner,
boolean priority,
ClassLoader configClassLoader) |
OperationThread(String name,
int threadId,
OperationQueue queue,
ILogger logger,
NodeExtension nodeExtension,
boolean priority,
ClassLoader configClassLoader) |
PartitionOperationThread(String name,
int threadId,
OperationQueue queue,
ILogger logger,
NodeExtension nodeExtension,
OperationRunner[] partitionOperationRunners,
ClassLoader configClassLoader) |
Constructor and Description |
---|
WaitSet(ILogger logger,
NodeEngine nodeEngine,
Map<WaitNotifyKey,WaitSet> waitSetMap,
Queue<com.hazelcast.spi.impl.operationparker.impl.WaitSetEntry> delayQueue) |
Constructor and Description |
---|
InvocationRegistry(ILogger logger,
CallIdSequence callIdSequence) |
RaftInvocationContext(ILogger logger,
RaftService raftService) |
Modifier and Type | Field and Description |
---|---|
protected ILogger |
MessageRunner.logger |
Constructor and Description |
---|
MessageRunner(String id,
ReliableMessageListener<E> listener,
Ringbuffer<ReliableTopicMessage> ringbuffer,
String topicName,
int batchSze,
SerializationService serializationService,
Executor executor,
ConcurrentMap<String,MessageRunner<E>> runnersMap,
ILogger logger) |
Modifier and Type | Method and Description |
---|---|
static FutureUtil.ExceptionHandler |
FutureUtil.logAllExceptions(ILogger logger,
Level level)
This ExceptionHandler rethrows
ExecutionException s and logs
MemberLeftException s to the log. |
static FutureUtil.ExceptionHandler |
FutureUtil.logAllExceptions(ILogger logger,
String message,
Level level)
This ExceptionHandler rethrows
ExecutionException s and logs
MemberLeftException s to the log. |
Constructor and Description |
---|
LoggingScheduledExecutor(ILogger logger,
int corePoolSize,
ThreadFactory threadFactory) |
LoggingScheduledExecutor(ILogger logger,
int corePoolSize,
ThreadFactory threadFactory,
boolean removeOnCancel) |
LoggingScheduledExecutor(ILogger logger,
int corePoolSize,
ThreadFactory threadFactory,
boolean removeOnCancel,
RejectedExecutionHandler handler) |
LoggingScheduledExecutor(ILogger logger,
int corePoolSize,
ThreadFactory threadFactory,
RejectedExecutionHandler handler) |
StripedExecutor(ILogger logger,
String threadNamePrefix,
int threadCount,
int queueCapacity) |
StripedExecutor(ILogger logger,
String threadNamePrefix,
int threadCount,
int queueCapacity,
boolean lazyThreads) |
Copyright © 2022 Hazelcast, Inc.. All Rights Reserved.