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.control Commands that control and coordinate certain cache operations, such as rehashing, state transfer and locking. 
org.infinispan.commands.read Commands that read data from the cache. 
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.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.demo Classes, programs and applications that help demonstrate how Infinispan can be used. 
org.infinispan.distexec   
org.infinispan.distexec.mapreduce   
org.infinispan.distribution Classes relating to the distributed cache mode. 
org.infinispan.distribution.ch   
org.infinispan.lucenedemo   
org.infinispan.manager Cache manager package 
org.infinispan.notifications.cachelistener Cache-specific notifications and eventing. 
org.infinispan.notifications.cachelistener.event   
org.infinispan.notifications.cachemanagerlistener CacheManager-specific notifications and eventing. 
org.infinispan.notifications.cachemanagerlistener.event   
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.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> KeyAffinityServiceImpl.getAddress2KeysMapping()
           
 

Methods in org.infinispan.affinity with parameters of type Address
 Object 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
KeyAffinityServiceFactory.newKeyAffinityService(Cache<K,V> cache, Collection<Address> filter, KeyGenerator 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
KeyAffinityServiceFactory.newKeyAffinityService(Cache<K,V> cache, Collection<Address> filter, KeyGenerator 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 cache, KeyGenerator 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>
CommandsFactoryImpl.buildDistributedExecuteCommand(Callable<T> callable, Address sender, Collection keys)
           
<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.
 MapReduceCommand CommandsFactoryImpl.buildMapReduceCommand(Mapper m, Reducer r, Address sender, Collection keys)
           
 MapReduceCommand CommandsFactory.buildMapReduceCommand(Mapper m, Reducer r, Address sender, Collection keys)
          Builds a MapReduceCommand used for migration and execution of MapReduce tasks.
 RehashControlCommand CommandsFactoryImpl.buildRehashControlCommand(RehashControlCommand.Type type, Address sender, int viewId)
           
 RehashControlCommand CommandsFactory.buildRehashControlCommand(RehashControlCommand.Type subtype, Address sender, int viewId)
          Builds a RehashControlCommand for coordinating a rehash event.
 RehashControlCommand CommandsFactoryImpl.buildRehashControlCommand(RehashControlCommand.Type type, Address sender, Map<Object,InternalCacheValue> state, ConsistentHash oldCH, ConsistentHash newCH)
           
 RehashControlCommand CommandsFactory.buildRehashControlCommand(RehashControlCommand.Type subtype, Address sender, Map<Object,InternalCacheValue> state, ConsistentHash oldCH, ConsistentHash newCH)
          Builds a RehashControlCommand for coordinating a rehash event.
 

Uses of Address in org.infinispan.commands.control
 

Constructors in org.infinispan.commands.control with parameters of type Address
RehashControlCommand(String cacheName, RehashControlCommand.Type type, Address sender, int viewId)
           
RehashControlCommand(String cacheName, RehashControlCommand.Type type, Address sender, Map<Object,InternalCacheValue> state, ConsistentHash oldConsistentHash, ConsistentHash consistentHash)
           
 

Uses of Address in org.infinispan.commands.read
 

Fields in org.infinispan.commands.read declared as Address
protected  Address MapReduceCommand.localAddress
           
 

Methods in org.infinispan.commands.read with parameters of type Address
 void MapReduceCommand.init(CommandsFactory factory, InterceptorChain invoker, InvocationContextContainer icc, DistributionManager dm, Address localAddress)
           
 

Uses of Address in org.infinispan.commands.remote
 

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

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

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.context
 

Methods in org.infinispan.context that return Address
 Address InvocationContextFlagsOverride.getOrigin()
           
 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
 NonTxInvocationContext InvocationContextContainerImpl.createRemoteInvocationContext(Address origin)
           
 InvocationContext InvocationContextContainer.createRemoteInvocationContext(Address origin)
          Returns an NonTxInvocationContext whose NonTxInvocationContext.isOriginLocal() flag will be true.
 InvocationContext InvocationContextContainerImpl.createRemoteInvocationContextForCommand(VisitableCommand cacheCommand, Address origin)
           
 InvocationContext InvocationContextContainer.createRemoteInvocationContextForCommand(VisitableCommand cacheCommand, Address origin)
          As #createRemoteInvocationContext(), but returning the flags to the context from the Command if any Flag was set.
 RemoteTxInvocationContext InvocationContextContainerImpl.createRemoteTxInvocationContext(Address origin)
           
 RemoteTxInvocationContext InvocationContextContainer.createRemoteTxInvocationContext(Address origin)
          Returns an RemoteTxInvocationContext.
 

Uses of Address in org.infinispan.context.impl
 

Methods in org.infinispan.context.impl that return Address
 Address AbstractInvocationContext.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.demo
 

Method parameters in org.infinispan.demo with type arguments of type Address
 void InfinispanDemo.ClusterTableModel.setMembers(List<Address> m)
           
 

Uses of Address in org.infinispan.distexec
 

Methods in org.infinispan.distexec that return Address
protected  Address DefaultExecutorService.selectExecutionNode()
           
protected  Address DefaultExecutorService.selectExecutionNode(List<Address> candidates)
           
 

Methods in org.infinispan.distexec that return types with arguments of type Address
protected
<K> Map<Address,List<K>>
DefaultExecutorService.mapKeysToNodes(K... input)
           
protected  List<Address> DefaultExecutorService.randomClusterMembers(List<Address> members, int numNeeded)
           
 

Methods in org.infinispan.distexec with parameters of type Address
protected
<T> void
DefaultExecutorService.executeFuture(Address address, org.infinispan.distexec.DefaultExecutorService.DistributedRunnableFuture<T> f)
           
 

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  Map<Address,List<KIn>> MapReduceTask.mapKeysToNodes()
           
 

Uses of Address in org.infinispan.distribution
 

Fields in org.infinispan.distribution declared as Address
protected  Address RehashTask.self
           
 

Methods in org.infinispan.distribution that return Address
 Address RebalanceTask.getMyAddress()
           
 Address DistributionManagerImpl.getSelf()
           
 

Methods in org.infinispan.distribution that return types with arguments of type Address
protected  Collection<Address> RehashTask.coordinator()
           
 List<Address> DistributionManagerImpl.getAffectedNodes(Collection<Object> affectedKeys)
           
 List<Address> DistributionManager.getAffectedNodes(Collection<Object> affectedKeys)
          A helper method that retrieves a list of nodes affected by operations on a set of keys.
 List<Address> DistributionManagerImpl.locate(Object key)
           
 List<Address> DistributionManager.locate(Object key)
          Locates a key in a cluster.
 Map<Object,List<Address>> DistributionManagerImpl.locateAll(Collection<Object> keys)
           
 Map<Object,List<Address>> DistributionManager.locateAll(Collection<Object> keys)
          Locates a list of keys in a cluster.
 Map<Object,List<Address>> DistributionManagerImpl.locateAll(Collection<Object> keys, int numOwners)
           
 Map<Object,List<Address>> DistributionManager.locateAll(Collection<Object> keys, int numOwners)
          Same as DistributionManager.locateAll(java.util.Collection), but the list of addresses only contains numOwners owners.
 

Methods in org.infinispan.distribution with parameters of type Address
 void L1ManagerImpl.addRequestor(Object key, Address origin)
           
 void L1Manager.addRequestor(Object key, Address requestor)
          Records a request that will be cached in another nodes L1
 void DistributionManagerImpl.applyState(ConsistentHash consistentHash, Map<Object,InternalCacheValue> state, Address sender)
           
 void DistributionManager.applyState(ConsistentHash newConsistentHash, Map<Object,InternalCacheValue> state, Address sender)
           
 NotifyingNotifiableFuture<Object> L1ManagerImpl.flushCache(Collection<Object> keys, Object retval, Address origin)
           
 NotifyingNotifiableFuture<Object> L1Manager.flushCache(Collection<Object> keys, Object retval, Address origin)
          Flushes a cache (using unicast or multicast) for a set of keys
 void DistributionManagerImpl.markNodePushCompleted(int viewId, Address node)
           
 void DistributionManager.markNodePushCompleted(int viewId, Address node)
           
 

Method parameters in org.infinispan.distribution with type arguments of type Address
protected  void RebalanceTask.rebalance(Object key, InternalCacheEntry value, int numOwners, ConsistentHash chOld, ConsistentHash chNew, CacheStore cacheStore, Map<Address,Map<Object,InternalCacheValue>> states, List<Object> removedKeys)
          Computes the list of old and new servers for a given key K and value V.
 

Uses of Address in org.infinispan.distribution.ch
 

Classes in org.infinispan.distribution.ch that implement Address
 class VirtualAddress
          Virtual addresses are used internally by the consistent hashes in order to provide virtual nodes.
 

Fields in org.infinispan.distribution.ch declared as Address
 Address ExperimentalDefaultConsistentHash.Entry.address
           
 

Fields in org.infinispan.distribution.ch with type parameters of type Address
protected  Map<Address,Integer> AbstractWheelConsistentHash.addressToHashIds
           
protected  Set<Address> AbstractConsistentHash.caches
           
protected  SortedMap<Integer,Address> AbstractWheelConsistentHash.positions
           
 

Methods in org.infinispan.distribution.ch that return Address
protected  Address AbstractWheelConsistentHash.createVirtualAddress(Address realAddress, int id)
          Default implementation that creates a VirtualAddress from an Address.
 Address VirtualAddress.getRealAddress()
           
protected  Address AbstractWheelConsistentHash.getRealAddress(Address a)
           
 

Methods in org.infinispan.distribution.ch that return types with arguments of type Address
 List<Address> UnionConsistentHash.getBackupsForNode(Address node, int replCount)
           
 List<Address> ExperimentalDefaultConsistentHash.getBackupsForNode(Address node, int replCount)
           
 List<Address> ConsistentHash.getBackupsForNode(Address node, int replCount)
          Returns the nodes that backup data for the supplied node including the node itself.
 List<Address> AbstractWheelConsistentHash.getBackupsForNode(Address node, int replCount)
           
 Set<Address> UnionConsistentHash.getCaches()
           
 Set<Address> ExperimentalDefaultConsistentHash.getCaches()
           
 Set<Address> ConsistentHash.getCaches()
          Should return a collection of cache addresses in the cluster.
 Set<Address> AbstractWheelConsistentHash.getCaches()
           
 Set<Address> AbstractConsistentHash.getCaches()
           
protected  Set<Address> AbstractWheelConsistentHash.getRealAddresses(Set<Address> virtualAddresses)
           
 List<Address> UnionConsistentHash.getStateProvidersOnJoin(Address joiner, int replCount)
           
 List<Address> TopologyAwareConsistentHash.getStateProvidersOnJoin(Address joiner, int replCount)
          In this situation are the same nodes providing state on join as the nodes that provide state on leave.
 List<Address> ExperimentalDefaultConsistentHash.getStateProvidersOnJoin(Address joiner, int replCount)
           
 List<Address> DefaultConsistentHash.getStateProvidersOnJoin(Address self, int replCount)
           
 List<Address> ConsistentHash.getStateProvidersOnJoin(Address joiner, int replCount)
          Returns the nodes that would act as state providers when a new node joins: - the nodes for which the joiner is a backup - the nodes that held joiner's state
 List<Address> UnionConsistentHash.getStateProvidersOnLeave(Address leaver, int replCount)
           
 List<Address> TopologyAwareConsistentHash.getStateProvidersOnLeave(Address leaver, int replCount)
           
 List<Address> ExperimentalDefaultConsistentHash.getStateProvidersOnLeave(Address leaver, int replCount)
           
 List<Address> DefaultConsistentHash.getStateProvidersOnLeave(Address leaver, int replCount)
           
 List<Address> ConsistentHash.getStateProvidersOnLeave(Address leaver, int replCount)
          Returns the nodes that need will replicate their state if the specified node crashes.
 List<Address> UnionConsistentHash.locate(Object key, int replCount)
           
 List<Address> TopologyAwareConsistentHash.locate(Object key, int replCount)
           
 List<Address> ExperimentalDefaultConsistentHash.locate(Object key, int replCount)
           
 List<Address> DefaultConsistentHash.locate(Object key, int replCount)
           
 List<Address> ConsistentHash.locate(Object key, int replCount)
          Locates a key, given a replication count (number of copies).
 Map<Object,List<Address>> ConsistentHash.locateAll(Collection<Object> keys, int replCount)
          The logical equivalent of calling ConsistentHash.locate(Object, int) multiple times for each key in the collection of keys.
 Map<Object,List<Address>> AbstractConsistentHash.locateAll(Collection<Object> keys, int replCount)
           
 

Methods in org.infinispan.distribution.ch with parameters of type Address
protected  void AbstractWheelConsistentHash.addNode(Address a)
           
static ConsistentHash ConsistentHashHelper.createConsistentHash(Configuration c, Collection<Address> addresses, Address... moreAddresses)
          Creates a new consistent hash instance based on the user's configuration, and populates the consistent hash with the collection of addresses passed in.
static ConsistentHash ConsistentHashHelper.createConsistentHash(ConsistentHash template, Collection<Address> addresses, Address... moreAddresses)
          Creates a new consistent hash instance based on the type specified, and populates the consistent hash with the collection of addresses passed in.
protected  Address AbstractWheelConsistentHash.createVirtualAddress(Address realAddress, int id)
          Default implementation that creates a VirtualAddress from an Address.
 List<Address> UnionConsistentHash.getBackupsForNode(Address node, int replCount)
           
 List<Address> ExperimentalDefaultConsistentHash.getBackupsForNode(Address node, int replCount)
           
 List<Address> ConsistentHash.getBackupsForNode(Address node, int replCount)
          Returns the nodes that backup data for the supplied node including the node itself.
 List<Address> AbstractWheelConsistentHash.getBackupsForNode(Address node, int replCount)
           
 int ExperimentalDefaultConsistentHash.getDistance(Address a1, Address a2)
          The distance between the first entries in the address array for two caches, a1 and a2.
 int DefaultConsistentHash.getDistance(Address a1, Address a2)
           
 int UnionConsistentHash.getHashId(Address a)
           
 int ExperimentalDefaultConsistentHash.getHashId(Address a)
           
 int ConsistentHash.getHashId(Address a)
          Deprecated. This method doesn't work with virtual nodes enabled (it will always return -1)
 int AbstractWheelConsistentHash.getHashId(Address a)
           
protected  Address AbstractWheelConsistentHash.getRealAddress(Address a)
           
 List<Address> UnionConsistentHash.getStateProvidersOnJoin(Address joiner, int replCount)
           
 List<Address> TopologyAwareConsistentHash.getStateProvidersOnJoin(Address joiner, int replCount)
          In this situation are the same nodes providing state on join as the nodes that provide state on leave.
 List<Address> ExperimentalDefaultConsistentHash.getStateProvidersOnJoin(Address joiner, int replCount)
           
 List<Address> DefaultConsistentHash.getStateProvidersOnJoin(Address self, int replCount)
           
 List<Address> ConsistentHash.getStateProvidersOnJoin(Address joiner, int replCount)
          Returns the nodes that would act as state providers when a new node joins: - the nodes for which the joiner is a backup - the nodes that held joiner's state
 List<Address> UnionConsistentHash.getStateProvidersOnLeave(Address leaver, int replCount)
           
 List<Address> TopologyAwareConsistentHash.getStateProvidersOnLeave(Address leaver, int replCount)
           
 List<Address> ExperimentalDefaultConsistentHash.getStateProvidersOnLeave(Address leaver, int replCount)
           
 List<Address> DefaultConsistentHash.getStateProvidersOnLeave(Address leaver, int replCount)
           
 List<Address> ConsistentHash.getStateProvidersOnLeave(Address leaver, int replCount)
          Returns the nodes that need will replicate their state if the specified node crashes.
 boolean ExperimentalDefaultConsistentHash.isAdjacent(Address a1, Address a2)
          Two hashes are adjacent if they are next to each other in the consistent hash.
 boolean DefaultConsistentHash.isAdjacent(Address a1, Address a2)
           
 boolean DefaultConsistentHash.isKeyLocalToAddress(Address target, Object key, int replCount)
           
 boolean ConsistentHash.isKeyLocalToAddress(Address a, Object key, int replCount)
          Test to see whether a key is mapped to a given address.
 boolean AbstractConsistentHash.isKeyLocalToAddress(Address a, Object key, int replCount)
           
static ConsistentHash ConsistentHashHelper.removeAddress(ConsistentHash ch, Address toRemove, Configuration c)
          Returns a new consistent hash of the same type with the given address removed.
static UnionConsistentHash ConsistentHashHelper.removeAddressFromUnionConsistentHash(UnionConsistentHash uch, Address toRemove, Configuration c)
          Creates a new UnionConsistentHash instance based on the old instance, removing the provided address from both target consistent hash instances in the union.
 

Method parameters in org.infinispan.distribution.ch with type arguments of type Address
static ConsistentHash ConsistentHashHelper.createConsistentHash(Configuration c, Collection<Address> addresses)
          Creates a new consistent hash instance based on the user's configuration, and populates the consistent hash with the collection of addresses passed in.
static ConsistentHash ConsistentHashHelper.createConsistentHash(Configuration c, Collection<Address> addresses, Address... moreAddresses)
          Creates a new consistent hash instance based on the user's configuration, and populates the consistent hash with the collection of addresses passed in.
static ConsistentHash ConsistentHashHelper.createConsistentHash(Configuration c, Collection<Address> addresses, Collection<Address> moreAddresses)
          Creates a new consistent hash instance based on the user's configuration, and populates the consistent hash with the collection of addresses passed in.
static ConsistentHash ConsistentHashHelper.createConsistentHash(Configuration c, Collection<Address> addresses, Collection<Address> moreAddresses)
          Creates a new consistent hash instance based on the user's configuration, and populates the consistent hash with the collection of addresses passed in.
static ConsistentHash ConsistentHashHelper.createConsistentHash(ConsistentHash template, Collection<Address> addresses)
          Creates a new consistent hash instance based on the type specified, and populates the consistent hash with the collection of addresses passed in.
static ConsistentHash ConsistentHashHelper.createConsistentHash(ConsistentHash template, Collection<Address> addresses, Address... moreAddresses)
          Creates a new consistent hash instance based on the type specified, and populates the consistent hash with the collection of addresses passed in.
protected  Set<Address> AbstractWheelConsistentHash.getRealAddresses(Set<Address> virtualAddresses)
           
 void ExperimentalDefaultConsistentHash.setCaches(List<Address> caches)
           
 void UnionConsistentHash.setCaches(Set<Address> caches)
           
 void ConsistentHash.setCaches(Set<Address> caches)
          Sets the collection of cache addresses in the cluster.
 void AbstractWheelConsistentHash.setCaches(Set<Address> newCaches)
           
 void AbstractConsistentHash.setCaches(Set<Address> caches)
           
 

Constructors in org.infinispan.distribution.ch with parameters of type Address
ExperimentalDefaultConsistentHash.Entry(Address address, String string, int differentiator, int hash)
           
VirtualAddress(Address realAddress, int id)
           
 

Uses of Address in org.infinispan.lucenedemo
 

Methods in org.infinispan.lucenedemo that return types with arguments of type Address
 List<Address> DemoActions.listAllMembers()
          Returns a list of Addresses of all members in the cluster
 

Uses of Address in org.infinispan.manager
 

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

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

Uses of Address in org.infinispan.notifications.cachelistener
 

Method parameters in org.infinispan.notifications.cachelistener with type arguments of type Address
 void CacheNotifierImpl.notifyDataRehashed(Collection<Address> oldView, Collection<Address> newView, long newViewId, boolean pre)
           
 void CacheNotifierImpl.notifyDataRehashed(Collection<Address> oldView, Collection<Address> newView, long newViewId, boolean pre)
           
 void CacheNotifier.notifyDataRehashed(Collection<Address> oldView, Collection<Address> newView, long newViewId, boolean pre)
           
 void CacheNotifier.notifyDataRehashed(Collection<Address> oldView, Collection<Address> newView, long newViewId, boolean pre)
           
 

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> EventImpl.getMembersAtEnd()
           
 Collection<Address> DataRehashedEvent.getMembersAtEnd()
           
 Collection<Address> EventImpl.getMembersAtStart()
           
 Collection<Address> DataRehashedEvent.getMembersAtStart()
           
 

Method parameters in org.infinispan.notifications.cachelistener.event with type arguments of type Address
 void EventImpl.setMembersAtEnd(Collection<Address> membersAtEnd)
           
 void EventImpl.setMembersAtStart(Collection<Address> membersAtStart)
           
 

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()
           
 List<Address> EventImpl.getNewMembers()
           
 List<Address> ViewChangedEvent.getOldMembers()
           
 List<Address> EventImpl.getOldMembers()
           
 List<List<Address>> MergeEvent.getSubgroupsMerged()
           
 List<List<Address>> EventImpl.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.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 InboundInvocationHandlerImpl.handle(CacheRpcCommand cmd, Address origin)
           
 Response InboundInvocationHandler.handle(CacheRpcCommand command, Address origin)
          Invokes a command on the cache, from a remote source.
 

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 ClusteredGetResponseValidityFilter.isAcceptable(Response response, Address address)
           
 

Constructor parameters in org.infinispan.remoting.responses with type arguments of type Address
ClusteredGetResponseValidityFilter(Collection<Address> pendingResponders)
           
 

Uses of Address in org.infinispan.remoting.rpc
 

Methods in org.infinispan.remoting.rpc that return Address
 Address RpcManagerImpl.getAddress()
           
 Address RpcManager.getAddress()
          Returns the address associated with this RpcManager or null if not part of the cluster.
 Address RpcManagerImpl.getCurrentStateTransferSource()
           
 Address RpcManager.getCurrentStateTransferSource()
          If RpcManager.retrieveState(String, long) has been invoked and hasn't yet returned (i.e., a state transfer is in progress), this method will return the current Address from which a state transfer is being attempted.
 

Methods in org.infinispan.remoting.rpc that return types with arguments of type Address
 Map<Address,Response> RpcManagerImpl.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpc, boolean sync, boolean usePriorityQueue)
           
 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, long timeout)
           
 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)
          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)
          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)
           
 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.
 

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
 void RpcManagerImpl.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpc, boolean sync)
           
 void 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, boolean usePriorityQueue)
           
 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, long timeout)
           
 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)
          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)
          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)
           
 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.
 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)
          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, long timeout)
           
 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, NotifyingNotifiableFuture<Object> l)
           
 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.
 

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, boolean supportReplay)
          Invokes an RPC call on other caches in the cluster.
 

