Infinispan Distribution 5.2.6.Final-redhat-2

Uses of Interface
org.infinispan.remoting.transport.Address

Packages that use Address
org.infinispan.affinity   
org.infinispan.commands Commands that operate on the cache, either locally or remotely. 
org.infinispan.commands.remote Meta-commands that wrap other commands for remote execution. 
org.infinispan.commands.tx Commands that represent transactional lifecycle transitions. 
org.infinispan.commands.write Commands that alter the state of the cache. 
org.infinispan.context Contexts contain information of a specific invocation on the cache, such as its origins, scope (transactional or non-transactional), as well as invocation-specific flags. 
org.infinispan.context.impl This package contains different context implementations, selected dynamically based on the type of invocation. 
org.infinispan.distexec   
org.infinispan.distexec.mapreduce   
org.infinispan.distribution Classes relating to the distributed cache mode. 
org.infinispan.distribution.ch   
org.infinispan.distribution.group Groups allow keys with differeing hash codes to be co-located on the same node. 
org.infinispan.distribution.topologyaware   
org.infinispan.interceptors Infinispan is designed around a set of interceptors around a data container. 
org.infinispan.interceptors.distribution   
org.infinispan.interceptors.locking   
org.infinispan.manager Cache manager package 
org.infinispan.notifications.cachelistener.event   
org.infinispan.notifications.cachemanagerlistener CacheManager-specific notifications and eventing. 
org.infinispan.notifications.cachemanagerlistener.event   
org.infinispan.query.clustered   
org.infinispan.query.logging   
org.infinispan.remoting Remote communication between cache instances. 
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.statetransfer Transfer of state to new caches in a cluster. 
org.infinispan.topology   
org.infinispan.transaction JTA transaction support. 
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.logging 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 that return types with arguments of type Address
 Map<Address,BlockingQueue<K>> KeyAffinityServiceImpl.getAddress2KeysMapping()
           
 

Methods in org.infinispan.affinity with parameters of type Address
 K KeyAffinityServiceImpl.getKeyForAddress(Address address)
           
 K KeyAffinityService.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
static
<K,V> KeyAffinityService<K>
KeyAffinityServiceFactory.newKeyAffinityService(Cache<K,V> cache, Collection<Address> filter, KeyGenerator<K> keyGenerator, Executor ex, int keyBufferSize)
          Same as KeyAffinityServiceFactory.newKeyAffinityService(org.infinispan.Cache, java.util.Collection, KeyGenerator, java.util.concurrent.Executor, int, boolean) with start == true.
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
KeyAffinityServiceImpl(Executor executor, Cache<? extends K,?> cache, KeyGenerator<? extends K> keyGenerator, int bufferSize, Collection<Address> filter, boolean start)
           
 

Uses of Address in org.infinispan.commands
 

Methods in org.infinispan.commands with parameters of type Address
<T> DistributedExecuteCommand<T>
CommandsFactory.buildDistributedExecuteCommand(Callable<T> callable, Address sender, Collection keys)
          Builds a DistributedExecuteCommand used for migration and execution of distributed Callables and Runnables.
<T> DistributedExecuteCommand<T>
CommandsFactoryImpl.buildDistributedExecuteCommand(Callable<T> callable, Address sender, Collection keys)
           
 InvalidateCommand CommandsFactory.buildInvalidateFromL1Command(Address origin, boolean forRehash, Set<Flag> flags, Collection<Object> keys)
           
 InvalidateCommand CommandsFactoryImpl.buildInvalidateFromL1Command(Address origin, boolean forRehash, Set<Flag> flags, Collection<Object> keys)
           
 StateRequestCommand CommandsFactory.buildStateRequestCommand(StateRequestCommand.Type subtype, Address sender, int viewId, Set<Integer> segments)
          Builds a StateRequestCommand used for requesting transactions and locks and for starting or canceling transfer of cache entries.
 StateRequestCommand CommandsFactoryImpl.buildStateRequestCommand(StateRequestCommand.Type subtype, Address sender, int viewId, Set<Integer> segments)
           
 StateResponseCommand CommandsFactory.buildStateResponseCommand(Address sender, int viewId, Collection<StateChunk> stateChunks)
          Builds a StateResponseCommand used for pushing cache entries to another node in response to a StateRequestCommand.
 StateResponseCommand CommandsFactoryImpl.buildStateResponseCommand(Address sender, int viewId, Collection<StateChunk> stateChunks)
           
 

Uses of Address in org.infinispan.commands.remote
 

Methods in org.infinispan.commands.remote that return Address
 Address BaseRpcCommand.getOrigin()
           
 Address CacheRpcCommand.getOrigin()
          Get the origin of the command
 

Methods in org.infinispan.commands.remote with parameters of type Address
 void BaseRpcCommand.setOrigin(Address origin)
           
 void CacheRpcCommand.setOrigin(Address origin)
          Set the origin of the command
 

Uses of Address in org.infinispan.commands.tx
 

Methods in org.infinispan.commands.tx that return Address
 Address AbstractTransactionBoundaryCommand.getOrigin()
           
 

Methods in org.infinispan.commands.tx with parameters of type Address
 void AbstractTransactionBoundaryCommand.setOrigin(Address origin)
           
 

Uses of Address in org.infinispan.commands.write
 

Methods in org.infinispan.commands.write with parameters of type Address
 boolean InvalidateL1Command.isCausedByALocalWrite(Address address)
          Returns true if the write that caused the invalidation was performed on this node.
 

Constructors in org.infinispan.commands.write with parameters of type Address
InvalidateL1Command(Address writeOrigin, boolean forRehash, DataContainer dc, Configuration config, DistributionManager dm, CacheNotifier notifier, Set<Flag> flags, Collection<Object> keys)
           
 

Uses of Address in org.infinispan.context
 

Methods in org.infinispan.context that return Address
 Address InvocationContext.getOrigin()
          Get the origin of the command, or null if the command originated locally
 

Methods in org.infinispan.context with parameters of type Address
 InvocationContext InvocationContextContainer.createRemoteInvocationContext(Address origin)
          Returns an NonTxInvocationContext whose NonTxInvocationContext.isOriginLocal() flag will be true.
 NonTxInvocationContext TransactionalInvocationContextContainer.createRemoteInvocationContext(Address origin)
           
 NonTxInvocationContext NonTransactionalInvocationContextContainer.createRemoteInvocationContext(Address origin)
           
 InvocationContext InvocationContextContainer.createRemoteInvocationContextForCommand(VisitableCommand cacheCommand, Address origin)
          As InvocationContextContainer.createRemoteInvocationContext(org.infinispan.remoting.transport.Address), but returning the flags to the context from the Command if any Flag was set.
 InvocationContext AbstractInvocationContextContainer.createRemoteInvocationContextForCommand(VisitableCommand cacheCommand, Address origin)
           
 RemoteTxInvocationContext InvocationContextContainer.createRemoteTxInvocationContext(RemoteTransaction tx, Address origin)
          Returns an RemoteTxInvocationContext.
 RemoteTxInvocationContext TransactionalInvocationContextContainer.createRemoteTxInvocationContext(RemoteTransaction tx, Address origin)
           
 RemoteTxInvocationContext NonTransactionalInvocationContextContainer.createRemoteTxInvocationContext(RemoteTransaction tx, Address origin)
           
 

Uses of Address in org.infinispan.context.impl
 

Methods in org.infinispan.context.impl that return Address
 Address AbstractInvocationContext.getOrigin()
           
 Address ImmutableContext.getOrigin()
           
 

Methods in org.infinispan.context.impl that return types with arguments of type Address
 Collection<Address> LocalTxInvocationContext.getRemoteLocksAcquired()
           
 

Methods in org.infinispan.context.impl with parameters of type Address
 void AbstractInvocationContext.setOrigin(Address origin)
           
 

Method parameters in org.infinispan.context.impl with type arguments of type Address
 void LocalTxInvocationContext.remoteLocksAcquired(Collection<Address> nodes)
           
 

Uses of Address in org.infinispan.distexec
 

Fields in org.infinispan.distexec declared as Address
static Address DefaultExecutorService.LOCAL_MODE_ADDRESS
           
 

Methods in org.infinispan.distexec that return Address
 Address FailoverContext.executionFailureLocation()
          Returns an Address of the node where the task failed
 Address DistributedTaskFailoverPolicy.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
<T> Address
DefaultExecutorService.selectExecutionNode(DistributedTask<T> task)
           
protected  Address DefaultExecutorService.selectExecutionNode(List<Address> candidates)
           
 

Methods in org.infinispan.distexec that return types with arguments of type Address
 List<Address> FailoverContext.executionCandidates()
          Returns a list of candidates for possible repeated execution governed by installed DistributedTaskFailoverPolicy
protected
<T> List<Address>
DefaultExecutorService.executionCandidates(DistributedTask<T> task)
           
protected  List<Address> DefaultExecutorService.getMembers()
           
protected
<K> Map<Address,List<K>>
DefaultExecutorService.keysToExecutionNodes(DistributedTaskExecutionPolicy policy, K... input)
           
protected  List<Address> DefaultExecutorService.randomClusterMembers(List<Address> members, int numNeeded)
           
 

Methods in org.infinispan.distexec with parameters of type Address
protected
<T,K> org.infinispan.distexec.DefaultExecutorService.DistributedTaskPart<T>
DefaultExecutorService.createDistributedTaskPart(DistributedTask<T> task, DistributedExecuteCommand<T> c, Address target, int failoverCount)
           
protected
<T,K> org.infinispan.distexec.DefaultExecutorService.DistributedTaskPart<T>
DefaultExecutorService.createDistributedTaskPart(DistributedTask<T> task, DistributedExecuteCommand<T> c, List<K> inputKeys, Address target, int failoverCount)
           
<T> Future<T>
DefaultExecutorService.submit(Address target, Callable<T> task)
           
<T> Future<T>
DistributedExecutorService.submit(Address target, Callable<T> task)
          Submits the given Callable task for execution on the specified target Infinispan node.
<T> Future<T>
DefaultExecutorService.submit(Address target, DistributedTask<T> task)
           
<T> Future<T>
DistributedExecutorService.submit(Address target, DistributedTask<T> task)
          Submits the given DistributedTask for execution on the specified target Infinispan node.
 

Method parameters in org.infinispan.distexec with type arguments of type Address
protected  List<Address> DefaultExecutorService.randomClusterMembers(List<Address> members, int numNeeded)
           
protected  Address DefaultExecutorService.selectExecutionNode(List<Address> candidates)
           
 

Uses of Address in org.infinispan.distexec.mapreduce
 

Methods in org.infinispan.distexec.mapreduce that return types with arguments of type Address
protected
<T> Map<Address,List<T>>
MapReduceTask.mapKeysToNodes(Collection<T> keysToMap)
           
protected
<T> Map<Address,List<T>>
MapReduceTask.mapKeysToNodes(Collection<T> keysToMap, boolean useIntermediateCompositeKey)
           
protected
<T> Map<Address,List<T>>
MapReduceTask.mapKeysToNodes(DistributionManager dm, Collection<T> keysToMap, boolean useIntermediateCompositeKey)
           
<T> Map<Address,List<T>>
MapReduceManager.mapKeysToNodes(DistributionManager dm, String taskId, Collection<T> keysToMap, boolean useIntermediateCompositeKey)
          Maps Map/Reduce task intermediate or input keys to nodes on Infinispan cluster
<T> Map<Address,List<T>>
MapReduceManagerImpl.mapKeysToNodes(DistributionManager dm, String taskId, Collection<T> keysToMap, boolean useIntermediateCompositeKey)
           
 

Methods in org.infinispan.distexec.mapreduce with parameters of type Address
protected
<V> org.infinispan.distexec.mapreduce.MapReduceTask.ReduceTaskPart<V>
MapReduceTask.createReducePart(ReduceCommand<KOut,VOut> cmd, Address target, String destCacheName)
           
protected
<V> org.infinispan.distexec.mapreduce.MapReduceTask.MapTaskPart<V>
MapReduceTask.createTaskMapPart(MapCombineCommand<KIn,VIn,KOut,VOut> cmd, Address target, boolean distributedReduce)
           
 

Uses of Address in org.infinispan.distribution
 

Methods in org.infinispan.distribution that return Address
 Address DistributionManager.getPrimaryLocation(Object key)
          Returns the first Address containing the key.
 Address DistributionManagerImpl.getPrimaryLocation(Object key)
           
 

Methods in org.infinispan.distribution that return types with arguments of type Address
 Collection<Address> DistributionManager.getAffectedNodes(Collection<Object> affectedKeys)
          A helper method that retrieves a list of nodes affected by operations on a set of keys.
 Collection<Address> DistributionManagerImpl.getAffectedNodes(Collection<Object> affectedKeys)
           
 List<Address> DistributionManager.locate(Object key)
          Locates a key in a cluster.
 List<Address> DistributionManagerImpl.locate(Object key)
           
 Set<Address> DistributionManager.locateAll(Collection<Object> keys)
          Locates a list of keys in a cluster.
 Set<Address> DistributionManagerImpl.locateAll(Collection<Object> keys)
           
 

Methods in org.infinispan.distribution with parameters of type Address
 void L1Manager.addRequestor(Object key, Address requestor)
          Records a request that will be cached in another nodes L1
 void L1ManagerImpl.addRequestor(Object key, Address origin)
           
 Future<Object> L1Manager.flushCache(Collection<Object> key, Address origin, boolean assumeOriginKeptEntryInL1)
           
 Future<Object> L1ManagerImpl.flushCache(Collection<Object> keys, Address origin, boolean assumeOriginKeptEntryInL1)
           
 Future<Object> L1Manager.flushCacheWithSimpleFuture(Collection<Object> keys, Object retval, Address origin, boolean assumeOriginKeptEntryInL1)
           
 Future<Object> L1ManagerImpl.flushCacheWithSimpleFuture(Collection<Object> keys, Object retval, Address origin, boolean assumeOriginKeptEntryInL1)
           
 

