A B C D E F G I K L M N O P R S T U W

A

ADD_NODE - Static variable in class org.activecluster.ClusterEvent
A node has joined the cluster
ActiveMQClusterFactory - class org.activecluster.impl.ActiveMQClusterFactory.
An implementation of ClusterFactory using ActiveMQ
ActiveMQClusterFactory() - Constructor for class org.activecluster.impl.ActiveMQClusterFactory
 
ActiveMQClusterFactory(String) - Constructor for class org.activecluster.impl.ActiveMQClusterFactory
 
ActiveMQClusterFactory(ActiveMQConnectionFactory) - Constructor for class org.activecluster.impl.ActiveMQClusterFactory
 
ActiveMQClusterFactory(boolean, int, String, long) - Constructor for class org.activecluster.impl.ActiveMQClusterFactory
 
ActiveMQClusterFactory(ActiveMQConnectionFactory, boolean, int, String, long) - Constructor for class org.activecluster.impl.ActiveMQClusterFactory
 
addClusterListener(ClusterListener) - Method in interface org.activecluster.Cluster
Adds a new listener to cluster events
addClusterListener(ClusterListener) - Method in class org.activecluster.impl.DefaultCluster
 
addClusterListener(ClusterListener) - Method in class org.activecluster.impl.StateServiceImpl
 
addGroup(Group) - Method in class org.activecluster.group.GroupModel
 
addMember(Node) - Method in class org.activecluster.group.Group
Adds a node to the given group
addNode(Node) - Method in class org.activecluster.group.BuddyGroupModel
 
addNode(Node) - Method in class org.activecluster.group.GroupModel
Adds the new node to this group model; we assume the node has not been added before.
addNodeToGroup(Group, Node) - Method in class org.activecluster.group.GroupModel
 
addToExistingGroup(Node) - Method in class org.activecluster.group.GroupModel
Attempts to add the node to an incomplete group, or a not-full group and returns true if its possible - else returns false
addToGroup(Group) - Method in class org.activecluster.group.NodeMemberships
 
addToIncompleteGroup(Node) - Method in class org.activecluster.group.GroupModel
 
addToNotFullGroup(Node) - Method in class org.activecluster.group.GroupModel
 
addToPendingGroup(LinkedList, Node) - Method in class org.activecluster.group.GroupModel
Adds the given node to the first pending group if possible
addToUnusedNodes(Node) - Method in class org.activecluster.group.GroupModel
 

B

BuddyGroupModel - class org.activecluster.group.BuddyGroupModel.
A kind of GroupModel in which every Node has its own Group and other nodes in the cluster act as buddies (slaves)
BuddyGroupModel() - Constructor for class org.activecluster.group.BuddyGroupModel
 
BullyElectionStrategy - class org.activecluster.election.impl.BullyElectionStrategy.
BullyElectionStrategy Use a simple bully algorithm to elect a coordinator.
BullyElectionStrategy() - Constructor for class org.activecluster.election.impl.BullyElectionStrategy
 

C

Cluster - interface org.activecluster.Cluster.
Represents a logical connection to a cluster.
ClusterEvent - class org.activecluster.ClusterEvent.
A cluster event
ClusterEvent() - Constructor for class org.activecluster.ClusterEvent
empty constructor
ClusterEvent(Cluster, Node, int) - Constructor for class org.activecluster.ClusterEvent
 
ClusterException - exception org.activecluster.ClusterException.
Represents a Cluster related exception
ClusterException() - Constructor for class org.activecluster.ClusterException
 
ClusterFactory - interface org.activecluster.ClusterFactory.
A Factory of Cluster instances
ClusterListener - interface org.activecluster.ClusterListener.
Listener to events occuring on the cluster
canBeMaster(Node) - Method in class org.activecluster.group.GroupModel
Returns true if the given node can be a master
canCreateGroup(Node) - Method in class org.activecluster.group.GroupModel
Returns true if we can add a new group to the cluster
checkForTimeouts() - Method in class org.activecluster.impl.StateServiceImpl
 
coordinator - Variable in class org.activecluster.impl.NodeImpl
 
coordinatorChanged(Node) - Method in class org.activecluster.impl.StateServiceImpl
 
createBytesMessage() - Method in interface org.activecluster.Cluster
Creates a new bytes message
createBytesMessage() - Method in class org.activecluster.impl.DefaultCluster
 