Methods in org.infinispan.remoting.transport with parameters of type Address
protected  boolean AbstractTransport.parseResponseAndAddToResponseList(Object responseObject, Map<Address,Response> responseListToAddTo, boolean wasSuspected, boolean wasReceived, Address sender, boolean usedResponseFilter)
           
 boolean Transport.retrieveState(String cacheName, Address address, long timeout)
          Initiates a state retrieval from a specific cache (by typically invoking InboundInvocationHandler.generateState(String, java.io.OutputStream)), and applies this state to the current cache via the InboundInvocationHandler.applyState(String, java.io.InputStream) callback.
 

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, boolean supportReplay)
          Invokes an RPC call on other caches in the cluster.
protected  boolean AbstractTransport.parseResponseAndAddToResponseList(Object responseObject, Map<Address,Response> responseListToAddTo, boolean wasSuspected, boolean wasReceived, Address sender, boolean usedResponseFilter)
           
 

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.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, boolean supportReplay)
           
 

Methods in org.infinispan.remoting.transport.jgroups with parameters of type Address
 boolean JGroupsTransport.retrieveState(String cacheName, Address address, long timeout)
           
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, boolean supportReplay)
           
 

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.transaction
 

Methods in org.infinispan.transaction that return types with arguments of type Address
 Collection<Address> LocalTransaction.getRemoteLocksAcquired()
           
 