Uses of Address in org.infinispan.distribution.ch
 

Methods in org.infinispan.distribution.ch that return Address
protected  Address DefaultConsistentHashFactory.findNewBackupOwner(DefaultConsistentHashFactory.Builder builder, Collection<Address> excludes, int maxSegments)
           
protected  Address DefaultConsistentHashFactory.findNewPrimaryOwner(DefaultConsistentHashFactory.Builder builder, Collection<Address> candidates, int maxSegments)
           
 Address DefaultConsistentHashFactory.Builder.getPrimaryOwner(int segment)
           
 Address ReplicatedConsistentHash.locatePrimaryOwner(Object key)
           
 Address DefaultConsistentHash.locatePrimaryOwner(Object key)
           
 Address ConsistentHash.locatePrimaryOwner(Object key)
          Should be equivalent to return the first element of ConsistentHash.locateOwners(java.lang.Object).
 Address ReplicatedConsistentHash.locatePrimaryOwnerForSegment(int segmentId)
           
 Address DefaultConsistentHash.locatePrimaryOwnerForSegment(int segmentId)
           
 Address ConsistentHash.locatePrimaryOwnerForSegment(int segmentId)
           
 

Methods in org.infinispan.distribution.ch that return types with arguments of type Address
 List<Address> DefaultConsistentHashFactory.Builder.getBackupOwners(int segment)
           
 List<Address> ReplicatedConsistentHash.getMembers()
           
 List<Address> DefaultConsistentHashFactory.Builder.getMembers()
           
 List<Address> DefaultConsistentHash.getMembers()
           
 List<Address> ConsistentHash.getMembers()
          Should return the addresses of the nodes used to create this consistent hash.
 List<Address> SyncConsistentHashFactory.Builder.getOwners(int i)
           
 List<Address> DefaultConsistentHashFactory.Builder.getOwners(int segment)
           
 List<Address> SyncConsistentHashFactory.Builder.getSortedMembers()
           
 Set<Address> ReplicatedConsistentHash.locateAllOwners(Collection<Object> keys)
           
 Set<Address> DefaultConsistentHash.locateAllOwners(Collection<Object> keys)
           
 Set<Address> ConsistentHash.locateAllOwners(Collection<Object> keys)
          The logical equivalent of calling ConsistentHash.locateOwners(java.lang.Object) multiple times for each key in the collection of keys and merging the results.
 List<Address> ReplicatedConsistentHash.locateOwners(Object key)
           
 List<Address> DefaultConsistentHash.locateOwners(Object key)
           
 List<Address> ConsistentHash.locateOwners(Object key)
          Finds all the owners of a key.
 List<Address> ReplicatedConsistentHash.locateOwnersForSegment(int segmentId)
           
 List<Address> DefaultConsistentHash.locateOwnersForSegment(int segmentId)
           
 List<Address> ConsistentHash.locateOwnersForSegment(int segmentId)
           
 

Methods in org.infinispan.distribution.ch with parameters of type Address
 boolean DefaultConsistentHashFactory.Builder.addOwner(int segment, Address owner)
           
 void OwnershipStatistics.decOwned(Address a)
           
 void OwnershipStatistics.decPrimaryOwned(Address a)
           
 int OwnershipStatistics.getOwned(Address a)
           
 int DefaultConsistentHashFactory.Builder.getOwned(Address node)
           
 int OwnershipStatistics.getPrimaryOwned(Address a)
           
 Set<Integer> ReplicatedConsistentHash.getSegmentsForOwner(Address owner)
           
 Set<Integer> DefaultConsistentHash.getSegmentsForOwner(Address owner)
           
 Set<Integer> ConsistentHash.getSegmentsForOwner(Address owner)
          Returns the segments owned by a cache member.
 void OwnershipStatistics.incOwned(Address a)
           
 void OwnershipStatistics.incPrimaryOwned(Address a)
           
 boolean ReplicatedConsistentHash.isKeyLocalToNode(Address nodeAddress, Object key)
           
 boolean DefaultConsistentHash.isKeyLocalToNode(Address nodeAddress, Object key)
           
 boolean ConsistentHash.isKeyLocalToNode(Address nodeAddress, Object key)
          Test to see whether a key is owned by a given node.
 boolean DefaultConsistentHashFactory.Builder.removeOwner(int segment, Address owner)
           
 void DefaultConsistentHashFactory.Builder.replacePrimaryOwner(int segment, Address newPrimaryOwner)
           
 

Method parameters in org.infinispan.distribution.ch with type arguments of type Address
 boolean DefaultConsistentHashFactory.Builder.addOwners(int segment, Collection<Address> newOwners)
           
 DefaultConsistentHash SyncConsistentHashFactory.create(Hash hashFunction, int numOwners, int numSegments, List<Address> members)
           
 CH ConsistentHashFactory.create(Hash hashFunction, int numOwners, int numSegments, List<Address> members)
          Create a new consistent hash instance.
 DefaultConsistentHash DefaultConsistentHashFactory.create(Hash hashFunction, int numOwners, int numSegments, List<Address> members)
           
 ReplicatedConsistentHash ReplicatedConsistentHashFactory.create(Hash hashFunction, int numOwners, int numSegments, List<Address> members)
           
protected  Address DefaultConsistentHashFactory.findNewBackupOwner(DefaultConsistentHashFactory.Builder builder, Collection<Address> excludes, int maxSegments)
           
protected  Address DefaultConsistentHashFactory.findNewPrimaryOwner(DefaultConsistentHashFactory.Builder builder, Collection<Address> candidates, int maxSegments)
           
protected  void SyncConsistentHashFactory.populateOwnersFewSegments(SyncConsistentHashFactory.Builder builder, SortedMap<Integer,Address> primarySegments)
           
protected  void TopologyAwareSyncConsistentHashFactory.populateOwnersFewSegments(SyncConsistentHashFactory.Builder builder, SortedMap<Integer,Address> primarySegments)
           
protected  void SyncConsistentHashFactory.populateOwnersManySegments(SyncConsistentHashFactory.Builder builder, SortedMap<Integer,Address> primarySegments)
           
protected  void TopologyAwareSyncConsistentHashFactory.populateOwnersManySegments(SyncConsistentHashFactory.Builder builder, SortedMap<Integer,Address> primarySegments)
           
 CH ConsistentHashFactory.updateMembers(CH baseCH, List<Address> newMembers)
          Create a new consistent hash instance, based on an existing instance, but with a new list of members.
 DefaultConsistentHash SyncConsistentHashFactory.updateMembers(DefaultConsistentHash baseCH, List<Address> newMembers)
           
 DefaultConsistentHash DefaultConsistentHashFactory.updateMembers(DefaultConsistentHash baseCH, List<Address> actualMembers)
          Leavers are removed and segments without owners are assigned new owners.
 ReplicatedConsistentHash ReplicatedConsistentHashFactory.updateMembers(ReplicatedConsistentHash baseCH, List<Address> newMembers)
           
 

