|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
CacheRecord
with key, value and
expiration time as internal state.AbstractClusterWideIterator
provides the core iterator functionality shared by its descendants.Credentials
EntryProcessor
that already has implemented the AbstractEntryProcessor.getBackupProcessor()
.EntryProcessor.process(java.util.Map.Entry)
to primary and backups.
EvictionPolicy
.EvictableStore
implementations as specified
EvictionPolicyEvaluator
.HazelcastCacheManager
(also CacheManager
as indirect) implementation
provides shared functionality to server and client cache managers.RegionFactory
implementationsCachingProvider
implementation providing shared functionality to server and client caching
providers.IMapEvent
.JobTracker
implementations on node and client side.LoadBalancer
implementation.ILogger
implementation that provides implementations for the convenience methods like
finest,info,warning and severe.NearCacheRecord
with value and
expiration time as internal state.Operation
implementation with some basic methods
implemented.ReplicatedRecordStore
implementationsEntryProcessor
s which will use the web data serializer
.Supplier
interface which accepts all input values and may apply a given
PropertyExtractor
on those.AddAllOperation
AddAllOperation
OverflowPolicy
.
CacheEntryListener
.
DistributedObject
will be created or destroyed.
MapListener
for this map.
IMap.addEntryListener(MapListener, boolean)
instead.
MapListener
for this map.
IMap.addEntryListener(MapListener, Predicate, Object, boolean)
instead.
MapListener
for this map.
IMap.addEntryListener(MapListener, Predicate, boolean)
instead.
MapListener
for this map.
IMap.addEntryListener(MapListener, Object, boolean)
EntryListenerConfig
to this QueryCacheConfig
.
CacheInvalidationListener
for specified cacheName
.
MapListener
for this map.
IMap.addLocalEntryListener(MapListener)
instead.
MapListener
for this map.
IMap.addLocalEntryListener(MapListener, com.hazelcast.query.Predicate, boolean)
IMap.addLocalEntryListener(MapListener, com.hazelcast.query.Predicate, boolean)
instead
MemberGroupConfig
.
ProxyFactoryConfig
queryCacheConfig
to this MapConfig
.
Address
that a Hazelcast cluster member binds its server socket to
and a (potentially different) address that Hazelcast will advertise to other cluster members and clients.PropertyExtractor
s transformation to the
input data.
ArrayList
.ArrayList
serializerIAtomicLong
interface that exposes its operations using an
ICompletableFuture
interface so it can be used in the reactive programming model
approach.IAtomicReference
that exposes its operations using a ICompletableFuture
so it can be used in the reactive programming model approach.==
the expected value.
==
the expected value.
IAtomicLong
IAtomicReference
HazelcastException
that is thrown when there is an Authentication failure: e.g.ClientConnection
.Notifier
operation or timeout specified by
WaitSupport.getWaitTimeout()
passes.
Cache.Entry
atomically, according to the defined
consistency of a Cache
.BackupOperation
is created to replicate the backup.BackupAwareOperation
makes a change, the backups need to be replicated to other
members (depending on the configuration and if change really happened).BackupOperation
.BigDecimal
average
of all supplied values.BigDecimal
.BigDecimal
maximum
of all supplied values.BigDecimal
.BigDecimal
minimum
of all supplied values.BigDecimal
.BigDecimal
sum
of all supplied values.BigDecimal
.BigInteger
average
of all supplied values.BigInteger
.BigInteger
maximum
of all supplied values.BigInteger
.BigInteger
minimum
of all supplied values.BigInteger
.BigInteger
sum
of all supplied values.BigInteger
.MutableDirectBuffer
that encapsulates the internal buffer.
BufferBuilder.INITIAL_CAPACITY
StreamSerializer
.ByteBuffer
if one exists.
CacheClearOperation
.CacheClearOperationFactory
on the server side.OperationFactory
implementation for Clear Operations.CacheClearOperationFactory
on the server side.CacheClearOperation
.ICache
CacheConfig
CompleteConfiguration
CacheContainsKeyOperation
on the server side.CacheContainsKeyOperation
on the server side.CacheCreateConfigOperation
on the server side.CacheCreateConfigOperation
on the server side.CacheRecord
where value has an internal serialized format.CacheDataSerializerHook
contains all the ID hooks for IdentifiedDataSerializable
classes used
inside the JCache framework.CacheDestroyParameters
on the server side.AbstractCacheService.destroyCache(String, boolean, String)
.CacheDestroyOperation
on the server side.CacheService
and NodeEngine
.Cache.Entry
implementation for wrapping a "key,value" pair.CacheEntryListener
.CacheEntryListener
instance.MutableEntry
which is provided into
EntryProcessor.process(javax.cache.processor.MutableEntry, Object...)
.CacheEntryProcessorOperation
on the server side.CacheEntryProcessorOperation
on the server side.EntryProcessorResult
wraps the result returned or exception thrown in a
single object so that multiple exceptions from multiple entry processes can be returned.CacheEventData
.CacheEventListener
uses the adapter pattern for wrapping all cache event listener
types into a single listener.CacheEventData
items used during publishing and dispatching events.EvictionConfig
instead of thisEvictionConfigReadOnly
instead of thisCacheGetAllOperationFactory
on the server side.CacheGetAllOperation
.CacheGetAllOperationFactory
on the server side.CacheGetAndRemoveOperation
on the server side.CacheGetAndRemoveOperation
on the server side.CacheGetAndReplaceOperation
on the server side.CacheGetAndReplaceOperation
on the server side.CacheGetConfigOperation
on the server side.CacheGetConfigOperation
on the server side.CacheGetOperation
on the server side.CacheGetOperation
on the server side.CacheKeyIteratorOperation
on the server side.CacheKeyIteratorOperation
on the server side.CacheKeyIteratorOperation
.CacheListenerRegistrationOperation
on the server side.CacheService
.CacheListenerRegistrationOperation
on the server side.CacheLoadAllOperationFactory
on the server side.ICacheRecordStore
.CacheLoadAllOperation
.CacheLoadAllOperationFactory
on the server side.CacheManagementConfigOperation
on the server side.CacheManagementConfigOperation
on the server side.CacheMXBean
.CacheRecordStore
instances but the cache config does not exist on the node to create the instance on.CacheRecord
which has an internal object format.CachePortableHook
contains all the ID hooks for classes used inside the JCache framework which implement
Portable
.CachePutIfAbsentOperation
on the server side.ICacheRecordStore.putIfAbsent(Data, Object, ExpiryPolicy, String, int)
.CachePutIfAbsentOperation
on the server side.CachePutOperation
on the server side.com.hazelcast.cache.impl.ICacheRecordStore#put(Data, Object, ExpiryPolicy, String)
and
com.hazelcast.cache.impl.ICacheRecordStore#getAndPut(Data, Object, ExpiryPolicy, String)
.CachePutOperation
on the server side.CacheRecord
.ICacheRecordStore
CacheRemoveAllOperation
.CacheRemoveAllOperationFactory
on the server side.OperationFactory
implementation for RemoveAll Operations.CacheRemoveOperation
on the server side.CacheRemoveOperation
on the server side.CachePutOperation
on the server side.CacheReplaceOperation
on the server side.CacheRecordStore
.CacheSimpleConfig
CacheSizeOperationFactory
on the server side.CacheSizeOperation
.CacheSizeOperationFactory
on the server side.CacheStatistics
implementation for ICache
.CacheStatisticsMXBean
CallIdSequence
that provided backpressure by taking
the number in flight operations into account when a call-id needs to be determined.false
.
false
.
Subject
has been granted specified permission or not.
true
.
OperationExecutor
that schedules:
partition specific operations to a specific partition-operation-thread (using a mod on the partition-id)
non specific operations to generic-operation-threads
The ClassicOperationExecutor.execute(Object, int, boolean)
accepts an Object instead of a runnable to prevent needing to
create wrapper runnables around tasks.ClassLoadingMXBean
metrics.Config
which is initialized by loading an XML configuration file from the classpath.ReplicatedRecordStore
implementations
a chance to register themself to being cleaned up from expired entriesCacheStatisticsMXBean.clear()
.
PartitionGroupConfig.MemberGroupType
instances.
MapStore.deleteAll(java.util.Collection)
deleteAll on MapStore which,
if connected to a database, will delete the records from that database.
WriteBehindQueue
Queue will be empty after this method returns.
NearCache
instances.
NearCache
instance associated with given name
but not removes it.
ClearOperation
ClientContext
.IExecutorService
.Cluster
.ClientClusterService
implementation.ICache
.ClientConnection
objects.ClientEndpoint
.ClientEndpoint
and Client
implementation.ClientEndpoint
s.ClientEndpointImpl
s.ClientEngine
SerializationService
, SocketChannelWrapperFactory
etc.ClientNearCache
.Client
implementation.ClientMessage
s from byte chunks.ClientPartitionService
implementation.ReplicatedMap.addEntryListener(com.hazelcast.core.EntryListener)
implementationMap.clear()
implementationMap.containsKey(Object)
implementationMap.containsValue(Object)
implementationMap.entrySet()
implementationMap.get(Object)
implementationMap.isEmpty()
implementationMap.keySet()
implementationMap.putAll(java.util.Map)
implementationReplicatedMap.put(Object, Object, long, java.util.concurrent.TimeUnit)
implementationReplicatedMap.removeEntryListener(String)
implementationMap.remove(Object)
implementationMap.size()
implementationMap.values()
implementationClient
s and
attach/detach ClientListener
s to listen to connection events.ClientService
.TransactionalMap
.TransactionalMap
interface.ICache
.Runnable
.EvictionPolicyEvaluator
implementations for cache.EvictionStrategy
implementations for cache.EvictionStrategy
implementations for cache.AtomicLong
.AtomicReference
.CountDownLatch
.IdGenerator
it is very simple to create cluster wide id's.ILock
is the distributed version of the Lock
.Semaphore
.ConfigPatternMatcher
.ExecutorService
and provides all kinds
of additional methods related to distributed systems.MetricsRegistry
implementation.com.hazelcast.map
package.IMap
TransactionalMap
MapListener
interfaces.IMap
InternalPartitionService
.Ringbuffer
.Ringbuffer
implementation classes.InternalEventService
.InternalEventService
implementation.EventServiceImpl
.InternalExecutionService
.InternalExecutionService
.OperationRunner
code.ClassicOperationExecutor
code.OperationRunner
instances from the
OperationExecutor
.InternalOperationService
API.InternalOperationService
implementation.OperationServiceImpl
.Operation
InternalProxyService
.InternalProxyService
.ProxyServiceImpl
.PacketTransceiver
.PacketTransceiver
.WaitNotifyService
.InternalWaitNotifyService
.ITopic
.Job
.Mapper
implementations in the same node.CombinerFactory
for this task.
Combiner
instances per key.Mapper
implementation to run alongside.ArrayList
subclass exists to prevent
DefaultContext.CollectingCombinerFactory
created collections to be mixed up with user provided List results from
Combiner
s.Map
backing arrays by rehashing with a capacity just larger than current size
and giving consideration to the load factor.
Comparable
implementing values.Comparable
.Comparable
implementing values.Comparable
.CompareAndRemoveOperation
==
the expected value.
==
the expected value.
HazelcastInstance
.HazelcastException
that is thrown when something is wrong with the server or client configuration.ICredentialsFactory
.
IPermissionPolicy
.
Config
to a Hazelcast XML string.ClientConnectionManager
to listen to connection heartbeatsConnectionManager
to listen to connections
being added or removed.Connection
objects.ConnectionManagerMBean
.ConnectionManager
Map.containsKey(Object)
that takes a primitive int key.
true
if this map contains an entry for the specified
key.
true
if this map contains an entry for the specified
key.
IMap.containsKey(Object)
.
ContainsOperation
CacheEventType
into EventType
.
ICountDownLatch
QueueStoreWrapper
EntryProcessor
to be executed on the backup-partition, or returns
LoginContext
.
Set
or List
depending on the MultiMapConfig.valueCollectionType
and creates it.
Set
or List
depending on the MultiMapConfig.valueCollectionType
and creates it.
MultiMapConfig.valueCollectionType
.
HashMap
with its initialCapacity calculated
to minimize rehash operations
HazelcastHttpSession instance
creation is split off to a separate method to allow subclasses to return a
customized / extended version of HazelcastHttpSession
.
ListenerAdapter
array
for all event types of EntryEventType
.
ListenerAdapter
array
for all event types of EntryEventType
.
MapService
object.
LoginContext
.
NearCacheManager
instance to be used by this client.
SerializationService
instance to be used by this client.
SocketChannelWrapperFactory
instance to be used by this client.
SocketInterceptor
to be used by this client if available,
otherwise returns null
.
DelayedEntry
.
ItemEvent
that is able to store a Data
.Data
based ReplicatedRecordStore
implementationQueryCache
.
QueryCache
.
QueryCache
as binary.
QueryCache
.
ObjectNamespace
implementation.InMemoryFormat.NATIVE
PartitioningStrategy
that checks if the key implements PartitionAware
.IMap.delete(Object)
.
ICredentialsFactory
.
IPermissionPolicy
.
SecurityContext
and all security elements.
NearCache
instances.
NearCache
instance associated with given name
and also removes it.
Boolean.TRUE
or Boolean.FALSE
to
indicate whether the reference count has reached zero.HazelcastException
that indicates that a DistributedObject
access was attempted, but the object is destroyed.DistributedObject
is created or destroyed cluster-wide.DistributedObject
is created or destroyed cluster-wide.EvictionConfig
in NearCacheConfig
.
MetricsRegistry.register(Object, String, DoubleProbe)
DrainOperation
Collections.emptySet()
or Collections.emptyList()
)} depending on the
MultiMapConfig.valueCollectionType
MapListener
.EvictionConfig.MaxSizePolicy.ENTRY_COUNT
EvictionConfig.MaxSizePolicy.ENTRY_COUNT
.IMap
listener related methods
such as IMap.addLocalEntryListener(EntryListener)
.Map.Entry
.Set
clone of the mappings contained in this map.
Set
view of the mappings contained in this map.
Set
view of the mappings contained in this map.
EvictionPolicy
rule
on the given input set of candidates.
EventServiceMBean
.EventService
EvictionStrategy
to eventually evict, by the policy, selected
candidates from the internal data structures.
EvictionChecker
.
EvictionChecker
.
Evictable
entries to evict.SampleableEvictableStore
.
EvictionConfig
.EvictionPolicy
.EvictionPolicyType
) of EvictionPolicyEvaluator
.EvictableStore
implementations as specified
EvictionPolicyEvaluator
.EvictionStrategyType
) of EvictionStrategy
.EvictionStrategy
IExecutorService
.IExecutorService
Predicate
or KeyPredicate
).
DataSerializer
! If the stream
format is ever changed this extraction method needs to be changed too!
tableIndex
as size
and puts them into keys
list.
Config
which includes functionality for loading itself from a
XML configuration file.IndexAwarePredicate
for filtering.
ValueOut
to be sent to the Reducer
for the according
key.
Mapper.map(Object, Object, Context)
method is executed for every value and
can be used to finalize the internal state of the mapper or to emit a special value.
Mapper.map(Object, Object, Context)
method is executed for every value and
can be used to finalize the internal state of the mapper or to emit a special value.
Level.FINEST
.
Level.FINEST
.
Level.FINEST
.
ExecutionException
and it has a non-null inner
cause, this inner cause is unwrapped and the local stacktrace and exception message are added to the
that instead of the given remoteCause itself.
ExecutionException
and it has a non-null inner
cause, this inner cause is unwrapped and the local stacktrace and exception message are added to the
that instead of the given remoteCause itself.
KeyPredicate
and does not perform any kind of data transformation.
KeyPredicate
and chains the filtered value to the given Supplier which might perform data transformation.
IList
.IMap
MultiMap
Predicate
and does not perform any kind of data transformation.
Predicate
and chains the filtered value to the given Supplier which might perform data transformation.
ISet
.GarbageCollectorMXBean
metrics.Metric
implementation.ClientExceptionConverter
that converts a Throwable to a GenericError
.OperationThread
for non partition specific operations.ExpiryPolicy
.
null
if this cache contains no mapping for the key.
key
.
key
.
Map.get(Object)
that takes a primitive int key.
null
if this map does not contain this key.
null
if this map does not contain this key.
IMap.get(Object)
.
RecordStore
.
null
if this map contains no mapping for the key.
Evictable
.
Evictable
entry or record or whatever.
Evictable
in milliseconds.
Map
of the values associated with the set of keys requested.
Map
of the values associated with the set of keys requested.
KeyValueSource.isAllKeysSupported()
returns true, a call to this method returns
all clusterwide available keys.
KeyValueSource.getAllKeys()
.
ExpiryPolicy
,
returning an existing value if one existed.
ExpiryPolicy
.
ExpiryPolicy
and returns the previously assigned value.
ExpiryPolicy
and returns the previously assigned value.
ExpiryPolicy
.
ExpiryPolicy
.
ClientAwsConfig
.
IMap
BackupOperation
responsible for making the backup.
QueryCache
.
DirectBuffer
into the provided MutableDirectBuffer
at given indices.
ByteBuffer
.
CacheEntryListener
CacheService
.
SocketInterceptor
implementation class.
ClusterClock
of the cluster.
ICompletableFuture
to add callbacks
or wait for the resulting value of the tracked job.
Evictable
in milliseconds.
Credentials
ICredentialsFactory
.
Data
.
Data
, if available.
Data
.
EvictionStrategy
implementation.
Constructor
which will be used to create a MapService
object.
QueryCache
HazelcastInstance.getDistributedObject(String, String)
instead.
SecurityInterceptor
DistributedObject
's such as; queue, map, set, list, topic, lock, multimap.
SecurityInterceptor
Address
of the other side of this Connection.
EntryEventType
.
DistributedObjectEvent.EventType.CREATED
or DistributedObjectEvent.EventType.DESTROYED
.
Evictable
entry or record or whatever.
EvictionConfig
instance for eviction configuration of the cache config.
EvictionConfig
instance for this QueryCache
EvictionPolicyEvaluator
implementation specified with evictionPolicy
.
EvictionStrategy
implementation specified with evictionStrategyType
.
SSLContextFactory
implementation class.
SSLContextFactory
implementation object.
EventFilter
attached to this registration.
GroupConfig
HazelcastInstance
implementation.
HazelcastInstance
from Session
.
HazelcastInstance
from SessionFactory
.
HazelcastInstance
from SessionFactoryImplementor
.
NodeEngine
belongs to.
DistributedObject.getName()
instead
SocketInterceptor
implementation object
Member.getSocketAddress()
instead
InMemoryFormat
of the storage for internal records.
QueryCache
.
JobProcessInformation
to find out the state and
statistics of a running task, or returns null if the underlying job id is not available because the job is already
finished or has not yet been submitted.JobTracker
JoinConfig
.
DistributedObject.getName()
instead.
ListenerConfig
's
HazelcastInstance.getLock(String)
instead.
ManagedContext
MapServiceContext
implementation.
EvictionConfig.getMaximumSizePolicy()
instead of this
ClientInitialMembershipEvent.MEMBER_ATTRIBUTE_CHANGED
.
ClientMembershipEvent.MEMBER_ATTRIBUTE_CHANGED
.
MemberGroupConfig
elements.
InitialMembershipListener
is
registered.
SecurityInterceptor
Method name which called via a distributedObject
for map.put, methodName will be 'put'
For requests which do not produced via a distributedObject should return null, for example internal client.
this
NearCache
instance.
IMap
QueryCache
.
QueryCache
.
JobTracker
NearCache
instance
associated with given name
.
NearCacheConfig
configured for the map / cache with name
NearCacheStats
instance to monitor this store.
NearCacheStats
instance to monitor this record store.
ClientNetworkConfig
Storage
.
InternalOperationService
.
OperationRunner
instance.
NearCache
with given configurations
or returns existing one.
Int2ObjectHashMap.Supplier
and put it in the map.
SecurityInterceptor
Parameters passed to the method by a distributedObject
for map.put(key, value) parameters should be 'key' and 'value'
parameters can be in binary or object form, underlying implementation will de-serialize lazily
Partition
s in the cluster.
JobPartitionState
s holding
information about the processing state (JobPartitionState.State
)
and the processing owner of this partition.JobPartitionState
inside of the
array is the number of the processed partition if the KeyValueSource
is PartitionIdAware
or a randomly assigned id for
the different members of the cluster.
QueryCache
.
Properties
object
ProxyFactoryConfig
QueryCacheConfig
instances defined on this MapConfig
Quorum
instance for a given quorum name.
sampleCount
.
PortableWriter.getRawDataOutput()
.
null
if it is unconnected.
GetResultOperation
instances.OperationFactory
this class
is never ever serialized and the DataSerializable methods GetResultOperationFactory.readData(com.hazelcast.nio.ObjectDataInput)
and GetResultOperationFactory.writeData(com.hazelcast.nio.ObjectDataOutput)
throw UnsupportedOperationException
s.ClientSecurityConfig
object
SerializationConfig
SharedService
for the given serviceName.
SocketInterceptorConfig
.
SSLConfig
.
SSLConfig
.
SymmetricEncryptionConfig
.
backupCount + asyncBackupCount
) of the cache config.
TrackableJob
, or null if the job id is not available
or the job is already finished.
TransactionOptions.TransactionType
.
ConnectionType
of this Connection.
NearCacheRecord
.
CacheRecord
.
WanReplicationPublisher
by the given name.
Arrays.hashCode(Object[])
.
HazelcastInstance
's, a node in a cluster.Clock.ClockImpl
implementation.
CacheManager
.CachingProvider
implementation.Hazelcast
class and provides the ability
the create and manage Hazelcast clients.HazelcastInstance
instance.HazelcastConnectionImpl
ExpiryPolicy
parameter.ExpiryPolicy
to
react on all three types of policies:
Create
Access
Update
TimeUnit
to convert those values to internally used time unites.
ExpiryPolicy
.
Duration
class.
IHazelcastInstanceLoader
that returns a HazelcastInstance
depending on configuration either backed by Hazelcast
client or node implementation.HazelcastInstance
that is thrown when the system won't handle more load due to
an overload.CacheManager
for server implementation.ThreadGroup
that provides some additional capabilities.LocalTransaction
and
LocalTransaction
into one interfaceHazelcastTransaction
java.util.concurrent.atomic.AtomicLong
.java.util.concurrent.atomic.AtomicReference
.ICache
interface is the Cache
extension offered by
Hazelcast JCache.ICache
implementations.ICacheRecordStore
is the core contract providing internal functionality to
ICache
implementations on partition scope.Condition
.java.util.concurrent.CountDownLatch
.Credentials
objects to be used
during node authentication before connection is accepted by the master node.DataSerializable
to avoid reflection during de-serialization.long
) in a cluster.ExecutorService
.MemberLeftException
per future and just tries
to finish all of the given ones.
List
The Hazelcast IList is not a partitioned data-structure.Lock
.RegionCache
implementation based on the underlying IMapEvictable
as 1
.
Evictable
as 1
.
Index
Level.INFO
.
Config.setProperty(String, String)
SSLConfig
init
method in some cases that same instance of this class can be used
instead of creating a new one for every iteration when scanning large data sets, for example:
Mapper.map(Object, Object, Context)
method is executed for every value and
can be used to initialize the internal state of the mapper or to emit a special value.
Mapper.map(Object, Object, Context)
method is executed for every value and
can be used to initialize the internal state of the mapper or to emit a special value.
InitialMembershipListener
registers itself on a Cluster
.MembershipListener
that first receives a
InitialMembershipEvent
when it is registered so it immediately knows which members are available.Config
loaded from an in-memory Hazelcast XML String.HazelcastInstance
Map
implementation specialised for int keys using open addressing and
linear probing for cache efficient access.SecurityInterceptor
configured
Any exception thrown during interception will be ignored
SecurityInterceptor
configured
ICompletableFuture
with more functionality like getting
the result without needing to deal with checked exceptions.EventService
interface that adds additional capabilities
we don't want to expose to the end user.ExecutionService
.InternalPartitionService
implementation.ProxyService
.key
.
destroyed
session, removing them
from the clustered map.InvocationBuilder
that is tied to the OperationServiceImpl
.EntryProcessor
against the Cache.Entry
specified by
the provided key.
Subject
's
permissions to perform a security sensitive Hazelcast operation.NodeEngine
belongs to is still active.
KeyValueSource.getAllKeys()
must return all available keys
to execute a preselection of interesting partitions / nodes based on returns keys.
true
if coalescing is is enabled, otherwise returns false
.
Semaphore
.Map.isEmpty()
.
true
if the given collection is null or empty, otherwise returns false
.
Set
This class is not a general-purpose Set implementation! While this class implements
the Set interface, it intentionally violates Set's general contract, which mandates the
use of the equals method when comparing objects.Expirable
entry is expired or not.
Level.FINEST
is enabled.
maxIdleSeconds
.
true
if value caching enabled, otherwise returns false
.
IndexAwarePredicate
for checking if indexed.
true
if the given collection is not null and not empty, otherwise returns false
.
true
if initial population of QueryCache
is enabled, otherwise returns false
.
Portable
object,
false otherwise.
EvictionConfig.MaxSizePolicy
MessageListener.onMessage(com.hazelcast.core.Message)
.
WanReplicationOperation
true
if write-coalescing is enabled.
IQueue
, ISet
and IList
Iterable
size
IteratorOperation
ClientExceptionConverter
for java.JobTracker.newJob(KeyValueSource)
.JobPartitionState
array.JobPartitionState
.Job
s depending
on the given data structure / data source.JobTracker
.JobTracker
.KeyPredicate
analysis.
KeyPredicate
implementation to preselect keys the MapReduce task will be executed on.
KeyPredicate
implementation to preselect keys that the MapReduce task will be executed on.
KeyPredicate
implementation to preselect keys the MapReduce task will be executed on.
KeyPredicate
implementation to preselect keys the MapReduce task
will be executed on.
KeyPredicate
s, used
to filter and optionally transform data (using the given
Supplier
).KeysAssignmentOperation
executions.Set
view of the key contained in this map.
IMap.keySet()
.
IMap.keySet(com.hazelcast.query.Predicate)
.
Set
view of the keys contained in this map.
KeyValueSource
based
map reduce operation on all cluster members.IMap
and MultiMap
.KeyValueSource
scope.EvictionPolicy.LFU
policy.Mapper
normally used for more complex
algorithms with a need for initialization and finalization.Job
.LifecycleEvent
's
on HazelcastInstance.LifecycleService
implementation for the client.LinkedList
.LinkedList
serializerListMessageType.LIST_ADDALL
ListMessageType.LIST_ADDALLWITHINDEX
ListMessageType.LIST_ADDLISTENER
ListMessageType.LIST_ADD
ListMessageType.LIST_ADDWITHINDEX
NearCache
instances.
ListMessageType.LIST_CLEAR
ListMessageType.LIST_COMPAREANDREMOVEALL
ListMessageType.LIST_COMPAREANDRETAINALL
IList
.IList
(read-only).ListMessageType.LIST_CONTAINSALL
ListMessageType.LIST_CONTAINS
IMap
listeners.ListenerAdapter
EventListener
.ListMessageType.LIST_GETALL
ListMessageType.LIST_GET
ListMessageType.LIST_INDEXOF
com.hazelcast.client.impl.protocol.parameters.ListMessageType#QUEUE_ADDLISTENER
ListMessageType.LIST_ITERATOR
KeyValueSource
implementation is used in
KeyValueSource.fromList(com.hazelcast.core.IList)
to generate a default
implementation based on a Hazelcast IList
.ListMessageType.LIST_LASTINDEXOF
IList
ListMessageType.LIST_REMOVELISTENER
ListMessageType.LIST_REMOVE
ListMessageType.LIST_REMOVEWITHINDEX
ListMessageType.LIST_SET
ListMessageType.LIST_SIZE
ListMessageType.LIST_SUB
IMap.loadAll(boolean)
calls.
CacheLoader
for the given keys.
LoadBalancer
allows you to send operations to one of a number of endpoints(Members).HazelcastInstance
or loads an already
existing instances by it's name.
MemberState
implementations.LocalCacheStats
This class just provides serialization/deserialization methods to be used in
MemberState
implementation while sending/receiving statistics to/from
Management center.LocalMapStats
LocalMapStatsProvider.createLocalMapStats(java.lang.String)
and also holds all LocalMapStatsImpl
implementations of all maps.RegionCache
implementation
based on a topic to distribute cache updates.ILock
ExecutionException
s and logs
MemberLeftException
s to the log.
ExecutionException
s and logs
MemberLeftException
s to the log.
ExecutionException
s and logs
MemberLeftException
s to the log.
ExecutionException
s and logs
MemberLeftException
s to the log.
MetricsRegistry.register(Object, String, LongProbe)
EvictionPolicy.LRU
policy.ManagedConnection
ManagedExecutorServiceMBean
.ManagedExecutorService
KeyValueSource
instance
on this cluster node and partition.KeyValueSource
instance
on this cluster node and partition.MapLoader.loadAllKeys()
MapLoader.loadAll(java.util.Collection)
.
MapStoreConfig.writeCoalescing
to false
.
EntryListener
for near cache operations.IMap.clear()
.
IMap.clear()
.IMap
.MapConfig
IMap
(read-only).PostJoinAwareService.getPostJoinOperation()
Otherwise undesired situations, like deadlocks, may appear.
EntryEventType.EVICT_ALL
and EntryEventType.CLEAR_ALL
.IMap.evictAll()
.
IMap.evictAll()
.MapLoader
and sends them to all partitions for loadingKeyValueSource
implementation is used in
KeyValueSource.fromMap(com.hazelcast.core.IMap)
to generate a default
implementation based on a Hazelcast IMap
.ListenerAdapter
implementations.MapMessageType.MAP_LOCK
IMap
Job
.Job
.IMap
interface.MapService
object.MapServiceContext
.MapServiceContext
.MapService
object
and also aware of its MapServiceContext
.MapStoreContext
objects
according to MapStoreConfig
.MapMessageType.MAP_TRYLOCK
IMap
InstancePermission
.
InstancePermission
.
ConfigPatternMatcher
supports a simplified wildcard matching.EvictionConfig.MaxSizePolicy
.MaxSizeConfig.MaxSizePolicy
to start eviction process.JobProcessInformationImpl
extending class is
used in non partitionId based map reduce tasks where partitions are kind of simulated using
a unique id per member.ExecutionException
thrown when a member left during an invocation or execution.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.SocketInterceptorConfig
MergePolicyProvider
instances.ITopic
.ITopic
.MetricsRegistry
implementation.IOSelector
.MapService
starts moving its data around because partitions are moving
to a different machine.a
by b
.
a
by b
.
MultiMapMessageType.MULTIMAP_ADDENTRYLISTENER
MultiMapMessageType.MULTIMAP_ADDENTRYLISTENERTOKEY
MultiMapMessageType.MULTIMAP_CLEAR
MultiMap
.MultiMapMessageType.MULTIMAP_CONTAINSENTRY
MultiMapMessageType.MULTIMAP_CONTAINSKEY
MultiMapMessageType.MULTIMAP_CONTAINSVALUE
MultiMapMessageType.MULTIMAP_COUNT
MultiMapMessageType.MULTIMAP_ENTRYSET
MultiMapMessageType.MULTIMAP_FORCEUNLOCK
MultiMapMessageType.MULTIMAP_GET
MultiMapMessageType.MULTIMAP_ISLOCKED
MultiMapMessageType.MULTIMAP_KEYSET
KeyValueSource
implementation is used in
KeyValueSource.fromMultiMap(com.hazelcast.core.MultiMap)
to generate a default
implementation based on a Hazelcast MultiMap
.MultiMapMessageType.MULTIMAP_LOCK
MultiMap
MultiMapMessageType.MULTIMAP_PUT
MultiMapMessageType.MULTIMAP_REMOVEENTRYLISTENER
MultiMapMessageType.MULTIMAP_REMOVEENTRY
MultiMapMessageType.MULTIMAP_REMOVE
MultiMapMessageType.MULTIMAP_SIZE
MultiMapMessageType.MULTIMAP_TRYLOCK
MultiMapMessageType.MULTIMAP_UNLOCK
MultiMapMessageType.MULTIMAP_VALUECOUNT
MultiMapMessageType.MULTIMAP_VALUES
Counter
that is thread-safe; so can be incremented by multiple threads concurrently.Operation
carries the distributed data structure name that is going to work on.NearCache
is the contract point to store keys and values in underlying
NearCacheRecordStore
.NearCache
.NearCacheRecord
to store
Data
type objects.NearCacheManager
is the contract point to manage all existing
NearCache
instances.NearCacheRecord
to store
any object type without Data
type.NearCacheRecordStore
is the contract point to store keys and values as
NearCacheRecord
internally and to serve them.NearCache
implementations.Combiner
instance specific to the supplied key.
ILock.newCondition(String)
instead.
ICondition
instance that is bound to this
ILock
instance with given name.
Credentials
object.
Job
instance for the given KeyValueSource
instance.
QueryResult
with configured result limit (according to the number of partitions) if feature is enabled.
Reducer
instance specific to the supplied key.
ManagedService
.Node
CachedDataRecord
.
WaitSupport
operation to wake-up and continue executing.
Getter
.InMemoryFormat.OBJECT
based
ReplicatedRecordStore
implementationOfferOperation
EntryListener
is not
overridden.
Evictable
entry is evicted.
EntryListener
is not
overridden.
OutOfMemoryError
is caught by Hazelcast threads,
this method is called for ALL HazelcastInstance
s
knows by current JVM (actually ClassLoader).
NodeExtension.onThreadStart(Thread)
.
OperatingSystemMXBean
metrics.Runnable
.Operation
instances.OperationRunner
instances.Operation
OperationServiceMBean
.InternalOperationService
.OperationService
TimeoutException
.OutOfMemoryError
.Packet
instances.PacketTransceiver
implementation.IllegalArgumentException
if pageSize is not greater than 0
IllegalArgumentException
if pageSize is not greater than 0
throws IllegalArgumentException
if inner predicate is also PagingPredicate
IllegalArgumentException
if pageSize is not greater than 0
IllegalArgumentException
if pageSize is not greater than 0
throws IllegalArgumentException
if inner predicate is also PagingPredicate
SecurityInterceptor
.PartitionAware.getPartitionKey()
's owner member.PartitionAware
key.MapService
notifies its map listeners when partition is lost for a map.Invocation
evaluates a Operation Invocation for a particular partition running on top of the
OperationServiceImpl
.RetryableHazelcastException
that is thrown when an operation is executed
on a partition, but that partition is currently being moved around.EventObject
for a partition migration.OperationThread
that executes Operations for a particular partition, e.g.MigrationAwareService
when partition changes happen.Partition
s and attach/detach MigrationListener
s to listen to partition
migration events.PartitionServiceMBean
.PartitionService
Runnable
for a specific partition.TargetClientRequest
which sends a Callable
task
to a specific target.PeekOperation
PollOperation
Predicate
.Predicate
instances.Predicate
s, used
to filter and optionally transform data (using the given
Supplier
).MetricsRegistry.scanAndRegister(Object, String)
is called.GroupProperties.PROP_ENTERPRISE_WAN_REP_BATCH_SIZE
in the given time period
(which is defined by GroupProperties.PROP_ENTERPRISE_WAN_REP_BATCH_FREQUENCY_SECONDS
),
those events are gathered into a batch and sent to target.
IOBalancer
executions.
TruePredicate
query operations on maps.
SlowOperationDetector
.
OperationService
is considered to be slow.
Properties
with the provided instance name.
Properties
with the provided config file location.
ClientProxyFactory
s.CoreService
responsible for managing the DistributedObject proxies.ProxyServiceMBean
.ProxyService
ExpiryPolicy
.
key
.
key
.
Map.put(Object, Object)
that takes a primitive int key.
IMap.put(Object, Object)
.
IMap.put(Object, Object, long, java.util.concurrent.TimeUnit)
.
ExpiryPolicy
.
ExpiryPolicy
.
DirectBuffer
into this MutableDirectBuffer
at given indices.
IMap.loadAll(boolean)
IMap.putIfAbsent(Object, Object)
.
#put(K, V, long, java.util.concurrent.TimeUnit)
except that MapStore, if defined,
will not be called to store/persist the entry.
IMap
.QueryCache
.QueueMessageType.QUEUE_ADDLISTENER
QueueMessageType.QUEUE_ADDLISTENER
QueueMessageType.QUEUE_CLEAR
QueueMessageType.QUEUE_COMPAREANDREMOVEALL
QueueMessageType.QUEUE_COMPAREANDRETAINALL
IQueue
IQueue
.QueueMessageType.QUEUE_CONTAINSALL
QueueMessageType.QUEUE_CONTAINS
DataSerializerHook
for the queue operations and support structures.QueueMessageType.QUEUE_DRAINTOMAXSIZE
QueueMessageType.QUEUE_DRAINTO
QueueMessageType.QUEUE_ISEMPTY
QueueMessageType.QUEUE_ITERATOR
IQueue
QueueMessageType.QUEUE_OFFER
AddAllOperation
.QueueMessageType.QUEUE_PEEK
QueueMessageType.QUEUE_POLL
QueueMessageType.QUEUE_PUT
QueueMessageType.QUEUE_REMAININGCAPACITY
QueueMessageType.QUEUE_REMOVELISTENER
QueueMessageType.QUEUE_REMOVE
ClearRequest
.QueueEvictionProcessor
QueueMessageType.QUEUE_SIZE
QueueStore
.QueueMessageType.QUEUE_TAKE
QuickMath
contains methods to perform optimized mathematical operations.Quorum
provides access to the current status of a quorum.QuorumAwareService
to decide whether operation participates into a quorum or not.Quorum
changes.QuorumImpl
can be used to notify quorum service for a particular quorum result that originated externally.QuorumListener
LoadBalancer
that selects a random member to route to.MapStore
rejects to accept a new element.MapConfig.isReadBackupData()
is true
from
MapProxySupport.getInternal(com.hazelcast.nio.serialization.Data)
Returns corresponding value for key as Data
.
Connection
.Ringbuffer.readManyAsync(long, int, int, com.hazelcast.core.IFunction)
operation.ReadManyOperation
.Record
object.ReducerFactory
for this task.
Job
.ReducerFactory
for this task.
Reducer
instances per key.JobSupervisor
owner node that a reducer has finished the reducing step for the defined partitionId.Job
.Job
.Boolean.FALSE
if the entry does not exist and
Boolean.TRUE
otherwise.ConfigPatternMatcher
uses Java regular expressions for matching.CacheMXBean
or
CacheStatisticsMXBean
implementations if not registered yet.
MessageListener
to better integrate with the reliable topic.ITopic
.ITopic
implementation for reliable topics.key
.
key
.
Map.remove(Object)
that takes a primitive int key.
IMap.remove(Object)
.
IMap.remove(Object, Object)
.
RecordStore.remove(com.hazelcast.nio.serialization.Data)
except removeBackup doesn't touch mapstore since it does not return previous value.
CacheEntryListener
.
ExpiryPolicy
.
ExpiryPolicy
.
IMap.replace(Object, Object)
.
IMap.replace(Object, Object, Object)
.
RecordFactory.isEquals(java.lang.Object, java.lang.Object)
comparison
of current value and expected value is true
.
ExpiryPolicy
.
ExpiryPolicy
.
ReplicatedMap.clear()
is called.ReplicatedMap
ReplicatedMap
ReplicatedMap
implementation proxying the requests to the underlying
ReplicatedRecordStore
ReplicatedRecordStore
s that actually hold the dataKeyValueSource
(not implementing PartitionIdAware
)
which can happen for custom data sources like distributed filesystems that are up to the end user on how to
manage the distribution.Evictable
to 0
.
Evictable
to 0
.
Response
is a result of an Operation
being executed.OperationService
when it has calculated a response.ResponsePacketHandler
is responsible for handling
response packets.ExecutionException
s and logs
MemberLeftException
s to the log.
IOException
indicating that there was a IO failure, but it can be retried.Ringbuffer
.DataSerializerHook
for the Ringbuffer.Ringbuffer
.Ringbuffer
.AbstractWaitNotifyKey
to make it possible to wait for an item to be published in the ringbuffer.LoadBalancer
implementation that relies on using round robin
to a next member to send a request to.Runnable
to become a Callable
.InterruptedException
.Runtime
.Runtime
metrics.Evictable
entries to evict.EvictionStrategy
implementation.Probe
annotation, and
registering these fields/methods as metrics.
ScriptEngineManager
ICredentialsFactory
, IPermissionPolicy
etc, to creating LoginContext
es
for member and client authentications and checking permissions for client operations.SecurityInterceptor
EvictionPolicy
rule.
candidates
.
candidates
.
ISemaphore
.SemaphoreConfig
.
ISemaphore
cacheName
with specified key
from mentioned source with sourceUuid
.
HazelcastInstance
.ByteArraySerializer
see StreamSerializer
Serializer
s are supported
(StreamSerializer
and
ByteArraySerializer
).ServiceManager.registerService(java.lang.String, java.lang.Object)
ServiceManager.registerService(java.lang.String, java.lang.Object)
RingbufferService
.
WebFilter
to notify it of HttpSession
timeouts.IMap.set(Object, Object)
.
Evictable
.
Evictable
.
Evictable
in milliseconds.
Evictable
in milliseconds.
Set
using
Hazelcast serialization support.QueryCache
CacheLoader
factory.
CacheWriter
factory.
SocketInterceptor
implementation class
true
to enable coalescing, otherwise set false
.
ISet
.ClientNetworkConfig.addressList
,
all might be not available.
Evictable
in milliseconds.
Evictable
in milliseconds.
Credentials
QueryCache
EvictionConfig
instance for eviction configuration of the cache config.
EvictionConfig
instance for this QueryCache
EvictionOperator
to this MapServiceContext
.
Factory
for the ExpiryPolicy
.
SSLContextFactory
implementation class.
SSLContextFactory
implementation object.
GroupConfig
SocketInterceptor
implementation object
true
to enable value caching, otherwise set false
.
QueryCache
.
KeyValueSource
implementation is used in
KeyValueSource.fromSet(com.hazelcast.core.ISet)
to generate a default
implementation based on a Hazelcast ISet
.ListenerConfig
's
LoadBalancer
ManagedContext
EvictionConfig.setMaximumSizePolicy(MaxSizePolicy)
instead of this
ISet
IMap
QueryCache
.
NearCacheConfig
's with the provided map
ClientNetworkConfig
true
to enable initial population, otherwise set false
.
QueryCache
.
ProxyFactoryConfig
QueryCacheConfig
instances to this MapConfig
ClientSecurityConfig
object
SerializationConfig
SocketInterceptorConfig
.
SSLConfig
.
SSLConfig
.
SymmetricEncryptionConfig
.
TransactionOptions.TransactionType
.
Cache
configured with this Configuration
.
NearCacheRecord
.
CacheRecord
.
MapStoreConfig.writeCoalescing
is meaningful if you are using write-behind MapStore
.
Level.SEVERE
.
Level.SEVERE
.
Level.SEVERE
.
EntryView
and also it is writable.Map.size()
.
WriteBehindQueue
.
OperationRunner
instances of the OperationExecutor
to see if operations are slow.SlowOperationLog
.SlowOperationLog.Invocation
.Connection
.TargetClientRequest
which sends
a Callable
task to the given target address.WebFilter
SSLContext
RuntimeException
that is thrown when accessing an item in the Ringbuffer
using a sequence that is smaller
than the current head sequence.LoadBalancer
that always returns the same member.IMap
or MultiMap
to an
aggregation.Counter
that is made to be used by a single writing thread.RetryableHazelcastException
that indicates that an operation is about to
be send to a non existing machine.Invocation
evaluates a Operation Invocation for a particular target running on top of the
OperationServiceImpl
.RetryableHazelcastException
that indicates operation is send to a
machine that isn't member of the cluster.Connection
.ThreadMXBean
metric.TimedMemberState
instances.Data
.
ITopic
.TopicConfig
by cloning another TopicConfig.
ITopic
HazelcastException
thrown when a publisher wants to write to a topic, but there is not sufficient storage
to deal with the event.TopologyChangedStrategy
is set to TopologyChangedStrategy.CANCEL_RUNNING_OPERATION
.TopologyChangedException
, but it is possible
to submit the same job configuration again if
JobTracker.getTrackableJob(String)
returns null for the requested job id.ICompletableFuture
and is returned to the users codebase.IList
.BaseMap
.TransactionalMap
interface.TransactionalMapProxy
BaseMultiMap
.BaseQueue
.ISet
.TransactionalMap
.TransactionalMap
.HazelcastException
that is thrown when something goes wrong while dealing with transactions and transactional
data-structures.HazelcastException
thrown when an a transactional operation is executed without an active transaction.JobProcessInformation
is used to
transmit the currently processed number of records and the partition states to a requesting
client.Predicate
which always returns true.true
,
reducing the number of available permits by one.
true
,
reducing the number of available permits by the given amount.
true
,
reducing the number of available permits by the given amount.
ByteBuffer
for providing direct access, the ByteBuffer
can be
heap based or direct.
ByteBuffer
for providing direct access, the ByteBuffer
can be
heap based or direct.
DirectBuffer
.
DirectBuffer
.
Config
which is loaded using some url pointing to a Hazelcast XML file.Credentials
using
username and password as security attributes.Collection
view of the values contained in this map.
Collection
view of the values contained in this map.
IMap.values()
.
IMap.values(com.hazelcast.query.Predicate)
.
Collection
view of the values contained in this map.
Portable
to support per class version instead of a global serialization version.Data
value objects with version information.WanReplicationService
Level.WARNING
.
Level.WARNING
.
Level.WARNING
.
IMap
.ConfigPatternMatcher
supports a simplified wildcard matching.ByteBuffer
for providing direct access, the ByteBuffer
can be
heap based or direct.
ByteBuffer
for providing direct access.
DirectBuffer
DirectBuffer
for providing direct access.
TcpIpConnection
.RetryableHazelcastException
indicating that an operation is executed on
the wrong machine.ClientConfig
using XML.XmlClientConfigBuilder
to locate the client
xml configuration.ConfigBuilder
implementation.XmlConfigBuilder
that locates the XML configuration:
system property
working directory
classpath
default
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |