Uses of Interface
org.infinispan.remoting.transport.Address
-
Packages that use Address Package Description org.infinispan.affinity This package contains theKeyAffinityServiceinterfaces which allow user code to determine mapping of keys onto nodesorg.infinispan.conflict This package contains the APIs that enable users to search for, and amend, data inconsistencies within their cache.org.infinispan.container.entries Entries which are stored in data containers.org.infinispan.context Contexts contain information of a specific invocation on the cache, such as its origins, scope (transactional or non-transactional), as well as invocation-specific flags.org.infinispan.distexec Distributed Executor APIs (deprecated)org.infinispan.distribution Classes relating to the distributed cache mode.org.infinispan.distribution.ch Consistent Hash interfacesorg.infinispan.distribution.topologyaware org.infinispan.interceptors.distribution Interceptors dealing with command replication in distributed/replicated mode.org.infinispan.interceptors.locking Interceptors dealing with locking.org.infinispan.interceptors.totalorder Interceptors dealing with total order.org.infinispan.manager Cache manager API.org.infinispan.notifications.cachelistener.cluster org.infinispan.notifications.cachelistener.event Cache-specific listener eventsorg.infinispan.notifications.cachemanagerlistener CacheManager-specific notifications and eventing.org.infinispan.notifications.cachemanagerlistener.event EmbeddedCacheManager-specific listener eventsorg.infinispan.query.affinity This package contains the implementation of the AffinityIndexManager, that maintains an index divided into shards with storage using the Infinispan Lucene directory.org.infinispan.query.clustered org.infinispan.remoting Remote communication between cache instances.org.infinispan.remoting.inboundhandler Handling of inbound commands on remote nodes.org.infinispan.remoting.responses Abstractions of the different response types allowed during RPC.org.infinispan.remoting.rpc Remote Procedure Call (RPC) interfaces and components used to invoke remote methods on cache instances.org.infinispan.remoting.transport Transports handle the low-level networking, used by the remoting components.org.infinispan.remoting.transport.jgroups A transport implementation based on JGroups.org.infinispan.scattered SCATTERED CACHE DESIGNorg.infinispan.security.actions org.infinispan.server.hotrod org.infinispan.server.hotrod.tx org.infinispan.server.hotrod.tx.table org.infinispan.statetransfer Transfer of state to new caches in a cluster.org.infinispan.stats.wrappers org.infinispan.topology org.infinispan.transaction.xa XA transaction support.org.infinispan.transaction.xa.recovery org.infinispan.util General utilities that are not specific to Infinispan, including string parsing helpers, reflection tools and collections and containers designed to supplement the JDK-provided containers.org.infinispan.util.concurrent Thread-safe containers and other concurrency-related utilities, designed to supplement JDK concurrency utilities and containers.org.infinispan.xsite.statetransfer org.infinispan.xsite.status -
-
Uses of Address in org.infinispan.affinity
Methods in org.infinispan.affinity with parameters of type Address Modifier and Type Method Description KKeyAffinityService. 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 Address Modifier and Type Method Description static <K,V>
KeyAffinityService<K>KeyAffinityServiceFactory. newKeyAffinityService(Cache<K,V> cache, Collection<Address> filter, KeyGenerator<K> keyGenerator, Executor ex, int keyBufferSize)static <K,V>
KeyAffinityService<K>KeyAffinityServiceFactory. newKeyAffinityService(Cache<K,V> cache, Collection<Address> filter, KeyGenerator<K> keyGenerator, Executor ex, int keyBufferSize, boolean start)Creates a service that would only generate keys for addresses specified in filter.Constructor parameters in org.infinispan.affinity with type arguments of type Address Constructor Description KeyAffinityServiceImpl(Executor executor, Cache<? extends K,?> cache, KeyGenerator<? extends K> keyGenerator, int bufferSize, Collection<Address> filter, boolean start)Deprecated. -
Uses of Address in org.infinispan.conflict
Methods in org.infinispan.conflict that return types with arguments of type Address Modifier and Type Method Description Map<Address,InternalCacheValue<V>>ConflictManager. getAllVersions(K key)Get all CacheEntry's that exists for a given key.Stream<Map<Address,CacheEntry<K,V>>>ConflictManager. getConflicts()Returns a stream of conflicts detected in the cluster. -
Uses of Address in org.infinispan.container.entries
Methods in org.infinispan.container.entries that return Address Modifier and Type Method Description AddressRemoteMetadata. getAddress()Constructors in org.infinispan.container.entries with parameters of type Address Constructor Description RemoteMetadata(Address address, EntryVersion version) -
Uses of Address in org.infinispan.context
Methods in org.infinispan.context that return Address Modifier and Type Method Description AddressInvocationContext. getOrigin()AddressSingleKeyNonTxInvocationContext. getOrigin()Deprecated.Methods in org.infinispan.context with parameters of type Address Modifier and Type Method Description InvocationContextInvocationContextFactory. createRemoteInvocationContext(Address origin)Returns anNonTxInvocationContextwhoseAbstractInvocationContext.isOriginLocal()flag will be true.org.infinispan.context.impl.NonTxInvocationContextNonTransactionalInvocationContextFactory. createRemoteInvocationContext(Address origin)Deprecated.org.infinispan.context.impl.NonTxInvocationContextTransactionalInvocationContextFactory. createRemoteInvocationContext(Address origin)Deprecated.InvocationContextAbstractInvocationContextFactory. createRemoteInvocationContextForCommand(org.infinispan.commands.VisitableCommand cacheCommand, Address origin)Deprecated.InvocationContextInvocationContextFactory. createRemoteInvocationContextForCommand(org.infinispan.commands.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.org.infinispan.context.impl.RemoteTxInvocationContextInvocationContextFactory. createRemoteTxInvocationContext(org.infinispan.transaction.impl.RemoteTransaction tx, Address origin)Returns anRemoteTxInvocationContext.org.infinispan.context.impl.RemoteTxInvocationContextNonTransactionalInvocationContextFactory. createRemoteTxInvocationContext(org.infinispan.transaction.impl.RemoteTransaction tx, Address origin)Deprecated.org.infinispan.context.impl.RemoteTxInvocationContextTransactionalInvocationContextFactory. createRemoteTxInvocationContext(org.infinispan.transaction.impl.RemoteTransaction tx, Address origin)Deprecated.protected org.infinispan.context.impl.NonTxInvocationContextTransactionalInvocationContextFactory. newNonTxInvocationContext(Address origin)Deprecated.Constructors in org.infinispan.context with parameters of type Address Constructor Description SingleKeyNonTxInvocationContext(Address origin)Deprecated. -
Uses of Address in org.infinispan.distexec
Methods in org.infinispan.distexec that return Address Modifier and Type Method Description AddressFailoverContext. executionFailureLocation()Returns an Address of the node where the task failedAddressDistributedTaskFailoverPolicy. failover(FailoverContext context)As parts of distributively executed task can fail due to the task itself throwing an exception or it can be an Infinispan system caused failure (e.g node failed or left cluster during task execution etc).protected AddressDefaultExecutorService. selectExecutionNode(List<Address> candidates)Deprecated.protected <T> AddressDefaultExecutorService. selectExecutionNode(DistributedTask<T> task)Deprecated.Methods in org.infinispan.distexec that return types with arguments of type Address Modifier and Type Method Description protected <T> List<Address>DefaultExecutorService. executionCandidates(DistributedTask<T> task)Deprecated.List<Address>FailoverContext. executionCandidates()Returns a list of candidates for possible repeated execution governed by installedDistributedTaskFailoverPolicyprotected List<Address>DefaultExecutorService. getMembers()Deprecated.protected <K> Map<Address,List<K>>DefaultExecutorService. keysToExecutionNodes(DistributedTaskExecutionPolicy policy, K... input)Deprecated.protected List<Address>DefaultExecutorService. randomClusterMembers(List<Address> members, int numNeeded)Deprecated.Methods in org.infinispan.distexec with parameters of type Address Modifier and Type Method Description protected <T,K>
org.infinispan.distexec.DefaultExecutorService.DistributedTaskPart<T>DefaultExecutorService. createDistributedTaskPart(DistributedTask<T> task, org.infinispan.commands.read.DistributedExecuteCommand<T> c, List<K> inputKeys, Address target, int failoverCount)Deprecated.protected <T,K>
org.infinispan.distexec.DefaultExecutorService.DistributedTaskPart<T>DefaultExecutorService. createDistributedTaskPart(DistributedTask<T> task, org.infinispan.commands.read.DistributedExecuteCommand<T> c, Address target, int failoverCount)Deprecated.<T> CompletableFuture<T>DefaultExecutorService. submit(Address target, Callable<T> task)Deprecated.<T> CompletableFuture<T>DefaultExecutorService. submit(Address target, DistributedTask<T> task)Deprecated.<K> CompletableFuture<V>DistributedExecutionCompletionService. submit(Address target, Callable<V> task)<T> CompletableFuture<T>DistributedExecutorService. submit(Address target, Callable<T> task)Deprecated.Submits the given Callable task for execution on the specified target Infinispan node.<T> CompletableFuture<T>DistributedExecutorService. submit(Address target, DistributedTask<T> task)Deprecated.Submits the given DistributedTask for execution on the specified target Infinispan node.Method parameters in org.infinispan.distexec with type arguments of type Address Modifier and Type Method Description protected List<Address>DefaultExecutorService. randomClusterMembers(List<Address> members, int numNeeded)Deprecated.protected AddressDefaultExecutorService. selectExecutionNode(List<Address> candidates)Deprecated. -
Uses of Address in org.infinispan.distribution
Methods in org.infinispan.distribution that return Address Modifier and Type Method Description AddressLocalizedCacheTopology. getLocalAddress()AddressDistributionManager. getPrimaryLocation(Object key)Deprecated.Since 9.0, please usegetCacheTopology().getDistributionInfo(key)instead.AddressDistributionInfo. primary()Methods in org.infinispan.distribution that return types with arguments of type Address Modifier and Type Method Description Set<Address>LocalizedCacheTopology. getMembersSet()Collection<Address>LocalizedCacheTopology. getWriteOwners(Object key)Collection<Address>LocalizedCacheTopology. getWriteOwners(Collection<?> keys)List<Address>DistributionManager. locate(Object key)Deprecated.Since 9.0, please usegetCacheTopology().getDistributionInfo(key)instead.Set<Address>DistributionManager. locateAll(Collection<Object> keys)Deprecated.Since 9.0, no direct replacement.List<Address>DistributionInfo. readOwners()Collection<Address>DistributionInfo. writeBackups()List<Address>DistributionInfo. writeOwners()Methods in org.infinispan.distribution with parameters of type Address Modifier and Type Method Description voidL1Manager. addRequestor(Object key, Address requestor)Records a request that will be cached in another nodes L1CompletableFuture<?>L1Manager. 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 Address Constructor Description DistributionInfo(int segmentId, Address primary, List<Address> readOwners, List<Address> writeOwners, Collection<Address> writeBackups, Address localAddress)LocalizedCacheTopology(CacheMode cacheMode, CacheTopology cacheTopology, KeyPartitioner keyPartitioner, Address localAddress, boolean connected)Constructor parameters in org.infinispan.distribution with type arguments of type Address Constructor Description DistributionInfo(int segmentId, Address primary, List<Address> readOwners, List<Address> writeOwners, Collection<Address> writeBackups, Address localAddress)DistributionInfo(int segmentId, Address primary, List<Address> readOwners, List<Address> writeOwners, Collection<Address> writeBackups, Address localAddress) -
Uses of Address in org.infinispan.distribution.ch
Methods in org.infinispan.distribution.ch that return Address Modifier and Type Method Description default AddressConsistentHash. locatePrimaryOwner(Object key)Deprecated.Since 9.0, please useLocalizedCacheTopology.getDistribution(Object)instead.AddressConsistentHash. locatePrimaryOwnerForSegment(int segmentId)Methods in org.infinispan.distribution.ch that return types with arguments of type Address Modifier and Type Method Description default Map<Address,Float>ConsistentHash. getCapacityFactors()The capacity factor of each member.List<Address>ConsistentHash. getMembers()Should return the addresses of the nodes used to create this consistent hash.default Set<Address>ConsistentHash. locateAllOwners(Collection<Object> keys)Deprecated.Since 9.0, please useLocalizedCacheTopology.getWriteOwners(Collection)instead.default List<Address>ConsistentHash. locateOwners(Object key)Deprecated.Since 9.0, please useLocalizedCacheTopology.getDistribution(Object)instead.List<Address>ConsistentHash. locateOwnersForSegment(int segmentId)Methods in org.infinispan.distribution.ch with parameters of type Address Modifier and Type Method Description Set<Integer>ConsistentHash. getPrimarySegmentsForOwner(Address owner)Returns the segments that this cache member is the primary owner for.Set<Integer>ConsistentHash. getSegmentsForOwner(Address owner)Returns the segments owned by a cache member.default booleanConsistentHash. isKeyLocalToNode(Address nodeAddress, Object key)Deprecated.Since 9.0, please useLocalizedCacheTopology.isReadOwner(Object)andLocalizedCacheTopology.isWriteOwner(Object)instead.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 Address Modifier and Type Method Description CHConsistentHashFactory. create(Hash hashFunction, int numOwners, int numSegments, List<Address> members, Map<Address,Float> capacityFactors)Create a new consistent hash instance.CHConsistentHashFactory. create(Hash hashFunction, int numOwners, int numSegments, List<Address> members, Map<Address,Float> capacityFactors)Create a new consistent hash instance.default ConsistentHashConsistentHash. remapAddresses(UnaryOperator<Address> remapper)Returns a new ConsistentHash with the addresses remapped according to the providedUnaryOperator.CHConsistentHashFactory. updateMembers(CH baseCH, List<Address> newMembers, Map<Address,Float> capacityFactors)Updates an existing consistent hash instance to remove owners that are not in thenewMemberslist.CHConsistentHashFactory. updateMembers(CH baseCH, List<Address> newMembers, Map<Address,Float> capacityFactors)Updates an existing consistent hash instance to remove owners that are not in thenewMemberslist. -
Uses of Address in org.infinispan.distribution.topologyaware
Methods in org.infinispan.distribution.topologyaware that return types with arguments of type Address Modifier and Type Method Description Collection<Address>TopologyInfo. getMachineNodes(String site, String rack, String machine)Collection<Address>TopologyInfo. getRackNodes(String site, String rack)Collection<Address>TopologyInfo. getSiteNodes(String site)Methods in org.infinispan.distribution.topologyaware with parameters of type Address Modifier and Type Method Description booleanTopologyInfo. duplicateLocation(TopologyLevel level, Collection<Address> addresses, Address candidate, boolean excludeCandidate)floatTopologyInfo. getExpectedOwnedSegments(Address address)floatTopologyInfo. getExpectedPrimarySegments(Address address)ObjectTopologyInfo. getLocationId(TopologyLevel level, Address address)Method parameters in org.infinispan.distribution.topologyaware with type arguments of type Address Modifier and Type Method Description floatTopologyInfo. 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 Address Constructor Description TopologyInfo(int numSegments, int numOwners, Collection<Address> members, Map<Address,Float> capacityFactors)TopologyInfo(int numSegments, int numOwners, Collection<Address> members, Map<Address,Float> capacityFactors) -
Uses of Address in org.infinispan.interceptors.distribution
Methods in org.infinispan.interceptors.distribution with parameters of type Address Modifier and Type Method Description voidBiasedCollector. addPendingAcks(boolean success, Address[] waitFor)default ValidResponseBiasedCollector. addResponse(Address sender, Response response)SuccessfulResponseRemoteGetSingleKeyCollector. addResponse(Address sender, Response response)protected voidBiasedScatteredDistributionInterceptor. completeManyWriteOnPrimaryOriginator(org.infinispan.commands.write.WriteCommand command, Address backup, org.infinispan.interceptors.distribution.CountDownCompletableFuture future)protected voidScatteredDistributionInterceptor. completeManyWriteOnPrimaryOriginator(org.infinispan.commands.write.WriteCommand command, Address backup, org.infinispan.interceptors.distribution.CountDownCompletableFuture future)This is a hook for bias-enabled mode where the primary performs additional RPCs but replication to another node.protected CompletionStage<?>BiasedScatteredDistributionInterceptor. completeSingleWriteOnPrimaryOriginator(org.infinispan.commands.write.DataWriteCommand command, Address backup, CompletionStage<?> rpcFuture)protected CompletionStage<?>ScatteredDistributionInterceptor. completeSingleWriteOnPrimaryOriginator(org.infinispan.commands.write.DataWriteCommand command, Address backup, CompletionStage<?> rpcFuture)This is a hook for bias-enabled mode where the primary performs additional RPCs but replication to another node.protected ObjectBaseDistributionInterceptor. invokeRemotely(InvocationContext ctx, org.infinispan.commands.write.DataWriteCommand command, Address primaryOwner)protected CompletionStage<ValidResponse>BiasedScatteredDistributionInterceptor. manyWriteOnRemotePrimary(Address target, org.infinispan.commands.write.WriteCommand command, CommandAckCollector.MultiTargetCollector multiTargetCollector)protected CompletionStage<ValidResponse>ScatteredDistributionInterceptor. manyWriteOnRemotePrimary(Address target, org.infinispan.commands.write.WriteCommand command, CommandAckCollector.MultiTargetCollector multiTargetCollector)protected CompletionStage<ValidResponse>BiasedScatteredDistributionInterceptor. singleWriteOnRemotePrimary(Address target, org.infinispan.commands.write.DataWriteCommand command)protected CompletionStage<ValidResponse>ScatteredDistributionInterceptor. singleWriteOnRemotePrimary(Address target, org.infinispan.commands.write.DataWriteCommand command)This method is called by a non-owner sending write request to the primary ownerMethod parameters in org.infinispan.interceptors.distribution with type arguments of type Address Modifier and Type Method Description protected voidTxDistributionInterceptor. checkTxCommandResponses(Map<Address,Response> responseMap, org.infinispan.commands.tx.TransactionBoundaryCommand command, org.infinispan.context.impl.TxInvocationContext<org.infinispan.transaction.impl.LocalTransaction> context, Collection<Address> recipients)protected voidTxDistributionInterceptor. checkTxCommandResponses(Map<Address,Response> responseMap, org.infinispan.commands.tx.TransactionBoundaryCommand command, org.infinispan.context.impl.TxInvocationContext<org.infinispan.transaction.impl.LocalTransaction> context, Collection<Address> recipients)CompletionStage<Void>BaseDistributionInterceptor.ReadManyCommandHelper. fetchRequiredKeys(LocalizedCacheTopology cacheTopology, Map<Address,List<Object>> requestedKeys, List<Object> availableKeys, InvocationContext ctx, C command)CompletionStage<Void>BaseDistributionInterceptor.ReadOnlyManyHelper. fetchRequiredKeys(LocalizedCacheTopology cacheTopology, Map<Address,List<Object>> requestedKeys, List<Object> availableKeys, InvocationContext ctx, org.infinispan.commands.functional.ReadOnlyManyCommand command)protected CompletionStage<Object>TxDistributionInterceptor. prepareOnAffectedNodes(org.infinispan.context.impl.TxInvocationContext<?> ctx, org.infinispan.commands.tx.PrepareCommand command, Collection<Address> recipients)protected CompletionStage<Object>VersionedDistributionInterceptor. prepareOnAffectedNodes(org.infinispan.context.impl.TxInvocationContext<?> ctx, org.infinispan.commands.tx.PrepareCommand command, Collection<Address> recipients) -
Uses of Address in org.infinispan.interceptors.locking
Methods in org.infinispan.interceptors.locking that return Address Modifier and Type Method Description AddressClusteringDependentLogic.AbstractClusteringDependentLogic. getAddress()AddressClusteringDependentLogic. getAddress()AddressClusteringDependentLogic.LocalLogic. getAddress()default AddressClusteringDependentLogic. getPrimaryOwner(Object key)Deprecated.Since 9.0, please usegetCacheTopology().getDistributionInfo(key).primary()instead.Methods in org.infinispan.interceptors.locking that return types with arguments of type Address Modifier and Type Method Description default Collection<Address>ClusteringDependentLogic. getOwners(Object key)Deprecated.Since 9.0, please usegetCacheTopology().getWriteOwners(key)instead.default Collection<Address>ClusteringDependentLogic. getOwners(Collection<Object> keys)Deprecated.Since 9.0, please usegetCacheTopology().getWriteOwners(keys)instead.Collection<Address>ClusteringDependentLogic.ReplicationLogic. getOwners(Object key)Collection<Address>ClusteringDependentLogic.ReplicationLogic. getOwners(Collection<Object> keys) -
Uses of Address in org.infinispan.interceptors.totalorder
Method parameters in org.infinispan.interceptors.totalorder with type arguments of type Address Modifier and Type Method Description protected CompletionStage<Object>TotalOrderDistributionInterceptor. prepareOnAffectedNodes(org.infinispan.context.impl.TxInvocationContext<?> ctx, org.infinispan.commands.tx.PrepareCommand command, Collection<Address> recipients)protected CompletionStage<Object>TotalOrderVersionedDistributionInterceptor. prepareOnAffectedNodes(org.infinispan.context.impl.TxInvocationContext<?> ctx, org.infinispan.commands.tx.PrepareCommand command, Collection<Address> recipients) -
Uses of Address in org.infinispan.manager
Methods in org.infinispan.manager that return Address Modifier and Type Method Description AddressDefaultCacheManager. getAddress()Warning: the address may benullbefore the first clustered cache starts and after all the clustered caches have been stopped.AddressEmbeddedCacheManager. getAddress()Warning: the address may benullbefore the first clustered cache starts and after all the clustered caches have been stopped.AddressDefaultCacheManager. getCoordinator()AddressEmbeddedCacheManager. getCoordinator()Methods in org.infinispan.manager that return types with arguments of type Address Modifier and Type Method Description List<Address>DefaultCacheManager. getMembers()List<Address>EmbeddedCacheManager. getMembers()Method parameters in org.infinispan.manager with type arguments of type Address Modifier and Type Method Description ClusterExecutorClusterExecutor. filterTargets(Collection<Address> addresses)Allows for filtering of address nodes by only allowing addresses in this collection from being contacted.ClusterExecutorClusterExecutor. filterTargets(Predicate<? super Address> predicate)Allows for filtering of address nodes dynamically per invocation.ClusterExecutorClusterExecutor. 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.notifications.cachelistener.cluster
Methods in org.infinispan.notifications.cachelistener.cluster that return Address Modifier and Type Method Description AddressRemoteClusterListener. getOwnerAddress()Methods in org.infinispan.notifications.cachelistener.cluster with parameters of type Address Modifier and Type Method Description voidClusterEventManager. addEvents(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 Address Constructor Description ClusterListenerReplicateCallable(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, DistributedExecutorService distExecService, CacheNotifier cacheNotifier, CacheManagerNotifier cacheManagerNotifier, ClusterEventManager eventManager, 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 Address Modifier and Type Method Description Collection<Address>DataRehashedEvent. getMembersAtEnd()Collection<Address>DataRehashedEvent. getMembersAtStart() -
Uses of Address in org.infinispan.notifications.cachemanagerlistener
Methods in org.infinispan.notifications.cachemanagerlistener with parameters of type Address Modifier and Type Method Description voidCacheManagerNotifier. notifyMerge(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId, List<List<Address>> subgroupsMerged)voidCacheManagerNotifierImpl. notifyMerge(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId, List<List<Address>> subgroupsMerged)voidCacheManagerNotifier. notifyViewChange(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId)Notifies all registered listeners of a viewChange event.voidCacheManagerNotifierImpl. notifyViewChange(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId)Method parameters in org.infinispan.notifications.cachemanagerlistener with type arguments of type Address Modifier and Type Method Description voidCacheManagerNotifier. notifyMerge(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId, List<List<Address>> subgroupsMerged)voidCacheManagerNotifierImpl. notifyMerge(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId, List<List<Address>> subgroupsMerged)voidCacheManagerNotifier. notifyViewChange(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId)Notifies all registered listeners of a viewChange event.voidCacheManagerNotifierImpl. 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 Address Modifier and Type Method Description AddressViewChangedEvent. getLocalAddress()Methods in org.infinispan.notifications.cachemanagerlistener.event that return types with arguments of type Address Modifier and Type Method Description List<Address>ViewChangedEvent. getNewMembers()Gets the current list of members.List<Address>ViewChangedEvent. getOldMembers()Gets the previous list of members.List<List<Address>>MergeEvent. getSubgroupsMerged() -
Uses of Address in org.infinispan.query.affinity
Methods in org.infinispan.query.affinity that return Address Modifier and Type Method Description AddressShardAllocationManagerImpl. getOwner(String shardId)AddressShardAllocatorManager. getOwner(String shardId)Methods in org.infinispan.query.affinity with parameters of type Address Modifier and Type Method Description Set<String>ShardAllocationManagerImpl. getShardsForModification(Address address)Set<String>ShardAllocatorManager. getShardsForModification(Address address) -
Uses of Address in org.infinispan.query.clustered
Fields in org.infinispan.query.clustered declared as Address Modifier and Type Field Description AddressNodeTopDocs. addressConstructors in org.infinispan.query.clustered with parameters of type Address Constructor Description NodeTopDocs(Address address, org.apache.lucene.search.TopDocs topDocs)NodeTopDocs(Address address, org.apache.lucene.search.TopDocs topDocs, Object[] keys, Object[] projections) -
Uses of Address in org.infinispan.remoting
Methods in org.infinispan.remoting with parameters of type Address Modifier and Type Method Description static LocalInvocationLocalInvocation. newInstance(ResponseGenerator responseGenerator, org.infinispan.commands.remote.CacheRpcCommand command, org.infinispan.commands.CommandsFactory commandsFactory, Address self) -
Uses of Address in org.infinispan.remoting.inboundhandler
Methods in org.infinispan.remoting.inboundhandler with parameters of type Address Modifier and Type Method Description voidGlobalInboundInvocationHandler. handleFromCluster(Address origin, org.infinispan.commands.ReplicableCommand command, Reply reply, DeliverOrder order)voidInboundInvocationHandler. handleFromCluster(Address origin, org.infinispan.commands.ReplicableCommand command, Reply reply, DeliverOrder order)Handles theReplicableCommandfrom other node belonging to local site. -
Uses of Address in org.infinispan.remoting.responses
Methods in org.infinispan.remoting.responses that return Address Modifier and Type Method Description Address[]BiasRevocationResponse. getWaitList()Methods in org.infinispan.remoting.responses with parameters of type Address Modifier and Type Method Description booleanClusteredGetResponseValidityFilter. isAcceptable(Response response, Address address)booleanIgnoreExtraResponsesValidityFilter. isAcceptable(Response response, Address address)Constructors in org.infinispan.remoting.responses with parameters of type Address Constructor Description BiasRevocationResponse(Object responseValue, Address[] waitFor)ClusteredGetResponseValidityFilter(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 Address Constructor Description ClusteredGetResponseValidityFilter(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 Address Modifier and Type Method Description AddressRpcManager. getAddress()Returns the address associated with this RpcManager or null if not part of the cluster.AddressRpcManagerImpl. getAddress()Methods in org.infinispan.remoting.rpc that return types with arguments of type Address Modifier and Type Method Description List<Address>RpcManager. getMembers()Returns members of a cluster scoped to the cache owning this RpcManager.List<Address>RpcManagerImpl. getMembers()Map<Address,Response>RpcManager. invokeRemotely(Collection<Address> recipients, org.infinispan.commands.ReplicableCommand rpc, RpcOptions options)Deprecated.Since 9.2, please useRpcManager.invokeCommand(Collection, ReplicableCommand, ResponseCollector, RpcOptions)instead.Map<Address,Response>RpcManager. invokeRemotely(Map<Address,org.infinispan.commands.ReplicableCommand> rpcs, RpcOptions options)Deprecated.Since 9.2, please useRpcManager.invokeCommands(Collection, Function, ResponseCollector, RpcOptions)instead.Map<Address,Response>RpcManagerImpl. invokeRemotely(Collection<Address> recipients, org.infinispan.commands.ReplicableCommand rpc, RpcOptions options)Map<Address,Response>RpcManagerImpl. invokeRemotely(Map<Address,org.infinispan.commands.ReplicableCommand> rpcs, RpcOptions options)CompletableFuture<Map<Address,Response>>RpcManager. invokeRemotelyAsync(Collection<Address> recipients, org.infinispan.commands.ReplicableCommand rpc, RpcOptions options)Invokes a command on remote nodes.CompletableFuture<Map<Address,Response>>RpcManagerImpl. invokeRemotelyAsync(Collection<Address> recipients, org.infinispan.commands.ReplicableCommand rpc, RpcOptions options)Methods in org.infinispan.remoting.rpc with parameters of type Address Modifier and Type Method Description <T> CompletionStage<T>RpcManager. invokeCommand(Address target, org.infinispan.commands.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, org.infinispan.commands.ReplicableCommand command, ResponseCollector<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.ReplicableCommand command, DeliverOrder deliverOrder)Asynchronously sends theReplicableCommandto the destination using the specifiedDeliverOrder.voidRpcManagerImpl. sendTo(Address destination, org.infinispan.commands.ReplicableCommand command, DeliverOrder deliverOrder)Method parameters in org.infinispan.remoting.rpc with type arguments of type Address Modifier and Type Method Description <T> CompletionStage<T>RpcManager. invokeCommand(Collection<Address> targets, org.infinispan.commands.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, org.infinispan.commands.ReplicableCommand command, ResponseCollector<T> collector, RpcOptions rpcOptions)<T> CompletionStage<T>RpcManager. invokeCommands(Collection<Address> targets, Function<Address,org.infinispan.commands.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,org.infinispan.commands.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,org.infinispan.commands.ReplicableCommand> commandGenerator, ResponseCollector<T> collector, RpcOptions rpcOptions)<T> CompletionStage<T>RpcManagerImpl. invokeCommands(Collection<Address> targets, Function<Address,org.infinispan.commands.ReplicableCommand> commandGenerator, ResponseCollector<T> collector, RpcOptions rpcOptions)<T> CompletionStage<T>RpcManager. invokeCommandStaggered(Collection<Address> targets, org.infinispan.commands.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, org.infinispan.commands.ReplicableCommand command, ResponseCollector<T> collector, RpcOptions rpcOptions)Map<Address,Response>RpcManager. invokeRemotely(Collection<Address> recipients, org.infinispan.commands.ReplicableCommand rpc, RpcOptions options)Deprecated.Since 9.2, please useRpcManager.invokeCommand(Collection, ReplicableCommand, ResponseCollector, RpcOptions)instead.Map<Address,Response>RpcManager. invokeRemotely(Map<Address,org.infinispan.commands.ReplicableCommand> rpcs, RpcOptions options)Deprecated.Since 9.2, please useRpcManager.invokeCommands(Collection, Function, ResponseCollector, RpcOptions)instead.Map<Address,Response>RpcManagerImpl. invokeRemotely(Collection<Address> recipients, org.infinispan.commands.ReplicableCommand rpc, RpcOptions options)Map<Address,Response>RpcManagerImpl. invokeRemotely(Map<Address,org.infinispan.commands.ReplicableCommand> rpcs, RpcOptions options)CompletableFuture<Map<Address,Response>>RpcManager. invokeRemotelyAsync(Collection<Address> recipients, org.infinispan.commands.ReplicableCommand rpc, RpcOptions options)Invokes a command on remote nodes.CompletableFuture<Map<Address,Response>>RpcManagerImpl. invokeRemotelyAsync(Collection<Address> recipients, org.infinispan.commands.ReplicableCommand rpc, RpcOptions options)voidRpcManager. sendToMany(Collection<Address> destinations, org.infinispan.commands.ReplicableCommand command, DeliverOrder deliverOrder)Asynchronously sends theReplicableCommandto the set of destination using the specifiedDeliverOrder.voidRpcManagerImpl. sendToMany(Collection<Address> destinations, org.infinispan.commands.ReplicableCommand command, DeliverOrder deliverOrder) -
Uses of Address in org.infinispan.remoting.transport
Subinterfaces of Address in org.infinispan.remoting.transport Modifier and Type Interface Description interfaceTopologyAwareAddressWraps a TopologyUUID JGroups addressClasses in org.infinispan.remoting.transport that implement Address Modifier and Type Class Description classLocalModeAddressRepresents the local node's address.Fields in org.infinispan.remoting.transport declared as Address Modifier and Type Field Description static Address[]Address. EMPTY_ARRAYstatic AddressLocalModeAddress. INSTANCEMethods in org.infinispan.remoting.transport that return Address Modifier and Type Method Description AddressAbstractDelegatingTransport. getAddress()AddressTransport. getAddress()Retrieves the current cache instance's network addressAddressAbstractDelegatingTransport. getCoordinator()AddressTransport. getCoordinator()Methods in org.infinispan.remoting.transport that return types with arguments of type Address Modifier and Type Method Description protected Map<Address,Response>AbstractDelegatingTransport. afterInvokeRemotely(org.infinispan.commands.ReplicableCommand command, Map<Address,Response> responseMap)method invoked after a successful remote invocation.List<Address>AbstractDelegatingTransport. getMembers()List<Address>Transport. getMembers()Returns a list of members in the current cluster view.List<Address>AbstractDelegatingTransport. getPhysicalAddresses()List<Address>Transport. getPhysicalAddresses()Retrieves the current cache instance's physical network addresses.Map<Address,Response>AbstractDelegatingTransport. invokeRemotely(Collection<Address> recipients, org.infinispan.commands.ReplicableCommand rpcCommand, ResponseMode mode, long timeout, ResponseFilter responseFilter, DeliverOrder deliverOrder, boolean anycast)Map<Address,Response>AbstractDelegatingTransport. invokeRemotely(Map<Address,org.infinispan.commands.ReplicableCommand> rpcCommands, ResponseMode mode, long timeout, boolean usePriorityQueue, ResponseFilter responseFilter, boolean totalOrder, boolean anycast)Map<Address,Response>AbstractDelegatingTransport. invokeRemotely(Map<Address,org.infinispan.commands.ReplicableCommand> rpcCommands, ResponseMode mode, long timeout, ResponseFilter responseFilter, DeliverOrder deliverOrder, boolean anycast)default Map<Address,Response>Transport. invokeRemotely(Collection<Address> recipients, org.infinispan.commands.ReplicableCommand rpcCommand, ResponseMode mode, long timeout, ResponseFilter responseFilter, DeliverOrder deliverOrder, boolean anycast)Deprecated.Since 9.2, please useTransport.invokeCommand(Collection, ReplicableCommand, ResponseCollector, DeliverOrder, long, TimeUnit)instead.default Map<Address,Response>Transport. invokeRemotely(Map<Address,org.infinispan.commands.ReplicableCommand> rpcCommands, ResponseMode mode, long timeout, boolean usePriorityQueue, ResponseFilter responseFilter, boolean totalOrder, boolean anycast)Deprecated.default Map<Address,Response>Transport. invokeRemotely(Map<Address,org.infinispan.commands.ReplicableCommand> rpcCommands, ResponseMode mode, long timeout, ResponseFilter responseFilter, DeliverOrder deliverOrder, boolean anycast)Deprecated.Since 9.2, please useTransport.invokeRemotelyAsync(Collection, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder, boolean)instead.CompletableFuture<Map<Address,Response>>AbstractDelegatingTransport. invokeRemotelyAsync(Collection<Address> recipients, org.infinispan.commands.ReplicableCommand rpcCommand, ResponseMode mode, long timeout, ResponseFilter responseFilter, DeliverOrder deliverOrder, boolean anycast)CompletableFuture<Map<Address,Response>>Transport. invokeRemotelyAsync(Collection<Address> recipients, org.infinispan.commands.ReplicableCommand rpcCommand, ResponseMode mode, long timeout, ResponseFilter responseFilter, DeliverOrder deliverOrder, boolean anycast)Methods in org.infinispan.remoting.transport with parameters of type Address Modifier and Type Method Description protected abstract TValidResponseCollector. addException(Address sender, Exception exception)Process an exception from a target.TResponseCollector. addResponse(Address sender, Response response)Called when a response is received, or when a target node becomes unavailable.TValidResponseCollector. addResponse(Address sender, Response response)TValidSingleResponseCollector. 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.ResponseAbstractTransport. checkResponse(Object responseObject, Address sender, boolean ignoreCacheNotFoundResponse)Deprecated.intLocalModeAddress. compareTo(Address o)<T> CompletionStage<T>AbstractDelegatingTransport. invokeCommand(Address target, org.infinispan.commands.ReplicableCommand command, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit unit)default <T> CompletionStage<T>Transport. invokeCommand(Address target, org.infinispan.commands.ReplicableCommand command, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit unit)Invoke a command on a single node and pass the response to aResponseCollector.static SuspectExceptionResponseCollectors. remoteNodeSuspected(Address sender)voidAbstractDelegatingTransport. sendTo(Address destination, org.infinispan.commands.ReplicableCommand rpcCommand, DeliverOrder deliverOrder)voidTransport. sendTo(Address destination, org.infinispan.commands.ReplicableCommand rpcCommand, DeliverOrder deliverOrder)Asynchronously sends theReplicableCommandto the destination using the specifiedDeliverOrder.protected abstract TValidSingleResponseCollector. targetNotFound(Address sender)protected TValidSingleResponseCollector. withException(Address sender, Exception exception)protected abstract TValidSingleResponseCollector. withValidResponse(Address sender, ValidResponse response)static CacheExceptionResponseCollectors. wrapRemoteException(Address sender, Throwable exception)Method parameters in org.infinispan.remoting.transport with type arguments of type Address Modifier and Type Method Description protected Map<Address,Response>AbstractDelegatingTransport. afterInvokeRemotely(org.infinispan.commands.ReplicableCommand command, Map<Address,Response> responseMap)method invoked after a successful remote invocation.<T> CompletionStage<T>AbstractDelegatingTransport. invokeCommand(Collection<Address> targets, org.infinispan.commands.ReplicableCommand command, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit unit)default <T> CompletionStage<T>Transport. invokeCommand(Collection<Address> targets, org.infinispan.commands.ReplicableCommand command, ResponseCollector<T> collector, 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, org.infinispan.commands.ReplicableCommand command, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit unit)Invoke a command on all the nodes in the cluster and pass the responses to aResponseCollector.<T> CompletionStage<T>AbstractDelegatingTransport. invokeCommands(Collection<Address> targets, Function<Address,org.infinispan.commands.ReplicableCommand> commandGenerator, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit timeUnit)<T> CompletionStage<T>AbstractDelegatingTransport. invokeCommands(Collection<Address> targets, Function<Address,org.infinispan.commands.ReplicableCommand> commandGenerator, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit timeUnit)default <T> CompletionStage<T>Transport. invokeCommands(Collection<Address> targets, Function<Address,org.infinispan.commands.ReplicableCommand> commandGenerator, ResponseCollector<T> responseCollector, long timeout, DeliverOrder deliverOrder)Deprecated.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,org.infinispan.commands.ReplicableCommand> commandGenerator, ResponseCollector<T> responseCollector, long timeout, DeliverOrder deliverOrder)Deprecated.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,org.infinispan.commands.ReplicableCommand> commandGenerator, ResponseCollector<T> collector, 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,org.infinispan.commands.ReplicableCommand> commandGenerator, ResponseCollector<T> collector, 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, org.infinispan.commands.ReplicableCommand command, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit unit)default <T> CompletionStage<T>Transport. invokeCommandStaggered(Collection<Address> targets, org.infinispan.commands.ReplicableCommand command, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit unit)Invoke a command on a collection of nodes and pass the responses to aResponseCollector.Map<Address,Response>AbstractDelegatingTransport. invokeRemotely(Collection<Address> recipients, org.infinispan.commands.ReplicableCommand rpcCommand, ResponseMode mode, long timeout, ResponseFilter responseFilter, DeliverOrder deliverOrder, boolean anycast)Map<Address,Response>AbstractDelegatingTransport. invokeRemotely(Map<Address,org.infinispan.commands.ReplicableCommand> rpcCommands, ResponseMode mode, long timeout, boolean usePriorityQueue, ResponseFilter responseFilter, boolean totalOrder, boolean anycast)Map<Address,Response>AbstractDelegatingTransport. invokeRemotely(Map<Address,org.infinispan.commands.ReplicableCommand> rpcCommands, ResponseMode mode, long timeout, ResponseFilter responseFilter, DeliverOrder deliverOrder, boolean anycast)default Map<Address,Response>Transport. invokeRemotely(Collection<Address> recipients, org.infinispan.commands.ReplicableCommand rpcCommand, ResponseMode mode, long timeout, ResponseFilter responseFilter, DeliverOrder deliverOrder, boolean anycast)Deprecated.Since 9.2, please useTransport.invokeCommand(Collection, ReplicableCommand, ResponseCollector, DeliverOrder, long, TimeUnit)instead.default Map<Address,Response>Transport. invokeRemotely(Map<Address,org.infinispan.commands.ReplicableCommand> rpcCommands, ResponseMode mode, long timeout, boolean usePriorityQueue, ResponseFilter responseFilter, boolean totalOrder, boolean anycast)Deprecated.default Map<Address,Response>Transport. invokeRemotely(Map<Address,org.infinispan.commands.ReplicableCommand> rpcCommands, ResponseMode mode, long timeout, ResponseFilter responseFilter, DeliverOrder deliverOrder, boolean anycast)Deprecated.Since 9.2, please useTransport.invokeRemotelyAsync(Collection, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder, boolean)instead.CompletableFuture<Map<Address,Response>>AbstractDelegatingTransport. invokeRemotelyAsync(Collection<Address> recipients, org.infinispan.commands.ReplicableCommand rpcCommand, ResponseMode mode, long timeout, ResponseFilter responseFilter, DeliverOrder deliverOrder, boolean anycast)CompletableFuture<Map<Address,Response>>Transport. invokeRemotelyAsync(Collection<Address> recipients, org.infinispan.commands.ReplicableCommand rpcCommand, ResponseMode mode, long timeout, ResponseFilter responseFilter, DeliverOrder deliverOrder, boolean anycast)voidAbstractDelegatingTransport. sendToMany(Collection<Address> destinations, org.infinispan.commands.ReplicableCommand rpcCommand, DeliverOrder deliverOrder)voidTransport. sendToMany(Collection<Address> destinations, org.infinispan.commands.ReplicableCommand rpcCommand, DeliverOrder deliverOrder)Asynchronously sends theReplicableCommandto the set of destination using the specifiedDeliverOrder. -
Uses of Address in org.infinispan.remoting.transport.jgroups
Classes in org.infinispan.remoting.transport.jgroups that implement Address Modifier and Type Class Description classJGroupsAddressAn encapsulation of a JGroups AddressclassJGroupsTopologyAwareAddressAn encapsulation of a JGroupsExtendedUUIDwith a site id, a rack id, and a machine id.Fields in org.infinispan.remoting.transport.jgroups declared as Address Modifier and Type Field Description protected AddressJGroupsTransport. addressprotected AddressJGroupsTransport. physicalAddressMethods in org.infinispan.remoting.transport.jgroups that return Address Modifier and Type Method Description static AddressJGroupsAddressCache. fromJGroupsAddress(org.jgroups.Address jgroupsAddress)AddressJGroupsTransport. getAddress()AddressClusterView. getCoordinator()AddressJGroupsTransport. getCoordinator()AddressSuspectException. getSuspect()Methods in org.infinispan.remoting.transport.jgroups that return types with arguments of type Address Modifier and Type Method Description List<Address>ClusterView. getMembers()List<Address>JGroupsTransport. getMembers()Set<Address>ClusterView. getMembersSet()List<Address>JGroupsTransport. getPhysicalAddresses()Map<Address,Response>JGroupsTransport. invokeRemotely(Map<Address,org.infinispan.commands.ReplicableCommand> commands, ResponseMode mode, long timeout, ResponseFilter responseFilter, DeliverOrder deliverOrder, boolean anycast)Deprecated.CompletableFuture<Map<Address,Response>>JGroupsTransport. invokeRemotelyAsync(Collection<Address> recipients, org.infinispan.commands.ReplicableCommand command, ResponseMode mode, long timeout, ResponseFilter responseFilter, DeliverOrder deliverOrder, boolean anycast)Methods in org.infinispan.remoting.transport.jgroups with parameters of type Address Modifier and Type Method Description intJGroupsAddress. compareTo(Address o)<T> CompletionStage<T>JGroupsTransport. invokeCommand(Address target, org.infinispan.commands.ReplicableCommand command, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit unit)voidSingleSiteRequest. onResponse(Address sender, Response response)voidStaggeredRequest. onResponse(Address sender, Response response)voidJGroupsTransport. sendTo(Address destination, org.infinispan.commands.ReplicableCommand command, DeliverOrder deliverOrder)Method parameters in org.infinispan.remoting.transport.jgroups with type arguments of type Address Modifier and Type Method Description <T> CompletionStage<T>JGroupsTransport. invokeCommand(Collection<Address> targets, org.infinispan.commands.ReplicableCommand command, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit unit)<T> CompletionStage<T>JGroupsTransport. invokeCommandOnAll(Collection<Address> requiredTargets, org.infinispan.commands.ReplicableCommand command, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit unit)<T> CompletionStage<T>JGroupsTransport. invokeCommands(Collection<Address> targets, Function<Address,org.infinispan.commands.ReplicableCommand> commandGenerator, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit timeUnit)<T> CompletionStage<T>JGroupsTransport. invokeCommands(Collection<Address> targets, Function<Address,org.infinispan.commands.ReplicableCommand> commandGenerator, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit timeUnit)<T> CompletionStage<T>JGroupsTransport. invokeCommandStaggered(Collection<Address> targets, org.infinispan.commands.ReplicableCommand command, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit unit)Map<Address,Response>JGroupsTransport. invokeRemotely(Map<Address,org.infinispan.commands.ReplicableCommand> commands, ResponseMode mode, long timeout, ResponseFilter responseFilter, DeliverOrder deliverOrder, boolean anycast)Deprecated.CompletableFuture<Map<Address,Response>>JGroupsTransport. invokeRemotelyAsync(Collection<Address> recipients, org.infinispan.commands.ReplicableCommand command, ResponseMode mode, long timeout, ResponseFilter responseFilter, DeliverOrder deliverOrder, boolean anycast)booleanSingleSiteRequest. onNewView(Set<Address> members)voidJGroupsTransport. sendToMany(Collection<Address> targets, org.infinispan.commands.ReplicableCommand command, DeliverOrder deliverOrder)Constructors in org.infinispan.remoting.transport.jgroups with parameters of type Address Constructor Description SuspectException(String msg, Address suspect)SuspectException(String msg, Address suspect, Throwable cause) -
Uses of Address in org.infinispan.scattered
Methods in org.infinispan.scattered that return types with arguments of type Address Modifier and Type Method Description List<Address>BiasManager.Revocation. biased()List<Address>BiasManager. getRemoteBias(Object key)Methods in org.infinispan.scattered with parameters of type Address Modifier and Type Method Description voidBiasManager. 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.voidScatteredStateProvider. startKeysTransfer(IntSet segments, Address origin)BiasManager.RevocationBiasManager. 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.security.actions
Methods in org.infinispan.security.actions that return Address Modifier and Type Method Description AddressGetCacheManagerAddress. run()AddressGetCacheManagerCoordinatorAddress. run() -
Uses of Address in org.infinispan.server.hotrod
Classes in org.infinispan.server.hotrod that implement Address Modifier and Type Class Description classServerAddressA Hot Rod server addressMethods in org.infinispan.server.hotrod that return types with arguments of type Address Modifier and Type Method Description Cache<Address,ServerAddress>HotRodServer. getAddressCache()Methods in org.infinispan.server.hotrod with parameters of type Address Modifier and Type Method Description intServerAddress. compareTo(Address o)Method parameters in org.infinispan.server.hotrod with type arguments of type Address Modifier and Type Method Description protected org.infinispan.server.hotrod.AbstractHashDistAwareResponseAbstractEncoder1x. createHashDistAwareResp(int topologyId, Map<Address,ServerAddress> serverEndpointsMap, Configuration cfg)protected org.infinispan.server.hotrod.AbstractHashDistAwareResponseAbstractTopologyAwareEncoder1x. createHashDistAwareResp(int topologyId, Map<Address,ServerAddress> serverEndpointsMap, Configuration cfg) -
Uses of Address in org.infinispan.server.hotrod.tx
Methods in org.infinispan.server.hotrod.tx with parameters of type Address Modifier and Type Method Description booleanPrepareCoordinator. isAlive(Address address)Method parameters in org.infinispan.server.hotrod.tx with type arguments of type Address Modifier and Type Method Description booleanServerTransactionOriginatorChecker. isOriginatorMissing(GlobalTransaction gtx, Collection<Address> liveMembers) -
Uses of Address in org.infinispan.server.hotrod.tx.table
Classes in org.infinispan.server.hotrod.tx.table that implement Address Modifier and Type Class Description classClientAddressAAddressimplementation for a client transaction.Methods in org.infinispan.server.hotrod.tx.table that return Address Modifier and Type Method Description AddressTxState. getOriginator()Methods in org.infinispan.server.hotrod.tx.table with parameters of type Address Modifier and Type Method Description intClientAddress. compareTo(Address o)Constructors in org.infinispan.server.hotrod.tx.table with parameters of type Address Constructor Description ClientAddress(Address localAddress)PerCacheTxTable(Address address) -
Uses of Address in org.infinispan.statetransfer
Methods in org.infinispan.statetransfer that return Address Modifier and Type Method Description AddressOutboundTransferTask. getDestination()AddressInboundTransferTask. getSource()Methods in org.infinispan.statetransfer that return types with arguments of type Address Modifier and Type Method Description Map<Address,Response>StateTransferManager. forwardCommandIfNeeded(org.infinispan.commands.TopologyAffectedCommand command, Set<Object> affectedKeys, Address origin)If there is an state transfer happening at the moment, this method forwards the supplied command to the nodes that are new owners of the data, in order to assure consistency.Map<Address,Response>StateTransferManagerImpl. forwardCommandIfNeeded(org.infinispan.commands.TopologyAffectedCommand command, Set<Object> affectedKeys, Address origin)Methods in org.infinispan.statetransfer with parameters of type Address Modifier and Type Method Description voidStateConsumer. applyState(Address sender, int topologyId, boolean pushTransfer, Collection<StateChunk> stateChunks)voidStateConsumerImpl. applyState(Address sender, int topologyId, boolean pushTransfer, Collection<StateChunk> stateChunks)voidStateProvider. cancelOutboundTransfer(Address destination, int topologyId, IntSet segments)Cancel sending of cache entries that belong to the given set of segments.voidStateProviderImpl. cancelOutboundTransfer(Address destination, int topologyId, IntSet segments)Map<Address,Response>StateTransferManager. forwardCommandIfNeeded(org.infinispan.commands.TopologyAffectedCommand command, Set<Object> affectedKeys, Address origin)If there is an state transfer happening at the moment, this method forwards the supplied command to the nodes that are new owners of the data, in order to assure consistency.Map<Address,Response>StateTransferManagerImpl. forwardCommandIfNeeded(org.infinispan.commands.TopologyAffectedCommand command, Set<Object> affectedKeys, Address origin)List<TransactionInfo>StateProvider. getTransactionsForSegments(Address destination, int topologyId, IntSet segments)Gets the list of transactions that affect keys from the given segments.List<TransactionInfo>StateProviderImpl. getTransactionsForSegments(Address destination, int requestTopologyId, IntSet segments)voidStateProvider. startOutboundTransfer(Address destination, int topologyId, IntSet segments, boolean applyState)Start to send cache entries that belong to the given set of segments.voidStateProviderImpl. startOutboundTransfer(Address destination, int requestTopologyId, IntSet segments, boolean applyState)Constructors in org.infinispan.statetransfer with parameters of type Address Constructor Description InboundTransferTask(IntSet segments, Address source, int topologyId, RpcManager rpcManager, org.infinispan.commands.CommandsFactory commandsFactory, long timeout, String cacheName, boolean applyState)OutboundTransferTask(Address destination, IntSet segments, int segmentCount, int chunkSize, int topologyId, KeyPartitioner keyPartitioner, Consumer<OutboundTransferTask> onCompletion, Consumer<List<StateChunk>> onChunkReplicated, BiFunction<InternalCacheEntry,org.infinispan.container.impl.InternalEntryFactory,InternalCacheEntry> mapEntryFromDataContainer, BiFunction<MarshalledEntry,org.infinispan.container.impl.InternalEntryFactory,InternalCacheEntry> mapEntryFromStore, org.infinispan.container.impl.InternalDataContainer dataContainer, PersistenceManager persistenceManager, RpcManager rpcManager, org.infinispan.commands.CommandsFactory commandsFactory, org.infinispan.container.impl.InternalEntryFactory ef, long timeout, String cacheName, boolean applyState, boolean pushTransfer)StateRequestCommand(ByteString cacheName, StateRequestCommand.Type type, Address origin, int topologyId, IntSet segments)StateResponseCommand(ByteString cacheName, Address origin, int topologyId, Collection<StateChunk> stateChunks, boolean applyState, boolean pushTransfer) -
Uses of Address in org.infinispan.stats.wrappers
Methods in org.infinispan.stats.wrappers that return Address Modifier and Type Method Description AddressExtendedStatisticRpcManager. getAddress()Methods in org.infinispan.stats.wrappers that return types with arguments of type Address Modifier and Type Method Description List<Address>ExtendedStatisticRpcManager. getMembers()Map<Address,Response>ExtendedStatisticRpcManager. invokeRemotely(Collection<Address> recipients, org.infinispan.commands.ReplicableCommand rpc, RpcOptions options)Map<Address,Response>ExtendedStatisticRpcManager. invokeRemotely(Map<Address,org.infinispan.commands.ReplicableCommand> rpcs, RpcOptions options)CompletableFuture<Map<Address,Response>>ExtendedStatisticRpcManager. invokeRemotelyAsync(Collection<Address> recipients, org.infinispan.commands.ReplicableCommand rpc, RpcOptions options)Methods in org.infinispan.stats.wrappers with parameters of type Address Modifier and Type Method Description <T> CompletionStage<T>ExtendedStatisticRpcManager. invokeCommand(Address target, org.infinispan.commands.ReplicableCommand command, ResponseCollector<T> collector, RpcOptions rpcOptions)voidExtendedStatisticRpcManager. sendTo(Address destination, org.infinispan.commands.ReplicableCommand command, DeliverOrder deliverOrder)Method parameters in org.infinispan.stats.wrappers with type arguments of type Address Modifier and Type Method Description <T> CompletionStage<T>ExtendedStatisticRpcManager. invokeCommand(Collection<Address> targets, org.infinispan.commands.ReplicableCommand command, ResponseCollector<T> collector, RpcOptions rpcOptions)<T> CompletionStage<T>ExtendedStatisticRpcManager. invokeCommands(Collection<Address> targets, Function<Address,org.infinispan.commands.ReplicableCommand> commandGenerator, ResponseCollector<T> collector, RpcOptions rpcOptions)<T> CompletionStage<T>ExtendedStatisticRpcManager. invokeCommands(Collection<Address> targets, Function<Address,org.infinispan.commands.ReplicableCommand> commandGenerator, ResponseCollector<T> collector, RpcOptions rpcOptions)<T> CompletionStage<T>ExtendedStatisticRpcManager. invokeCommandStaggered(Collection<Address> targets, org.infinispan.commands.ReplicableCommand command, ResponseCollector<T> collector, RpcOptions rpcOptions)Map<Address,Response>ExtendedStatisticRpcManager. invokeRemotely(Collection<Address> recipients, org.infinispan.commands.ReplicableCommand rpc, RpcOptions options)Map<Address,Response>ExtendedStatisticRpcManager. invokeRemotely(Map<Address,org.infinispan.commands.ReplicableCommand> rpcs, RpcOptions options)CompletableFuture<Map<Address,Response>>ExtendedStatisticRpcManager. invokeRemotelyAsync(Collection<Address> recipients, org.infinispan.commands.ReplicableCommand rpc, RpcOptions options)voidExtendedStatisticRpcManager. sendToMany(Collection<Address> destinations, org.infinispan.commands.ReplicableCommand command, DeliverOrder deliverOrder) -
Uses of Address in org.infinispan.topology
Classes in org.infinispan.topology that implement Address Modifier and Type Class Description classPersistentUUIDPersistentUUID.Methods in org.infinispan.topology that return Address Modifier and Type Method Description AddressPersistentUUIDManager. getAddress(PersistentUUID persistentUUID)Retrieves theAddressof a node given itsPersistentUUIDAddressPersistentUUIDManagerImpl. getAddress(PersistentUUID persistentUUID)AddressCacheTopologyControlCommand. getOrigin()Methods in org.infinispan.topology that return types with arguments of type Address Modifier and Type Method Description UnaryOperator<Address>PersistentUUIDManager. addressToPersistentUUID()Provides a remapping operator which translates addresses to persistentuuidsUnaryOperator<Address>PersistentUUIDManagerImpl. addressToPersistentUUID()List<Address>CacheTopology. getActualMembers()Map<Address,Float>ClusterCacheStatus. getCapacityFactors()List<Address>ClusterCacheStatus. getExpectedMembers()List<Address>CacheTopology. getMembers()UnaryOperator<Address>PersistentUUIDManager. persistentUUIDToAddress()Provides a remapping operator which translates persistentuuids to addressesUnaryOperator<Address>PersistentUUIDManagerImpl. persistentUUIDToAddress()Methods in org.infinispan.topology with parameters of type Address Modifier and Type Method Description voidPersistentUUIDManager. addPersistentAddressMapping(Address address, PersistentUUID persistentUUID)Adds a mapping between anAddressand aPersistentUUIDvoidPersistentUUIDManagerImpl. addPersistentAddressMapping(Address address, PersistentUUID persistentUUID)intPersistentUUID. compareTo(Address o)voidClusterCacheStatus. confirmRebalancePhase(Address member, int receivedTopologyId)CacheStatusResponseClusterCacheStatus. doJoin(Address joiner, CacheJoinInfo joinInfo)booleanClusterCacheStatus. doLeave(Address leaver)PersistentUUIDPersistentUUIDManager. getPersistentUuid(Address address)Retrieves thePersistentUUIDof a node given itsAddressPersistentUUIDPersistentUUIDManagerImpl. getPersistentUuid(Address address)CacheStatusResponseClusterTopologyManager. handleJoin(String cacheName, Address joiner, CacheJoinInfo joinInfo, int viewId)Signals that a new member is joining the cache.CacheStatusResponseClusterTopologyManagerImpl. handleJoin(String cacheName, Address joiner, CacheJoinInfo joinInfo, int joinerViewId)voidClusterTopologyManager. handleLeave(String cacheName, Address leaver, int viewId)Signals that a member is leaving the cache.voidClusterTopologyManagerImpl. handleLeave(String cacheName, Address leaver, int viewId)voidLocalTopologyManager. handleRebalance(String cacheName, CacheTopology cacheTopology, int viewId, Address sender)Performs the state transfer.voidLocalTopologyManagerImpl. handleRebalance(String cacheName, CacheTopology cacheTopology, int viewId, Address sender)voidClusterTopologyManager. handleRebalancePhaseConfirm(String cacheName, Address node, int topologyId, Throwable throwable, int viewId)Marks the rebalance as complete on the sender.voidClusterTopologyManagerImpl. handleRebalancePhaseConfirm(String cacheName, Address node, int topologyId, Throwable throwable, int viewId)voidLocalTopologyManager. handleStableTopologyUpdate(String cacheName, CacheTopology cacheTopology, Address sender, int viewId)Update the stable cache topology.voidLocalTopologyManagerImpl. handleStableTopologyUpdate(String cacheName, CacheTopology newStableTopology, Address sender, int viewId)voidLocalTopologyManager. handleTopologyUpdate(String cacheName, CacheTopology cacheTopology, AvailabilityMode availabilityMode, int viewId, Address sender)Updates the current and/or pending consistent hash, without transferring any state.voidLocalTopologyManagerImpl. 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 Address Modifier and Type Method Description ConsistentHashClusterCacheStatus. calculateConflictHash(ConsistentHash preferredHash, Set<ConsistentHash> distinctHashes, List<Address> actualMembers)static booleanClusterTopologyManagerImpl. distLostDataCheck(ConsistentHash stableCH, List<Address> newMembers)voidClusterCacheStatus. doMergePartitions(Map<Address,CacheStatusResponse> statusResponses)List<PersistentUUID>PersistentUUIDManager. mapAddresses(List<Address> addresses)Returns a list ofPersistentUUIDs for the suppliedAddressesList<PersistentUUID>PersistentUUIDManagerImpl. mapAddresses(List<Address> addresses)voidClusterCacheStatus. queueConflictResolution(CacheTopology conflictTopology, Set<Address> preferredNodes)voidClusterCacheStatus. queueRebalance(List<Address> newMembers)booleanClusterCacheStatus. restartConflictResolution(List<Address> members)static booleanClusterTopologyManagerImpl. scatteredLostDataCheck(ConsistentHash stableCH, List<Address> newMembers)voidClusterCacheStatus. updateAvailabilityMode(List<Address> actualMembers, AvailabilityMode newAvailabilityMode, boolean cancelRebalance)voidClusterCacheStatus. updateCurrentTopology(List<Address> newMembers)Constructors in org.infinispan.topology with parameters of type Address Constructor Description CacheTopologyControlCommand(String cacheName, CacheTopologyControlCommand.Type type, Address sender, int viewId)CacheTopologyControlCommand(String cacheName, CacheTopologyControlCommand.Type type, Address sender, int topologyId, int rebalanceId, Throwable throwable, int viewId)CacheTopologyControlCommand(String cacheName, CacheTopologyControlCommand.Type type, Address sender, AvailabilityMode availabilityMode, int viewId)CacheTopologyControlCommand(String cacheName, CacheTopologyControlCommand.Type type, Address sender, CacheJoinInfo joinInfo, int viewId)CacheTopologyControlCommand(String cacheName, CacheTopologyControlCommand.Type type, Address sender, CacheTopology cacheTopology, AvailabilityMode availabilityMode, int viewId)Constructor parameters in org.infinispan.topology with type arguments of type Address Constructor Description 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.xa
Fields in org.infinispan.transaction.xa declared as Address Modifier and Type Field Description protected AddressGlobalTransaction. addrMethods in org.infinispan.transaction.xa that return Address Modifier and Type Method Description AddressGlobalTransaction. getAddress()Methods in org.infinispan.transaction.xa with parameters of type Address Modifier and Type Method Description GlobalTransactionTransactionFactory. newGlobalTransaction(Address addr, boolean remote)abstract GlobalTransactionTransactionFactory.TxFactoryEnum. newGlobalTransaction(Address addr, boolean remote, VersionGenerator clusterIdGenerator, boolean clustered)voidGlobalTransaction. setAddress(Address address)Constructors in org.infinispan.transaction.xa with parameters of type Address Constructor Description DldGlobalTransaction(Address addr, boolean remote)Deprecated.GlobalTransaction(Address addr, boolean remote) -
Uses of Address in org.infinispan.transaction.xa.recovery
Methods in org.infinispan.transaction.xa.recovery that return types with arguments of type Address Modifier and Type Method Description Set<Address>InDoubtTxInfoImpl. getOwners()Set<Address>RecoveryManager.InDoubtTxInfo. getOwners()Returns the set of nodes where this transaction information is maintained.Methods in org.infinispan.transaction.xa.recovery with parameters of type Address Modifier and Type Method Description voidInDoubtTxInfoImpl. addOwner(Address owner)StringRecoveryManager. forceTransactionCompletionFromCluster(Xid xid, Address where, boolean commit)This method invokesRecoveryManager.forceTransactionCompletion(javax.transaction.xa.Xid, boolean)on the specified node.StringRecoveryManagerImpl. forceTransactionCompletionFromCluster(Xid xid, Address where, boolean commit)Method parameters in org.infinispan.transaction.xa.recovery with type arguments of type Address Modifier and Type Method Description voidRecoveryAwareTransactionTable. 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().voidRecoveryManager. removeRecoveryInformation(Collection<Address> where, Xid xid, boolean sync, 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.voidRecoveryManagerImpl. removeRecoveryInformation(Collection<Address> lockOwners, Xid xid, boolean sync, GlobalTransaction gtx, boolean fromCluster)voidRecoveryManager. removeRecoveryInformationFromCluster(Collection<Address> where, long internalId, boolean sync)Same asRecoveryManager.removeRecoveryInformation(java.util.Collection, javax.transaction.xa.Xid, boolean, org.infinispan.transaction.xa.GlobalTransaction, boolean)but the transaction is identified by its internal id, and not by its xid.voidRecoveryManagerImpl. removeRecoveryInformationFromCluster(Collection<Address> where, long internalId, boolean sync)Constructors in org.infinispan.transaction.xa.recovery with parameters of type Address Constructor Description RecoveryAwareDldGlobalTransaction(Address addr, boolean remote)Deprecated.RecoveryAwareGlobalTransaction(Address addr, boolean remote) -
Uses of Address in org.infinispan.util
Methods in org.infinispan.util with parameters of type Address Modifier and Type Method Description voidAbstractControlledLocalTopologyManager. handleRebalance(String cacheName, CacheTopology cacheTopology, int viewId, Address sender)voidAbstractControlledLocalTopologyManager. handleStableTopologyUpdate(String cacheName, CacheTopology cacheTopology, Address sender, int viewId)voidAbstractControlledLocalTopologyManager. handleTopologyUpdate(String cacheName, CacheTopology cacheTopology, AvailabilityMode availabilityMode, int viewId, Address sender) -
Uses of Address in org.infinispan.util.concurrent
Methods in org.infinispan.util.concurrent with parameters of type Address Modifier and Type Method Description voidCommandAckCollector. backupAck(long id, Address from, int topologyId)Acknowledges a write operation completion in the backup owner.BiasedCollectorCommandAckCollector.MultiTargetCollector. collectorFor(Address target)voidCommandAckCollector. multiKeyBackupAck(long id, Address from, int segment, int topologyId)Acknowledges aPutMapCommandcompletion in the backup owner.Method parameters in org.infinispan.util.concurrent with type arguments of type Address Modifier and Type Method Description <T> Collector<T>CommandAckCollector. create(long id, Collection<Address> backupOwners, int topologyId)Creates a collector for a single key write operation.<T> Collector<T>CommandAckCollector. createSegmentBasedCollector(long id, Map<Address,Collection<Integer>> backups, int topologyId)Creates a collector forPutMapCommand.voidCommandAckCollector. onMembersChange(Collection<Address> members)Notifies a change in member list. -
Uses of Address in org.infinispan.xsite.statetransfer
Methods in org.infinispan.xsite.statetransfer with parameters of type Address Modifier and Type Method Description booleanXSiteStateTransferCollector. confirmStateTransfer(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)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 Address Modifier and Type Method Description Collection<String>XSiteStateProvider. getSitesMissingCoordinator(Collection<Address> currentMembers)Collection<String>XSiteStateProviderImpl. getSitesMissingCoordinator(Collection<Address> currentMembers)booleanXSiteStateTransferCollector. updateMembers(Collection<Address> members)Constructor parameters in org.infinispan.xsite.statetransfer with type arguments of type Address Constructor Description XSiteStateTransferCollector(Collection<Address> confirmationPending) -
Uses of Address in org.infinispan.xsite.status
Methods in org.infinispan.xsite.status with parameters of type Address Modifier and Type Method Description voidCacheSiteStatusBuilder. addMember(Address address, boolean online)Adds 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 Address Modifier and Type Method Description protected SiteStatusCacheSiteStatusBuilder. createMixedStatus(List<Address> onlineElements, List<Address> offlineElements)Constructor parameters in org.infinispan.xsite.status with type arguments of type Address Constructor Description CacheMixedSiteStatus(List<Address> onlineMembers, List<Address> offlineMembers)
-