Uses of Class
org.infinispan.remoting.transport.Address
Packages that use 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 eventsEmbeddedCacheManager-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.
XA transaction support.
Thread-safe containers and other concurrency-related utilities, designed to supplement JDK concurrency utilities
and containers.
Infinispan's logging abstractions that delegate to either JDK or Log4J logging engines.
-
Uses of Address in org.infinispan.affinity
Methods in org.infinispan.affinity with parameters of type AddressModifier and TypeMethodDescriptionKeyAffinityService.getKeyForAddress(Address address) Returns a key that will be distributed on the cluster node identified by address.Method parameters in org.infinispan.affinity with type arguments of type AddressModifier 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
Methods in org.infinispan.affinity.impl that return types with arguments of type AddressModifier and TypeMethodDescriptionMap<Address, BlockingQueue<K>> KeyAffinityServiceImpl.getAddress2KeysMapping()Methods in org.infinispan.affinity.impl with parameters of type AddressConstructor parameters in org.infinispan.affinity.impl with type arguments of type AddressModifierConstructorDescriptionKeyAffinityServiceImpl(Executor executor, Cache<? extends K, ?> cache, KeyGenerator<? extends K> keyGenerator, int bufferSize, Collection<Address> filter, boolean start) -
Uses of Address in org.infinispan.commands
Fields in org.infinispan.commands declared as AddressMethods in org.infinispan.commands that return AddressModifier and TypeMethodDescriptionCommandInvocationId.getAddress()AbstractFlagAffectedCommand.getOrigin()RequestUUID.toAddress()Returns anAddressrepresenting the origin of this request within the cluster.Methods in org.infinispan.commands with parameters of type AddressModifier and TypeMethodDescriptionorg.infinispan.commands.write.InvalidateCommandCommandsFactory.buildInvalidateFromL1Command(Address origin, long flagsBitSet, Collection<Object> keys) org.infinispan.commands.write.InvalidateCommandCommandsFactoryImpl.buildInvalidateFromL1Command(Address origin, long flagsBitSet, Collection<Object> keys) static CommandInvocationIdCommandInvocationId.generateId(Address address) static RequestUUIDCreates aRequestUUIDfor the specified nodeAddressand request ID.voiddefault voidSets the sender'sAddress. -
Uses of Address in org.infinispan.conflict
Methods in org.infinispan.conflict that return types with arguments of type AddressModifier 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
Methods in org.infinispan.container.entries that return AddressConstructors in org.infinispan.container.entries with parameters of type Address -
Uses of Address in org.infinispan.container.versioning.irac
Methods in org.infinispan.container.versioning.irac with parameters of type AddressModifier and TypeMethodDescriptionvoidDefaultIracTombstoneManager.sendStateTo(Address requestor, IntSet segments) voidIracTombstoneManager.sendStateTo(Address requestor, IntSet segments) Sends the tombstone belonging to the segments insegmentto theoriginatorvoidNoOpIracTombstoneManager.sendStateTo(Address requestor, IntSet segments) -
Uses of Address in org.infinispan.context
Methods in org.infinispan.context that return AddressMethods in org.infinispan.context with parameters of type AddressModifier and TypeMethodDescriptionInvocationContextFactory.createRemoteInvocationContext(Address origin) Returns anNonTxInvocationContextwhoseAbstractInvocationContext.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
Methods in org.infinispan.context.impl that return AddressModifier and TypeMethodDescriptionfinal AddressAbstractInvocationContext.getOrigin()ImmutableContext.getOrigin()SingleKeyNonTxInvocationContext.getOrigin()Methods in org.infinispan.context.impl that return types with arguments of type AddressModifier and TypeMethodDescriptionfinal Collection<Address> LocalTxInvocationContext.getRemoteLocksAcquired()Methods in org.infinispan.context.impl with parameters of type AddressModifier 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 NonTxInvocationContextTransactionalInvocationContextFactory.newNonTxInvocationContext(Address origin) Method parameters in org.infinispan.context.impl with type arguments of type AddressModifier and TypeMethodDescriptionfinal voidLocalTxInvocationContext.remoteLocksAcquired(Collection<Address> nodes) Constructors in org.infinispan.context.impl with parameters of type AddressModifierConstructorDescriptionprotectedAbstractInvocationContext(Address origin) protectedAbstractTxInvocationContext(T cacheTransaction, Address origin) ClearInvocationContext(Address origin) NonTxInvocationContext(int numEntries, Address origin) NonTxInvocationContext(Address origin) -
Uses of Address in org.infinispan.distribution
Methods in org.infinispan.distribution that return AddressModifier and TypeMethodDescriptionLocalizedCacheTopology.getLocalAddress()DistributionInfo.primary()Methods in org.infinispan.distribution that return types with arguments of type AddressModifier and TypeMethodDescriptionLocalizedCacheTopology.getMembersSet()LocalizedCacheTopology.getWriteOwners(Object key) LocalizedCacheTopology.getWriteOwners(Collection<?> keys) DistributionInfo.readOwners()DistributionInfo.writeBackups()DistributionInfo.writeOwners()Methods in org.infinispan.distribution with parameters of type AddressModifier and TypeMethodDescriptionvoidL1Manager.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 LocalizedCacheTopologyLocalizedCacheTopology.makeSegmentedSingletonTopology(KeyPartitioner keyPartitioner, int numSegments, Address localAddress) Creates a new local topology that has a single address but multiple segments.static LocalizedCacheTopologyLocalizedCacheTopology.makeSingletonTopology(CacheMode cacheMode, Address localAddress) Constructors in org.infinispan.distribution with parameters of type AddressModifierConstructorDescriptionDistributionInfo(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 parameters in org.infinispan.distribution with type arguments of type AddressModifierConstructorDescriptionDistributionInfo(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
Methods in org.infinispan.distribution.ch that return AddressMethods in org.infinispan.distribution.ch that return types with arguments of type AddressModifier 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) Methods in org.infinispan.distribution.ch with parameters of type AddressModifier 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 booleanConsistentHash.isSegmentLocalToNode(Address nodeAddress, int segmentId) Check if a segment is local to a given member.Method parameters in org.infinispan.distribution.ch with type arguments of type AddressModifier and TypeMethodDescriptiondefault voidConsistentHash.toScopedState(ScopedPersistentState state, Function<Address, UUID> addressMapper) Writes thisConsistentHashto the specified scoped persistent state. -
Uses of Address in org.infinispan.distribution.ch.impl
Fields in org.infinispan.distribution.ch.impl with type parameters of type AddressModifier and TypeFieldDescriptionAbstractConsistentHashFactory.Builder.capacityFactorsAbstractConsistentHash.membersThe membership of the cache topology that uses this CH.AbstractConsistentHashFactory.Builder.membersMethods in org.infinispan.distribution.ch.impl that return AddressModifier and TypeMethodDescriptionprotected AddressDefaultConsistentHashFactory.findNewBackupOwner(DefaultConsistentHashFactory.Builder builder, Collection<Address> excludes, Address owner) protected AddressAbstractConsistentHashFactory.findNewPrimaryOwner(org.infinispan.distribution.ch.impl.AbstractConsistentHashFactory.Builder builder, Collection<Address> candidates, Address primaryOwner) protected AddressAbstractConsistentHashFactory.findWorstPrimaryOwner(org.infinispan.distribution.ch.impl.AbstractConsistentHashFactory.Builder builder, List<Address> nodes) DefaultConsistentHashFactory.Builder.getPrimaryOwner(int segment) DefaultConsistentHash.locatePrimaryOwnerForSegment(int segmentId) ReplicatedConsistentHash.locatePrimaryOwnerForSegment(int segmentId) Methods in org.infinispan.distribution.ch.impl that return types with arguments of type AddressModifier and TypeMethodDescriptionDefaultConsistentHashFactory.Builder.getBackupOwners(int segment) AbstractConsistentHash.getCapacityFactors()ReplicatedConsistentHash.getCapacityFactors()AbstractConsistentHash.getMemberIndexMap(List<Address> members) AbstractConsistentHash.getMembers()ReplicatedConsistentHash.getMembers()DefaultConsistentHashFactory.Builder.getOwners(int segment) DefaultConsistentHash.locateOwnersForSegment(int segmentId) ReplicatedConsistentHash.locateOwnersForSegment(int segmentId) AbstractConsistentHash.unionCapacityFactors(AbstractConsistentHash ch2) Methods in org.infinispan.distribution.ch.impl with parameters of type AddressModifier and TypeMethodDescriptionbooleanvoidDefaultConsistentHashFactory.Builder.addPrimaryOwner(int segment, Address newPrimaryOwner) voidvoidOwnershipStatistics.decPrimaryOwned(Address a) protected AddressDefaultConsistentHashFactory.findNewBackupOwner(DefaultConsistentHashFactory.Builder builder, Collection<Address> excludes, Address owner) protected AddressAbstractConsistentHashFactory.findNewPrimaryOwner(org.infinispan.distribution.ch.impl.AbstractConsistentHashFactory.Builder builder, Collection<Address> candidates, Address primaryOwner) intintintDefaultConsistentHashFactory.Builder.getPrimaryOwned(Address node) intOwnershipStatistics.getPrimaryOwned(Address a) DefaultConsistentHash.getPrimarySegmentsForOwner(Address owner) ReplicatedConsistentHash.getPrimarySegmentsForOwner(Address owner) DefaultConsistentHash.getSegmentsForOwner(Address owner) ReplicatedConsistentHash.getSegmentsForOwner(Address owner) voidvoidOwnershipStatistics.incPrimaryOwned(Address a) booleanDefaultConsistentHash.isSegmentLocalToNode(Address nodeAddress, int segmentId) booleanReplicatedConsistentHash.isSegmentLocalToNode(Address nodeAddress, int segmentId) booleanDefaultConsistentHashFactory.Builder.removeOwner(int segment, Address owner) voidDefaultConsistentHashFactory.Builder.replacePrimaryOwnerWithBackup(int segment, Address newPrimaryOwner) Method parameters in org.infinispan.distribution.ch.impl with type arguments of type AddressModifier and TypeMethodDescriptionbooleanDefaultConsistentHashFactory.Builder.addOwners(int segment, Collection<Address> newOwners) protected voidAbstractConsistentHashFactory.checkCapacityFactors(List<Address> members, Map<Address, Float> capacityFactors) protected voidAbstractConsistentHashFactory.checkCapacityFactors(List<Address> members, Map<Address, Float> capacityFactors) intDefaultConsistentHashFactory.Builder.computeActualNumOwners(int numOwners, List<Address> members, Map<Address, Float> capacityFactors) intDefaultConsistentHashFactory.Builder.computeActualNumOwners(int numOwners, List<Address> members, Map<Address, Float> capacityFactors) ConsistentHashFactory.create(int numOwners, int numSegments, List<Address> members, Map<Address, Float> capacityFactors) Create a new consistent hash instance.ConsistentHashFactory.create(int numOwners, int numSegments, List<Address> members, Map<Address, Float> capacityFactors) Create a new consistent hash instance.static DefaultConsistentHashDefaultConsistentHash.create(int numOwners, int numSegments, List<Address> members, Map<Address, Float> capacityFactors, List<Address>[] segmentOwners) static DefaultConsistentHashDefaultConsistentHash.create(int numOwners, int numSegments, List<Address> members, Map<Address, Float> capacityFactors, List<Address>[] segmentOwners) 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) 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 AddressDefaultConsistentHashFactory.findNewBackupOwner(DefaultConsistentHashFactory.Builder builder, Collection<Address> excludes, Address owner) protected AddressAbstractConsistentHashFactory.findNewPrimaryOwner(org.infinispan.distribution.ch.impl.AbstractConsistentHashFactory.Builder builder, Collection<Address> candidates, Address primaryOwner) protected AddressAbstractConsistentHashFactory.findWorstPrimaryOwner(org.infinispan.distribution.ch.impl.AbstractConsistentHashFactory.Builder builder, List<Address> nodes) default PersistedConsistentHash<CH> ConsistentHashFactory.fromPersistentState(ScopedPersistentState state, Function<UUID, Address> addressMapper) Recreates aConsistentHashfrom a previously stored persistent state.DefaultConsistentHashFactory.fromPersistentState(ScopedPersistentState state, Function<UUID, Address> addressMapper) ReplicatedConsistentHashFactory.fromPersistentState(ScopedPersistentState state, Function<UUID, Address> addressMapper) SyncConsistentHashFactory.fromPersistentState(ScopedPersistentState state, Function<UUID, Address> addressMapper) SyncReplicatedConsistentHashFactory.fromPersistentState(ScopedPersistentState state, Function<UUID, Address> addressMapper) AbstractConsistentHash.getMemberIndexMap(List<Address> members) protected static voidAbstractConsistentHash.mergeLists(List<Address> dest, List<Address> src) Adds all elements fromsrclist that do not already exist indestlist to the latter.protected static org.infinispan.distribution.ch.impl.PersistedMembersAbstractConsistentHash.parseMembers(ScopedPersistentState state, Function<UUID, Address> addressMapper) voidAbstractConsistentHash.toScopedState(ScopedPersistentState state, Function<Address, UUID> addressMapper) voidDefaultConsistentHash.toScopedState(ScopedPersistentState state, Function<Address, UUID> addressMapper) voidReplicatedConsistentHash.toScopedState(ScopedPersistentState state, Function<Address, UUID> addressMapper) ConsistentHashFactory.updateMembers(CH baseCH, List<Address> newMembers, Map<Address, Float> capacityFactors) Updates an existing consistent hash instance to remove owners that are not in thenewMemberslist.ConsistentHashFactory.updateMembers(CH baseCH, List<Address> newMembers, Map<Address, Float> capacityFactors) Updates an existing consistent hash instance to remove owners that are not in thenewMemberslist.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) 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) protected static voidAbstractConsistentHash.writeAddressToState(ScopedPersistentState state, List<Address> members, String sizeKey, String memberKeyFormat, Function<Address, UUID> addressMapper) protected static voidAbstractConsistentHash.writeAddressToState(ScopedPersistentState state, List<Address> members, String sizeKey, String memberKeyFormat, Function<Address, UUID> addressMapper) Constructor parameters in org.infinispan.distribution.ch.impl with type arguments of type AddressModifierConstructorDescriptionprotectedAbstractConsistentHash(int numSegments, List<Address> members, List<Float> capacityFactors) protectedprotectedBuilder(DefaultConsistentHash baseCH, List<Address> actualMembers, Map<Address, Float> actualCapacityFactors) Builder(DefaultConsistentHash baseCH, List<Address> actualMembers, Map<Address, Float> actualCapacityFactors) protectedprotectedOwnershipStatistics(List<Address> nodes) OwnershipStatistics(ConsistentHash ch, List<Address> activeNodes) ReplicatedConsistentHash(List<Address> members, List<Integer> primaryOwners) ReplicatedConsistentHash(List<Address> members, Map<Address, Float> capacityFactors, List<Address> membersWithoutState, List<Integer> primaryOwners) ReplicatedConsistentHash(List<Address> members, Map<Address, Float> capacityFactors, List<Address> membersWithoutState, List<Integer> primaryOwners) -
Uses of Address in org.infinispan.distribution.impl
Methods in org.infinispan.distribution.impl with parameters of type AddressModifier and TypeMethodDescriptionvoidL1ManagerImpl.addRequestor(Object key, Address origin) L1ManagerImpl.flushCache(Collection<Object> keys, Address origin, boolean assumeOriginKeptEntryInL1) static LocalizedCacheTopologyDistributionManagerImpl.makeSingletonTopology(CacheMode cacheMode, KeyPartitioner keyPartitioner, int numSegments, Address localAddress) -
Uses of Address in org.infinispan.distribution.topologyaware
Methods in org.infinispan.distribution.topologyaware that return types with arguments of type AddressModifier and TypeMethodDescriptionTopologyInfo.getMachineNodes(String site, String rack, String machine) TopologyInfo.getRackNodes(String site, String rack) TopologyInfo.getSiteNodes(String site) Methods in org.infinispan.distribution.topologyaware with parameters of type AddressModifier and TypeMethodDescriptionbooleanTopologyInfo.duplicateLocation(TopologyLevel level, Collection<Address> addresses, Address candidate, boolean excludeCandidate) floatTopologyInfo.getExpectedOwnedSegments(Address address) floatTopologyInfo.getExpectedPrimarySegments(Address address) TopologyInfo.getLocationId(TopologyLevel level, Address address) intTopologyInfo.getMachineIndex(Address address) intTopologyInfo.getRackIndex(Address address) intTopologyInfo.getSiteIndex(Address address) Method parameters in org.infinispan.distribution.topologyaware with type arguments of type AddressModifier and TypeMethodDescriptionfloatTopologyInfo.computeTotalCapacity(Collection<Address> nodes, Map<Address, Float> capacityFactors) floatTopologyInfo.computeTotalCapacity(Collection<Address> nodes, Map<Address, Float> capacityFactors) booleanTopologyInfo.duplicateLocation(TopologyLevel level, Collection<Address> addresses, Address candidate, boolean excludeCandidate) intTopologyInfo.getDistinctLocationsCount(TopologyLevel level, Collection<Address> addresses) Constructor parameters in org.infinispan.distribution.topologyaware with type arguments of type AddressModifierConstructorDescriptionTopologyInfo(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.manager
Methods in org.infinispan.manager that return AddressModifier and TypeMethodDescriptionDefaultCacheManager.getAddress()Warning: the address may benullbefore the first clustered cache starts and after all the clustered caches have been stopped.EmbeddedCacheManager.getAddress()Warning: the address may benullbefore the first clustered cache starts and after all the clustered caches have been stopped.DefaultCacheManager.getCoordinator()EmbeddedCacheManager.getCoordinator()Methods in org.infinispan.manager that return types with arguments of type AddressModifier and TypeMethodDescriptionDefaultCacheManager.getMembers()EmbeddedCacheManager.getMembers()Methods in org.infinispan.manager with parameters of type AddressModifier and TypeMethodDescriptionabstract booleanMethod parameters in org.infinispan.manager with type arguments of type AddressModifier 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
Methods in org.infinispan.manager.impl that return AddressModifier and TypeMethodDescriptionAbstractDelegatingEmbeddedCacheManager.getAddress()AbstractDelegatingEmbeddedCacheManager.getCoordinator()Methods in org.infinispan.manager.impl that return types with arguments of type AddressMethod parameters in org.infinispan.manager.impl with type arguments of type AddressModifier and TypeMethodDescriptionstatic ClusterExecutorClusterExecutors.allSubmissionExecutor(Predicate<? super Address> predicate, EmbeddedCacheManager manager, Transport transport, long time, TimeUnit unit, BlockingManager bm, ScheduledExecutorService timeoutExecutor) static ClusterExecutorClusterExecutors.singleNodeSubmissionExecutor(Predicate<? super Address> predicate, EmbeddedCacheManager manager, Transport transport, long time, TimeUnit unit, BlockingManager bm, ScheduledExecutorService timeoutExecutor, int failOverCount) -
Uses of Address in org.infinispan.notifications.cachelistener.cluster
Methods in org.infinispan.notifications.cachelistener.cluster that return AddressMethods in org.infinispan.notifications.cachelistener.cluster with parameters of type AddressModifier and TypeMethodDescriptionvoidClusterEventManager.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.Constructors in org.infinispan.notifications.cachelistener.cluster with parameters of type AddressModifierConstructorDescriptionClusterListenerReplicateCallable(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
Fields in org.infinispan.notifications.cachelistener.cluster.impl with type parameters of type AddressModifier and TypeFieldDescriptionprotected final Map<Address, org.infinispan.notifications.cachelistener.cluster.impl.BatchingClusterEventManagerImpl.TargetEvents<K, V>> BatchingClusterEventManagerImpl.UnicastEventContext.targetsMethods in org.infinispan.notifications.cachelistener.cluster.impl with parameters of type AddressModifier and TypeMethodDescriptionvoidBatchingClusterEventManagerImpl.addEvents(Object batchIdentifier, Address target, UUID identifier, Collection<ClusterEvent<K, V>> events, boolean sync) voidClusterEventManagerStub.addEvents(Object batchIdentifier, Address target, UUID identifier, Collection<ClusterEvent<K, V>> clusterEvents, boolean sync) voidBatchingClusterEventManagerImpl.UnicastEventContext.addTargets(Address address, UUID identifier, Collection<ClusterEvent<K, V>> events, boolean sync) -
Uses of Address in org.infinispan.notifications.cachelistener.event
Methods in org.infinispan.notifications.cachelistener.event that return types with arguments of type AddressModifier and TypeMethodDescriptionDataRehashedEvent.getMembersAtEnd()DataRehashedEvent.getMembersAtStart() -
Uses of Address in org.infinispan.notifications.cachelistener.event.impl
Methods in org.infinispan.notifications.cachelistener.event.impl that return types with arguments of type Address -
Uses of Address in org.infinispan.notifications.cachemanagerlistener
Methods in org.infinispan.notifications.cachemanagerlistener with parameters of type AddressModifier 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) Method parameters in org.infinispan.notifications.cachemanagerlistener with type arguments of type AddressModifier 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
Methods in org.infinispan.notifications.cachemanagerlistener.event that return AddressMethods in org.infinispan.notifications.cachemanagerlistener.event that return types with arguments of type AddressModifier 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
Methods in org.infinispan.notifications.cachemanagerlistener.event.impl that return AddressMethods in org.infinispan.notifications.cachemanagerlistener.event.impl that return types with arguments of type AddressModifier and TypeMethodDescriptionEventImpl.getNewMembers()EventImpl.getOldMembers()EventImpl.getSubgroupsMerged()Methods in org.infinispan.notifications.cachemanagerlistener.event.impl with parameters of type AddressMethod parameters in org.infinispan.notifications.cachemanagerlistener.event.impl with type arguments of type AddressModifier and TypeMethodDescriptionvoidEventImpl.setNewMembers(List<Address> newMembers) voidEventImpl.setOldMembers(List<Address> oldMembers) voidEventImpl.setSubgroupsMerged(List<List<Address>> subgroupsMerged) Constructors in org.infinispan.notifications.cachemanagerlistener.event.impl with parameters of type AddressModifierConstructorDescriptionEventImpl(String cacheName, EmbeddedCacheManager cacheManager, Event.Type type, List<Address> newMemberList, List<Address> oldMemberList, Address localAddress, int viewId) Constructor parameters in org.infinispan.notifications.cachemanagerlistener.event.impl with type arguments of type AddressModifierConstructorDescriptionEventImpl(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
Methods in org.infinispan.partitionhandling.impl that return types with arguments of type AddressModifier and TypeMethodDescriptionAvailabilityStrategyContext.getCapacityFactors()AvailabilityStrategyContext.getExpectedMembers()The members of the cache.Methods in org.infinispan.partitionhandling.impl with parameters of type AddressModifier and TypeMethodDescriptionvoidAvailabilityStrategy.onGracefulLeave(AvailabilityStrategyContext context, Address leaver) Called when a node leaves gracefully.voidPreferAvailabilityStrategy.onGracefulLeave(AvailabilityStrategyContext context, Address leaver) voidPreferConsistencyStrategy.onGracefulLeave(AvailabilityStrategyContext context, Address leaver) voidAvailabilityStrategy.onJoin(AvailabilityStrategyContext context, Address joiner) Called when a node joins.voidPreferAvailabilityStrategy.onJoin(AvailabilityStrategyContext context, Address joiner) voidPreferConsistencyStrategy.onJoin(AvailabilityStrategyContext context, Address joiner) Method parameters in org.infinispan.partitionhandling.impl with type arguments of type AddressModifier and TypeMethodDescriptionbooleanAvailablePartitionHandlingManager.addPartialCommit1PCTransaction(GlobalTransaction globalTransaction, Collection<Address> affectedNodes, Collection<Object> lockedKeys, List<org.infinispan.commands.write.WriteCommand> modifications) booleanPartitionHandlingManager.addPartialCommit1PCTransaction(GlobalTransaction globalTransaction, Collection<Address> affectedNodes, Collection<Object> lockedKeys, List<org.infinispan.commands.write.WriteCommand> modifications) Adds a partially committed transaction.booleanPartitionHandlingManagerImpl.addPartialCommit1PCTransaction(GlobalTransaction globalTransaction, Collection<Address> affectedNodes, Collection<Object> lockedKeys, List<org.infinispan.commands.write.WriteCommand> modifications) booleanAvailablePartitionHandlingManager.addPartialCommit2PCTransaction(GlobalTransaction globalTransaction, Collection<Address> affectedNodes, Collection<Object> lockedKeys, Map<Object, IncrementableEntryVersion> newVersions) booleanPartitionHandlingManager.addPartialCommit2PCTransaction(GlobalTransaction globalTransaction, Collection<Address> affectedNodes, Collection<Object> lockedKeys, Map<Object, IncrementableEntryVersion> newVersions) Adds a partially committed transaction.booleanPartitionHandlingManagerImpl.addPartialCommit2PCTransaction(GlobalTransaction globalTransaction, Collection<Address> affectedNodes, Collection<Object> lockedKeys, Map<Object, IncrementableEntryVersion> newVersions) booleanAvailablePartitionHandlingManager.addPartialRollbackTransaction(GlobalTransaction globalTransaction, Collection<Address> affectedNodes, Collection<Object> lockedKeys) booleanPartitionHandlingManager.addPartialRollbackTransaction(GlobalTransaction globalTransaction, Collection<Address> affectedNodes, Collection<Object> lockedKeys) Adds a partially aborted transaction.booleanPartitionHandlingManagerImpl.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.static booleanAvailabilityStrategy.isDataLost(ConsistentHash consistentHash, Collection<Address> members) Checks that all segments have, at least, one owner online to ensure data availability.static <T> booleanAvailabilityStrategy.isDataLost(ConsistentHash consistentHash, Collection<T> members, Function<Address, T> addressMapper) Checks that all segments have, at least, one owner online to ensure data availability.voidAvailabilityStrategyContext.manuallyUpdateAvailabilityMode(List<Address> actualMembers, AvailabilityMode mode, boolean cancelRebalance) Enter a new availability mode manually.voidAvailabilityStrategy.onClusterViewChange(AvailabilityStrategyContext context, List<Address> clusterMembers) Called when the cluster view changed (e.g. because one or more nodes left abruptly).voidPreferAvailabilityStrategy.onClusterViewChange(AvailabilityStrategyContext context, List<Address> clusterMembers) voidPreferConsistencyStrategy.onClusterViewChange(AvailabilityStrategyContext context, List<Address> clusterMembers) voidAvailabilityStrategy.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.voidPreferAvailabilityStrategy.onPartitionMerge(AvailabilityStrategyContext context, Map<Address, CacheStatusResponse> statusResponseMap) voidPreferConsistencyStrategy.onPartitionMerge(AvailabilityStrategyContext context, Map<Address, CacheStatusResponse> statusResponseMap) voidAvailabilityStrategyContext.queueConflictResolution(CacheTopology conflictTopology, Set<Address> preferredNodes) Initiates conflict resolution using the conflictTopology, which should have already been broadcast viaAvailabilityStrategyContext.updateTopologiesAfterMerge(CacheTopology, CacheTopology, AvailabilityMode)voidAvailabilityStrategyContext.queueRebalance(List<Address> newMembers) Queue (or start) a rebalance.booleanAvailabilityStrategyContext.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 topologyvoidAvailabilityStrategyContext.updateAvailabilityMode(List<Address> actualMembers, AvailabilityMode mode, boolean cancelRebalance) Enter a new availability mode.voidAvailabilityStrategyContext.updateCurrentTopology(List<Address> newMembers) Use the configuredConsistentHashFactoryto create a new CH with the givenmembers, but do not start a rebalance. -
Uses of Address in org.infinispan.reactive.publisher.impl
Constructor parameters in org.infinispan.reactive.publisher.impl with type arguments of type AddressModifierConstructorDescriptionInnerPublisherSubscriptionBuilder(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
Methods in org.infinispan.remoting.responses with parameters of type AddressModifier and TypeMethodDescriptionbooleanClusteredGetResponseValidityFilter.isAcceptable(Response response, Address address) booleanIgnoreExtraResponsesValidityFilter.isAcceptable(Response response, Address address) Constructors in org.infinispan.remoting.responses with parameters of type AddressModifierConstructorDescriptionClusteredGetResponseValidityFilter(Collection<Address> targets, Address self) IgnoreExtraResponsesValidityFilter(Collection<Address> targets, Address self, boolean removeSelf) Constructor parameters in org.infinispan.remoting.responses with type arguments of type AddressModifierConstructorDescriptionClusteredGetResponseValidityFilter(Collection<Address> targets, Address self) IgnoreExtraResponsesValidityFilter(Collection<Address> targets, Address self, boolean removeSelf) -
Uses of Address in org.infinispan.remoting.rpc
Methods in org.infinispan.remoting.rpc that return AddressModifier and TypeMethodDescriptionRpcManager.getAddress()Returns the address associated with this RpcManager or null if not part of the cluster.RpcManagerImpl.getAddress()Methods in org.infinispan.remoting.rpc that return types with arguments of type AddressModifier and TypeMethodDescriptionRpcManager.getMembers()Returns members of a cluster scoped to the cache owning this RpcManager.RpcManagerImpl.getMembers()Methods in org.infinispan.remoting.rpc with parameters of type AddressModifier and TypeMethodDescription<T> CompletionStage<T> RpcManager.invokeCommand(Address target, org.infinispan.commands.remote.CacheRpcCommand command, ResponseCollector<Address, T> collector, RpcOptions rpcOptions) Invoke a command on a single node and pass the response to aResponseCollector.<T> CompletionStage<T> RpcManagerImpl.invokeCommand(Address target, org.infinispan.commands.remote.CacheRpcCommand command, ResponseCollector<Address, T> collector, RpcOptions rpcOptions) booleanResponseFilter.isAcceptable(Response response, Address sender) Determines whether a response from a given sender should be added to the response list of the requestvoidRpcManager.sendTo(Address destination, org.infinispan.commands.remote.CacheRpcCommand command, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) Asynchronously sends theReplicableCommandto the destination using the specifiedDeliverOrder.voidRpcManagerImpl.sendTo(Address destination, org.infinispan.commands.remote.CacheRpcCommand command, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) Method parameters in org.infinispan.remoting.rpc with type arguments of type AddressModifier and TypeMethodDescription<T> CompletionStage<T> RpcManager.invokeCommand(Collection<Address> targets, org.infinispan.commands.remote.CacheRpcCommand command, ResponseCollector<Address, T> collector, RpcOptions rpcOptions) Invoke a command on a collection of node and pass the responses to aResponseCollector.<T> CompletionStage<T> RpcManager.invokeCommand(Collection<Address> targets, org.infinispan.commands.remote.CacheRpcCommand command, ResponseCollector<Address, T> collector, RpcOptions rpcOptions) Invoke a command on a collection of node and pass the responses to aResponseCollector.<T> CompletionStage<T> RpcManager.invokeCommand(Address target, org.infinispan.commands.remote.CacheRpcCommand command, ResponseCollector<Address, T> collector, RpcOptions rpcOptions) Invoke a command on a single node and pass the response to aResponseCollector.<T> CompletionStage<T> RpcManagerImpl.invokeCommand(Collection<Address> targets, org.infinispan.commands.remote.CacheRpcCommand command, ResponseCollector<Address, T> collector, RpcOptions rpcOptions) <T> CompletionStage<T> RpcManagerImpl.invokeCommand(Collection<Address> targets, org.infinispan.commands.remote.CacheRpcCommand command, ResponseCollector<Address, T> collector, RpcOptions rpcOptions) <T> CompletionStage<T> RpcManagerImpl.invokeCommand(Address target, org.infinispan.commands.remote.CacheRpcCommand command, ResponseCollector<Address, T> collector, RpcOptions rpcOptions) <T> CompletionStage<T> RpcManager.invokeCommandOnAll(org.infinispan.commands.remote.CacheRpcCommand command, ResponseCollector<Address, T> collector, RpcOptions rpcOptions) Invoke a command on all the nodes in the cluster and pass the responses to aResponseCollector.<T> CompletionStage<T> RpcManagerImpl.invokeCommandOnAll(org.infinispan.commands.remote.CacheRpcCommand command, ResponseCollector<Address, T> collector, RpcOptions rpcOptions) <T> CompletionStage<T> RpcManager.invokeCommands(Collection<Address> targets, Function<Address, org.infinispan.commands.remote.CacheRpcCommand> commandGenerator, ResponseCollector<Address, 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, org.infinispan.commands.remote.CacheRpcCommand> commandGenerator, ResponseCollector<Address, 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, org.infinispan.commands.remote.CacheRpcCommand> commandGenerator, ResponseCollector<Address, 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, org.infinispan.commands.remote.CacheRpcCommand> commandGenerator, ResponseCollector<Address, T> collector, RpcOptions rpcOptions) <T> CompletionStage<T> RpcManagerImpl.invokeCommands(Collection<Address> targets, Function<Address, org.infinispan.commands.remote.CacheRpcCommand> commandGenerator, ResponseCollector<Address, T> collector, RpcOptions rpcOptions) <T> CompletionStage<T> RpcManagerImpl.invokeCommands(Collection<Address> targets, Function<Address, org.infinispan.commands.remote.CacheRpcCommand> commandGenerator, ResponseCollector<Address, T> collector, RpcOptions rpcOptions) <T> CompletionStage<T> RpcManager.invokeCommandStaggered(Collection<Address> targets, org.infinispan.commands.remote.CacheRpcCommand command, ResponseCollector<Address, T> collector, RpcOptions rpcOptions) Invoke a command on a collection of nodes and pass the responses to aResponseCollector.<T> CompletionStage<T> RpcManager.invokeCommandStaggered(Collection<Address> targets, org.infinispan.commands.remote.CacheRpcCommand command, ResponseCollector<Address, 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, org.infinispan.commands.remote.CacheRpcCommand command, ResponseCollector<Address, T> collector, RpcOptions rpcOptions) <T> CompletionStage<T> RpcManagerImpl.invokeCommandStaggered(Collection<Address> targets, org.infinispan.commands.remote.CacheRpcCommand command, ResponseCollector<Address, T> collector, RpcOptions rpcOptions) voidRpcManager.sendToMany(Collection<Address> destinations, org.infinispan.commands.remote.CacheRpcCommand command, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) Asynchronously sends theReplicableCommandto the set of destination using the specifiedDeliverOrder.voidRpcManagerImpl.sendToMany(Collection<Address> destinations, org.infinispan.commands.remote.CacheRpcCommand command, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) -
Uses of Address in org.infinispan.remoting.transport
Classes in org.infinispan.remoting.transport that implement interfaces with type arguments of type AddressModifier and TypeClassDescriptionclassAn encapsulation of a JGroupsExtendedUUIDwith aNodeVersion, site id, rack id, and a machine id.final classWARNING: Generated code!classBase class for response collectors, splitting responses into valid responses, exception responses, and target missing.Fields in org.infinispan.remoting.transport declared as AddressMethods in org.infinispan.remoting.transport that return AddressModifier and TypeMethodDescriptionstatic AddressAddress.fromExtendedUUID(org.jgroups.util.ExtendedUUID address) static AddressAddress.fromNodeUUID(UUID nodeUUID) AbstractDelegatingTransport.getAddress()Transport.getAddress()Retrieves the current cache instance's network addressAbstractDelegatingTransport.getCoordinator()Transport.getCoordinator()static AddressAddress.protoFactory(long mostSignificantBits, long leastSignificantBits, NodeVersion version, String siteId, String rackId, String machineId) static AddressAddress.random()static Addressstatic AddressAddress$___Marshaller_4f32fa50926d8770f1ad6f353f6c769a25846818788604d769c7e3c601cdac10.read(org.infinispan.protostream.ProtobufTagMarshaller.ReadContext $1) Methods in org.infinispan.remoting.transport that return types with arguments of type AddressModifier and TypeMethodDescriptionAddress$___Marshaller_4f32fa50926d8770f1ad6f353f6c769a25846818788604d769c7e3c601cdac10.getJavaClass()AbstractDelegatingTransport.getMembers()Transport.getMembers()Returns a list of members in the current cluster view.AbstractDelegatingTransport.getRelayNodesAddress()Transport.getRelayNodesAddress()AbstractDelegatingTransport.invokeRemotelyAsync(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, ResponseFilter responseFilter, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) Transport.invokeRemotelyAsync(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, ResponseFilter responseFilter, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) default CompletableFuture<Map<Address, Response>> Transport.invokeRemotelyAsync(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.Methods in org.infinispan.remoting.transport with parameters of type AddressModifier and TypeMethodDescriptionprotected abstract TValidResponseCollector.addException(Address sender, Exception exception) Process an exception from a target.final TValidResponseCollector.addResponse(Address sender, Response response) protected abstract TValidResponseCollector.addTargetNotFound(Address sender) Process a target leaving the cluster or stopping the cache.protected abstract TValidResponseCollector.addValidResponse(Address sender, ValidResponse<?> response) Process a valid response from a target.int<T> CompletionStage<T> AbstractDelegatingTransport.invokeCommand(Address target, ReplicableCommand command, ResponseCollector<Address, T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) default <T> CompletionStage<T> Transport.invokeCommand(Address target, ReplicableCommand command, ResponseCollector<Address, 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.booleanAddress.isSameMachine(Address other) booleanAddress.isSameRack(Address other) booleanAddress.isSameSite(Address other) voidAbstractDelegatingTransport.sendTo(Address destination, ReplicableCommand rpcCommand, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) voidTransport.sendTo(Address destination, ReplicableCommand rpcCommand, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) Asynchronously sends theReplicableCommandto the destination using the specifiedDeliverOrder.static org.jgroups.util.ExtendedUUIDAddress.toExtendedUUID(Address address) voidAddress$___Marshaller_4f32fa50926d8770f1ad6f353f6c769a25846818788604d769c7e3c601cdac10.write(org.infinispan.protostream.ProtobufTagMarshaller.WriteContext $1, Address $2) Method parameters in org.infinispan.remoting.transport with type arguments of type AddressModifier and TypeMethodDescription<T> CompletionStage<T> AbstractDelegatingTransport.invokeCommand(Collection<Address> targets, ReplicableCommand command, ResponseCollector<Address, T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) <T> CompletionStage<T> AbstractDelegatingTransport.invokeCommand(Collection<Address> targets, ReplicableCommand command, ResponseCollector<Address, T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) <T> CompletionStage<T> AbstractDelegatingTransport.invokeCommand(Address target, ReplicableCommand command, ResponseCollector<Address, T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) default <T> CompletionStage<T> Transport.invokeCommand(Collection<Address> targets, ReplicableCommand command, ResponseCollector<Address, 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.invokeCommand(Collection<Address> targets, ReplicableCommand command, ResponseCollector<Address, 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.invokeCommand(Address target, ReplicableCommand command, ResponseCollector<Address, 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.<T> CompletionStage<T> AbstractDelegatingTransport.invokeCommandOnAll(ReplicableCommand command, ResponseCollector<Address, T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) default <T> CompletionStage<T> Transport.invokeCommandOnAll(Collection<Address> requiredTargets, ReplicableCommand command, ResponseCollector<Address, 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.default <T> CompletionStage<T> Transport.invokeCommandOnAll(Collection<Address> requiredTargets, ReplicableCommand command, ResponseCollector<Address, 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.default <T> CompletionStage<T> Transport.invokeCommandOnAll(ReplicableCommand command, ResponseCollector<Address, 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<Address, 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<Address, 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<Address, 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<Address, 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<Address, 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<Address, 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<Address, T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) <T> CompletionStage<T> AbstractDelegatingTransport.invokeCommandStaggered(Collection<Address> targets, ReplicableCommand command, ResponseCollector<Address, T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) default <T> CompletionStage<T> Transport.invokeCommandStaggered(Collection<Address> targets, ReplicableCommand command, ResponseCollector<Address, 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.default <T> CompletionStage<T> Transport.invokeCommandStaggered(Collection<Address> targets, ReplicableCommand command, ResponseCollector<Address, 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.invokeRemotelyAsync(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, ResponseFilter responseFilter, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) Transport.invokeRemotelyAsync(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, ResponseFilter responseFilter, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) default CompletableFuture<Map<Address, Response>> Transport.invokeRemotelyAsync(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.voidAbstractDelegatingTransport.sendToMany(Collection<Address> destinations, ReplicableCommand rpcCommand, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) voidTransport.sendToMany(Collection<Address> destinations, ReplicableCommand rpcCommand, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) Asynchronously sends theReplicableCommandto the set of destination using the specifiedDeliverOrder. -
Uses of Address in org.infinispan.remoting.transport.impl
Subclasses with type arguments of type Address in org.infinispan.remoting.transport.implModifier and TypeClassDescriptionclassRequest implementation that waits for responses from multiple target nodes.classResponse collector supportingJGroupsTransport.invokeRemotelyAsync(Collection, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder).classResponse collector supportingJGroupsTransport.invokeRemotelyAsync(Collection, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder).classRequest implementation that waits for a response from a single target node.classResponse collector supportingJGroupsTransport.invokeRemotelyAsync(Collection, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder).classResponse collector supportingJGroupsTransport.invokeRemotelyAsync(Collection, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder).Classes in org.infinispan.remoting.transport.impl that implement interfaces with type arguments of type AddressModifier and TypeClassDescriptionclassReceive responses from multiple nodes, without checking that the responses are valid.classReceive responses from multiple nodes, without checking that the responses are valid.classRPC to a single node, without any validity checks.Fields in org.infinispan.remoting.transport.impl with type parameters of type AddressMethods in org.infinispan.remoting.transport.impl that return types with arguments of type AddressModifier 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) Methods in org.infinispan.remoting.transport.impl with parameters of type AddressModifier and TypeMethodDescriptionprotected abstract voidExclusiveTargetRequest.actualOnResponse(Address sender, Response response) protected voidMultiTargetRequest.actualOnResponse(Address sender, Response response) FilterMapResponseCollector.addException(Address sender, Exception exception) MapResponseCollector.addException(Address sender, Exception exception) protected VoidVoidResponseCollector.addException(Address sender, Exception exception) PassthroughMapResponseCollector.addResponse(Address sender, Response response) PassthroughSingleResponseCollector.addResponse(Address sender, Response response) FilterMapResponseCollector.addTargetNotFound(Address sender) protected VoidVoidResponseCollector.addTargetNotFound(Address sender) FilterMapResponseCollector.addValidResponse(Address sender, ValidResponse<?> response) MapResponseCollector.addValidResponse(Address sender, ValidResponse<?> response) protected VoidVoidResponseCollector.addValidResponse(Address sender, ValidResponse<?> response) final voidExclusiveTargetRequest.onResponse(Address sender, Response response) voidSingleTargetRequest.onResponse(Address sender, Response response) SingletonMapResponseCollector.targetNotFound(Address sender) SingletonMapResponseCollector.withValidResponse(Address sender, ValidResponse<?> response) Method parameters in org.infinispan.remoting.transport.impl with type arguments of type AddressModifier and TypeMethodDescriptionprotected abstract booleanExclusiveTargetRequest.actualOnView(Set<Address> members) protected booleanMultiTargetRequest.actualOnView(Set<Address> members) final booleanbooleanCalled when the node received a new cluster view.booleanConstructors in org.infinispan.remoting.transport.impl with parameters of type AddressModifierConstructorDescriptionMultiTargetRequest(ResponseCollector<Address, T> responseCollector, long requestId, RequestRepository repository, Collection<Address> targets, Address excluded, JGroupsMetricsManager metricsCollector) Constructor parameters in org.infinispan.remoting.transport.impl with type arguments of type AddressModifierConstructorDescriptionExclusiveTargetRequest(ResponseCollector<Address, T> responseCollector, long requestId, RequestRepository repository) MultiTargetRequest(ResponseCollector<Address, T> responseCollector, long requestId, RequestRepository repository, Collection<Address> targets, Address excluded, JGroupsMetricsManager metricsCollector) MultiTargetRequest(ResponseCollector<Address, T> responseCollector, long requestId, RequestRepository repository, Collection<Address> targets, Address excluded, JGroupsMetricsManager metricsCollector) SingleTargetRequest(ResponseCollector<Address, T> wrapper, long requestId, RequestRepository repository, RequestTracker requestTracker) -
Uses of Address in org.infinispan.remoting.transport.jgroups
Fields in org.infinispan.remoting.transport.jgroups declared as AddressMethods in org.infinispan.remoting.transport.jgroups that return AddressModifier and TypeMethodDescriptionRequestTracker.destination()static AddressAddressCache.fromExtendedUUID(org.jgroups.util.ExtendedUUID addr) JGroupsTransport.getAddress()ClusterView.getCoordinator()JGroupsTransport.getCoordinator()static AddressAddressCache.getIfPresent(long mostSignificantBits, long leastSignificantBits) SuspectException.getSuspect()Methods in org.infinispan.remoting.transport.jgroups that return types with arguments of type AddressModifier and TypeMethodDescriptionClusterView.getMembers()JGroupsTransport.getMembers()ClusterView.getMembersSet()JGroupsTransport.getRelayNodesAddress()JGroupsTransport.invokeRemotelyAsync(Collection<Address> recipients, ReplicableCommand command, ResponseMode mode, long timeout, ResponseFilter responseFilter, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) Methods in org.infinispan.remoting.transport.jgroups with parameters of type AddressModifier and TypeMethodDescriptionprotected voidStaggeredRequest.actualOnResponse(Address sender, Response response) org.jgroups.util.ExtendedUUIDClusterView.getAddressFromView(Address address) <T> CompletionStage<T> JGroupsTransport.invokeCommand(Address target, ReplicableCommand command, ResponseCollector<Address, T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) voidJGroupsMetricsManager.recordMessageSent(Address destination, int bytesSent, boolean async) Records a message sent to adestination.voidJGroupsMetricsManagerImpl.recordMessageSent(Address destination, int bytesSent, boolean async) voidNoOpJGroupsMetricManager.recordMessageSent(Address destination, int bytesSent, boolean async) voidJGroupsTransport.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) Method parameters in org.infinispan.remoting.transport.jgroups with type arguments of type AddressModifier and TypeMethodDescription<T> CompletionStage<T> JGroupsTransport.invokeCommand(Collection<Address> targets, ReplicableCommand command, ResponseCollector<Address, T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) <T> CompletionStage<T> JGroupsTransport.invokeCommand(Collection<Address> targets, ReplicableCommand command, ResponseCollector<Address, T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) <T> CompletionStage<T> JGroupsTransport.invokeCommand(Address target, ReplicableCommand command, ResponseCollector<Address, T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) <T> CompletionStage<T> JGroupsTransport.invokeCommandOnAll(Collection<Address> requiredTargets, ReplicableCommand command, ResponseCollector<Address, T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) <T> CompletionStage<T> JGroupsTransport.invokeCommandOnAll(Collection<Address> requiredTargets, ReplicableCommand command, ResponseCollector<Address, T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) <T> CompletionStage<T> JGroupsTransport.invokeCommandOnAll(ReplicableCommand command, ResponseCollector<Address, 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<Address, 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<Address, 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<Address, T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit timeUnit) <T> CompletionStage<T> JGroupsTransport.invokeCommandStaggered(Collection<Address> targets, ReplicableCommand command, ResponseCollector<Address, T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) <T> CompletionStage<T> JGroupsTransport.invokeCommandStaggered(Collection<Address> targets, ReplicableCommand command, ResponseCollector<Address, T> collector, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder, long timeout, TimeUnit unit) JGroupsTransport.invokeRemotelyAsync(Collection<Address> recipients, ReplicableCommand command, ResponseMode mode, long timeout, ResponseFilter responseFilter, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) booleanvoidJGroupsTransport.sendToMany(Collection<Address> targets, ReplicableCommand command, org.infinispan.remoting.inboundhandler.DeliverOrder deliverOrder) Constructors in org.infinispan.remoting.transport.jgroups with parameters of type AddressModifierConstructorDescriptionSuspectException(String msg, Address suspect) SuspectException(String msg, Address suspect, Throwable cause) -
Uses of Address in org.infinispan.server.hotrod
Methods in org.infinispan.server.hotrod that return types with arguments of type Address -
Uses of Address in org.infinispan.server.hotrod.tx
Methods in org.infinispan.server.hotrod.tx with parameters of type AddressMethod parameters in org.infinispan.server.hotrod.tx with type arguments of type AddressModifier and TypeMethodDescriptionbooleanServerTransactionOriginatorChecker.isOriginatorMissing(GlobalTransaction gtx, Collection<Address> liveMembers) -
Uses of Address in org.infinispan.server.hotrod.tx.table
Methods in org.infinispan.server.hotrod.tx.table that return Address -
Uses of Address in org.infinispan.stream.impl
Fields in org.infinispan.stream.impl declared as AddressConstructors in org.infinispan.stream.impl with parameters of type AddressModifierConstructorDescriptionprotectedAbstractCacheStream(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
Methods in org.infinispan.topology that return AddressModifier and TypeMethodDescriptionPersistentUUIDManager.getAddress(UUID persistentUUID) PersistentUUIDManagerImpl.getAddress(UUID persistentUUID) Methods in org.infinispan.topology that return types with arguments of type AddressModifier 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 givencacheNameif 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()Methods in org.infinispan.topology with parameters of type AddressModifier and TypeMethodDescriptionvoidPersistentUUIDManager.addPersistentAddressMapping(Address address, UUID persistentUUID) voidPersistentUUIDManagerImpl.addPersistentAddressMapping(Address address, UUID persistentUUID) voidClusterCacheStatus.confirmRebalancePhase(Address member, int receivedTopologyId) ClusterCacheStatus.doJoin(Address joiner, CacheJoinInfo joinInfo) PersistentUUIDManager.getPersistentUuid(Address address) 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) Signals that a member is leaving the cache.default CompletionStage<Void> ClusterTopologyManager.handleLeave(String cacheName, Address leaver, int viewId) Deprecated, for removal: This API element is subject to removal in a future version.since 16.0, useClusterTopologyManager.handleLeave(String, Address)insteadClusterTopologyManagerImpl.handleLeave(String cacheName, Address leaver) 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) default CompletionStage<Void> ClusterTopologyManager.handleRebalancePhaseConfirm(String cacheName, Address node, int topologyId, Throwable throwable, int viewId) Deprecated, for removal: This API element is subject to removal in a future version.since 16.0, useClusterTopologyManager.handleRebalancePhaseConfirm(String, Address, int, Throwable)insteadClusterTopologyManagerImpl.handleRebalancePhaseConfirm(String cacheName, Address node, int topologyId, Throwable throwable) 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) voidPersistentUUIDManager.removePersistentAddressMapping(Address address) Removes any address mapping for the specifiedAddressvoidPersistentUUIDManagerImpl.removePersistentAddressMapping(Address address) Method parameters in org.infinispan.topology with type arguments of type AddressModifier and TypeMethodDescriptionClusterCacheStatus.calculateConflictHash(ConsistentHash preferredHash, Set<ConsistentHash> distinctHashes, List<Address> actualMembers) voidClusterCacheStatus.doMergePartitions(Map<Address, CacheStatusResponse> statusResponses) <T> CompletionStage<T> TopologyManagementHelper.executeOnClusterSync(Transport transport, ReplicableCommand command, int timeout, ResponseCollector<Address, T> responseCollector) voidClusterCacheStatus.manuallyUpdateAvailabilityMode(List<Address> actualMembers, AvailabilityMode mode, boolean cancelRebalance) PersistentUUIDManager.mapAddresses(List<Address> addresses) PersistentUUIDManagerImpl.mapAddresses(List<Address> addresses) voidClusterCacheStatus.queueConflictResolution(CacheTopology conflictTopology, Set<Address> preferredNodes) voidClusterCacheStatus.queueRebalance(List<Address> newMembers) booleanClusterCacheStatus.restartConflictResolution(List<Address> members) voidClusterCacheStatus.updateAvailabilityMode(List<Address> actualMembers, AvailabilityMode newAvailabilityMode, boolean cancelRebalance) voidClusterCacheStatus.updateCurrentTopology(List<Address> newMembers) Constructor parameters in org.infinispan.topology with type arguments of type AddressModifierConstructorDescriptionCacheStatusResponse(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<UUID> persistentUUIDs) CacheTopology(int topologyId, int rebalanceId, boolean restoredTopology, ConsistentHash currentCH, ConsistentHash pendingCH, CacheTopology.Phase phase, List<Address> actualMembers, List<UUID> persistentUUIDs) CacheTopology(int topologyId, int rebalanceId, ConsistentHash currentCH, ConsistentHash pendingCH, ConsistentHash unionCH, CacheTopology.Phase phase, List<Address> actualMembers, List<UUID> persistentUUIDs) CacheTopology(int topologyId, int rebalanceId, ConsistentHash currentCH, ConsistentHash pendingCH, CacheTopology.Phase phase, List<Address> actualMembers, List<UUID> persistentUUIDs) -
Uses of Address in org.infinispan.transaction.impl
Methods in org.infinispan.transaction.impl that return types with arguments of type AddressModifier 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()Method parameters in org.infinispan.transaction.impl with type arguments of type AddressModifier and TypeMethodDescriptionvoidTransactionTable.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.booleanClusteredTransactionOriginatorChecker.isOriginatorMissing(GlobalTransaction gtx, Collection<Address> liveMembers) booleanTransactionOriginatorChecker.isOriginatorMissing(GlobalTransaction gtx, Collection<Address> liveMembers) voidLocalTransaction.locksAcquired(Collection<Address> nodes) -
Uses of Address in org.infinispan.transaction.xa
Methods in org.infinispan.transaction.xa that return AddressMethods in org.infinispan.transaction.xa with parameters of type AddressModifier and TypeMethodDescriptionTransactionFactory.newGlobalTransaction(Address addr, boolean remote) TransactionFactory.newGlobalTransaction(Address addr, boolean remote, boolean client) TransactionFactory.TxFactoryEnum.newGlobalTransaction(Address addr, boolean remote, VersionGenerator clusterIdGenerator, boolean clustered) Deprecated, for removal: This API element is subject to removal in a future version.abstract GlobalTransactionTransactionFactory.TxFactoryEnum.newGlobalTransaction(Address addr, boolean remote, VersionGenerator clusterIdGenerator, boolean clustered, boolean client) Constructors in org.infinispan.transaction.xa with parameters of type AddressModifierConstructorDescriptionGlobalTransaction(Address addr, boolean remote) GlobalTransaction(Address addr, boolean remote, boolean clientTx) -
Uses of Address in org.infinispan.transaction.xa.recovery
Methods in org.infinispan.transaction.xa.recovery that return types with arguments of type AddressMethods in org.infinispan.transaction.xa.recovery with parameters of type AddressModifier and TypeMethodDescriptionvoidAddsowneras 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) Method parameters in org.infinispan.transaction.xa.recovery with type arguments of type AddressModifier and TypeMethodDescriptionvoidRecoveryAwareTransactionTable.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.voidRecoveryAwareRemoteTransaction.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
Methods in org.infinispan.util.concurrent with parameters of type AddressModifier and TypeMethodDescriptionvoidAcknowledges aPutMapCommandcompletion in the backup owner.Method parameters in org.infinispan.util.concurrent with type arguments of type AddressModifier 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.voidCommandAckCollector.onMembersChange(Collection<Address> members) Notifies a change in member list. -
Uses of Address in org.infinispan.util.logging
Methods in org.infinispan.util.logging with parameters of type AddressModifier and TypeMethodDescriptionfinal voidLog_$logger.errorReadingRebalancingStatus(Address coordinator, Throwable t) final voidLog_$logger.exceptionDuringClusterListenerRetrieval(Address address, Throwable cause) final voidLog_$logger.failedToRequestSegments(String cacheName, Address source, Collection<Integer> segments, Throwable e) final voidLog_$logger.failedToRetrieveTransactionsForSegments(String cacheName, Address source, Collection<Integer> segments, Throwable t) final voidLog_$logger.failedToTransferTombstones(Address requestor, IntSet segments, Throwable t) final voidLog_$logger.ignoringUnsolicitedState(Address node, int segment, String cacheName) final TimeoutExceptionLog_$logger.initialStateTransferTimeout(String cacheName, Address localAddress) final voidLog_$logger.localAndPhysicalAddress(String cluster, Address address, List<PhysicalAddress> physicalAddresses) final CacheJoinExceptionLog_$logger.nodeWithIncompatibleStateJoiningCache(Address joiner, String cacheName) final CacheJoinExceptionLog_$logger.nodeWithPersistentStateJoiningClusterWithoutState(Address joiner, String cacheName) final voidLog_$logger.rebalanceError(String cacheName, Address node, int topologyId, Throwable cause) final voidLog_$logger.rebalancePhaseConfirmedOnNode(CacheTopology.Phase phase, String cacheName, Address node, int topologyId) final TimeoutExceptionLog_$logger.remoteNodeTimedOut(Address address, long time, TimeUnit unit) final voidLog_$logger.unableToLockToInvalidate(Object key, Address address) final IllegalArgumentExceptionLog_$logger.unexpectedResponse(Address target, Response response) final voidLog_$logger.unsuccessfulResponseForClusterListeners(Address address, Response response) final voidLog_$logger.unsuccessfulResponseRetrievingTransactionsForSegments(Address address, Response response) Method parameters in org.infinispan.util.logging with type arguments of type AddressModifier and TypeMethodDescriptionfinal voidLog_$logger.expectedJustOneResponse(Map<Address, Response> lr) final CacheJoinExceptionLog_$logger.extraneousMembersJoinRestoredCache(List<Address> extraneousMembers, String cacheName) final voidLog_$logger.ignoringCacheTopology(Collection<Address> sender, CacheTopology topology) final voidLog_$logger.recoverFromStateMissingMembers(String cacheName, List<Address> members, int total) final MissingMembersExceptionLog_$logger.recoverFromStateMissingMembers(String cacheName, List<Address> members, String total) -
Uses of Address in org.infinispan.xsite.irac
Methods in org.infinispan.xsite.irac with parameters of type AddressModifier and TypeMethodDescriptionvoidDefaultIracManager.checkStaleKeys(Address origin, Collection<IracManagerKeyInfo> keys) voidIracManager.checkStaleKeys(Address origin, Collection<IracManagerKeyInfo> keys) Checks a remote node's list ofIracManagerKeyInfofor stale or outdated entries.voidNoOpIracManager.checkStaleKeys(Address origin, Collection<IracManagerKeyInfo> keys) voidDefaultIracManager.requestState(Address requestor, IntSet segments) voidIracManager.requestState(Address requestor, IntSet segments) Requests the state stored in this instance for the givensegments.voidNoOpIracManager.requestState(Address requestor, IntSet segments) -
Uses of Address in org.infinispan.xsite.response
Classes in org.infinispan.xsite.response that implement interfaces with type arguments of type AddressModifier and TypeClassDescriptionclassAResponseCollectorthat mergesAutoStateTransferResponse.Methods in org.infinispan.xsite.response with parameters of type AddressModifier and TypeMethodDescriptionAutoStateTransferResponseCollector.addResponse(Address sender, Response response) -
Uses of Address in org.infinispan.xsite.statetransfer
Methods in org.infinispan.xsite.statetransfer with parameters of type AddressModifier and TypeMethodDescriptionbooleanRemoteSiteStatus.confirmStateTransfer(Address node, boolean statusOk) booleanXSiteStateTransferCollector.confirmStateTransfer(Address node, boolean statusOk) BaseXSiteStateProviderState.createPushTask(Address originator, XSiteStateProvider provider) XSiteStateProviderState.createPushTask(Address originator, XSiteStateProvider provider) Creates a newXSiteStatePushTaskto do state transfer to remove site.voidNoOpXSiteStateTransferManager.notifyStatePushFinished(String siteName, Address node, boolean statusOk) voidXSiteStateTransferManager.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.voidXSiteStateTransferManagerImpl.notifyStatePushFinished(String siteName, Address node, boolean statusOk) voidNoOpXSiteStateProvider.notifyStateTransferEnd(String siteName, Address origin, boolean statusOk) voidXSiteStateProvider.notifyStateTransferEnd(String siteName, Address origin, boolean statusOk) NotifiesXSiteStatePushTaskhas completed the send.voidXSiteStateProviderImpl.notifyStateTransferEnd(String siteName, Address origin, boolean statusOk) voidNoOpXSiteStateProvider.startStateTransfer(String siteName, Address requestor, int minTopologyId) voidXSiteStateProvider.startStateTransfer(String siteName, Address requestor, int minTopologyId) It notifies this node to start sending state to the remote site.voidXSiteStateProviderImpl.startStateTransfer(String siteName, Address origin, int minTopologyId) Method parameters in org.infinispan.xsite.statetransfer with type arguments of type AddressModifier and TypeMethodDescriptionNoOpXSiteStateProvider.getSitesMissingCoordinator(Collection<Address> currentMembers) XSiteStateProvider.getSitesMissingCoordinator(Collection<Address> currentMembers) XSiteStateProviderImpl.getSitesMissingCoordinator(Collection<Address> currentMembers) booleanBaseXSiteStateProviderState.isOriginatorMissing(Collection<Address> members) booleanXSiteStateProviderState.isOriginatorMissing(Collection<Address> members) ReturnsbooleanRemoteSiteStatus.restartStateTransfer(Collection<Address> newMembers) booleanRemoteSiteStatus.startStateTransfer(Collection<Address> members) booleanXSiteStateTransferCollector.updateMembers(Collection<Address> members) Constructor parameters in org.infinispan.xsite.statetransfer with type arguments of type AddressModifierConstructorDescriptionXSiteStateTransferCollector(Collection<Address> confirmationPending) -
Uses of Address in org.infinispan.xsite.status
Subclasses with type arguments of type Address in org.infinispan.xsite.statusMethods in org.infinispan.xsite.status with parameters of type AddressModifier and TypeMethodDescriptionvoidAdds a member with an online/offline connection to the server based on theonlineparameter.Method parameters in org.infinispan.xsite.status with type arguments of type AddressModifier and TypeMethodDescriptionprotected SiteStatusCacheSiteStatusBuilder.createMixedStatus(List<Address> onlineElements, List<Address> offlineElements) Constructor parameters in org.infinispan.xsite.status with type arguments of type AddressModifierConstructorDescriptionCacheMixedSiteStatus(List<Address> onlineMembers, List<Address> offlineMembers)
Transport.invokeRemotelyAsync(Collection, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder).