|
||||||||||
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.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
CacheEntryListener
.
DistributedObject
will be created or destroyed.
MemberGroupConfig
.
ProxyFactoryConfig
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 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).BasicOperationScheduler
clean of operations/packets etc, the scheduler
takes care of scheduling, but forwards the actual handling of the task to the BasicDispatcher
.InvocationBuilder
that is tied to the BasicOperationService
.BasicInvocation
evaluates a Operation Invocation for a particular partition running on top of the
BasicOperationService
.BasicInvocation
evaluates a Operation Invocation for a particular target running on top of the
BasicOperationService
.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
.StreamSerializer
.CacheClearOperation
.OperationFactory
implementation for Clear Operations.CacheClearOperationFactory
on the server side.CacheClearOperation
.ICache
ICache
(read-only).CompleteConfiguration
CacheContainsKeyOperation
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.AbstractCacheService.destroyCache(String, boolean, String)
.CacheDestroyOperation
on the server side.CacheService
and NodeEngine
.Cache.Entry
implementation for wrapping a "key,value" pair.CacheEntryListener
.MutableEntry
which is provided into
EntryProcessor.process(javax.cache.processor.MutableEntry, Object...)
.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.CacheGetAllOperation
.CacheGetAllOperationFactory
on the server side.CacheGetAndRemoveOperation
on the server side.CacheGetAndReplaceOperation
on the server side.CacheGetConfigOperation
on the server side.CacheGetOperation
on the server side.CacheKeyIteratorOperation
on the server side.CacheKeyIteratorOperation
.CacheService
.CacheListenerRegistrationOperation
on the server side.ICacheRecordStore
.CacheLoadAllOperation
.CacheLoadAllOperationFactory
on the server side.CacheManagementConfigOperation
on the server side.com.hazelcast.config.CacheMaxSizeConfig.CacheMaxSizePolicy
.CacheMXBean
.CacheRecordStore
instances but the cache config is not existing 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
.ICacheRecordStore.putIfAbsent(Data, Object, ExpiryPolicy, String, int)
.CachePutIfAbsentOperation
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
.OperationFactory
implementation for RemoveAll Operations.CacheRemoveOperation
on the server side.CacheReplaceOperation
on the server side.CacheRecordStore
.CacheSizeOperation
.CacheSizeOperationFactory
on the server side.CacheStatistics
implementation for ICache
.CacheStatisticsMXBean
Subject
has been granted specified permission or not.
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.
ClearOperation
ClientContext
.IExecutorService
.Cluster
.ClientClusterService
implementation.ICache
.ClientConnection
objects.ClientEndpoint
and Client
implementation.ClientEndpoint
s.ClientEndpointImpl
s.ClientEngine
ClientNearCache
.Client
implementation.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
.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
.ExecutorService
and provides all kinds
of additional methods related to distributed systems.com.hazelcast.map
package.IMap
TransactionalMap
IMap
InternalPartitionService
.IQueue
is the distributed version of the BlockingQueue
.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.Comparable
implementing values.Comparable
.Comparable
implementing values.Comparable
.CompareAndRemoveOperation
==
the expected value.
==
the expected value.
HazelcastInstance
.ICredentialsFactory
.
IPermissionPolicy
.
Config
to a Hazelcast XML string.ConnectionManager
to listen to connections
being added or removed.Connection
objects.ConnectionManager
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
.
LoginContext
.
Data
based ReplicatedRecordStore
implementationObjectNamespace
implementation.InMemoryFormat.NATIVE
PartitioningStrategy
that checks if the key implements PartitionAware
.IMap.delete(Object)
.
ICredentialsFactory
.
IPermissionPolicy
.
SecurityContext
and all security elements.
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.DrainOperation
Collections.emptySet()
or Collections.emptyList()
)} depending on the
MultiMapConfig.valueCollectionType
CacheEvictionConfig.CacheMaxSizePolicy.ENTRY_COUNT
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.
EventService
EvictionStrategy
to eventually evict, by the policy, selected
candidates from the internal data structures.
EvictionChecker
.
EvictionChecker
.
Evictable
entries to evict.SampleableEvictableStore
.
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 is which includes functionality for loading itself from a
XML configuration file.IndexAwarePredicate
for filtering
ValueOut
to be send 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
.ClientExceptionConverter
that converts a Throwable to a GenericError
.ExpiryPolicy
.
null
if this cache contains no mapping for the 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 has to return
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
.
BackupOperation
responsible for making the backup.
CacheService
.
SocketInterceptor
implementation class
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.
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.
CacheEvictionConfig
instance for eviction configuration of the cache config.
EvictionPolicyEvaluator
implementation specified with evictionPolicy
.
EvictionStrategy
implementation specified with evictionStrategyType
.
SSLContextFactory
implementation class
SSLContextFactory
implementation object
EventFilter
attached to this registration.
GroupConfig
HazelcastInstance
from Session
.
HazelcastInstance
from SessionFactory
.
HazelcastInstance
from SessionFactoryImplementor
.
DistributedObject.getName()
instead
SocketInterceptor
implementation object
Member.getSocketAddress()
instead
JobProcessInformation
to find out the state and
statistics of a running task or null if the underlying job id is not available because job is already
finished or not yet submitted.JobTracker
JoinConfig
.
DistributedObject.getName()
instead.
ListenerConfig
's
HazelcastInstance.getLock(String)
instead.
ManagedContext
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.
JobTracker
NearCacheConfig
configured for the map with mapName
NearCacheConfig
of the cache config instance.
ClientNetworkConfig
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.
Properties
object
ProxyFactoryConfig
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
SocketInterceptorConfig
.
SSLConfig
.
SSLConfig
.
SymmetricEncryptionConfig
.
backupCount + asyncBackupCount
) of the cache config.
TrackableJob
if the job or null if the job id is not available
or is already finished.
TransactionOptions.TransactionType
.
ConnectionType
of this Connection.
CacheRecord
.
WanReplicationPublisher
by the given name, if
already existing returns the previous instance.
Arrays.hashCode(Object[])
.
HazelcastInstance
's, a node in a cluster.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.CacheManager
for server implementation.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.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 accepted by 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
.
Index
Level.INFO
.
Config.setProperty(String, String)
SSLConfig
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
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.InternalPartitionService
implementation.destroyed
session, removing them
from the clustered map.EntryProcessor
against the Cache.Entry
specified by
the provided key.
Subject
's
permissions to perform a security sensitive Hazelcast operation.KeyValueSource.getAllKeys()
must return all available keys
to execute a preselection of interesting partitions / nodes based on returns keys.
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.Level.FINEST
is enabled.
IndexAwarePredicate
for checking if indexed
true
if the given collection is not null and not empty, otherwise returns false
.
Portable
object,
false otherwise.
com.hazelcast.config.CacheMaxSizeConfig.CacheMaxSizePolicy
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 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.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 complexer
algorithms with a need of initialization and finalization.Job
.LifecycleEvent
's
on HazelcastInstance.LifecycleService
implementation for the client.LinkedList
.LinkedList
serializerIList
.IList
(read-only).EventListener
.KeyValueSource
implementation is used in
KeyValueSource.fromList(com.hazelcast.core.IList)
to generate a default
implementation based on a Hazelcast IList
.IList
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.
EvictionPolicy.LRU
policy.ManagedConnection
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
.MapConfig
IMap
(read-only).PostJoinAwareService.getPostJoinOperation()
Otherwise undesired situations, like deadlocks, may appear.
EntryEventType.EVICT_ALL
and EntryEventType.CLEAR_ALL
.IMap.evictAll()
.
KeyValueSource
implementation is used in
KeyValueSource.fromMap(com.hazelcast.core.IMap)
to generate a default
implementation based on a Hazelcast IMap
.IMap
Job
.Job
.IMap
interface.MapServiceContext
.MapServiceContext
.MapStoreContext
objects
according to MapStoreConfig
.IMap
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
.a
by b
.
a
by b
.
MultiMap
.KeyValueSource
implementation is used in
KeyValueSource.fromMultiMap(com.hazelcast.core.MultiMap)
to generate a default
implementation based on a Hazelcast MultiMap
.MultiMap
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.
Reducer
instance specific to the supplied key.
Node
CachedDataRecord
.
WaitSupport
operation to wake-up and continue executing.
InMemoryFormat.OBJECT
based
ReplicatedRecordStore
implementationOfferOperation
EntryListener
is not
overridden.
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)
.
Runnable
.Operation
instances.OperationService
TimeoutException
.OutOfMemoryError
.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.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.MigrationAwareService
when partitions changes happen.Partition
s and attach/detach MigrationListener
s to listen to partition
migration events.PartitionService
PeekOperation
PollOperation
Predicate
instances.Predicate
s, used
to filter and optionally transform data (using the given
Supplier
).ClientNetworkConfig.redoOperation
is set to true.
ClientNetworkConfig.redoOperation
is set to true.
Properties
with the provided instance name.
Properties
with the provided config file location.
ClientProxyFactory
s.CoreService
responsible for managing the DistributedObject proxies.ProxyService
ExpiryPolicy
.
IMap.put(Object, Object)
.
IMap.put(Object, Object, long, java.util.concurrent.TimeUnit)
.
ExpiryPolicy
.
ExpiryPolicy
.
IMap.loadAll(boolean)
IMap.putIfAbsent(Object, Object)
.
#put(K, V, long, java.util.concurrent.TimeUnit)
but MapStore, if defined,
will not be called to store/persist the entry.
IQueue
IQueue
.DataSerializerHook
for the queue operations and support structures.IQueue
AddAllOperation
.ClearRequest
.QueueEvictionProcessor
QueueStore
.QuickMath
contains methods to perform optimized mathematical operations.LoadBalancer
that selects a random member to route to.BoundedArrayWriteBehindQueue
rejects to accept an offer.MapConfig.isReadBackupData()
is true
from
MapProxySupport.getInternal(com.hazelcast.nio.serialization.Data)
Returns corresponding value for key as Data
.
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.CacheMXBean
or
CacheStatisticsMXBean
implementations if not registered yet.
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
.
Response
is a result of an Operation
being executed.OperationService
when it has calculated a response.ExecutionException
s and logs
MemberLeftException
s to the log.
IOException
indicating that there was a IO failure, but it can be retried.LoadBalancer
implementation that relies on using round robin
to a next member to send a request to.Runnable
to become a Callable
.InterruptedException
.Runtime
.Evictable
entries to evict.EvictionStrategy
implementation.ScriptEngineManager
ICredentialsFactory
, IPermissionPolicy
etc, to creating LoginContext
es
for member and client authentications and checking permissions for client operations.SecurityInterceptor
EvictionPolicy
rule.
ISemaphore
.SemaphoreConfig
.
ISemaphore
ClientEndpoint
.ConnectionManagerMBean
.EventServiceMBean
.ManagedExecutorServiceMBean
.OperationServiceMBean
.PartitionServiceMBean
.ProxyServiceMBean
.HazelcastInstance
.ByteArraySerializer
see StreamSerializer
Serializer
s are supported
(StreamSerializer
and
ByteArraySerializer
).ServiceManager.registerService(java.lang.String, java.lang.Object)
WebFilter
to notify it of HttpSession
timeouts.IMap.set(Object, Object)
.
Evictable
.
Evictable
in milliseconds.
Set
using
Hazelcast serialization support.CacheLoader
factory.
CacheWriter
factory.
SocketInterceptor
implementation class
ISet
.ClientNetworkConfig.addressList
,
all might be not available.
Evictable
in milliseconds.
Credentials
CacheEvictionConfig
instance for eviction configuration of the cache config.
Factory
for the ExpiryPolicy
.
SSLContextFactory
implementation class
SSLContextFactory
implementation object
GroupConfig
SocketInterceptor
implementation object
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
ISet
NearCacheConfig
of the cache config instance.
NearCacheConfig
's with the provided map
ClientNetworkConfig
ProxyFactoryConfig
ClientSecurityConfig
object
SerializationConfig
SocketInterceptorConfig
.
SSLConfig
.
SSLConfig
.
SymmetricEncryptionConfig
.
TransactionOptions.TransactionType
.
Cache
configured with this Configuration
.
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()
.
Connection
.WebFilter
SSLContext
LoadBalancer
that always returns the same member.IMap
or MultiMap
to an
aggregation.RetryableHazelcastException
that indicates that an operation is about to
be send to a non existing machine.RetryableHazelcastException
that indicates operation is send to a
machine that isn't member of the cluster.Connection
.TimedMemberState
instances.ITopic
.TopicConfig
by cloning another TopicConfig.
ITopic
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.
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
.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 |