| Package | Description | 
|---|---|
| com.hazelcast.cache.impl | 
     Hazelcast JSR-107 aka JCache implementation | 
| com.hazelcast.client | Contains classes/interfaces related to Client | 
| com.hazelcast.client.impl | 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.client.spi.impl.listener | |
| com.hazelcast.collection.impl.collection | |
| 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.diagnostics | Contains functionality what is happening in a HazelcastInstance. | 
| com.hazelcast.internal.metrics.impl | Contains the  MetricsRegistryimplementation. | 
| com.hazelcast.internal.nearcache.impl.invalidation | Invalidations for near-cache | 
| com.hazelcast.internal.networking.nonblocking | Contains the non blocking  TcpIpConnectionMonitor. | 
| com.hazelcast.internal.networking.spinning | Contains the implementation of the  SpinningIOThreadingModel. | 
| com.hazelcast.internal.partition | Contains the internals for partition assignment/management, migration, replication etc. | 
| com.hazelcast.internal.usercodedeployment.impl | |
| 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.impl.eviction | This package contains eviction classes. | 
| 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  Accumulatorspecific classes. | 
| com.hazelcast.map.impl.querycache.subscriber | This package contains classes which are used for  QueryCacheevent subscription side. | 
| com.hazelcast.map.impl.recordstore | |
| 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.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
  DiscoveryStrategylookup 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  InternalEventServiceimplementation. | 
| com.hazelcast.spi.impl.operationexecutor.impl | Contains the  OperationExecutorImplcode. | 
| com.hazelcast.spi.impl.operationservice.impl | Contains the code for the  InternalOperationServiceimplementation. | 
| com.hazelcast.spi.impl.packetdispatcher.impl | Contains the implementation of the  PacketDispatcher. | 
| 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 ILogger | CacheProxy. logger | 
| protected static ILogger | AbstractHazelcastCachingProvider. LOGGER | 
| Modifier and Type | Method and Description | 
|---|---|
| static boolean | JCacheDetector. isJCacheAvailable(ClassLoader classLoader,
                 ILogger logger) | 
| Modifier and Type | Method and Description | 
|---|---|
| ILogger | ClientEngine. getLogger(Class clazz) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected static ILogger | DefaultClientExtension. LOGGER | 
| Modifier and Type | Method and Description | 
|---|---|
| protected ILogger | MemberImpl. getLogger() | 
| ILogger | ClientLoggingService. getLogger(Class clazz) | 
| ILogger | ClientEngineImpl. 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 | ClientListenerServiceImpl. logger | 
| Modifier and Type | Field and Description | 
|---|---|
| protected ILogger | CollectionContainer. 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 | Field and Description | 
|---|---|
| protected ILogger | DiagnosticsPlugin. logger | 
| Constructor and Description | 
|---|
| ConfigPropertiesPlugin(ILogger logger,
                      HazelcastProperties properties) | 
| Diagnostics(String fileName,
           ILogger logger,
           String hzName,
           HazelcastProperties properties) | 
| DiagnosticsPlugin(ILogger logger) | 
| MetricsPlugin(ILogger logger,
             MetricsRegistry metricsRegistry,
             HazelcastProperties properties) | 
| StoreLatencyPlugin(ILogger logger,
                  HazelcastProperties properties) | 
| SystemLogPlugin(HazelcastProperties properties,
               ConnectionListenable connectionObservable,
               HazelcastInstance hazelcastInstance,
               ILogger logger) | 
| SystemLogPlugin(HazelcastProperties properties,
               ConnectionListenable connectionObservable,
               HazelcastInstance hazelcastInstance,
               ILogger logger,
               NodeExtension nodeExtension) | 
| SystemPropertiesPlugin(ILogger logger) | 
| Constructor and Description | 
|---|
| MetricsRegistryImpl(ILogger logger,
                   ProbeLevel minimumLevel)Creates a MetricsRegistryImpl instance. | 
| Modifier and Type | Field and Description | 
|---|---|
| protected ILogger | Invalidator. logger | 
| protected ILogger | MetaDataFetcher. logger | 
| Constructor and Description | 
|---|
| MetaDataFetcher(ILogger logger) | 
| RepairingHandler(String name,
                NearCache nearCache,
                MinimalPartitionService partitionService,
                String localUuid,
                ILogger logger) | 
| RepairingTask(MetaDataFetcher metaDataFetcher,
             TaskScheduler scheduler,
             MinimalPartitionService partitionService,
             HazelcastProperties properties,
             String localUuid,
             ILogger logger) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected ILogger | AbstractHandler. logger | 
