| Package | Description | 
|---|---|
| com.hazelcast.cache.impl | 
     Hazelcast JSR-107 aka JCache implementation | 
| com.hazelcast.cache.impl.merge.entry | This package contains merge entry internal interfaces and functionality for Hazelcast cache. | 
| com.hazelcast.cache.impl.record | 
     Hazelcast JSR-107 aka JCache implementation
     Internal record store | 
| 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.map.impl | |
| com.hazelcast.client.spi | Contains classes/interfaces related to the Hazelcast client Service Provider Interface. | 
| 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.collection.impl.common | |
| com.hazelcast.collection.impl.queue | |
| com.hazelcast.internal.nearcache.impl | Near Cache implementations. | 
| com.hazelcast.internal.nearcache.impl.preloader | Near Cache pre-loader implementation. | 
| com.hazelcast.internal.nearcache.impl.store | Near Cache store implementations. | 
| com.hazelcast.internal.serialization | Contains the private serialization API + implementation. | 
| com.hazelcast.internal.serialization.impl | |
| com.hazelcast.map.impl | Contains implementation specific classes of  com.hazelcast.mappackage. | 
| com.hazelcast.map.impl.event | |
| com.hazelcast.map.impl.iterator | |
| com.hazelcast.map.impl.mapstore | Contains map store operations. | 
| com.hazelcast.map.impl.mapstore.writethrough | Package for processing write through store operations. | 
| com.hazelcast.map.impl.nearcache.invalidation | |
| com.hazelcast.map.impl.query | |
| com.hazelcast.map.impl.querycache.event | This package contains classes for query cache events. | 
| com.hazelcast.map.impl.querycache.subscriber | This package contains classes which are used for  QueryCacheevent subscription side. | 
| com.hazelcast.map.impl.querycache.subscriber.record | This package contains classes for  QueryCacheRecord. | 
| com.hazelcast.map.impl.record | Contains record specific classes. | 
| com.hazelcast.map.impl.recordstore | |
| com.hazelcast.multimap.impl | Contains classes for Hazelcast MultiMap module. | 
| 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.ringbuffer.impl | Contains the  Ringbufferimplementation classes. | 
| com.hazelcast.ringbuffer.impl.client | |
| com.hazelcast.spi | Provides interfaces/classes for the Hazelcast SPI for building distributed data structures and services. | 
| com.hazelcast.spi.impl | Contains implementations for Hazelcast SPI. | 
| 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.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 SerializationService | CacheRecordStore. serializationService | 
| Constructor and Description | 
|---|
| CacheEventListenerAdaptor(ICache<K,V> source,
                         javax.cache.configuration.CacheEntryListenerConfiguration<K,V> cacheEntryListenerConfiguration,
                         SerializationService serializationService,
                         HazelcastInstance hazelcastInstance) | 
| Constructor and Description | 
|---|
| LazyCacheEntryView(Object key,
                  Object value,
                  long creationTime,
                  long expirationTime,
                  long lastAccessTime,
                  long accessHit,
                  SerializationService serializationService) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected SerializationService | CacheRecordFactory. serializationService | 
| Constructor and Description | 
|---|
| CacheRecordFactory(InMemoryFormat inMemoryFormat,
                  SerializationService serializationService) | 
| CacheRecordHashMap(SerializationService serializationService,
                  int initialCapacity,
                  CacheContext cacheContext) | 