createCluster(Topic) - Method in interface org.activecluster.ClusterFactory
Creates a new cluster connection using the given group
createCluster(String) - Method in interface org.activecluster.ClusterFactory
Creates a new cluster connection using the given topic name
createCluster(Topic) - Method in class org.activecluster.impl.DefaultClusterFactory
 
createCluster(String) - Method in class org.activecluster.impl.DefaultClusterFactory
 
createCluster(Connection, Session, Topic) - Method in class org.activecluster.impl.DefaultClusterFactory
 
createConsumer(Destination) - Method in interface org.activecluster.Cluster
Creates a consumer of all the messags sent to the given destination, including messages sent via the send() messages
createConsumer(Destination, String) - Method in interface org.activecluster.Cluster
Creates a consumer of all message sent to the given destination, including messages sent via the send() message with an optional SQL 92 based selector to filter messages
createConsumer(Destination, String, boolean) - Method in interface org.activecluster.Cluster
Creates a consumer of all message sent to the given destination, including messages sent via the send() message with an optional SQL 92 based selector to filter messages along with optionally ignoring local traffic - messages sent via the send() method on this object.
createConsumer(Destination) - Method in class org.activecluster.impl.DefaultCluster
 
createConsumer(Destination, String) - Method in class org.activecluster.impl.DefaultCluster
 
createConsumer(Destination, String, boolean) - Method in class org.activecluster.impl.DefaultCluster
 
createGroup(Node) - Method in class org.activecluster.group.GroupModel
 
createMapMessage() - Method in interface org.activecluster.Cluster
Creates a new MapMessage
createMapMessage() - Method in class org.activecluster.impl.DefaultCluster
 
createMessage() - Method in interface org.activecluster.Cluster
Creates a new message without a body
createMessage() - Method in class org.activecluster.impl.DefaultCluster
 
createObjectMessage() - Method in interface org.activecluster.Cluster
Creates a new ObjectMessage
createObjectMessage(Serializable) - Method in interface org.activecluster.Cluster
Creates a new ObjectMessage
createObjectMessage() - Method in class org.activecluster.impl.DefaultCluster
 
createObjectMessage(Serializable) - Method in class org.activecluster.impl.DefaultCluster
 
createProducer(Session, Topic) - Method in class org.activecluster.impl.DefaultClusterFactory
 
createSession(Connection) - Method in class org.activecluster.impl.DefaultClusterFactory
 
createStreamMessage() - Method in interface org.activecluster.Cluster
Creates a new StreamMessage
createStreamMessage() - Method in class org.activecluster.impl.DefaultCluster
 
createTextMessage() - Method in interface org.activecluster.Cluster
Creates a new TextMessage
createTextMessage(String) - Method in interface org.activecluster.Cluster
Creates a new TextMessage
createTextMessage() - Method in class org.activecluster.impl.DefaultCluster
 
createTextMessage(String) - Method in class org.activecluster.impl.DefaultCluster
 
createTimerTask() - Method in class org.activecluster.impl.StateServiceImpl
 

D

DEFAULT_CLUSTER_URL - Static variable in class org.activecluster.impl.ActiveMQClusterFactory
 
DefaultCluster - class org.activecluster.impl.DefaultCluster.
A default implementation of ActiveCluster which uses standard JMS operations
DefaultCluster(LocalNode, Topic, Topic, Connection, Session, MessageProducer, Timer, long) - Constructor for class org.activecluster.impl.DefaultCluster
 
DefaultClusterFactory - class org.activecluster.impl.DefaultClusterFactory.
A Factory of DefaultCluster instances
DefaultClusterFactory(ConnectionFactory, boolean, int, String, long) - Constructor for class org.activecluster.impl.DefaultClusterFactory
 
DefaultClusterFactory(ConnectionFactory) - Constructor for class org.activecluster.impl.DefaultClusterFactory
 
doElection(Cluster) - Method in interface org.activecluster.election.ElectionStrategy
Elect a coordinator.
doElection(Cluster) - Method in class org.activecluster.election.impl.BullyElectionStrategy
Elect a coordinator.
doElection() - Method in class org.activecluster.impl.StateServiceImpl
 

E

ELECTED_COORDINATOR - Static variable in class org.activecluster.ClusterEvent
this node has been elected Coordinator
ElectionStrategy - interface org.activecluster.election.ElectionStrategy.
Service Used by the Cluster to elect a coordinator.
evaluate(Node) - Method in class org.activecluster.group.MasterZoneFilter
 