Method parameters in org.infinispan.transaction with type arguments of type Address
 void LocalTransaction.filterRemoteLocksAcquire(Collection<Address> existingMembers)
           
 boolean LocalTransaction.hasRemoteLocksAcquired(Collection<Address> leavers)
           
 void LocalTransaction.locksAcquired(Collection<Address> nodes)
           
protected  void TransactionTable.updateStateOnNodesLeaving(Collection<Address> leavers)
           
 

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
 boolean DldGlobalTransaction.isAcquiringRemoteLock(Object key, Address 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 RecoveryManagerImpl.forceTransactionCompletionFromCluster(Xid xid, Address where, boolean commit)
           
 String RecoveryManager.forceTransactionCompletionFromCluster(Xid xid, Address where, boolean commit)
          This method invokes RecoveryManager.forceTransactionCompletion(javax.transaction.xa.Xid, boolean) on the specified node.
 

Method parameters in org.infinispan.transaction.xa.recovery with type arguments of type Address
 void RecoveryAwareRemoteTransaction.computeOrphan(Collection<Address> leavers)
          Check's if this transaction's originator is no longer part of the cluster (orphan transaction) and updates RecoveryAwareRemoteTransaction.isOrphan().
 void RecoveryManagerImpl.removeRecoveryInformationFromCluster(Collection<Address> where, long internalId, boolean sync)
           
 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> lockOwners, Xid xid, boolean sync)
           
 void RecoveryManager.removeRecoveryInformationFromCluster(Collection<Address> where, Xid xid, boolean sync)
          Removes from the specified nodes (or all nodes if the value of 'where' is null) the recovery information associated with these Xids.