| Modifier and Type | Method and Description | 
|---|---|
| SerializationService | ClientEngine. getSerializationService()Returns the SerializationService. | 
| Modifier and Type | Method and Description | 
|---|---|
| SerializationService | HazelcastClientInstanceImpl. getSerializationService() | 
| SerializationService | HazelcastClientProxy. getSerializationService() | 
| SerializationService | ClientEngineImpl. getSerializationService() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected SerializationService | ClientMapPartitionIterator. getSerializationService() | 
| Modifier and Type | Method and Description | 
|---|---|
| SerializationService | ClientContext. getSerializationService() | 
| protected SerializationService | ClientProxy. getSerializationService() | 
| Modifier and Type | Field and Description | 
|---|---|
| protected SerializationService | ClientListenerServiceImpl. serializationService | 
| Constructor and Description | 
|---|
| ClientDelegatingFuture(ClientInvocationFuture clientInvocationFuture,
                      SerializationService serializationService,
                      ClientMessageDecoder clientMessageDecoder) | 
| ClientDelegatingFuture(ClientInvocationFuture clientInvocationFuture,
                      SerializationService serializationService,
                      ClientMessageDecoder clientMessageDecoder,
                      V defaultValue) | 
| Constructor and Description | 
|---|
| DataAwareItemEvent(String name,
                  ItemEventType itemEventType,
                  Data dataItem,
                  Member member,
                  SerializationService serializationService) | 
| Modifier and Type | Method and Description | 
|---|---|
| static QueueStoreWrapper | QueueStoreWrapper. create(String name,
      QueueStoreConfig storeConfig,
      SerializationService serializationService,
      ClassLoader classLoader)Factory method that creates a  QueueStoreWrapper | 
| Constructor and Description | 
|---|
| QueueIterator(Iterator<Data> iterator,
             SerializationService serializationService,
             boolean binary) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected SerializationService | DefaultNearCacheManager. serializationService | 
| protected SerializationService | DefaultNearCache. serializationService | 
| Modifier and Type | Method and Description | 
|---|---|
| protected SerializationService | DefaultNearCacheManager. getSerializationService() | 
| Constructor and Description | 
|---|
| DefaultNearCache(String name,
                NearCacheConfig nearCacheConfig,
                NearCacheRecordStore<K,V> nearCacheRecordStore,
                SerializationService serializationService,
                ExecutionService executionService,
                ClassLoader classLoader) | 
| DefaultNearCache(String name,
                NearCacheConfig nearCacheConfig,
                SerializationService serializationService,
                ExecutionService executionService,
                ClassLoader classLoader) | 
| DefaultNearCacheManager(SerializationService ss,
                       ExecutionService es,
                       ClassLoader classLoader) | 
| Constructor and Description | 
|---|
| NearCachePreloader(String nearCacheName,
                  NearCachePreloaderConfig preloaderConfig,
                  NearCacheStatsImpl nearCacheStats,
                  SerializationService serializationService) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected SerializationService | AbstractNearCacheRecordStore. serializationService | 
| Constructor and Description | 
|---|
| AbstractNearCacheRecordStore(NearCacheConfig nearCacheConfig,
                            NearCacheStatsImpl nearCacheStats,
                            SerializationService serializationService,
                            ClassLoader classLoader) | 
| AbstractNearCacheRecordStore(NearCacheConfig nearCacheConfig,
                            SerializationService serializationService,
                            ClassLoader classLoader) | 
| BaseHeapNearCacheRecordStore(String name,
                            NearCacheConfig nearCacheConfig,
                            SerializationService serializationService,
                            ClassLoader classLoader) | 
| HeapNearCacheRecordMap(SerializationService serializationService,
                      int initialCapacity) | 
| NearCacheDataRecordStore(String name,
                        NearCacheConfig nearCacheConfig,
                        SerializationService serializationService,
                        ClassLoader classLoader) | 
| NearCacheObjectRecordStore(String name,
                          NearCacheConfig nearCacheConfig,
                          SerializationService serializationService,
                          ClassLoader classLoader) | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | InternalSerializationService | 
| Modifier and Type | Method and Description | 
|---|---|
| <T extends SerializationService> | SerializationServiceBuilder. build() | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractSerializationService | 
| class  | SerializationServiceV1 | 
| Modifier and Type | Field and Description | 
|---|---|
| protected SerializationService | MapContainer. serializationService | 
| Modifier and Type | Method and Description | 
|---|---|
| static <K,V> EntryView<K,V> | EntryViews. convertToLazyEntryView(EntryView entryView,
                      SerializationService serializationService,
                      MapMergePolicy mergePolicy) | 
| static <K,V> EntryView<K,V> | EntryViews. createLazyEntryView(K key,
                   V value,
                   Record record,
                   SerializationService serializationService,
                   MapMergePolicy mergePolicy) | 
| <K,V> void | MapEntries. putAllToMap(SerializationService serializationService,
           Map<K,V> map) | 
| Constructor and Description | 
|---|
| DataAwareEntryEvent(Member from,
                   int eventType,
                   String source,
                   Data dataKey,
                   Data dataNewValue,
                   Data dataOldValue,
                   Data dataMergingValue,
                   SerializationService serializationService) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected SerializationService | MapEventPublisherImpl. serializationService | 
| protected SerializationService | AbstractFilteringStrategy. serializationService | 
| Constructor and Description | 
|---|
| AbstractFilteringStrategy(SerializationService serializationService,
                         MapServiceContext mapServiceContext) | 
| DefaultEntryEventFilteringStrategy(SerializationService serializationService,
                                  MapServiceContext mapServiceContext) | 
| QueryCacheNaturalFilteringStrategy(SerializationService serializationService,
                                  MapServiceContext mapServiceContext) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected SerializationService | MapPartitionIterator. getSerializationService() | 
| protected abstract SerializationService | AbstractMapPartitionIterator. getSerializationService() | 
| Modifier and Type | Method and Description | 
|---|---|
| SerializationService | MapStoreContext. getSerializationService() | 
| Constructor and Description | 
|---|
| AbstractMapDataStore(MapStoreWrapper store,
                    SerializationService serializationService) | 
| Constructor and Description | 
|---|
| WriteThroughStore(MapStoreWrapper store,
                 SerializationService serializationService) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected SerializationService | Invalidator. serializationService | 
| Modifier and Type | Method and Description | 
|---|---|
| void | QueryResult. add(QueryableEntry entry,
   Projection projection,
   SerializationService serializationService) | 
| static Set | QueryResultUtils. transformToSet(SerializationService ss,
              QueryResult queryResult,
              Predicate predicate,
              IterationType iterationType,
              boolean unique) | 
| Constructor and Description | 
|---|
| CallerRunsAccumulationExecutor(SerializationService serializationService) | 
| ParallelAccumulationExecutor(ManagedExecutorService executor,
                            SerializationService serializationService,
                            int callTimeoutInMillis) | 
| QueryResultCollection(SerializationService serializationService,
                     IterationType iterationType,
                     boolean binary,
                     boolean unique) | 
| QueryResultCollection(SerializationService serializationService,
                     IterationType iterationType,
                     boolean binary,
                     boolean unique,
                     QueryResult queryResult) | 
| QueryResultProcessor(SerializationService serializationService) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | DefaultQueryCacheEventData. setSerializationService(SerializationService serializationService) | 
| void | QueryCacheEventData. setSerializationService(SerializationService serializationService) | 
| Constructor and Description | 
|---|
| LocalEntryEventData(SerializationService serializationService,
                   String source,
                   int eventType,
                   Object key,
                   Object oldValue,
                   Object value,
                   int partitionId) | 
| Modifier and Type | Method and Description | 
|---|---|
| static IMapEvent | EventPublisherHelper. createIMapEvent(EventData eventData,
               EventFilter filter,
               Member member,
               SerializationService serializationService) | 
| Constructor and Description | 
|---|
| QueryCacheRecordHashMap(SerializationService serializationService,
                       int initialCapacity) | 
| QueryCacheRecordHashMap(SerializationService serializationService,
                       int initialCapacity,
                       float loadFactor,
                       int concurrencyLevel,
                       ConcurrentReferenceHashMap.ReferenceType keyType,
                       ConcurrentReferenceHashMap.ReferenceType valueType,
                       EnumSet<ConcurrentReferenceHashMap.Option> options) | 
| Constructor and Description | 
|---|
| DataQueryCacheRecordFactory(SerializationService serializationService) | 
| ObjectQueryCacheRecordFactory(SerializationService serializationService) | 
| Modifier and Type | Method and Description | 
|---|---|
| static Object | Records. getValueOrCachedValue(Record record,
                     SerializationService serializationService)Return cached value where appropriate, otherwise return the actual value. | 
| Constructor and Description | 
|---|
| DataRecordFactory(MapConfig config,
                 SerializationService serializationService,
                 PartitioningStrategy partitionStrategy) | 
| ObjectRecordFactory(MapConfig config,
                   SerializationService serializationService) | 
| Modifier and Type | Method and Description | 
|---|---|
| MapEntriesWithCursor | StorageImpl. fetchEntries(int tableIndex,
            int size,
            SerializationService serializationService) | 
| MapEntriesWithCursor | Storage. fetchEntries(int tableIndex,
            int size,
            SerializationService serializationService) | 
| Constructor and Description | 
|---|
| LazyEntryViewFromRecord(R record,
                       SerializationService serializationService) | 
| StorageSCHM(SerializationService serializationService) | 
| Modifier and Type | Method and Description | 
|---|---|
| SerializationService | MultiMapService. getSerializationService() | 
| Constructor and Description | 
|---|
| ReplicationOperation(SerializationService serializationService,
                    PartitionContainer container,
                    int partitionId) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected SerializationService | AbstractBaseReplicatedRecordStore. serializationService | 
| Modifier and Type | Method and Description | 
|---|---|
| static RingbufferStoreWrapper | RingbufferStoreWrapper. create(String name,
      RingbufferStoreConfig storeConfig,
      InMemoryFormat inMemoryFormat,
      SerializationService serializationService,
      ClassLoader classLoader)Factory method that creates a  RingbufferStoreWrapper. | 
| void | RingbufferContainer. init(String name,
    RingbufferConfig config,
    SerializationService serializationService,
    ClassLoader configClassLoader)Initializes the ring buffer with references to other services, the ring buffer store and the config. | 
| Constructor and Description | 
|---|
| RingbufferContainer(String name,
                   RingbufferConfig config,
                   SerializationService serializationService,
                   ClassLoader configClassLoader) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | PortableReadResultSet. setSerializationService(SerializationService serializationService) | 
| Modifier and Type | Method and Description | 
|---|---|
| SerializationService | NodeEngine. getSerializationService()Gets the SerializationService. | 
| Modifier and Type | Method and Description | 
|---|---|
| SerializationService | SerializationServiceSupport. getSerializationService() | 
| SerializationService | NodeEngineImpl. getSerializationService() | 
| Constructor and Description | 
|---|
| UnmodifiableLazyList(List list,
                    SerializationService serializationService) | 
| Constructor and Description | 
|---|
| DataAwareMessage(String topicName,
                Data messageData,
                long publishTime,
                Member publishingMember,
                SerializationService serializationService) | 
| Modifier and Type | Method and Description | 
|---|---|
| static <C> Collection<Data> | CollectionUtil. objectToDataCollection(Collection<C> collection,
                      SerializationService serializationService)Converts a collection of any type to a collection of  Data. | 
| Constructor and Description | 
|---|
| CompletedFuture(SerializationService serializationService,
               Object value,
               ExecutorService asyncExecutor) | 
| DelegatingFuture(InternalCompletableFuture future,
                SerializationService serializationService) | 
| DelegatingFuture(InternalCompletableFuture future,
                SerializationService serializationService,
                V result)Creates a DelegatingFuture | 
Copyright © 2016 Hazelcast, Inc.. All Rights Reserved.