evaluate(Node) - Method in interface org.activecluster.group.NodeFilter
Returns true if the given node matches the filter

F

FAILED_NODE - Static variable in class org.activecluster.ClusterEvent
A node has failed due to a system/network error

G

Group - class org.activecluster.group.Group.
Represents a logical group of nodes in a cluster, such as a Master and a number of Slaves which operate as a logical unit.
Group() - Constructor for class org.activecluster.group.Group
 
Group(int, int) - Constructor for class org.activecluster.group.Group
 
GroupClusterListener - class org.activecluster.group.GroupClusterListener.
A ClusterListener which maintains a GroupModel implementation
GroupClusterListener(GroupModel) - Constructor for class org.activecluster.group.GroupClusterListener
 
GroupModel - class org.activecluster.group.GroupModel.
Represents a collection of zero or more groups in a cluster.
GroupModel() - Constructor for class org.activecluster.group.GroupModel
 
getAcknowledgeMode() - Method in class org.activecluster.impl.DefaultClusterFactory
 
getActiveMQConnectionFactory() - Method in class org.activecluster.impl.ActiveMQClusterFactory
 
getCluster() - Method in class org.activecluster.ClusterEvent
 
getConnectionFactory() - Method in class org.activecluster.impl.DefaultClusterFactory
 
getDataTopicPrefix() - Method in class org.activecluster.impl.DefaultClusterFactory
 
getDeliveryMode() - Method in class org.activecluster.impl.DefaultClusterFactory
 
getDestination() - Method in interface org.activecluster.Cluster
Returns the destination used to send a message to all members of the cluster
getDestination() - Method in interface org.activecluster.Node
Access to the queue to send messages direct to this node.
getDestination() - Method in class org.activecluster.impl.DefaultCluster
 
getDestination() - Method in class org.activecluster.impl.NodeImpl
 
getElectionStrategy() - Method in class org.activecluster.impl.StateServiceImpl
 
getGroups() - Method in class org.activecluster.group.GroupModel
Returns a snapshot of the groups currently available
getInactiveTime() - Method in class org.activecluster.impl.DefaultClusterFactory
 
getInactiveTime() - Method in class org.activecluster.impl.StateServiceImpl
 
getIndex() - Method in class org.activecluster.group.Membership
 
getLocalNode() - Method in interface org.activecluster.Cluster
The local Node which allows you to mutate the state or subscribe to the nodes temporary queue for inbound messages direct to the Node
getLocalNode() - Method in class org.activecluster.impl.DefaultCluster
 
getMasterFilter() - Method in class org.activecluster.group.GroupModel
 
getMaximumGroups() - Method in class org.activecluster.group.GroupModel
 
getMaximumMemberCount() - Method in class org.activecluster.group.Group
 
getMaximumMemberCount() - Method in class org.activecluster.group.GroupModel
 
getMaximumWeighting() - Method in class org.activecluster.group.GroupModel
 
getMemberCount() - Method in class org.activecluster.group.Group
 
getMembers() - Method in class org.activecluster.group.Group
 
getMinimumMemberCount() - Method in class org.activecluster.group.Group
 
getMinimumMemberCount() - Method in class org.activecluster.group.GroupModel
 
getModel() - Method in class org.activecluster.group.GroupClusterListener
 
getName() - Method in interface org.activecluster.Node
 
getName() - Method in class org.activecluster.impl.NodeImpl
 
getNode() - Method in class org.activecluster.ClusterEvent
 
getNode() - Method in class org.activecluster.group.NodeMemberships
 
getNodes() - Method in interface org.activecluster.Cluster
A snapshot of the nodes in the cluster indexed by the Destination
getNodes() - Method in class org.activecluster.impl.DefaultCluster
 
getNodes() - Method in class org.activecluster.impl.StateServiceImpl
 
getSession() - Method in class org.activecluster.impl.DefaultCluster
 
getState() - Method in interface org.activecluster.Node
 
getState() - Method in class org.activecluster.impl.NodeImpl
 
getStatus() - Method in class org.activecluster.group.Membership
 
getTimeMillis() - Method in class org.activecluster.impl.StateServiceImpl
For performance we may wish to use a less granualar timing mechanism only updating the time every x millis since we're only using the time as a judge of when a node has not pinged for at least a few hundred millis etc.
getType() - Method in class org.activecluster.ClusterEvent
 
getWeighting() - Method in class org.activecluster.group.Membership
 
getWeighting() - Method in class org.activecluster.group.NodeMemberships
Returns the weighting of how heavily loaded the node is so that a decision can be made on which node to buddy group with
getZone() - Method in interface org.activecluster.Node
Returns the Zone of this node - typically the DMZ zone or the subnet on which the node is on
getZone() - Method in class org.activecluster.impl.NodeImpl
 

I

isCoordinator() - Method in interface org.activecluster.Node
 
isCoordinator() - Method in class org.activecluster.impl.NodeImpl
 
isFull() - Method in class org.activecluster.group.Group
Returns true if the group cannot accept any more new members
isMember(Group) - Method in class org.activecluster.group.NodeMemberships
Returns true if this node is a member of the given group
isTransacted() - Method in class org.activecluster.impl.DefaultClusterFactory
 
isUsable() - Method in class org.activecluster.group.Group
Returns true if the group is usable, that it has enough members to be used.
isUseQueueForInbox() - Method in class org.activecluster.impl.DefaultClusterFactory
 

K

keepAlive(Node) - Method in interface org.activecluster.impl.StateService
Sends a keep alive to the cluster
keepAlive(Node) - Method in class org.activecluster.impl.StateServiceImpl
 
keepAlive(Node) - Method in class org.activecluster.impl.StateServiceStub
 

L

LocalNode - interface org.activecluster.LocalNode.
Represents the local (in process) node
lastKeepAlive - Variable in class org.activecluster.impl.StateServiceImpl.NodeEntry
 

M

MasterZoneFilter - class org.activecluster.group.MasterZoneFilter.
A filter configured with a list of DMZ zones on which to restrict which nodes are allowed to be master nodes.
MasterZoneFilter(List) - Constructor for class org.activecluster.group.MasterZoneFilter
 
Membership - class org.activecluster.group.Membership.
Represents the membership of a Group for a Node
Membership(Group, int) - Constructor for class org.activecluster.group.Membership
 
makeNewGroup(Node) - Method in class org.activecluster.group.GroupModel
Attempt to make a new group with the current node as the master or if the node cannot be a master node

N

Node - interface org.activecluster.Node.
Represents a node member in a cluster
NodeFilter - interface org.activecluster.group.NodeFilter.
Represents a filter on a Node to allow a pluggable Strategy Pattern to decide which nodes can be master nodes etc.
NodeImpl - class org.activecluster.impl.NodeImpl.
Default implementation of a remote Node
NodeImpl(Node) - Constructor for class org.activecluster.impl.NodeImpl
Allow a node to be copied for sending it as a message
NodeImpl(Destination) - Constructor for class org.activecluster.impl.NodeImpl
 
NodeImpl(Destination, Map) - Constructor for class org.activecluster.impl.NodeImpl
 
NodeMemberships - class org.activecluster.group.NodeMemberships.
Represents all of the memberhips of a node and can be used to act as a weighting to decide which is the least heavily loaded Node to be assigned to a buddy group.
NodeMemberships(Node) - Constructor for class org.activecluster.group.NodeMemberships
 
NonReplicatedLocalNode - class org.activecluster.impl.NonReplicatedLocalNode.
Default implementation of a local Node which doesn't have its state replicated
NonReplicatedLocalNode(Destination) - Constructor for class org.activecluster.impl.NonReplicatedLocalNode
 
node - Variable in class org.activecluster.impl.StateServiceImpl.NodeEntry
 
nodeAdded(Node) - Method in class org.activecluster.impl.StateServiceImpl
 
nodeFailed(Node) - Method in class org.activecluster.impl.StateServiceImpl
 
nodeUpdated(Node) - Method in class org.activecluster.impl.StateServiceImpl
 

O

onCoordinatorChanged(ClusterEvent) - Method in interface org.activecluster.ClusterListener
An election has occurred and a new coordinator has been selected
onCoordinatorChanged(ClusterEvent) - Method in class org.activecluster.group.GroupClusterListener
 
onMessage(Message) - Method in class org.activecluster.impl.StateConsumer
 
onNodeAdd(ClusterEvent) - Method in interface org.activecluster.ClusterListener
A new node has been added
onNodeAdd(ClusterEvent) - Method in class org.activecluster.group.GroupClusterListener
 