Constructor parameters in org.infinispan.distribution.ch with type arguments of type Address
DefaultConsistentHash(Hash hashFunction, int numOwners, int numSegments, List<Address> members, List<Address>[] segmentOwners)
           
DefaultConsistentHashFactory.Builder(DefaultConsistentHash baseCH, List<Address> actualMembers)
           
DefaultConsistentHashFactory.Builder(int numOwners, int numSegments, List<Address> members)
           
OwnershipStatistics(DefaultConsistentHash ch, List<Address> nodes)
           
OwnershipStatistics(List<Address> nodes)
           
ReplicatedConsistentHash(List<Address> members)
           
 

Uses of Address in org.infinispan.distribution.group
 

Methods in org.infinispan.distribution.group that return Address
 Address GroupingConsistentHash.locatePrimaryOwner(Object key)
           
 Address GroupingConsistentHash.locatePrimaryOwnerForSegment(int segmentId)
           
 

Methods in org.infinispan.distribution.group that return types with arguments of type Address
 List<Address> GroupingConsistentHash.getMembers()
           
 Set<Address> GroupingConsistentHash.locateAllOwners(Collection<Object> keys)
           
 List<Address> GroupingConsistentHash.locateOwners(Object key)
           
 List<Address> GroupingConsistentHash.locateOwnersForSegment(int segmentId)
           
 

Methods in org.infinispan.distribution.group with parameters of type Address
 Set<Integer> GroupingConsistentHash.getSegmentsForOwner(Address owner)
           
 boolean GroupingConsistentHash.isKeyLocalToNode(Address nodeAddress, Object key)
           
 

Uses of Address in org.infinispan.distribution.topologyaware
 

Methods in org.infinispan.distribution.topologyaware that return types with arguments of type Address
 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
 int TopologyInfo.computeMaxSegments(int numSegments, int numOwners, Address node)
           
 

Constructor parameters in org.infinispan.distribution.topologyaware with type arguments of type Address
TopologyInfo(Collection<Address> members)
           
 

Uses of Address in org.infinispan.interceptors
 

Methods in org.infinispan.interceptors that return Address
protected  Address ReplicationInterceptor.getPrimaryOwner()
           
 

Uses of Address in org.infinispan.interceptors.distribution
 

Methods in org.infinispan.interceptors.distribution with parameters of type Address
protected  Object NonTxDistributionInterceptor.getResponseFromPrimaryOwner(Address primaryOwner, Map<Address,Response> addressResponseMap)
           
 

Method parameters in org.infinispan.interceptors.distribution with type arguments of type Address
protected  Object NonTxDistributionInterceptor.getResponseFromPrimaryOwner(Address primaryOwner, Map<Address,Response> addressResponseMap)
           
protected  void TxDistributionInterceptor.prepareOnAffectedNodes(TxInvocationContext ctx, PrepareCommand command, Collection<Address> recipients, boolean sync)
           
protected  void VersionedDistributionInterceptor.prepareOnAffectedNodes(TxInvocationContext ctx, PrepareCommand command, Collection<Address> recipients, boolean ignored)
           
 

Uses of Address in org.infinispan.interceptors.locking
 

Methods in org.infinispan.interceptors.locking that return Address
 Address ClusteringDependentLogic.getAddress()
           
 Address ClusteringDependentLogic.LocalLogic.getAddress()
           
 Address ClusteringDependentLogic.InvalidationLogic.getAddress()
           
 Address ClusteringDependentLogic.DistributionLogic.getAddress()
           
 Address ClusteringDependentLogic.getPrimaryOwner(Object key)
           
 Address ClusteringDependentLogic.LocalLogic.getPrimaryOwner(Object key)
           
 Address ClusteringDependentLogic.InvalidationLogic.getPrimaryOwner(Object key)
           
 Address ClusteringDependentLogic.DistributionLogic.getPrimaryOwner(Object key)
           
 

Methods in org.infinispan.interceptors.locking that return types with arguments of type Address
 Collection<Address> ClusteringDependentLogic.getOwners(Collection<Object> keys)
           
 Collection<Address> ClusteringDependentLogic.LocalLogic.getOwners(Collection<Object> keys)
           
 Collection<Address> ClusteringDependentLogic.InvalidationLogic.getOwners(Collection<Object> keys)
           
 Collection<Address> ClusteringDependentLogic.DistributionLogic.getOwners(Collection<Object> keys)
           
 

Uses of Address in org.infinispan.manager
 

Methods in org.infinispan.manager that return Address
 Address EmbeddedCacheManager.getAddress()
           
 Address DefaultCacheManager.getAddress()
          
 Address AbstractDelegatingEmbeddedCacheManager.getAddress()
           
 Address EmbeddedCacheManager.getCoordinator()
           
 Address DefaultCacheManager.getCoordinator()
          
 Address AbstractDelegatingEmbeddedCacheManager.getCoordinator()
           
 

Methods in org.infinispan.manager that return types with arguments of type Address
 List<Address> EmbeddedCacheManager.getMembers()
           
 List<Address> DefaultCacheManager.getMembers()
          
 List<Address> AbstractDelegatingEmbeddedCacheManager.getMembers()
           
 

Uses of Address in org.infinispan.notifications.cachelistener.event
 

Methods in org.infinispan.notifications.cachelistener.event that return types with arguments of type Address
 Collection<Address> DataRehashedEvent.getMembersAtEnd()
           
 Collection<Address> EventImpl.getMembersAtEnd()
           
 Collection<Address> DataRehashedEvent.getMembersAtStart()
           
 Collection<Address> EventImpl.getMembersAtStart()
           
 

Uses of Address in org.infinispan.notifications.cachemanagerlistener
 

Methods in org.infinispan.notifications.cachemanagerlistener with parameters of type Address
 void CacheManagerNotifierImpl.notifyMerge(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId, List<List<Address>> subgroupsMerged)
           
 void CacheManagerNotifier.notifyMerge(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId, List<List<Address>> subgroupsMerged)
           
 void CacheManagerNotifierImpl.notifyViewChange(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId)
           
 void CacheManagerNotifier.notifyViewChange(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId)
          Notifies all registered listeners of a viewChange event.
 

