Package | Description |
---|---|
org.infinispan.affinity |
This package contains the
KeyAffinityService interfaces which allow user code to determine mapping of keys onto nodes |
org.infinispan.affinity.impl | |
org.infinispan.commands |
Commands that operate on the cache, either locally or remotely.
|
org.infinispan.commands.irac | |
org.infinispan.commands.remote |
Meta-commands that wrap other commands for remote execution.
|
org.infinispan.commands.topology | |
org.infinispan.commands.tx |
Commands that represent transactional lifecycle transitions.
|
org.infinispan.commands.write |
Commands that alter the state of the cache.
|
org.infinispan.conflict |
This package contains the APIs that enable users to search for, and amend, data inconsistencies within their cache.
|
org.infinispan.conflict.impl |
This package contains implementations of the conflict resolution API.
|
org.infinispan.container.entries |
Entries which are stored in data containers.
|
org.infinispan.context |
Contexts contain information of a specific invocation on the cache, such as its origins, scope
(transactional or non-transactional), as well as invocation-specific flags.
|
org.infinispan.context.impl |
This package contains different context implementations, selected dynamically based on the type of invocation.
|
org.infinispan.distribution |
Classes relating to the distributed cache mode.
|
org.infinispan.distribution.ch |
Consistent Hash interfaces
|
org.infinispan.distribution.ch.impl | |
org.infinispan.distribution.impl | |
org.infinispan.distribution.topologyaware | |
org.infinispan.interceptors.distribution |
Interceptors dealing with command replication in distributed/replicated mode.
|
org.infinispan.interceptors.impl |
Basic interceptors
|
org.infinispan.interceptors.locking |
Interceptors dealing with locking.
|
org.infinispan.manager |
Cache manager API.
|
org.infinispan.manager.impl | |
org.infinispan.notifications.cachelistener.cluster | |
org.infinispan.notifications.cachelistener.cluster.impl | |
org.infinispan.notifications.cachelistener.event |
Cache -specific listener events |
org.infinispan.notifications.cachelistener.event.impl | |
org.infinispan.notifications.cachemanagerlistener |
CacheManager -specific notifications and eventing. |
org.infinispan.notifications.cachemanagerlistener.event |
EmbeddedCacheManager -specific listener events |
org.infinispan.notifications.cachemanagerlistener.event.impl | |
org.infinispan.partitionhandling.impl | |
org.infinispan.remoting.inboundhandler |
Handling of inbound commands on remote nodes.
|
org.infinispan.remoting.responses |
Abstractions of the different response types allowed during RPC.
|
org.infinispan.remoting.rpc |
Remote Procedure Call (RPC) interfaces and components used to invoke remote methods on cache instances.
|
org.infinispan.remoting.transport |
Transports handle the low-level networking, used by the remoting components.
|
org.infinispan.remoting.transport.impl | |
org.infinispan.remoting.transport.jgroups |
A transport implementation based on JGroups.
|
org.infinispan.scattered |
SCATTERED CACHE DESIGN
|
org.infinispan.scattered.impl | |
org.infinispan.security.actions | |
org.infinispan.statetransfer |
Transfer of state to new caches in a cluster.
|
org.infinispan.stream.impl | |
org.infinispan.topology | |
org.infinispan.transaction.impl | |
org.infinispan.transaction.xa |
XA transaction support.
|
org.infinispan.transaction.xa.recovery | |
org.infinispan.util.concurrent |
Thread-safe containers and other concurrency-related utilities, designed to supplement JDK concurrency utilities
and containers.
|
org.infinispan.util.logging |
Infinispan's logging abstractions that delegate to either JDK or Log4J logging engines.
|
org.infinispan.util.logging.events | |
org.infinispan.util.logging.events.impl | |
org.infinispan.xsite | |
org.infinispan.xsite.irac | |
org.infinispan.xsite.statetransfer | |
org.infinispan.xsite.status |
Modifier and Type | Method and Description |
---|---|
K |
KeyAffinityService.getKeyForAddress(Address address)
Returns a key that will be distributed on the cluster node identified by address.
|
Modifier and Type | Method and Description |
---|---|
static <K,V> KeyAffinityService<K> |
KeyAffinityServiceFactory.newKeyAffinityService(Cache<K,V> cache,
Collection<Address> filter,
KeyGenerator<K> keyGenerator,
Executor ex,
int keyBufferSize)
|
static <K,V> KeyAffinityService<K> |
KeyAffinityServiceFactory.newKeyAffinityService(Cache<K,V> cache,
Collection<Address> filter,
KeyGenerator<K> keyGenerator,
Executor ex,
int keyBufferSize,
boolean start)
Creates a service that would only generate keys for addresses specified in filter.
|
Modifier and Type | Method and Description |
---|---|
Map<Address,BlockingQueue<K>> |
KeyAffinityServiceImpl.getAddress2KeysMapping() |
Modifier and Type | Method and Description |
---|---|
K |
KeyAffinityServiceImpl.getKeyForAddress(Address address) |
Constructor and Description |
---|
KeyAffinityServiceImpl(Executor executor,
Cache<? extends K,?> cache,
KeyGenerator<? extends K> keyGenerator,
int bufferSize,
Collection<Address> filter,
boolean start) |
Modifier and Type | Method and Description |
---|---|
Address |
CommandInvocationId.getAddress() |
Modifier and Type | Method and Description |
---|---|
InvalidateCommand |
CommandsFactory.buildInvalidateFromL1Command(Address origin,
long flagsBitSet,
Collection<Object> keys) |
InvalidateCommand |
CommandsFactoryImpl.buildInvalidateFromL1Command(Address origin,
long flagsBitSet,
Collection<Object> keys) |
RevokeBiasCommand |
CommandsFactory.buildRevokeBiasCommand(Address ackTarget,
long id,
int topologyId,
Collection<Object> keys) |
RevokeBiasCommand |
CommandsFactoryImpl.buildRevokeBiasCommand(Address ackTarget,
long id,
int topologyId,
Collection<Object> keys) |
static CommandInvocationId |
CommandInvocationId.generateId(Address address) |
default void |
ReplicableCommand.setOrigin(Address origin)
Sets the sender's
Address . |
Modifier and Type | Method and Description |
---|---|
Address |
IracCleanupKeyCommand.getOrigin() |
Address |
IracMetadataRequestCommand.getOrigin() |
Address |
IracStateResponseCommand.getOrigin() |
Modifier and Type | Method and Description |
---|---|
void |
IracCleanupKeyCommand.setOrigin(Address origin) |
void |
IracMetadataRequestCommand.setOrigin(Address origin) |
void |
IracStateResponseCommand.setOrigin(Address origin) |
Modifier and Type | Field and Description |
---|---|
protected Address |
BaseRpcCommand.origin |
Modifier and Type | Method and Description |
---|---|
Address |
BaseRpcCommand.getOrigin() |
Address |
CacheRpcCommand.getOrigin()
Get the origin of the command
|
Address |
CheckTransactionRpcCommand.getOrigin() |
Modifier and Type | Method and Description |
---|---|
void |
BaseRpcCommand.setOrigin(Address origin) |
void |
CacheRpcCommand.setOrigin(Address origin)
Set the origin of the command
|
void |
CheckTransactionRpcCommand.setOrigin(Address origin) |
Constructor and Description |
---|
RevokeBiasCommand(ByteString cacheName,
Address ackTarget,
long id,
int topologyId,
Collection<Object> keys) |
Modifier and Type | Field and Description |
---|---|
protected Address |
AbstractCacheControlCommand.origin |
Modifier and Type | Method and Description |
---|---|
void |
AbstractCacheControlCommand.setOrigin(Address origin) |
Constructor and Description |
---|
CacheJoinCommand(String cacheName,
Address origin,
CacheJoinInfo joinInfo,
int viewId) |
CacheLeaveCommand(String cacheName,
Address origin,
int viewId) |
RebalancePhaseConfirmCommand(String cacheName,
Address origin,
Throwable throwable,
int topologyId,
int viewId) |
RebalanceStartCommand(String cacheName,
Address origin,
CacheTopology cacheTopology,
int viewId) |
TopologyUpdateCommand(String cacheName,
Address origin,
CacheTopology cacheTopology,
AvailabilityMode availabilityMode,
int viewId) |
TopologyUpdateStableCommand(String cacheName,
Address origin,
CacheTopology cacheTopology,
int viewId) |
Modifier and Type | Method and Description |
---|---|
Address |
AbstractTransactionBoundaryCommand.getOrigin() |
Modifier and Type | Method and Description |
---|---|
void |
AbstractTransactionBoundaryCommand.setOrigin(Address origin) |
Modifier and Type | Method and Description |
---|---|
boolean |
InvalidateL1Command.isCausedByALocalWrite(Address address)
Returns true if the write that caused the invalidation was performed on this node.
|
Constructor and Description |
---|
InvalidateL1Command(Address writeOrigin,
long flagsBitSet,
Collection<Object> keys,
CommandInvocationId commandInvocationId) |
Modifier and Type | Method and Description |
---|---|
Map<Address,InternalCacheValue<V>> |
ConflictManager.getAllVersions(K key)
Get all CacheEntry's that exists for a given key.
|
Stream<Map<Address,CacheEntry<K,V>>> |
ConflictManager.getConflicts()
Returns a stream of conflicts detected in the cluster.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<List<Map<Address,CacheEntry<K,V>>>> |
StateReceiver.getAllReplicasForSegment(int segmentId,
LocalizedCacheTopology topology,
long timeout)
Return all replicas of a cache entry for a given segment.
|
CompletableFuture<List<Map<Address,CacheEntry<K,V>>>> |
StateReceiverImpl.getAllReplicasForSegment(int segmentId,
LocalizedCacheTopology topology,
long timeout) |
Map<Address,InternalCacheValue<V>> |
DefaultConflictManager.getAllVersions(K key) |
Stream<Map<Address,CacheEntry<K,V>>> |
DefaultConflictManager.getConflicts() |
Modifier and Type | Method and Description |
---|---|
void |
StateReceiver.receiveState(Address sender,
int topologyId,
Collection<StateChunk> stateChunks) |
void |
StateReceiverImpl.receiveState(Address sender,
int topologyId,
Collection<StateChunk> stateChunks) |
Modifier and Type | Method and Description |
---|---|
CompletionStage<Void> |
DefaultConflictManager.resolveConflicts(CacheTopology topology,
Set<Address> preferredNodes) |
CompletionStage<Void> |
InternalConflictManager.resolveConflicts(CacheTopology cacheTopology,
Set<Address> preferredNodes) |
Modifier and Type | Method and Description |
---|---|
Address |
RemoteMetadata.getAddress() |
Constructor and Description |
---|
RemoteMetadata(Address address,
EntryVersion version) |
Modifier and Type | Method and Description |
---|---|
Address |
InvocationContext.getOrigin() |
Modifier and Type | Method and Description |
---|---|
InvocationContext |
InvocationContextFactory.createRemoteInvocationContext(Address origin)
Returns an
NonTxInvocationContext whose AbstractInvocationContext.isOriginLocal() flag will be true. |
InvocationContext |
InvocationContextFactory.createRemoteInvocationContextForCommand(VisitableCommand cacheCommand,
Address origin)
As
InvocationContextFactory.createRemoteInvocationContext(org.infinispan.remoting.transport.Address) ,
but returning the flags to the context from the Command if any Flag was set. |
RemoteTxInvocationContext |
InvocationContextFactory.createRemoteTxInvocationContext(RemoteTransaction tx,
Address origin)
Returns an
RemoteTxInvocationContext . |
Modifier and Type | Method and Description |
---|---|
Address |
AbstractInvocationContext.getOrigin() |
Address |
ImmutableContext.getOrigin() |
Address |
SingleKeyNonTxInvocationContext.getOrigin() |
Modifier and Type | Method and Description |
---|---|
Collection<Address> |
LocalTxInvocationContext.getRemoteLocksAcquired() |
Modifier and Type | Method and Description |
---|---|
NonTxInvocationContext |
NonTransactionalInvocationContextFactory.createRemoteInvocationContext(Address origin) |
NonTxInvocationContext |
TransactionalInvocationContextFactory.createRemoteInvocationContext(Address origin) |
InvocationContext |
AbstractInvocationContextFactory.createRemoteInvocationContextForCommand(VisitableCommand cacheCommand,
Address origin) |
RemoteTxInvocationContext |
NonTransactionalInvocationContextFactory.createRemoteTxInvocationContext(RemoteTransaction tx,
Address origin) |
RemoteTxInvocationContext |
TransactionalInvocationContextFactory.createRemoteTxInvocationContext(RemoteTransaction tx,
Address origin) |
protected NonTxInvocationContext |
TransactionalInvocationContextFactory.newNonTxInvocationContext(Address origin) |
Modifier and Type | Method and Description |
---|---|
void |
LocalTxInvocationContext.remoteLocksAcquired(Collection<Address> nodes) |
Constructor and Description |
---|
AbstractInvocationContext(Address origin) |
AbstractTxInvocationContext(T cacheTransaction,
Address origin) |
ClearInvocationContext(Address origin) |
NonTxInvocationContext(Address origin) |
NonTxInvocationContext(int numEntries,
Address origin) |
SingleKeyNonTxInvocationContext(Address origin) |
Modifier and Type | Method and Description |
---|---|
Address |
LocalizedCacheTopology.getLocalAddress() |
Address |
DistributionInfo.primary() |
Modifier and Type | Method and Description |
---|---|
Set<Address> |
LocalizedCacheTopology.getMembersSet() |
Collection<Address> |
LocalizedCacheTopology.getWriteOwners(Collection<?> keys) |
Collection<Address> |
LocalizedCacheTopology.getWriteOwners(Object key) |
List<Address> |
DistributionInfo.readOwners() |
Collection<Address> |
DistributionInfo.writeBackups() |
List<Address> |
DistributionInfo.writeOwners() |
Modifier and Type | Method and Description |
---|---|
void |
L1Manager.addRequestor(Object key,
Address requestor)
Records a request that will be cached in another nodes L1
|
CompletableFuture<?> |
L1Manager.flushCache(Collection<Object> key,
Address origin,
boolean assumeOriginKeptEntryInL1) |
static LocalizedCacheTopology |
LocalizedCacheTopology.makeSegmentedSingletonTopology(KeyPartitioner keyPartitioner,
int numSegments,
Address localAddress)
Creates a new local topology that has a single address but multiple segments.
|
static LocalizedCacheTopology |
LocalizedCacheTopology.makeSingletonTopology(CacheMode cacheMode,
Address localAddress) |
Constructor and Description |
---|
DistributionInfo(int segmentId,
Address primary,
List<Address> readOwners,
List<Address> writeOwners,
Collection<Address> writeBackups,
Address localAddress) |
LocalizedCacheTopology(CacheMode cacheMode,
CacheTopology cacheTopology,
KeyPartitioner keyPartitioner,
Address localAddress,
boolean connected) |
Constructor and Description |
---|
DistributionInfo(int segmentId,
Address primary,
List<Address> readOwners,
List<Address> writeOwners,
Collection<Address> writeBackups,
Address localAddress) |
DistributionInfo(int segmentId,
Address primary,
List<Address> readOwners,
List<Address> writeOwners,
Collection<Address> writeBackups,
Address localAddress) |
DistributionInfo(int segmentId,
Address primary,
List<Address> readOwners,
List<Address> writeOwners,
Collection<Address> writeBackups,
Address localAddress) |
Modifier and Type | Method and Description |
---|---|
Address |
ConsistentHash.locatePrimaryOwnerForSegment(int segmentId) |
Modifier and Type | Method and Description |
---|---|
default Map<Address,Float> |
ConsistentHash.getCapacityFactors()
The capacity factor of each member.
|
List<Address> |
ConsistentHash.getMembers()
Should return the addresses of the nodes used to create this consistent hash.
|
List<Address> |
ConsistentHash.locateOwnersForSegment(int segmentId) |
Modifier and Type | Method and Description |
---|---|
Set<Integer> |
ConsistentHash.getPrimarySegmentsForOwner(Address owner)
Returns the segments that this cache member is the primary owner for.
|
Set<Integer> |
ConsistentHash.getSegmentsForOwner(Address owner)
Returns the segments owned by a cache member.
|
default boolean |
ConsistentHash.isSegmentLocalToNode(Address nodeAddress,
int segmentId)
Check if a segment is local to a given member.
|
Modifier and Type | Method and Description |
---|---|
default CH |
ConsistentHashFactory.create(Hash hashFunction,
int numOwners,
int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors)
Deprecated.
since 11.0. hashFunction is ignored, use
ConsistentHashFactory.create(int, int, List, Map) instead. |
default CH |
ConsistentHashFactory.create(Hash hashFunction,
int numOwners,
int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors)
Deprecated.
since 11.0. hashFunction is ignored, use
ConsistentHashFactory.create(int, int, List, Map) instead. |
CH |
ConsistentHashFactory.create(int numOwners,
int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors)
Deprecated.
Create a new consistent hash instance.
|
CH |
ConsistentHashFactory.create(int numOwners,
int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors)
Deprecated.
Create a new consistent hash instance.
|
default ConsistentHash |
ConsistentHash.remapAddresses(UnaryOperator<Address> remapper)
Returns a new ConsistentHash with the addresses remapped according to the provided
UnaryOperator . |
CH |
ConsistentHashFactory.updateMembers(CH baseCH,
List<Address> newMembers,
Map<Address,Float> capacityFactors)
Deprecated.
Updates an existing consistent hash instance to remove owners that are not in the
newMembers list. |
CH |
ConsistentHashFactory.updateMembers(CH baseCH,
List<Address> newMembers,
Map<Address,Float> capacityFactors)
Deprecated.
Updates an existing consistent hash instance to remove owners that are not in the
newMembers list. |
Modifier and Type | Field and Description |
---|---|
protected List<Address> |
AbstractConsistentHash.members
The membership of the cache topology that uses this CH.
|
Modifier and Type | Method and Description |
---|---|
protected Address |
DefaultConsistentHashFactory.findNewBackupOwner(DefaultConsistentHashFactory.Builder builder,
Collection<Address> excludes,
Address owner) |
protected Address |
AbstractConsistentHashFactory.findNewPrimaryOwner(org.infinispan.distribution.ch.impl.AbstractConsistentHashFactory.Builder builder,
Collection<Address> candidates,
Address primaryOwner) |
protected Address |
AbstractConsistentHashFactory.findWorstPrimaryOwner(org.infinispan.distribution.ch.impl.AbstractConsistentHashFactory.Builder builder,
List<Address> nodes) |
Address |
DefaultConsistentHashFactory.Builder.getPrimaryOwner(int segment) |
Address |
ScatteredConsistentHashFactory.Builder.getPrimaryOwner(int segment) |
Address |
DefaultConsistentHash.locatePrimaryOwnerForSegment(int segmentId) |
Address |
ReplicatedConsistentHash.locatePrimaryOwnerForSegment(int segmentId) |
Address |
ScatteredConsistentHash.locatePrimaryOwnerForSegment(int segmentId) |
Modifier and Type | Method and Description |
---|---|
List<Address> |
DefaultConsistentHashFactory.Builder.getBackupOwners(int segment) |
Map<Address,Float> |
AbstractConsistentHash.getCapacityFactors() |
List<Address> |
AbstractConsistentHash.getMembers() |
List<Address> |
ReplicatedConsistentHash.getMembers() |
List<Address> |
DefaultConsistentHashFactory.Builder.getOwners(int segment) |
List<Address> |
DefaultConsistentHash.locateOwnersForSegment(int segmentId) |
List<Address> |
ReplicatedConsistentHash.locateOwnersForSegment(int segmentId) |
List<Address> |
ScatteredConsistentHash.locateOwnersForSegment(int segmentId) |
protected static List<Address> |
AbstractConsistentHash.parseMembers(ScopedPersistentState state) |
protected Map<Address,Float> |
AbstractConsistentHash.remapCapacityFactors(UnaryOperator<Address> remapper) |
protected List<Address> |
AbstractConsistentHash.remapMembers(UnaryOperator<Address> remapper) |
protected Map<Address,Float> |
AbstractConsistentHash.unionCapacityFactors(AbstractConsistentHash ch2) |
Modifier and Type | Method and Description |
---|---|
boolean |
DefaultConsistentHashFactory.Builder.addOwner(int segment,
Address owner) |
void |
DefaultConsistentHashFactory.Builder.addPrimaryOwner(int segment,
Address newPrimaryOwner) |
void |
ScatteredConsistentHashFactory.Builder.addPrimaryOwner(int segment,
Address newPrimaryOwner) |
void |
OwnershipStatistics.decOwned(Address a) |
void |
OwnershipStatistics.decPrimaryOwned(Address a) |
protected Address |
DefaultConsistentHashFactory.findNewBackupOwner(DefaultConsistentHashFactory.Builder builder,
Collection<Address> excludes,
Address owner) |
protected Address |
AbstractConsistentHashFactory.findNewPrimaryOwner(org.infinispan.distribution.ch.impl.AbstractConsistentHashFactory.Builder builder,
Collection<Address> candidates,
Address primaryOwner) |
int |
DefaultConsistentHashFactory.Builder.getOwned(Address node) |
int |
OwnershipStatistics.getOwned(Address a) |
int |
ScatteredConsistentHashFactory.Builder.getOwned(Address node) |
int |
DefaultConsistentHashFactory.Builder.getPrimaryOwned(Address node) |
int |
OwnershipStatistics.getPrimaryOwned(Address a) |
int |
ScatteredConsistentHashFactory.Builder.getPrimaryOwned(Address node) |
Set<Integer> |
DefaultConsistentHash.getPrimarySegmentsForOwner(Address owner) |
Set<Integer> |
ReplicatedConsistentHash.getPrimarySegmentsForOwner(Address owner) |
Set<Integer> |
ScatteredConsistentHash.getPrimarySegmentsForOwner(Address owner) |
Set<Integer> |
DefaultConsistentHash.getSegmentsForOwner(Address owner) |
Set<Integer> |
ReplicatedConsistentHash.getSegmentsForOwner(Address owner) |
Set<Integer> |
ScatteredConsistentHash.getSegmentsForOwner(Address owner) |
void |
OwnershipStatistics.incOwned(Address a) |
void |
OwnershipStatistics.incPrimaryOwned(Address a) |
boolean |
DefaultConsistentHash.isSegmentLocalToNode(Address nodeAddress,
int segmentId) |
boolean |
ReplicatedConsistentHash.isSegmentLocalToNode(Address nodeAddress,
int segmentId) |
boolean |
ScatteredConsistentHash.isSegmentLocalToNode(Address nodeAddress,
int segmentId) |
boolean |
DefaultConsistentHashFactory.Builder.removeOwner(int segment,
Address owner) |
void |
DefaultConsistentHashFactory.Builder.replacePrimaryOwnerWithBackup(int segment,
Address newPrimaryOwner) |
Modifier and Type | Method and Description |
---|---|
boolean |
DefaultConsistentHashFactory.Builder.addOwners(int segment,
Collection<Address> newOwners) |
protected void |
AbstractConsistentHashFactory.checkCapacityFactors(List<Address> members,
Map<Address,Float> capacityFactors) |
protected void |
AbstractConsistentHashFactory.checkCapacityFactors(List<Address> members,
Map<Address,Float> capacityFactors) |
int |
DefaultConsistentHashFactory.Builder.computeActualNumOwners(int numOwners,
List<Address> members,
Map<Address,Float> capacityFactors) |
int |
DefaultConsistentHashFactory.Builder.computeActualNumOwners(int numOwners,
List<Address> members,
Map<Address,Float> capacityFactors) |
DefaultConsistentHash |
DefaultConsistentHashFactory.create(int numOwners,
int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors) |
DefaultConsistentHash |
DefaultConsistentHashFactory.create(int numOwners,
int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors) |
ReplicatedConsistentHash |
ReplicatedConsistentHashFactory.create(int numOwners,
int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors) |
ReplicatedConsistentHash |
ReplicatedConsistentHashFactory.create(int numOwners,
int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors) |
ScatteredConsistentHash |
ScatteredConsistentHashFactory.create(int numOwners,
int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors) |
ScatteredConsistentHash |
ScatteredConsistentHashFactory.create(int numOwners,
int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors) |
DefaultConsistentHash |
SyncConsistentHashFactory.create(int numOwners,
int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors) |
DefaultConsistentHash |
SyncConsistentHashFactory.create(int numOwners,
int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors) |
ReplicatedConsistentHash |
SyncReplicatedConsistentHashFactory.create(int numOwners,
int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors) |
ReplicatedConsistentHash |
SyncReplicatedConsistentHashFactory.create(int numOwners,
int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors) |
protected TopologyAwareSyncConsistentHashFactory.Builder |
TopologyAwareSyncConsistentHashFactory.createBuilder(int numOwners,
int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors) |
protected TopologyAwareSyncConsistentHashFactory.Builder |
TopologyAwareSyncConsistentHashFactory.createBuilder(int numOwners,
int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors) |
protected Address |
DefaultConsistentHashFactory.findNewBackupOwner(DefaultConsistentHashFactory.Builder builder,
Collection<Address> excludes,
Address owner) |
protected Address |
AbstractConsistentHashFactory.findNewPrimaryOwner(org.infinispan.distribution.ch.impl.AbstractConsistentHashFactory.Builder builder,
Collection<Address> candidates,
Address primaryOwner) |
protected Address |
AbstractConsistentHashFactory.findWorstPrimaryOwner(org.infinispan.distribution.ch.impl.AbstractConsistentHashFactory.Builder builder,
List<Address> nodes) |
protected static void |
AbstractConsistentHash.mergeLists(List<Address> dest,
List<Address> src)
Adds all elements from
src list that do not already exist in dest list to the latter. |
protected static void |
AbstractConsistentHash.mergeLists(List<Address> dest,
List<Address> src)
Adds all elements from
src list that do not already exist in dest list to the latter. |
ConsistentHash |
DefaultConsistentHash.remapAddresses(UnaryOperator<Address> remapper) |
ConsistentHash |
ReplicatedConsistentHash.remapAddresses(UnaryOperator<Address> remapper) |
ConsistentHash |
ScatteredConsistentHash.remapAddresses(UnaryOperator<Address> remapper) |
protected Map<Address,Float> |
AbstractConsistentHash.remapCapacityFactors(UnaryOperator<Address> remapper) |
protected List<Address> |
AbstractConsistentHash.remapMembers(UnaryOperator<Address> remapper) |
DefaultConsistentHash |
DefaultConsistentHashFactory.updateMembers(DefaultConsistentHash baseCH,
List<Address> actualMembers,
Map<Address,Float> actualCapacityFactors)
Leavers are removed and segments without owners are assigned new owners.
|
DefaultConsistentHash |
DefaultConsistentHashFactory.updateMembers(DefaultConsistentHash baseCH,
List<Address> actualMembers,
Map<Address,Float> actualCapacityFactors)
Leavers are removed and segments without owners are assigned new owners.
|
DefaultConsistentHash |
SyncConsistentHashFactory.updateMembers(DefaultConsistentHash baseCH,
List<Address> newMembers,
Map<Address,Float> actualCapacityFactors) |
DefaultConsistentHash |
SyncConsistentHashFactory.updateMembers(DefaultConsistentHash baseCH,
List<Address> newMembers,
Map<Address,Float> actualCapacityFactors) |
ReplicatedConsistentHash |
ReplicatedConsistentHashFactory.updateMembers(ReplicatedConsistentHash baseCH,
List<Address> newMembers,
Map<Address,Float> actualCapacityFactors) |
ReplicatedConsistentHash |
ReplicatedConsistentHashFactory.updateMembers(ReplicatedConsistentHash baseCH,
List<Address> newMembers,
Map<Address,Float> actualCapacityFactors) |
ReplicatedConsistentHash |
SyncReplicatedConsistentHashFactory.updateMembers(ReplicatedConsistentHash baseCH,
List<Address> newMembers,
Map<Address,Float> actualCapacityFactors) |
ReplicatedConsistentHash |
SyncReplicatedConsistentHashFactory.updateMembers(ReplicatedConsistentHash baseCH,
List<Address> newMembers,
Map<Address,Float> actualCapacityFactors) |
ScatteredConsistentHash |
ScatteredConsistentHashFactory.updateMembers(ScatteredConsistentHash baseCH,
List<Address> actualMembers,
Map<Address,Float> actualCapacityFactors)
Leavers are removed and segments without owners are assigned new owners.
|
ScatteredConsistentHash |
ScatteredConsistentHashFactory.updateMembers(ScatteredConsistentHash baseCH,
List<Address> actualMembers,
Map<Address,Float> actualCapacityFactors)
Leavers are removed and segments without owners are assigned new owners.
|
Constructor and Description |
---|
ScatteredConsistentHash(int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors,
Address[] segmentOwners,
boolean isRebalanced) |
Constructor and Description |
---|
AbstractConsistentHash(int numSegments,
List<Address> members,
float[] capacityFactors) |
AbstractConsistentHash(int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors) |
AbstractConsistentHash(int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors) |
Builder(DefaultConsistentHash baseCH,
List<Address> actualMembers,
Map<Address,Float> actualCapacityFactors) |
Builder(DefaultConsistentHash baseCH,
List<Address> actualMembers,
Map<Address,Float> actualCapacityFactors) |
Builder(int numOwners,
int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors) |
Builder(int numOwners,
int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors) |
Builder(int numOwners,
int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors) |
Builder(int numOwners,
int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors) |
Builder(int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors) |
Builder(int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors) |
Builder(ScatteredConsistentHash baseCH,
List<Address> actualMembers,
Map<Address,Float> actualCapacityFactors) |
Builder(ScatteredConsistentHash baseCH,
List<Address> actualMembers,
Map<Address,Float> actualCapacityFactors) |
DefaultConsistentHash(int numOwners,
int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors,
List<Address>[] segmentOwners) |
DefaultConsistentHash(int numOwners,
int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors,
List<Address>[] segmentOwners) |
OwnershipStatistics(ConsistentHash ch,
List<Address> activeNodes) |
OwnershipStatistics(List<Address> nodes) |
ReplicatedConsistentHash(List<Address> members,
int[] primaryOwners) |
ScatteredConsistentHash(int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors,
Address[] segmentOwners,
boolean isRebalanced) |
ScatteredConsistentHash(int numSegments,
List<Address> members,
Map<Address,Float> capacityFactors,
Address[] segmentOwners,
boolean isRebalanced) |
Modifier and Type | Method and Description |
---|---|
void |
L1ManagerImpl.addRequestor(Object key,
Address origin) |
CompletableFuture<?> |
L1ManagerImpl.flushCache(Collection<Object> keys,
Address origin,
boolean assumeOriginKeptEntryInL1) |
static LocalizedCacheTopology |
DistributionManagerImpl.makeSingletonTopology(CacheMode cacheMode,
KeyPartitioner keyPartitioner,
int numSegments,
Address localAddress) |
Modifier and Type | Method and Description |
---|---|
Collection<Address> |
TopologyInfo.getMachineNodes(String site,
String rack,
String machine) |
Collection<Address> |
TopologyInfo.getRackNodes(String site,
String rack) |
Collection<Address> |
TopologyInfo.getSiteNodes(String site) |
Modifier and Type | Method and Description |
---|---|
boolean |
TopologyInfo.duplicateLocation(TopologyLevel level,
Collection<Address> addresses,
Address candidate,
boolean excludeCandidate) |
float |
TopologyInfo.getExpectedOwnedSegments(Address address) |
float |
TopologyInfo.getExpectedPrimarySegments(Address address) |
Object |
TopologyInfo.getLocationId(TopologyLevel level,
Address address) |
int |
TopologyInfo.getMachineIndex(Address address) |
int |
TopologyInfo.getRackIndex(Address address) |
int |
TopologyInfo.getSiteIndex(Address address) |
Modifier and Type | Method and Description |
---|---|
float |
TopologyInfo.computeTotalCapacity(Collection<Address> nodes,
Map<Address,Float> capacityFactors) |
float |
TopologyInfo.computeTotalCapacity(Collection<Address> nodes,
Map<Address,Float> capacityFactors) |
boolean |
TopologyInfo.duplicateLocation(TopologyLevel level,
Collection<Address> addresses,
Address candidate,
boolean excludeCandidate) |
int |
TopologyInfo.getDistinctLocationsCount(TopologyLevel level,
Collection<Address> addresses) |
Constructor and Description |
---|
TopologyInfo(int numSegments,
int numOwners,
Collection<Address> members,
Map<Address,Float> capacityFactors) |
TopologyInfo(int numSegments,
int numOwners,
Collection<Address> members,
Map<Address,Float> capacityFactors) |
Modifier and Type | Method and Description |
---|---|
void |
BiasedCollector.addPendingAcks(boolean success,
Address[] waitFor) |
default ValidResponse |
BiasedCollector.addResponse(Address sender,
Response response) |
SuccessfulResponse |
RemoteGetSingleKeyCollector.addResponse(Address sender,
Response response) |
protected void |
BiasedScatteredDistributionInterceptor.completeManyWriteOnPrimaryOriginator(WriteCommand command,
Address backup,
org.infinispan.interceptors.distribution.CountDownCompletableFuture future) |
protected void |
ScatteredDistributionInterceptor.completeManyWriteOnPrimaryOriginator(WriteCommand command,
Address backup,
org.infinispan.interceptors.distribution.CountDownCompletableFuture future)
This is a hook for bias-enabled mode where the primary performs additional RPCs but replication to another node.
|
protected CompletionStage<?> |
BiasedScatteredDistributionInterceptor.completeSingleWriteOnPrimaryOriginator(DataWriteCommand command,
Address backup,
CompletionStage<?> rpcFuture) |
protected CompletionStage<?> |
ScatteredDistributionInterceptor.completeSingleWriteOnPrimaryOriginator(DataWriteCommand command,
Address backup,
CompletionStage<?> rpcFuture)
This is a hook for bias-enabled mode where the primary performs additional RPCs but replication to another node.
|
protected Object |
BaseDistributionInterceptor.invokeRemotely(InvocationContext ctx,
DataWriteCommand command,
Address primaryOwner) |
protected CompletionStage<ValidResponse> |
BiasedScatteredDistributionInterceptor.manyWriteOnRemotePrimary(Address target,
WriteCommand command,
CommandAckCollector.MultiTargetCollector multiTargetCollector) |
protected CompletionStage<ValidResponse> |
ScatteredDistributionInterceptor.manyWriteOnRemotePrimary(Address target,
WriteCommand command,
CommandAckCollector.MultiTargetCollector multiTargetCollector) |
protected CompletionStage<ValidResponse> |
BiasedScatteredDistributionInterceptor.singleWriteOnRemotePrimary(Address target,
DataWriteCommand command) |
protected CompletionStage<ValidResponse> |
ScatteredDistributionInterceptor.singleWriteOnRemotePrimary(Address target,
DataWriteCommand command)
This method is called by a non-owner sending write request to the primary owner
|
Modifier and Type | Method and Description |
---|---|
protected static RuntimeException |
ClusteringInterceptor.unexpected(Address sender,
Response response) |
Modifier and Type | Method and Description |
---|---|
protected static SuccessfulResponse |
ClusteringInterceptor.getSuccessfulResponseOrFail(Map<Address,Response> responseMap,
CompletableFuture<?> future,
Consumer<Response> cacheNotFound) |
Modifier and Type | Method and Description |
---|---|
Address |
ClusteringDependentLogic.getAddress() |
Address |
ClusteringDependentLogic.AbstractClusteringDependentLogic.getAddress() |
Address |
ClusteringDependentLogic.LocalLogic.getAddress() |
Address |
OrderedClusteringDependentLogic.getAddress() |
Modifier and Type | Method and Description |
---|---|
Address |
DefaultCacheManager.getAddress()
Warning: the address may be
null before the first clustered cache starts
and after all the clustered caches have been stopped. |
Address |
EmbeddedCacheManager.getAddress()
Warning: the address may be
null before the first clustered cache starts
and after all the clustered caches have been stopped. |
Address |
DefaultCacheManager.getCoordinator() |
Address |
EmbeddedCacheManager.getCoordinator() |
Modifier and Type | Method and Description |
---|---|
List<Address> |
DefaultCacheManager.getMembers() |
List<Address> |
EmbeddedCacheManager.getMembers() |
Modifier and Type | Method and Description |
---|---|
ClusterExecutor |
ClusterExecutor.filterTargets(ClusterExecutionPolicy policy,
Predicate<? super Address> predicate)
Allows for filtering of address nodes dynamically per invocation.
|
ClusterExecutor |
ClusterExecutor.filterTargets(Collection<Address> addresses)
Allows for filtering of address nodes by only allowing addresses in this collection from being contacted.
|
ClusterExecutor |
ClusterExecutor.filterTargets(Predicate<? super Address> predicate)
Allows for filtering of address nodes dynamically per invocation.
|
<V> CompletableFuture<Void> |
ClusterExecutor.submitConsumer(Function<? super EmbeddedCacheManager,? extends V> callable,
TriConsumer<? super Address,? super V,? super Throwable> triConsumer)
Submits the given command to the desired nodes and allows for handling of results as they return.
|
default <V> CompletableFuture<Void> |
ClusterExecutor.submitConsumer(SerializableFunction<? super EmbeddedCacheManager,? extends V> callable,
TriConsumer<? super Address,? super V,? super Throwable> triConsumer)
The same as
ClusterExecutor.submitConsumer(Function, TriConsumer) , except the Callable must also implement
Serializable. |
Modifier and Type | Method and Description |
---|---|
Address |
AbstractDelegatingEmbeddedCacheManager.getAddress() |
Address |
AbstractDelegatingEmbeddedCacheManager.getCoordinator() |
Modifier and Type | Method and Description |
---|---|
List<Address> |
AbstractDelegatingEmbeddedCacheManager.getMembers() |
Modifier and Type | Method and Description |
---|---|
static ClusterExecutor |
ClusterExecutors.allSubmissionExecutor(Predicate<? super Address> predicate,
EmbeddedCacheManager manager,
Transport transport,
long time,
TimeUnit unit,
Executor localExecutor,
ScheduledExecutorService timeoutExecutor) |
static ClusterExecutor |
ClusterExecutors.singleNodeSubmissionExecutor(Predicate<? super Address> predicate,
EmbeddedCacheManager manager,
Transport transport,
long time,
TimeUnit unit,
Executor localExecutor,
ScheduledExecutorService timeoutExecutor,
int failOverCount) |
Modifier and Type | Method and Description |
---|---|
Address |
RemoteClusterListener.getOwnerAddress() |
Modifier and Type | Method and Description |
---|---|
void |
ClusterEventManager.addEvents(Object batchIdentifier,
Address target,
UUID identifier,
Collection<ClusterEvent<K,V>> events,
boolean sync)
Adds additional cluster events that need to be sent remotely for an event originating locally.
|
Constructor and Description |
---|
ClusterListenerReplicateCallable(String cacheName,
UUID identifier,
Address origin,
CacheEventFilter<K,V> filter,
CacheEventConverter<K,V,?> converter,
boolean sync,
Set<Class<? extends Annotation>> filterAnnotations,
DataConversion keyDataConversion,
DataConversion valueDataConversion,
boolean useStorageFormat) |
RemoteClusterListener(UUID id,
Address origin,
CacheNotifier cacheNotifier,
CacheManagerNotifier cacheManagerNotifier,
ClusterEventManager eventManager,
boolean sync) |
Modifier and Type | Field and Description |
---|---|
protected Map<Address,org.infinispan.notifications.cachelistener.cluster.impl.BatchingClusterEventManagerImpl.TargetEvents<K,V>> |
BatchingClusterEventManagerImpl.UnicastEventContext.targets |
Modifier and Type | Method and Description |
---|---|
void |
BatchingClusterEventManagerImpl.addEvents(Object batchIdentifier,
Address target,
UUID identifier,
Collection<ClusterEvent<K,V>> events,
boolean sync) |
void |
ClusterEventManagerStub.addEvents(Object batchIdentifier,
Address target,
UUID identifier,
Collection<ClusterEvent<K,V>> clusterEvents,
boolean sync) |
void |
BatchingClusterEventManagerImpl.UnicastEventContext.addTargets(Address address,
UUID identifier,
Collection<ClusterEvent<K,V>> events,
boolean sync) |
Modifier and Type | Method and Description |
---|---|
Collection<Address> |
DataRehashedEvent.getMembersAtEnd() |
Collection<Address> |
DataRehashedEvent.getMembersAtStart() |
Modifier and Type | Method and Description |
---|---|
Collection<Address> |
EventImpl.getMembersAtEnd() |
Collection<Address> |
EventImpl.getMembersAtStart() |
Modifier and Type | Method and Description |
---|---|
CompletionStage<Void> |
CacheManagerNotifier.notifyMerge(List<Address> members,
List<Address> oldMembers,
Address myAddress,
int viewId,
List<List<Address>> subgroupsMerged) |
CompletionStage<Void> |
CacheManagerNotifierImpl.notifyMerge(List<Address> members,
List<Address> oldMembers,
Address myAddress,
int viewId,
List<List<Address>> subgroupsMerged) |
CompletionStage<Void> |
CacheManagerNotifier.notifyViewChange(List<Address> members,
List<Address> oldMembers,
Address myAddress,
int viewId)
Notifies all registered listeners of a viewChange event.
|
CompletionStage<Void> |
CacheManagerNotifierImpl.notifyViewChange(List<Address> members,
List<Address> oldMembers,
Address myAddress,
int viewId) |
Modifier and Type | Method and Description |
---|---|
CompletionStage<Void> |
CacheManagerNotifier.notifyMerge(List<Address> members,
List<Address> oldMembers,
Address myAddress,
int viewId,
List<List<Address>> subgroupsMerged) |
CompletionStage<Void> |
CacheManagerNotifier.notifyMerge(List<Address> members,
List<Address> oldMembers,
Address myAddress,
int viewId,
List<List<Address>> subgroupsMerged) |
CompletionStage<Void> |
CacheManagerNotifier.notifyMerge(List<Address> members,
List<Address> oldMembers,
Address myAddress,
int viewId,
List<List<Address>> subgroupsMerged) |
CompletionStage<Void> |
CacheManagerNotifierImpl.notifyMerge(List<Address> members,
List<Address> oldMembers,
Address myAddress,
int viewId,
List<List<Address>> subgroupsMerged) |
CompletionStage<Void> |
CacheManagerNotifierImpl.notifyMerge(List<Address> members,
List<Address> oldMembers,
Address myAddress,
int viewId,
List<List<Address>> subgroupsMerged) |
CompletionStage<Void> |
CacheManagerNotifierImpl.notifyMerge(List<Address> members,
List<Address> oldMembers,
Address myAddress,
int viewId,
List<List<Address>> subgroupsMerged) |
CompletionStage<Void> |
CacheManagerNotifier.notifyViewChange(List<Address> members,
List<Address> oldMembers,
Address myAddress,
int viewId)
Notifies all registered listeners of a viewChange event.
|
CompletionStage<Void> |
CacheManagerNotifier.notifyViewChange(List<Address> members,
List<Address> oldMembers,
Address myAddress,
int viewId)
Notifies all registered listeners of a viewChange event.
|
CompletionStage<Void> |
CacheManagerNotifierImpl.notifyViewChange(List<Address> members,
List<Address> oldMembers,
Address myAddress,
int viewId) |
CompletionStage<Void> |
CacheManagerNotifierImpl.notifyViewChange(List<Address> members,
List<Address> oldMembers,
Address myAddress,
int viewId) |
Modifier and Type | Method and Description |
---|---|
Address |
ViewChangedEvent.getLocalAddress() |
Modifier and Type | Method and Description |
---|---|
List<Address> |
ViewChangedEvent.getNewMembers()
Gets the current list of members.
|
List<Address> |
ViewChangedEvent.getOldMembers()
Gets the previous list of members.
|
List<List<Address>> |
MergeEvent.getSubgroupsMerged() |
Modifier and Type | Method and Description |
---|---|
Address |
EventImpl.getLocalAddress() |
Modifier and Type | Method and Description |
---|---|
List<Address> |
EventImpl.getNewMembers() |
List<Address> |
EventImpl.getOldMembers() |
List<List<Address>> |
EventImpl.getSubgroupsMerged() |
Modifier and Type | Method and Description |
---|---|
void |
EventImpl.setLocalAddress(Address localAddress) |
Modifier and Type | Method and Description |
---|---|
void |
EventImpl.setNewMembers(List<Address> newMembers) |
void |
EventImpl.setOldMembers(List<Address> oldMembers) |
void |
EventImpl.setSubgroupsMerged(List<List<Address>> subgroupsMerged) |
Constructor and Description |
---|
EventImpl(String cacheName,
EmbeddedCacheManager cacheManager,
Event.Type type,
List<Address> newMemberList,
List<Address> oldMemberList,
Address localAddress,
int viewId) |
Constructor and Description |
---|
EventImpl(String cacheName,
EmbeddedCacheManager cacheManager,
Event.Type type,
List<Address> newMemberList,
List<Address> oldMemberList,
Address localAddress,
int viewId) |
EventImpl(String cacheName,
EmbeddedCacheManager cacheManager,
Event.Type type,
List<Address> newMemberList,
List<Address> oldMemberList,
Address localAddress,
int viewId) |
Modifier and Type | Method and Description |
---|---|
Map<Address,Float> |
AvailabilityStrategyContext.getCapacityFactors() |
List<Address> |
AvailabilityStrategyContext.getExpectedMembers()
The members of the cache.
|
Modifier and Type | Method and Description |
---|---|
void |
AvailabilityStrategy.onGracefulLeave(AvailabilityStrategyContext context,
Address leaver)
Called when a node leaves gracefully.
|
void |
PreferAvailabilityStrategy.onGracefulLeave(AvailabilityStrategyContext context,
Address leaver) |
void |
PreferConsistencyStrategy.onGracefulLeave(AvailabilityStrategyContext context,
Address leaver) |
void |
AvailabilityStrategy.onJoin(AvailabilityStrategyContext context,
Address joiner)
Called when a node joins.
|
void |
PreferAvailabilityStrategy.onJoin(AvailabilityStrategyContext context,
Address joiner) |
void |
PreferConsistencyStrategy.onJoin(AvailabilityStrategyContext context,
Address joiner) |
Modifier and Type | Method and Description |
---|---|
boolean |
AvailablePartitionHandlingManager.addPartialCommit1PCTransaction(GlobalTransaction globalTransaction,
Collection<Address> affectedNodes,
Collection<Object> lockedKeys,
List<WriteCommand> modifications) |
boolean |
PartitionHandlingManager.addPartialCommit1PCTransaction(GlobalTransaction globalTransaction,
Collection<Address> affectedNodes,
Collection<Object> lockedKeys,
List<WriteCommand> modifications)
Adds a partially committed transaction.
|
boolean |
PartitionHandlingManagerImpl.addPartialCommit1PCTransaction(GlobalTransaction globalTransaction,
Collection<Address> affectedNodes,
Collection<Object> lockedKeys,
List<WriteCommand> modifications) |
boolean |
AvailablePartitionHandlingManager.addPartialCommit2PCTransaction(GlobalTransaction globalTransaction,
Collection<Address> affectedNodes,
Collection<Object> lockedKeys,
Map<Object,IncrementableEntryVersion> newVersions) |
boolean |
PartitionHandlingManager.addPartialCommit2PCTransaction(GlobalTransaction globalTransaction,
Collection<Address> affectedNodes,
Collection<Object> lockedKeys,
Map<Object,IncrementableEntryVersion> newVersions)
Adds a partially committed transaction.
|
boolean |
PartitionHandlingManagerImpl.addPartialCommit2PCTransaction(GlobalTransaction globalTransaction,
Collection<Address> affectedNodes,
Collection<Object> lockedKeys,
Map<Object,IncrementableEntryVersion> newVersions) |
boolean |
AvailablePartitionHandlingManager.addPartialRollbackTransaction(GlobalTransaction globalTransaction,
Collection<Address> affectedNodes,
Collection<Object> lockedKeys) |
boolean |
PartitionHandlingManager.addPartialRollbackTransaction(GlobalTransaction globalTransaction,
Collection<Address> affectedNodes,
Collection<Object> lockedKeys)
Adds a partially aborted transaction.
|
boolean |
PartitionHandlingManagerImpl.addPartialRollbackTransaction(GlobalTransaction globalTransaction,
Collection<Address> affectedNodes,
Collection<Object> lockedKeys) |
ConsistentHash |
AvailabilityStrategyContext.calculateConflictHash(ConsistentHash preferredHash,
Set<ConsistentHash> distinctHashes,
List<Address> actualMembers) |
CacheTopology |
PreferAvailabilityStrategy.computePreferredTopology(Map<Address,CacheStatusResponse> statusResponseMap)
Ignore the AvailabilityStrategyContext and only compute the preferred topology for testing.
|
protected boolean |
PreferConsistencyStrategy.isMinorityPartition(List<Address> stableMembers,
List<Address> lostMembers) |
protected boolean |
PreferConsistencyStrategy.isMinorityPartition(List<Address> stableMembers,
List<Address> lostMembers) |
void |
AvailabilityStrategy.onClusterViewChange(AvailabilityStrategyContext context,
List<Address> clusterMembers)
Called when the cluster view changed (e.g.
|
void |
PreferAvailabilityStrategy.onClusterViewChange(AvailabilityStrategyContext context,
List<Address> clusterMembers) |
void |
PreferConsistencyStrategy.onClusterViewChange(AvailabilityStrategyContext context,
List<Address> clusterMembers) |
void |
AvailabilityStrategy.onPartitionMerge(AvailabilityStrategyContext context,
Map<Address,CacheStatusResponse> statusResponseMap)
Called when two or more partitions merge, to compute the stable and current cache topologies for the merged
cluster.
|
void |
PreferAvailabilityStrategy.onPartitionMerge(AvailabilityStrategyContext context,
Map<Address,CacheStatusResponse> statusResponseMap) |
void |
PreferConsistencyStrategy.onPartitionMerge(AvailabilityStrategyContext context,
Map<Address,CacheStatusResponse> statusResponseMap) |
void |
AvailabilityStrategyContext.queueConflictResolution(CacheTopology conflictTopology,
Set<Address> preferredNodes)
Initiates conflict resolution using the conflictTopology, which should have already been broadcast via
this#updateTopologiesAfterMerge(CacheTopology, CacheTopology, AvailabilityMode) |
void |
AvailabilityStrategyContext.queueRebalance(List<Address> newMembers)
Queue (or start) a rebalance.
|
boolean |
AvailabilityStrategyContext.restartConflictResolution(List<Address> newMembers)
If CR is in progress, then this method cancels the current CR and starts a new CR phase with an updated topology
based upon newMembers and the previously queued CR topology
|
void |
AvailabilityStrategyContext.updateAvailabilityMode(List<Address> actualMembers,
AvailabilityMode mode,
boolean cancelRebalance)
Enter a new availability mode.
|
void |
AvailabilityStrategyContext.updateCurrentTopology(List<Address> newMembers)
Use the configured
ConsistentHashFactory to create a new CH
with the given members , but do not start a rebalance. |
Modifier and Type | Method and Description |
---|---|
void |
GlobalInboundInvocationHandler.handleFromCluster(Address origin,
ReplicableCommand command,
Reply reply,
DeliverOrder order) |
void |
InboundInvocationHandler.handleFromCluster(Address origin,
ReplicableCommand command,
Reply reply,
DeliverOrder order)
Handles the
ReplicableCommand from other node belonging to local site. |
Modifier and Type | Method and Description |
---|---|
Address[] |
BiasRevocationResponse.getWaitList() |
Modifier and Type | Method and Description |
---|---|
boolean |
ClusteredGetResponseValidityFilter.isAcceptable(Response response,
Address address) |
boolean |
IgnoreExtraResponsesValidityFilter.isAcceptable(Response response,
Address address) |
Constructor and Description |
---|
BiasRevocationResponse(Object responseValue,
Address[] waitFor) |
ClusteredGetResponseValidityFilter(Collection<Address> targets,
Address self) |
IgnoreExtraResponsesValidityFilter(Collection<Address> targets,
Address self,
boolean removeSelf) |
Constructor and Description |
---|
ClusteredGetResponseValidityFilter(Collection<Address> targets,
Address self) |
IgnoreExtraResponsesValidityFilter(Collection<Address> targets,
Address self,
boolean removeSelf) |
Modifier and Type | Method and Description |
---|---|
Address |
RpcManager.getAddress()
Returns the address associated with this RpcManager or null if not part of the cluster.
|
Address |
RpcManagerImpl.getAddress() |
Modifier and Type | Method and Description |
---|---|
List<Address> |
RpcManager.getMembers()
Returns members of a cluster scoped to the cache owning this RpcManager.
|
List<Address> |
RpcManagerImpl.getMembers() |
default CompletableFuture<Map<Address,Response>> |
RpcManager.invokeRemotelyAsync(Collection<Address> recipients,
ReplicableCommand rpc,
RpcOptions options)
Deprecated.
|
CompletableFuture<Map<Address,Response>> |
RpcManagerImpl.invokeRemotelyAsync(Collection<Address> recipients,
ReplicableCommand rpc,
RpcOptions options) |
Modifier and Type | Method and Description |
---|---|
<T> CompletionStage<T> |
RpcManager.invokeCommand(Address target,
ReplicableCommand command,
ResponseCollector<T> collector,
RpcOptions rpcOptions)
Invoke a command on a single node and pass the response to a
ResponseCollector . |
<T> CompletionStage<T> |
RpcManagerImpl.invokeCommand(Address target,
ReplicableCommand command,
ResponseCollector<T> collector,
RpcOptions rpcOptions) |
boolean |
ResponseFilter.isAcceptable(Response response,
Address sender)
Determines whether a response from a given sender should be added to the response list of the request
|
void |
RpcManager.sendTo(Address destination,
ReplicableCommand command,
DeliverOrder deliverOrder)
Asynchronously sends the
ReplicableCommand to the destination using the specified DeliverOrder . |
void |
RpcManagerImpl.sendTo(Address destination,
ReplicableCommand command,
DeliverOrder deliverOrder) |
Modifier and Type | Method and Description |
---|---|
<T> CompletionStage<T> |
RpcManager.invokeCommand(Collection<Address> targets,
ReplicableCommand command,
ResponseCollector<T> collector,
RpcOptions rpcOptions)
Invoke a command on a collection of node and pass the responses to a
ResponseCollector . |
<T> CompletionStage<T> |
RpcManagerImpl.invokeCommand(Collection<Address> targets,
ReplicableCommand command,
ResponseCollector<T> collector,
RpcOptions rpcOptions) |
<T> CompletionStage<T> |
RpcManager.invokeCommands(Collection<Address> targets,
Function<Address,ReplicableCommand> commandGenerator,
ResponseCollector<T> collector,
RpcOptions rpcOptions)
Invoke different commands on a collection of nodes and pass the responses to a
ResponseCollector . |
<T> CompletionStage<T> |
RpcManager.invokeCommands(Collection<Address> targets,
Function<Address,ReplicableCommand> commandGenerator,
ResponseCollector<T> collector,
RpcOptions rpcOptions)
Invoke different commands on a collection of nodes and pass the responses to a
ResponseCollector . |
<T> CompletionStage<T> |
RpcManagerImpl.invokeCommands(Collection<Address> targets,
Function<Address,ReplicableCommand> commandGenerator,
ResponseCollector<T> collector,
RpcOptions rpcOptions) |
<T> CompletionStage<T> |
RpcManagerImpl.invokeCommands(Collection<Address> targets,
Function<Address,ReplicableCommand> commandGenerator,
ResponseCollector<T> collector,
RpcOptions rpcOptions) |
<T> CompletionStage<T> |
RpcManager.invokeCommandStaggered(Collection<Address> targets,
ReplicableCommand command,
ResponseCollector<T> collector,
RpcOptions rpcOptions)
Invoke a command on a collection of nodes and pass the responses to a
ResponseCollector . |
<T> CompletionStage<T> |
RpcManagerImpl.invokeCommandStaggered(Collection<Address> targets,
ReplicableCommand command,
ResponseCollector<T> collector,
RpcOptions rpcOptions) |
default CompletableFuture<Map<Address,Response>> |
RpcManager.invokeRemotelyAsync(Collection<Address> recipients,
ReplicableCommand rpc,
RpcOptions options)
Deprecated.
|
CompletableFuture<Map<Address,Response>> |
RpcManagerImpl.invokeRemotelyAsync(Collection<Address> recipients,
ReplicableCommand rpc,
RpcOptions options) |
void |
RpcManager.sendToMany(Collection<Address> destinations,
ReplicableCommand command,
DeliverOrder deliverOrder)
Asynchronously sends the
ReplicableCommand to the set of destination using the specified DeliverOrder . |
void |
RpcManagerImpl.sendToMany(Collection<Address> destinations,
ReplicableCommand command,
DeliverOrder deliverOrder) |
Modifier and Type | Interface and Description |
---|---|
interface |
TopologyAwareAddress
Wraps a TopologyUUID JGroups address
|
Modifier and Type | Class and Description |
---|---|
class |
LocalModeAddress
Represents the local node's address.
|
Modifier and Type | Field and Description |
---|---|
static Address[] |
Address.EMPTY_ARRAY |
static Address |
LocalModeAddress.INSTANCE |
Modifier and Type | Method and Description |
---|---|
Address |
AbstractDelegatingTransport.getAddress() |
Address |
Transport.getAddress()
Retrieves the current cache instance's network address
|
Address |
AbstractDelegatingTransport.getCoordinator() |
Address |
Transport.getCoordinator() |
Modifier and Type | Method and Description |
---|---|
List<Address> |
AbstractDelegatingTransport.getMembers() |
List<Address> |
Transport.getMembers()
Returns a list of members in the current cluster view.
|
List<Address> |
AbstractDelegatingTransport.getMembersPhysicalAddresses() |
List<Address> |
Transport.getMembersPhysicalAddresses()
Returns physical addresses of members in the current cluster view.
|
List<Address> |
AbstractDelegatingTransport.getPhysicalAddresses() |
List<Address> |
Transport.getPhysicalAddresses()
Retrieves the current cache instance's physical network addresses.
|
Map<Address,Response> |
AbstractDelegatingTransport.invokeRemotely(Collection<Address> recipients,
ReplicableCommand rpcCommand,
ResponseMode mode,
long timeout,
ResponseFilter responseFilter,
DeliverOrder deliverOrder,
boolean anycast)
Deprecated.
|
default Map<Address,Response> |
Transport.invokeRemotely(Collection<Address> recipients,
ReplicableCommand rpcCommand,
ResponseMode mode,
long timeout,
ResponseFilter responseFilter,
DeliverOrder deliverOrder,
boolean anycast)
Deprecated.
Since 9.2, please use
Transport.invokeCommand(Collection, ReplicableCommand, ResponseCollector, DeliverOrder, long, TimeUnit) instead. |
Map<Address,Response> |
AbstractDelegatingTransport.invokeRemotely(Map<Address,ReplicableCommand> rpcCommands,
ResponseMode mode,
long timeout,
boolean usePriorityQueue,
ResponseFilter responseFilter,
boolean totalOrder,
boolean anycast)
Deprecated.
|
default Map<Address,Response> |
Transport.invokeRemotely(Map<Address,ReplicableCommand> rpcCommands,
ResponseMode mode,
long timeout,
boolean usePriorityQueue,
ResponseFilter responseFilter,
boolean totalOrder,
boolean anycast)
Deprecated.
|
Map<Address,Response> |
AbstractDelegatingTransport.invokeRemotely(Map<Address,ReplicableCommand> rpcCommands,
ResponseMode mode,
long timeout,
ResponseFilter responseFilter,
DeliverOrder deliverOrder,
boolean anycast)
Deprecated.
|
default Map<Address,Response> |
Transport.invokeRemotely(Map<Address,ReplicableCommand> rpcCommands,
ResponseMode mode,
long timeout,
ResponseFilter responseFilter,
DeliverOrder deliverOrder,
boolean anycast)
Deprecated.
Since 9.2, please use
Transport.invokeRemotelyAsync(Collection, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder, boolean) instead. |
CompletableFuture<Map<Address,Response>> |
AbstractDelegatingTransport.invokeRemotelyAsync(Collection<Address> recipients,
ReplicableCommand rpcCommand,
ResponseMode mode,
long timeout,
ResponseFilter responseFilter,
DeliverOrder deliverOrder,
boolean anycast) |
CompletableFuture<Map<Address,Response>> |
Transport.invokeRemotelyAsync(Collection<Address> recipients,
ReplicableCommand rpcCommand,
ResponseMode mode,
long timeout,
ResponseFilter responseFilter,
DeliverOrder deliverOrder,
boolean anycast) |
Modifier and Type | Method and Description |
---|---|
protected abstract T |
ValidResponseCollector.addException(Address sender,
Exception exception)
Process an exception from a target.
|
T |
ValidResponseCollector.addResponse(Address sender,
Response response) |
T |
ValidSingleResponseCollector.addResponse(Address sender,
Response response) |
T |
ResponseCollector.addResponse(Address sender,
Response response)
Called when a response is received, or when a target node becomes unavailable.
|
protected abstract T |
ValidResponseCollector.addTargetNotFound(Address sender)
Process a target leaving the cluster or stopping the cache.
|
protected abstract T |
ValidResponseCollector.addValidResponse(Address sender,
ValidResponse response)
Process a valid response from a target.
|
Response |
AbstractTransport.checkResponse(Object responseObject,
Address sender,
boolean ignoreCacheNotFoundResponse)
Deprecated.
|
int |
LocalModeAddress.compareTo(Address o) |
<T> CompletionStage<T> |
AbstractDelegatingTransport.invokeCommand(Address target,
ReplicableCommand command,
ResponseCollector<T> collector,
DeliverOrder deliverOrder,
long timeout,
TimeUnit unit) |
default <T> CompletionStage<T> |
Transport.invokeCommand(Address target,
ReplicableCommand command,
ResponseCollector<T> collector,
DeliverOrder deliverOrder,
long timeout,
TimeUnit unit)
Invoke a command on a single node and pass the response to a
ResponseCollector . |
static SuspectException |
ResponseCollectors.remoteNodeSuspected(Address sender) |
void |
AbstractDelegatingTransport.sendTo(Address destination,
ReplicableCommand rpcCommand,
DeliverOrder deliverOrder) |
void |
Transport.sendTo(Address destination,
ReplicableCommand rpcCommand,
DeliverOrder deliverOrder)
Asynchronously sends the
ReplicableCommand to the destination using the specified DeliverOrder . |
protected abstract T |
ValidSingleResponseCollector.targetNotFound(Address sender) |
protected T |
ValidSingleResponseCollector.withException(Address sender,
Exception exception) |
protected abstract T |
ValidSingleResponseCollector.withValidResponse(Address sender,
ValidResponse response) |
static CacheException |
ResponseCollectors.wrapRemoteException(Address sender,
Throwable exception) |
Modifier and Type | Method and Description |
---|---|
<T> CompletionStage<T> |
AbstractDelegatingTransport.invokeCommand(Collection<Address> targets,
ReplicableCommand command,
ResponseCollector<T> collector,
DeliverOrder deliverOrder,
long timeout,
TimeUnit unit) |
default <T> CompletionStage<T> |
Transport.invokeCommand(Collection<Address> targets,
ReplicableCommand command,
ResponseCollector<T> collector,
DeliverOrder deliverOrder,
long timeout,
TimeUnit unit)
Invoke a command on a collection of node and pass the responses to a
ResponseCollector . |
default <T> CompletionStage<T> |
Transport.invokeCommandOnAll(Collection<Address> requiredTargets,
ReplicableCommand command,
ResponseCollector<T> collector,
DeliverOrder deliverOrder,
long timeout,
TimeUnit unit)
Invoke a command on all the nodes in the cluster and pass the responses to a
ResponseCollector . |
<T> CompletionStage<T> |
AbstractDelegatingTransport.invokeCommands(Collection<Address> targets,
Function<Address,ReplicableCommand> commandGenerator,
ResponseCollector<T> collector,
DeliverOrder deliverOrder,
long timeout,
TimeUnit timeUnit) |
<T> CompletionStage<T> |
AbstractDelegatingTransport.invokeCommands(Collection<Address> targets,
Function<Address,ReplicableCommand> commandGenerator,
ResponseCollector<T> collector,
DeliverOrder deliverOrder,
long timeout,
TimeUnit timeUnit) |
default <T> CompletionStage<T> |
Transport.invokeCommands(Collection<Address> targets,
Function<Address,ReplicableCommand> commandGenerator,
ResponseCollector<T> collector,
DeliverOrder deliverOrder,
long timeout,
TimeUnit timeUnit)
Invoke different commands on a collection of nodes and pass the responses to a
ResponseCollector . |
default <T> CompletionStage<T> |
Transport.invokeCommands(Collection<Address> targets,
Function<Address,ReplicableCommand> commandGenerator,
ResponseCollector<T> collector,
DeliverOrder deliverOrder,
long timeout,
TimeUnit timeUnit)
Invoke different commands on a collection of nodes and pass the responses to a
ResponseCollector . |
default <T> CompletionStage<T> |
Transport.invokeCommands(Collection<Address> targets,
Function<Address,ReplicableCommand> commandGenerator,
ResponseCollector<T> responseCollector,
long timeout,
DeliverOrder deliverOrder)
Deprecated.
Introduced in 9.1, but replaced in 9.2 with
Transport.invokeCommands(Collection, Function, ResponseCollector, DeliverOrder, long, TimeUnit) . |
default <T> CompletionStage<T> |
Transport.invokeCommands(Collection<Address> targets,
Function<Address,ReplicableCommand> commandGenerator,
ResponseCollector<T> responseCollector,
long timeout,
DeliverOrder deliverOrder)
Deprecated.
Introduced in 9.1, but replaced in 9.2 with
Transport.invokeCommands(Collection, Function, ResponseCollector, DeliverOrder, long, TimeUnit) . |
<T> CompletionStage<T> |
AbstractDelegatingTransport.invokeCommandStaggered(Collection<Address> targets,
ReplicableCommand command,
ResponseCollector<T> collector,
DeliverOrder deliverOrder,
long timeout,
TimeUnit unit) |
default <T> CompletionStage<T> |
Transport.invokeCommandStaggered(Collection<Address> targets,
ReplicableCommand command,
ResponseCollector<T> collector,
DeliverOrder deliverOrder,
long timeout,
TimeUnit unit)
Invoke a command on a collection of nodes and pass the responses to a
ResponseCollector . |
Map<Address,Response> |
AbstractDelegatingTransport.invokeRemotely(Collection<Address> recipients,
ReplicableCommand rpcCommand,
ResponseMode mode,
long timeout,
ResponseFilter responseFilter,
DeliverOrder deliverOrder,
boolean anycast)
Deprecated.
|
default Map<Address,Response> |
Transport.invokeRemotely(Collection<Address> recipients,
ReplicableCommand rpcCommand,
ResponseMode mode,
long timeout,
ResponseFilter responseFilter,
DeliverOrder deliverOrder,
boolean anycast)
Deprecated.
Since 9.2, please use
Transport.invokeCommand(Collection, ReplicableCommand, ResponseCollector, DeliverOrder, long, TimeUnit) instead. |
Map<Address,Response> |
AbstractDelegatingTransport.invokeRemotely(Map<Address,ReplicableCommand> rpcCommands,
ResponseMode mode,
long timeout,
boolean usePriorityQueue,
ResponseFilter responseFilter,
boolean totalOrder,
boolean anycast)
Deprecated.
|
default Map<Address,Response> |
Transport.invokeRemotely(Map<Address,ReplicableCommand> rpcCommands,
ResponseMode mode,
long timeout,
boolean usePriorityQueue,
ResponseFilter responseFilter,
boolean totalOrder,
boolean anycast)
Deprecated.
|
Map<Address,Response> |
AbstractDelegatingTransport.invokeRemotely(Map<Address,ReplicableCommand> rpcCommands,
ResponseMode mode,
long timeout,
ResponseFilter responseFilter,
DeliverOrder deliverOrder,
boolean anycast)
Deprecated.
|
default Map<Address,Response> |
Transport.invokeRemotely(Map<Address,ReplicableCommand> rpcCommands,
ResponseMode mode,
long timeout,
ResponseFilter responseFilter,
DeliverOrder deliverOrder,
boolean anycast)
Deprecated.
Since 9.2, please use
Transport.invokeRemotelyAsync(Collection, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder, boolean) instead. |
CompletableFuture<Map<Address,Response>> |
AbstractDelegatingTransport.invokeRemotelyAsync(Collection<Address> recipients,
ReplicableCommand rpcCommand,
ResponseMode mode,
long timeout,
ResponseFilter responseFilter,
DeliverOrder deliverOrder,
boolean anycast) |
CompletableFuture<Map<Address,Response>> |
Transport.invokeRemotelyAsync(Collection<Address> recipients,
ReplicableCommand rpcCommand,
ResponseMode mode,
long timeout,
ResponseFilter responseFilter,
DeliverOrder deliverOrder,
boolean anycast) |
void |
AbstractDelegatingTransport.sendToMany(Collection<Address> destinations,
ReplicableCommand rpcCommand,
DeliverOrder deliverOrder) |
void |
Transport.sendToMany(Collection<Address> destinations,
ReplicableCommand rpcCommand,
DeliverOrder deliverOrder)
Asynchronously sends the
ReplicableCommand to the set of destination using the specified DeliverOrder . |
Modifier and Type | Field and Description |
---|---|
protected HashMap<Address,Response> |
MapResponseCollector.map |
Modifier and Type | Method and Description |
---|---|
protected Address |
MultiTargetRequest.getTarget(int i) |
Modifier and Type | Method and Description |
---|---|
protected Map<Address,Response> |
FilterMapResponseCollector.addException(Address sender,
Exception exception) |
protected Map<Address,Response> |
MapResponseCollector.addException(Address sender,
Exception exception) |
Map<Address,Response> |
PassthroughMapResponseCollector.addResponse(Address sender,
Response response) |
protected Map<Address,Response> |
FilterMapResponseCollector.addTargetNotFound(Address sender) |
protected Map<Address,Response> |
FilterMapResponseCollector.addValidResponse(Address sender,
ValidResponse response) |
protected Map<Address,Response> |
MapResponseCollector.addValidResponse(Address sender,
ValidResponse response) |
Map<Address,Response> |
FilterMapResponseCollector.finish() |
Map<Address,Response> |
MapResponseCollector.finish() |
Map<Address,Response> |
PassthroughMapResponseCollector.finish() |
protected Map<Address,Response> |
SingletonMapResponseCollector.targetNotFound(Address sender) |
protected Map<Address,Response> |
SingletonMapResponseCollector.withValidResponse(Address sender,
ValidResponse response) |
Modifier and Type | Method and Description |
---|---|
protected Void |
VoidResponseCollector.addException(Address sender,
Exception exception) |
protected Map<Address,Response> |
FilterMapResponseCollector.addException(Address sender,
Exception exception) |
protected Map<Address,Response> |
MapResponseCollector.addException(Address sender,
Exception exception) |
Response |
PassthroughSingleResponseCollector.addResponse(Address sender,
Response response) |
Map<Address,Response> |
PassthroughMapResponseCollector.addResponse(Address sender,
Response response) |
void |
RequestRepository.addResponse(long requestId,
Address sender,
Response response) |
protected Void |
VoidResponseCollector.addTargetNotFound(Address sender) |
protected Map<Address,Response> |
FilterMapResponseCollector.addTargetNotFound(Address sender) |
protected Void |
VoidResponseCollector.addValidResponse(Address sender,
ValidResponse response) |
protected Map<Address,Response> |
FilterMapResponseCollector.addValidResponse(Address sender,
ValidResponse response) |
protected Map<Address,Response> |
MapResponseCollector.addValidResponse(Address sender,
ValidResponse response) |
void |
MultiTargetRequest.onResponse(Address sender,
Response response) |
void |
Request.onResponse(Address sender,
Response response)
Called when a response is received for this response.
|
void |
SingleTargetRequest.onResponse(Address sender,
Response response) |
protected ValidResponse |
SingleResponseCollector.targetNotFound(Address sender) |
protected Map<Address,Response> |
SingletonMapResponseCollector.targetNotFound(Address sender) |
protected ValidResponse |
SingleResponseCollector.withValidResponse(Address sender,
ValidResponse response) |
protected Map<Address,Response> |
SingletonMapResponseCollector.withValidResponse(Address sender,
ValidResponse response) |
Modifier and Type | Method and Description |
---|---|
boolean |
MultiTargetRequest.onNewView(Set<Address> members) |
boolean |
Request.onNewView(Set<Address> members)
Called when the node received a new cluster view.
|
boolean |
SingleTargetRequest.onNewView(Set<Address> members) |
Constructor and Description |
---|
MultiTargetRequest(ResponseCollector<T> responseCollector,
long requestId,
RequestRepository repository,
Collection<Address> targets,
Address excluded) |
SingleTargetRequest(ResponseCollector<T> wrapper,
long requestId,
RequestRepository repository,
Address target) |
Constructor and Description |
---|
MultiTargetRequest(ResponseCollector<T> responseCollector,
long requestId,
RequestRepository repository,
Collection<Address> targets,
Address excluded) |
Modifier and Type | Class and Description |
---|---|
class |
JGroupsAddress
An encapsulation of a JGroups Address
|
class |
JGroupsTopologyAwareAddress
An encapsulation of a JGroups
ExtendedUUID with a site id, a rack id, and a machine id. |
Modifier and Type | Field and Description |
---|---|
protected Address |
JGroupsTransport.address |
protected Address |
JGroupsTransport.physicalAddress |
Modifier and Type | Method and Description |
---|---|
static Address |
JGroupsAddressCache.fromJGroupsAddress(org.jgroups.Address jgroupsAddress) |
Address |
JGroupsTransport.getAddress() |
Address |
ClusterView.getCoordinator() |
Address |
JGroupsTransport.getCoordinator() |
Address |
SuspectException.getSuspect() |
Modifier and Type | Method and Description |
---|---|
List<Address> |
ClusterView.getMembers() |
List<Address> |
JGroupsTransport.getMembers() |
List<Address> |
JGroupsTransport.getMembersPhysicalAddresses() |
Set<Address> |
ClusterView.getMembersSet() |
List<Address> |
JGroupsTransport.getPhysicalAddresses() |
Map<Address,Response> |
JGroupsTransport.invokeRemotely(Map<Address,ReplicableCommand> commands,
ResponseMode mode,
long timeout,
ResponseFilter responseFilter,
DeliverOrder deliverOrder,
boolean anycast)
Deprecated.
|
CompletableFuture<Map<Address,Response>> |
JGroupsTransport.invokeRemotelyAsync(Collection<Address> recipients,
ReplicableCommand command,
ResponseMode mode,
long timeout,
ResponseFilter responseFilter,
DeliverOrder deliverOrder,
boolean anycast) |
Modifier and Type | Method and Description |
---|---|
int |
JGroupsAddress.compareTo(Address o) |
<T> CompletionStage<T> |
JGroupsTransport.invokeCommand(Address target,
ReplicableCommand command,
ResponseCollector<T> collector,
DeliverOrder deliverOrder,
long timeout,
TimeUnit unit) |
void |
SingleSiteRequest.onResponse(Address sender,
Response response) |
void |
StaggeredRequest.onResponse(Address sender,
Response response) |
void |
JGroupsTransport.sendTo(Address destination,
ReplicableCommand command,
DeliverOrder deliverOrder) |
Modifier and Type | Method and Description |
---|---|
<T> CompletionStage<T> |
JGroupsTransport.invokeCommand(Collection<Address> targets,
ReplicableCommand command,
ResponseCollector<T> collector,
DeliverOrder deliverOrder,
long timeout,
TimeUnit unit) |
<T> CompletionStage<T> |
JGroupsTransport.invokeCommandOnAll(Collection<Address> requiredTargets,
ReplicableCommand command,
ResponseCollector<T> collector,
DeliverOrder deliverOrder,
long timeout,
TimeUnit unit) |
<T> CompletionStage<T> |
JGroupsTransport.invokeCommands(Collection<Address> targets,
Function<Address,ReplicableCommand> commandGenerator,
ResponseCollector<T> collector,
DeliverOrder deliverOrder,
long timeout,
TimeUnit timeUnit) |
<T> CompletionStage<T> |
JGroupsTransport.invokeCommands(Collection<Address> targets,
Function<Address,ReplicableCommand> commandGenerator,
ResponseCollector<T> collector,
DeliverOrder deliverOrder,
long timeout,
TimeUnit timeUnit) |
<T> CompletionStage<T> |
JGroupsTransport.invokeCommandStaggered(Collection<Address> targets,
ReplicableCommand command,
ResponseCollector<T> collector,
DeliverOrder deliverOrder,
long timeout,
TimeUnit unit) |
Map<Address,Response> |
JGroupsTransport.invokeRemotely(Map<Address,ReplicableCommand> commands,
ResponseMode mode,
long timeout,
ResponseFilter responseFilter,
DeliverOrder deliverOrder,
boolean anycast)
Deprecated.
|
CompletableFuture<Map<Address,Response>> |
JGroupsTransport.invokeRemotelyAsync(Collection<Address> recipients,
ReplicableCommand command,
ResponseMode mode,
long timeout,
ResponseFilter responseFilter,
DeliverOrder deliverOrder,
boolean anycast) |
boolean |
SingleSiteRequest.onNewView(Set<Address> members) |
void |
JGroupsTransport.sendToMany(Collection<Address> targets,
ReplicableCommand command,
DeliverOrder deliverOrder) |
Constructor and Description |
---|
SuspectException(String msg,
Address suspect) |
SuspectException(String msg,
Address suspect,
Throwable cause) |
Modifier and Type | Method and Description |
---|---|
List<Address> |
BiasManager.Revocation.biased() |
List<Address> |
BiasManager.getRemoteBias(Object key) |
Modifier and Type | Method and Description |
---|---|
void |
BiasManager.renewRemoteBias(Object key,
Address origin)
Notify the component that the node is reading the biased entry and the bias
should not be revoked unless necessary.
|
void |
ScatteredStateProvider.startKeysTransfer(IntSet segments,
Address origin)
Start transferring keys and remote metadata for the given segments to the origin.
|
BiasManager.Revocation |
BiasManager.startRevokingRemoteBias(Object key,
Address newBiased)
Check if there are any nodes that have local bias, and starting replacing them
with the provided address.
|
Modifier and Type | Field and Description |
---|---|
protected Collection<Address> |
ScatteredStateConsumerImpl.backupAddress |
protected ConcurrentMap<Address,BlockingQueue<ScatteredStateConsumerImpl.KeyAndVersion>> |
ScatteredStateConsumerImpl.invalidations |
protected Collection<Address> |
ScatteredStateConsumerImpl.nonBackupAddresses |
protected ConcurrentMap<Address,BlockingQueue<Object>> |
ScatteredStateConsumerImpl.retrievedEntries |
Modifier and Type | Method and Description |
---|---|
List<Address> |
BiasManagerImpl.getRemoteBias(Object key) |
Modifier and Type | Method and Description |
---|---|
void |
BiasManagerImpl.renewRemoteBias(Object key,
Address origin) |
void |
ScatteredStateProviderImpl.startKeysTransfer(IntSet segments,
Address origin) |
BiasManager.Revocation |
BiasManagerImpl.startRevokingRemoteBias(Object key,
Address newBiased) |
Modifier and Type | Method and Description |
---|---|
Address |
GetCacheManagerAddress.run() |
Address |
GetCacheManagerCoordinatorAddress.run() |
Modifier and Type | Method and Description |
---|---|
Address |
OutboundTransferTask.getDestination() |
Address |
InboundTransferTask.getSource() |
Modifier and Type | Method and Description |
---|---|
Map<Address,Response> |
StateTransferManager.forwardCommandIfNeeded(TopologyAffectedCommand command,
Set<Object> affectedKeys,
Address origin)
If there is an state transfer happening at the moment, this method forwards the supplied
command to the nodes that are new owners of the data, in order to assure consistency.
|
Map<Address,Response> |
StateTransferManagerImpl.forwardCommandIfNeeded(TopologyAffectedCommand command,
Set<Object> affectedKeys,
Address origin) |
Modifier and Type | Method and Description |
---|---|
CompletionStage<?> |
StateConsumer.applyState(Address sender,
int topologyId,
boolean pushTransfer,
Collection<StateChunk> stateChunks) |
CompletionStage<?> |
StateConsumerImpl.applyState(Address sender,
int topologyId,
boolean pushTransfer,
Collection<StateChunk> stateChunks) |
void |
StateProvider.cancelOutboundTransfer(Address destination,
int topologyId,
IntSet segments)
Cancel sending of cache entries that belong to the given set of segments.
|
void |
StateProviderImpl.cancelOutboundTransfer(Address destination,
int topologyId,
IntSet segments) |
Map<Address,Response> |
StateTransferManager.forwardCommandIfNeeded(TopologyAffectedCommand command,
Set<Object> affectedKeys,
Address origin)
If there is an state transfer happening at the moment, this method forwards the supplied
command to the nodes that are new owners of the data, in order to assure consistency.
|
Map<Address,Response> |
StateTransferManagerImpl.forwardCommandIfNeeded(TopologyAffectedCommand command,
Set<Object> affectedKeys,
Address origin) |
CompletionStage<List<TransactionInfo>> |
StateProvider.getTransactionsForSegments(Address destination,
int topologyId,
IntSet segments)
Gets the list of transactions that affect keys from the given segments.
|
CompletionStage<List<TransactionInfo>> |
StateProviderImpl.getTransactionsForSegments(Address destination,
int requestTopologyId,
IntSet segments) |
void |
StateProvider.startOutboundTransfer(Address destination,
int topologyId,
IntSet segments,
boolean applyState)
Start to send cache entries that belong to the given set of segments.
|
void |
StateProviderImpl.startOutboundTransfer(Address destination,
int requestTopologyId,
IntSet segments,
boolean applyState) |
Constructor and Description |
---|
InboundTransferTask(IntSet segments,
Address source,
int topologyId,
RpcManager rpcManager,
CommandsFactory commandsFactory,
long timeout,
String cacheName,
boolean applyState) |
OutboundTransferTask(Address destination,
IntSet segments,
int segmentCount,
int chunkSize,
int topologyId,
KeyPartitioner keyPartitioner,
Consumer<Collection<StateChunk>> onChunkReplicated,
RpcManager rpcManager,
CommandsFactory commandsFactory,
long timeout,
String cacheName,
boolean applyState,
boolean pushTransfer) |
Modifier and Type | Field and Description |
---|---|
protected Address |
AbstractCacheStream.localAddress |
Constructor and Description |
---|
AbstractCacheStream(Address localAddress,
boolean parallel,
DistributionManager dm,
InvocationContext ctx,
Supplier<CacheStream<Original>> supplier,
boolean includeLoader,
int distributedBatchSize,
Executor executor,
ComponentRegistry registry,
Function<? super Original,?> toKeyFunction) |
DistributedCacheStream(Address localAddress,
boolean parallel,
DistributionManager dm,
InvocationContext ctx,
Supplier<CacheStream<R>> supplier,
boolean includeLoader,
int distributedBatchSize,
Executor executor,
ComponentRegistry registry,
Function<? super Original,?> toKeyFunction)
Standard constructor requiring all pertinent information to properly utilize a distributed cache stream
|
Modifier and Type | Class and Description |
---|---|
class |
PersistentUUID
PersistentUUID.
|
Modifier and Type | Method and Description |
---|---|
Address |
PersistentUUIDManager.getAddress(PersistentUUID persistentUUID)
Retrieves the
Address of a node given its PersistentUUID |
Address |
PersistentUUIDManagerImpl.getAddress(PersistentUUID persistentUUID) |
Modifier and Type | Method and Description |
---|---|
UnaryOperator<Address> |
PersistentUUIDManager.addressToPersistentUUID()
Provides a remapping operator which translates addresses to persistentuuids
|
UnaryOperator<Address> |
PersistentUUIDManagerImpl.addressToPersistentUUID() |
List<Address> |
CacheTopology.getActualMembers() |
Map<Address,Float> |
ClusterCacheStatus.getCapacityFactors() |
List<Address> |
ClusterCacheStatus.getExpectedMembers() |
List<Address> |
CacheTopology.getMembers() |
UnaryOperator<Address> |
PersistentUUIDManager.persistentUUIDToAddress()
Provides a remapping operator which translates persistentuuids to addresses
|
UnaryOperator<Address> |
PersistentUUIDManagerImpl.persistentUUIDToAddress() |
Modifier and Type | Method and Description |
---|---|
void |
PersistentUUIDManager.addPersistentAddressMapping(Address address,
PersistentUUID persistentUUID)
Adds a mapping between an
Address and a PersistentUUID |
void |
PersistentUUIDManagerImpl.addPersistentAddressMapping(Address address,
PersistentUUID persistentUUID) |
int |
PersistentUUID.compareTo(Address o) |
void |
ClusterCacheStatus.confirmRebalancePhase(Address member,
int receivedTopologyId) |
CacheStatusResponse |
ClusterCacheStatus.doJoin(Address joiner,
CacheJoinInfo joinInfo) |
CompletionStage<Void> |
ClusterCacheStatus.doLeave(Address leaver) |
PersistentUUID |
PersistentUUIDManager.getPersistentUuid(Address address)
Retrieves the
PersistentUUID of a node given its Address |
PersistentUUID |
PersistentUUIDManagerImpl.getPersistentUuid(Address address) |
CompletionStage<CacheStatusResponse> |
ClusterTopologyManager.handleJoin(String cacheName,
Address joiner,
CacheJoinInfo joinInfo,
int viewId)
Signals that a new member is joining the cache.
|
CompletionStage<CacheStatusResponse> |
ClusterTopologyManagerImpl.handleJoin(String cacheName,
Address joiner,
CacheJoinInfo joinInfo,
int joinerViewId) |
CompletionStage<Void> |
ClusterTopologyManager.handleLeave(String cacheName,
Address leaver,
int viewId)
Signals that a member is leaving the cache.
|
CompletionStage<Void> |
ClusterTopologyManagerImpl.handleLeave(String cacheName,
Address leaver,
int viewId) |
CompletionStage<Void> |
LocalTopologyManager.handleRebalance(String cacheName,
CacheTopology cacheTopology,
int viewId,
Address sender)
Performs the state transfer.
|
CompletionStage<Void> |
LocalTopologyManagerImpl.handleRebalance(String cacheName,
CacheTopology cacheTopology,
int viewId,
Address sender) |
CompletionStage<Void> |
ClusterTopologyManager.handleRebalancePhaseConfirm(String cacheName,
Address node,
int topologyId,
Throwable throwable,
int viewId)
Marks the rebalance as complete on the sender.
|
CompletionStage<Void> |
ClusterTopologyManagerImpl.handleRebalancePhaseConfirm(String cacheName,
Address node,
int topologyId,
Throwable throwable,
int viewId) |
CompletionStage<Void> |
LocalTopologyManager.handleStableTopologyUpdate(String cacheName,
CacheTopology cacheTopology,
Address sender,
int viewId)
Update the stable cache topology.
|
CompletionStage<Void> |
LocalTopologyManagerImpl.handleStableTopologyUpdate(String cacheName,
CacheTopology newStableTopology,
Address sender,
int viewId) |
CompletionStage<Void> |
LocalTopologyManager.handleTopologyUpdate(String cacheName,
CacheTopology cacheTopology,
AvailabilityMode availabilityMode,
int viewId,
Address sender)
Updates the current and/or pending consistent hash, without transferring any state.
|
CompletionStage<Void> |
LocalTopologyManagerImpl.handleTopologyUpdate(String cacheName,
CacheTopology cacheTopology,
AvailabilityMode availabilityMode,
int viewId,
Address sender) |
void |
PersistentUUIDManager.removePersistentAddressMapping(Address address)
Removes any address mapping for the specified
Address |
void |
PersistentUUIDManagerImpl.removePersistentAddressMapping(Address address) |
Modifier and Type | Method and Description |
---|---|
ConsistentHash |
ClusterCacheStatus.calculateConflictHash(ConsistentHash preferredHash,
Set<ConsistentHash> distinctHashes,
List<Address> actualMembers) |
static boolean |
ClusterTopologyManagerImpl.distLostDataCheck(ConsistentHash stableCH,
List<Address> newMembers) |
void |
ClusterCacheStatus.doMergePartitions(Map<Address,CacheStatusResponse> statusResponses) |
List<PersistentUUID> |
PersistentUUIDManager.mapAddresses(List<Address> addresses)
Returns a list of
PersistentUUID s for the supplied Address es |
List<PersistentUUID> |
PersistentUUIDManagerImpl.mapAddresses(List<Address> addresses) |
void |
ClusterCacheStatus.queueConflictResolution(CacheTopology conflictTopology,
Set<Address> preferredNodes) |
void |
ClusterCacheStatus.queueRebalance(List<Address> newMembers) |
boolean |
ClusterCacheStatus.restartConflictResolution(List<Address> members) |
static boolean |
ClusterTopologyManagerImpl.scatteredLostDataCheck(ConsistentHash stableCH,
List<Address> newMembers) |
void |
ClusterCacheStatus.updateAvailabilityMode(List<Address> actualMembers,
AvailabilityMode newAvailabilityMode,
boolean cancelRebalance) |
void |
ClusterCacheStatus.updateCurrentTopology(List<Address> newMembers) |
Constructor and Description |
---|
CacheTopology(int topologyId,
int rebalanceId,
ConsistentHash currentCH,
ConsistentHash pendingCH,
CacheTopology.Phase phase,
List<Address> actualMembers,
List<PersistentUUID> persistentUUIDs) |
CacheTopology(int topologyId,
int rebalanceId,
ConsistentHash currentCH,
ConsistentHash pendingCH,
ConsistentHash unionCH,
CacheTopology.Phase phase,
List<Address> actualMembers,
List<PersistentUUID> persistentUUIDs) |
Modifier and Type | Method and Description |
---|---|
Collection<Address> |
LocalTransaction.getCommitNodes(Collection<Address> recipients,
CacheTopology cacheTopology)
Calculates the list of nodes to which a commit/rollback needs to be sent based on the nodes to which prepare
was sent.
|
Collection<Address> |
LocalTransaction.getRemoteLocksAcquired() |
Modifier and Type | Method and Description |
---|---|
void |
TransactionTable.cleanupLeaverTransactions(List<Address> members) |
Collection<Address> |
LocalTransaction.getCommitNodes(Collection<Address> recipients,
CacheTopology cacheTopology)
Calculates the list of nodes to which a commit/rollback needs to be sent based on the nodes to which prepare
was sent.
|
boolean |
TransactionOriginatorChecker.isOriginatorMissing(GlobalTransaction gtx,
Collection<Address> liveMembers) |
boolean |
ClusteredTransactionOriginatorChecker.isOriginatorMissing(GlobalTransaction gtx,
Collection<Address> liveMembers) |
void |
LocalTransaction.locksAcquired(Collection<Address> nodes) |
Modifier and Type | Method and Description |
---|---|
Address |
GlobalTransaction.getAddress() |
Modifier and Type | Method and Description |
---|---|
GlobalTransaction |
TransactionFactory.newGlobalTransaction(Address addr,
boolean remote) |
abstract GlobalTransaction |
TransactionFactory.TxFactoryEnum.newGlobalTransaction(Address addr,
boolean remote,
VersionGenerator clusterIdGenerator,
boolean clustered) |
void |
GlobalTransaction.setAddress(Address address) |
Constructor and Description |
---|
GlobalTransaction(Address addr,
boolean remote) |
Modifier and Type | Method and Description |
---|---|
Set<Address> |
InDoubtTxInfo.getOwners() |
Modifier and Type | Method and Description |
---|---|
void |
InDoubtTxInfo.addOwner(Address owner)
Adds
owner as a node where this transaction information is maintained. |
String |
RecoveryManager.forceTransactionCompletionFromCluster(XidImpl xid,
Address where,
boolean commit)
This method invokes
RecoveryManager.forceTransactionCompletion(XidImpl, boolean) on the specified node. |
String |
RecoveryManagerImpl.forceTransactionCompletionFromCluster(XidImpl xid,
Address where,
boolean commit) |
Modifier and Type | Method and Description |
---|---|
void |
RecoveryAwareTransactionTable.cleanupLeaverTransactions(List<Address> members)
First moves the prepared transactions originated on the leavers into the recovery cache and then cleans up the
transactions that are not yet prepared.
|
void |
RecoveryAwareRemoteTransaction.computeOrphan(Collection<Address> currentMembers)
Check's if this transaction's originator is no longer part of the cluster (orphan transaction) and updates
RecoveryAwareRemoteTransaction.isOrphan() . |
CompletionStage<Void> |
RecoveryManager.removeRecoveryInformation(Collection<Address> where,
XidImpl xid,
GlobalTransaction gtx,
boolean fromCluster)
Removes from the specified nodes (or all nodes if the value of 'where' is null) the recovery information
associated with these Xids.
|
CompletionStage<Void> |
RecoveryManagerImpl.removeRecoveryInformation(Collection<Address> lockOwners,
XidImpl xid,
GlobalTransaction gtx,
boolean fromCluster) |
CompletionStage<Void> |
RecoveryManager.removeRecoveryInformationFromCluster(Collection<Address> where,
long internalId)
Same as
RecoveryManager.removeRecoveryInformation(Collection, XidImpl, GlobalTransaction, boolean)
but the transaction is identified by its internal id, and not by its xid. |
CompletionStage<Void> |
RecoveryManagerImpl.removeRecoveryInformationFromCluster(Collection<Address> where,
long internalId) |
Modifier and Type | Method and Description |
---|---|
void |
CommandAckCollector.backupAck(long id,
Address from,
int topologyId)
Acknowledges a write operation completion in the backup owner.
|
BiasedCollector |
CommandAckCollector.MultiTargetCollector.collectorFor(Address target) |
void |
CommandAckCollector.multiKeyBackupAck(long id,
Address from,
int segment,
int topologyId)
Acknowledges a
PutMapCommand completion in the backup owner. |
Modifier and Type | Method and Description |
---|---|
<T> Collector<T> |
CommandAckCollector.create(long id,
Collection<Address> backupOwners,
int topologyId)
Creates a collector for a single key write operation.
|
<T> Collector<T> |
CommandAckCollector.createSegmentBasedCollector(long id,
Map<Address,Collection<Integer>> backups,
int topologyId)
Creates a collector for
PutMapCommand . |
void |
CommandAckCollector.onMembersChange(Collection<Address> members)
Notifies a change in member list.
|
Modifier and Type | Method and Description |
---|---|
String |
Messages.enteringDegradedModeGracefulLeaver(Address leaver) |
String |
Messages_$bundle.enteringDegradedModeGracefulLeaver(Address leaver) |
String |
Messages.lostDataBecauseOfGracefulLeaver(Address leaver) |
String |
Messages_$bundle.lostDataBecauseOfGracefulLeaver(Address leaver) |
String |
Messages.nodeJoined(Address joiner) |
String |
Messages_$bundle.nodeJoined(Address joiner) |
String |
Messages.nodeLeft(Address leaver) |
String |
Messages_$bundle.nodeLeft(Address leaver) |
default EventLogger |
EventLogger.scope(Address scope)
Sets a node address as the scope of this event log
|
Modifier and Type | Method and Description |
---|---|
EventLogger |
DecoratedEventLogger.scope(Address scope) |
Modifier and Type | Method and Description |
---|---|
Map<Address,String> |
XSiteAdminOperations.nodeStatus(String site)
Obtain the status of the nodes from a site
|
Modifier and Type | Method and Description |
---|---|
void |
DefaultIracManager.requestState(Address origin,
IntSet segments) |
void |
IracManager.requestState(Address origin,
IntSet segments)
Requests the state stored in this instance for the given
segments . |
void |
NoOpIracManager.requestState(Address origin,
IntSet segments) |
void |
DefaultIracManager.sendStateIfNeeded(Address origin,
IntSet segments,
Object key,
Object lockOwner) |
Modifier and Type | Method and Description |
---|---|
boolean |
XSiteStateTransferCollector.confirmStateTransfer(Address node,
boolean statusOk) |
void |
NoOpXSiteStateTransferManager.notifyStatePushFinished(String siteName,
Address node,
boolean statusOk) |
void |
XSiteStateTransferManager.notifyStatePushFinished(String siteName,
Address node,
boolean statusOk)
It receives the notifications from local site when some node finishes pushing the state to the remote site.
|
void |
XSiteStateTransferManagerImpl.notifyStatePushFinished(String siteName,
Address node,
boolean statusOk) |
void |
XSiteStateProvider.startStateTransfer(String siteName,
Address requestor,
int minTopologyId)
It notifies this node to start sending state to the remote site.
|
void |
NoOpXSiteStateProvider.startStateTransfer(String siteName,
Address requestor,
int minTopologyId) |
void |
XSiteStateProviderImpl.startStateTransfer(String siteName,
Address origin,
int minTopologyId) |
Modifier and Type | Method and Description |
---|---|
Collection<String> |
XSiteStateProvider.getSitesMissingCoordinator(Collection<Address> currentMembers) |
Collection<String> |
NoOpXSiteStateProvider.getSitesMissingCoordinator(Collection<Address> currentMembers) |
Collection<String> |
XSiteStateProviderImpl.getSitesMissingCoordinator(Collection<Address> currentMembers) |
boolean |
XSiteStateTransferCollector.updateMembers(Collection<Address> members) |
Constructor and Description |
---|
XSiteStateTransferCollector(Collection<Address> confirmationPending) |
Modifier and Type | Method and Description |
---|---|
void |
CacheSiteStatusBuilder.addMember(Address address,
boolean online)
Adds a member with an online/offline connection to the server based on the
online parameter. |
Modifier and Type | Method and Description |
---|---|
protected SiteStatus |
CacheSiteStatusBuilder.createMixedStatus(List<Address> onlineElements,
List<Address> offlineElements) |
protected SiteStatus |
CacheSiteStatusBuilder.createMixedStatus(List<Address> onlineElements,
List<Address> offlineElements) |
Constructor and Description |
---|
CacheMixedSiteStatus(List<Address> onlineMembers,
List<Address> offlineMembers) |
CacheMixedSiteStatus(List<Address> onlineMembers,
List<Address> offlineMembers) |
Copyright © 2021 JBoss by Red Hat. All rights reserved.