protected  void RecoveryAwareTransactionTable.updateStateOnNodesLeaving(Collection<Address> leavers)
           
 

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
 long ClusterIdGenerator.RankCalculator.calculateRank(Address address, List<Address> members, long viewId)
           
 

Method parameters in org.infinispan.util with type arguments of type Address
 long ClusterIdGenerator.RankCalculator.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.completedLeaveRehash(Address self, String duration, List<Address> leavers)
           
 void Log.joinEvent(Address joiner)
           
 void Log.joinRehashAborted(Address self, String duration)
           
 void Log.joinRehashCompleted(Address self, String duration)
           
 void Log.leaveEvent(Address leaver)
           
 void Log.localAndPhysicalAddress(Address address, List<Address> physicalAddresses)
           
 void Log.participatingInRehash(Address address, List<Address> stateProviders, List<Address> receiversOfLeaverState)
           
 void Log.remoteExecutionFailed(Address address, Throwable t)
           
 void Log.successfullyAppliedState(Address member)
           
 void Log.tryingToFetchState(Address member)
           
 void Log.unableToLockToInvalidate(Object key, Address address)
           
 void Log.unableToRetrieveState(Address member, Exception e)
           
 

Method parameters in org.infinispan.util.logging with type arguments of type Address
 void Log.cannotSelectRandomMembers(int numNeeded, List<Address> members)
           
 void Log.completedLeaveRehash(Address self, String duration, List<Address> leavers)
           
 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.participatingInRehash(Address address, List<Address> stateProviders, List<Address> receiversOfLeaverState)
           
 void Log.participatingInRehash(Address address, List<Address> stateProviders, List<Address> receiversOfLeaverState)
           
 void Log.viewChangeDetected(List<Address> oldMembers, List<Address> newMembers)
           
 void Log.viewChangeDetected(List<Address> oldMembers, List<Address> newMembers)
           
 


-->

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