Method parameters in org.infinispan.notifications.cachemanagerlistener with type arguments of type Address
 void CacheManagerNotifierImpl.notifyMerge(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId, List<List<Address>> subgroupsMerged)
           
 void CacheManagerNotifierImpl.notifyMerge(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId, List<List<Address>> subgroupsMerged)
           
 void CacheManagerNotifierImpl.notifyMerge(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId, List<List<Address>> subgroupsMerged)
           
 void CacheManagerNotifier.notifyMerge(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId, List<List<Address>> subgroupsMerged)
           
 void CacheManagerNotifier.notifyMerge(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId, List<List<Address>> subgroupsMerged)
           
 void CacheManagerNotifier.notifyMerge(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId, List<List<Address>> subgroupsMerged)
           
 void CacheManagerNotifierImpl.notifyViewChange(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId)
           
 void CacheManagerNotifierImpl.notifyViewChange(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId)
           
 void CacheManagerNotifier.notifyViewChange(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId)
          Notifies all registered listeners of a viewChange event.
 void CacheManagerNotifier.notifyViewChange(List<Address> members, List<Address> oldMembers, Address myAddress, int viewId)
          Notifies all registered listeners of a viewChange event.
 

Uses of Address in org.infinispan.notifications.cachemanagerlistener.event
 

Methods in org.infinispan.notifications.cachemanagerlistener.event that return Address
 Address ViewChangedEvent.getLocalAddress()
           
 Address EventImpl.getLocalAddress()
           
 

Methods in org.infinispan.notifications.cachemanagerlistener.event that return types with arguments of type Address
 List<Address> ViewChangedEvent.getNewMembers()
          Gets the current list of members.
 List<Address> EventImpl.getNewMembers()
           
 List<Address> ViewChangedEvent.getOldMembers()
          Gets the previous list of members.
 List<Address> EventImpl.getOldMembers()
           
 List<List<Address>> EventImpl.getSubgroupsMerged()
           
 List<List<Address>> MergeEvent.getSubgroupsMerged()
           
 

Methods in org.infinispan.notifications.cachemanagerlistener.event with parameters of type Address
 void EventImpl.setLocalAddress(Address localAddress)
           
 

Method parameters in org.infinispan.notifications.cachemanagerlistener.event with type arguments of type Address
 void EventImpl.setNewMembers(List<Address> newMembers)
           
 void EventImpl.setOldMembers(List<Address> oldMembers)
           
 void EventImpl.setSubgroupsMerged(List<List<Address>> subgroupsMerged)
           
 

Constructors in org.infinispan.notifications.cachemanagerlistener.event with parameters of type Address
EventImpl(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 with type arguments of type Address
EventImpl(String cacheName, EmbeddedCacheManager cacheManager, Event.Type type, List<Address> newMemberList, List<Address> oldMemberList, Address localAddress, int viewId)
           
EventImpl(String cacheName, EmbeddedCacheManager cacheManager, Event.Type type, List<Address> newMemberList, List<Address> oldMemberList, Address localAddress, int viewId)
           
 

Uses of Address in org.infinispan.query.clustered
 

Methods in org.infinispan.query.clustered that return Address
 Address QueryResponse.getAddress()
           
 Address ClusteredTopDocs.getNodeAddress()
           
 

Methods in org.infinispan.query.clustered with parameters of type Address
 Object ClusteredQueryInvoker.getValue(int doc, Address address, UUID queryId)
          Retrieves the value (using doc index) in a remote query instance
 void QueryResponse.setAddress(Address address)
           
 void ClusteredTopDocs.setNodeAddress(Address nodeAddress)
           
 

Uses of Address in org.infinispan.query.logging
 

Methods in org.infinispan.query.logging with parameters of type Address
 void Log.workListRemotedTo(Object workList, Address primaryNodeAddress)
           
 

Uses of Address in org.infinispan.remoting
 

Methods in org.infinispan.remoting that return types with arguments of type Address
static List<Address> MembershipArithmetic.getMembersJoined(List<Address> oldList, List<Address> newList)
           
static Set<Address> MembershipArithmetic.getMembersJoined(Set<Address> oldSet, Set<Address> newSet)
           
static List<Address> MembershipArithmetic.getMembersLeft(List<Address> oldList, List<Address> newList)
           
static Set<Address> MembershipArithmetic.getMembersLeft(Set<Address> oldSet, Set<Address> newSet)
           
 

Methods in org.infinispan.remoting with parameters of type Address
 Response InboundInvocationHandler.handle(CacheRpcCommand command, Address origin)
          Invokes a command on the cache, from a remote source.
 Response InboundInvocationHandlerImpl.handle(CacheRpcCommand cmd, Address origin)
           
 

Method parameters in org.infinispan.remoting with type arguments of type Address
static List<Address> MembershipArithmetic.getMembersJoined(List<Address> oldList, List<Address> newList)
           
static List<Address> MembershipArithmetic.getMembersJoined(List<Address> oldList, List<Address> newList)
           
static Set<Address> MembershipArithmetic.getMembersJoined(Set<Address> oldSet, Set<Address> newSet)
           
static Set<Address> MembershipArithmetic.getMembersJoined(Set<Address> oldSet, Set<Address> newSet)
           
static List<Address> MembershipArithmetic.getMembersLeft(List<Address> oldList, List<Address> newList)
           
static List<Address> MembershipArithmetic.getMembersLeft(List<Address> oldList, List<Address> newList)
           
static Set<Address> MembershipArithmetic.getMembersLeft(Set<Address> oldSet, Set<Address> newSet)
           
static Set<Address> MembershipArithmetic.getMembersLeft(Set<Address> oldSet, Set<Address> newSet)
           
 

Uses of Address in org.infinispan.remoting.responses
 

Methods in org.infinispan.remoting.responses with parameters of type Address
 boolean IgnoreExtraResponsesValidityFilter.isAcceptable(Response response, Address address)
           
 boolean ClusteredGetResponseValidityFilter.isAcceptable(Response response, Address address)
           
 

Constructors in org.infinispan.remoting.responses with parameters of type Address
ClusteredGetResponseValidityFilter(Collection<Address> targets, Address self)
           
IgnoreExtraResponsesValidityFilter(Collection<Address> targets, Address self)
           
 

Constructor parameters in org.infinispan.remoting.responses with type arguments of type Address
ClusteredGetResponseValidityFilter(Collection<Address> targets, Address self)
           
IgnoreExtraResponsesValidityFilter(Collection<Address> targets, Address self)
           
 

Uses of Address in org.infinispan.remoting.rpc
 

Methods in org.infinispan.remoting.rpc that return Address
 Address RpcManager.getAddress()
          Returns the address associated with this RpcManager or null if not part of the cluster.
 Address RpcManagerImpl.getAddress()
           
 

Methods in org.infinispan.remoting.rpc that return types with arguments of type Address
 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, ReplicableCommand rpc, boolean sync)
          Broadcasts an RPC command to a specified set of recipients
 Map<Address,Response> RpcManagerImpl.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpc, boolean sync)
           
 Map<Address,Response> RpcManager.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpc, boolean sync, boolean usePriorityQueue)
          Broadcasts an RPC command to a specified set of recipients
 Map<Address,Response> RpcManagerImpl.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpc, boolean sync, boolean usePriorityQueue)
           
 Map<Address,Response> RpcManagerImpl.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpc, boolean sync, boolean usePriorityQueue, long timeout)
           
 Map<Address,Response> RpcManager.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout)
          Invokes an RPC call on other caches in the cluster.
 Map<Address,Response> RpcManagerImpl.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout)
           
 Map<Address,Response> RpcManager.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, boolean usePriorityQueue)
          Invokes an RPC call on other caches in the cluster.
 Map<Address,Response> RpcManagerImpl.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, boolean usePriorityQueue)
           
 Map<Address,Response> RpcManager.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, boolean usePriorityQueue, ResponseFilter responseFilter)
          Invokes an RPC call on other caches in the cluster.
 Map<Address,Response> RpcManagerImpl.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, boolean usePriorityQueue, ResponseFilter responseFilter)
           
 

