Uses of Interface
org.infinispan.remoting.transport.Address
Package
Description
This package contains the
KeyAffinityService
interfaces which allow user code to determine mapping of keys onto nodesCommands that operate on the cache, either locally or remotely.
This package contains the APIs that enable users to search for, and amend, data inconsistencies within their cache.
Entries which are stored in data containers.
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.
This package contains different context implementations, selected dynamically based on the type of invocation.
Classes relating to the distributed cache mode.
Consistent Hash interfaces
Cache manager API.
Cache
-specific listener eventsCacheManager
-specific notifications and eventing.EmbeddedCacheManager
-specific listener eventsAbstractions of the different response types allowed during RPC.
Remote Procedure Call (RPC) interfaces and components used to invoke remote methods on cache instances.
Transports handle the low-level networking, used by the remoting components.
A transport implementation based on JGroups.
SCATTERED CACHE DESIGN
XA transaction support.
Thread-safe containers and other concurrency-related utilities, designed to supplement JDK concurrency utilities
and containers.
-
Uses of Address in org.infinispan.affinity
Modifier and TypeMethodDescriptionKeyAffinityService.getKeyForAddress
(Address address) Returns a key that will be distributed on the cluster node identified by address.Modifier and TypeMethodDescriptionstatic <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. -
Uses of Address in org.infinispan.affinity.impl
ModifierConstructorDescriptionKeyAffinityServiceImpl
(Executor executor, Cache<? extends K, ?> cache, KeyGenerator<? extends K> keyGenerator, int bufferSize, Collection<Address> filter, boolean start) -
Uses of Address in org.infinispan.commands
Modifier and TypeMethodDescriptionorg.infinispan.commands.write.InvalidateCommand
CommandsFactory.buildInvalidateFromL1Command
(Address origin, long flagsBitSet, Collection<Object> keys) org.infinispan.commands.write.InvalidateCommand
CommandsFactoryImpl.buildInvalidateFromL1Command
(Address origin, long flagsBitSet, Collection<Object> keys) org.infinispan.commands.remote.RevokeBiasCommand
CommandsFactory.buildRevokeBiasCommand
(Address ackTarget, long id, int topologyId, Collection<Object> keys) org.infinispan.commands.remote.RevokeBiasCommand
CommandsFactoryImpl.buildRevokeBiasCommand
(Address ackTarget, long id, int topologyId, Collection<Object> keys) static CommandInvocationId
CommandInvocationId.generateId
(Address address) default void
Sets the sender'sAddress
. -
Uses of Address in org.infinispan.conflict
Modifier and TypeMethodDescriptionConflictManager.getAllVersions
(K key) Get all CacheEntry's that exists for a given key.ConflictManager.getConflicts()
Returns a stream of conflicts detected in the cluster. -
Uses of Address in org.infinispan.container.entries
-
Uses of Address in org.infinispan.container.versioning.irac
Modifier and TypeMethodDescriptionvoid
DefaultIracTombstoneManager.sendStateTo
(Address requestor, IntSet segments) void
IracTombstoneManager.sendStateTo
(Address requestor, IntSet segments) Sends the tombstone belonging to the segments insegment
to theoriginator
void
NoOpIracTombstoneManager.sendStateTo
(Address requestor, IntSet segments) -
Uses of Address in org.infinispan.context
Modifier and TypeMethodDescriptionInvocationContextFactory.createRemoteInvocationContext
(Address origin) Returns anNonTxInvocationContext
whoseAbstractInvocationContext.isOriginLocal()
flag will be true.InvocationContextFactory.createRemoteInvocationContextForCommand
(VisitableCommand cacheCommand, Address origin) AsInvocationContextFactory.createRemoteInvocationContext(org.infinispan.remoting.transport.Address)
, but returning the flags to the context from the Command if any Flag was set.InvocationContextFactory.createRemoteTxInvocationContext
(RemoteTransaction tx, Address origin) Returns anRemoteTxInvocationContext
. -
Uses of Address in org.infinispan.context.impl
Modifier and TypeMethodDescriptionfinal Address
AbstractInvocationContext.getOrigin()
ImmutableContext.getOrigin()
SingleKeyNonTxInvocationContext.getOrigin()
Modifier and TypeMethodDescriptionfinal Collection<Address>
LocalTxInvocationContext.getRemoteLocksAcquired()
Modifier and TypeMethodDescriptionNonTransactionalInvocationContextFactory.createRemoteInvocationContext
(Address origin) TransactionalInvocationContextFactory.createRemoteInvocationContext
(Address origin) AbstractInvocationContextFactory.createRemoteInvocationContextForCommand
(VisitableCommand cacheCommand, Address origin) NonTransactionalInvocationContextFactory.createRemoteTxInvocationContext
(RemoteTransaction tx, Address origin) TransactionalInvocationContextFactory.createRemoteTxInvocationContext
(RemoteTransaction tx, Address origin) protected final NonTxInvocationContext
TransactionalInvocationContextFactory.newNonTxInvocationContext
(Address origin) Modifier and TypeMethodDescriptionfinal void
LocalTxInvocationContext.remoteLocksAcquired
(Collection<Address> nodes) ModifierConstructorDescriptionprotected
AbstractInvocationContext
(Address origin) protected
AbstractTxInvocationContext
(T cacheTransaction, Address origin) ClearInvocationContext
(Address origin) NonTxInvocationContext
(int numEntries, Address origin) NonTxInvocationContext
(Address origin) -
Uses of Address in org.infinispan.distribution
Modifier and TypeMethodDescriptionLocalizedCacheTopology.getLocalAddress()
DistributionInfo.primary()
Modifier and TypeMethodDescriptionLocalizedCacheTopology.getMembersSet()
LocalizedCacheTopology.getWriteOwners
(Object key) LocalizedCacheTopology.getWriteOwners
(Collection<?> keys) DistributionInfo.readOwners()
DistributionInfo.writeBackups()
DistributionInfo.writeOwners()
Modifier and TypeMethodDescriptionvoid
L1Manager.addRequestor
(Object key, Address requestor) Records a request that will be cached in another nodes L1L1Manager.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) ModifierConstructorDescriptionDistributionInfo
(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) ModifierConstructorDescriptionDistributionInfo
(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) -
Uses of Address in org.infinispan.distribution.ch
Modifier and TypeMethodDescriptionConsistentHash.getCapacityFactors()
The capacity factor of each member.ConsistentHash.getMembers()
Should return the addresses of the nodes used to create this consistent hash.ConsistentHash.locateOwnersForSegment
(int segmentId) Modifier and TypeMethodDescriptionConsistentHash.getPrimarySegmentsForOwner
(Address owner) Returns the segments that this cache member is the primary owner for.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 TypeMethodDescriptionConsistentHashFactory.create
(int numOwners, int numSegments, List<Address> members, Map<Address, Float> capacityFactors) Deprecated, for removal: This API element is subject to removal in a future version.Create a new consistent hash instance.ConsistentHashFactory.create
(int numOwners, int numSegments, List<Address> members, Map<Address, Float> capacityFactors) Deprecated, for removal: This API element is subject to removal in a future version.Create a new consistent hash instance.default CH
ConsistentHashFactory.create
(Hash hashFunction, int numOwners, int numSegments, List<Address> members, Map<Address, Float> capacityFactors) Deprecated, for removal: This API element is subject to removal in a future version.since 11.0.default CH
ConsistentHashFactory.create
(Hash hashFunction, int numOwners, int numSegments, List<Address> members, Map<Address, Float> capacityFactors) Deprecated, for removal: This API element is subject to removal in a future version.since 11.0.default ConsistentHash
ConsistentHash.remapAddresses
(UnaryOperator<Address> remapper) Returns a new ConsistentHash with the addresses remapped according to the providedUnaryOperator
.default ConsistentHash
ConsistentHash.remapAddressRemoveMissing
(UnaryOperator<Address> remapper) Same asConsistentHash.remapAddresses(UnaryOperator)
but skip missing members.ConsistentHashFactory.updateMembers
(CH baseCH, List<Address> newMembers, Map<Address, Float> capacityFactors) Deprecated, for removal: This API element is subject to removal in a future version.Updates an existing consistent hash instance to remove owners that are not in thenewMembers
list.ConsistentHashFactory.updateMembers
(CH baseCH, List<Address> newMembers, Map<Address, Float> capacityFactors) Deprecated, for removal: This API element is subject to removal in a future version.Updates an existing consistent hash instance to remove owners that are not in thenewMembers
list. -
Uses of Address in org.infinispan.distribution.ch.impl
Modifier and TypeFieldDescriptionAbstractConsistentHashFactory.Builder.capacityFactors
AbstractConsistentHashFactory.Builder.capacityFactors
AbstractConsistentHash.members
The membership of the cache topology that uses this CH.AbstractConsistentHashFactory.Builder.members
AbstractConsistentHashFactory.Builder.members
Modifier and TypeMethodDescriptionprotected 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) DefaultConsistentHashFactory.Builder.getPrimaryOwner
(int segment) ScatteredConsistentHashFactory.Builder.getPrimaryOwner
(int segment) DefaultConsistentHash.locatePrimaryOwnerForSegment
(int segmentId) ReplicatedConsistentHash.locatePrimaryOwnerForSegment
(int segmentId) ScatteredConsistentHash.locatePrimaryOwnerForSegment
(int segmentId) Modifier and TypeMethodDescriptionDefaultConsistentHashFactory.Builder.getBackupOwners
(int segment) AbstractConsistentHash.getCapacityFactors()
ReplicatedConsistentHash.getCapacityFactors()
AbstractConsistentHash.getMembers()
ReplicatedConsistentHash.getMembers()
DefaultConsistentHashFactory.Builder.getOwners
(int segment) DefaultConsistentHash.locateOwnersForSegment
(int segmentId) ReplicatedConsistentHash.locateOwnersForSegment
(int segmentId) ScatteredConsistentHash.locateOwnersForSegment
(int segmentId) AbstractConsistentHash.parseMembers
(ScopedPersistentState state) AbstractConsistentHash.remapCapacityFactors
(UnaryOperator<Address> remapper, boolean allowMissing) AbstractConsistentHash.remapMembers
(UnaryOperator<Address> remapper, boolean allowMissing) AbstractConsistentHash.unionCapacityFactors
(AbstractConsistentHash ch2) Modifier and TypeMethodDescriptionboolean
void
DefaultConsistentHashFactory.Builder.addPrimaryOwner
(int segment, Address newPrimaryOwner) void
ScatteredConsistentHashFactory.Builder.addPrimaryOwner
(int segment, Address newPrimaryOwner) void
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
int
int
int
DefaultConsistentHashFactory.Builder.getPrimaryOwned
(Address node) int
OwnershipStatistics.getPrimaryOwned
(Address a) int
ScatteredConsistentHashFactory.Builder.getPrimaryOwned
(Address node) DefaultConsistentHash.getPrimarySegmentsForOwner
(Address owner) ReplicatedConsistentHash.getPrimarySegmentsForOwner
(Address owner) ScatteredConsistentHash.getPrimarySegmentsForOwner
(Address owner) DefaultConsistentHash.getSegmentsForOwner
(Address owner) ReplicatedConsistentHash.getSegmentsForOwner
(Address owner) ScatteredConsistentHash.getSegmentsForOwner
(Address owner) void
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 TypeMethodDescriptionboolean
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) DefaultConsistentHashFactory.create
(int numOwners, int numSegments, List<Address> members, Map<Address, Float> capacityFactors) DefaultConsistentHashFactory.create
(int numOwners, int numSegments, List<Address> members, Map<Address, Float> capacityFactors) ReplicatedConsistentHashFactory.create
(int numOwners, int numSegments, List<Address> members, Map<Address, Float> capacityFactors) ReplicatedConsistentHashFactory.create
(int numOwners, int numSegments, List<Address> members, Map<Address, Float> capacityFactors) ScatteredConsistentHashFactory.create
(int numOwners, int numSegments, List<Address> members, Map<Address, Float> capacityFactors) ScatteredConsistentHashFactory.create
(int numOwners, int numSegments, List<Address> members, Map<Address, Float> capacityFactors) SyncConsistentHashFactory.create
(int numOwners, int numSegments, List<Address> members, Map<Address, Float> capacityFactors) SyncConsistentHashFactory.create
(int numOwners, int numSegments, List<Address> members, Map<Address, Float> capacityFactors) SyncReplicatedConsistentHashFactory.create
(int numOwners, int numSegments, List<Address> members, Map<Address, Float> capacityFactors) SyncReplicatedConsistentHashFactory.create
(int numOwners, int numSegments, List<Address> members, Map<Address, Float> capacityFactors) TopologyAwareSyncConsistentHashFactory.createBuilder
(int numOwners, int numSegments, List<Address> members, Map<Address, Float> capacityFactors) 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 fromsrc
list that do not already exist indest
list to the latter.DefaultConsistentHash.remapAddresses
(UnaryOperator<Address> remapper) ReplicatedConsistentHash.remapAddresses
(UnaryOperator<Address> remapper) ScatteredConsistentHash.remapAddresses
(UnaryOperator<Address> remapper) DefaultConsistentHash.remapAddressRemoveMissing
(UnaryOperator<Address> remapper) AbstractConsistentHash.remapCapacityFactors
(UnaryOperator<Address> remapper, boolean allowMissing) AbstractConsistentHash.remapMembers
(UnaryOperator<Address> remapper, boolean allowMissing) DefaultConsistentHashFactory.updateMembers
(DefaultConsistentHash baseCH, List<Address> actualMembers, Map<Address, Float> actualCapacityFactors) Leavers are removed and segments without owners are assigned new owners.DefaultConsistentHashFactory.updateMembers
(DefaultConsistentHash baseCH, List<Address> actualMembers, Map<Address, Float> actualCapacityFactors) Leavers are removed and segments without owners are assigned new owners.ReplicatedConsistentHashFactory.updateMembers
(ReplicatedConsistentHash baseCH, List<Address> newMembers, Map<Address, Float> actualCapacityFactors) ReplicatedConsistentHashFactory.updateMembers
(ReplicatedConsistentHash baseCH, List<Address> newMembers, Map<Address, Float> actualCapacityFactors) ScatteredConsistentHashFactory.updateMembers
(ScatteredConsistentHash baseCH, List<Address> actualMembers, Map<Address, Float> actualCapacityFactors) Leavers are removed and segments without owners are assigned new owners.ScatteredConsistentHashFactory.updateMembers
(ScatteredConsistentHash baseCH, List<Address> actualMembers, Map<Address, Float> actualCapacityFactors) Leavers are removed and segments without owners are assigned new owners.SyncConsistentHashFactory.updateMembers
(DefaultConsistentHash baseCH, List<Address> newMembers, Map<Address, Float> actualCapacityFactors) SyncConsistentHashFactory.updateMembers
(DefaultConsistentHash baseCH, List<Address> newMembers, Map<Address, Float> actualCapacityFactors) SyncReplicatedConsistentHashFactory.updateMembers
(ReplicatedConsistentHash baseCH, List<Address> newMembers, Map<Address, Float> actualCapacityFactors) SyncReplicatedConsistentHashFactory.updateMembers
(ReplicatedConsistentHash baseCH, List<Address> newMembers, Map<Address, Float> actualCapacityFactors) ModifierConstructorDescriptionScatteredConsistentHash
(int numSegments, List<Address> members, Map<Address, Float> capacityFactors, Address[] segmentOwners, boolean isRebalanced) ModifierConstructorDescriptionprotected
AbstractConsistentHash
(int numSegments, List<Address> members, float[] capacityFactors) protected
protected
Builder
(DefaultConsistentHash baseCH, List<Address> actualMembers, Map<Address, Float> actualCapacityFactors) Builder
(DefaultConsistentHash baseCH, List<Address> actualMembers, Map<Address, Float> actualCapacityFactors) Builder
(ScatteredConsistentHash baseCH, List<Address> actualMembers, Map<Address, Float> actualCapacityFactors) Builder
(ScatteredConsistentHash baseCH, List<Address> actualMembers, Map<Address, Float> actualCapacityFactors) protected
protected
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
(List<Address> nodes) OwnershipStatistics
(ConsistentHash ch, List<Address> activeNodes) ReplicatedConsistentHash
(List<Address> members, int[] primaryOwners) ReplicatedConsistentHash
(List<Address> members, Map<Address, Float> capacityFactors, List<Address> membersWithoutState, int[] primaryOwners) ReplicatedConsistentHash
(List<Address> members, Map<Address, Float> capacityFactors, List<Address> membersWithoutState, 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) -
Uses of Address in org.infinispan.distribution.impl
Modifier and TypeMethodDescriptionvoid
L1ManagerImpl.addRequestor
(Object key, Address origin) L1ManagerImpl.flushCache
(Collection<Object> keys, Address origin, boolean assumeOriginKeptEntryInL1) static LocalizedCacheTopology
DistributionManagerImpl.makeSingletonTopology
(CacheMode cacheMode, KeyPartitioner keyPartitioner, int numSegments, Address localAddress) -
Uses of Address in org.infinispan.distribution.topologyaware
Modifier and TypeMethodDescriptionTopologyInfo.getMachineNodes
(String site, String rack, String machine) TopologyInfo.getRackNodes
(String site, String rack) TopologyInfo.getSiteNodes
(String site) Modifier and TypeMethodDescriptionboolean
TopologyInfo.duplicateLocation
(TopologyLevel level, Collection<Address> addresses, Address candidate, boolean excludeCandidate) float
TopologyInfo.getExpectedOwnedSegments
(Address address) float
TopologyInfo.getExpectedPrimarySegments
(Address address) TopologyInfo.getLocationId
(TopologyLevel level, Address address) int
TopologyInfo.getMachineIndex
(Address address) int
TopologyInfo.getRackIndex
(Address address) int
TopologyInfo.getSiteIndex
(Address address) Modifier and TypeMethodDescriptionfloat
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) ModifierConstructorDescriptionTopologyInfo
(int numSegments, int numOwners, Collection<Address> members, Map<Address, Float> capacityFactors) TopologyInfo
(int numSegments, int numOwners, Collection<Address> members, Map<Address, Float> capacityFactors) -
Uses of Address in org.infinispan.extendedstats.wrappers
Modifier and TypeMethodDescriptionExtendedStatisticRpcManager.getMembers()
ExtendedStatisticRpcManager.invokeRemotelyAsync
(Collection<Address> recipients, ReplicableCommand rpc, RpcOptions options) Modifier and TypeMethodDescription<T> CompletionStage<T>
ExtendedStatisticRpcManager.invokeCommand
(Address target, ReplicableCommand command, ResponseCollector<T> collector, RpcOptions rpcOptions) void
ExtendedStatisticRpcManager.sendTo
(Address destination, ReplicableCommand command, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) Modifier and TypeMethodDescription<T> CompletionStage<T>
ExtendedStatisticRpcManager.invokeCommand
(Collection<Address> targets, ReplicableCommand command, ResponseCollector<T> collector, RpcOptions rpcOptions) <T> CompletionStage<T>
ExtendedStatisticRpcManager.invokeCommands
(Collection<Address> targets, Function<Address, ReplicableCommand> commandGenerator, ResponseCollector<T> collector, RpcOptions rpcOptions) <T> CompletionStage<T>
ExtendedStatisticRpcManager.invokeCommands
(Collection<Address> targets, Function<Address, ReplicableCommand> commandGenerator, ResponseCollector<T> collector, RpcOptions rpcOptions) <T> CompletionStage<T>
ExtendedStatisticRpcManager.invokeCommandStaggered
(Collection<Address> targets, ReplicableCommand command, ResponseCollector<T> collector, RpcOptions rpcOptions) ExtendedStatisticRpcManager.invokeRemotelyAsync
(Collection<Address> recipients, ReplicableCommand rpc, RpcOptions options) void
ExtendedStatisticRpcManager.sendToMany
(Collection<Address> destinations, ReplicableCommand command, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) -
Uses of Address in org.infinispan.manager
Modifier and TypeMethodDescriptionDefaultCacheManager.getAddress()
Warning: the address may benull
before the first clustered cache starts and after all the clustered caches have been stopped.EmbeddedCacheManager.getAddress()
Warning: the address may benull
before the first clustered cache starts and after all the clustered caches have been stopped.DefaultCacheManager.getCoordinator()
EmbeddedCacheManager.getCoordinator()
Modifier and TypeMethodDescriptionDefaultCacheManager.getMembers()
EmbeddedCacheManager.getMembers()
Modifier and TypeMethodDescriptionClusterExecutor.filterTargets
(Collection<Address> addresses) Allows for filtering of address nodes by only allowing addresses in this collection from being contacted.ClusterExecutor.filterTargets
(Predicate<? super Address> predicate) Allows for filtering of address nodes dynamically per invocation.ClusterExecutor.filterTargets
(ClusterExecutionPolicy policy, 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 asClusterExecutor.submitConsumer(Function, TriConsumer)
, except the Callable must also implement Serializable. -
Uses of Address in org.infinispan.manager.impl
Modifier and TypeMethodDescriptionAbstractDelegatingEmbeddedCacheManager.getAddress()
AbstractDelegatingEmbeddedCacheManager.getCoordinator()
Modifier and TypeMethodDescriptionstatic 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) -
Uses of Address in org.infinispan.notifications.cachelistener.cluster
Modifier and TypeMethodDescriptionvoid
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.ModifierConstructorDescriptionClusterListenerReplicateCallable
(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) -
Uses of Address in org.infinispan.notifications.cachelistener.cluster.impl
Modifier and TypeFieldDescriptionprotected final Map<Address,
org.infinispan.notifications.cachelistener.cluster.impl.BatchingClusterEventManagerImpl.TargetEvents<K, V>> BatchingClusterEventManagerImpl.UnicastEventContext.targets
Modifier and TypeMethodDescriptionvoid
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) -
Uses of Address in org.infinispan.notifications.cachelistener.event
Modifier and TypeMethodDescriptionDataRehashedEvent.getMembersAtEnd()
DataRehashedEvent.getMembersAtStart()
-
Uses of Address in org.infinispan.notifications.cachelistener.event.impl
-
Uses of Address in org.infinispan.notifications.cachemanagerlistener
Modifier and TypeMethodDescriptionCacheManagerNotifier.notifyMerge
(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId, List<List<Address>> subgroupsMerged) CacheManagerNotifierImpl.notifyMerge
(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId, List<List<Address>> subgroupsMerged) CacheManagerNotifier.notifyViewChange
(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId) Notifies all registered listeners of a viewChange event.CacheManagerNotifierImpl.notifyViewChange
(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId) Modifier and TypeMethodDescriptionCacheManagerNotifier.notifyMerge
(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId, List<List<Address>> subgroupsMerged) CacheManagerNotifierImpl.notifyMerge
(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId, List<List<Address>> subgroupsMerged) CacheManagerNotifier.notifyViewChange
(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId) Notifies all registered listeners of a viewChange event.CacheManagerNotifierImpl.notifyViewChange
(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId) -
Uses of Address in org.infinispan.notifications.cachemanagerlistener.event
Modifier and TypeMethodDescriptionViewChangedEvent.getNewMembers()
Gets the current list of members.ViewChangedEvent.getOldMembers()
Gets the previous list of members.MergeEvent.getSubgroupsMerged()
-
Uses of Address in org.infinispan.notifications.cachemanagerlistener.event.impl
Modifier and TypeMethodDescriptionEventImpl.getNewMembers()
EventImpl.getOldMembers()
EventImpl.getSubgroupsMerged()
Modifier and TypeMethodDescriptionvoid
EventImpl.setNewMembers
(List<Address> newMembers) void
EventImpl.setOldMembers
(List<Address> oldMembers) void
EventImpl.setSubgroupsMerged
(List<List<Address>> subgroupsMerged) ModifierConstructorDescriptionEventImpl
(String cacheName, EmbeddedCacheManager cacheManager, Event.Type type, List<Address> newMemberList, List<Address> oldMemberList, Address localAddress, int viewId) ModifierConstructorDescriptionEventImpl
(String cacheName, EmbeddedCacheManager cacheManager, Event.Type type, List<Address> newMemberList, List<Address> oldMemberList, Address localAddress, int viewId) -
Uses of Address in org.infinispan.partitionhandling.impl
Modifier and TypeMethodDescriptionAvailabilityStrategyContext.getCapacityFactors()
AvailabilityStrategyContext.getExpectedMembers()
The members of the cache.Modifier and TypeMethodDescriptionvoid
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 TypeMethodDescriptionboolean
AvailablePartitionHandlingManager.addPartialCommit1PCTransaction
(GlobalTransaction globalTransaction, Collection<Address> affectedNodes, Collection<Object> lockedKeys, List<org.infinispan.commands.write.WriteCommand> modifications) boolean
PartitionHandlingManager.addPartialCommit1PCTransaction
(GlobalTransaction globalTransaction, Collection<Address> affectedNodes, Collection<Object> lockedKeys, List<org.infinispan.commands.write.WriteCommand> modifications) Adds a partially committed transaction.boolean
PartitionHandlingManagerImpl.addPartialCommit1PCTransaction
(GlobalTransaction globalTransaction, Collection<Address> affectedNodes, Collection<Object> lockedKeys, List<org.infinispan.commands.write.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) AvailabilityStrategyContext.calculateConflictHash
(ConsistentHash preferredHash, Set<ConsistentHash> distinctHashes, List<Address> actualMembers) 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) void
AvailabilityStrategyContext.manuallyUpdateAvailabilityMode
(List<Address> actualMembers, AvailabilityMode mode, boolean cancelRebalance) Enter a new availability mode manually.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 {@link 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 topologyvoid
AvailabilityStrategyContext.updateAvailabilityMode
(List<Address> actualMembers, AvailabilityMode mode, boolean cancelRebalance) Enter a new availability mode.void
AvailabilityStrategyContext.updateCurrentTopology
(List<Address> newMembers) Use the configuredConsistentHashFactory
to create a new CH with the givenmembers
, but do not start a rebalance. -
Uses of Address in org.infinispan.reactive.publisher.impl
ModifierConstructorDescriptionInnerPublisherSubscriptionBuilder
(ClusterPublisherManagerImpl<K, ?>.org.infinispan.reactive.publisher.impl.ClusterPublisherManagerImpl.SubscriberHandler<I, R> parent, int batchSize, Supplier<Map.Entry<Address, IntSet>> supplier, Map<Address, Set<K>> excludedKeys, int topologyId) InnerPublisherSubscriptionBuilder
(ClusterPublisherManagerImpl<K, ?>.org.infinispan.reactive.publisher.impl.ClusterPublisherManagerImpl.SubscriberHandler<I, R> parent, int batchSize, Supplier<Map.Entry<Address, IntSet>> supplier, Map<Address, Set<K>> excludedKeys, int topologyId) -
Uses of Address in org.infinispan.remoting.responses
Modifier and TypeMethodDescriptionboolean
ClusteredGetResponseValidityFilter.isAcceptable
(Response response, Address address) boolean
IgnoreExtraResponsesValidityFilter.isAcceptable
(Response response, Address address) ModifierConstructorDescriptionBiasRevocationResponse
(Object responseValue, Address[] waitFor) ClusteredGetResponseValidityFilter
(Collection<Address> targets, Address self) IgnoreExtraResponsesValidityFilter
(Collection<Address> targets, Address self, boolean removeSelf) ModifierConstructorDescriptionClusteredGetResponseValidityFilter
(Collection<Address> targets, Address self) IgnoreExtraResponsesValidityFilter
(Collection<Address> targets, Address self, boolean removeSelf) -
Uses of Address in org.infinispan.remoting.rpc
Modifier and TypeMethodDescriptionRpcManager.getAddress()
Returns the address associated with this RpcManager or null if not part of the cluster.RpcManagerImpl.getAddress()
Modifier and TypeMethodDescriptionRpcManager.getMembers()
Returns members of a cluster scoped to the cache owning this RpcManager.RpcManagerImpl.getMembers()
default CompletableFuture<Map<Address,
Response>> RpcManager.invokeRemotelyAsync
(Collection<Address> recipients, ReplicableCommand rpc, RpcOptions options) Deprecated, for removal: This API element is subject to removal in a future version.RpcManagerImpl.invokeRemotelyAsync
(Collection<Address> recipients, ReplicableCommand rpc, RpcOptions options) Modifier and TypeMethodDescription<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 aResponseCollector
.<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 requestvoid
RpcManager.sendTo
(Address destination, ReplicableCommand command, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) Asynchronously sends theReplicableCommand
to the destination using the specifiedDeliverOrder
.void
RpcManagerImpl.sendTo
(Address destination, ReplicableCommand command, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) Modifier and TypeMethodDescription<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 aResponseCollector
.<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 aResponseCollector
.<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 aResponseCollector
.<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 aResponseCollector
.<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, for removal: This API element is subject to removal in a future version.RpcManagerImpl.invokeRemotelyAsync
(Collection<Address> recipients, ReplicableCommand rpc, RpcOptions options) void
RpcManager.sendToMany
(Collection<Address> destinations, ReplicableCommand command, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) Asynchronously sends theReplicableCommand
to the set of destination using the specifiedDeliverOrder
.void
RpcManagerImpl.sendToMany
(Collection<Address> destinations, ReplicableCommand command, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) -
Uses of Address in org.infinispan.remoting.transport
Modifier and TypeInterfaceDescriptioninterface
Wraps a TopologyUUID JGroups addressModifier and TypeClassDescriptionclass
Represents the local node's address.class
ImplementationAddress
that contains the site name.Modifier and TypeFieldDescriptionstatic final Address[]
Address.EMPTY_ARRAY
static final Address
LocalModeAddress.INSTANCE
Modifier and TypeMethodDescriptionAbstractDelegatingTransport.getAddress()
Transport.getAddress()
Retrieves the current cache instance's network addressAbstractDelegatingTransport.getCoordinator()
Transport.getCoordinator()
Modifier and TypeMethodDescriptionAbstractDelegatingTransport.getMembers()
Transport.getMembers()
Returns a list of members in the current cluster view.AbstractDelegatingTransport.getMembersPhysicalAddresses()
Transport.getMembersPhysicalAddresses()
Returns physical addresses of members in the current cluster view.AbstractDelegatingTransport.getPhysicalAddresses()
Transport.getPhysicalAddresses()
Retrieves the current cache instance's physical network addresses.AbstractDelegatingTransport.getRelayNodesAddress()
Transport.getRelayNodesAddress()
AbstractDelegatingTransport.invokeRemotely
(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, ResponseFilter responseFilter, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, boolean anycast) Deprecated, for removal: This API element is subject to removal in a future version.AbstractDelegatingTransport.invokeRemotely
(Map<Address, ReplicableCommand> rpcCommands, ResponseMode mode, long timeout, boolean usePriorityQueue, ResponseFilter responseFilter, boolean totalOrder, boolean anycast) Deprecated, for removal: This API element is subject to removal in a future version.AbstractDelegatingTransport.invokeRemotely
(Map<Address, ReplicableCommand> rpcCommands, ResponseMode mode, long timeout, ResponseFilter responseFilter, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, boolean anycast) Deprecated, for removal: This API element is subject to removal in a future version.Transport.invokeRemotely
(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, ResponseFilter responseFilter, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, boolean anycast) Deprecated, for removal: This API element is subject to removal in a future version.Since 9.2, please useTransport.invokeCommand(Collection, ReplicableCommand, ResponseCollector, DeliverOrder, long, TimeUnit)
instead.Transport.invokeRemotely
(Map<Address, ReplicableCommand> rpcCommands, ResponseMode mode, long timeout, boolean usePriorityQueue, ResponseFilter responseFilter, boolean totalOrder, boolean anycast) Deprecated, for removal: This API element is subject to removal in a future version.Transport.invokeRemotely
(Map<Address, ReplicableCommand> rpcCommands, ResponseMode mode, long timeout, ResponseFilter responseFilter, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, boolean anycast) Deprecated, for removal: This API element is subject to removal in a future version.Since 9.2, please useTransport.invokeRemotelyAsync(Collection, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder, boolean)
instead.AbstractDelegatingTransport.invokeRemotelyAsync
(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, ResponseFilter responseFilter, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, boolean anycast) Transport.invokeRemotelyAsync
(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, ResponseFilter responseFilter, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, boolean anycast) Modifier and TypeMethodDescriptionprotected abstract T
ValidResponseCollector.addException
(Address sender, Exception exception) Process an exception from a target.ResponseCollector.addResponse
(Address sender, Response response) Called when a response is received, or when a target node becomes unavailable.final T
ValidResponseCollector.addResponse
(Address sender, Response response) final T
ValidSingleResponseCollector.addResponse
(Address sender, Response response) 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.AbstractTransport.checkResponse
(Object responseObject, Address sender, boolean ignoreCacheNotFoundResponse) Deprecated, for removal: This API element is subject to removal in a future version.int
int
<T> CompletionStage<T>
AbstractDelegatingTransport.invokeCommand
(Address target, ReplicableCommand command, ResponseCollector<T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) default <T> CompletionStage<T>
Transport.invokeCommand
(Address target, ReplicableCommand command, ResponseCollector<T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) Invoke a command on a single node and pass the response to aResponseCollector
.static SuspectException
ResponseCollectors.remoteNodeSuspected
(Address sender) void
AbstractDelegatingTransport.sendTo
(Address destination, ReplicableCommand rpcCommand, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) void
Transport.sendTo
(Address destination, ReplicableCommand rpcCommand, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) Asynchronously sends theReplicableCommand
to the destination using the specifiedDeliverOrder
.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 TypeMethodDescription<T> CompletionStage<T>
AbstractDelegatingTransport.invokeCommand
(Collection<Address> targets, ReplicableCommand command, ResponseCollector<T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) default <T> CompletionStage<T>
Transport.invokeCommand
(Collection<Address> targets, ReplicableCommand command, ResponseCollector<T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) Invoke a command on a collection of node and pass the responses to aResponseCollector
.default <T> CompletionStage<T>
Transport.invokeCommandOnAll
(Collection<Address> requiredTargets, ReplicableCommand command, ResponseCollector<T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) Invoke a command on all the nodes in the cluster and pass the responses to aResponseCollector
.<T> CompletionStage<T>
AbstractDelegatingTransport.invokeCommands
(Collection<Address> targets, Function<Address, ReplicableCommand> commandGenerator, ResponseCollector<T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit timeUnit) <T> CompletionStage<T>
AbstractDelegatingTransport.invokeCommands
(Collection<Address> targets, Function<Address, ReplicableCommand> commandGenerator, ResponseCollector<T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit timeUnit) default <T> CompletionStage<T>
Transport.invokeCommands
(Collection<Address> targets, Function<Address, ReplicableCommand> commandGenerator, ResponseCollector<T> responseCollector, long timeout, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) Deprecated, for removal: This API element is subject to removal in a future version.Introduced in 9.1, but replaced in 9.2 withTransport.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, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) Deprecated, for removal: This API element is subject to removal in a future version.Introduced in 9.1, but replaced in 9.2 withTransport.invokeCommands(Collection, Function, ResponseCollector, DeliverOrder, long, TimeUnit)
.default <T> CompletionStage<T>
Transport.invokeCommands
(Collection<Address> targets, Function<Address, ReplicableCommand> commandGenerator, ResponseCollector<T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit timeUnit) Invoke different commands on a collection of nodes and pass the responses to aResponseCollector
.default <T> CompletionStage<T>
Transport.invokeCommands
(Collection<Address> targets, Function<Address, ReplicableCommand> commandGenerator, ResponseCollector<T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit timeUnit) Invoke different commands on a collection of nodes and pass the responses to aResponseCollector
.<T> CompletionStage<T>
AbstractDelegatingTransport.invokeCommandStaggered
(Collection<Address> targets, ReplicableCommand command, ResponseCollector<T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) default <T> CompletionStage<T>
Transport.invokeCommandStaggered
(Collection<Address> targets, ReplicableCommand command, ResponseCollector<T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) Invoke a command on a collection of nodes and pass the responses to aResponseCollector
.AbstractDelegatingTransport.invokeRemotely
(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, ResponseFilter responseFilter, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, boolean anycast) Deprecated, for removal: This API element is subject to removal in a future version.AbstractDelegatingTransport.invokeRemotely
(Map<Address, ReplicableCommand> rpcCommands, ResponseMode mode, long timeout, boolean usePriorityQueue, ResponseFilter responseFilter, boolean totalOrder, boolean anycast) Deprecated, for removal: This API element is subject to removal in a future version.AbstractDelegatingTransport.invokeRemotely
(Map<Address, ReplicableCommand> rpcCommands, ResponseMode mode, long timeout, ResponseFilter responseFilter, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, boolean anycast) Deprecated, for removal: This API element is subject to removal in a future version.Transport.invokeRemotely
(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, ResponseFilter responseFilter, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, boolean anycast) Deprecated, for removal: This API element is subject to removal in a future version.Since 9.2, please useTransport.invokeCommand(Collection, ReplicableCommand, ResponseCollector, DeliverOrder, long, TimeUnit)
instead.Transport.invokeRemotely
(Map<Address, ReplicableCommand> rpcCommands, ResponseMode mode, long timeout, boolean usePriorityQueue, ResponseFilter responseFilter, boolean totalOrder, boolean anycast) Deprecated, for removal: This API element is subject to removal in a future version.Transport.invokeRemotely
(Map<Address, ReplicableCommand> rpcCommands, ResponseMode mode, long timeout, ResponseFilter responseFilter, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, boolean anycast) Deprecated, for removal: This API element is subject to removal in a future version.Since 9.2, please useTransport.invokeRemotelyAsync(Collection, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder, boolean)
instead.AbstractDelegatingTransport.invokeRemotelyAsync
(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, ResponseFilter responseFilter, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, boolean anycast) Transport.invokeRemotelyAsync
(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, ResponseFilter responseFilter, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, boolean anycast) void
AbstractDelegatingTransport.sendToMany
(Collection<Address> destinations, ReplicableCommand rpcCommand, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) void
Transport.sendToMany
(Collection<Address> destinations, ReplicableCommand rpcCommand, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) Asynchronously sends theReplicableCommand
to the set of destination using the specifiedDeliverOrder
. -
Uses of Address in org.infinispan.remoting.transport.impl
Modifier and TypeMethodDescriptionFilterMapResponseCollector.addException
(Address sender, Exception exception) MapResponseCollector.addException
(Address sender, Exception exception) PassthroughMapResponseCollector.addResponse
(Address sender, Response response) FilterMapResponseCollector.addTargetNotFound
(Address sender) FilterMapResponseCollector.addValidResponse
(Address sender, ValidResponse response) MapResponseCollector.addValidResponse
(Address sender, ValidResponse response) FilterMapResponseCollector.finish()
MapResponseCollector.finish()
PassthroughMapResponseCollector.finish()
SingletonMapResponseCollector.targetNotFound
(Address sender) SingletonMapResponseCollector.withValidResponse
(Address sender, ValidResponse response) Modifier and TypeMethodDescriptionFilterMapResponseCollector.addException
(Address sender, Exception exception) MapResponseCollector.addException
(Address sender, Exception exception) protected Void
VoidResponseCollector.addException
(Address sender, Exception exception) PassthroughMapResponseCollector.addResponse
(Address sender, Response response) PassthroughSingleResponseCollector.addResponse
(Address sender, Response response) void
RequestRepository.addResponse
(long requestId, Address sender, Response response) FilterMapResponseCollector.addTargetNotFound
(Address sender) protected Void
VoidResponseCollector.addTargetNotFound
(Address sender) FilterMapResponseCollector.addValidResponse
(Address sender, ValidResponse response) MapResponseCollector.addValidResponse
(Address sender, ValidResponse response) protected Void
VoidResponseCollector.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) SingletonMapResponseCollector.targetNotFound
(Address sender) protected ValidResponse
SingleResponseCollector.withValidResponse
(Address sender, ValidResponse response) SingletonMapResponseCollector.withValidResponse
(Address sender, ValidResponse response) Modifier and TypeMethodDescriptionboolean
boolean
Called when the node received a new cluster view.boolean
ModifierConstructorDescriptionMultiTargetRequest
(ResponseCollector<T> responseCollector, long requestId, RequestRepository repository, Collection<Address> targets, Address excluded, JGroupsMetricsManager metricsCollector) ModifierConstructorDescriptionMultiTargetRequest
(ResponseCollector<T> responseCollector, long requestId, RequestRepository repository, Collection<Address> targets, Address excluded, JGroupsMetricsManager metricsCollector) -
Uses of Address in org.infinispan.remoting.transport.jgroups
Modifier and TypeClassDescriptionclass
An encapsulation of a JGroups Addressclass
An encapsulation of a JGroupsExtendedUUID
with a site id, a rack id, and a machine id.Modifier and TypeFieldDescriptionprotected Address
JGroupsTransport.address
protected Address
JGroupsTransport.physicalAddress
Modifier and TypeMethodDescriptionRequestTracker.destination()
static Address
JGroupsAddressCache.fromJGroupsAddress
(org.jgroups.Address jgroupsAddress) JGroupsTransport.getAddress()
ClusterView.getCoordinator()
JGroupsTransport.getCoordinator()
SuspectException.getSuspect()
Modifier and TypeMethodDescriptionClusterView.getMembers()
JGroupsTransport.getMembers()
JGroupsTransport.getMembersPhysicalAddresses()
ClusterView.getMembersSet()
JGroupsTransport.getPhysicalAddresses()
JGroupsTransport.getRelayNodesAddress()
JGroupsTransport.invokeRemotely
(Map<Address, ReplicableCommand> commands, ResponseMode mode, long timeout, ResponseFilter responseFilter, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, boolean anycast) Deprecated, for removal: This API element is subject to removal in a future version.JGroupsTransport.invokeRemotelyAsync
(Collection<Address> recipients, ReplicableCommand command, ResponseMode mode, long timeout, ResponseFilter responseFilter, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, boolean anycast) Modifier and TypeMethodDescriptionint
<T> CompletionStage<T>
JGroupsTransport.invokeCommand
(Address target, ReplicableCommand command, ResponseCollector<T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) void
SingleSiteRequest.onResponse
(Address sender, Response response) void
StaggeredRequest.onResponse
(Address sender, Response response) void
JGroupsMetricsManager.recordMessageSent
(Address destination, int bytesSent, boolean async) Records a message sent to adestination
.void
JGroupsMetricsManagerImpl.recordMessageSent
(Address destination, int bytesSent, boolean async) void
NoOpJGroupsMetricManager.recordMessageSent
(Address destination, int bytesSent, boolean async) void
JGroupsTransport.sendTo
(Address destination, ReplicableCommand command, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) JGroupsMetricsManager.trackRequest
(Address destination) Track the latency for a synchronous request.JGroupsMetricsManagerImpl.trackRequest
(Address destination) NoOpJGroupsMetricManager.trackRequest
(Address destination) Modifier and TypeMethodDescription<T> CompletionStage<T>
JGroupsTransport.invokeCommand
(Collection<Address> targets, ReplicableCommand command, ResponseCollector<T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) <T> CompletionStage<T>
JGroupsTransport.invokeCommandOnAll
(Collection<Address> requiredTargets, ReplicableCommand command, ResponseCollector<T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) <T> CompletionStage<T>
JGroupsTransport.invokeCommands
(Collection<Address> targets, Function<Address, ReplicableCommand> commandGenerator, ResponseCollector<T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit timeUnit) <T> CompletionStage<T>
JGroupsTransport.invokeCommands
(Collection<Address> targets, Function<Address, ReplicableCommand> commandGenerator, ResponseCollector<T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit timeUnit) <T> CompletionStage<T>
JGroupsTransport.invokeCommandStaggered
(Collection<Address> targets, ReplicableCommand command, ResponseCollector<T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) JGroupsTransport.invokeRemotely
(Map<Address, ReplicableCommand> commands, ResponseMode mode, long timeout, ResponseFilter responseFilter, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, boolean anycast) Deprecated, for removal: This API element is subject to removal in a future version.JGroupsTransport.invokeRemotelyAsync
(Collection<Address> recipients, ReplicableCommand command, ResponseMode mode, long timeout, ResponseFilter responseFilter, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, boolean anycast) boolean
void
JGroupsTransport.sendToMany
(Collection<Address> targets, ReplicableCommand command, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) ModifierConstructorDescriptionSuspectException
(String msg, Address suspect) SuspectException
(String msg, Address suspect, Throwable cause) -
Uses of Address in org.infinispan.scattered
Modifier and TypeMethodDescriptionBiasManager.Revocation.biased()
BiasManager.getRemoteBias
(Object key) Modifier and TypeMethodDescriptionvoid
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.startRevokingRemoteBias
(Object key, Address newBiased) Check if there are any nodes that have local bias, and starting replacing them with the provided address. -
Uses of Address in org.infinispan.scattered.impl
Modifier and TypeFieldDescriptionprotected Collection<Address>
ScatteredStateConsumerImpl.backupAddress
protected final ConcurrentMap<Address,
BlockingQueue<ScatteredStateConsumerImpl.KeyAndVersion>> ScatteredStateConsumerImpl.invalidations
protected Collection<Address>
ScatteredStateConsumerImpl.nonBackupAddresses
protected final ConcurrentMap<Address,
BlockingQueue<Object>> ScatteredStateConsumerImpl.retrievedEntries
Modifier and TypeMethodDescriptionvoid
BiasManagerImpl.renewRemoteBias
(Object key, Address origin) void
ScatteredStateProviderImpl.startKeysTransfer
(IntSet segments, Address origin) BiasManagerImpl.startRevokingRemoteBias
(Object key, Address newBiased) -
Uses of Address in org.infinispan.security.actions
-
Uses of Address in org.infinispan.server.hotrod
-
Uses of Address in org.infinispan.server.hotrod.tx
Modifier and TypeMethodDescriptionboolean
ServerTransactionOriginatorChecker.isOriginatorMissing
(GlobalTransaction gtx, Collection<Address> liveMembers) -
Uses of Address in org.infinispan.server.hotrod.tx.table
ModifierConstructorDescriptionClientAddress
(Address localAddress) PerCacheTxTable
(Address address) -
Uses of Address in org.infinispan.stream.impl
ModifierConstructorDescriptionprotected
AbstractCacheStream
(Address localAddress, boolean parallel, InvocationContext ctx, long explicitFlags, int distributedBatchSize, Executor executor, ComponentRegistry registry, Function<? super Original, ?> toKeyFunction, ClusterPublisherManager<?, ?> clusterPublisherManager) DistributedCacheStream
(Address localAddress, boolean parallel, InvocationContext ctx, long explicitFlags, int distributedBatchSize, Executor executor, ComponentRegistry registry, Function<? super Original, ?> toKeyFunction, ClusterPublisherManager<?, ?> clusterPublisherManager) Standard constructor requiring all pertinent information to properly utilize a distributed cache stream -
Uses of Address in org.infinispan.topology
Modifier and TypeMethodDescriptionPersistentUUIDManager.getAddress
(PersistentUUID persistentUUID) Retrieves theAddress
of a node given itsPersistentUUID
PersistentUUIDManagerImpl.getAddress
(PersistentUUID persistentUUID) Modifier and TypeMethodDescriptionPersistentUUIDManager.addressToPersistentUUID()
Provides a remapping operator which translates addresses to persistentuuidsPersistentUUIDManagerImpl.addressToPersistentUUID()
ClusterTopologyManager.currentJoiners
(String cacheName) Returns the list of nodes that joined the cache with the givencacheName
if the current node is the coordinator.ClusterTopologyManagerImpl.currentJoiners
(String cacheName) CacheTopology.getActualMembers()
ClusterCacheStatus.getCapacityFactors()
ClusterCacheStatus.getExpectedMembers()
CacheTopology.getMembers()
CacheStatusResponse.joinedMembers()
PersistentUUIDManager.persistentUUIDToAddress()
Provides a remapping operator which translates persistentuuids to addressesPersistentUUIDManagerImpl.persistentUUIDToAddress()
Modifier and TypeMethodDescriptionvoid
PersistentUUIDManager.addPersistentAddressMapping
(Address address, PersistentUUID persistentUUID) Adds a mapping between anAddress
and aPersistentUUID
void
PersistentUUIDManagerImpl.addPersistentAddressMapping
(Address address, PersistentUUID persistentUUID) int
void
ClusterCacheStatus.confirmRebalancePhase
(Address member, int receivedTopologyId) ClusterCacheStatus.doJoin
(Address joiner, CacheJoinInfo joinInfo) PersistentUUIDManager.getPersistentUuid
(Address address) Retrieves thePersistentUUID
of a node given itsAddress
PersistentUUIDManagerImpl.getPersistentUuid
(Address address) ClusterTopologyManager.handleJoin
(String cacheName, Address joiner, CacheJoinInfo joinInfo, int viewId) Signals that a new member is joining the cache.ClusterTopologyManagerImpl.handleJoin
(String cacheName, Address joiner, CacheJoinInfo joinInfo, int joinerViewId) ClusterTopologyManager.handleLeave
(String cacheName, Address leaver, int viewId) Signals that a member is leaving the cache.ClusterTopologyManagerImpl.handleLeave
(String cacheName, Address leaver, int viewId) LocalTopologyManager.handleRebalance
(String cacheName, CacheTopology cacheTopology, int viewId, Address sender) Performs the state transfer.LocalTopologyManagerImpl.handleRebalance
(String cacheName, CacheTopology cacheTopology, int viewId, Address sender) ClusterTopologyManager.handleRebalancePhaseConfirm
(String cacheName, Address node, int topologyId, Throwable throwable, int viewId) Marks the rebalance as complete on the sender.ClusterTopologyManagerImpl.handleRebalancePhaseConfirm
(String cacheName, Address node, int topologyId, Throwable throwable, int viewId) LocalTopologyManager.handleStableTopologyUpdate
(String cacheName, CacheTopology cacheTopology, Address sender, int viewId) Update the stable cache topology.LocalTopologyManagerImpl.handleStableTopologyUpdate
(String cacheName, CacheTopology newStableTopology, Address sender, int viewId) LocalTopologyManager.handleTopologyUpdate
(String cacheName, CacheTopology cacheTopology, AvailabilityMode availabilityMode, int viewId, Address sender) Updates the current and/or pending consistent hash, without transferring any state.LocalTopologyManagerImpl.handleTopologyUpdate
(String cacheName, CacheTopology cacheTopology, AvailabilityMode availabilityMode, int viewId, Address sender) void
PersistentUUIDManager.removePersistentAddressMapping
(Address address) Removes any address mapping for the specifiedAddress
void
PersistentUUIDManagerImpl.removePersistentAddressMapping
(Address address) Modifier and TypeMethodDescriptionClusterCacheStatus.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) void
ClusterCacheStatus.manuallyUpdateAvailabilityMode
(List<Address> actualMembers, AvailabilityMode mode, boolean cancelRebalance) PersistentUUIDManager.mapAddresses
(List<Address> addresses) Returns a list ofPersistentUUID
s for the suppliedAddress
esPersistentUUIDManagerImpl.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) ModifierConstructorDescriptionCacheStatusResponse
(CacheJoinInfo cacheJoinInfo, CacheTopology cacheTopology, CacheTopology stableTopology, AvailabilityMode availabilityMode, List<Address> current) CacheTopology
(int topologyId, int rebalanceId, boolean restoredTopology, ConsistentHash currentCH, ConsistentHash pendingCH, ConsistentHash unionCH, CacheTopology.Phase phase, List<Address> actualMembers, List<PersistentUUID> persistentUUIDs) CacheTopology
(int topologyId, int rebalanceId, boolean restoredTopology, 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) CacheTopology
(int topologyId, int rebalanceId, ConsistentHash currentCH, ConsistentHash pendingCH, CacheTopology.Phase phase, List<Address> actualMembers, List<PersistentUUID> persistentUUIDs) -
Uses of Address in org.infinispan.transaction.impl
Modifier and TypeMethodDescriptionLocalTransaction.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.LocalTransaction.getRemoteLocksAcquired()
Modifier and TypeMethodDescriptionvoid
TransactionTable.cleanupLeaverTransactions
(List<Address> members) 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
ClusteredTransactionOriginatorChecker.isOriginatorMissing
(GlobalTransaction gtx, Collection<Address> liveMembers) boolean
TransactionOriginatorChecker.isOriginatorMissing
(GlobalTransaction gtx, Collection<Address> liveMembers) void
LocalTransaction.locksAcquired
(Collection<Address> nodes) -
Uses of Address in org.infinispan.transaction.xa
Modifier and TypeMethodDescriptionTransactionFactory.newGlobalTransaction
(Address addr, boolean remote) abstract GlobalTransaction
TransactionFactory.TxFactoryEnum.newGlobalTransaction
(Address addr, boolean remote, VersionGenerator clusterIdGenerator, boolean clustered) void
GlobalTransaction.setAddress
(Address address) -
Uses of Address in org.infinispan.transaction.xa.recovery
Modifier and TypeMethodDescriptionvoid
Addsowner
as a node where this transaction information is maintained.RecoveryManager.forceTransactionCompletionFromCluster
(XidImpl xid, Address where, boolean commit) This method invokesRecoveryManager.forceTransactionCompletion(XidImpl, boolean)
on the specified node.RecoveryManagerImpl.forceTransactionCompletionFromCluster
(XidImpl xid, Address where, boolean commit) Modifier and TypeMethodDescriptionvoid
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 updatesRecoveryAwareRemoteTransaction.isOrphan()
.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.RecoveryManagerImpl.removeRecoveryInformation
(Collection<Address> lockOwners, XidImpl xid, GlobalTransaction gtx, boolean fromCluster) RecoveryManager.removeRecoveryInformationFromCluster
(Collection<Address> where, long internalId) Same asRecoveryManager.removeRecoveryInformation(Collection, XidImpl, GlobalTransaction, boolean)
but the transaction is identified by its internal id, and not by its xid.RecoveryManagerImpl.removeRecoveryInformationFromCluster
(Collection<Address> where, long internalId) -
Uses of Address in org.infinispan.util.concurrent
Modifier and TypeMethodDescriptionvoid
Acknowledges a write operation completion in the backup owner.org.infinispan.interceptors.distribution.BiasedCollector
CommandAckCollector.MultiTargetCollector.collectorFor
(Address target) void
CommandAckCollector.multiKeyBackupAck
(long id, Address from, int segment, int topologyId) Acknowledges aPutMapCommand
completion in the backup owner.Modifier and TypeMethodDescription<T> org.infinispan.interceptors.distribution.Collector<T>
CommandAckCollector.create
(long id, Collection<Address> backupOwners, int topologyId) Creates a collector for a single key write operation.<T> org.infinispan.interceptors.distribution.Collector<T>
CommandAckCollector.createSegmentBasedCollector
(long id, Map<Address, Collection<Integer>> backups, int topologyId) Creates a collector forPutMapCommand
.void
CommandAckCollector.onMembersChange
(Collection<Address> members) Notifies a change in member list. -
Uses of Address in org.infinispan.xsite.irac
Modifier and TypeMethodDescriptionvoid
DefaultIracManager.requestState
(Address requestor, IntSet segments) void
IracManager.requestState
(Address requestor, IntSet segments) Requests the state stored in this instance for the givensegments
.void
NoOpIracManager.requestState
(Address requestor, IntSet segments) -
Uses of Address in org.infinispan.xsite.response
Modifier and TypeMethodDescriptionAutoStateTransferResponseCollector.addResponse
(Address sender, Response response) -
Uses of Address in org.infinispan.xsite.statetransfer
Modifier and TypeMethodDescriptionboolean
RemoteSiteStatus.confirmStateTransfer
(Address node, boolean statusOk) boolean
XSiteStateTransferCollector.confirmStateTransfer
(Address node, boolean statusOk) BaseXSiteStateProviderState.createPushTask
(Address originator, XSiteStateProvider provider) XSiteStateProviderState.createPushTask
(Address originator, XSiteStateProvider provider) Creates a newXSiteStatePushTask
to do state transfer to remove site.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
NoOpXSiteStateProvider.notifyStateTransferEnd
(String siteName, Address origin, boolean statusOk) void
XSiteStateProvider.notifyStateTransferEnd
(String siteName, Address origin, boolean statusOk) NotifiesXSiteStatePushTask
has completed the send.void
XSiteStateProviderImpl.notifyStateTransferEnd
(String siteName, Address origin, boolean statusOk) void
NoOpXSiteStateProvider.startStateTransfer
(String siteName, Address requestor, int minTopologyId) void
XSiteStateProvider.startStateTransfer
(String siteName, Address requestor, int minTopologyId) It notifies this node to start sending state to the remote site.void
XSiteStateProviderImpl.startStateTransfer
(String siteName, Address origin, int minTopologyId) Modifier and TypeMethodDescriptionNoOpXSiteStateProvider.getSitesMissingCoordinator
(Collection<Address> currentMembers) XSiteStateProvider.getSitesMissingCoordinator
(Collection<Address> currentMembers) XSiteStateProviderImpl.getSitesMissingCoordinator
(Collection<Address> currentMembers) boolean
BaseXSiteStateProviderState.isOriginatorMissing
(Collection<Address> members) boolean
XSiteStateProviderState.isOriginatorMissing
(Collection<Address> members) Returnsboolean
RemoteSiteStatus.restartStateTransfer
(Collection<Address> newMembers) boolean
RemoteSiteStatus.startStateTransfer
(Collection<Address> members) boolean
XSiteStateTransferCollector.updateMembers
(Collection<Address> members) ModifierConstructorDescriptionXSiteStateTransferCollector
(Collection<Address> confirmationPending) -
Uses of Address in org.infinispan.xsite.status
Modifier and TypeMethodDescriptionvoid
Adds a member with an online/offline connection to the server based on theonline
parameter.Modifier and TypeMethodDescriptionprotected SiteStatus
CacheSiteStatusBuilder.createMixedStatus
(List<Address> onlineElements, List<Address> offlineElements) ModifierConstructorDescriptionCacheMixedSiteStatus
(List<Address> onlineMembers, List<Address> offlineMembers)