onNodeFailed(ClusterEvent) - Method in interface org.activecluster.ClusterListener
A node has failed due to process or network failure
onNodeFailed(ClusterEvent) - Method in class org.activecluster.group.GroupClusterListener
 
onNodeRemoved(ClusterEvent) - Method in interface org.activecluster.ClusterListener
A node has been removed (a clean shutdown)
onNodeRemoved(ClusterEvent) - Method in class org.activecluster.group.GroupClusterListener
 
onNodeUpdate(ClusterEvent) - Method in interface org.activecluster.ClusterListener
A node has updated its state
onNodeUpdate(ClusterEvent) - Method in class org.activecluster.group.GroupClusterListener
 
org.activecluster - package org.activecluster
ActiveCluster API for working with a simple cluster abstraction for building cluster algorithms like buddy systems, voting, master/slave protocols, electing a controller and so forth.
org.activecluster.election - package org.activecluster.election
 
org.activecluster.election.impl - package org.activecluster.election.impl
 
org.activecluster.group - package org.activecluster.group
Contains Group Organsisation models and policies for arranging Node instances into groups, such as buddy-groups (failover nodes) or master/slave groups for High Availability (HA) protocols.
org.activecluster.impl - package org.activecluster.impl
Default implementation of ActiveCluster using standard JMS API to build the cluster.

P

pingRemoteNodes() - Method in class org.activecluster.impl.NonReplicatedLocalNode
 
pingRemoteNodes() - Method in class org.activecluster.impl.ReplicatedLocalNode
 

R

REMOVE_NODE - Static variable in class org.activecluster.ClusterEvent
A node has left the Cluster
ReplicatedLocalNode - class org.activecluster.impl.ReplicatedLocalNode.
Default implementation of a local Node which has its state replicated across the cluster
ReplicatedLocalNode(Destination, StateService) - Constructor for class org.activecluster.impl.ReplicatedLocalNode
 
readExternal(ObjectInput) - Method in class org.activecluster.ClusterEvent
read from stream
removeClusterListener(ClusterListener) - Method in interface org.activecluster.Cluster
Removes a listener to cluster events
removeClusterListener(ClusterListener) - Method in class org.activecluster.impl.DefaultCluster
 
removeClusterListener(ClusterListener) - Method in class org.activecluster.impl.StateServiceImpl
 
removeFromGroup(Group) - Method in class org.activecluster.group.NodeMemberships
 
removeMember(Node) - Method in class org.activecluster.group.Group
 
removeNode(Node) - Method in class org.activecluster.group.GroupModel
Removes the node from the group model
removeNodeFromGroup(Group, Node) - Method in class org.activecluster.group.GroupModel
 

S

STATUS_FAILED - Static variable in class org.activecluster.group.Membership
 
STATUS_OK - Static variable in class org.activecluster.group.Membership
 
STATUS_REQUESTED - Static variable in class org.activecluster.group.Membership
 
STATUS_SYNCHONIZING - Static variable in class org.activecluster.group.Membership
 
Service - interface org.activecluster.Service.
Service represents some service of some kind with a simple start/stop lifecycle.
StateConsumer - class org.activecluster.impl.StateConsumer.
A JMS MessageListener which processes inbound messages and applies them to a StateService
StateConsumer(StateService) - Constructor for class org.activecluster.impl.StateConsumer
 
StateService - interface org.activecluster.impl.StateService.
A client side proxy to the remove cluster
StateServiceImpl - class org.activecluster.impl.StateServiceImpl.
Represents a node list
StateServiceImpl(Cluster, Object, Runnable, Timer, long) - Constructor for class org.activecluster.impl.StateServiceImpl
 
StateServiceImpl.NodeEntry - class org.activecluster.impl.StateServiceImpl.NodeEntry.
 
StateServiceImpl.NodeEntry() - Constructor for class org.activecluster.impl.StateServiceImpl.NodeEntry
 
StateServiceStub - class org.activecluster.impl.StateServiceStub.
A local stub for the state service which sends JMS messages to the cluster
StateServiceStub(Session, MessageProducer) - Constructor for class org.activecluster.impl.StateServiceStub
 
send(Destination, Message) - Method in interface org.activecluster.Cluster
Sends a message to a destination, which could be to the entire group or could be a single Node's destination
send(Destination, Message) - Method in class org.activecluster.impl.DefaultCluster
 
setAcknowledgeMode(int) - Method in class org.activecluster.impl.DefaultClusterFactory
 
setActiveMQConnectionFactory(ActiveMQConnectionFactory) - Method in class org.activecluster.impl.ActiveMQClusterFactory
 
setCluster(Cluster) - Method in class org.activecluster.ClusterEvent
set the cluster
setConnectionFactory(ConnectionFactory) - Method in class org.activecluster.impl.DefaultClusterFactory
 
setCoordinator(boolean) - Method in class org.activecluster.impl.NodeImpl
 
setDataTopicPrefix(String) - Method in class org.activecluster.impl.DefaultClusterFactory
 
setDeliveryMode(int) - Method in class org.activecluster.impl.DefaultClusterFactory
Sets the delivery mode of the group based producer
setElectionStrategy(ElectionStrategy) - Method in class org.activecluster.impl.StateServiceImpl
set the election strategy
setInactiveTime(long) - Method in class org.activecluster.impl.DefaultClusterFactory
 
setInactiveTime(long) - Method in class org.activecluster.impl.StateServiceImpl
 
setIndex(int) - Method in class org.activecluster.group.Membership
 
setMasterFilter(NodeFilter) - Method in class org.activecluster.group.GroupModel
 
setMaximumGroups(int) - Method in class org.activecluster.group.GroupModel
 
setMaximumMemberCount(int) - Method in class org.activecluster.group.Group
 
setMaximumMemberCount(int) - Method in class org.activecluster.group.GroupModel
 
setMaximumWeighting(int) - Method in class org.activecluster.group.GroupModel
 
setMinimumMemberCount(int) - Method in class org.activecluster.group.Group
 
setMinimumMemberCount(int) - Method in class org.activecluster.group.GroupModel
 
setState(Map) - Method in interface org.activecluster.LocalNode
Allows the local state to be modified, which will be replicated asynchronously around the cluster
setState(Map) - Method in class org.activecluster.impl.NodeImpl
 
setState(Map) - Method in class org.activecluster.impl.NonReplicatedLocalNode
 
setState(Map) - Method in class org.activecluster.impl.ReplicatedLocalNode
 
setStatus(int) - Method in class org.activecluster.group.Membership
 
setTransacted(boolean) - Method in class org.activecluster.impl.DefaultClusterFactory
 
setUseQueueForInbox(boolean) - Method in class org.activecluster.impl.DefaultClusterFactory
 
shutdown(Node) - Method in interface org.activecluster.impl.StateService
Sends a shutdown message to the cluster
shutdown(Node) - Method in class org.activecluster.impl.StateServiceImpl
 
shutdown(Node) - Method in class org.activecluster.impl.StateServiceStub
 
start() - Method in interface org.activecluster.Service
Called to start the service
start() - Method in class org.activecluster.impl.DefaultCluster
 
start() - Method in class org.activecluster.impl.ReplicatedLocalNode
 
state - Variable in class org.activecluster.impl.NodeImpl
 
stateHasChanged(Node, Node) - Method in class org.activecluster.impl.StateServiceImpl
 
stop() - Method in interface org.activecluster.Service
Called to shutdown the service
stop() - Method in class org.activecluster.impl.DefaultCluster
 
stop() - Method in class org.activecluster.impl.ReplicatedLocalNode
 

T

toString() - Method in class org.activecluster.ClusterEvent
 
toString() - Method in class org.activecluster.impl.NodeImpl
 
tryToAddBuddy(Group) - Method in class org.activecluster.group.GroupModel
 
tryToFillGroupWithBuddies(Group) - Method in class org.activecluster.group.GroupModel
 

U

UPDATE_NODE - Static variable in class org.activecluster.ClusterEvent
existing node has updated it's state
updateGroupCollections(Group, boolean, boolean) - Method in class org.activecluster.group.GroupModel
Lets move the group from its current state collection to the new collection if its state has changed

W

waitForClusterToComplete(int, long) - Method in interface org.activecluster.Cluster
wait until a the cardimality of the cluster is reaches the expected count.
waitForClusterToComplete(int, long) - Method in class org.activecluster.impl.DefaultCluster
 
writeExternal(ObjectOutput) - Method in class org.activecluster.ClusterEvent
dump on to a stream

A B C D E F G I K L M N O P R S T U W

Copyright © 2004-2007 Protique, Ltd.. All Rights Reserved.