Methods in org.infinispan.remoting.rpc with parameters of type Address
 boolean ResponseFilter.isAcceptable(Response response, Address sender)
          Determines whether a response from a given sender should be added to the response list of the request
 

Method parameters in org.infinispan.remoting.rpc with type arguments of type Address
 Map<Address,Response> RpcManager.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpc, boolean sync)
          Broadcasts an RPC command to a specified set of recipients
 Map<Address,Response> RpcManagerImpl.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpc, boolean sync)
           
 Map<Address,Response> RpcManager.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpc, boolean sync, boolean usePriorityQueue)
          Broadcasts an RPC command to a specified set of recipients
 Map<Address,Response> RpcManagerImpl.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpc, boolean sync, boolean usePriorityQueue)
           
 Map<Address,Response> RpcManagerImpl.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpc, boolean sync, boolean usePriorityQueue, long timeout)
           
 Map<Address,Response> RpcManager.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout)
          Invokes an RPC call on other caches in the cluster.
 Map<Address,Response> RpcManagerImpl.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout)
           
 Map<Address,Response> RpcManager.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, boolean usePriorityQueue)
          Invokes an RPC call on other caches in the cluster.
 Map<Address,Response> RpcManagerImpl.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, boolean usePriorityQueue)
           
 Map<Address,Response> RpcManager.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, boolean usePriorityQueue, ResponseFilter responseFilter)
          Invokes an RPC call on other caches in the cluster.
 Map<Address,Response> RpcManagerImpl.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, boolean usePriorityQueue, ResponseFilter responseFilter)
           
 void RpcManager.invokeRemotelyInFuture(Collection<Address> recipients, ReplicableCommand rpc, boolean usePriorityQueue, NotifyingNotifiableFuture<Object> future)
          The same as RpcManager.invokeRemotely(java.util.Collection, org.infinispan.commands.ReplicableCommand, boolean) except that the task is passed to the transport executor and a Future is returned.
 void RpcManagerImpl.invokeRemotelyInFuture(Collection<Address> recipients, ReplicableCommand rpc, boolean usePriorityQueue, NotifyingNotifiableFuture<Object> l)
           
 void RpcManager.invokeRemotelyInFuture(Collection<Address> recipients, ReplicableCommand rpc, boolean usePriorityQueue, NotifyingNotifiableFuture<Object> future, long timeout)
          The same as RpcManager.invokeRemotelyInFuture(java.util.Collection, org.infinispan.commands.ReplicableCommand, boolean, org.infinispan.util.concurrent.NotifyingNotifiableFuture) except that you can specify a timeout.
 void RpcManagerImpl.invokeRemotelyInFuture(Collection<Address> recipients, ReplicableCommand rpc, boolean usePriorityQueue, NotifyingNotifiableFuture<Object> l, long timeout)
           
 void RpcManager.invokeRemotelyInFuture(Collection<Address> recipients, ReplicableCommand rpc, boolean usePriorityQueue, NotifyingNotifiableFuture<Object> future, long timeout, boolean ignoreLeavers)
          The same as RpcManager.invokeRemotelyInFuture(java.util.Collection, org.infinispan.commands.ReplicableCommand, boolean, org.infinispan.util.concurrent.NotifyingNotifiableFuture, long) except that you can specify a response mode.
 void RpcManagerImpl.invokeRemotelyInFuture(Collection<Address> recipients, ReplicableCommand rpc, boolean usePriorityQueue, NotifyingNotifiableFuture<Object> l, long timeout, boolean ignoreLeavers)
           
 void RpcManager.invokeRemotelyInFuture(Collection<Address> recipients, ReplicableCommand rpc, NotifyingNotifiableFuture<Object> future)
          The same as RpcManager.invokeRemotely(java.util.Collection, org.infinispan.commands.ReplicableCommand, boolean) except that the task is passed to the transport executor and a Future is returned.
 void RpcManagerImpl.invokeRemotelyInFuture(Collection<Address> recipients, ReplicableCommand rpc, NotifyingNotifiableFuture<Object> l)
           
 

Uses of Address in org.infinispan.remoting.transport
 

Subinterfaces of Address in org.infinispan.remoting.transport
 interface TopologyAwareAddress
          Wraps a TopologyUUID JGroups address
 

Methods in org.infinispan.remoting.transport that return Address
 Address Transport.getAddress()
          Retrieves the current cache instance's network address
 Address Transport.getCoordinator()
           
 

Methods in org.infinispan.remoting.transport that return types with arguments of type Address
 List<Address> Transport.getMembers()
          Returns a list of members in the current cluster view.
 List<Address> Transport.getPhysicalAddresses()
          Retrieves the current cache instance's physical network addresses.
 Map<Address,Response> Transport.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, boolean usePriorityQueue, ResponseFilter responseFilter)
          Invokes an RPC call on other caches in the cluster.
 

Methods in org.infinispan.remoting.transport with parameters of type Address
 boolean AbstractTransport.checkResponse(Object responseObject, Address sender)
           
protected  boolean AbstractTransport.parseResponseAndAddToResponseList(Object responseObject, Throwable exception, Map<Address,Response> responseListToAddTo, boolean wasSuspected, boolean wasReceived, Address sender, boolean usedResponseFilter, boolean ignoreLeavers)
           
 

Method parameters in org.infinispan.remoting.transport with type arguments of type Address
 Map<Address,Response> Transport.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, boolean usePriorityQueue, ResponseFilter responseFilter)
          Invokes an RPC call on other caches in the cluster.
protected  boolean AbstractTransport.parseResponseAndAddToResponseList(Object responseObject, Throwable exception, Map<Address,Response> responseListToAddTo, boolean wasSuspected, boolean wasReceived, Address sender, boolean usedResponseFilter, boolean ignoreLeavers)
           
 

Uses of Address in org.infinispan.remoting.transport.jgroups
 

Classes in org.infinispan.remoting.transport.jgroups that implement Address
 class JGroupsAddress
          An encapsulation of a JGroups Address
 class JGroupsTopologyAwareAddress
          An encapsulation of a JGroups Address
 