| Modifier and Type | Method and Description | 
|---|---|
| static com.hazelcast.internal.networking.nonblocking.SelectorOptimizer.SelectionKeysSet | SelectorOptimizer. optimize(Selector selector,
        ILogger logger)Tries to optimize the provided Selector. | 
| Constructor and Description | 
|---|
| AbstractHandler(SocketConnection connection,
               NonBlockingIOThread ioThread,
               int initialOps,
               ILogger logger,
               IOBalancer ioBalancer) | 
| NonBlockingIOThread(String threadName,
                   ILogger logger,
                   IOOutOfMemoryHandler oomeHandler) | 
| NonBlockingIOThread(String threadName,
                   ILogger logger,
                   IOOutOfMemoryHandler oomeHandler,
                   SelectorMode selectMode) | 
| NonBlockingIOThread(String threadName,
                   ILogger logger,
                   IOOutOfMemoryHandler oomeHandler,
                   SelectorMode selectMode,
                   Selector selector) | 
| NonBlockingSocketReader(SocketConnection connection,
                       NonBlockingIOThread ioThread,
                       ILogger logger,
                       IOBalancer balancer,
                       SocketReaderInitializer initializer) | 
| NonBlockingSocketWriter(SocketConnection connection,
                       NonBlockingIOThread ioThread,
                       ILogger logger,
                       IOBalancer balancer,
                       SocketWriterInitializer initializer) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected ILogger | AbstractHandler. logger | 
| Constructor and Description | 
|---|
| AbstractHandler(SocketConnection connection,
               ILogger logger,
               IOOutOfMemoryHandler oomeHandler) | 
| SpinningSocketReader(SocketConnection connection,
                    ILogger logger,
                    IOOutOfMemoryHandler oomeHandler,
                    SocketReaderInitializer initializer) | 
| SpinningSocketWriter(SocketConnection connection,
                    ILogger logger,
                    IOOutOfMemoryHandler oomeHandler,
                    SocketWriterInitializer initializer) | 
| 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,
                 ILogger logger) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractLoggerAbstract  ILoggerimplementation that provides implementations for the convenience methods like
 finest,info,warning and severe. | 
| 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) | 
| ILogger | LoggingService. getLogger(Class type) | 
| ILogger | LoggingServiceImpl. getLogger(Class clazz) | 
| ILogger | LoggerFactory. getLogger(String name) | 
| static ILogger | Logger. getLogger(String 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 | Field and Description | 
|---|---|
| protected ILogger | EvictionChecker. logger | 
| Modifier and Type | Method and Description | 
|---|---|
| ILogger | MapStoreContext. getLogger(Class clazz) | 
| Constructor and Description | 
|---|
| MemberMapMetaDataFetcher(ClusterService clusterService,
                        OperationService operationService,
                        ILogger logger) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected ILogger | QueryRunner. logger | 
| protected ILogger | MapQueryEngineImpl. 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 | 
|---|
| SocketReaderInitializerImpl(ILogger logger) | 
| SocketWriterInitializerImpl(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  ILoggerinstance 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  DiscoveryStrategywith 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) | 
| 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 | 
|---|
| InvocationRegistry(ILogger logger,
                  com.hazelcast.spi.impl.operationservice.impl.CallIdSequence callIdSequence) | 
| Constructor and Description | 
|---|
| PacketDispatcherImpl(ILogger logger,
                    PacketHandler operationExecutor,
                    PacketHandler responseHandler,
                    PacketHandler invocationMonitor,
                    PacketHandler eventService,
                    PacketHandler connectionManager,
                    PacketHandler jetService) | 
| Modifier and Type | Method and Description | 
|---|---|
| static FutureUtil.ExceptionHandler | FutureUtil. logAllExceptions(ILogger logger,
                Level level)This ExceptionHandler rethrows  ExecutionExceptions and logsMemberLeftExceptions to the log. | 
| static FutureUtil.ExceptionHandler | FutureUtil. logAllExceptions(ILogger logger,
                String message,
                Level level)This ExceptionHandler rethrows  ExecutionExceptions and logsMemberLeftExceptions to the log. | 
| Constructor and Description | 
|---|
| LoggingScheduledExecutor(ILogger logger,
                        int corePoolSize,
                        ThreadFactory threadFactory) | 
| LoggingScheduledExecutor(ILogger logger,
                        int corePoolSize,
                        ThreadFactory threadFactory,
                        RejectedExecutionHandler handler) | 
| StripedExecutor(ILogger logger,
               String threadNamePrefix,
               int threadCount,
               int maximumQueueCapacity) | 
Copyright © 2017 Hazelcast, Inc.. All Rights Reserved.