Fields in org.infinispan.remoting.transport.jgroups declared as Address
protected  Address JGroupsTransport.address
           
protected  Address JGroupsTransport.coordinator
           
protected  Address JGroupsTransport.physicalAddress
           
 

Fields in org.infinispan.remoting.transport.jgroups with type parameters of type Address
protected  List<Address> JGroupsTransport.members
           
 

Methods in org.infinispan.remoting.transport.jgroups that return Address
 Address JGroupsTransport.getAddress()
           
 Address JGroupsTransport.getCoordinator()
           
 Address SuspectException.getSuspect()
           
 

Methods in org.infinispan.remoting.transport.jgroups that return types with arguments of type Address
 List<Address> JGroupsTransport.getMembers()
           
 List<Address> JGroupsTransport.getPhysicalAddresses()
           
 Map<Address,Response> JGroupsTransport.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, boolean usePriorityQueue, ResponseFilter responseFilter)
           
 

Methods in org.infinispan.remoting.transport.jgroups with parameters of type Address
 int JGroupsAddress.compareTo(Address o)
           
protected static org.jgroups.Address JGroupsTransport.toJGroupsAddress(Address a)
           
 

Method parameters in org.infinispan.remoting.transport.jgroups with type arguments of type Address
 Map<Address,Response> JGroupsTransport.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, boolean usePriorityQueue, ResponseFilter responseFilter)
           
 

Constructors in org.infinispan.remoting.transport.jgroups with parameters of type Address
SuspectException(String msg, Address suspect)
           
SuspectException(String msg, Address suspect, Throwable cause)
           
 

Uses of Address in org.infinispan.statetransfer
 

Methods in org.infinispan.statetransfer that return Address
 Address OutboundTransferTask.getDestination()
           
 Address InboundTransferTask.getSource()
           
 

Methods in org.infinispan.statetransfer with parameters of type Address
 void StateConsumerImpl.applyState(Address sender, int topologyId, Collection<StateChunk> stateChunks)
           
 void StateConsumer.applyState(Address sender, int topologyId, Collection<StateChunk> stateChunks)
           
 void StateProvider.cancelOutboundTransfer(Address destination, int topologyId, Set<Integer> segments)
          Cancel sending of cache entries that belong to the given set of segments.
 void StateProviderImpl.cancelOutboundTransfer(Address destination, int topologyId, Set<Integer> segments)
           
 void StateTransferManager.forwardCommandIfNeeded(TopologyAffectedCommand command, Set<Object> affectedKeys, Address origin, boolean sync)
          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.
 void StateTransferManagerImpl.forwardCommandIfNeeded(TopologyAffectedCommand command, Set<Object> affectedKeys, Address origin, boolean sync)
           
 List<TransactionInfo> StateProvider.getTransactionsForSegments(Address destination, int topologyId, Set<Integer> segments)
          Gets the list of transactions that affect keys from the given segments.
 List<TransactionInfo> StateProviderImpl.getTransactionsForSegments(Address destination, int requestTopologyId, Set<Integer> segments)
           
 void StateProvider.startOutboundTransfer(Address destination, int topologyId, Set<Integer> segments)
          Start to send cache entries that belong to the given set of segments.
 void StateProviderImpl.startOutboundTransfer(Address destination, int requestTopologyId, Set<Integer> segments)
           
 

Constructors in org.infinispan.statetransfer with parameters of type Address
InboundTransferTask(Set<Integer> segments, Address source, int topologyId, StateConsumerImpl stateConsumer, RpcManager rpcManager, CommandsFactory commandsFactory, long timeout, String cacheName)
           
OutboundTransferTask(Address destination, Set<Integer> segments, int stateTransferChunkSize, int topologyId, ConsistentHash readCh, StateProviderImpl stateProvider, DataContainer dataContainer, CacheLoaderManager cacheLoaderManager, RpcManager rpcManager, CommandsFactory commandsFactory, long timeout, String cacheName)
           
StateRequestCommand(String cacheName, StateRequestCommand.Type type, Address origin, int topologyId, Set<Integer> segments)
           
StateResponseCommand(String cacheName, Address origin, int topologyId, Collection<StateChunk> stateChunks)
           
 

Uses of Address in org.infinispan.topology
 

Methods in org.infinispan.topology that return Address
 Address CacheTopologyControlCommand.getOrigin()
           
 

Methods in org.infinispan.topology that return types with arguments of type Address
 List<Address> ClusterCacheStatus.getJoiners()
           
 List<Address> ClusterCacheStatus.getMembers()
           
 List<Address> CacheTopology.getMembers()
           
 List<Address> ClusterCacheStatus.pruneInvalidMembers(List<Address> possibleMembers)
           
 

Methods in org.infinispan.topology with parameters of type Address
 boolean ClusterCacheStatus.addMember(Address joiner)
           
 boolean ClusterCacheStatus.confirmRebalanceOnNode(Address member, int receivedTopologyId)
           
 CacheTopology ClusterTopologyManager.handleJoin(String cacheName, Address joiner, CacheJoinInfo joinInfo, int viewId)
          Updates the members list and notifies the RebalancePolicy.
 CacheTopology ClusterTopologyManagerImpl.handleJoin(String cacheName, Address joiner, CacheJoinInfo joinInfo, int viewId)
           
 void ClusterTopologyManager.handleLeave(String cacheName, Address leaver, int viewId)
          Updates the members list and notifies the RebalancePolicy
 void ClusterTopologyManagerImpl.handleLeave(String cacheName, Address leaver, int viewId)
           
 void ClusterTopologyManager.handleRebalanceCompleted(String cacheName, Address node, int topologyId, Throwable throwable, int viewId)
          Marks the rebalance as complete on the sender.
 void ClusterTopologyManagerImpl.handleRebalanceCompleted(String cacheName, Address node, int topologyId, Throwable throwable, int viewId)
           
 boolean ClusterCacheStatus.removeMember(Address leaver)
           
 

Method parameters in org.infinispan.topology with type arguments of type Address
protected  void ClusterTopologyManagerImpl.handleNewView(List<Address> newMembers, boolean mergeView, int newViewId)
           
 List<Address> ClusterCacheStatus.pruneInvalidMembers(List<Address> possibleMembers)
           
 void ClusterCacheStatus.setMembers(List<Address> newMembers)
           
 void ClusterTopologyManagerImpl.updateCacheStatusAfterMerge(String cacheName, List<Address> clusterMembers, List<CacheTopology> partitionTopologies)
           
 boolean ClusterCacheStatus.updateClusterMembers(List<Address> newClusterMembers)
           
 void ClusterTopologyManagerImpl.updateClusterMembers(List<Address> newClusterMembers)
           
 

Constructors in org.infinispan.topology with parameters of type Address
CacheTopologyControlCommand(String cacheName, CacheTopologyControlCommand.Type type, Address sender, CacheJoinInfo joinInfo, int viewId)
           
CacheTopologyControlCommand(String cacheName, CacheTopologyControlCommand.Type type, Address sender, CacheTopology cacheTopology, int viewId)
           
CacheTopologyControlCommand(String cacheName, CacheTopologyControlCommand.Type type, Address sender, int viewId)
           
CacheTopologyControlCommand(String cacheName, CacheTopologyControlCommand.Type type, Address sender, int topologyId, Throwable throwable, int viewId)
           
 

Uses of Address in org.infinispan.transaction
 

Methods in org.infinispan.transaction that return types with arguments of type Address
 Collection<Address> LocalTransaction.getCommitNodes(Collection<Address> recipients, int currentTopologyId, Collection<Address> members)
          Calculates the list of nodes to which a commit/rollback needs to be sent based on the nodes to which prepare was sent.
 Collection<Address> LocalTransaction.getRemoteLocksAcquired()
           
 

Method parameters in org.infinispan.transaction with type arguments of type Address
 Collection<Address> LocalTransaction.getCommitNodes(Collection<Address> recipients, int currentTopologyId, Collection<Address> members)
          Calculates the list of nodes to which a commit/rollback needs to be sent based on the nodes to which prepare was sent.
 Collection<Address> LocalTransaction.getCommitNodes(Collection<Address> recipients, int currentTopologyId, Collection<Address> members)
          Calculates the list of nodes to which a commit/rollback needs to be sent based on the nodes to which prepare was sent.
 void LocalTransaction.locksAcquired(Collection<Address> nodes)
           
 

Uses of Address in org.infinispan.transaction.xa
 

Fields in org.infinispan.transaction.xa declared as Address
protected  Address GlobalTransaction.addr
           
 

Methods in org.infinispan.transaction.xa that return Address
 Address GlobalTransaction.getAddress()
           
 

Methods in org.infinispan.transaction.xa with parameters of type Address
 GlobalTransaction TransactionFactory.newGlobalTransaction(Address addr, boolean remote)
           
abstract  GlobalTransaction TransactionFactory.TxFactoryEnum.newGlobalTransaction(Address addr, boolean remote, ClusterIdGenerator clusterIdGenerator, boolean clustered)
           
 void GlobalTransaction.setAddress(Address address)
           
 

Constructors in org.infinispan.transaction.xa with parameters of type Address
DldGlobalTransaction(Address addr, boolean remote)
           
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
 Set<Address> RecoveryManager.InDoubtTxInfo.getOwners()
          Returns the set of nodes where this transaction information is maintained.
 Set<Address> InDoubtTxInfoImpl.getOwners()
           
 

Methods in org.infinispan.transaction.xa.recovery with parameters of type Address
 void InDoubtTxInfoImpl.addOwner(Address owner)
           
 String RecoveryManager.forceTransactionCompletionFromCluster(Xid xid, Address where, boolean commit)
          This method invokes RecoveryManager.forceTransactionCompletion(javax.transaction.xa.Xid, boolean) on the specified node.
 String RecoveryManagerImpl.forceTransactionCompletionFromCluster(Xid xid, Address where, boolean commit)
           
 

Method parameters in org.infinispan.transaction.xa.recovery with type arguments of type Address
 void RecoveryAwareRemoteTransaction.computeOrphan(Collection<Address> currentMembers)
          Check's if this transaction's originator is no longer part of the cluster (orphan transaction) and updates RecoveryAwareRemoteTransaction.isOrphan().
 void RecoveryManager.removeRecoveryInformationFromCluster(Collection<Address> where, long internalId, boolean sync)
          Same as #removeRecoveryInformationFromCluster(java.util.Collection but the transaction is identified by its internal id, and not by its xid.
 void RecoveryManagerImpl.removeRecoveryInformationFromCluster(Collection<Address> where, long internalId, boolean sync)
           
 void RecoveryManager.removeRecoveryInformationFromCluster(Collection<Address> where, Xid xid, boolean sync, GlobalTransaction gtx)
          Removes from the specified nodes (or all nodes if the value of 'where' is null) the recovery information associated with these Xids.
 void RecoveryManagerImpl.removeRecoveryInformationFromCluster(Collection<Address> lockOwners, Xid xid, boolean sync, GlobalTransaction gtx)
           
 

Constructors in org.infinispan.transaction.xa.recovery with parameters of type Address
RecoveryAwareDldGlobalTransaction(Address addr, boolean remote)
           
RecoveryAwareGlobalTransaction(Address addr, boolean remote)
           
 

Uses of Address in org.infinispan.util
 

Methods in org.infinispan.util with parameters of type Address
protected  long ClusterIdGenerator.calculateRank(Address address, List<Address> members, long viewId)
           
 

Method parameters in org.infinispan.util with type arguments of type Address
protected  long ClusterIdGenerator.calculateRank(Address address, List<Address> members, long viewId)
           
 

Uses of Address in org.infinispan.util.logging
 

Methods in org.infinispan.util.logging with parameters of type Address
 void Log.failedToRequestSegments(Collection<Integer> segments, String cacheName, Address source, Exception e)
           
 void Log.failedToRetrieveTransactionsForSegments(Collection<Integer> segments, String cacheName, Address source, Exception e)
           
 void Log.joinRehashAborted(Address self, String duration)
           
 void Log.joinRehashCompleted(Address self, String duration)
           
 void Log.localAndPhysicalAddress(Address address, List<Address> physicalAddresses)
           
 void Log.rebalanceError(String cacheName, Address node, Throwable cause)
           
 RemoteException Log.remoteException(Address sender, Exception e)
           
 void Log.remoteExecutionFailed(Address address, Throwable t)
           
 void Log.segmentsRequestedByNodeWithOlderTopology(Address node, int requestTopologyId, int localTopologyId)
           
 void Log.transactionsRequestedByNodeWithOlderTopology(Address node, int requestTopologyId, int localTopologyId)
           
 void Log.unableToLockToInvalidate(Object key, Address address)
           
 void Log.unableToUnlockRebalancedKeys(GlobalTransaction gtx, List<Object> keys, Address self, Throwable t)
           
 

Method parameters in org.infinispan.util.logging with type arguments of type Address
 void Log.cannotSelectRandomMembers(int numNeeded, List<Address> members)
           
 void Log.expectedJustOneResponse(Map<Address,Response> lr)
           
 void Log.keyDoesNotMapToLocalNode(Object key, Collection<Address> nodes)
           
 void Log.localAndPhysicalAddress(Address address, List<Address> physicalAddresses)
           
 void Log.noLiveOwnersFoundForSegment(int segmentId, String cacheName, Collection<Address> owners, Collection<Address> faultySources)
           
 void Log.noLiveOwnersFoundForSegment(int segmentId, String cacheName, Collection<Address> owners, Collection<Address> faultySources)
           
 


Infinispan Distribution 5.2.6.Final-redhat-2

Copyright © 2013 JBoss, a division of Red Hat. All Rights Reserved.