Rice Pastry API
A B C D E F G H I J K L M N O P R S T U V W X _

A

abs(int) - Method in class rice.pastry.testing.LeafSetTest
 
AbstractSubscribeMessage - class rice.p2p.scribe.messaging.AbstractSubscribeMessage.
 
AbstractSubscribeMessage(NodeHandle, Topic, int) - Constructor for class rice.p2p.scribe.messaging.AbstractSubscribeMessage
Constructor which takes a unique integer Id
accept(SelectionKey) - Method in class rice.pastry.wire.DatagramManager
Specified by the SelectionKeyHandler - should NEVER be called (since datagrams are never accepted).
accept(SelectionKey) - Method in interface rice.pastry.wire.SelectionKeyHandler
Method which is called when the key becomes acceptable.
accept(SelectionKey) - Method in class rice.pastry.wire.SocketManager
Specified by the SelectionKeyHandler interface.
accept(SelectionKey) - Method in class rice.pastry.wire.WireNodeHandle
Requeired by the SelectionKeyHandler interface.
acceptAnycast - Variable in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribeClient
Whether or not this client should accept anycasts
acceptAnycast(boolean) - Method in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribeClient
 
accepted() - Method in class rice.pastry.join.JoinRequest
Returns true if the request was accepted, false if it hasn't yet.
acceptJoin(NodeHandle, LeafSet) - Method in class rice.pastry.join.JoinRequest
Accept join request.
AcknowledgementMessage - class rice.pastry.wire.messaging.datagram.AcknowledgementMessage.
Class which represents an "ack" packet in the UDP version of the pastry wire protocol.
AcknowledgementMessage(NodeId, NodeId, int, InetSocketAddress) - Constructor for class rice.pastry.wire.messaging.datagram.AcknowledgementMessage
Constructor.
add(Id.Distance) - Method in class rice.pastry.Id
Returns an Id corresponding to this Id plus a given distance
add(PendingWrite) - Method in class rice.pastry.wire.DatagramTransmissionManager
Adds a pending write to the queue.
addChild(NodeHandle) - Method in class rice.p2p.scribe.ScribeImpl.TopicManager
Adds a feature to the Child attribute of the TopicManager object
addChild(NodeHandle, NodeId) - Method in interface rice.scribe.IScribe
Add a node as a child in the children table for a topic.
addChild(NodeHandle, NodeId) - Method in class rice.scribe.Scribe
Add a node as a child in the children table for a topic.
addChild(NodeHandle, NodeId, Serializable) - Method in class rice.scribe.Scribe
Add a node as a child in the children table for a topic.
addChild(NodeHandle, ScribeMessage) - Method in class rice.scribe.Topic
Adds a node to the Set of children in this topic's multicast subtree rooted at this node
addChild(NodeHandle, ScribeMessage, Serializable) - Method in class rice.scribe.Topic
Adds a node to the Set of children in this topic's multicast subtree rooted at this node.
addChild(Topic, NodeHandle) - Method in interface rice.p2p.scribe.Scribe
Adds a child to the given topic
addChild(Topic, NodeHandle) - Method in class rice.p2p.scribe.ScribeImpl
Adds a child to the given topic
addChildForTopic(NodeHandle, NodeId) - Method in class rice.scribe.Scribe
Adds a child for a topic into the distinctChildrenTable.
addChildPastryNode(MultiRingPastryNode) - Method in class rice.pastry.multiring.MultiRingPastryNode
 
addChildToAlreadySentHBNodes(NodeId) - Method in class rice.scribe.Scribe
Adds a child to the list of nodes to which this node has already send a implicit HeartBeat message in the form of Publish message in this Heartbeat period.
addClient(ScribeClient) - Method in class rice.p2p.scribe.ScribeImpl.TopicManager
Adds a feature to the Client attribute of the TopicManager object
addDistance(double) - Method in class rice.pastry.testing.PingTestRecord
 
addFirst(NodeHandle) - Method in class rice.p2p.scribe.messaging.AnycastMessage
Adds a node the the front of the to-visit list
addHop(NodeHandle) - Method in class rice.p2p.past.messaging.LookupMessage
Method which is designed to be overridden by subclasses if they need to keep track of where they've been.
addHop(NodeHandle) - Method in class rice.p2p.past.messaging.PastMessage
Method which is designed to be overridden by subclasses if they need to keep track of where they've been.
addHops(int) - Method in class rice.pastry.testing.PingTestRecord
 
addId(Id) - Method in interface rice.p2p.commonapi.IdSet
add a member
addId(Id) - Method in class rice.pastry.IdSet
add a member
addLast(NodeHandle) - Method in class rice.p2p.scribe.messaging.AnycastMessage
Adds a node the the end of the to-visit list
addLeafSetObserver(Observer) - Method in class rice.pastry.multiring.MultiRingPastryNode
 
addLeafSetObserver(Observer) - Method in class rice.pastry.PastryNode
Add a leaf set observer to the Pastry node.
addMember(Id) - Method in class rice.pastry.IdSet
add a member
addObserver(Observer) - Method in class rice.pastry.dist.DistNodeHandle
 
addObserver(Observer) - Method in class rice.pastry.leafset.LeafSet
Add observer method.
addParentForTopic(NodeHandle, NodeId) - Method in class rice.scribe.Scribe
Adds a parent for a topic into the distinctParentTable.
addPending(ObjectInputStream, LocalNodeI) - Method in class rice.pastry.PendingLocalNodesList
Adds a pending LocalNode to the list of pending LocalNodes.
addPendingEvent(NodeId, int) - Method in class rice.rm.RMImpl
Used to insert entries to the m_pendingEvents hashtable
addPendingRange(NodeId, IdRange) - Method in class rice.rm.RMImpl
Used to insert a pending range to the m_pendingRanges hashtable
address - Variable in class rice.pastry.client.PastryAppl
 
address - Variable in class rice.pastry.dist.DistNodeHandle
 
Address - interface rice.pastry.messaging.Address.
The address interface.
addRing(RingId) - Method in class rice.pastry.multiring.MultiRingAppl
 
addRouteSetObserver(Observer) - Method in class rice.pastry.multiring.MultiRingPastryNode
 
addRouteSetObserver(Observer) - Method in class rice.pastry.PastryNode
Add a route set observer to the Pastry node.
addToId(Id.Distance) - Method in interface rice.p2p.commonapi.Id
Returns an Id corresponding to this Id plus a given distance
addToId(Id.Distance) - Method in class rice.pastry.Id
Returns an Id corresponding to this Id plus a given distance
addToScribe() - Method in class rice.scribe.Topic
Creates a topic reference on the current Scribe node.
addVisited(NodeHandle) - Method in class rice.p2p.scribe.messaging.AnycastMessage
Adds a node to the visited list
afterSetLocalNode() - Method in class rice.pastry.dist.DistNodeHandle
Method called from LocalNode after localnode is set to non-null.
afterSetLocalNode() - Method in class rice.pastry.LocalNode
Method that can be overridden by handle to set isLocal, etc.
afterSetLocalNode() - Method in class rice.pastry.NodeHandle
Method that can be overridden by handle to set isLocal, etc.
alive - Variable in class rice.pastry.dist.DistNodeHandle
 
allowSubscribe - Variable in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribePolicy
 
allowSubscribe(boolean) - Method in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribePolicy
 
allowSubscribe(SubscribeMessage, ScribeClient[], NodeHandle[]) - Method in interface rice.p2p.scribe.ScribePolicy
This method is called when the newChild is about to become our child, and the policy should return whether or not the child should be allowed to become our child.
allowSubscribe(SubscribeMessage, ScribeClient[], NodeHandle[]) - Method in class rice.p2p.scribe.ScribePolicy.DefaultScribePolicy
This method always return true;
allowSubscribe(SubscribeMessage, ScribeClient[], NodeHandle[]) - Method in class rice.p2p.scribe.ScribePolicy.LimitedScribePolicy
This method returns (children.length < maxChildren-1);
allowSubscribe(SubscribeMessage, ScribeClient[], NodeHandle[]) - Method in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribePolicy
 
allowSubscribe(SubscribeMessage, ScribeClient[], NodeHandle[]) - Method in class rice.p2p.splitstream.SplitStreamScribePolicy
This method implements the "locating parent" algorithm of SplitStream.
alreadySeenSize() - Method in class rice.scribe.messaging.MessageAnycast
Method returns the number of nodes visited during the DFS.
alternateRoutes(Id, int) - Method in class rice.pastry.routing.RoutingTable
Determines a set of alternate hops towards a given key.
alternateTest() - Method in class rice.pastry.testing.NodeIdUnit
 
anycast(NodeId) - Method in class rice.scribe.testing.BasicScribeRegrTestApp
direct call to scribe for anycasting to a topic from the current node.
anycast(NodeId) - Method in class rice.scribe.testing.DirectScribeMaintenanceTestApp
direct call to scribe for anycasting to a topic from the current node
anycast(NodeId, MessageAnycast, Credentials) - Method in interface rice.scribe.IScribe
An application can create sub-classes of MessageAnycast type of messages and write their own handling functions so as to take care of routing of these messages and also to handle cases where the anycast message reaches an intermediate node where there is no application running to take care of it.
anycast(NodeId, MessageAnycast, Credentials) - Method in class rice.scribe.Scribe
An application can create sub-classes of MessageAnycast type of messages and write their own handling functions so as to do some application-specific predicate searching.
anycast(NodeId, Serializable) - Method in class rice.scribe.testing.DistScribeRegrTestApp
direct call to scribe for anycasting to a topic from the current node.
anycast(NodeId, Serializable, Credentials) - Method in interface rice.scribe.IScribe
Anycast to a group/topic.
anycast(NodeId, Serializable, Credentials) - Method in class rice.scribe.Scribe
Anycast to a group/topic.
anycast(Topic, ScribeContent) - Method in interface rice.p2p.scribe.Scribe
Anycasts the given content to a member of the given topic
anycast(Topic, ScribeContent) - Method in interface rice.p2p.scribe.ScribeClient
This method is invoked when an anycast is received for a topic which this client is interested in.
anycast(Topic, ScribeContent) - Method in class rice.p2p.scribe.ScribeImpl
Anycasts the given content to a member of the given topic
anycast(Topic, ScribeContent) - Method in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribeClient
DESCRIBE THE METHOD
anycast(Topic, ScribeContent) - Method in class rice.p2p.splitstream.Stripe
This method is invoked when an anycast is received for a topic which this client is interested in.
anycastHandler(ScribeMessage) - Method in class rice.pastry.multiring.MultiRingAppl
 
anycastHandler(ScribeMessage) - Method in interface rice.scribe.IScribeApp
Invoked by underlying scribe when it receives a anycast Message, to check if there is a local application which can take care of this anycast message.
anycastHandler(ScribeMessage) - Method in class rice.scribe.testing.BasicScribeRegrTestApp
up-call invoked by Scribe when an anycast message is being handled.
anycastHandler(ScribeMessage) - Method in class rice.scribe.testing.DirectScribeMaintenanceTestApp
up-call invoked by Scribe when an anycast message is being handled.
anycastHandler(ScribeMessage) - Method in class rice.scribe.testing.DistScribeRegrTestApp
up-call invoked by Scribe when an anycast message is being handled.
AnycastMessage - class rice.p2p.scribe.messaging.AnycastMessage.
 
AnycastMessage(NodeHandle, Topic, ScribeContent) - Constructor for class rice.p2p.scribe.messaging.AnycastMessage
Constructor which takes a unique integer Id
anycastMessages - Variable in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribeClient
The publish messages received so far
app - Variable in class rice.rm.RMImpl
Application that uses this Replica Manager.
application - Variable in class rice.pastry.commonapi.PastryEndpoint
 
Application - interface rice.p2p.commonapi.Application.
 
apps - Variable in class rice.pastry.PastryNode
 
assertEquals(String, Object, Object) - Method in class rice.p2p.commonapi.testing.CommonAPITest
Thows an exception if expected is not equal to actual.
assertEquals(String, String, Object, Object) - Method in class rice.past.testing.DistPASTRegrTest
Deprecated. Thows an exception if expected is not equal to actual.
assertLocalNode() - Method in class rice.pastry.LocalNode
May be called from handle etc methods to ensure that local node has been set, either on construction or on deserialization/receivemsg.
assertLocalNode() - Method in interface rice.pastry.LocalNodeI
May be called from handle etc methods to ensure that local node has been set, either on construction or on deserialization/receivemsg.
assertLocalNode() - Method in class rice.pastry.NodeHandle
May be called from handle etc methods to ensure that local node has been set, either on construction or on deserialization/receivemsg.
assertTrue(String, boolean) - Method in class rice.p2p.commonapi.testing.CommonAPITest
Throws an exception if the test condition is not met.
assertTrue(String, boolean) - Method in class rice.pastry.testing.LeafSetTest
Throws an exception if the test condition is not met.
assertTrue(String, String, boolean) - Method in class rice.past.testing.DistPASTRegrTest
Deprecated. Throws an exception if the test condition is not met.
attachChannel(ChannelId) - Method in interface rice.p2p.splitstream.SplitStream
A SplitStream application calls this method to join a channel.
attachChannel(ChannelId) - Method in class rice.p2p.splitstream.SplitStreamImpl
This method is used by peers who wish to listen to content distributed by some other peer using SplitStream.

B

baseBitLength() - Static method in class rice.pastry.routing.RoutingTable
return the bit length of the base
baseFiddlingTest() - Method in class rice.pastry.testing.NodeIdUnit
 
BasicScribeRegrTest - class rice.scribe.testing.BasicScribeRegrTest.
 
BasicScribeRegrTest() - Constructor for class rice.scribe.testing.BasicScribeRegrTest
 
BasicScribeRegrTestApp - class rice.scribe.testing.BasicScribeRegrTestApp.
 
BasicScribeRegrTestApp(PastryNode, Scribe, int, Credentials) - Constructor for class rice.scribe.testing.BasicScribeRegrTestApp
 
BEGIN_ACK_NUM - Static variable in class rice.pastry.wire.DatagramTransmissionManager
 
bestAlternateRoute(Id) - Method in class rice.pastry.routing.RoutingTable
Determines an alternate hop numerically closer to the key than the one we are at.
BFS(NodeId) - Method in class rice.scribe.testing.DirectScribeMaintenanceTest
This does the Breadth First Traversal of the multicast tree for a topic.
blit(byte[]) - Method in class rice.pastry.Id
Blits the Id into a target array.
blit(byte[]) - Method in class rice.pastry.Id.Distance
Blits the distance into a target array.
blit(byte[]) - Method in class rice.pastry.multiring.RingId
Blits the ringId into a target array.
BOOTSTRAP_HOST - Static variable in class rice.p2p.commonapi.testing.CommonAPITest
 
BOOTSTRAP_PORT - Static variable in class rice.p2p.commonapi.testing.CommonAPITest
 
broadcast() - Method in class rice.pastry.standard.StandardLeafSetProtocol
Broadcast the leaf set to all members of the local leaf set.
broadcast(int) - Method in class rice.pastry.standard.StandardLeafSetProtocol
Broadcast the leaf set to all members of the local leaf set.
broadcast(LeafSet, NodeHandle) - Method in class rice.pastry.standard.StandardLeafSetProtocol
Broadcast the local leaf set to all members of the given leaf set, plus the node from which the leaf set was received.
BroadcastLeafSet - class rice.pastry.leafset.BroadcastLeafSet.
Broadcast a leaf set to another node.
BroadcastLeafSet(Credentials, Date, NodeHandle, LeafSet, int) - Constructor for class rice.pastry.leafset.BroadcastLeafSet
Constructor.
BroadcastLeafSet(Credentials, NodeHandle, LeafSet, int) - Constructor for class rice.pastry.leafset.BroadcastLeafSet
Constructor.
BroadcastLeafSet(Date, NodeHandle, LeafSet, int) - Constructor for class rice.pastry.leafset.BroadcastLeafSet
Constructor.
BroadcastLeafSet(NodeHandle, LeafSet, int) - Constructor for class rice.pastry.leafset.BroadcastLeafSet
Constructor.
broadcastRingId(RingId) - Method in class rice.pastry.multiring.MultiRingPastryNode
 
BroadcastRouteRow - class rice.pastry.routing.BroadcastRouteRow.
Broadcast message for a row from a routing table.
BroadcastRouteRow(Credentials, Date, NodeHandle, RouteSet[]) - Constructor for class rice.pastry.routing.BroadcastRouteRow
Constructor.
BroadcastRouteRow(Credentials, NodeHandle, RouteSet[]) - Constructor for class rice.pastry.routing.BroadcastRouteRow
Constructor.
BroadcastRouteRow(Date, NodeHandle, RouteSet[]) - Constructor for class rice.pastry.routing.BroadcastRouteRow
Constructor.
BroadcastRouteRow(NodeHandle, RouteSet[]) - Constructor for class rice.pastry.routing.BroadcastRouteRow
Constructor.
broadcastRows(JoinRequest) - Method in class rice.pastry.standard.StandardJoinProtocol
Broadcasts the route table rows.
buildId(byte[]) - Method in interface rice.p2p.commonapi.IdFactory
Builds a protocol-specific Id given the source data.
buildId(byte[]) - Method in class rice.pastry.commonapi.PastryIdFactory
Builds a protocol-specific Id given the source data.
buildId(int[]) - Method in interface rice.p2p.commonapi.IdFactory
Builds a protocol-specific Id given the source data.
buildId(int[]) - Method in class rice.pastry.commonapi.PastryIdFactory
Builds a protocol-specific Id given the source data.
buildId(String) - Method in interface rice.p2p.commonapi.IdFactory
Builds a protocol-specific Id by using the hash of the given string as source data.
buildId(String) - Method in class rice.pastry.commonapi.PastryIdFactory
Builds a protocol-specific Id by using the hash of the given string as source data.
buildIdDistance(byte[]) - Method in interface rice.p2p.commonapi.IdFactory
Builds a protocol-specific Id.Distance given the source data.
buildIdDistance(byte[]) - Method in class rice.pastry.commonapi.PastryIdFactory
Builds a protocol-specific Id.Distance given the source data.
buildIdRange(Id, Id) - Method in interface rice.p2p.commonapi.IdFactory
Creates an IdRange given the CW and CCW ids.
buildIdRange(Id, Id) - Method in class rice.pastry.commonapi.PastryIdFactory
Creates an IdRange given the CW and CCW ids.
buildIdSet() - Method in interface rice.p2p.commonapi.IdFactory
Creates an empty IdSet.
buildIdSet() - Method in class rice.pastry.commonapi.PastryIdFactory
Creates an empty IdSet.

C

Cache - interface rice.persistence.Cache.
This interface is the abstraction of something which provides a caching service.
CACHE_SIZE - Static variable in class rice.persistence.testing.LRUCacheTest
 
cache(Id, Serializable, Continuation) - Method in interface rice.persistence.Cache
Caches an object in this storage.
cache(Id, Serializable, Continuation) - Method in class rice.persistence.LRUCache
Caches an object in this storage.
cache(Id, Serializable, Continuation) - Method in class rice.persistence.StorageManager
Caches an object in this storage.
CacheMessage - class rice.p2p.past.messaging.CacheMessage.
 
CacheMessage(int, PastContent, NodeHandle, Id) - Constructor for class rice.p2p.past.messaging.CacheMessage
Constructor which takes a unique integer Id and the local id
canRandom() - Method in class rice.pastry.routing.SendOptions
Returns whether randomizations on the route are allowed.
Catalog - interface rice.persistence.Catalog.
This interface is the abstraction of something which holds objects which are available for lookup.
ccwHalf() - Method in class rice.pastry.IdRange
get counterclockwise half of the range
ccwSize() - Method in class rice.pastry.leafset.LeafSet
Gets the current counterclockwise size.
channel - Variable in class rice.p2p.splitstream.Stripe
This stripe's channel
Channel - class rice.p2p.splitstream.Channel.
The channel controls all the meta data associated with a group of stripes.
Channel(ChannelId, Scribe, IdFactory, Id) - Constructor for class rice.p2p.splitstream.Channel
Constructor to create a new channel from scratch
channelId - Variable in class rice.p2p.splitstream.Channel
ChannelId for this channel
ChannelId - class rice.p2p.splitstream.ChannelId.
This class wraps the nodeId object so we can use type checking and allow more readable and understandable code.
ChannelId(Id) - Constructor for class rice.p2p.splitstream.ChannelId
Constructor that takes in an Id and makes a ChannelId
ChannelId(String) - Constructor for class rice.p2p.splitstream.ChannelId
Constructor that takes in a String and makes a ChannelId
channels - Variable in class rice.p2p.splitstream.SplitStreamImpl
Hashtable of all the channels currently created on this node implicitly or explicitly.
checkAnycastDFS(NodeId) - Method in class rice.scribe.testing.DirectScribeMaintenanceTest
Checks the DFS implemented by MessageAnycast class.
checkBit(int) - Method in class rice.pastry.Id
Checks if the ith bit is flipped.
checkFreq - Static variable in class rice.rm.testing.DistRMRegrTestApp
 
checkInsert(Id, PastContent) - Method in class rice.p2p.past.ContentHashPastContent
Checks if a insert operation should be allowed.
checkInsert(Id, PastContent) - Method in interface rice.p2p.past.PastContent
Checks if a insert operation should be allowed.
checkInsert(Id, PastContent) - Method in class rice.p2p.past.testing.PastRegrTest.TestPastContent
 
checkInsert(Id, PastContent) - Method in class rice.p2p.past.testing.PastRegrTest.NonOverwritingTestPastContent
 
checkLeafSet(LeafSet, NodeHandle, boolean) - Method in class rice.pastry.standard.StandardLeafSetProtocol
Checks a received leafset advertisement for missing nodes
checkNewJoin(NodeId) - Method in class rice.scribe.testing.DirectScribeMaintenanceTest
A test for checking if data was correctly propogated along subscribe messages if new join method was used, which takes data as a parameter.
checkParentPointerForAllTopics(int) - Method in class rice.scribe.testing.DirectScribeMaintenanceTest
Check if parent pointer is set for all topics on the specified node.
checkPassed() - Method in class rice.rm.testing.RMRegrTestApp
 
checkRemoveChild(NodeId) - Method in class rice.scribe.testing.DirectScribeMaintenanceTest
Tests the removeChild interface method.
checkRoutingTable() - Method in class rice.pastry.testing.SinglePingTest
 
checkStart - Static variable in class rice.rm.testing.DistRMRegrTestApp
 
checkTree(int, int) - Method in class rice.p2p.splitstream.testing.SplitStreamRegrTest
 
childAdded(Topic, NodeHandle) - Method in interface rice.p2p.scribe.ScribeClient
Informs this client that a child was added to a topic in which it was interested in.
childAdded(Topic, NodeHandle) - Method in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribeClient
DESCRIBE THE METHOD
childAdded(Topic, NodeHandle) - Method in class rice.p2p.splitstream.Stripe
Informs this client that a child was added to a topic in which it was interested in.
childObserver(NodeHandle, NodeId, boolean, ScribeMessage, Serializable) - Method in class rice.scribe.Scribe
Whenever the children table for a topic is changed, ( a child is added or removed), this method is invoked to do some handling.
childParentViewConsistencyTest(int) - Method in class rice.scribe.testing.DirectScribeMaintenanceTest
Here we are trying to check that the parent-child relationship is consistent from the view of the CHILD as well as the PARENT, on given node.
childRemoved(Topic, NodeHandle) - Method in interface rice.p2p.scribe.ScribeClient
Informs this client that a child was removed from a topic in which it was interested in.
childRemoved(Topic, NodeHandle) - Method in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribeClient
DESCRIBE THE METHOD
childRemoved(Topic, NodeHandle) - Method in class rice.p2p.splitstream.Stripe
Informs this client that a child was removed from a topic in which it was interested in.
children - Variable in class rice.p2p.scribe.ScribeImpl.TopicManager
DESCRIBE THE FIELD
clearAlreadySentHBNodes() - Method in class rice.scribe.Scribe
The set is cleared so that the set contains only those nodes to which Publish message was sent in last HeartBeat period.
clearChanged() - Method in class rice.pastry.dist.DistNodeHandle
 
clearRefreshedKeys() - Method in class rice.rm.testing.RMRegrTestApp
 
clients - Variable in class rice.p2p.scribe.ScribeImpl.TopicManager
DESCRIBE THE FIELD
clients - Variable in class rice.p2p.splitstream.Stripe
The list of SplitStreamClients interested in data from this client
clockwise(Id) - Method in interface rice.p2p.commonapi.Id
Checks to see if the Id nid is clockwise or counterclockwise from this, on the ring.
clockwise(Id) - Method in class rice.pastry.Id
Checks to see if the Id nid is clockwise or counterclockwise from this, on the ring.
clockwise(Id) - Method in class rice.pastry.Id
Checks to see if the Id nid is clockwise or counterclockwise from this, on the ring.
closeSocket(WireNodeHandle) - Method in class rice.pastry.wire.SocketManager
Method which is designed to be called by node handles which have been disconnected by the remote node (i.e.
closestNode() - Method in class rice.pastry.routing.RouteSet
Return the closest live node in the set.
ClosestRegrTest - class rice.pastry.testing.ClosestRegrTest.
ClosestRegrTest A test suite for the getClosest algorithm
coalesce(DistNodeHandle) - Method in class rice.pastry.dist.DistNodeHandlePool
The method verifies a DistNodeHandle.
coalesce(DistNodeHandle) - Method in class rice.pastry.wire.WireNodeHandlePool
The method verifies a WireNodeHandle.
commandTable - Variable in class rice.past.PASTServiceImpl
Deprecated. The table used to store commands waiting for a response.
CommonAPIAppl - class rice.pastry.client.CommonAPIAppl.
CommonAPIAppl is an abstract class that all new applications should extend.
CommonAPIAppl(PastryNode) - Constructor for class rice.pastry.client.CommonAPIAppl
Constructor.
CommonAPIAppl(PastryNode, String) - Constructor for class rice.pastry.client.CommonAPIAppl
Constructor.
CommonAPITest - class rice.p2p.commonapi.testing.CommonAPITest.
Provides regression testing setup for applications written on top of the commonapi.
CommonAPITest() - Constructor for class rice.p2p.commonapi.testing.CommonAPITest
Constructor, which takes no arguments and sets up the factories in preparation for node creation.
compareTo(Object) - Method in class rice.pastry.Id
Comparison operator for Ids.
compareTo(Object) - Method in class rice.pastry.Id.Distance
Comparison operator.
compareTo(Object) - Method in class rice.pastry.multiring.RingId
Comparison operator for ringIds.
compareTo(Object) - Method in class rice.pastry.testing.LeafSetTest.TestNodeHandle
 
complement() - Method in class rice.pastry.IdRange
get the complement of this range on the ring
connect(SelectionKey) - Method in class rice.pastry.wire.DatagramManager
Specified by the SelectionKeyHandler - should NEVER be called (since datagrams are never connected).
connect(SelectionKey) - Method in interface rice.pastry.wire.SelectionKeyHandler
Method which is called when the key becomes connectable.
connect(SelectionKey) - Method in class rice.pastry.wire.SocketManager
Specified by the SelectionKeyHandler interface - should NEVER be called!
connect(SelectionKey) - Method in class rice.pastry.wire.WireNodeHandle
Called by the socket manager whnever this node handle needs to complete it's connection to it's remote node.
connectToRemoteNode(LinkedList) - Method in class rice.pastry.wire.WireNodeHandle
Method which initiates a connection to a remote node.
contains(Id) - Method in class rice.pastry.IdRange
test if a given key lies within this range
containsId(Id) - Method in interface rice.p2p.commonapi.IdRange
test if a given key lies within this range
containsId(Id) - Method in class rice.pastry.IdRange
test if a given key lies within this range
content - Variable in class rice.p2p.past.messaging.CacheMessage
 
content - Variable in class rice.p2p.scribe.messaging.AnycastMessage
the content of this message
content - Variable in class rice.p2p.scribe.messaging.PublishMessage
 
content - Variable in class rice.p2p.scribe.messaging.PublishRequestMessage
 
ContentHashPastContent - class rice.p2p.past.ContentHashPastContent.
 
ContentHashPastContent() - Constructor for class rice.p2p.past.ContentHashPastContent
 
ContentHashPastContentHandle - class rice.p2p.past.ContentHashPastContentHandle.
 
ContentHashPastContentHandle(NodeHandle, Id) - Constructor for class rice.p2p.past.ContentHashPastContentHandle
Constructor
Continuation - interface rice.Continuation.
Asynchronously receives the result to a given method call, using the command pattern.
Continuation.ExternalContinuation - class rice.Continuation.ExternalContinuation.
This class provides a continuation which is designed to be used from an external thread.
Continuation.ExternalContinuation() - Constructor for class rice.Continuation.ExternalContinuation
 
Continuation.ListenerContinuation - class rice.Continuation.ListenerContinuation.
This class is a Continuation provided for simplicity which listens for any errors and ignores any success values.
Continuation.ListenerContinuation(String) - Constructor for class rice.Continuation.ListenerContinuation
Constructor which takes in a name
Continuation.StandardContinuation - class rice.Continuation.StandardContinuation.
This class is a Continuation provided for simplicity which passes any errors up to the parent Continuation which it is constructed with.
Continuation.StandardContinuation(Continuation) - Constructor for class rice.Continuation.StandardContinuation
Constructor which takes in the parent continuation for this continuation.
ContinuationMessage - class rice.p2p.past.messaging.ContinuationMessage.
 
ContinuationMessage(int, NodeHandle, Id) - Constructor for class rice.p2p.past.messaging.ContinuationMessage
Constructor which takes a unique integer Id, as well as the data to be stored
copy() - Method in class rice.pastry.Id
Copy the Id into a freshly generated array.
copy() - Method in class rice.pastry.Id.Distance
Copy the distance into a freshly generated array.
copy() - Method in class rice.pastry.multiring.RingId
Copy the ringId into a freshly generated array.
Correction - Static variable in class rice.pastry.leafset.BroadcastLeafSet
 
countObservers() - Method in class rice.pastry.dist.DistNodeHandle
 
create(NodeId) - Method in class rice.scribe.testing.BasicScribeRegrTestApp
direct call to scribe for creating a topic from the current node.
create(NodeId) - Method in class rice.scribe.testing.DirectScribeMaintenanceTestApp
direct call to scribe for creating a topic from the current node.
create(NodeId) - Method in class rice.scribe.testing.DistScribeRegrTestApp
direct call to scribe for creating a topic from the current node.
create(NodeId, Credentials) - Method in interface rice.scribe.IScribe
Creates a group/topic if the credentials are valid.
create(NodeId, Credentials) - Method in class rice.scribe.Scribe
Creates a group/topic if the credentials are valid.
createApps() - Method in class rice.pastry.multiring.testing.MultiRingPastryRegrTest
 
createChannel(ChannelId) - Method in interface rice.p2p.splitstream.SplitStream
A SplitStream application calls this method when it wishes to distribute content, creating a new channel object.
createChannel(ChannelId) - Method in class rice.p2p.splitstream.SplitStreamImpl
This method is used by a peer who wishes to distribute the content using SplitStream.
CREATED - Static variable in class rice.scribe.Topic
The two states in which Topic can be.
createEmptyIdRange() - Method in class rice.pastry.testing.IdRangeUnit
 
createFullIdRange() - Method in class rice.pastry.testing.IdRangeUnit
 
createIdRangeEndingIn(Id) - Method in class rice.pastry.testing.IdRangeUnit
 
createIdRangeStartingWith(Id) - Method in class rice.pastry.testing.IdRangeUnit
 
createIdWithPrefix(byte) - Method in class rice.pastry.testing.IdRangeUnit
 
createNode(int) - Method in class rice.p2p.commonapi.testing.CommonAPITest
Method which creates a single node, given it's node number
createNodeId() - Method in class rice.pastry.testing.NodeIdUnit
 
createNodes() - Method in class rice.past.testing.DistPASTRegrTest
Deprecated. Creates the nodes used for testing.
createPastryNodes() - Method in class rice.pastry.multiring.testing.MultiRingPastryRegrTest
 
createRandomIdRange() - Method in class rice.pastry.testing.IdRangeUnit
 
credentials - Variable in class rice.pastry.commonapi.PastryEndpoint
 
Credentials - interface rice.pastry.security.Credentials.
This is the interface for a Pastry Credentials object.
cwHalf() - Method in class rice.pastry.IdRange
get clockwise half of the range
cwSize() - Method in class rice.pastry.leafset.LeafSet
Gets the current clockwise size.

D

data - Variable in class rice.p2p.splitstream.SplitStreamContent
The internal data - just the bytes
DATAGRAM_RECEIVE_BUFFER_SIZE - Static variable in class rice.pastry.wire.DatagramManager
 
DATAGRAM_SEND_BUFFER_SIZE - Static variable in class rice.pastry.wire.DatagramManager
 
DatagramManager - class rice.pastry.wire.DatagramManager.
This class is an implementation of a UDP-based Pastry protocol.
DatagramManager(WirePastryNode, SelectorManager, int) - Constructor for class rice.pastry.wire.DatagramManager
Constructor.
DatagramMessage - class rice.pastry.wire.messaging.datagram.DatagramMessage.
Class which wraps all messages to be sent through the UDP-based pastry protocol.
DatagramMessage(NodeId, NodeId, int) - Constructor for class rice.pastry.wire.messaging.datagram.DatagramMessage
Builds a DatagramMessage given a packet number
DatagramTransmissionManager - class rice.pastry.wire.DatagramTransmissionManager.
Class which controls which object should be transmitted in the UPD version of the pastry protocol.
DatagramTransmissionManager(WirePastryNode, SelectionKey) - Constructor for class rice.pastry.wire.DatagramTransmissionManager
Builds a transmission manager for a given pastry node using a given key.
DatagramTransportMessage - class rice.pastry.wire.messaging.datagram.DatagramTransportMessage.
Message which is a "transport" message in the datagram protocol.
DatagramTransportMessage(NodeId, NodeId, int, Object) - Constructor for class rice.pastry.wire.messaging.datagram.DatagramTransportMessage
Builds a DatagramMessage given an object to wrap and a packet number
DEBUG - Static variable in class rice.past.PASTServiceImpl
Deprecated. Whether to print debugging statements.
debug(String) - Method in class rice.past.messaging.PASTMessage
Deprecated. Print a debug message if the PASTServiceImpl.DEBUG flag is enabled.
debug(String) - Method in class rice.past.PASTServiceImpl
Deprecated. Prints a debugging message to System.out if the DEBUG flag is turned on.
debug(String) - Method in class rice.pastry.dist.DistNodeHandle
Prints out nicely formatted debug messages.
DECLARED_DEAD - Static variable in class rice.p2p.commonapi.NodeHandle
 
DECLARED_LIVE - Static variable in class rice.p2p.commonapi.NodeHandle
 
DEFAULT_DISTANCE - Static variable in class rice.pastry.dist.DistNodeHandle
 
DEFAULT_MAXIMUM_CHILDREN - Static variable in class rice.p2p.splitstream.SplitStreamScribePolicy
The default maximum number of children per channel
DEFAULT_REGISTRY_PORT - Static variable in class rice.pastry.rmi.RMIPastryNodeFactory
 
defaultAllowMultipleHops - Static variable in class rice.pastry.routing.SendOptions
 
defaultNoShortCuts - Static variable in class rice.pastry.routing.SendOptions
 
defaultRandom - Static variable in class rice.pastry.routing.SendOptions
 
defaultShortestPath - Static variable in class rice.pastry.routing.SendOptions
 
delete(Id, Continuation) - Method in interface rice.past.PASTService
Deprecated. Reclaims the storage used by the object with the given ID.
delete(Id, Continuation) - Method in class rice.past.PASTServiceImpl
Deprecated. Reclaims the storage used by the object with the given ID.
deleteLeafSetObserver(Observer) - Method in class rice.pastry.multiring.MultiRingPastryNode
 
deleteLeafSetObserver(Observer) - Method in class rice.pastry.PastryNode
Delete a leaf set observer from the Pastry node.
deleteObserver(Observer) - Method in class rice.pastry.dist.DistNodeHandle
 
deleteObserver(Observer) - Method in class rice.pastry.leafset.LeafSet
Delete observer method.
deleteObservers() - Method in class rice.pastry.dist.DistNodeHandle
 
deleteRouteSetObserver(Observer) - Method in class rice.pastry.multiring.MultiRingPastryNode
 
deleteRouteSetObserver(Observer) - Method in class rice.pastry.PastryNode
Delete a route set observer from the Pastry node.
deliver(Id, Message) - Method in interface rice.p2p.commonapi.Application
This method is called on the application at the destination node for the given id.
deliver(Id, Message) - Method in class rice.p2p.past.PastImpl
This method is called on the application at the destination node for the given id.
deliver(Id, Message) - Method in class rice.p2p.scribe.ScribeImpl
This method is called on the application at the destination node for the given id.
deliver(Id, Message) - Method in class rice.past.PASTServiceImpl
Deprecated. Called by pastry when a message arrives for this application.
deliver(Id, Message) - Method in class rice.pastry.client.CommonAPIAppl
Called by pastry when a message arrives for this application.
deliver(Id, Message) - Method in class rice.pastry.testing.RegrTestApp
 
deliver(Id, Message) - Method in class rice.rm.RMImpl
Called by pastry when a message arrives for this application.
deliver(Id, Message) - Method in class rice.rm.testing.RMRegrTestApp
 
deliver(Stripe, byte[]) - Method in interface rice.p2p.splitstream.SplitStreamClient
Is called when data is received on a stripe which this client has registered interest
deliver(Topic, ScribeContent) - Method in interface rice.p2p.scribe.ScribeClient
This method is invoked when a message is delivered for a topic this client is interested in.
deliver(Topic, ScribeContent) - Method in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribeClient
DESCRIBE THE METHOD
deliver(Topic, ScribeContent) - Method in class rice.p2p.splitstream.Stripe
This method is invoked when a message is delivered for a topic this client is interested in.
deliverMessage(Message, PastryNode) - Method in class rice.pastry.direct.EuclideanNetwork
DESCRIBE THE METHOD
deliverMessage(Message, PastryNode) - Method in interface rice.pastry.direct.NetworkSimulator
Deliver message.
deliverMessage(Message, PastryNode) - Method in class rice.pastry.direct.SphereNetwork
DESCRIBE THE METHOD
DeserializationException - exception rice.pastry.wire.exception.DeserializationException.
Class which represents an exception occuring during the deserialization of a Pastry message.
DeserializationException(String) - Constructor for class rice.pastry.wire.exception.DeserializationException
Constructs an DeserializationException with a given message
deserialize(ByteBuffer) - Static method in class rice.pastry.wire.DatagramManager
Method which takes in a ByteBuffer read from a datagram, and deserializes the contained object.
dest - Variable in class rice.p2p.past.messaging.PastMessage
 
destination - Variable in class rice.pastry.wire.messaging.datagram.DatagramMessage
 
diff(IdRange) - Method in class rice.pastry.IdRange
compute the difference between two ranges (exclusive or of keys in the two ranges) two ranges may differ in two ranges on the circle; this method produces one such range of difference if one exists the other range of difference can be computed by invoking o.diff(this)
diffSubtractTest(IdRange, IdRange) - Method in class rice.pastry.testing.IdRangeUnit
 
directAnycast(AnycastMessage, NodeHandle, NodeHandle[]) - Method in interface rice.p2p.scribe.ScribePolicy
This method is called when an anycast is received which is not satisfied at the local node.
directAnycast(AnycastMessage, NodeHandle, NodeHandle[]) - Method in class rice.p2p.scribe.ScribePolicy.DefaultScribePolicy
Simply adds the parent and children in order, which implements a depth-first-search.
directAnycast(AnycastMessage, NodeHandle, NodeHandle[]) - Method in class rice.p2p.splitstream.SplitStreamScribePolicy
This method adds the parent and child in such a way that the nodes who have this stripe as their primary strpe are examined first.
DirectNodeHandle - class rice.pastry.direct.DirectNodeHandle.
the node handle used with the direct network
DirectNodeHandle(PastryNode, PastryNode, NetworkSimulator) - Constructor for class rice.pastry.direct.DirectNodeHandle
Constructor for DirectNodeHandle.
DirectPastryNode - class rice.pastry.direct.DirectPastryNode.
Direct pastry node.
DirectPastryNode(NodeId, NetworkSimulator) - Constructor for class rice.pastry.direct.DirectPastryNode
 
DirectPastryNodeFactory - class rice.pastry.direct.DirectPastryNodeFactory.
Pastry node factory for direct connections between nodes (local instances).
DirectPastryNodeFactory(NodeIdFactory, NetworkSimulator) - Constructor for class rice.pastry.direct.DirectPastryNodeFactory
 
DirectPastryPingTest - class rice.pastry.testing.DirectPastryPingTest.
DirectPastryPingTest A performance test suite for pastry.
DirectPastryPingTest() - Constructor for class rice.pastry.testing.DirectPastryPingTest
 
DirectPastryRegrTest - class rice.pastry.testing.DirectPastryRegrTest.
PastryRegrTest a regression test suite for pastry.
DirectRMRegrTest - class rice.rm.testing.DirectRMRegrTest.
 
DirectRMRegrTest() - Constructor for class rice.rm.testing.DirectRMRegrTest
 
DirectRMRegrTestApp - class rice.rm.testing.DirectRMRegrTestApp.
 
DirectRMRegrTestApp(PastryNode, Credentials, String) - Constructor for class rice.rm.testing.DirectRMRegrTestApp
 
DirectScribeMaintenanceTest - class rice.scribe.testing.DirectScribeMaintenanceTest.
 
DirectScribeMaintenanceTest.TestAnycastMessage - class rice.scribe.testing.DirectScribeMaintenanceTest.TestAnycastMessage.
A dummy test message used for checking if anycast is doing DFS correctly.
DirectScribeMaintenanceTest.TestAnycastMessage(Address, NodeHandle, NodeId, Credentials) - Constructor for class rice.scribe.testing.DirectScribeMaintenanceTest.TestAnycastMessage
 
DirectScribeMaintenanceTest() - Constructor for class rice.scribe.testing.DirectScribeMaintenanceTest
 
DirectScribeMaintenanceTestApp - class rice.scribe.testing.DirectScribeMaintenanceTestApp.
 
DirectScribeMaintenanceTestApp(PastryNode, Scribe, Credentials) - Constructor for class rice.scribe.testing.DirectScribeMaintenanceTestApp
Constructor
DirectScribeRegrTest - class rice.scribe.testing.DirectScribeRegrTest.
 
DirectScribeRegrTest() - Constructor for class rice.scribe.testing.DirectScribeRegrTest
 
DirectSecurityManager - class rice.pastry.direct.DirectSecurityManager.
Security manager for direct connections between nodes.
DirectSecurityManager(NetworkSimulator) - Constructor for class rice.pastry.direct.DirectSecurityManager
Constructor.
disconnect() - Method in class rice.pastry.wire.WireNodeHandle
Method that is designed to be called by the SocketManager when it wishes for this node handle to disconnect.
DisconnectMessage - class rice.pastry.wire.messaging.socket.DisconnectMessage.
Class which represents a disconnect notice in the Socket-based pastry wire protocol.
DisconnectMessage() - Constructor for class rice.pastry.wire.messaging.socket.DisconnectMessage
Constructor
dispatchMessage(Message) - Method in class rice.pastry.messaging.MessageDispatch
Dispatches a message to the appropriate receiver.
dispatchMessage(Message) - Method in class rice.pastry.multiring.MultiRingMessageDispatch
 
distance(Id) - Method in class rice.pastry.Id
Returns the shorter numerical distance on the ring between a pair of Ids.
distanceFromId(Id) - Method in interface rice.p2p.commonapi.Id
Returns the shorter numerical distance on the ring between a pair of Ids.
distanceFromId(Id) - Method in class rice.pastry.Id
Returns the shorter numerical distance on the ring between a pair of Ids.
distanceTest() - Method in class rice.pastry.testing.NodeIdUnit
 
distClients - Variable in class rice.rm.testing.DistRMRegrTest
 
distClients - Variable in class rice.scribe.testing.DistScribeRegrTest
 
DistHelloWorld - class rice.pastry.testing.DistHelloWorld.
A hello world example for pastry.
DistHelloWorld() - Constructor for class rice.pastry.testing.DistHelloWorld
Constructor
distinctChildrenTableConsistencyTest(int) - Method in class rice.scribe.testing.DirectScribeMaintenanceTest
Check the consistency between distinctChildrenTable maintained by scribe on a node and the children maintained by each Topic on that node.
distinctChildrenTableConsistencyTest(Scribe) - Method in class rice.scribe.testing.DistScribeRegrTestMessage
Check the consistency between distinctChildrenTable maintained by scribe on a node and the children maintained by each Topic on that node.
distinctParentTableConsistencyTest(int) - Method in class rice.scribe.testing.DirectScribeMaintenanceTest
Check the consistency between distinctParentTable maintained by scribe on a node and the parent maintained by each Topic on that node.
distinctParentTableConsistencyTest(Scribe) - Method in class rice.scribe.testing.DistScribeRegrTestMessage
Check the consistency between distinctParentTable maintained by scribe on a node and the parent maintained by each Topic on that node.
DistNodeHandle - class rice.pastry.dist.DistNodeHandle.
Abstract class for handles to "real" remote nodes.
DistNodeHandle(NodeId, InetSocketAddress) - Constructor for class rice.pastry.dist.DistNodeHandle
Constructor
DistNodeHandlePool - class rice.pastry.dist.DistNodeHandlePool.
The DistNodeHandlePool controls all of the node handles in use by the DistPastryNode.
DistNodeHandlePool() - Constructor for class rice.pastry.dist.DistNodeHandlePool
Constructor.
DistPASTRegrTest - class rice.past.testing.DistPASTRegrTest.
Deprecated. This version of PAST has been deprecated - please use the version located in the rice.p2p.past package.
DistPASTRegrTest.TestCommand - class rice.past.testing.DistPASTRegrTest.TestCommand.
Deprecated. Common superclass for test commands.
DistPASTRegrTest.TestCommand() - Constructor for class rice.past.testing.DistPASTRegrTest.TestCommand
Deprecated.  
DistPASTRegrTest.TestFailedException - exception rice.past.testing.DistPASTRegrTest.TestFailedException.
Deprecated. Exception indicating that a regression test failed.
DistPASTRegrTest.TestFailedException(String) - Constructor for class rice.past.testing.DistPASTRegrTest.TestFailedException
Deprecated.  
DistPASTRegrTest.TestPASTFunctions - class rice.past.testing.DistPASTRegrTest.TestPASTFunctions.
Deprecated. Commands for running the PAST functions test.
DistPASTRegrTest.TestPASTFunctions() - Constructor for class rice.past.testing.DistPASTRegrTest.TestPASTFunctions
Deprecated. Sets up this test.
DistPASTRegrTest() - Constructor for class rice.past.testing.DistPASTRegrTest
Deprecated.  
DistPastryNode - class rice.pastry.dist.DistPastryNode.
Class which represents the abstraction of a "real" pastry node.
DistPastryNode(NodeId) - Constructor for class rice.pastry.dist.DistPastryNode
Constructor, with NodeId.
DistPastryNodeFactory - class rice.pastry.dist.DistPastryNodeFactory.
An abstraction of the nodeId factory for distributed nodes.
DistPastryNodeFactory() - Constructor for class rice.pastry.dist.DistPastryNodeFactory
Constructor.
DistPastryRegrTest - class rice.pastry.testing.DistPastryRegrTest.
a regression test suite for pastry with "distributed" nodes.
DistPastryRegrTest() - Constructor for class rice.pastry.testing.DistPastryRegrTest
 
DistRMRegrTest - class rice.rm.testing.DistRMRegrTest.
 
DistRMRegrTest() - Constructor for class rice.rm.testing.DistRMRegrTest
 
DistRMRegrTestApp - class rice.rm.testing.DistRMRegrTestApp.
 
DistRMRegrTestApp(PastryNode, Credentials, boolean, String) - Constructor for class rice.rm.testing.DistRMRegrTestApp
 
DistRMRegrTestMessage - class rice.rm.testing.DistRMRegrTestMessage.
DistRMRegrTestMessage is used by the dist regression test application on the RM layer to do system invariant checking.
DistRMRegrTestMessage(Address, Credentials) - Constructor for class rice.rm.testing.DistRMRegrTestMessage
Constructor
DistRMRegrTestReplicateMessage - class rice.rm.testing.DistRMRegrTestReplicateMessage.
DistRMRegrTestReplicateMessage is used by the dist regression test application on the RM layer to do the initial replication of a few objects into the system and the periodic refreshing.
DistRMRegrTestReplicateMessage(Address, Credentials) - Constructor for class rice.rm.testing.DistRMRegrTestReplicateMessage
Constructor
DistScribeRegrTest - class rice.scribe.testing.DistScribeRegrTest.
 
DistScribeRegrTest() - Constructor for class rice.scribe.testing.DistScribeRegrTest
 
DistScribeRegrTestApp - class rice.scribe.testing.DistScribeRegrTestApp.
 
DistScribeRegrTestApp(PastryNode, Scribe, Credentials, DistScribeRegrTest) - Constructor for class rice.scribe.testing.DistScribeRegrTestApp
 
DistScribeRegrTestMessage - class rice.scribe.testing.DistScribeRegrTestMessage.
DistScribeRegrTestMessage is used by the dist regression test application on the Scribe layer to do publishing on some topics, etc.
DistScribeRegrTestMessage(Address, Credentials) - Constructor for class rice.scribe.testing.DistScribeRegrTestMessage
Constructor
DistTopicLog - class rice.scribe.testing.DistTopicLog.
 
DistTopicLog() - Constructor for class rice.scribe.testing.DistTopicLog
 
domainPrefixTest() - Method in class rice.pastry.testing.NodeIdUnit
 
doneNode(NodeHandle) - Method in class rice.pastry.direct.DirectPastryNode
 
doneNode(NodeHandle) - Method in class rice.pastry.dist.DistPastryNode
Called after the node is initialized.
doneNode(NodeHandle) - Method in class rice.pastry.rmi.RMIPastryNode
Called after the node is initialized.
doneNode(NodeHandle) - Method in class rice.pastry.wire.WirePastryNode
Called after the node is initialized.
doneTest() - Method in class rice.pastry.direct.TestRecord
 
doneTest() - Method in class rice.pastry.testing.PingTestRecord
 
doPing() - Method in class rice.pastry.rmi.RMINodeHandle
Do the (blocking) ping
doSend(Message) - Method in class rice.pastry.rmi.RMINodeHandle
Do the actual (blocking) RMI call to the remote node
doTesting() - Method in class rice.rm.testing.DirectRMRegrTest
The system of nodes is set up and the testing is performed while stepwise failing the desired number of nodes.
doTesting() - Method in class rice.scribe.testing.DirectScribeMaintenanceTest
The system of nodes is set up and the testing is performed while stepwise failing the desired number of nodes.
doTheTesting(int, int) - Method in class rice.scribe.testing.BasicScribeRegrTest
 
DropMessage - class rice.p2p.scribe.messaging.DropMessage.
 
DropMessage(NodeHandle, Topic) - Constructor for class rice.p2p.scribe.messaging.DropMessage
Constructor which takes a unique integer Id

E

endpoint - Variable in class rice.p2p.past.PastImpl
 
endpoint - Variable in class rice.p2p.scribe.ScribeImpl
this application's endpoint
Endpoint - interface rice.p2p.commonapi.Endpoint.
 
enqueue(Object) - Method in class rice.pastry.wire.SocketChannelWriter
Adds an object to this SocketChannelWriter's queue of pending objects to write.
enqueueSendMsg(Message, RMINodeHandle) - Method in class rice.pastry.rmi.RMIPastryNode
Enqueues a message for asynchronous transmission
enrouteMessage(Message, Id, NodeId, SendOptions) - Method in class rice.pastry.client.PastryAppl
Called by pastry when a message is enroute and is passing through this node.
enrouteMessage(Message, Id, NodeId, SendOptions) - Method in class rice.pastry.commonapi.PastryEndpoint
 
enrouteMessage(Message, Id, NodeId, SendOptions) - Method in class rice.pastry.testing.HelloWorldApp
Invoked on intermediate nodes in routing path.
enrouteMessage(Message, Id, NodeId, SendOptions) - Method in class rice.pastry.testing.Ping
 
enrouteMessage(Message, Id, NodeId, SendOptions) - Method in class rice.pastry.testing.PingClient
 
enrouteMessage(Message, Id, NodeId, SendOptions) - Method in class rice.scribe.Scribe
Called by pastry when a message is enroute and is passing through this node.
equalityTest() - Method in class rice.pastry.testing.NodeIdUnit
 
equalityTest(IdRange, IdRange) - Method in class rice.pastry.testing.IdRangeUnit
 
equals(Id) - Method in class rice.pastry.Id
Equivalence relation for Ids.
equals(Object) - Method in class rice.p2p.past.testing.PastRegrTest.TestPastContent
 
equals(Object) - Method in class rice.p2p.past.testing.PastRegrTest.VersionedTestPastContent
 
equals(Object) - Method in class rice.p2p.past.testing.PastRegrTest.NonMutableTestPastContent
 
equals(Object) - Method in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribeContent
DESCRIBE THE METHOD
equals(Object) - Method in class rice.p2p.scribe.Topic
Returns whether this is equal to o or not
equals(Object) - Method in class rice.p2p.splitstream.ChannelId
 
equals(Object) - Method in class rice.p2p.splitstream.StripeId
 
equals(Object) - Method in interface rice.past.messaging.PASTMessageID
Deprecated. Indicates whether some other object is equal to this one.
equals(Object) - Method in class rice.past.messaging.PASTMessageIDImpl
Deprecated. Indicates whether some other object is equal to this one.
equals(Object) - Method in class rice.pastry.direct.DirectNodeHandle
Equivalence relation for nodehandles.
equals(Object) - Method in class rice.pastry.dist.DistNodeHandle
Equivalence relation for nodehandles.
equals(Object) - Method in class rice.pastry.Id
Equality operator for Ids.
equals(Object) - Method in class rice.pastry.Id.Distance
Equality operator.
equals(Object) - Method in class rice.pastry.IdRange
equality operator
equals(Object) - Method in class rice.pastry.join.JoinAddress
 
equals(Object) - Method in class rice.pastry.leafset.LeafSetProtocolAddress
 
equals(Object) - Method in class rice.pastry.multiring.messaging.MultiRingApplAddress
Determines if another object is equal to this one.
equals(Object) - Method in class rice.pastry.multiring.RingId
Equality operator for ringIds.
equals(Object) - Method in class rice.pastry.multiring.RingNodeId
 
equals(Object) - Method in class rice.pastry.multiring.testing.MultiRingPastryRegrTest.MultiRingTestAppAddress
 
equals(Object) - Method in class rice.pastry.NodeHandle
Equality operator for nodehandles.
equals(Object) - Method in class rice.pastry.routing.RouteProtocolAddress
 
equals(Object) - Method in class rice.pastry.routing.RouterAddress
 
equals(Object) - Method in class rice.pastry.standard.StandardAddress
 
equals(Object) - Method in class rice.pastry.testing.LeafSetTest.TestNodeHandle
 
equals(Object) - Method in class rice.pastry.testing.PingAddress
 
equals(Object) - Method in class rice.rm.RMImpl.KEPenEntry
Equality is based only on the reqRange part, does not care about the numKeys argument.
equals(RingId) - Method in class rice.pastry.multiring.RingId
Equivalence relation for ringIds.
EuclideanNetwork - class rice.pastry.direct.EuclideanNetwork.
Euclidean network topology and idealized node life.
EuclideanNetwork() - Constructor for class rice.pastry.direct.EuclideanNetwork
Constructor.
exception - Variable in class rice.Continuation.ExternalContinuation
 
exception - Variable in class rice.p2p.past.messaging.ContinuationMessage
 
exceptionThrown() - Method in class rice.Continuation.ExternalContinuation
 
existing - Variable in class rice.p2p.past.testing.PastRegrTest.TestPastContent
 
exists() - Method in class rice.past.messaging.MessageExists
Deprecated. Returns whether the file exists.
exists(Id) - Method in interface rice.persistence.Catalog
Returns whether or not an object is present in the location id.
exists(Id) - Method in class rice.persistence.LRUCache
Returns whether or not an object is cached in the location id.
exists(Id) - Method in class rice.persistence.MemoryStorage
Returns whether or not the provided id exists
exists(Id) - Method in class rice.persistence.PersistentStorage
Returns whether or not an object is present in the location id.
exists(Id) - Method in class rice.persistence.StorageManager
Returns whether or not an object is present in the location id.
exists(Id, Continuation) - Method in interface rice.past.PASTService
Deprecated. Determines whether an object is currently stored at the given ID.
exists(Id, Continuation) - Method in class rice.past.PASTServiceImpl
Deprecated. Determines whether an object is currently stored at the given ID.
exists(Id, Continuation) - Method in interface rice.persistence.Catalog
Returns whether or not an object is present in the location id.
exists(Id, Continuation) - Method in class rice.persistence.LRUCache
Returns whether or not an object is cached in the location id.
exists(Id, Continuation) - Method in class rice.persistence.MemoryStorage
Returns whether or not the provided id exists, by returning a Boolean through receiveResult on c
exists(Id, Continuation) - Method in class rice.persistence.PersistentStorage
Returns whether or not an object is present in the location id.
exists(Id, Continuation) - Method in class rice.persistence.StorageManager
Returns whether or not an object is present in the location id.

F

factory - Variable in class rice.p2p.commonapi.testing.CommonAPITest
 
factory - Variable in class rice.p2p.past.PastImpl
 
factory - Variable in class rice.pastry.testing.LeafSetTest
 
factory - Variable in class rice.pastry.testing.PastryRegrTest
 
FACTORY - Static variable in class rice.p2p.commonapi.testing.CommonAPITest
 
failed - Variable in class rice.p2p.splitstream.Stripe
The count of failed subscribe messages
FAILURE - Static variable in class rice.p2p.commonapi.testing.CommonAPITest
 
FAILURE - Static variable in class rice.persistence.testing.Test
 
faultHandler(Scribe) - Method in class rice.scribe.messaging.MessageAnycast
Method to notify that anycast has failed.
faultHandler(Scribe) - Method in class rice.scribe.testing.DirectScribeMaintenanceTest.TestAnycastMessage
 
faultHandler(ScribeMessage, NodeHandle) - Method in class rice.pastry.multiring.MultiRingAppl
 
faultHandler(ScribeMessage, NodeHandle) - Method in interface rice.scribe.IScribeApp
Invoked by Scribe just before the "repair" SUBSCRIBE message is sent when a node suspects its parent is faulty.
faultHandler(ScribeMessage, NodeHandle) - Method in class rice.scribe.testing.BasicScribeRegrTestApp
up-call invoked by scribe when a node detects a failure from its parent.
faultHandler(ScribeMessage, NodeHandle) - Method in class rice.scribe.testing.DirectScribeMaintenanceTestApp
up-call invoked by scribe when a node detects a failure from its parent.
faultHandler(ScribeMessage, NodeHandle) - Method in class rice.scribe.testing.DistScribeRegrTestApp
up-call invoked by scribe when a node detects a failure from its parent.
fetch(IdSet) - Method in class rice.p2p.past.PastImpl
This upcall is invoked to notify the application that is should fetch the cooresponding keys in this set, since the node is now responsible for these keys also.
fetch(IdSet) - Method in class rice.past.PASTServiceImpl
Deprecated. This upcall is invoked to notify the application that is should fetch the cooresponding keys in this set, since the node is now responsible for these keys also
fetch(IdSet) - Method in interface rice.rm.RMClient
This upcall is invoked to notify the application that is should fetch the cooresponding keys in this set, since the node is now responsible for these keys also.
fetch(IdSet) - Method in class rice.rm.testing.RMRegrTestApp
 
fetch(PastContentHandle, Continuation) - Method in interface rice.p2p.past.Past
Retrieves the object associated with a given content handle.
fetch(PastContentHandle, Continuation) - Method in class rice.p2p.past.PastImpl
Retrieves the object associated with a given content handle.
FetchHandleMessage - class rice.p2p.past.messaging.FetchHandleMessage.
 
FetchHandleMessage(int, Id, NodeHandle, Id) - Constructor for class rice.p2p.past.messaging.FetchHandleMessage
Constructor
FetchMessage - class rice.p2p.past.messaging.FetchMessage.
 
FetchMessage(int, PastContentHandle, NodeHandle, Id) - Constructor for class rice.p2p.past.messaging.FetchMessage
Constructor
forward(RouteMessage) - Method in interface rice.p2p.commonapi.Application
This method is invoked on applications when the underlying node is about to forward the given message with the provided target to the specified next hop.
forward(RouteMessage) - Method in class rice.p2p.past.PastImpl
This method is invoked on applications when the underlying node is about to forward the given message with the provided target to the specified next hop.
forward(RouteMessage) - Method in class rice.p2p.scribe.ScribeImpl
This method is invoked on applications when the underlying node is about to forward the given message with the provided target to the specified next hop.
forward(RouteMessage) - Method in class rice.past.PASTServiceImpl
Deprecated. This method is invoked on applications when the underlying node is about to forward the given message with the provided target to the specified next hop.
forward(RouteMessage) - Method in class rice.pastry.client.CommonAPIAppl
Called by pastry when a message is enroute and is passing through this node.
forward(RouteMessage) - Method in class rice.pastry.testing.RegrTestApp
 
forwardHandler(ScribeMessage) - Method in class rice.pastry.multiring.MultiRingAppl
 
forwardHandler(ScribeMessage) - Method in interface rice.scribe.IScribeApp
Called by Scribe before the node forwards a message to its children in the multicast tree.
forwardHandler(ScribeMessage) - Method in class rice.scribe.testing.BasicScribeRegrTestApp
up-call invoked by scribe when a publish message is forwarded through the multicast tree.
forwardHandler(ScribeMessage) - Method in class rice.scribe.testing.DirectScribeMaintenanceTestApp
up-call invoked by scribe when a publish message is forwarded through the multicast tree.
forwardHandler(ScribeMessage) - Method in class rice.scribe.testing.DistScribeRegrTestApp
up-call invoked by scribe when a publish message is forwarded through the multicast tree.
fractionUnsubscribedAllowed - Static variable in class rice.scribe.testing.DistScribeRegrTest
 
freeBandwidth(Channel, NodeHandle, Id) - Method in class rice.p2p.splitstream.SplitStreamScribePolicy
This method attempts to free bandwidth from our primary stripe.
freeBandwidthUltimate(Id) - Method in class rice.p2p.splitstream.SplitStreamScribePolicy
This method makes an attempt to free up bandwidth from non-primary, non-root stripes (for which local node is not root).
from() - Method in class rice.pastry.leafset.BroadcastLeafSet
Returns the node id of the node that broadcast its leaf set.
from() - Method in class rice.pastry.routing.BroadcastRouteRow
Gets the from node.

G

generateIdRng - Variable in class rice.p2p.scribe.testing.ScribeRegrTest
 
generateIdRng - Variable in class rice.p2p.splitstream.testing.SplitStreamRegrTest
 
generateLeafSet(int, int, boolean) - Method in class rice.pastry.testing.LeafSetTest
Returns a leafset of size size out of a network with the specified number of nodes
generateNode(NodeHandle) - Method in class rice.pastry.testing.PastryRegrTest
 
generateNodeHandle(InetSocketAddress) - Method in class rice.pastry.dist.DistPastryNodeFactory
Method which all subclasses should implement allowing the client to generate a node handle given the address of a node.
generateNodeHandle(InetSocketAddress) - Method in class rice.pastry.rmi.RMIPastryNodeFactory
Specified by the DistPastryNodeFactory class.
generateNodeHandle(InetSocketAddress) - Method in class rice.pastry.wire.WirePastryNodeFactory
Method which contructs a node handle (using the wire protocol) for the node at address NodeHandle.
generateNodeId() - Method in class rice.pastry.multiring.RandomRingNodeIdFactory
generate a nodeId
generateNodeId() - Method in interface rice.pastry.NodeIdFactory
Generates a nodeId.
generateNodeId() - Method in class rice.pastry.standard.IPNodeIdFactory
generate a nodeId multiple invocations result in a deterministic series of randomized NodeIds, seeded by the IP address of the local host.
generateNodeId() - Method in class rice.pastry.standard.RandomNodeIdFactory
generate a nodeId
generateStripeIds(ChannelId, IdFactory) - Static method in class rice.p2p.splitstream.Channel
Creates and returns the Ids associated with the provided channelId
generateTopicId(String) - Method in class rice.rm.testing.DirectRMRegrTest
 
generateTopicId(String) - Method in class rice.rm.testing.DistRMRegrTestApp
 
generateTopicId(String) - Method in interface rice.scribe.IScribe
Generate a unique id for the topic, which will determine its rendezvous point.
generateTopicId(String) - Method in class rice.scribe.Scribe
Generate a unique id for the topic, which will determine its rendezvous point.
generateTopicId(String) - Method in class rice.scribe.testing.BasicScribeRegrTest
 
generateTopicId(String) - Method in class rice.scribe.testing.BasicScribeRegrTestApp
 
generateTopicId(String) - Method in class rice.scribe.testing.DirectScribeMaintenanceTest
 
generateTopicId(String) - Static method in class rice.scribe.testing.DistScribeRegrTest
 
get(int) - Method in class rice.pastry.leafset.LeafSet
Finds the NodeHandle at a given index.
get(int) - Method in class rice.pastry.leafset.SimilarSet
Gets the ith element in the set.
get(int) - Method in class rice.pastry.NodeSet
Gets the ith element in the set.
get(int) - Method in interface rice.pastry.NodeSetI
Gets the ith element in the set.
get(int) - Method in class rice.pastry.routing.RouteSet
Returns the node in the ith position in the set.
get(NodeId) - Method in class rice.pastry.leafset.LeafSet
Finds the NodeHandle associated with the NodeId.
get(NodeId) - Method in class rice.pastry.leafset.SimilarSet
Finds the NodeHandle associated with the NodeId.
get(NodeId) - Method in class rice.pastry.NodeSet
Finds the NodeHandle associated with a NodeId.
get(NodeId) - Method in interface rice.pastry.NodeSetI
Finds the NodeHandle associated with the NodeId.
get(NodeId) - Method in class rice.pastry.routing.RouteSet
Returns the node handle with the matching node id or null if none exists.
get(NodeId) - Method in class rice.pastry.routing.RoutingTable
Gets the node handle associated with a given id.
get(NodeId) - Method in class rice.pastry.wire.WireNodeHandlePool
 
getAck(InetSocketAddress) - Method in class rice.pastry.wire.messaging.datagram.DatagramMessage
Returns the approriate 'ack' message for this datagram transport message.
getAddress() - Method in class rice.pastry.client.PastryAppl
Returns the address of this application.
getAddress() - Method in class rice.pastry.dist.DistNodeHandle
Returns the IP address and port of the remote node.
getAddress() - Method in class rice.pastry.multiring.MultiRingAppl
 
getAddress() - Method in class rice.pastry.standard.StandardJoinProtocol
Get address.
getAddress() - Method in class rice.pastry.standard.StandardLeafSetProtocol
Gets the address.
getAddress() - Method in class rice.pastry.standard.StandardRouter
Gets the address of this component.
getAddress() - Method in class rice.pastry.standard.StandardRouteSetProtocol
Gets the address.
getAddress() - Method in class rice.pastry.testing.HelloWorldApp
Get address.
getAddress() - Method in class rice.pastry.testing.Ping
 
getAddress() - Method in class rice.pastry.testing.PingClient
 
getAddress() - Method in class rice.pastry.testing.RegrTestApp
 
getAddress() - Method in class rice.pastry.wire.messaging.datagram.AcknowledgementMessage
Returns the address of the destination of this ack message.
getAddress() - Method in class rice.pastry.wire.messaging.socket.HelloMessage
Returns the address of the source of this message.
getAddress() - Method in class rice.pastry.wire.messaging.socket.HelloResponseMessage
Returns the address of the source of this message.
getAddress() - Method in class rice.pastry.wire.PendingWrite
Returns the destination address of this write
getAddress() - Method in class rice.scribe.Scribe
Returns the address of this client.
getAddress() - Method in class rice.scribe.testing.DistScribeRegrTestApp
 
getAlreadySentHBNodes() - Method in class rice.scribe.Scribe
Gets the vector of nodes to which an implicit HeartBeat in form of Publish message was sent in last HeartBeat period.
getAlternateId(int, int, int) - Method in class rice.pastry.Id
produces a set of ids (keys) that are evenly distributed around the id ring.
getAnycastMessages() - Method in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribeClient
 
getApps() - Method in class rice.scribe.Topic
Gets all the applications that wish to receive events regarding this Topic.
getAttempt() - Method in class rice.rm.messaging.RMRequestKeysMsg
 
getAveDistance() - Method in class rice.pastry.testing.PingTestRecord
 
getAveHops() - Method in class rice.pastry.testing.PingTestRecord
 
getBestEntry(Id) - Method in class rice.pastry.routing.RoutingTable
Gets the set of handles that match at least one more digit of the key than the local nodeId.
getBootstrap() - Method in class rice.p2p.commonapi.testing.CommonAPITest
Gets a handle to a bootstrap node.
getBootstrap() - Method in class rice.past.testing.DistPASTRegrTest
Deprecated. Gets a handle to a bootstrap node.
getBootstrap() - Method in class rice.pastry.testing.ClosestRegrTest
Get pastryNodes.last() to bootstrap with, or return null.
getBootstrap(boolean) - Method in class rice.pastry.testing.DirectPastryRegrTest
Get pastryNodes.last() to bootstrap with, or return null.
getBootstrap(boolean) - Method in class rice.pastry.testing.DistHelloWorld
Gets a handle to a bootstrap node.
getBootstrap(boolean) - Method in class rice.pastry.testing.DistPastryRegrTest
Gets a handle to a bootstrap node.
getBootstrap(boolean) - Method in class rice.pastry.testing.PastryRegrTest
get a node handle to bootstrap from.
getCache() - Method in class rice.persistence.StorageManager
Returns the cache object used by this StorageManager
getCCW() - Method in class rice.pastry.Id
gets the Id just counterclockwise from this
getCCW() - Method in class rice.pastry.IdRange
get counterclockwise edge of range
getCCWId() - Method in interface rice.p2p.commonapi.IdRange
get counterclockwise edge of range
getCCWId() - Method in class rice.pastry.IdRange
get counterclockwise edge of range
getChannelId() - Method in class rice.p2p.splitstream.Channel
Gets the channelId for this channel
getChannels() - Method in interface rice.p2p.splitstream.SplitStream
Returns all of the channels on this local splitstream
getChannels() - Method in class rice.p2p.splitstream.SplitStreamImpl
Returns all of the channels on this local splitstream
getChildren() - Method in class rice.p2p.scribe.ScribeImpl.TopicManager
Gets the Children attribute of the TopicManager object
getChildren() - Method in class rice.p2p.splitstream.Stripe
Utility method.
getChildren() - Method in class rice.scribe.Topic
This returns the most current view of the children in this topic's multicast subtree rooted at the local node.
getChildren(NodeId) - Method in interface rice.scribe.IScribe
This returns the most current view of the children in this topic's multicast subtree rooted at the local node.
getChildren(NodeId) - Method in class rice.scribe.Scribe
This returns the most current view of the children in this topic's multicast subtree rooted at the local node.
getChildren(Topic) - Method in interface rice.p2p.scribe.Scribe
Returns the list of children for a given topic
getChildren(Topic) - Method in class rice.p2p.scribe.ScribeImpl
Returns the list of children for a given topic
getClients() - Method in class rice.p2p.scribe.ScribeImpl.TopicManager
Gets the Clients attribute of the TopicManager object
getClients(Topic) - Method in class rice.p2p.scribe.ScribeImpl
Returns the list of clients for a given topic
getClosest(NodeId) - Method in class rice.pastry.direct.EuclideanNetwork
find the closest NodeId to an input NodeId out of all NodeIds in the network
getClosest(NodeId) - Method in interface rice.pastry.direct.NetworkSimulator
 
getClosest(NodeId) - Method in class rice.pastry.direct.SphereNetwork
find the closest NodeId to an input NodeId out of all NodeIds in the network
getComplementRange() - Method in interface rice.p2p.commonapi.IdRange
get the complement of this range
getComplementRange() - Method in class rice.pastry.IdRange
get the complement of this range
getContent() - Method in class rice.p2p.past.messaging.CacheMessage
Method which returns the content
getContent() - Method in class rice.p2p.past.messaging.InsertMessage
Method which returns the content
getContent() - Method in class rice.p2p.scribe.messaging.AnycastMessage
Returns the content
getContent() - Method in class rice.p2p.scribe.messaging.PublishMessage
Returns the content
getContent() - Method in class rice.p2p.scribe.messaging.PublishRequestMessage
Returns the content
getContent() - Method in class rice.past.messaging.MessageFetch
Deprecated. Returns the located storage object.
getContent() - Method in class rice.past.messaging.MessageLookup
Deprecated. Returns the located storage object.
getCount() - Method in class rice.scribe.testing.DistTopicLog
 
getCredentials() - Method in class rice.pastry.client.CommonAPIAppl
Returns the credentials of this application.
getCredentials() - Method in class rice.pastry.client.PastryAppl
Returns the credentials of this application.
getCredentials() - Method in class rice.pastry.commonapi.PastryEndpoint
Returns the credentials of this application.
getCredentials() - Method in class rice.pastry.messaging.Message
Gets the credentials of the sender.
getCredentials() - Method in class rice.pastry.multiring.MultiRingAppl
 
getCredentials() - Method in class rice.pastry.testing.HelloWorldApp
Get credentials.
getCredentials() - Method in class rice.pastry.testing.Ping
 
getCredentials() - Method in class rice.pastry.testing.PingClient
 
getCredentials() - Method in class rice.pastry.testing.RegrTestApp
 
getCredentials() - Method in class rice.rm.messaging.RMMessage
Gets the author's credentials associated with this object
getCredentials() - Method in class rice.rm.RMImpl
Returns the credentials for the application
getCredentials() - Method in class rice.rm.testing.RMRegrTestApp
 
getCredentials() - Method in class rice.rm.testing.TestMessage
 
getCredentials() - Method in class rice.scribe.Scribe
Returns the credentials of this client.
getCredentials() - Method in class rice.scribe.testing.DistScribeRegrTestApp
 
getCW() - Method in class rice.pastry.Id
gets the Id just clockwise from this
getCW() - Method in class rice.pastry.IdRange
get clockwise edge of range
getCWId() - Method in interface rice.p2p.commonapi.IdRange
get clockwise edge of range
getCWId() - Method in class rice.pastry.IdRange
get clockwise edge of range
getData() - Method in class rice.p2p.splitstream.SplitStreamContent
Returns the data for this content
getData() - Method in class rice.scribe.messaging.ScribeMessage
Gets the data inside of the ScribeMessage object.
getDatagramManager() - Method in class rice.pastry.wire.WirePastryNode
Returns the DatagramManager for this pastry node.
getDate() - Method in class rice.pastry.messaging.Message
Gets the timestamp of the message, if it exists.
getDest() - Method in class rice.rm.messaging.RMRequestKeysMsg.WrappedMsg
 
getDestination() - Method in class rice.p2p.past.messaging.PastMessage
Method which returns this messages' destination address
getDestination() - Method in class rice.pastry.messaging.Message
Gets the address of message receiver that the message is for.
getDestination() - Method in class rice.pastry.routing.RouteMessage
Get receiver address.
getDestination() - Method in class rice.pastry.wire.messaging.datagram.DatagramMessage
Returns the NodeId which is the destination
getDestination() - Method in class rice.pastry.wire.messaging.socket.HelloMessage
Returns the NodeId of the source
getDestination() - Method in class rice.pastry.wire.messaging.socket.HelloResponseMessage
Returns the NodeId of the source
getDestination() - Method in class rice.pastry.wire.messaging.socket.SocketTransportMessage
Returns the destination node id
getDestination() - Method in class rice.pastry.wire.PendingWrite
Returns the destination address of this write
getDestinationId() - Method in interface rice.p2p.commonapi.RouteMessage
Returns the destination Id for this message
getDestinationId() - Method in class rice.p2p.past.testing.PastRegrTest.TestRouteMessage
 
getDestinationId() - Method in class rice.p2p.scribe.testing.ScribeRegrTest.TestRouteMessage
Gets the DestinationId attribute of the TestRouteMessage object
getDestinationId() - Method in class rice.pastry.routing.RouteMessage
 
getDigit(int, int) - Method in class rice.pastry.Id
Gets the ith digit in base 2^b.
getDigit(int, int) - Method in class rice.pastry.multiring.RingId
Gets the ith digit in base 2^b.
getDistance() - Method in class rice.pastry.testing.PingMessageNew
 
getDistinctChildren() - Method in class rice.scribe.Scribe
Gets the Vector of distinct children of this local node in multicast tree of all topics.
getDistinctParents() - Method in class rice.scribe.Scribe
Gets the Vector of distinct parent of this local node in the multicast trees of all topics.
getDomainPrefix(int, int, int, int) - Method in class rice.pastry.Id
produces a Id whose prefix up to row is identical to this, followed by a digit with value column, followed by a suffix of digits with value suffixDigits.
getEventId() - Method in class rice.rm.messaging.RMRequestKeysMsg
 
getEventId() - Method in class rice.rm.messaging.RMResponseKeysMsg
 
getException() - Method in class rice.Continuation.ExternalContinuation
 
getFactory(NodeIdFactory, int, int) - Static method in class rice.pastry.dist.DistPastryNodeFactory
Static method which is designed to be used by clients needing a distrubuted pastry node factory.
getFileId() - Method in class rice.past.messaging.PASTMessage
Deprecated. Gets the fileId for this file, which is used as the destination.
getFingerprintForChildTopics(NodeHandle) - Method in class rice.scribe.Scribe
 
getFingerprintForParentTopics(NodeHandle) - Method in class rice.scribe.Scribe
 
getGlobalBootstrap(boolean) - Method in class rice.pastry.multiring.testing.MultiRingPastryRegrTest
 
getHandle() - Method in class rice.p2p.past.messaging.FetchMessage
Method which returns the handle
getHandle() - Method in class rice.pastry.join.InitiateJoin
Gets the handle for the join.
getHandle() - Method in class rice.pastry.join.JoinRequest
Gets the handle of the node trying to join.
getHandle(Id) - Method in interface rice.p2p.commonapi.NodeHandleSet
Finds the NodeHandle associated with the NodeId.
getHandle(Id) - Method in class rice.pastry.leafset.SimilarSet
Finds the NodeHandle associated with the NodeId.
getHandle(Id) - Method in class rice.pastry.NodeSet
Finds the NodeHandle associated with the NodeId.
getHandle(Id) - Method in class rice.pastry.routing.RouteSet
Finds the NodeHandle associated with the NodeId.
getHandle(int) - Method in interface rice.p2p.commonapi.NodeHandleSet
Gets the ith element in the set.
getHandle(int) - Method in class rice.pastry.leafset.SimilarSet
Gets the ith element in the set.
getHandle(int) - Method in class rice.pastry.NodeSet
Gets the ith element in the set.
getHandle(int) - Method in class rice.pastry.routing.RouteSet
Gets the ith element in the set.
getHandle(Past) - Method in class rice.p2p.past.ContentHashPastContent
Produces a handle for this content object.
getHandle(Past) - Method in interface rice.p2p.past.PastContent
Produces a handle for this content object.
getHandle(Past) - Method in class rice.p2p.past.testing.PastRegrTest.TestPastContent
 
getHash() - Method in class rice.pastry.IdSet
compute a fingerprint of the members in this IdSet
getHash() - Method in class rice.rm.messaging.RMMessage.KEEntry
 
getHashEnabled() - Method in class rice.rm.messaging.RMMessage.KEEntry
 
getHops() - Method in class rice.pastry.testing.PingMessageNew
 
getId() - Method in interface rice.p2p.commonapi.Endpoint
Returns this node's id, which is its identifier in the namespace.
getId() - Method in interface rice.p2p.commonapi.Node
Returns the Id of this node
getId() - Method in class rice.p2p.commonapi.NodeHandle
Returns this node's id.
getId() - Method in class rice.p2p.past.ContentHashPastContent
Returns the Id under which this object is stored in Past.
getId() - Method in class rice.p2p.past.ContentHashPastContentHandle
Returns the id of the PastContent object associated with this handle
getId() - Method in class rice.p2p.past.messaging.FetchHandleMessage
Method which returns the id
getId() - Method in class rice.p2p.past.messaging.LookupHandlesMessage
Method which returns the id
getId() - Method in class rice.p2p.past.messaging.LookupMessage
Method which returns the id
getId() - Method in interface rice.p2p.past.PastContent
Returns the Id under which this object is stored in Past.
getId() - Method in interface rice.p2p.past.PastContentHandle
get the id of the PastContent object associated with this handle
getId() - Method in class rice.p2p.past.testing.PastRegrTest.TestPastContent
 
getId() - Method in class rice.p2p.past.testing.PastRegrTest.TestPastContentHandle
 
getId() - Method in class rice.p2p.scribe.messaging.AbstractSubscribeMessage
Returns this subscribe lost message's id
getId() - Method in class rice.p2p.scribe.messaging.SubscribeMessage
Returns this subscribe lost message's id
getId() - Method in class rice.p2p.scribe.ScribeImpl
Returns the Id of the local node
getId() - Method in class rice.p2p.scribe.Topic
Returns the Id to which this topic is mapped
getId() - Method in class rice.p2p.splitstream.ChannelId
Gets the Id attribute of the ChannelId object
getId() - Method in class rice.p2p.splitstream.StripeId
Gets the Id attribute of the StripeId object
getId() - Method in class rice.past.PASTServiceImpl
Deprecated. Returns the Node
getId() - Method in class rice.pastry.commonapi.PastryEndpoint
Returns this node's id, which is its identifier in the namespace.
getId() - Method in class rice.pastry.NodeHandle
 
getId() - Method in class rice.pastry.PastryNode
Returns the Id of this node
getID() - Method in class rice.past.messaging.PASTMessage
Deprecated. Gets this message's identifier.
getId(IdFactory, String) - Static method in class rice.p2p.scribe.Topic
Returns the Id to which the string is mapped
getIDCode() - Method in class rice.past.messaging.PASTMessageIDImpl
Deprecated. Returns the internal representation of the id.
getIdFactory() - Method in interface rice.p2p.commonapi.Node
Returns a factory for Ids specific to this node's protocol.
getIdFactory() - Method in class rice.pastry.PastryNode
Returns a factory for Ids specific to this node's protocol.
getIndex(NodeId) - Method in class rice.pastry.leafset.LeafSet
Gets the index of the element with the given node id.
getIndex(NodeId) - Method in class rice.pastry.leafset.SimilarSet
Gets the index of the element with the given node id.
getIndex(NodeId) - Method in class rice.pastry.NodeSet
Gets the index of the element with the given node id.
getIndex(NodeId) - Method in interface rice.pastry.NodeSetI
Gets the index of the element with the given node id.
getIndex(NodeId) - Method in class rice.pastry.routing.RouteSet
Get the index of the node id.
getIndexHandle(Id) - Method in interface rice.p2p.commonapi.NodeHandleSet
Gets the index of the element with the given node id.
getIndexHandle(Id) - Method in class rice.pastry.leafset.SimilarSet
Gets the index of the element with the given node id.
getIndexHandle(Id) - Method in class rice.pastry.NodeSet
Gets the index of the element with the given node id.
getIndexHandle(Id) - Method in class rice.pastry.routing.RouteSet
Gets the index of the element with the given node id.
getIsInPool() - Method in class rice.pastry.dist.DistNodeHandle
Returns whether or not this node handle is the one in the node handle pool.
getIterator() - Method in interface rice.p2p.commonapi.IdSet
return an iterator over the elements of this set
getIterator() - Method in class rice.pastry.IdSet
return an iterator over the elements of this set
getIterator() - Method in class rice.pastry.NodeSet
return an iterator that iterates over the elements of this set
getJoinData(NodeId) - Method in class rice.scribe.testing.DirectScribeMaintenanceTestApp
 
getJoinHandle() - Method in class rice.pastry.join.JoinRequest
Gets the handle of the node that accepted the join request;
getKeySet() - Method in class rice.rm.messaging.RMMessage.KEEntry
 
getLastRecvTime() - Method in class rice.scribe.testing.DistTopicLog
 
getLastSeqNumRecv() - Method in class rice.scribe.testing.DistTopicLog
 
getLeafSet() - Method in class rice.pastry.client.PastryAppl
Called by a layered Pastry application to obtain a copy of the leaf set.
getLeafSet() - Method in class rice.pastry.join.JoinRequest
Gets the leafset of the node that accepted the join request;
getLeafSet() - Method in class rice.pastry.multiring.MultiRingPastryNode
 
getLeafSet() - Method in class rice.pastry.PastryNode
 
getLeafSet() - Method in interface rice.pastry.rmi.RMIRemoteNodeI
 
getLeafSet() - Method in class rice.pastry.wire.messaging.socket.LeafSetResponseMessage
Returns the leafset of the receiver.
getLeafSet(NodeHandle) - Method in class rice.pastry.direct.DirectPastryNodeFactory
This method returns the remote leafset of the provided handle to the caller, in a protocol-dependent fashion.
getLeafSet(NodeHandle) - Method in class rice.pastry.multiring.MultiRingPastryNodeFactory
This method returns the remote leafset of the provided handle to the caller, in a protocol-dependent fashion.
getLeafSet(NodeHandle) - Method in class rice.pastry.PastryNodeFactory
This method returns the remote leafset of the provided handle to the caller, in a protocol-dependent fashion.
getLeafSet(NodeHandle) - Method in class rice.pastry.rmi.RMIPastryNodeFactory
This method returns the remote leafset of the provided handle to the caller, in a protocol-dependent fashion.
getLeafSet(NodeHandle) - Method in class rice.pastry.wire.WirePastryNodeFactory
This method returns the remote leafset of the provided handle to the caller, in a protocol-dependent fashion.
getLocalBootstrap(int, boolean) - Method in class rice.pastry.multiring.testing.MultiRingPastryRegrTest
 
getLocalHandle() - Method in class rice.pastry.multiring.MultiRingPastryNode
 
getLocalHandle() - Method in class rice.pastry.PastryNode
 
getLocalHandle() - Method in class rice.rm.RMImpl
Gets the local NodeHandle associated with this Pastry node.
getLocalHandle() - Method in class rice.rm.testing.RMRegrTestApp
 
getLocalHandle() - Method in class rice.scribe.Scribe
 
getLocalHandle() - Method in class rice.scribe.testing.DirectScribeMaintenanceTestApp
 
getLocalId() - Method in class rice.p2p.splitstream.Channel
Gets the local node id.
getLocalNode() - Method in class rice.pastry.LocalNode
Accessor method.
getLocalNode() - Method in interface rice.pastry.LocalNodeI
Accessor method.
getLocalNode() - Method in class rice.pastry.NodeHandle
Accessor method.
getLocalNodeHandle() - Method in interface rice.p2p.commonapi.Endpoint
Returns a handle to the local node below this endpoint.
getLocalNodeHandle() - Method in interface rice.p2p.past.Past
get the nodeHandle of the local Past node
getLocalNodeHandle() - Method in class rice.p2p.past.PastImpl
get the nodeHandle of the local Past node
getLocalNodeHandle() - Method in class rice.pastry.commonapi.PastryEndpoint
Returns a handle to the local node below this endpoint.
getMax() - Method in class rice.p2p.past.messaging.LookupHandlesMessage
Method which returns the number of replicas
getMaxChildren(ChannelId) - Method in class rice.p2p.splitstream.SplitStreamScribePolicy
Gets the max bandwidth for a channel.
getMaximumSize(Continuation) - Method in interface rice.persistence.Cache
Returns the maximum size of the cache, in bytes.
getMaximumSize(Continuation) - Method in class rice.persistence.LRUCache
Returns the maximum size of the cache, in bytes.
getMaximumSize(Continuation) - Method in class rice.persistence.StorageManager
Returns the maximum size of the cache, in bytes.
getMessage() - Method in interface rice.p2p.commonapi.RouteMessage
Returns the enclosed message inside of this message
getMessage() - Method in class rice.p2p.past.testing.PastRegrTest.TestRouteMessage
 
getMessage() - Method in class rice.p2p.scribe.testing.ScribeRegrTest.TestRouteMessage
Gets the Message attribute of the TestRouteMessage object
getMessage() - Method in class rice.pastry.commonapi.PastryEndpointMessage
Returns the internal message
getMessage() - Method in class rice.pastry.multiring.messaging.RingForwardMessage
 
getMessage() - Method in class rice.pastry.routing.RouteMessage
 
getMessage() - Method in class rice.pastry.ScheduledMessage
Returns the message
getMessageDispatch() - Method in class rice.pastry.multiring.MultiRingPastryNode
 
getMessageDispatch() - Method in class rice.pastry.PastryNode
FOR TESTING ONLY - DO NOT USE!
getmissingCount() - Method in class rice.rm.testing.ObjectState
 
getMsg() - Method in class rice.rm.messaging.RMRequestKeysMsg.WrappedMsg
 
getMultiRingAppl() - Method in class rice.pastry.multiring.MultiRingPastryNode
 
getNearest(NodeHandle, NodeHandle) - Method in class rice.pastry.PastryNodeFactory
This method implements the algorithm in the Pastry locality paper for finding a close node the the current node through iterative leafset and route row requests.
getNetworkSimulator() - Method in class rice.pastry.direct.DirectPastryNodeFactory
 
getNext() - Method in class rice.p2p.scribe.messaging.AnycastMessage
Returns the next handle to visit and removes the node from the list.
getNextHop() - Method in class rice.pastry.routing.RouteMessage
 
getNextHopHandle() - Method in interface rice.p2p.commonapi.RouteMessage
Returns the next hop handle for this message
getNextHopHandle() - Method in class rice.p2p.past.testing.PastRegrTest.TestRouteMessage
 
getNextHopHandle() - Method in class rice.p2p.scribe.testing.ScribeRegrTest.TestRouteMessage
Gets the NextHopHandle attribute of the TestRouteMessage object
getNextHopHandle() - Method in class rice.pastry.routing.RouteMessage
 
getNodeHandle() - Method in class rice.p2p.past.ContentHashPastContentHandle
Returns the NodeHandle of the Past node on which the object associated with this handle is stored
getNodeHandle() - Method in interface rice.p2p.past.PastContentHandle
get the NodeHandle of the Past node on which the object associated with this handle is stored
getNodeHandle() - Method in class rice.p2p.past.testing.PastRegrTest.TestPastContentHandle
 
getNodeHandle() - Method in class rice.pastry.client.PastryAppl
Gets the handle of the Pastry node associated with this client
getNodeHandle() - Method in class rice.scribe.Scribe
Returns the handle of the local node on which this Scribe application resides.
getNodeHandle(InetSocketAddress) - Method in class rice.pastry.dist.DistPastryNodeFactory
Method which a client should use in order to get a bootstrap node from the factory.
getNodeHandlePool() - Method in class rice.pastry.dist.DistPastryNode
Method which returns the Dist for this Pastry node.
getNodeHandlePool() - Method in class rice.pastry.rmi.RMIPastryNode
accessor method for RMI handle pool.
getNodeHandlePool() - Method in class rice.pastry.wire.WirePastryNode
Returns the WireNodeHandlePool for this pastry node.
getNodeId() - Method in class rice.pastry.client.PastryAppl
Gets the node id associated with this client.
getNodeId() - Method in class rice.pastry.direct.DirectNodeHandle
Gets the NodeId attribute of the DirectNodeHandle object
getNodeId() - Method in class rice.pastry.dist.DistNodeHandle
Gets the nodeId of this Pastry node.
getNodeId() - Method in class rice.pastry.multiring.MultiRingPastryNode
 
getNodeId() - Method in class rice.pastry.NodeHandle
Gets the nodeId of this Pastry node.
getNodeId() - Method in class rice.pastry.PastryNode
 
getNodeId() - Method in interface rice.pastry.rmi.RMIRemoteNodeI
 
getNodeId() - Method in class rice.pastry.testing.LeafSetTest.TestNodeHandle
 
getNodeId() - Method in class rice.pastry.wire.messaging.socket.HelloMessage
Returns the NodeId of the source
getNodeId() - Method in class rice.pastry.wire.messaging.socket.HelloResponseMessage
Returns the NodeId of the source
getNodeId() - Method in class rice.pastry.wire.messaging.socket.NodeIdResponseMessage
Returns the nodeId of the receiver.
getNodeId() - Method in class rice.scribe.testing.BasicScribeRegrTestApp
 
getNodeId() - Method in class rice.scribe.testing.DirectScribeMaintenanceTestApp
 
getNodeNumber() - Method in class rice.pastry.direct.TestRecord
returns the number of nodes
getNum() - Method in class rice.pastry.wire.messaging.datagram.DatagramMessage
Returns the "packet number" of this transmission
getNumAcks() - Method in class rice.rm.testing.RMRegrTestApp.ReplicateEntry
 
getNumKeys() - Method in class rice.rm.messaging.RMMessage.KEEntry
 
getNumKeys() - Method in class rice.rm.RMImpl.KEPenEntry
 
getNumUnsubscribed(NodeId) - Static method in class rice.scribe.testing.DistScribeRegrTest
 
getObject() - Method in class rice.pastry.wire.messaging.datagram.DatagramTransportMessage
Returns the iternal wrapped object.
getObject() - Method in class rice.pastry.wire.messaging.socket.SocketTransportMessage
Returns the wrapped message
getObject() - Method in class rice.pastry.wire.PendingWrite
Returns the object to be written
getObject() - Method in class rice.rm.testing.InsertMsg
Gets the object contained in this message
getObject() - Method in class rice.rm.testing.RMRegrTestApp.ReplicateEntry
 
getObject(Id, Continuation) - Method in interface rice.persistence.Catalog
Returns the object identified by the given id, or null if there is no cooresponding object (through receiveResult on c).
getObject(Id, Continuation) - Method in class rice.persistence.LRUCache
Returns the object identified by the given id.
getObject(Id, Continuation) - Method in class rice.persistence.MemoryStorage
Returns the object identified by the given id, or null if there is no cooresponding object (through receiveResult on c).
getObject(Id, Continuation) - Method in class rice.persistence.PersistentStorage
Returns the object identified by the given id.
getObject(Id, Continuation) - Method in class rice.persistence.StorageManager
Returns the object identified by the given id, or null if there is no cooresponding object (through receiveResult on c).
getObjectKey() - Method in class rice.rm.testing.HeartbeatMsg
Gets the objectKey of the object.
getObjectKey() - Method in class rice.rm.testing.InsertMsg
Gets the objectKey of the object.
getObjectKey() - Method in class rice.rm.testing.InsertResponseMsg
 
getObjectKey() - Method in class rice.rm.testing.RefreshMsg
Gets the objectKey of the object.
getObjectKey() - Method in class rice.rm.testing.ReplicateMsg
Gets the objectKey of the object.
getObjectKey() - Method in class rice.rm.testing.ReplicateResponseMsg
 
getObjectKey() - Method in class rice.rm.testing.ReplicateTimeoutMsg
 
getOptions() - Method in class rice.pastry.routing.RouteMessage
Get transmission options.
getParent() - Method in class rice.p2p.scribe.ScribeImpl.TopicManager
Gets the Parent attribute of the TopicManager object
getParent() - Method in class rice.p2p.splitstream.Stripe
Utility method.
getParent() - Method in class rice.pastry.multiring.MultiRingPastryNode
 
getParent() - Method in class rice.scribe.Topic
Returns the local node's parent in this topic's multicast tree.
getParent(NodeId) - Method in interface rice.scribe.IScribe
Returns the local node's parent in this topic's multicast tree.
getParent(NodeId) - Method in class rice.scribe.Scribe
Returns the local node's parent in this topic's multicast tree.
getParent(Topic) - Method in class rice.p2p.scribe.ScribeImpl
Returns the parent for a given topic
getPastryNode() - Method in class rice.pastry.multiring.MultiRingPastryNode
 
getPastryNode() - Method in class rice.rm.RMImpl
Gets the underlying local Pastry node.
getPastryNode() - Method in class rice.rm.testing.RMRegrTestApp
 
getPastryNode() - Method in class rice.scribe.Scribe
Returns the pastryNode for this application.
getPathToRoot() - Method in class rice.p2p.scribe.messaging.SubscribeAckMessage
Returns the path to the root for the node receiving this message
getPathToRoot() - Method in class rice.p2p.scribe.ScribeImpl.TopicManager
Gets the PathToRoot attribute of the TopicManager object
getPendingObject(Id) - Method in class rice.rm.testing.RMRegrTestApp
 
getPendingRanges(NodeId) - Method in class rice.rm.RMImpl
Gets the list of pending Ranges corresponding to a node that we are communicating to in the Keys Exchange Protocol.
getPolicy() - Method in interface rice.p2p.scribe.Scribe
Returns the current policy for this scribe object
getPolicy() - Method in class rice.p2p.scribe.ScribeImpl
Returns the current policy for this scribe object
getPolicy() - Method in class rice.p2p.splitstream.SplitStreamImpl
Returns the policy used to control Scribe
getPrefixMatch(Id, Id) - Static method in class rice.p2p.splitstream.SplitStreamScribePolicy
Helper method for finding prefix match between two Ids.
getPreviousNodeHandle() - Method in class rice.p2p.past.messaging.LookupMessage
Method which returns the previous hop (where the message was just at)
getPreviousParent() - Method in class rice.p2p.scribe.messaging.SubscribeMessage
Returns the node who is trying to subscribe
getPrevNode() - Method in class rice.pastry.routing.RouteMessage
 
getPrimaryStripe() - Method in class rice.p2p.splitstream.Channel
The primary stripe is the stripe that the user must have.
getProbability() - Method in class rice.pastry.testing.PingTestRecord
 
getProximity(NodeHandle, NodeHandle) - Method in class rice.pastry.direct.DirectPastryNodeFactory
This method determines and returns the proximity of the current local node the provided NodeHandle.
getProximity(NodeHandle, NodeHandle) - Method in class rice.pastry.multiring.MultiRingPastryNodeFactory
This method determines and returns the proximity of the current local node the provided NodeHandle.
getProximity(NodeHandle, NodeHandle) - Method in class rice.pastry.PastryNodeFactory
This method determines and returns the proximity of the current local node the provided NodeHandle.
getProximity(NodeHandle, NodeHandle) - Method in class rice.pastry.rmi.RMIPastryNodeFactory
This method determines and returns the proximity of the current local node the provided NodeHandle.
getProximity(NodeHandle, NodeHandle) - Method in class rice.pastry.wire.WirePastryNodeFactory
This method determines and returns the proximity of the current local node the provided NodeHandle.
getPublishMessages() - Method in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribeClient
 
getQueue() - Method in class rice.pastry.wire.SocketChannelWriter
Returns the queue of writes for the remote address
getRange() - Method in class rice.rm.messaging.RMMessage.KEEntry
 
getReady() - Method in class rice.pastry.wire.DatagramTransmissionManager
Returns an iterator over the pending writes ready to be written.
getRemote() - Method in class rice.pastry.direct.DirectNodeHandle
Gets the Remote attribute of the DirectNodeHandle object
getRemote() - Method in class rice.pastry.rmi.RMINodeHandle
Remotenode accessor method.
getReplicaManager() - Method in class rice.p2p.past.PastImpl
Returns the replica manager for this Past instance.
getReplicaSet() - Method in class rice.rm.testing.ReplicateResponseMsg
 
getReplicationFactor() - Method in interface rice.p2p.past.Past
Returns the number of replicas used in this Past
getReplicationFactor() - Method in class rice.p2p.past.PastImpl
Returns the number of replicas used in this Past
getReqRange() - Method in class rice.rm.messaging.RMMessage.KEEntry
 
getReqRange() - Method in class rice.rm.RMImpl.KEPenEntry
 
getResponse() - Method in class rice.p2p.past.messaging.ContinuationMessage
Returns the response
getResponse(InetSocketAddress, SocketCommandMessage) - Method in class rice.pastry.wire.WirePastryNodeFactory
This method anonymously sends the given message to the remote address, blocks until a response is received, and then closes the socket and returns the response.
getResponse(WirePastryNode) - Method in class rice.pastry.wire.messaging.socket.HelloMessage
Returns the appropriate response for this HelloMessage
getResult() - Method in class rice.Continuation.ExternalContinuation
 
getRingId() - Method in class rice.pastry.multiring.messaging.RingLookupReminderMessage
 
getRingId() - Method in class rice.pastry.multiring.messaging.RingLookupRequestMessage
 
getRingId() - Method in class rice.pastry.multiring.messaging.RingLookupResponseMessage
 
getRingId() - Method in class rice.pastry.multiring.MultiRingAppl
 
getRingId() - Method in class rice.pastry.multiring.MultiRingPastryNode
 
getRingId() - Method in class rice.pastry.multiring.RingNodeId
 
getRingNodeId() - Method in class rice.pastry.multiring.testing.MultiRingPastryRegrTest.MultiRingTestAppMessage
 
getRM() - Method in class rice.past.PASTServiceImpl
Deprecated. Return the RM
getRoot() - Method in class rice.persistence.PersistentStorage
gets the root directory that the persistence Manager uses
getRouteRow() - Method in class rice.pastry.wire.messaging.socket.RouteRowResponseMessage
Returns the routeset of the receiver.
getRouteRow(int) - Method in class rice.pastry.rmi.RMIPastryNode
Returns the given row of the routing table
getRouteRow(int) - Method in interface rice.pastry.rmi.RMIRemoteNodeI
 
getRouteRow(NodeHandle, int) - Method in class rice.pastry.direct.DirectPastryNodeFactory
This method returns the remote route row of the provided handle to the caller, in a protocol-dependent fashion.
getRouteRow(NodeHandle, int) - Method in class rice.pastry.multiring.MultiRingPastryNodeFactory
This method returns the remote route row of the provided handle to the caller, in a protocol-dependent fashion.
getRouteRow(NodeHandle, int) - Method in class rice.pastry.PastryNodeFactory
This method returns the remote route row of the provided handle to the caller, in a protocol-dependent fashion.
getRouteRow(NodeHandle, int) - Method in class rice.pastry.rmi.RMIPastryNodeFactory
This method returns the remote route row of the provided handle to the caller, in a protocol-dependent fashion.
getRouteRow(NodeHandle, int) - Method in class rice.pastry.wire.WirePastryNodeFactory
This method returns the remote route row of the provided handle to the caller, in a protocol-dependent fashion.
getRouteSet(int, int) - Method in class rice.pastry.routing.RoutingTable
Gets the set of handles at a particular entry in the table.
getRoutingTable() - Method in class rice.pastry.client.PastryAppl
Called by a layered Pastry application to obtain a copy of the routing table.
getRoutingTable() - Method in class rice.pastry.multiring.MultiRingPastryNode
 
getRoutingTable() - Method in class rice.pastry.PastryNode
 
getRow() - Method in class rice.pastry.routing.BroadcastRouteRow
Gets the row that was sent in the message.
getRow() - Method in class rice.pastry.routing.RequestRouteRow
Gets the row that made the request.
getRow() - Method in class rice.pastry.wire.messaging.socket.RouteRowRequestMessage
Returns the row which this a request for
getRow(int) - Method in class rice.pastry.join.JoinRequest
Get row.
getRow(int) - Method in class rice.pastry.routing.RoutingTable
Get a row from the routing table.
getScribe() - Method in class rice.pastry.multiring.MultiRingAppl
 
getScribe() - Method in class rice.pastry.multiring.MultiRingPastryNode
 
getScribe() - Method in class rice.scribe.testing.DirectScribeMaintenanceTestApp
Returns the underlying scribe object.
getScribe() - Method in class rice.scribe.testing.DistScribeRegrTestApp
 
getSecurityManager() - Method in class rice.scribe.Scribe
Returns the security manager from the Scribe node.
getSeed() - Static method in class rice.pastry.PastrySeed
 
getSelector() - Method in class rice.pastry.wire.SelectorManager
Returns the selector used by this SelectorManager.
getSelectorManager() - Method in class rice.pastry.wire.WirePastryNode
Returns the SelectorManager for this pastry node.
getSenderId() - Method in class rice.pastry.messaging.Message
Get sender Id.
getSendOptions() - Method in class rice.scribe.Scribe
Returns the send options in the Scribe system.
getSeqno() - Method in class rice.rm.messaging.RMMessage
 
getSeqNumToPublish() - Method in class rice.scribe.testing.DistTopicLog
 
getSimulator() - Method in class rice.pastry.direct.DirectNodeHandle
Gets the Simulator attribute of the DirectNodeHandle object
getSocketManager() - Method in class rice.pastry.wire.WirePastryNode
Returns the SocketManager for this pastry node.
getSource() - Method in class rice.p2p.past.messaging.PastMessage
Method which returns this messages' source address
getSource() - Method in class rice.p2p.scribe.messaging.ScribeMessage
Method which returns this messages' source address
getSource() - Method in class rice.past.messaging.PASTMessage
Deprecated. Gets the source Id for this message.
getSource() - Method in class rice.pastry.multiring.messaging.RingLookupResponseMessage
 
getSource() - Method in class rice.pastry.testing.PingMessageNew
 
getSource() - Method in class rice.pastry.wire.messaging.datagram.DatagramMessage
Returns the NodeId from which this message came.
getSource() - Method in class rice.rm.messaging.RMMessage
 
getSource() - Method in class rice.rm.testing.TestMessage
 
getSource() - Method in class rice.scribe.messaging.ScribeMessage
Returns the nodeId of the node that generated the message.
getStage() - Method in class rice.p2p.splitstream.SplitStreamSubscribeContent
Returns the data for this content
getstaleCount() - Method in class rice.rm.testing.ObjectState
 
getState() - Method in class rice.pastry.wire.WireNodeHandle
Returns the state of this WireNodeHandle
getState() - Method in class rice.scribe.Topic
Gets the current state of topic.
getStorage() - Method in class rice.past.PASTServiceImpl
Deprecated. Returns the StorageManager object
getStorage() - Method in class rice.persistence.StorageManager
Returns the permantent storage object used by this StorageManager
getStorageManager() - Method in class rice.p2p.past.PastImpl
Returns this Past's storage manager.
getStorageSize() - Method in class rice.persistence.PersistentStorage
gets the amount of storage that the persistence Manager uses
getStream() - Method in class rice.pastry.messaging.Message
Get stream over which the object was deserialized.
getStripeId() - Method in class rice.p2p.splitstream.Stripe
gets the StripeID for this stripe
getStripes() - Method in class rice.p2p.splitstream.Channel
At any moment a node is subscribed to at least 1 but possibly more stripes.
getSubscribeFailed() - Method in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribeClient
 
getSubscriber() - Method in class rice.p2p.scribe.messaging.SubscribeMessage
Returns the node who is trying to subscribe
getSuccess() - Method in class rice.past.messaging.MessageInsert
Deprecated. Returns whether the insert was successful.
getSuccess() - Method in class rice.past.messaging.MessageReclaim
Deprecated. Returns whether the reclaim command was successful.
getTarget() - Method in class rice.pastry.routing.RouteMessage
Gets the target node id of this message.
getTestNumber() - Method in class rice.pastry.direct.TestRecord
returns the number of tests
getTestRecord() - Method in class rice.pastry.direct.EuclideanNetwork
get TestRecord
getTestRecord() - Method in interface rice.pastry.direct.NetworkSimulator
 
getTestRecord() - Method in class rice.pastry.direct.SphereNetwork
get TestRecord
getTimestamp() - Method in class rice.pastry.direct.DirectSecurityManager
Gets the current time for a timestamp.
getTimestamp() - Method in class rice.pastry.rmi.RMIPastrySecurityManager
Gets the current time for a timestamp.
getTimestamp() - Method in interface rice.pastry.security.PastrySecurityManager
Gets the current time for a timestamp.
getTimestamp() - Method in class rice.pastry.security.PermissiveSecurityManager
 
getTimestamp() - Method in class rice.pastry.wire.WirePastrySecurityManager
Gets the current time for a timestamp.
getTopic() - Method in class rice.p2p.scribe.messaging.ScribeMessage
Method which returns this messages' topic
getTopic(NodeId) - Method in class rice.scribe.Scribe
Returns the topic object associated with topicId.
getTopicId() - Method in class rice.scribe.messaging.ScribeMessage
Returns the topicId associated with the message.
getTopicId() - Method in class rice.scribe.Topic
Returns the topic's id
getTopics() - Method in class rice.scribe.Scribe
Method to access the list of topics this scribe is responsible for.
getTopicsForChild(NodeHandle) - Method in class rice.scribe.Scribe
Gets the vector of topicIds for which given node is a child.
getTopicsForParent(NodeHandle) - Method in class rice.scribe.Scribe
Gets the vector of topicIds for which given node is our parent.
getTotalChildren(Channel) - Method in class rice.p2p.splitstream.SplitStreamScribePolicy
Returns the total number of children for the given channel
getTotalSize(Continuation) - Method in interface rice.persistence.Catalog
Returns the total size of the stored data in bytes.The result is returned via the receiveResult method on the provided Continuation with an Integer representing the size.
getTotalSize(Continuation) - Method in class rice.persistence.LRUCache
Returns the total size of the stored data in bytes.
getTotalSize(Continuation) - Method in class rice.persistence.MemoryStorage
Returns the total size of the stored data in bytes.The result is returned via the receiveResult method on the provided Continuation with an Integer representing the size.
getTotalSize(Continuation) - Method in class rice.persistence.PersistentStorage
Returns the total size of the stored data in bytes.The result is returned via the receiveResult method on the provided Continuation with an Integer representing the size.
getTotalSize(Continuation) - Method in class rice.persistence.StorageManager
Returns the total size of the stored data in bytes.The result is returned via the receiveResult method on the provided Continuation with an Integer representing the size.
getTreeRepairThreshold() - Method in class rice.scribe.Scribe
Gets the tree repair threshold value.
getType() - Method in class rice.past.messaging.PASTMessage
Deprecated. Gets this message's type.
getUID() - Method in class rice.p2p.past.messaging.PastMessage
Method which returns this messages' unique id
getUnsubscribed() - Method in class rice.scribe.testing.DistTopicLog
 
GLOBAL_RING_ID - Static variable in class rice.pastry.multiring.MultiRingPastryNode
 
greetingReceived() - Method in class rice.pastry.wire.SocketChannelWriter
 

H

Half - Static variable in class rice.pastry.Id
 
handle - Variable in class rice.p2p.past.testing.PastRegrTest.TestPastContentHandle
 
handle - Variable in class rice.p2p.scribe.ScribeImpl
the local node handle
handle() - Method in class rice.pastry.NodeSetUpdate
The handle that changed.
handleDeliverMessage(DistRMRegrTestApp) - Method in class rice.rm.testing.DistRMRegrTestMessage
This method is called whenever the pastry node receives this message for the DistRMRegrTestApp.
handleDeliverMessage(DistRMRegrTestApp) - Method in class rice.rm.testing.DistRMRegrTestReplicateMessage
This method is called whenever the pastry node receives this message for the DistRMRegrTestApp.
handleDeliverMessage(DistScribeRegrTestApp) - Method in class rice.scribe.testing.DistScribeRegrTestMessage
This method is called whenever the pastry node receives a message for the DistScribeRegrTestApp.
handleDeliverMessage(RMImpl) - Method in class rice.rm.messaging.RMMaintenanceMsg
 
handleDeliverMessage(RMImpl) - Method in class rice.rm.messaging.RMMessage
This method is called whenever the rm node receives a message for itself and wants to process it.
handleDeliverMessage(RMImpl) - Method in class rice.rm.messaging.RMRequestKeysMsg
The handling of the message iterates of the 'rangeSet' as takes the following action on the entries of type RMMessage.KEEntry.
handleDeliverMessage(RMImpl) - Method in class rice.rm.messaging.RMResponseKeysMsg
The handling of the message does the following - 1.
handleDeliverMessage(RMImpl) - Method in class rice.rm.messaging.RMTimeoutMsg
If the RMResponseKeysMsg corresponding to the wrapped RMRequestKeysMsg was received (done by having same 'eventId' field in RMRequestKeysMsg & corresponding RMResponseKeysMsg) then nothing needs to be done.
handleDeliverMessage(RMRegrTestApp) - Method in class rice.rm.testing.HeartbeatMsg
This method is called whenever the rm node receives a message for itself and wants to process it.
handleDeliverMessage(RMRegrTestApp) - Method in class rice.rm.testing.InsertMsg
This method is called whenever the rm node receives a message for itself and wants to process it.
handleDeliverMessage(RMRegrTestApp) - Method in class rice.rm.testing.InsertResponseMsg
This method is called whenever the rm node receives a message for itself and wants to process it.
handleDeliverMessage(RMRegrTestApp) - Method in class rice.rm.testing.InvariantCheckMsg
 
handleDeliverMessage(RMRegrTestApp) - Method in class rice.rm.testing.ObjectInsertionMsg
 
handleDeliverMessage(RMRegrTestApp) - Method in class rice.rm.testing.ObjectRefreshMsg
 
handleDeliverMessage(RMRegrTestApp) - Method in class rice.rm.testing.RefreshMsg
 
handleDeliverMessage(RMRegrTestApp) - Method in class rice.rm.testing.ReplicateMsg
This method is called whenever the rm node receives a message for itself and wants to process it.
handleDeliverMessage(RMRegrTestApp) - Method in class rice.rm.testing.ReplicateResponseMsg
This method is called whenever the rm node receives a message for itself and wants to process it.
handleDeliverMessage(RMRegrTestApp) - Method in class rice.rm.testing.ReplicateTimeoutMsg
 
handleDeliverMessage(RMRegrTestApp) - Method in class rice.rm.testing.TestMessage
 
handleDeliverMessage(Scribe, Topic) - Method in class rice.scribe.maintenance.MessageScribeMaintenance
This method is called whenever the scribe node receives a message for itself and wants to process it.
handleDeliverMessage(Scribe, Topic) - Method in class rice.scribe.messaging.MessageAckOnSubscribe
This method is called whenever the scribe node receives a message for itself and wants to process it.
handleDeliverMessage(Scribe, Topic) - Method in class rice.scribe.messaging.MessageAnycast
This method is called whenever the scribe node receives a message for itself and wants to process it.
handleDeliverMessage(Scribe, Topic) - Method in class rice.scribe.messaging.MessageCreate
This method is called whenever the scribe node receives a message for itself and wants to process it.
handleDeliverMessage(Scribe, Topic) - Method in class rice.scribe.messaging.MessageHeartBeat
This method is called whenever the scribe node receives a message for itself and wants to process it.
handleDeliverMessage(Scribe, Topic) - Method in class rice.scribe.messaging.MessagePublish
This method is called whenever the scribe node receives a message for itself and wants to process it.
handleDeliverMessage(Scribe, Topic) - Method in class rice.scribe.messaging.MessageReplyFromParent
This method is called whenever the scribe node receives a message for itself and wants to process it.
handleDeliverMessage(Scribe, Topic) - Method in class rice.scribe.messaging.MessageRequestToParent
This method is called whenever the scribe node receives a message for itself and wants to process it.
handleDeliverMessage(Scribe, Topic) - Method in class rice.scribe.messaging.MessageSubscribe
This method is called whenever the scribe node receives a message for itself and wants to process it.
handleDeliverMessage(Scribe, Topic) - Method in class rice.scribe.messaging.MessageUnsubscribe
This method is called whenever the scribe node receives a message for itself and wants to process it.
handleDeliverMessage(Scribe, Topic) - Method in class rice.scribe.messaging.ScribeMessage
This method is called whenever the scribe node receives a message for itself and wants to process it.
handleForwardMessage(Scribe, Topic) - Method in class rice.scribe.maintenance.MessageScribeMaintenance
This method is called whenever the scribe node forwards a message in the scribe network.
handleForwardMessage(Scribe, Topic) - Method in class rice.scribe.messaging.MessageAckOnSubscribe
This method is called whenever the scribe node forwards a message in the scribe network.
handleForwardMessage(Scribe, Topic) - Method in class rice.scribe.messaging.MessageAnycast
This method is called whenever the scribe node forwards a message in the scribe network.
handleForwardMessage(Scribe, Topic) - Method in class rice.scribe.messaging.MessageCreate
This method is called whenever the scribe node forwards a message in the scribe network.
handleForwardMessage(Scribe, Topic) - Method in class rice.scribe.messaging.MessageHeartBeat
This method is called whenever the scribe node forwards a message in the scribe network.
handleForwardMessage(Scribe, Topic) - Method in class rice.scribe.messaging.MessagePublish
This method is called whenever the scribe node forwards a message in the scribe network.
handleForwardMessage(Scribe, Topic) - Method in class rice.scribe.messaging.MessageReplyFromParent
This method is called whenever the scribe node forwards a message in the scribe network.
handleForwardMessage(Scribe, Topic) - Method in class rice.scribe.messaging.MessageRequestToParent
This method is called whenever the scribe node forwards a message in the scribe network.
handleForwardMessage(Scribe, Topic) - Method in class rice.scribe.messaging.MessageSubscribe
This method is called whenever the scribe node forwards a message in the scribe network.
handleForwardMessage(Scribe, Topic) - Method in class rice.scribe.messaging.MessageUnsubscribe
This method is called whenever the scribe node forwards a message in the scribe network.
handleForwardMessage(Scribe, Topic) - Method in class rice.scribe.messaging.ScribeMessage
This method is called whenever the scribe node forwards a message in the scribe network.
hasChanged() - Method in class rice.pastry.dist.DistNodeHandle
 
hasChildren() - Method in class rice.scribe.Topic
Indicates if the local node has children associated with this topic.
hashCode() - Method in class rice.p2p.scribe.Topic
Returns the hashCode for this topic
hashCode() - Method in class rice.p2p.splitstream.ChannelId
 
hashCode() - Method in class rice.p2p.splitstream.StripeId
 
hashCode() - Method in interface rice.past.messaging.PASTMessageID
Deprecated. Returns the hashcode value of the object.
hashCode() - Method in class rice.past.messaging.PASTMessageIDImpl
Deprecated. Returns the hashcode value of the object.
hashCode() - Method in class rice.pastry.direct.DirectNodeHandle
Hash codes for node handles.It is the hashcode of their corresponding NodeId's.
hashCode() - Method in class rice.pastry.dist.DistNodeHandle
Hash codes for node handles.
hashCode() - Method in class rice.pastry.Id
Hash codes for Ids.
hashCode() - Method in class rice.pastry.Id.Distance
Hash codes.
hashCode() - Method in class rice.pastry.join.JoinAddress
 
hashCode() - Method in class rice.pastry.leafset.LeafSetProtocolAddress
 
hashCode() - Method in class rice.pastry.multiring.messaging.MultiRingApplAddress
Returns the code representing the address.
hashCode() - Method in class rice.pastry.multiring.RingId
Hash codes for ringIds.
hashCode() - Method in class rice.pastry.multiring.RingNodeId
 
hashCode() - Method in class rice.pastry.multiring.testing.MultiRingPastryRegrTest.MultiRingTestAppAddress
 
hashCode() - Method in class rice.pastry.NodeHandle
Hash codes for nodehandles.
hashCode() - Method in class rice.pastry.routing.RouteProtocolAddress
 
hashCode() - Method in class rice.pastry.routing.RouterAddress
 
hashCode() - Method in class rice.pastry.standard.StandardAddress
 
hashCode() - Method in class rice.pastry.testing.LeafSetTest.TestNodeHandle
 
hashCode() - Method in class rice.pastry.testing.PingAddress
 
hasPriority() - Method in class rice.pastry.messaging.Message
Get priority
hasPriority() - Method in class rice.pastry.routing.RouteMessage
Get priority
hasSubscribers() - Method in class rice.scribe.Topic
If this topic has any applications registered as subscribers.
heartbeat(Id) - Method in class rice.rm.testing.RMRegrTestApp
 
HeartbeatMsg - class rice.rm.testing.HeartbeatMsg.
 
HeartbeatMsg(NodeHandle, Address, Id, Credentials) - Constructor for class rice.rm.testing.HeartbeatMsg
Constructor : Builds a new Heartbeat Message
HelloMessage - class rice.pastry.wire.messaging.socket.HelloMessage.
Class which represents a greeting in the socket-based pastry protocol.
HelloMessage(WirePastryNode, NodeId) - Constructor for class rice.pastry.wire.messaging.socket.HelloMessage
Constructor
HelloResponseMessage - class rice.pastry.wire.messaging.socket.HelloResponseMessage.
Class which represents a greeting response in the socket-based pastry protocol.
HelloResponseMessage(WirePastryNode, NodeId) - Constructor for class rice.pastry.wire.messaging.socket.HelloResponseMessage
Constructor
HelloWorld - class rice.pastry.testing.HelloWorld.
A hello world example for pastry.
HelloWorld() - Constructor for class rice.pastry.testing.HelloWorld
Constructor
HelloWorldApp - class rice.pastry.testing.HelloWorldApp.
A hello world example for pastry.
HelloWorldApp(PastryNode) - Constructor for class rice.pastry.testing.HelloWorldApp
 

I

i - Variable in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribeClient
DESCRIBE THE FIELD
id - Variable in class rice.p2p.past.messaging.PastMessage
 
id - Variable in class rice.p2p.past.testing.PastRegrTest.TestPastContent
 
id - Variable in class rice.p2p.past.testing.PastRegrTest.TestPastContentHandle
 
id - Variable in class rice.p2p.scribe.messaging.AbstractSubscribeMessage
The id of this subscribe message
id - Variable in class rice.p2p.scribe.messaging.SubscribeMessage
The id of this message
id - Variable in class rice.p2p.scribe.Topic
The Id to which this topic is mapped
id - Variable in class rice.p2p.splitstream.ChannelId
The underlying id for this channelid
id - Variable in class rice.p2p.splitstream.StripeId
This stripe's Id
id - Variable in class rice.pastry.rmi.RMINodeHandle
 
Id - interface rice.p2p.commonapi.Id.
 
Id - class rice.pastry.Id.
Represents a Pastry identifier for a node, object or key.
Id.Distance - interface rice.p2p.commonapi.Id.Distance.
A class for representing and manipulating the distance between two Ids on the circle.
Id.Distance - class rice.pastry.Id.Distance.
A class for representing and manipulating the distance between two Ids on the circle.
Id.Distance() - Constructor for class rice.pastry.Id.Distance
Constructor.
Id.Distance(byte[]) - Constructor for class rice.pastry.Id.Distance
Constructor.
Id.Distance(int[]) - Constructor for class rice.pastry.Id.Distance
Constructor.
Id() - Constructor for class rice.pastry.Id
Constructor.
Id(byte[]) - Constructor for class rice.pastry.Id
Constructor.
Id(int[]) - Constructor for class rice.pastry.Id
Constructor.
idBaseBitLength - Static variable in class rice.pastry.routing.RoutingTable
The routing calculations will occur in base 2 idBaseBitLength
IdBitLength - Static variable in class rice.pastry.Id
This is the bit length of the node ids.
idFactory - Variable in class rice.p2p.commonapi.testing.CommonAPITest
 
IdFactory - interface rice.p2p.commonapi.IdFactory.
 
IDLE_TIME - Static variable in class rice.scribe.testing.DistScribeRegrTest
 
IdRange - interface rice.p2p.commonapi.IdRange.
 
IdRange - class rice.pastry.IdRange.
Represents a contiguous range of Pastry ids.
IdRange() - Constructor for class rice.pastry.IdRange
Constructor, constructs an empty IdRange
IdRange(boolean) - Constructor for class rice.pastry.IdRange
 
IdRange(Id, Id) - Constructor for class rice.pastry.IdRange
Constructor.
IdRange(IdRange) - Constructor for class rice.pastry.IdRange
Copy constructor.
IdRangeUnit - class rice.pastry.testing.IdRangeUnit.
IdRangeUnit tests the IdRange class.
IdRangeUnit() - Constructor for class rice.pastry.testing.IdRangeUnit
 
IdSet - interface rice.p2p.commonapi.IdSet.
 
IdSet - class rice.pastry.IdSet.
Represents a set of Pastry ids.
IdSet() - Constructor for class rice.pastry.IdSet
Constructor.
IdSet(IdSet) - Constructor for class rice.pastry.IdSet
Copy constructor.
IdSet(TreeSet) - Constructor for class rice.pastry.IdSet
Constructor.
ifp(int) - Static method in class rice.pastry.Log
Called before every println, to check if verbosity levels are okay.
ImproperlyFormattedMessageException - exception rice.pastry.wire.exception.ImproperlyFormattedMessageException.
Class which represents an exception occuring during the parsing of a Pastry message sent through the Socket protocol.
ImproperlyFormattedMessageException(String) - Constructor for class rice.pastry.wire.exception.ImproperlyFormattedMessageException
Constructs an ImproperlyFormattedMessageException with a given message
incNumAcks() - Method in class rice.rm.testing.RMRegrTestApp.ReplicateEntry
 
inConcJoin - Variable in class rice.pastry.testing.PastryRegrTest
 
incrAttempt() - Method in class rice.rm.messaging.RMRequestKeysMsg
Since this message has a timeout mechanism, the next time we resend the message as a result of Timeout we need to increment the attempt number.
incrDistance(double) - Method in class rice.pastry.testing.PingMessageNew
 
incrementNumUnsubscribed(NodeId) - Static method in class rice.scribe.testing.DistScribeRegrTest
 
incrHops() - Method in class rice.pastry.testing.PingMessageNew
 
incrMissingCount() - Method in class rice.rm.testing.ObjectState
 
incrStaleCount() - Method in class rice.rm.testing.ObjectState
 
index - Static variable in class rice.pastry.rmi.RMINodeHandle
 
indexOf(NodeHandle) - Method in class rice.pastry.NodeSet
determine rank of a member
indexOfMSDB(Id) - Method in class rice.pastry.Id
Returns the index of the most significant differing bit (MSDB).
indexOfMSDD(Id, int) - Method in class rice.pastry.Id
Returns the index of the most significant different digit (MSDD) in a given base.
init(String[]) - Static method in class rice.pastry.Log
Called by Pastry applications to parse for verbosity options.
initialize() - Method in class rice.past.testing.DistPASTRegrTest
Deprecated. Sets up the environment for regression tests.
initialize() - Method in class rice.pastry.testing.ClosestRegrTest
initializes the network and prepares for testing
InitiateJoin - class rice.pastry.join.InitiateJoin.
Request for the join protocols on the local node to join the overlay.
InitiateJoin(Credentials, Date, NodeHandle) - Constructor for class rice.pastry.join.InitiateJoin
Constructor.
InitiateJoin(Credentials, NodeHandle) - Constructor for class rice.pastry.join.InitiateJoin
Constructor.
InitiateJoin(Date, NodeHandle) - Constructor for class rice.pastry.join.InitiateJoin
Constructor.
initiateJoin(NodeHandle) - Method in class rice.pastry.direct.DirectPastryNode
Sends an InitiateJoin message to itself.
initiateJoin(NodeHandle) - Method in class rice.pastry.dist.DistPastryNode
Sends an InitiateJoin message to itself.
initiateJoin(NodeHandle) - Method in class rice.pastry.multiring.MultiRingPastryNode
 
initiateJoin(NodeHandle) - Method in class rice.pastry.PastryNode
Overridden by derived classes to initiate the join process
InitiateJoin(NodeHandle) - Constructor for class rice.pastry.join.InitiateJoin
Constructor.
InitiateLeafSetMaintenance - class rice.pastry.leafset.InitiateLeafSetMaintenance.
Initiate leaf set maintenance on the local node.
InitiateLeafSetMaintenance() - Constructor for class rice.pastry.leafset.InitiateLeafSetMaintenance
Constructor.
initiateMaintenance() - Method in class rice.past.testing.DistPASTRegrTest
Deprecated. Initiates replica maintenance on all nodes
InitiateRouteSetMaintenance - class rice.pastry.routing.InitiateRouteSetMaintenance.
Initiate routing table maintenance on the local node
InitiateRouteSetMaintenance() - Constructor for class rice.pastry.routing.InitiateRouteSetMaintenance
Constructor.
insert(Id, Serializable, Continuation) - Method in interface rice.past.PASTService
Deprecated. Inserts an object with the given ID into distributed storage.
insert(Id, Serializable, Continuation) - Method in class rice.past.PASTServiceImpl
Deprecated. Inserts an object with the given ID into distributed storage.
insert(int, NodeHandle) - Method in class rice.pastry.NodeSet
insert a member at the given index
insert(PastContent, Continuation) - Method in interface rice.p2p.past.Past
Inserts an object with the given ID into this instance of Past.
insert(PastContent, Continuation) - Method in class rice.p2p.past.PastImpl
Inserts an object with the given ID into this instance of Past.
insert(Past, Continuation) - Method in class rice.p2p.past.ContentHashPastContent
Inserts this object into its associated Past instance.
insertionFreq - Static variable in class rice.rm.testing.DistRMRegrTestApp
 
InsertMessage - class rice.p2p.past.messaging.InsertMessage.
 
InsertMessage(int, PastContent, NodeHandle, Id) - Constructor for class rice.p2p.past.messaging.InsertMessage
Constructor which takes a unique integer Id, as well as the data to be stored
InsertMsg - class rice.rm.testing.InsertMsg.
 
InsertMsg(NodeHandle, Address, Id, Object, Credentials) - Constructor for class rice.rm.testing.InsertMsg
 
InsertResponseMsg - class rice.rm.testing.InsertResponseMsg.
 
InsertResponseMsg(NodeHandle, Address, Id, Credentials) - Constructor for class rice.rm.testing.InsertResponseMsg
Constructor : Builds a new RM Message
instance - Variable in class rice.pastry.client.PastryAppl
 
INSTANCE - Static variable in class rice.p2p.past.testing.PastRegrTest
 
INSTANCE - Static variable in class rice.p2p.scribe.testing.ScribeRegrTest
DESCRIBE THE FIELD
INSTANCE - Static variable in class rice.p2p.splitstream.testing.SplitStreamRegrTest
DESCRIBE THE FIELD
INSTANCE_NAME - Static variable in class rice.p2p.commonapi.testing.CommonAPITest
 
instance() - Static method in class rice.pastry.multiring.messaging.MultiRingApplAddress
Returns the single instance of MultiRingApplAddress.
instance() - Static method in class rice.pastry.multiring.testing.MultiRingPastryRegrTest.MultiRingTestAppAddress
 
intersect(IdRange) - Method in class rice.pastry.IdRange
intersect two ranges returns an empty range if the ranges don't intersect two ranges may intersect in two ranges on the circle; this method produces one such range of intersection if one exists the other range of intersection can be computed by invoking o.intersect(this)
inThread() - Method in class rice.pastry.wire.WirePastryNode
Checks whether the current thread is the execution thread.
InvariantCheckMsg - class rice.rm.testing.InvariantCheckMsg.
 
InvariantCheckMsg(NodeHandle, Address, Credentials) - Constructor for class rice.rm.testing.InvariantCheckMsg
Constructor
IPNodeIdFactory - class rice.pastry.standard.IPNodeIdFactory.
Constructs NodeIds for virtual nodes derived from the IP address and port number of this Java VM.
IPNodeIdFactory(int) - Constructor for class rice.pastry.standard.IPNodeIdFactory
Constructor.
isAdjacent(IdRange) - Method in class rice.pastry.IdRange
test if this range is adjacent to another range
isAlive() - Method in class rice.p2p.commonapi.NodeHandle
Returns whether or not this node is currently alive
isAlive() - Method in class rice.pastry.direct.DirectNodeHandle
Gets the Alive attribute of the DirectNodeHandle object
isAlive() - Method in class rice.pastry.dist.DistNodeHandle
Returns the last known liveness information about the Pastry node associated with this handle.
isAlive() - Method in class rice.pastry.NodeHandle
Returns the last known liveness information about the Pastry node associated with this handle.
isAlive() - Method in class rice.pastry.testing.LeafSetTest.TestNodeHandle
 
isAlive(NodeId) - Method in class rice.pastry.direct.EuclideanNetwork
testing if a NodeId is alive
isAlive(NodeId) - Method in interface rice.pastry.direct.NetworkSimulator
Checks to see if a node id is alive.
isAlive(NodeId) - Method in class rice.pastry.direct.SphereNetwork
testing if a NodeId is alive
isBetween(Id, Id) - Method in interface rice.p2p.commonapi.Id
Checks if this Id is between two given ids ccw (inclusive) and cw (exclusive) on the circle
isBetween(Id, Id) - Method in class rice.pastry.Id
Checks if this Id is between two given ids ccw (inclusive) and cw (exclusive) on the circle
isBetween(Id, Id) - Method in class rice.pastry.Id
Checks if this Id is between two given ids ccw (inclusive) and cw (exclusive) on the circle
isCached() - Method in class rice.p2p.past.messaging.FetchMessage
Returns whether or not this message has been cached
isCached() - Method in class rice.p2p.past.messaging.LookupMessage
Returns whether or not this message has been cached
isClosest(NodeId) - Method in class rice.pastry.client.PastryAppl
Called by the layered Pastry application to check if the local pastry node is the one that is currently closest to the object key id.
isClosest(NodeId) - Method in class rice.pastry.multiring.MultiRingPastryNode
 
isClosest(NodeId) - Method in class rice.pastry.PastryNode
Called by the layered Pastry application to check if the local pastry node is the one that is currently closest to the object key id.
IScribe - interface rice.scribe.IScribe.
 
IScribeApp - interface rice.scribe.IScribeApp.
 
IScribeObserver - interface rice.scribe.IScribeObserver.
 
IScribeSecurityManager - interface rice.scribe.security.IScribeSecurityManager.
The Scribe security manager interface.
isEmpty() - Method in class rice.pastry.IdRange
test if the range is empty
isEmpty() - Method in class rice.pastry.wire.SocketChannelWriter
Returns whether or not there are objects in the queue on in writing.
isFull() - Method in class rice.pastry.IdRange
test if the range is the full circle
isInPool - Variable in class rice.pastry.dist.DistNodeHandle
 
isLocal - Variable in class rice.pastry.dist.DistNodeHandle
 
isMember(Id) - Method in class rice.pastry.IdSet
test membership
isMemberId(Id) - Method in interface rice.p2p.commonapi.IdSet
test membership
isMemberId(Id) - Method in class rice.pastry.IdSet
test membership
isMissing() - Method in class rice.rm.testing.ObjectState
 
isMutable() - Method in class rice.p2p.past.ContentHashPastContent
States if this content object is mutable.
isMutable() - Method in interface rice.p2p.past.PastContent
States if this content object is mutable.
isMutable() - Method in class rice.p2p.past.testing.PastRegrTest.TestPastContent
 
isMutable() - Method in class rice.p2p.past.testing.PastRegrTest.NonMutableTestPastContent
 
isNewRoot(NodeId) - Method in class rice.pastry.multiring.MultiRingAppl
 
isNewRoot(NodeId) - Method in interface rice.scribe.IScribeApp
Upcall made by scribe to registered applications to inform them that local node is now the root for some topic, and hence can take appropriate action.
isNewRoot(NodeId) - Method in class rice.scribe.testing.BasicScribeRegrTestApp
Upcall by scribe to let this application know that it is the new root.
isNewRoot(NodeId) - Method in class rice.scribe.testing.DirectScribeMaintenanceTestApp
Upcall by scribe to let this application know that it is the new root.
isNewRoot(NodeId) - Method in class rice.scribe.testing.DistScribeRegrTestApp
Upcall by scribe to let this application know that it is the new root.
isPendingEvent(NodeId, int) - Method in class rice.rm.RMImpl
Used to check for existence of an entry in the m_pendingEvents hashtable
isPresent() - Method in class rice.rm.testing.ObjectState
 
isPrimary - Variable in class rice.p2p.splitstream.Stripe
A flag whether or not this stripe is the primary stripe for this node
isPrimary() - Method in class rice.p2p.splitstream.Stripe
Returns whether or not this stripe is the primary stripe for the local node
isReady() - Method in class rice.pastry.multiring.MultiRingPastryNode
 
isReady() - Method in class rice.pastry.PastryNode
 
isReady() - Method in class rice.rm.RMImpl
Returns true if the RM substrate is ready.
isReady() - Method in class rice.scribe.Scribe
Returns true is the Scribe substrate is ready.
isReallyAlive(NodeId) - Method in class rice.pastry.testing.DirectPastryRegrTest
get authoritative information about liveness of node.
isReallyAlive(NodeId) - Method in class rice.pastry.testing.DistPastryRegrTest
 
isReallyAlive(NodeId) - Method in class rice.pastry.testing.PastryRegrTest
determine whether this node is really alive.
isResponse - Variable in class rice.p2p.past.messaging.PastMessage
 
isResponse() - Method in class rice.p2p.past.messaging.PastMessage
Method which returns whether or not this message is a response.
isResponsible(IdRange) - Method in class rice.p2p.past.PastImpl
This upcall is to notify the application of the range of keys for which it is responsible.
isResponsible(IdRange) - Method in class rice.past.PASTServiceImpl
Deprecated. This upcall is to notify the application of the range of keys for which it is responsible.
isResponsible(IdRange) - Method in interface rice.rm.RMClient
This upcall is to notify the application of the range of keys for which it is responsible.
isResponsible(IdRange) - Method in class rice.rm.testing.RMRegrTestApp
 
isRoot() - Method in class rice.p2p.splitstream.Stripe
Utility method.
isRoot(NodeId) - Method in class rice.scribe.Scribe
Returns true if the local node is currently the root(the node that is closest to the topicId) of the topic.
isRoot(Topic) - Method in interface rice.p2p.scribe.Scribe
Returns whether or not this Scribe is the root for the given topic
isRoot(Topic) - Method in class rice.p2p.scribe.ScribeImpl
Returns whether or not this Scribe is the root for the given topic
isStale() - Method in class rice.rm.testing.ObjectState
 
isSubscribed() - Method in class rice.p2p.splitstream.Stripe
get the state of the Stripe
isTopicManager() - Method in class rice.scribe.Topic
Return boolean indicating if the node is topic manager for the current topic.
isWaitingUnsubscribe() - Method in class rice.scribe.Topic
Returns true if the local node is waiting to be unsubscribed from this topic.

J

join(NodeId) - Method in class rice.scribe.testing.BasicScribeRegrTestApp
direct call to scribe for subscribing to a topic from the current node.
join(NodeId) - Method in class rice.scribe.testing.DirectScribeMaintenanceTestApp
direct call to scribe for subscribing to a topic from the current node.
join(NodeId) - Method in class rice.scribe.testing.DistScribeRegrTestApp
direct call to scribe for subscribing to a topic from the current node.
join(NodeId, IScribeApp, Credentials) - Method in interface rice.scribe.IScribe
Joins a multicast group/topic.
join(NodeId, IScribeApp, Credentials) - Method in class rice.scribe.Scribe
Joins a multicast group/topic.
join(NodeId, IScribeApp, Credentials, Serializable) - Method in interface rice.scribe.IScribe
Joins a multicast group/topic.
join(NodeId, IScribeApp, Credentials, Serializable) - Method in class rice.scribe.Scribe
Joins a multicast group/topic.
join(NodeId, Serializable) - Method in class rice.scribe.testing.DirectScribeMaintenanceTestApp
direct call to scribe for subscribing to a topic from the current node.
JoinAddress - class rice.pastry.join.JoinAddress.
The address of the join receiver at a pastry node.
JoinAddress() - Constructor for class rice.pastry.join.JoinAddress
Constructor.
JoinAdvertise - Static variable in class rice.pastry.leafset.BroadcastLeafSet
 
joinData - Variable in class rice.scribe.testing.DirectScribeMaintenanceTestApp
 
joinFailed(Stripe) - Method in interface rice.p2p.splitstream.SplitStreamClient
This is a call back into the application to notify it that one of the stripes was unable to to find a parent, and thus unable to recieve data.
JOINING - Static variable in class rice.scribe.Topic
 
JoinInitial - Static variable in class rice.pastry.leafset.BroadcastLeafSet
 
joinNodes(int) - Method in class rice.rm.testing.DirectRMRegrTest
Creates the specified number of new nodes and joins them to the existing Pastry network.
joinNodes(int) - Method in class rice.scribe.testing.DirectScribeMaintenanceTest
Creates the specified number of new nodes and joins them to the existing Pastry network.
JoinRequest - class rice.pastry.join.JoinRequest.
Request to join this network.
JoinRequest(NodeHandle) - Constructor for class rice.pastry.join.JoinRequest
Constructor.
JoinRequest(NodeHandle, Credentials) - Constructor for class rice.pastry.join.JoinRequest
Constructor.
JoinRequest(NodeHandle, Credentials, Date) - Constructor for class rice.pastry.join.JoinRequest
Constructor.
JoinRequest(NodeHandle, Date) - Constructor for class rice.pastry.join.JoinRequest
Constructor.
joinRing(MultiRingPastryNode, NodeHandle) - Method in class rice.pastry.multiring.MultiRingPastryNodeFactory
 

K

kill() - Method in class rice.pastry.dist.DistPastryNode
Method which kills a PastryNode (used only for testing).
kill() - Method in class rice.pastry.rmi.RMIPastryNode
Testing purposes only!
kill() - Method in class rice.pastry.wire.SelectorManager
To be used for testing purposes only - kills the socket client by shutting down all outgoing sockets and stopping the client thread.
kill() - Method in class rice.pastry.wire.WirePastryNode
Method for simulating the death of this node.
kill(int) - Method in class rice.p2p.commonapi.testing.CommonAPITest
Method which kills the specified node
killNode(PastryNode) - Method in class rice.pastry.testing.DirectPastryRegrTest
murder the node.
killNode(PastryNode) - Method in class rice.pastry.testing.DistPastryRegrTest
 
killNode(PastryNode) - Method in class rice.pastry.testing.PastryRegrTest
kill a given node.

L

lastDist - Variable in class rice.pastry.testing.PastryRegrTest
 
lastMsg - Variable in class rice.pastry.testing.PastryRegrTest
 
lastNode - Variable in class rice.pastry.testing.PastryRegrTest
 
lastRow() - Method in class rice.pastry.join.JoinRequest
Returns the number of rows left to determine (in order).
LeafSet - class rice.pastry.leafset.LeafSet.
A class for representing and manipulating the leaf set.
leafSet() - Method in class rice.pastry.leafset.BroadcastLeafSet
Returns the leaf set that was broadcast.
LeafSet(NodeHandle, int) - Constructor for class rice.pastry.leafset.LeafSet
Constructor.
leafSetChange(NodeHandle, boolean) - Method in class rice.pastry.client.CommonAPIAppl
Called by pastry when the leaf set changes.
leafSetChange(NodeHandle, boolean) - Method in class rice.pastry.client.PastryAppl
Called by pastry when the leaf set changes.
leafSetChange(NodeHandle, boolean) - Method in class rice.pastry.commonapi.PastryEndpoint
 
leafSetChange(NodeHandle, boolean) - Method in class rice.pastry.testing.HelloWorldApp
Invoked upon change to leafset.
leafSetChange(NodeHandle, boolean) - Method in class rice.pastry.testing.Ping
 
leafSetChange(NodeHandle, boolean) - Method in class rice.pastry.testing.PingClient
 
leafSetChange(NodeHandle, boolean) - Method in class rice.scribe.Scribe
Called by pastry when the leaf set changes.
leafSetMaintFreq - Variable in class rice.pastry.dist.DistPastryNode
 
LeafSetProtocolAddress - class rice.pastry.leafset.LeafSetProtocolAddress.
The address of the leafset protocol at a pastry node.
LeafSetProtocolAddress() - Constructor for class rice.pastry.leafset.LeafSetProtocolAddress
Constructor.
LeafSetRequestMessage - class rice.pastry.wire.messaging.socket.LeafSetRequestMessage.
Message which represents a request to get the leafset from the remote node.
LeafSetRequestMessage() - Constructor for class rice.pastry.wire.messaging.socket.LeafSetRequestMessage
Constructor
LeafSetResponseMessage - class rice.pastry.wire.messaging.socket.LeafSetResponseMessage.
A response message to a LeafSetRequestMessage, containing the remote node's leafset.
LeafSetResponseMessage(LeafSet) - Constructor for class rice.pastry.wire.messaging.socket.LeafSetResponseMessage
Constructor
LeafSetTest - class rice.pastry.testing.LeafSetTest.
This class tests the correctness of the leafset in Pastry.
LeafSetTest.TestNodeHandle - class rice.pastry.testing.LeafSetTest.TestNodeHandle.
 
LeafSetTest.TestNodeHandle(NodeId) - Constructor for class rice.pastry.testing.LeafSetTest.TestNodeHandle
 
LeafSetTest() - Constructor for class rice.pastry.testing.LeafSetTest
 
leave(NodeId) - Method in class rice.scribe.testing.BasicScribeRegrTestApp
direct call to scribe for unsubscribing a topic from the current node The topic is chosen randomly if null is passed and topics exist.
leave(NodeId) - Method in class rice.scribe.testing.DirectScribeMaintenanceTestApp
direct call to scribe for unsubscribing a topic from the current node The topic is chosen randomly if null is passed and topics exist.
leave(NodeId) - Method in class rice.scribe.testing.DistScribeRegrTestApp
direct call to scribe for unsubscribing a topic from the current node The topic is chosen randomly if null is passed and topics exist.
leave(NodeId, IScribeApp, Credentials) - Method in interface rice.scribe.IScribe
Leaving a multicast group/topic.
leave(NodeId, IScribeApp, Credentials) - Method in class rice.scribe.Scribe
Leaving a multicast group/topic.
localhandle - Variable in class rice.pastry.PastryNode
 
localId - Variable in class rice.p2p.splitstream.Channel
The Id of the local node
localLookup(Id, int, boolean) - Method in interface rice.p2p.commonapi.Endpoint
This call produces a list of nodes that can be used as next hops on a route towards the given id, such that the resulting route satisfies the overlay protocol's bounds on the number of hops taken.
localLookup(Id, int, boolean) - Method in class rice.pastry.client.CommonAPIAppl
This method produces a list of nodes that can be used as next hops on a route towards key, such that the resulting route satisfies the overlay protocol's bounds on the number of hops taken.
localLookup(Id, int, boolean) - Method in class rice.pastry.commonapi.PastryEndpoint
This method produces a list of nodes that can be used as next hops on a route towards key, such that the resulting route satisfies the overlay protocol's bounds on the number of hops taken.
localnode - Variable in class rice.pastry.NodeHandle
 
LocalNode - class rice.pastry.LocalNode.
Implementation of the LocalNodeI interface that some Serializable classes (such as Certificate) extend, if they want to be kept informed of what node they're on.
LocalNode() - Constructor for class rice.pastry.LocalNode
 
LocalNodeI - interface rice.pastry.LocalNodeI.
Interface that some Serializable classes (such as NodeHandle and Certificate) implement, if they want to be kept informed of what node they're on.
localNodes - Variable in class rice.rm.testing.DistRMRegrTest
 
localNodes - Variable in class rice.scribe.testing.DistScribeRegrTest
 
LOCK - Static variable in class rice.scribe.testing.DistScribeRegrTest
 
log - Variable in class rice.p2p.past.PastImpl
 
log - Variable in class rice.p2p.scribe.ScribeImpl
the logger which we will use
Log - class rice.pastry.Log.
A fairly rudimentary Log class for the moment.
Log() - Constructor for class rice.pastry.Log
 
longDistance(Id) - Method in class rice.pastry.Id
Returns the longer numerical distance on the ring between a pair of Ids.
longDistanceFromId(Id) - Method in interface rice.p2p.commonapi.Id
Returns the longer numerical distance on the ring between a pair of Ids.
longDistanceFromId(Id) - Method in class rice.pastry.Id
Returns the longer numerical distance on the ring between a pair of Ids.
lookup(Id, Continuation) - Method in interface rice.p2p.past.Past
Retrieves the object stored in this instance of Past with the given ID.
lookup(Id, Continuation) - Method in class rice.p2p.past.PastImpl
Retrieves the object stored in this instance of Past with the given ID.
lookup(Id, Continuation) - Method in interface rice.past.PASTService
Deprecated. Retrieves the object and all associated updates with the given ID.
lookup(Id, Continuation) - Method in class rice.past.PASTServiceImpl
Deprecated. Retrieves the object and all associated updates with the given ID.
lookupForward(RouteMessage) - Method in interface rice.rm.RM
Called by client(RMClient) to enable optimizations to route to the nearest replica.
lookupForward(RouteMessage) - Method in class rice.rm.RMImpl
Called by client(RMClient) to enable optimizations to route to the nearest replica.
lookupHandles(Id, int, Continuation) - Method in interface rice.p2p.past.Past
Retrieves the handles of up to max replicas of the object stored in this instance of Past with the given ID.
lookupHandles(Id, int, Continuation) - Method in class rice.p2p.past.PastImpl
Retrieves the handles of up to max replicas of the object stored in this instance of Past with the given ID.
LookupHandlesMessage - class rice.p2p.past.messaging.LookupHandlesMessage.
 
LookupHandlesMessage(int, Id, int, NodeHandle, Id) - Constructor for class rice.p2p.past.messaging.LookupHandlesMessage
Constructor
LookupMessage - class rice.p2p.past.messaging.LookupMessage.
 
LookupMessage(int, Id, NodeHandle, Id) - Constructor for class rice.p2p.past.messaging.LookupMessage
Constructor
LRUCache - class rice.persistence.LRUCache.
This class is an encapsulation of a least-recently-used (LRU) cache.
LRUCache(Storage, int) - Constructor for class rice.persistence.LRUCache
Builds a LRU cache given a storage object to store the cached data in and a maximum cache size.
LRUCacheTest - class rice.persistence.testing.LRUCacheTest.
This class is a class which tests the Cache class in the rice.persistence package.
LRUCacheTest() - Constructor for class rice.persistence.testing.LRUCacheTest
Builds a MemoryStorageTest

M

m_ackOnSubscribeSwitch - Variable in class rice.scribe.Scribe
The AckOnSubscribe switch if true activates the immediate sending of ACK by a node when it receives a SUBSCRIBE message from its child for a topic.
m_address - Static variable in class rice.scribe.Scribe
The receiver address for the scribe system.
m_address - Static variable in class rice.scribe.testing.DistScribeRegrTestApp
The receiver address for the DistScribeApp system.
m_alreadySentHBNodes - Variable in class rice.scribe.Scribe
Optimization on number of HeartBeat Messages sent.
m_appCount - Variable in class rice.rm.testing.RMRegrTestApp
 
m_appCount - Variable in class rice.scribe.testing.DirectScribeMaintenanceTestApp
 
m_appCount - Static variable in class rice.scribe.testing.DistScribeRegrTestApp
 
m_appIndex - Variable in class rice.scribe.testing.DistScribeRegrTestApp
 
m_apps - Variable in class rice.scribe.Scribe
The set of IScribeApp's that have registered to this Scribe substrate.
m_apps - Variable in class rice.scribe.Topic
Set of IScribeApps that have subscribed to this Topic.
m_children - Variable in class rice.scribe.Topic
Set of NodeHandle objects for the local node's children in this topic's multicast subtree rooted at the local node.
m_credentials - Static variable in class rice.scribe.Scribe
The Credentials object to be used for all messaging through Pastry.
m_credentials - Static variable in class rice.scribe.testing.DistScribeRegrTestApp
The Credentials object to be used for all messaging through Pastry
m_distinctChildrenTable - Variable in class rice.scribe.Scribe
Hashtable having mapping from a child -> list of topics for which this child is in local node's children list for that topic.
m_distinctParentTable - Variable in class rice.scribe.Scribe
Hashtable having mapping from a parent node -> list of topics for which the parent node is local node's parent in the corresponding multicast tree for that topic.
m_driver - Variable in class rice.scribe.testing.DistScribeRegrTestApp
 
m_eId - Variable in class rice.rm.RMImpl
This is to keep track of events with respect to RMRequestKeysMsg only.
m_firstNodeInSystem - Variable in class rice.rm.testing.DistRMRegrTestApp
 
m_heartBeatsMissed - Variable in class rice.scribe.Topic
This keeps track of the number of heartbeat messages missed corresponding to this topic.
m_keys - Variable in class rice.rm.testing.RMRegrTestApp
 
m_lastDist - Variable in class rice.scribe.testing.BasicScribeRegrTest
 
m_lastMsg - Variable in class rice.scribe.testing.BasicScribeRegrTest
 
m_logTable - Variable in class rice.scribe.testing.DistScribeRegrTestApp
The hashtable maintaining mapping from topicId to log object maintained by this application for that topic.
m_maintainer - Variable in class rice.scribe.Scribe
The ScribeMaintainer object handles all the tree maintenance activities like the sending of heartbeat messages and issuing tree repair events for all the topics residing on the local node.
m_objectInsertionMsg - Variable in class rice.rm.testing.DistRMRegrTestApp
 
m_parent - Variable in class rice.scribe.Topic
Local node's parent in this topic's multicast tree
m_pastryNode - Variable in class rice.rm.testing.RMRegrTestApp
 
m_pastryNode - Variable in class rice.scribe.testing.DistScribeRegrTestApp
 
m_pendingEvents - Variable in class rice.rm.RMImpl
This table will be used by the Timeout mechanism in RMRequestKeysMsg.
m_pendingObjects - Variable in class rice.rm.testing.RMRegrTestApp
 
m_pendingRanges - Variable in class rice.rm.RMImpl
This hashtable is keyed by the NodeId of the node to whom this local node is requesting for a set of keys in the Keys Exchange protocol.
m_refreshedKeys - Variable in class rice.rm.testing.RMRegrTestApp
 
m_rm - Variable in class rice.rm.testing.RMRegrTestApp
 
m_rng - Variable in class rice.scribe.testing.DistScribeRegrTestApp
 
m_scribe - Variable in class rice.scribe.testing.DirectScribeMaintenanceTestApp
 
m_scribe - Variable in class rice.scribe.testing.DistScribeRegrTestApp
 
m_scribe - Variable in class rice.scribe.Topic
The scribe object on which this topic resides.
m_scribeMaintFreq - Static variable in class rice.scribe.Scribe
The time period determining Scribe Tree Maintenance Activity frequency
m_scribeObservers - Variable in class rice.scribe.Scribe
The set of applications which are interested in getting notified whenever the local node becomes an intermediate node for a topic.
m_securityManager - Variable in class rice.scribe.Scribe
Handles all the security verification.
m_sendOptions - Variable in class rice.scribe.Scribe
The SendOptions object to be used for all messaging through Pastry.
m_sendOptions - Variable in class rice.scribe.testing.DistScribeRegrTestApp
The SendOptions object to be used for all messaging through Pastry
m_seqno - Variable in class rice.rm.RMImpl
This will be incremented for every message that this node sends remotely.
m_source - Variable in class rice.scribe.messaging.ScribeMessage
The ID of the source of this message.
m_state - Variable in class rice.scribe.Topic
Current state of Topic.
m_topicId - Variable in class rice.scribe.messaging.ScribeMessage
The ID of the topic that this message refers to.
m_topicId - Variable in class rice.scribe.Topic
This topic's identifier
m_topicManager - Variable in class rice.scribe.Topic
Indicates whether this node is manager of this topic.
m_topics - Variable in class rice.scribe.Scribe
Set of topics on the local scribe node.
m_topics - Variable in class rice.scribe.testing.DistScribeRegrTestApp
 
m_wantUnsubscribe - Variable in class rice.scribe.Topic
Flag indicating if the local node is waiting to be unsubscribed (because it still does not know parent)
MAGIC_NUMBER - Static variable in class rice.pastry.wire.SocketChannelReader
 
MAGIC_NUMBER - Static variable in class rice.pastry.wire.SocketChannelWriter
 
main(String[]) - Static method in class rice.p2p.past.testing.PastRegrTest
Usage: DistPastTest [-port p] [-bootstrap host[:port]] [-nodes n] [-protocol (rmi|wire)] [-help]
main(String[]) - Static method in class rice.p2p.scribe.testing.ScribeRegrTest
Usage: DistScribeRegrTest [-port p] [-bootstrap host[:port]] [-nodes n] [-protocol (rmi|wire)] [-help]
main(String[]) - Static method in class rice.p2p.splitstream.testing.SplitStreamRegrTest
Usage: DistScribeRegrTest [-port p] [-bootstrap host[:port]] [-nodes n] [-protocol (rmi|wire)] [-help]
main(String[]) - Static method in class rice.past.testing.DistPASTRegrTest
Deprecated. Usage: DistPASTTest [-port p] [-bootstrap host[:port]] [-nodes n] [-protocol (rmi|wire)] [-help]
main(String[]) - Static method in class rice.pastry.multiring.testing.MultiRingPastryRegrTest
 
main(String[]) - Static method in class rice.pastry.testing.ClosestRegrTest
main
main(String[]) - Static method in class rice.pastry.testing.DirectPastryPingTest
 
main(String[]) - Static method in class rice.pastry.testing.DirectPastryRegrTest
main.
main(String[]) - Static method in class rice.pastry.testing.DistHelloWorld
Usage: DistHelloWorld [-msgs m] [-nodes n] [-port p] [-bootstrap bshost[:bsport]] [-verbose|-silent|-verbosity v] [-help].
main(String[]) - Static method in class rice.pastry.testing.DistPastryRegrTest
Usage: DistRegrPastryTest [-port p] [-protocol (wire|rmi)] [-nodes n] [-bootstrap host[:port]] [-help]
main(String[]) - Static method in class rice.pastry.testing.HelloWorld
Usage: HelloWorld [-msgs m] [-nodes n] [-verbose|-silent|-verbosity v] [-simultaneous_joins] [-simultaneous_msgs] [-help]
main(String[]) - Static method in class rice.pastry.testing.IdRangeUnit
 
main(String[]) - Static method in class rice.pastry.testing.LeafSetTest
 
main(String[]) - Static method in class rice.pastry.testing.NodeIdUnit
 
main(String[]) - Static method in class rice.pastry.testing.PastryTest
 
main(String[]) - Static method in class rice.persistence.testing.LRUCacheTest
 
main(String[]) - Static method in class rice.persistence.testing.MemoryStorageTest
 
main(String[]) - Static method in class rice.persistence.testing.PersistentStorageTest
 
main(String[]) - Static method in class rice.rm.testing.DirectRMRegrTest
 
main(String[]) - Static method in class rice.rm.testing.DistRMRegrTest
Usage: DistRMRegrTest [-nodes n] [-port p] [-bootstrap bshost[:bsport]] [-protocol [wire,rmi]] [-help].
main(String[]) - Static method in class rice.scribe.testing.DirectScribeRegrTest
 
main(String[]) - Static method in class rice.scribe.testing.DistScribeRegrTest
Usage: DistScribeRegrTest [-nodes n] [-port p] [-bootstrap bshost[:bsport]] [-protocol [wire,rmi]] [-help].
mainfunc(PastryRegrTest, String[], int, int, int, int, int) - Static method in class rice.pastry.testing.PastryRegrTest
main
maintainLeafSet() - Method in class rice.pastry.standard.StandardLeafSetProtocol
Maintain the leaf set.
maintFreq - Static variable in class rice.rm.messaging.RMMaintenanceMsg
The time interval between successive replica manager maintenance activities.
maintStart - Static variable in class rice.rm.messaging.RMMaintenanceMsg
The time offset after the RM substrate on the local node is ready when we first trigger the maintenance protocol.
makeAckOnSubscribeMessage(NodeId, Credentials) - Method in class rice.scribe.Scribe
Makes a AckOnSubscribe message using the current Pastry node as the source.
makeAckOnSubscribeMessage(NodeId, Credentials, Serializable) - Method in class rice.scribe.Scribe
Makes a AckOnSubscribe message using the current Pastry node as the source.
makeAnycastMessage(NodeId, Credentials) - Method in class rice.scribe.Scribe
Makes a anycast message using the current Pastry node as the source.
makeCreateMessage(NodeId, Credentials) - Method in class rice.scribe.Scribe
Makes a create message using the current Pastry node as the source.
makeHeartBeatMessage(Credentials) - Method in class rice.scribe.Scribe
Makes a heart-beat message using the current Pastry node as the source.
makeNoShortCuts() - Method in class rice.pastry.routing.SendOptions
Returns whether it is required for each routing step to go to a node whose id matches in exactly one more digit.
makePASTNode() - Method in class rice.past.testing.DistPASTRegrTest
Deprecated. Creates a pastryNode with a PASTService running on it.
makePastryNode() - Method in class rice.pastry.testing.HelloWorld
Create a Pastry node and add it to pastryNodes.
makePastryNode() - Method in class rice.pastry.testing.PastryTest
 
makePastryNode() - Method in class rice.pastry.testing.SinglePingTest
 
makePastryNode(boolean) - Method in class rice.pastry.testing.DistHelloWorld
Create a Pastry node and add it to pastryNodes.
makePublishMessage(NodeId, Credentials) - Method in class rice.scribe.Scribe
Makes a publish message using the current Pastry node as the source.
makeRandomId(Random) - Static method in class rice.pastry.Id
Creates a random Id.
makeReplyFromParentMessage(Credentials) - Method in class rice.scribe.Scribe
Makes a ReplyFromParent message using the current Pastry node as the source.
makeRequestToParentMessage(Credentials) - Method in class rice.scribe.Scribe
Makes a RequestToParent message using the current Pastry node as the source.
makeRMNode() - Method in class rice.rm.testing.DirectRMRegrTest
 
makeRMNode() - Method in class rice.rm.testing.DistRMRegrTest
Create a Pastry node and add it to pastryNodes.
makeScribeMaintenanceMessage(Credentials) - Method in class rice.scribe.Scribe
Makes a ScribeMaintenance message using the current Pastry node as the source.
makeScribeNode() - Method in class rice.scribe.testing.DirectScribeMaintenanceTest
 
makeScribeNode() - Method in class rice.scribe.testing.DistScribeRegrTest
Create a Pastry node and add it to pastryNodes.
makeScribeNode(int) - Method in class rice.scribe.testing.BasicScribeRegrTest
 
makeSubscribeMessage(NodeId, Credentials) - Method in class rice.scribe.Scribe
Makes a subscribe message using the current Pastry node as the source.
makeUnsubscribeMessage(NodeId, Credentials) - Method in class rice.scribe.Scribe
Makes an unsubscribe message using the current Pastry node as the source.
markAlive() - Method in class rice.pastry.dist.DistNodeHandle
Marks this handle as alive (if dead earlier), and reset distance to infinity.
markDead() - Method in class rice.pastry.dist.DistNodeHandle
Mark this handle as dead (if alive earlier), and reset distance to infinity.
MAX_FAILED_SUBSCRIPTION - Static variable in class rice.p2p.splitstream.Stripe
The maximum number of failed subscriptions
MAX_OPEN_SOCKETS - Static variable in class rice.pastry.wire.SocketManager
 
MAX_UDP_MESSAGE_SIZE - Static variable in class rice.pastry.wire.WireNodeHandle
 
MAXATTEMPTS - Static variable in class rice.rm.messaging.RMRequestKeysMsg
The maximum number of attempts made in the timeout mechanism after which the message is ignored.
maxChildren - Variable in class rice.p2p.scribe.ScribePolicy.LimitedScribePolicy
The number of children to allow per topic
MAXIMUM_QUEUE_LENGTH - Static variable in class rice.pastry.wire.SocketChannelWriter
 
MAXKEYSINRANGE - Static variable in class rice.rm.RMImpl
This value represents the maximum size of the keySet corresponding to a requested id range that we would like to fit in a single message.
maxMember() - Method in class rice.pastry.IdSet
return the largest member id
maxSize() - Method in class rice.pastry.leafset.LeafSet
Gets the maximal size of the leaf set.
member(NodeHandle) - Method in class rice.pastry.NodeSet
test membership
member(NodeId) - Method in class rice.pastry.leafset.LeafSet
Verifies if the set contains this particular id.
member(NodeId) - Method in class rice.pastry.leafset.SimilarSet
Verifies if the set contains this particular id.
member(NodeId) - Method in class rice.pastry.NodeSet
test membership using Id
member(NodeId) - Method in interface rice.pastry.NodeSetI
Verifies if the set contains this particular id.
member(NodeId) - Method in class rice.pastry.routing.RouteSet
Membership test.
memberHandle(Id) - Method in interface rice.p2p.commonapi.NodeHandleSet
Verifies if the set contains this particular id.
memberHandle(Id) - Method in class rice.pastry.leafset.SimilarSet
Verifies if the set contains this particular id.
memberHandle(Id) - Method in class rice.pastry.NodeSet
Verifies if the set contains this particular id.
memberHandle(Id) - Method in class rice.pastry.routing.RouteSet
Verifies if the set contains this particular id.
MemoryStorage - class rice.persistence.MemoryStorage.
This class is an implementation of Storage which provides in-memory storage.
MemoryStorage(IdFactory) - Constructor for class rice.persistence.MemoryStorage
Builds a MemoryStorage object.
MemoryStorageTest - class rice.persistence.testing.MemoryStorageTest.
This class is a class which tests the Storage class in the rice.persistence package.
MemoryStorageTest(boolean) - Constructor for class rice.persistence.testing.MemoryStorageTest
Builds a MemoryMemoryStorageTest
merge(IdRange) - Method in class rice.pastry.IdRange
merge two ranges if this and other don't overlap, are not adjacent, and this is not empty, then the result is this
merge(LeafSet, NodeHandle, RoutingTable, PastrySecurityManager, boolean, Set) - Method in class rice.pastry.leafset.LeafSet
Merge a remote leafset into this
mergeIntersectTest(IdRange, IdRange) - Method in class rice.pastry.testing.IdRangeUnit
 
mergeLeafSet(LeafSet, NodeHandle) - Method in class rice.pastry.standard.StandardLeafSetProtocol
Merge a remote leafset into our own
mergeTest(IdRange, IdRange) - Method in class rice.pastry.testing.IdRangeUnit
 
message - Variable in class rice.pastry.commonapi.PastryEndpointMessage
 
Message - interface rice.p2p.commonapi.Message.
 
Message - class rice.pastry.messaging.Message.
This is an abstract implementation of a message object.
MESSAGE_TIMEOUT - Static variable in class rice.p2p.past.PastImpl
 
MESSAGE_TIMEOUT - Static variable in class rice.p2p.scribe.ScribeImpl
the timeout for a subscribe message
Message(Address) - Constructor for class rice.pastry.messaging.Message
Constructor.
Message(Address, Credentials) - Constructor for class rice.pastry.messaging.Message
Constructor.
Message(Address, Credentials, Date) - Constructor for class rice.pastry.messaging.Message
Constructor.
Message(Address, Date) - Constructor for class rice.pastry.messaging.Message
Constructor.
MessageAckOnSubscribe - class rice.scribe.messaging.MessageAckOnSubscribe.
 
MessageAckOnSubscribe(Address, NodeHandle, NodeId, Credentials, Serializable) - Constructor for class rice.scribe.messaging.MessageAckOnSubscribe
Constructor
MessageAnycast - class rice.scribe.messaging.MessageAnycast.
MessageAnycast is used whenever a Scribe node wishes to anycast to a particular topic.
MessageAnycast(Address, NodeHandle, NodeId, Credentials) - Constructor for class rice.scribe.messaging.MessageAnycast
Constructor
MessageCreate - class rice.scribe.messaging.MessageCreate.
MessageCreate is used whenever a Scribe node wants to create a new topic.
MessageCreate(Address, NodeHandle, NodeId, Credentials) - Constructor for class rice.scribe.messaging.MessageCreate
Constructor.
MessageDispatch - class rice.pastry.messaging.MessageDispatch.
An object which remembers the mapping from names to MessageReceivers and dispatches messages by request.
MessageDispatch() - Constructor for class rice.pastry.messaging.MessageDispatch
Constructor.
MessageExists - class rice.past.messaging.MessageExists.
Deprecated. This version of PAST has been deprecated - please use the version located in the rice.p2p.past package.
MessageExists(Id, Id) - Constructor for class rice.past.messaging.MessageExists
Deprecated. Builds a new request to see if a file exists.
MessageFetch - class rice.past.messaging.MessageFetch.
Deprecated. This version of PAST has been deprecated - please use the version located in the rice.p2p.past package.
MessageFetch(Id, Id) - Constructor for class rice.past.messaging.MessageFetch
Deprecated. Builds a new request to lookup an existing file.
messageForAppl(Message) - Method in class rice.pastry.client.CommonAPIAppl
 
messageForAppl(Message) - Method in class rice.pastry.client.PastryAppl
Called by pastry when a message arrives for this application.
messageForAppl(Message) - Method in class rice.pastry.commonapi.PastryEndpoint
 
messageForAppl(Message) - Method in class rice.pastry.multiring.MultiRingAppl
 
messageForAppl(Message) - Method in class rice.pastry.testing.HelloWorldApp
Invoked on destination node when a message arrives.
messageForAppl(Message) - Method in class rice.pastry.testing.Ping
 
messageForAppl(Message) - Method in class rice.pastry.testing.PingClient
 
messageForAppl(Message) - Method in class rice.scribe.Scribe
Called by pastry when a message arrives for this client.
messageForAppl(Message) - Method in class rice.scribe.testing.DistScribeRegrTestApp
 
MessageHeartBeat - class rice.scribe.messaging.MessageHeartBeat.
HeartBeatMessage is used whenever a Scribe nodes wishes let its children know that it is still alive, so that the children need not do any repairing of the multicast tree.
MessageHeartBeat(Address, NodeHandle, Credentials) - Constructor for class rice.scribe.messaging.MessageHeartBeat
Constructor
MessageInsert - class rice.past.messaging.MessageInsert.
Deprecated. This version of PAST has been deprecated - please use the version located in the rice.p2p.past package.
MessageInsert(Id, Id, Serializable) - Constructor for class rice.past.messaging.MessageInsert
Deprecated. Builds a new request to insert a file.
MessageLookup - class rice.past.messaging.MessageLookup.
Deprecated. This version of PAST has been deprecated - please use the version located in the rice.p2p.past package.
MessageLookup(Id, Id) - Constructor for class rice.past.messaging.MessageLookup
Deprecated. Builds a new request to lookup an existing file.
MessageLostMessage - class rice.p2p.past.messaging.MessageLostMessage.
 
MessageLostMessage(int, NodeHandle) - Constructor for class rice.p2p.past.messaging.MessageLostMessage
Constructor which takes a unique integer Id and the local id
MessagePublish - class rice.scribe.messaging.MessagePublish.
MessagePublish is used whenever a Scribe nodes wishes to send events to a particular topic.
MessagePublish(Address, NodeHandle, NodeId, Credentials) - Constructor for class rice.scribe.messaging.MessagePublish
Constructor
MessageReceiver - interface rice.pastry.messaging.MessageReceiver.
An interface to an agent which can receive messages.
MessageReclaim - class rice.past.messaging.MessageReclaim.
Deprecated. This version of PAST has been deprecated - please use the version located in the rice.p2p.past package.
MessageReclaim(Id, Id) - Constructor for class rice.past.messaging.MessageReclaim
Deprecated. Builds a new request to reclaim space used by an existing file.
MessageReplyFromParent - class rice.scribe.messaging.MessageReplyFromParent.
MessageReplyFromParent is a message sent by the PARENT node to a node as a response to a MessageRequestToParent type of message.
MessageReplyFromParent(Address, NodeHandle, Credentials) - Constructor for class rice.scribe.messaging.MessageReplyFromParent
Constructor
MessageRequestToParent - class rice.scribe.messaging.MessageRequestToParent.
MessageRequestToParent is a message sent by a CHILD node to the PARENT requesting it for the list of topics for which the PARENT node has this node as a CHILD.
MessageRequestToParent(Address, NodeHandle, Credentials) - Constructor for class rice.scribe.messaging.MessageRequestToParent
Constructor
MessageScribeMaintenance - class rice.scribe.maintenance.MessageScribeMaintenance.
MessageScribeMaintenance is used by a Scribe node to initiate tree maintenance activities for the topics residing on the local node.
MessageScribeMaintenance(Address, NodeHandle, Credentials) - Constructor for class rice.scribe.maintenance.MessageScribeMaintenance
Constructor
MessageSubscribe - class rice.scribe.messaging.MessageSubscribe.
MessageSubscribe is used whenever a Scribe node wants to subscribe itself to a topic.
MessageSubscribe(Address, NodeHandle, NodeId, Credentials) - Constructor for class rice.scribe.messaging.MessageSubscribe
Constructor
MessageUnsubscribe - class rice.scribe.messaging.MessageUnsubscribe.
MessageUnsubscribe is used whenever a Scribe node wishes to unsubscribe from a topic.
MessageUnsubscribe(Address, NodeHandle, NodeId, Credentials) - Constructor for class rice.scribe.messaging.MessageUnsubscribe
Contructor
min(int, int) - Method in class rice.pastry.testing.LeafSetTest
 
minMember() - Method in class rice.pastry.IdSet
return the smallest member id
mostSimilar(Id) - Method in class rice.pastry.leafset.LeafSet
Numerically closests node to a given a node in the leaf set.
mostSimilar(Id) - Method in class rice.pastry.leafset.SimilarSet
Numerically closest node to a given a node.
msdTest() - Method in class rice.pastry.testing.NodeIdUnit
 
multicast(NodeId) - Method in class rice.scribe.testing.BasicScribeRegrTestApp
direct call to scribe for publishing to a topic from the current node.
multicast(NodeId) - Method in class rice.scribe.testing.DirectScribeMaintenanceTestApp
direct call to scribe for publishing to a topic from the current node.
multicast(NodeId, Serializable) - Method in class rice.scribe.testing.DistScribeRegrTestApp
direct call to scribe for publishing to a topic from the current node.
multicast(NodeId, Serializable, Credentials) - Method in interface rice.scribe.IScribe
Multicast information to a group/topic.
multicast(NodeId, Serializable, Credentials) - Method in class rice.scribe.Scribe
Multicast information to a group/topic.
multipleHopsAllowed() - Method in class rice.pastry.routing.SendOptions
Returns whether multiple hops are allowed during the transmission of this message.
MultiRingAppl - class rice.pastry.multiring.MultiRingAppl.
Class which represents a pastry node which is in multiple rings.
MultiRingAppl(MultiRingPastryNode) - Constructor for class rice.pastry.multiring.MultiRingAppl
Constructor
MultiRingApplAddress - class rice.pastry.multiring.messaging.MultiRingApplAddress.
The application address for MultiRingAppl.
MultiRingApplMessage - class rice.pastry.multiring.messaging.MultiRingApplMessage.
Super class for messages used in the multiring appl.
MultiRingApplMessage() - Constructor for class rice.pastry.multiring.messaging.MultiRingApplMessage
Constructor
MultiRingMessageDispatch - class rice.pastry.multiring.MultiRingMessageDispatch.
 
MultiRingMessageDispatch(MultiRingPastryNode, MessageDispatch) - Constructor for class rice.pastry.multiring.MultiRingMessageDispatch
 
MultiRingPastryNode - class rice.pastry.multiring.MultiRingPastryNode.
Class which represents a pastry node which is in multiple rings.
MultiRingPastryNode(PastryNode) - Constructor for class rice.pastry.multiring.MultiRingPastryNode
Which takes in the first "real" pastry node.
MultiRingPastryNodeFactory - class rice.pastry.multiring.MultiRingPastryNodeFactory.
This class represents a factory for MultiRing pastry nodes.
MultiRingPastryNodeFactory(PastryNodeFactory) - Constructor for class rice.pastry.multiring.MultiRingPastryNodeFactory
 
MultiRingPastryRegrTest - class rice.pastry.multiring.testing.MultiRingPastryRegrTest.
 
MultiRingPastryRegrTest.MultiRingTestAppAddress - class rice.pastry.multiring.testing.MultiRingPastryRegrTest.MultiRingTestAppAddress.
 
MultiRingPastryRegrTest.MultiRingTestAppMessage - class rice.pastry.multiring.testing.MultiRingPastryRegrTest.MultiRingTestAppMessage.
 
MultiRingPastryRegrTest.MultiRingTestAppMessage(RingNodeId) - Constructor for class rice.pastry.multiring.testing.MultiRingPastryRegrTest.MultiRingTestAppMessage
 
MultiRingPastryRegrTest() - Constructor for class rice.pastry.multiring.testing.MultiRingPastryRegrTest
 
myCode - Variable in class rice.pastry.standard.StandardAddress
 
myId - Variable in class rice.p2p.past.ContentHashPastContent
 
myNodeId - Variable in class rice.pastry.PastryNode
 
myRange - Variable in class rice.rm.RMImpl
This represents the range of object identifiers in the Id space for which this node (by virtue of its position in the Id Space relative to the positions of the other Pastry nodes) is an i-root (0<=i<=k).

N

name - Variable in class rice.Continuation.ListenerContinuation
The name of this continuation
NegOne - Static variable in class rice.pastry.Id
 
neighborSet(int) - Method in interface rice.p2p.commonapi.Endpoint
This methods returns an unordered set of nodehandles on which are neighbors of the local node in the id space.
neighborSet(int) - Method in class rice.pastry.client.CommonAPIAppl
This method produces an unordered list of nodehandles that are neighbors of the local node in the ID space.
neighborSet(int) - Method in class rice.pastry.commonapi.PastryEndpoint
This method produces an unordered list of nodehandles that are neighbors of the local node in the ID space.
neighborSet(int) - Method in class rice.pastry.leafset.LeafSet
compute an ordered set of nodes that are neighbors of this local node, in order of numerical closeness to the local node
NetworkSimulator - interface rice.pastry.direct.NetworkSimulator.
Interface to an object which is simulating the network.
neverAllowSubscribe - Variable in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribePolicy
 
neverAllowSubscribe(boolean) - Method in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribePolicy
 
newNode(NodeHandle) - Method in class rice.pastry.direct.DirectPastryNodeFactory
Manufacture a new Pastry node.
newNode(NodeHandle) - Method in class rice.pastry.dist.DistPastryNodeFactory
Generates a new pastry node with a random NodeId using the bootstrap bootstrap.
newNode(NodeHandle) - Method in class rice.pastry.multiring.MultiRingPastryNodeFactory
 
newNode(NodeHandle) - Method in class rice.pastry.PastryNodeFactory
Call this to construct a new node of the type chosen by the factory.
newNode(NodeHandle) - Method in class rice.pastry.rmi.RMIPastryNodeFactory
 
newNode(NodeHandle) - Method in class rice.pastry.wire.WirePastryNodeFactory
Method which creates a Pastry node from the next port with a randomly generated NodeId.
newNode(NodeHandle, NodeId) - Method in class rice.pastry.direct.DirectPastryNodeFactory
Manufacture a new Pastry node.
newNode(NodeHandle, NodeId) - Method in class rice.pastry.dist.DistPastryNodeFactory
Generates a new pastry node with the specified NodeId using the bootstrap bootstrap.
newNode(NodeHandle, NodeId) - Method in class rice.pastry.multiring.MultiRingPastryNodeFactory
 
newNode(NodeHandle, NodeId) - Method in class rice.pastry.PastryNodeFactory
Call this to construct a new node of the type chosen by the factory, with the given nodeId.
newNode(NodeHandle, NodeId) - Method in class rice.pastry.rmi.RMIPastryNodeFactory
Makes many policy choices and manufactures a new RMIPastryNode.
newNode(NodeHandle, NodeId) - Method in class rice.pastry.wire.WirePastryNodeFactory
Method which creates a Pastry node from the next port with a randomly generated NodeId.
newParent(NodeId, NodeHandle, Serializable) - Method in class rice.pastry.multiring.MultiRingAppl
 
newParent(NodeId, NodeHandle, Serializable) - Method in interface rice.scribe.IScribeApp
Upcall made by scribe to the registered applications to inform them that a new parent is found for local node in the topic tree.
newParent(NodeId, NodeHandle, Serializable) - Method in class rice.scribe.testing.BasicScribeRegrTestApp
Upcall by scribe to let this application know about local node's new parent in the topic tree
newParent(NodeId, NodeHandle, Serializable) - Method in class rice.scribe.testing.DirectScribeMaintenanceTestApp
Upcall by scribe to let this application know about local node's new parent in the topic tree
newParent(NodeId, NodeHandle, Serializable) - Method in class rice.scribe.testing.DistScribeRegrTestApp
Upcall by scribe to let this application know about local node's new parent in the topic tree
nextHop - Variable in class rice.pastry.routing.RouteMessage
 
nNodes - Variable in class rice.pastry.direct.TestRecord
 
node - Variable in class rice.p2p.splitstream.SplitStreamImpl
The node that this application is running on
Node - interface rice.p2p.commonapi.Node.
 
NodeHandle - class rice.p2p.commonapi.NodeHandle.
 
NodeHandle - class rice.pastry.NodeHandle.
Interface for handles to remote nodes.
NodeHandle() - Constructor for class rice.p2p.commonapi.NodeHandle
 
NodeHandle() - Constructor for class rice.pastry.NodeHandle
 
NodeHandleSet - interface rice.p2p.commonapi.NodeHandleSet.
 
nodeId - Variable in class rice.pastry.dist.DistNodeHandle
 
NodeId - class rice.pastry.NodeId.
Represents a Pastry identifier for a node.
NodeId() - Constructor for class rice.pastry.NodeId
Constructor.
NodeId(byte[]) - Constructor for class rice.pastry.NodeId
Constructor.
NodeId(int[]) - Constructor for class rice.pastry.NodeId
Constructor.
nodeIdBitLength - Static variable in class rice.pastry.NodeId
This is the bit length of the node ids.
NodeIdFactory - interface rice.pastry.NodeIdFactory.
An interface to any object capable of generating nodeIds.
NodeIdRequestMessage - class rice.pastry.wire.messaging.socket.NodeIdRequestMessage.
Message which represents a request to get a node Id from the remote node.
NodeIdRequestMessage() - Constructor for class rice.pastry.wire.messaging.socket.NodeIdRequestMessage
Constructor
NodeIdResponseMessage - class rice.pastry.wire.messaging.socket.NodeIdResponseMessage.
A response message to a NodeIdRequestMessage, containing the remote node's nodeId.
NodeIdResponseMessage(NodeId) - Constructor for class rice.pastry.wire.messaging.socket.NodeIdResponseMessage
Constructor
nodeIdToApp - Variable in class rice.rm.testing.DirectRMRegrTest
 
nodeIdToApp - Variable in class rice.scribe.testing.DirectScribeMaintenanceTest
 
NodeIdUnit - class rice.pastry.testing.NodeIdUnit.
NodeIdUnit tests the NodeId class.
NodeIdUnit() - Constructor for class rice.pastry.testing.NodeIdUnit
 
nodeIsReady() - Method in class rice.pastry.direct.DirectPastryNode
Called from PastryNode after the join succeeds.
nodeIsReady() - Method in class rice.pastry.dist.DistPastryNode
Called from PastryNode when the join succeeds.
nodeIsReady() - Method in class rice.pastry.multiring.MultiRingPastryNode
 
nodeIsReady() - Method in class rice.pastry.PastryNode
Overridden by derived classes, and invoked when the node has joined successfully.
nodeIsReady() - Method in class rice.pastry.rmi.RMIPastryNode
Called from PastryNode when the join succeeds, whereupon it rebinds the node into the RMI registry.
nodeIsReady() - Method in class rice.pastry.wire.WirePastryNode
 
nodes - Variable in class rice.p2p.commonapi.testing.CommonAPITest
 
NodeSet - class rice.pastry.NodeSet.
Represents an ordered set of NodeHandles.
NodeSet() - Constructor for class rice.pastry.NodeSet
Constructor.
NodeSet(NodeSet) - Constructor for class rice.pastry.NodeSet
Copy constructor.
NodeSet(Vector) - Constructor for class rice.pastry.NodeSet
Constructor.
NodeSetI - interface rice.pastry.NodeSetI.
An interface to a generic set of nodes.
NodeSetUpdate - class rice.pastry.NodeSetUpdate.
A class which stores changes to a node set.
NodeSetUpdate(NodeHandle, boolean) - Constructor for class rice.pastry.NodeSetUpdate
Constructor.
notifyObservers() - Method in class rice.pastry.dist.DistNodeHandle
 
notifyObservers(Object) - Method in class rice.pastry.direct.DirectNodeHandle
DESCRIBE THE METHOD
notifyObservers(Object) - Method in class rice.pastry.dist.DistNodeHandle
 
notifyReady() - Method in class rice.pastry.client.CommonAPIAppl
Invoked when the Pastry node has joined the overlay network and is ready to send and receive messages
notifyReady() - Method in class rice.pastry.client.PastryAppl
Invoked when the Pastry node has joined the overlay network and is ready to send and receive messages
notifyReady() - Method in class rice.pastry.testing.HelloWorldApp
Invoked by {RMI,Direct}PastryNode when the node has something in its leaf set, and has become ready to receive application messages.
notifyReady() - Method in class rice.pastry.testing.RegrTestApp
Invoked when the Pastry node has joined the overlay network and is ready to send and receive messages
notifyReady() - Method in class rice.rm.RMImpl
This is called when the underlying pastry node is ready.
notifyReady() - Method in class rice.scribe.Scribe
This is called when the underlying pastry node is ready.
notifyScribeObservers(NodeId) - Method in class rice.scribe.Scribe
Notifies the applications on top of scribe who are interested in knowing the events of implicit topic creation.
nTests - Variable in class rice.pastry.direct.TestRecord
 
Null - Static variable in class rice.pastry.Id
 
num - Variable in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribeContent
DESCRIBE THE FIELD
num - Variable in class rice.pastry.wire.messaging.datagram.DatagramMessage
 
num - Variable in class rice.scribe.testing.DistScribeRegrTest
 
NUM_ATTEMPTS - Static variable in class rice.pastry.rmi.RMIPastryNodeFactory
 
NUM_NODES - Static variable in class rice.p2p.commonapi.testing.CommonAPITest
 
NUM_NODES - Static variable in class rice.pastry.testing.ClosestRegrTest
 
NUM_TOPICS - Static variable in class rice.scribe.testing.DistScribeRegrTest
 
NUM_TRIALS - Static variable in class rice.pastry.testing.ClosestRegrTest
 
numChildren(NodeId) - Method in interface rice.scribe.IScribe
This returns the number of children in this topic's multicast subtree rooted at the local node.
numChildren(NodeId) - Method in class rice.scribe.Scribe
This returns the number of children in this topic's multicast subtree rooted at the local node.
numColumns() - Method in class rice.pastry.routing.RoutingTable
return ths number of columns in the routing table
numDigits(int) - Static method in class rice.pastry.Id
return the number of digits in a given base
numDigits(int) - Static method in class rice.pastry.multiring.RingId
return the number of digits in a given base
numElements() - Method in interface rice.p2p.commonapi.IdSet
return the number of elements
numElements() - Method in class rice.pastry.IdSet
return the number of elements
numObjects - Static variable in class rice.rm.testing.DistRMRegrTestApp
 
numObjectsInPeriod - Static variable in class rice.rm.testing.DistRMRegrTestApp
 
numRefreshed - Variable in class rice.rm.testing.DistRMRegrTestApp
 
numReplicated - Variable in class rice.rm.testing.DistRMRegrTestApp
 
numRows() - Method in class rice.pastry.join.JoinRequest
Get the number of rows.
numRows() - Method in class rice.pastry.routing.RoutingTable
return the number of rows in the routing table

O

ObjectInsertionMsg - class rice.rm.testing.ObjectInsertionMsg.
 
ObjectInsertionMsg(NodeHandle, Address, Credentials) - Constructor for class rice.rm.testing.ObjectInsertionMsg
Constructor
ObjectRefreshMsg - class rice.rm.testing.ObjectRefreshMsg.
 
ObjectRefreshMsg(NodeHandle, Address, Credentials) - Constructor for class rice.rm.testing.ObjectRefreshMsg
Constructor
ObjectState - class rice.rm.testing.ObjectState.
 
ObjectState(boolean, int, int) - Constructor for class rice.rm.testing.ObjectState
 
One - Static variable in class rice.pastry.Id
 
openSocket(WireNodeHandle) - Method in class rice.pastry.wire.SocketManager
Method which is designed to be called by node handles when they wish to open a socket to their remote node.
overlaps() - Method in class rice.pastry.leafset.LeafSet
Test if the leafset overlaps

P

PAD_SIZE - Static variable in class rice.p2p.commonapi.testing.CommonAPITest
 
PAD_SIZE - Static variable in class rice.persistence.testing.Test
 
parent - Variable in class rice.Continuation.StandardContinuation
The parent continuation
parent - Variable in class rice.p2p.scribe.ScribeImpl.TopicManager
DESCRIBE THE FIELD
parseArgs(String[]) - Static method in class rice.p2p.commonapi.testing.CommonAPITest
process command line args
Past - interface rice.p2p.past.Past.
 
PastContent - interface rice.p2p.past.PastContent.
 
PastContentHandle - interface rice.p2p.past.PastContentHandle.
 
PastException - exception rice.p2p.past.PastException.
 
PastException(String) - Constructor for class rice.p2p.past.PastException
Constructor.
PastImpl - class rice.p2p.past.PastImpl.
 
PastImpl(Node, StorageManager, int, String) - Constructor for class rice.p2p.past.PastImpl
Constructor for Past
PastMessage - class rice.p2p.past.messaging.PastMessage.
 
PASTMessage - class rice.past.messaging.PASTMessage.
Deprecated. This version of PAST has been deprecated - please use the version located in the rice.p2p.past package.
PASTMessage(Id, Id) - Constructor for class rice.past.messaging.PASTMessage
Deprecated. Constructor
PASTMessage(Id, Id, int) - Constructor for class rice.past.messaging.PASTMessage
Deprecated. Constructor
PastMessage(int, NodeHandle, Id) - Constructor for class rice.p2p.past.messaging.PastMessage
Constructor which takes a unique integer Id
PASTMessageID - interface rice.past.messaging.PASTMessageID.
Deprecated. This version of PAST has been deprecated - please use the version located in the rice.p2p.past package.
PASTMessageIDImpl - class rice.past.messaging.PASTMessageIDImpl.
Deprecated. This version of PAST has been deprecated - please use the version located in the rice.p2p.past package.
PastRegrTest - class rice.p2p.past.testing.PastRegrTest.
 
PastRegrTest.NonMutableTestPastContent - class rice.p2p.past.testing.PastRegrTest.NonMutableTestPastContent.
 
PastRegrTest.NonMutableTestPastContent(Id) - Constructor for class rice.p2p.past.testing.PastRegrTest.NonMutableTestPastContent
 
PastRegrTest.NonOverwritingTestPastContent - class rice.p2p.past.testing.PastRegrTest.NonOverwritingTestPastContent.
 
PastRegrTest.NonOverwritingTestPastContent(Id, int) - Constructor for class rice.p2p.past.testing.PastRegrTest.NonOverwritingTestPastContent
 
PastRegrTest.TestCommand - class rice.p2p.past.testing.PastRegrTest.TestCommand.
Common superclass for test commands.
PastRegrTest.TestCommand() - Constructor for class rice.p2p.past.testing.PastRegrTest.TestCommand
 
PastRegrTest.TestExceptionCommand - class rice.p2p.past.testing.PastRegrTest.TestExceptionCommand.
Common superclass for test commands which should throw an exception
PastRegrTest.TestExceptionCommand() - Constructor for class rice.p2p.past.testing.PastRegrTest.TestExceptionCommand
 
PastRegrTest.TestPastContent - class rice.p2p.past.testing.PastRegrTest.TestPastContent.
Utility class for past content objects
PastRegrTest.TestPastContent(Id) - Constructor for class rice.p2p.past.testing.PastRegrTest.TestPastContent
 
PastRegrTest.TestPastContentHandle - class rice.p2p.past.testing.PastRegrTest.TestPastContentHandle.
Utility class for past content object handles
PastRegrTest.TestPastContentHandle(Past, Id) - Constructor for class rice.p2p.past.testing.PastRegrTest.TestPastContentHandle
 
PastRegrTest.TestRouteMessage - class rice.p2p.past.testing.PastRegrTest.TestRouteMessage.
Utility class which simulates a route message
PastRegrTest.TestRouteMessage(Id, NodeHandle, Message) - Constructor for class rice.p2p.past.testing.PastRegrTest.TestRouteMessage
 
PastRegrTest.VersionedTestPastContent - class rice.p2p.past.testing.PastRegrTest.VersionedTestPastContent.
 
PastRegrTest.VersionedTestPastContent(Id, int) - Constructor for class rice.p2p.past.testing.PastRegrTest.VersionedTestPastContent
 
PastRegrTest() - Constructor for class rice.p2p.past.testing.PastRegrTest
Constructor which sets up all local variables
PastryAppl - class rice.pastry.client.PastryAppl.
A PastryAppl is an abstract class that every Pastry application extends.
PastryAppl(PastryNode) - Constructor for class rice.pastry.client.PastryAppl
Constructor.
PastryAppl(PastryNode, String) - Constructor for class rice.pastry.client.PastryAppl
Constructor.
PastryEndpoint - class rice.pastry.commonapi.PastryEndpoint.
This class serves as gluecode, which allows applications written for the common API to work with pastry.
PastryEndpoint(PastryNode, Application, String) - Constructor for class rice.pastry.commonapi.PastryEndpoint
Constructor.
PastryEndpointMessage - class rice.pastry.commonapi.PastryEndpointMessage.
This class is an internal message to the commonapi gluecode.
PastryEndpointMessage(Address, Message) - Constructor for class rice.pastry.commonapi.PastryEndpointMessage
Constructor.
PastryIdFactory - class rice.pastry.commonapi.PastryIdFactory.
This class provides applications with a way of genertating pastry Ids.
PastryIdFactory() - Constructor for class rice.pastry.commonapi.PastryIdFactory
Constructor
PastryNode - class rice.pastry.PastryNode.
A Pastry node is single entity in the pastry network.
PastryNode(NodeId) - Constructor for class rice.pastry.PastryNode
Constructor, with NodeId.
PastryNodeFactory - class rice.pastry.PastryNodeFactory.
The interface to an object which can construct PastryNodes.
PastryNodeFactory() - Constructor for class rice.pastry.PastryNodeFactory
 
pastryNodes - Variable in class rice.pastry.testing.PastryRegrTest
 
pastryNodesLastAdded - Variable in class rice.pastry.testing.PastryRegrTest
 
pastryNodesSorted - Variable in class rice.pastry.testing.PastryRegrTest
 
PastryRegrTest - class rice.pastry.testing.PastryRegrTest.
PastryRegrTest a regression test suite for pastry.
PastryRegrTest() - Constructor for class rice.pastry.testing.PastryRegrTest
constructor
PastrySecurityManager - interface rice.pastry.security.PastrySecurityManager.
The security manager interface.
PastrySeed - class rice.pastry.PastrySeed.
 
PastrySeed() - Constructor for class rice.pastry.PastrySeed
 
PastryTest - class rice.pastry.testing.PastryTest.
Pastry test.
PastryTest() - Constructor for class rice.pastry.testing.PastryTest
 
pasts - Variable in class rice.p2p.past.testing.PastRegrTest
 
PASTService - interface rice.past.PASTService.
Deprecated. This version of PAST has been deprecated - please use the version located in the rice.p2p.past package.
PASTServiceImpl - class rice.past.PASTServiceImpl.
Deprecated. This version of PAST has been deprecated - please use the version located in the rice.p2p.past package.
PASTServiceImpl(Node, StorageManager, String) - Constructor for class rice.past.PASTServiceImpl
Deprecated. Builds a new PASTService to run on the given PastryNode, given a Storage object (to persistedly store objects) and a cache used to cache objects.
pathToRoot - Variable in class rice.p2p.scribe.messaging.SubscribeAckMessage
The contained path to the root
pathToRoot - Variable in class rice.p2p.scribe.ScribeImpl.TopicManager
The current path to the root for this node
pause(int) - Method in class rice.p2p.commonapi.testing.CommonAPITest
Method which pauses for the provided number of milliseconds
pause(int) - Method in class rice.past.testing.DistPASTRegrTest
Deprecated.  
pause(int) - Method in class rice.pastry.multiring.testing.MultiRingPastryRegrTest
 
pause(int) - Method in class rice.pastry.rmi.RMIPastryNodeFactory
Pauses the current thread for ms milliseconds.
pause(int) - Method in class rice.pastry.testing.DirectPastryRegrTest
 
pause(int) - Method in class rice.pastry.testing.DistPastryRegrTest
 
pause(int) - Method in class rice.pastry.testing.PastryRegrTest
 
peekNext() - Method in class rice.p2p.scribe.messaging.AnycastMessage
Returns the next handle to visit
pending - Variable in class rice.p2p.past.PastImpl
 
pending - Static variable in interface rice.pastry.LocalNodeI
Refer to README.handles_localnode.
PendingLocalNodesList - class rice.pastry.PendingLocalNodesList.
Class which stores a list of LocalNodes waiting to have their local pastry node to be set non-null.
PendingLocalNodesList() - Constructor for class rice.pastry.PendingLocalNodesList
 
PendingWrite - class rice.pastry.wire.PendingWrite.
Wrapper class which contains an object to write and the address it needs to be written to.
PendingWrite(NodeId, InetSocketAddress, Object) - Constructor for class rice.pastry.wire.PendingWrite
Contructs a PendingWrite from an address and an object
performAction(PASTServiceImpl) - Method in class rice.past.messaging.MessageExists
Deprecated. Looks up the file in the given service's storage.
performAction(PASTServiceImpl) - Method in class rice.past.messaging.MessageFetch
Deprecated. Looks up the file in the given service's storage.
performAction(PASTServiceImpl) - Method in class rice.past.messaging.MessageInsert
Deprecated. Inserts this message's file into the service.
performAction(PASTServiceImpl) - Method in class rice.past.messaging.MessageLookup
Deprecated. Looks up the file in the given service's storage.
performAction(PASTServiceImpl) - Method in class rice.past.messaging.MessageReclaim
Deprecated. Reclaims the space in the service's storage.
performAction(PASTServiceImpl) - Method in class rice.past.messaging.PASTMessage
Deprecated. Performs this message's action after it is delivered.
periodicMaintenance() - Method in class rice.rm.RMImpl
This is the periodic maintenance protocol which removes stale objects as well as checks to see if there is any missing object.
periodicMaintenance() - Method in class rice.rm.testing.RMRegrTestApp
 
PermissiveCredentials - class rice.pastry.security.PermissiveCredentials.
Trivial credentials.
PermissiveCredentials() - Constructor for class rice.pastry.security.PermissiveCredentials
 
PermissiveSecurityManager - class rice.pastry.security.PermissiveSecurityManager.
A trivial security manager.
PermissiveSecurityManager() - Constructor for class rice.pastry.security.PermissiveSecurityManager
 
PersistentStorage - class rice.persistence.PersistentStorage.
This class is an implementation of Storage which provides persistent storage to disk.
PersistentStorage(IdFactory, String, int) - Constructor for class rice.persistence.PersistentStorage
Builds a PersistentStorage given a root directory in which to persist the data.
PersistentStorage(IdFactory, String, String, int) - Constructor for class rice.persistence.PersistentStorage
Builds a PersistentStorage given and an instance name and a root directoy in which to persist the data.
PersistentStorageTest - class rice.persistence.testing.PersistentStorageTest.
This class is a class which tests the PersistentStorage class in the rice.persistence package.
PersistentStorageTest(boolean) - Constructor for class rice.persistence.testing.PersistentStorageTest
Builds a MemoryStorageTest
Ping - class rice.pastry.testing.Ping.
Ping A performance test suite for pastry.
PING_THROTTLE - Static variable in class rice.pastry.wire.WireNodeHandle
 
ping() - Method in class rice.pastry.direct.DirectNodeHandle
DESCRIBE THE METHOD
ping() - Method in class rice.pastry.dist.DistNodeHandle
Ping the node.
ping() - Method in class rice.pastry.NodeHandle
Ping the node.
ping() - Method in class rice.pastry.testing.LeafSetTest.TestNodeHandle
 
Ping(PastryNode) - Constructor for class rice.pastry.testing.Ping
 
PingAddress - class rice.pastry.testing.PingAddress.
PingAddress A performance test suite for pastry.
PingAddress() - Constructor for class rice.pastry.testing.PingAddress
 
pingAllNew() - Method in class rice.pastry.routing.RouteSet
Pings all new nodes in the RouteSet.
PingClient - class rice.pastry.testing.PingClient.
A very simple ping object.
PingClient(PastryNode) - Constructor for class rice.pastry.testing.PingClient
 
pingImpl() - Method in class rice.pastry.dist.DistNodeHandle
Ping the node.
pingImpl() - Method in class rice.pastry.rmi.RMINodeHandle
Ping the remote node now, and update the proximity metric.
pingImpl() - Method in class rice.pastry.wire.WireNodeHandle
Ping the remote node now, and update the proximity metric.
PingMessage - class rice.pastry.wire.messaging.datagram.PingMessage.
Class which represents a "ping" message sent through the udp pastry system.
PingMessage(NodeId, NodeId, int, WireNodeHandle) - Constructor for class rice.pastry.wire.messaging.datagram.PingMessage
Constructor
PingMessageNew - class rice.pastry.testing.PingMessageNew.
PingMessageNew A performance test suite for pastry.
PingMessageNew(Address, NodeId, NodeId) - Constructor for class rice.pastry.testing.PingMessageNew
 
pingResponse() - Method in class rice.pastry.wire.WireNodeHandle
Method which is called by the SocketPingManager when a ping response comes back for this node.
pingStarted() - Method in class rice.pastry.wire.WireNodeHandle
Method which is called by the PingMessage right before it is going to be sent across the wire.
PingTestRecord - class rice.pastry.testing.PingTestRecord.
PingAddress A performance test suite for pastry.
PingTestRecord(int, int) - Constructor for class rice.pastry.testing.PingTestRecord
 
policies - Variable in class rice.p2p.scribe.testing.ScribeRegrTest
The scribe policies
policy - Variable in class rice.p2p.scribe.ScribeImpl
this scribe's policy
policy - Variable in class rice.p2p.splitstream.SplitStreamScribePolicy
A mapping from channelId -> maximum children
PORT - Static variable in class rice.p2p.commonapi.testing.CommonAPITest
 
postponeParentHandler() - Method in class rice.scribe.Topic
Resets the number of heartbeat messages corresponding to this topic to zero.
previousParent - Variable in class rice.p2p.scribe.messaging.SubscribeMessage
The previous parent
printPendingRanges(NodeId) - Method in class rice.rm.RMImpl
Prints the list of pending Ranges corresponding to a node that we are communicating to in the Keys Exchange Protocol.
printRange() - Method in class rice.rm.testing.RMRegrTestApp
 
processLog(NodeId, int) - Method in class rice.scribe.testing.DistScribeRegrTestApp
 
processMessage(Message) - Method in class rice.pastry.multiring.MultiRingPastryNode
 
processNode(int, Node) - Method in class rice.p2p.commonapi.testing.CommonAPITest
Method which should process the given newly-created node
processNode(int, Node) - Method in class rice.p2p.past.testing.PastRegrTest
Method which should process the given newly-created node
processNode(int, Node) - Method in class rice.p2p.scribe.testing.ScribeRegrTest
Method which should process the given newly-created node
processNode(int, Node) - Method in class rice.p2p.splitstream.testing.SplitStreamRegrTest
Method which should process the given newly-created node
protocol - Static variable in class rice.pastry.testing.DistHelloWorld
 
protocol - Static variable in class rice.rm.testing.DistRMRegrTest
 
protocol - Static variable in class rice.scribe.testing.DistScribeRegrTest
 
PROTOCOL - Static variable in class rice.p2p.commonapi.testing.CommonAPITest
 
PROTOCOL_DIRECT - Static variable in class rice.p2p.commonapi.testing.CommonAPITest
 
PROTOCOL_RMI - Static variable in class rice.pastry.dist.DistPastryNodeFactory
 
PROTOCOL_WIRE - Static variable in class rice.pastry.dist.DistPastryNodeFactory
 
PROXIMITY_CHANGED - Static variable in class rice.p2p.commonapi.NodeHandle
 
proximity() - Method in class rice.p2p.commonapi.NodeHandle
Returns the current proximity value of this node
proximity() - Method in class rice.pastry.direct.DirectNodeHandle
DESCRIBE THE METHOD
proximity() - Method in class rice.pastry.dist.DistNodeHandle
Returns the last known proximity information about the Pastry node associated with this handle.
proximity() - Method in class rice.pastry.NodeHandle
Returns the last known proximity information about the Pastry node associated with this handle.
proximity() - Method in class rice.pastry.testing.LeafSetTest.TestNodeHandle
 
proximity(NodeId, NodeId) - Method in class rice.pastry.direct.EuclideanNetwork
computes the proximity between two NodeIds
proximity(NodeId, NodeId) - Method in interface rice.pastry.direct.NetworkSimulator
Determines proximity between two nodes.
proximity(NodeId, NodeId) - Method in class rice.pastry.direct.SphereNetwork
computes the proximity between two NodeIds
PSecurityManager - class rice.scribe.security.PSecurityManager.
Implementation of a trivial security manager.
PSecurityManager() - Constructor for class rice.scribe.security.PSecurityManager
 
publish(byte[]) - Method in class rice.p2p.splitstream.Stripe
Publishes the given data to this stripe
publish(Topic, ScribeContent) - Method in interface rice.p2p.scribe.Scribe
Publishes the given message to the topic.
publish(Topic, ScribeContent) - Method in class rice.p2p.scribe.ScribeImpl
Publishes the given message to the topic.
PublishMessage - class rice.p2p.scribe.messaging.PublishMessage.
 
PublishMessage(NodeHandle, Topic, ScribeContent) - Constructor for class rice.p2p.scribe.messaging.PublishMessage
Constructor which takes a unique integer Id
publishMessages - Variable in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribeClient
The publish messages received so far
PublishRequestMessage - class rice.p2p.scribe.messaging.PublishRequestMessage.
 
PublishRequestMessage(NodeHandle, Topic, ScribeContent) - Constructor for class rice.p2p.scribe.messaging.PublishRequestMessage
Constructor which takes a unique integer Id
pushRow(RouteSet[]) - Method in class rice.pastry.join.JoinRequest
Push row.
put(NodeHandle) - Method in class rice.pastry.leafset.LeafSet
Puts a NodeHandle into the set.
put(NodeHandle) - Method in class rice.pastry.leafset.SimilarSet
Puts a NodeHandle into the set.
put(NodeHandle) - Method in class rice.pastry.NodeSet
Appends a member to the ordered set.
put(NodeHandle) - Method in interface rice.pastry.NodeSetI
Puts a NodeHandle into the set.
put(NodeHandle) - Method in class rice.pastry.routing.RouteSet
Puts a node into the set.
put(NodeHandle) - Method in class rice.pastry.routing.RoutingTable
Puts a handle into the routing table.
putHandle(NodeHandle) - Method in interface rice.p2p.commonapi.NodeHandleSet
Puts a NodeHandle into the set.
putHandle(NodeHandle) - Method in class rice.pastry.leafset.SimilarSet
Puts a NodeHandle into the set.
putHandle(NodeHandle) - Method in class rice.pastry.NodeSet
Puts a NodeHandle into the set.
putHandle(NodeHandle) - Method in class rice.pastry.routing.RouteSet
Puts a NodeHandle into the set.
putTopic(NodeId) - Method in class rice.scribe.testing.BasicScribeRegrTestApp
Let's the current node know about a topic created in the whole scribe network.

R

random - Variable in class rice.pastry.testing.LeafSetTest
 
RandomNodeIdFactory - class rice.pastry.standard.RandomNodeIdFactory.
Constructs random node ids by SHA'ing consecutive numbers, with random starting value.
RandomNodeIdFactory() - Constructor for class rice.pastry.standard.RandomNodeIdFactory
Constructor.
RandomRingNodeIdFactory - class rice.pastry.multiring.RandomRingNodeIdFactory.
Constructs random ring node ids by SHA'ing consecutive numbers, with random starting value.
RandomRingNodeIdFactory() - Constructor for class rice.pastry.multiring.RandomRingNodeIdFactory
 
RandomRingNodeIdFactory(RingId) - Constructor for class rice.pastry.multiring.RandomRingNodeIdFactory
 
range(NodeHandle, int) - Method in class rice.pastry.leafset.LeafSet
range computes the range of keys for which node n is a i-root, 0<=i<=r a node is the r-root for a key of the node becomes the numerically closest node to the key when i-roots for the key fail, O<=irange(NodeHandle, int, boolean) - Method in class rice.pastry.leafset.LeafSet
range computes the ranges of keys for which node n is a r-root a node is the r-root for a key of the node becomes the numerically closest node to the key when i-roots for the key fail, O<=irange(NodeHandle, int, Id) - Method in interface rice.p2p.commonapi.Endpoint
This operation provides information about ranges of keys for which the node is currently a rank-root.
range(NodeHandle, int, Id) - Method in class rice.pastry.client.CommonAPIAppl
This method provides information about ranges of keys for which the node n is currently a r-root.
range(NodeHandle, int, Id) - Method in class rice.pastry.commonapi.PastryEndpoint
This method provides information about ranges of keys for which the node n is currently a r-root.
range(NodeHandle, int, Id, boolean) - Method in class rice.pastry.client.CommonAPIAppl
This method provides information about ranges of keys for which the node n is currently a r-root.
range(NodeHandle, int, Id, boolean) - Method in class rice.pastry.commonapi.PastryEndpoint
This method provides information about ranges of keys for which the node n is currently a r-root.
read(SelectionKey) - Method in class rice.pastry.wire.DatagramManager
Specified by the SelectionKeyHandler interface - is called when there is a datagram ready to be read.
read(SelectionKey) - Method in interface rice.pastry.wire.SelectionKeyHandler
Method which is called when the key becomes readable.
read(SelectionKey) - Method in class rice.pastry.wire.SocketManager
Specified by the SelectionKeyHandler interface - is called whenever a key has data available.
read(SelectionKey) - Method in class rice.pastry.wire.WireNodeHandle
Called by the socket manager whenever there is data to be read from this node handle's remote node.
read(SocketChannel) - Method in class rice.pastry.wire.SocketChannelReader
Method which is to be called when there is data available on the specified SocketChannel.
receive(Object) - Method in class rice.p2p.past.testing.PastRegrTest.TestCommand
 
receive(Object) - Method in class rice.p2p.past.testing.PastRegrTest.TestExceptionCommand
 
receive(Object) - Method in class rice.past.testing.DistPASTRegrTest.TestCommand
Deprecated.  
receivedAck(AcknowledgementMessage) - Method in class rice.pastry.wire.DatagramTransmissionManager
Callback mechanism designed to be called when an ack packet is received.
receiveException(Exception) - Method in interface rice.Continuation
Called when an execption occured as a result of the previous command.
receiveException(Exception) - Method in class rice.Continuation.StandardContinuation
Called when an execption occured as a result of the previous command.
receiveException(Exception) - Method in class rice.Continuation.ListenerContinuation
Called when an execption occured as a result of the previous command.
receiveException(Exception) - Method in class rice.Continuation.ExternalContinuation
 
receiveException(Exception) - Method in class rice.p2p.past.messaging.ContinuationMessage
Method which builds a response for this message, using the provided exception, which was thrown
receiveException(Exception) - Method in class rice.p2p.past.testing.PastRegrTest.TestCommand
 
receiveException(Exception) - Method in class rice.p2p.past.testing.PastRegrTest.TestExceptionCommand
 
receiveException(Exception) - Method in class rice.past.testing.DistPASTRegrTest.TestCommand
Deprecated.  
receiveMessage(Message) - Method in class rice.pastry.client.CommonAPIAppl
Called by pastry to deliver a message to this client.
receiveMessage(Message) - Method in class rice.pastry.client.PastryAppl
Called by pastry to deliver a message to this client.
receiveMessage(Message) - Method in class rice.pastry.commonapi.PastryEndpoint
Called by pastry to deliver a message to this client.
receiveMessage(Message) - Method in class rice.pastry.direct.DirectNodeHandle
DESCRIBE THE METHOD
receiveMessage(Message) - Method in class rice.pastry.dist.DistNodeHandle
Called to send a message to the node corresponding to this handle.
receiveMessage(Message) - Method in interface rice.pastry.messaging.MessageReceiver
Passes a message along to entity which is this message receiver.
receiveMessage(Message) - Method in class rice.pastry.multiring.MultiRingPastryNode
 
receiveMessage(Message) - Method in class rice.pastry.PastryNode
message receiver interface.
receiveMessage(Message) - Method in class rice.pastry.standard.StandardJoinProtocol
Receives a message from the outside world.
receiveMessage(Message) - Method in class rice.pastry.standard.StandardLeafSetProtocol
Receives messages.
receiveMessage(Message) - Method in class rice.pastry.standard.StandardRouter
Receive a message from a remote node.
receiveMessage(Message) - Method in class rice.pastry.standard.StandardRouteSetProtocol
Receives a message.
receiveMessage(Message) - Method in class rice.pastry.testing.LeafSetTest.TestNodeHandle
 
receiveMessage(ScribeMessage) - Method in class rice.pastry.multiring.MultiRingAppl
 
receiveMessage(ScribeMessage) - Method in interface rice.scribe.IScribeApp
Called by Scribe when a multicast message arrives.
receiveMessage(ScribeMessage) - Method in class rice.scribe.testing.BasicScribeRegrTestApp
up-call invoked by scribe when a publish message is 'delivered'.
receiveMessage(ScribeMessage) - Method in class rice.scribe.testing.DirectScribeMaintenanceTestApp
up-call invoked by scribe when a publish message is 'delivered'.
receiveMessage(ScribeMessage) - Method in class rice.scribe.testing.DistScribeRegrTestApp
up-call invoked by scribe when a publish message is 'delivered'.
receiveMessageImpl(Message) - Method in class rice.pastry.dist.DistNodeHandle
Called to send a message to the node corresponding to this handle.
receiveMessageImpl(Message) - Method in class rice.pastry.rmi.RMINodeHandle
Called to send a message to the node corresponding to this handle.
receiveMessageImpl(Message) - Method in class rice.pastry.wire.WireNodeHandle
Called to send a message to the node corresponding to this handle.
receiveResult(Object) - Method in interface rice.Continuation
Called when a previously requested result is now availble.
receiveResult(Object) - Method in class rice.Continuation.ListenerContinuation
Called when a previously requested result is now availble.
receiveResult(Object) - Method in class rice.Continuation.ExternalContinuation
 
receiveResult(Object) - Method in class rice.p2p.past.messaging.ContinuationMessage
Method which builds a response for this message, using the provided object as a result.
receiveResult(Object) - Method in class rice.p2p.past.testing.PastRegrTest.TestCommand
 
receiveResult(Object) - Method in class rice.p2p.past.testing.PastRegrTest.TestExceptionCommand
 
receiveResult(Object) - Method in class rice.past.testing.DistPASTRegrTest.TestCommand
Deprecated.  
receiveRouteMessage(RouteMessage) - Method in class rice.pastry.standard.StandardRouter
Receive and process a route message.
receiveSocketMessage(SocketCommandMessage) - Method in class rice.pastry.wire.WireNodeHandle
Method which is called when a SocketCommandMessage comes across an open socket for this node handle.
refresh(Id) - Method in class rice.rm.testing.RMRegrTestApp
 
refreshFreq - Static variable in class rice.rm.testing.DistRMRegrTestApp
 
RefreshMsg - class rice.rm.testing.RefreshMsg.
 
RefreshMsg(NodeHandle, Address, Id, Credentials) - Constructor for class rice.rm.testing.RefreshMsg
 
refreshStart - Static variable in class rice.rm.testing.DistRMRegrTestApp
 
registerApp(IScribeApp) - Method in interface rice.scribe.IScribe
Registers the IScribeApp to the Scribe substrate.
registerApp(IScribeApp) - Method in class rice.scribe.Scribe
Registers the IScribeApp to the Scribe substrate.
registerApp(PastryAppl) - Method in class rice.pastry.multiring.MultiRingPastryNode
 
registerApp(PastryAppl) - Method in class rice.pastry.PastryNode
Registers an application with this pastry node.
registerapp(PastryNode, RegrTestApp) - Method in class rice.pastry.testing.DirectPastryRegrTest
wire protocol specific handling of the application object e.g., RMI may launch a new thread
registerapp(PastryNode, RegrTestApp) - Method in class rice.pastry.testing.DistPastryRegrTest
wire protocol specific handling of the application object e.g., RMI may launch a new thread
registerapp(PastryNode, RegrTestApp) - Method in class rice.pastry.testing.PastryRegrTest
wire protocol specific handling of the application object e.g., RMI may launch a new thread
registerApplication(Application, String) - Method in interface rice.p2p.commonapi.Node
This returns a VirtualizedNode specific to the given application and instance name to the application, which the application can then use in order to send an receive messages.
registerApplication(Application, String) - Method in class rice.pastry.PastryNode
This returns a VirtualizedNode specific to the given application and instance name to the application, which the application can then use in order to send an receive messages.
registerKey(Id) - Method in interface rice.rm.RM
Called by client(RMClient) to notify the RM substrate of the presence of a key corresponding to a object that was 'recently' inserted at itself.
registerKey(Id) - Method in class rice.rm.RMImpl
Called by client(RMClient) to notify the RM substrate of the presence of a key corresponding to a object that was 'recently' inserted at itself.
registerNodeId(DirectNodeHandle) - Method in class rice.pastry.direct.EuclideanNetwork
register a new node
registerNodeId(DirectNodeHandle) - Method in interface rice.pastry.direct.NetworkSimulator
Registers a node handle with the simulator.
registerNodeId(DirectNodeHandle) - Method in class rice.pastry.direct.SphereNetwork
register a new node
registerReceiver(Address, MessageReceiver) - Method in class rice.pastry.messaging.MessageDispatch
Registers a receiver with the mail service.
registerReceiver(Address, MessageReceiver) - Method in class rice.pastry.multiring.MultiRingMessageDispatch
 
registerReceiver(Credentials, Address, MessageReceiver) - Method in class rice.pastry.client.PastryAppl
Registers a message receiver with the pastry node.
registerReceiver(Credentials, Address, MessageReceiver) - Method in class rice.pastry.multiring.MultiRingPastryNode
 
registerReceiver(Credentials, Address, MessageReceiver) - Method in class rice.pastry.PastryNode
Registers a message receiver with this Pastry node.
registerScribeObserver(IScribeObserver) - Method in interface rice.scribe.IScribe
Registers the application that implements the IScribeObserver interface.
registerScribeObserver(IScribeObserver) - Method in class rice.scribe.Scribe
Registers the application that implements the IScribeObserver interface.
RegrTestApp - class rice.pastry.testing.RegrTestApp.
RegrTestApp A regression test suite for pastry.
RegrTestApp(PastryNode, PastryRegrTest) - Constructor for class rice.pastry.testing.RegrTestApp
 
REMINDER_TIMEOUT - Static variable in class rice.pastry.multiring.MultiRingAppl
 
remoteReceiveMessage(Message, NodeId) - Method in class rice.pastry.rmi.RMIPastryNode
Proxies to the local node to accept a message.
remoteReceiveMessage(Message, NodeId) - Method in interface rice.pastry.rmi.RMIRemoteNodeI
 
remove(Id) - Method in class rice.rm.testing.RMRegrTestApp
 
remove(int) - Method in class rice.pastry.leafset.SimilarSet
Removes a node id and its handle from the set.
remove(int) - Method in class rice.pastry.NodeSet
remove a member at a given position
remove(NodeHandle) - Method in class rice.p2p.scribe.messaging.AnycastMessage
Removes the node handle from the to visit and visited lists
remove(NodeHandle) - Method in class rice.pastry.NodeSet
remove a member
remove(NodeId) - Method in class rice.pastry.leafset.LeafSet
Removes a node id and its handle from the set.
remove(NodeId) - Method in class rice.pastry.leafset.SimilarSet
Removes a node id and its handle from the set.
remove(NodeId) - Method in class rice.pastry.NodeSet
Removes a node id and its handle from the set.
remove(NodeId) - Method in interface rice.pastry.NodeSetI
Removes a node id and its handle from the set.
remove(NodeId) - Method in class rice.pastry.routing.RouteSet
Removes a node from a set.
remove(NodeId) - Method in class rice.pastry.routing.RoutingTable
Removes a node id from the table.
removeChild(NodeHandle) - Method in class rice.p2p.scribe.ScribeImpl.TopicManager
DESCRIBE THE METHOD
removeChild(NodeHandle, NodeId) - Method in interface rice.scribe.IScribe
Removes a node as a child from the children table for a topic.
removeChild(NodeHandle, NodeId) - Method in class rice.scribe.Scribe
Removes a node as a child from the children table for a topic.
removeChild(NodeHandle, ScribeMessage) - Method in class rice.scribe.Topic
Removes a node from the Set of children in this topic's multicast subtree rooted at this node
removeChild(Topic, NodeHandle) - Method in interface rice.p2p.scribe.Scribe
Removes a child from the given topic
removeChild(Topic, NodeHandle) - Method in class rice.p2p.scribe.ScribeImpl
Removes a child from the given topic
removeChild(Topic, NodeHandle, boolean) - Method in class rice.p2p.scribe.ScribeImpl
Removes a child from the given topic
removeChildForTopic(NodeHandle, NodeId) - Method in class rice.scribe.Scribe
Removes a child for a topic from the distinctChildrenTable.
removeClient(ScribeClient) - Method in class rice.p2p.scribe.ScribeImpl.TopicManager
DESCRIBE THE METHOD
removeFromScribe() - Method in class rice.scribe.Topic
Removes this topic reference on the current Scribe node.
removeHandle(Id) - Method in interface rice.p2p.commonapi.NodeHandleSet
Removes a node id and its handle from the set.
removeHandle(Id) - Method in class rice.pastry.leafset.SimilarSet
Removes a node id and its handle from the set.
removeHandle(Id) - Method in class rice.pastry.NodeSet
Removes a node id and its handle from the set.
removeHandle(Id) - Method in class rice.pastry.routing.RouteSet
Removes a node id and its handle from the set.
removeId(Id) - Method in interface rice.p2p.commonapi.IdSet
remove a member
removeId(Id) - Method in class rice.pastry.IdSet
remove a member
removeMember(Id) - Method in class rice.pastry.IdSet
remove a member
removeParentForTopic(NodeHandle, NodeId) - Method in class rice.scribe.Scribe
Removes a parent for a topic fromthe distinctParentTable.
removePendingEvent(NodeId, int) - Method in class rice.rm.RMImpl
Used to remove entries to the m_pendingEvents hashtable
removePendingObject(Id) - Method in class rice.rm.testing.RMRegrTestApp
 
removePendingRange(NodeId, IdRange) - Method in class rice.rm.RMImpl
Used to remove a pending range to the m_pendingRanges hashtable
replicaManager - Variable in class rice.p2p.past.PastImpl
 
replicaSet(Id, int) - Method in interface rice.p2p.commonapi.Endpoint
This methods returns an ordered set of nodehandles on which replicas of an object with a given id can be stored.
replicaSet(Id, int) - Method in class rice.pastry.client.CommonAPIAppl
This method returns an ordered set of nodehandles on which replicas of the object with key can be stored.
replicaSet(Id, int) - Method in class rice.pastry.commonapi.PastryEndpoint
This method returns an ordered set of nodehandles on which replicas of the object with key can be stored.
replicaSet(Id, int) - Method in class rice.pastry.leafset.LeafSet
compute an ordered set of nodes, in order of numerical closeness to a given key
replicate(Id) - Method in class rice.rm.testing.RMRegrTestApp
Called by the application when it needs to replicate an object into k nodes closest to the object key.
ReplicateMsg - class rice.rm.testing.ReplicateMsg.
 
ReplicateMsg(NodeHandle, Address, Id, Credentials) - Constructor for class rice.rm.testing.ReplicateMsg
 
ReplicateResponseMsg - class rice.rm.testing.ReplicateResponseMsg.
 
ReplicateResponseMsg(NodeHandle, Address, Id, NodeSet, Credentials) - Constructor for class rice.rm.testing.ReplicateResponseMsg
Constructor : Builds a new RM Message
replicateSuccess(Id, boolean) - Method in class rice.rm.testing.RMRegrTestApp
 
ReplicateTimeoutMsg - class rice.rm.testing.ReplicateTimeoutMsg.
 
ReplicateTimeoutMsg(NodeHandle, Address, Id, Credentials) - Constructor for class rice.rm.testing.ReplicateTimeoutMsg
Constructor
REPLICATION_FACTOR - Static variable in class rice.p2p.past.testing.PastRegrTest
 
replicationFactor - Variable in class rice.p2p.past.PastImpl
 
REQUEST - Static variable in class rice.past.messaging.PASTMessage
Deprecated.  
RequestLeafSet - class rice.pastry.leafset.RequestLeafSet.
Request a leaf set from another node.
RequestLeafSet(Credentials, Date, NodeHandle) - Constructor for class rice.pastry.leafset.RequestLeafSet
Constructor.
RequestLeafSet(Credentials, NodeHandle) - Constructor for class rice.pastry.leafset.RequestLeafSet
Constructor.
RequestLeafSet(Date, NodeHandle) - Constructor for class rice.pastry.leafset.RequestLeafSet
Constructor.
RequestLeafSet(NodeHandle) - Constructor for class rice.pastry.leafset.RequestLeafSet
Constructor.
RequestRouteRow - class rice.pastry.routing.RequestRouteRow.
Request a row from the routing table from another node.
RequestRouteRow(Credentials, Date, NodeHandle, int) - Constructor for class rice.pastry.routing.RequestRouteRow
Constructor.
RequestRouteRow(Credentials, NodeHandle, int) - Constructor for class rice.pastry.routing.RequestRouteRow
Constructor.
RequestRouteRow(Date, NodeHandle, int) - Constructor for class rice.pastry.routing.RequestRouteRow
Constructor.
RequestRouteRow(NodeHandle, int) - Constructor for class rice.pastry.routing.RequestRouteRow
Constructor.
requireShortestPath() - Method in class rice.pastry.routing.SendOptions
Returns whether it is required to go to the strictly nearest known node with appropriate node id.
reset() - Method in class rice.pastry.wire.SocketChannelReader
Resets this input stream so that it is ready to read another object off of the queue.
reset(SocketCommandMessage) - Method in class rice.pastry.wire.SocketChannelWriter
Resets the SocketChannelWriter, by clearing both the buffer and the queue.
resetAckNumber(NodeId) - Method in class rice.pastry.wire.DatagramManager
Designed to be called by a node handle when a socket is open in order to reset the seqence number of UDP.
resetAckNumber(NodeId) - Method in class rice.pastry.wire.DatagramTransmissionManager
Resets the sequence number for the specified node
response - Variable in class rice.p2p.past.messaging.ContinuationMessage
 
RESPONSE - Static variable in class rice.past.messaging.PASTMessage
Deprecated.  
result - Variable in class rice.Continuation.ExternalContinuation
 
returnHandle() - Method in class rice.pastry.leafset.RequestLeafSet
The return handle for the message
returnHandle() - Method in class rice.pastry.routing.RequestRouteRow
The return handle for the message
returnResponse(Continuation) - Method in class rice.p2p.past.messaging.CacheMessage
Method by which this message is supposed to return it's response.
returnResponse(Continuation) - Method in class rice.p2p.past.messaging.ContinuationMessage
Method by which this message is supposed to return it's response.
returnResponse(Continuation) - Method in class rice.p2p.past.messaging.MessageLostMessage
Method by which this message is supposed to return it's response - in this case, it lets the continuation know that a the message was lost via the receiveException method.
returnResponse(Continuation) - Method in class rice.p2p.past.messaging.PastMessage
Method by which this message is supposed to return it's response.
rFactor - Variable in class rice.rm.RMImpl
rFactor stands for the number of additional replicas for an object.
rFactor - Static variable in class rice.rm.testing.RMRegrTestApp
 
rice - package rice
 
rice.p2p.commonapi - package rice.p2p.commonapi
 
rice.p2p.commonapi.testing - package rice.p2p.commonapi.testing
 
rice.p2p.past - package rice.p2p.past
 
rice.p2p.past.messaging - package rice.p2p.past.messaging
 
rice.p2p.past.testing - package rice.p2p.past.testing
 
rice.p2p.scribe - package rice.p2p.scribe
 
rice.p2p.scribe.messaging - package rice.p2p.scribe.messaging
 
rice.p2p.scribe.testing - package rice.p2p.scribe.testing
 
rice.p2p.splitstream - package rice.p2p.splitstream
 
rice.p2p.splitstream.testing - package rice.p2p.splitstream.testing
 
rice.past - package rice.past
 
rice.past.messaging - package rice.past.messaging
 
rice.past.testing - package rice.past.testing
 
rice.pastry - package rice.pastry
 
rice.pastry.client - package rice.pastry.client
 
rice.pastry.commonapi - package rice.pastry.commonapi
 
rice.pastry.direct - package rice.pastry.direct
 
rice.pastry.dist - package rice.pastry.dist
 
rice.pastry.join - package rice.pastry.join
 
rice.pastry.leafset - package rice.pastry.leafset
 
rice.pastry.messaging - package rice.pastry.messaging
 
rice.pastry.multiring - package rice.pastry.multiring
 
rice.pastry.multiring.messaging - package rice.pastry.multiring.messaging
 
rice.pastry.multiring.testing - package rice.pastry.multiring.testing
 
rice.pastry.rmi - package rice.pastry.rmi
 
rice.pastry.routing - package rice.pastry.routing
 
rice.pastry.security - package rice.pastry.security
 
rice.pastry.standard - package rice.pastry.standard
 
rice.pastry.testing - package rice.pastry.testing
 
rice.pastry.wire - package rice.pastry.wire
 
rice.pastry.wire.exception - package rice.pastry.wire.exception
 
rice.pastry.wire.messaging.datagram - package rice.pastry.wire.messaging.datagram
 
rice.pastry.wire.messaging.socket - package rice.pastry.wire.messaging.socket
 
rice.persistence - package rice.persistence
 
rice.persistence.testing - package rice.persistence.testing
 
rice.rm - package rice.rm
 
rice.rm.messaging - package rice.rm.messaging
 
rice.rm.testing - package rice.rm.testing
 
rice.scribe - package rice.scribe
 
rice.scribe.maintenance - package rice.scribe.maintenance
 
rice.scribe.messaging - package rice.scribe.messaging
 
rice.scribe.security - package rice.scribe.security
 
rice.scribe.testing - package rice.scribe.testing
 
RingForwardMessage - class rice.pastry.multiring.messaging.RingForwardMessage.
A class representing a ring forward request
RingForwardMessage(RouteMessage) - Constructor for class rice.pastry.multiring.messaging.RingForwardMessage
Constructor
RingId - class rice.pastry.multiring.RingId.
This class represents a ringId, which is based on a NodeId and represents a unique identifier for a ring.
RingId() - Constructor for class rice.pastry.multiring.RingId
Constructor.
RingId(byte[]) - Constructor for class rice.pastry.multiring.RingId
Constructor.
RingId(int[]) - Constructor for class rice.pastry.multiring.RingId
Constructor.
ringIdBitLength - Static variable in class rice.pastry.multiring.RingId
This is the bit length of the node ids.
RingLookupReminderMessage - class rice.pastry.multiring.messaging.RingLookupReminderMessage.
A class representing a ring lookup reminder message
RingLookupReminderMessage(RingId) - Constructor for class rice.pastry.multiring.messaging.RingLookupReminderMessage
Constructor
RingLookupRequestMessage - class rice.pastry.multiring.messaging.RingLookupRequestMessage.
A class representing a ring lookup request, which is anycast to the Scribe group rooted at the ringId.
RingLookupRequestMessage(RingId) - Constructor for class rice.pastry.multiring.messaging.RingLookupRequestMessage
Constructor
RingLookupResponseMessage - class rice.pastry.multiring.messaging.RingLookupResponseMessage.
A class representing a reponse ring lookup request, which is sent directly to the node which sent the lookup.
RingLookupResponseMessage(NodeHandle, RingId) - Constructor for class rice.pastry.multiring.messaging.RingLookupResponseMessage
Constructor
RingNodeId - class rice.pastry.multiring.RingNodeId.
This class represents a nodeId, combined with a ring-identfying Id.
RingNodeId(byte[], RingId) - Constructor for class rice.pastry.multiring.RingNodeId
 
RingNodeId(int[], RingId) - Constructor for class rice.pastry.multiring.RingNodeId
 
RingNodeId(NodeId, RingId) - Constructor for class rice.pastry.multiring.RingNodeId
 
RingNodeId(RingId) - Constructor for class rice.pastry.multiring.RingNodeId
 
RM - interface rice.rm.RM.
 
RMClient - interface rice.rm.RMClient.
 
rmClients - Variable in class rice.rm.testing.DirectRMRegrTest
 
RMImpl - class rice.rm.RMImpl.
 
RMImpl.KEPenEntry - class rice.rm.RMImpl.KEPenEntry.
This is the per entry state corresponding to the m_pendingRanges hashtable that we maintain in the Keys Exchange Protocol.
RMImpl.KEPenEntry(IdRange) - Constructor for class rice.rm.RMImpl.KEPenEntry
 
RMImpl.KEPenEntry(IdRange, int) - Constructor for class rice.rm.RMImpl.KEPenEntry
 
RMImpl(PastryNode, RMClient, int, String) - Constructor for class rice.rm.RMImpl
Builds a new ReplicaManager(RM) associated with a particular RMclient.
RMINodeHandle - class rice.pastry.rmi.RMINodeHandle.
A locally stored node handle that points to a remote RMIRemoteNodeI.
RMINodeHandle(RMIRemoteNodeI, NodeId, InetSocketAddress) - Constructor for class rice.pastry.rmi.RMINodeHandle
Constructor.
RMINodeHandle(RMIRemoteNodeI, NodeId, PastryNode, InetSocketAddress) - Constructor for class rice.pastry.rmi.RMINodeHandle
Alternate constructor with local Pastry node.
RMIPastryNode - class rice.pastry.rmi.RMIPastryNode.
An RMI-exported Pastry node.
RMIPastryNode(NodeId) - Constructor for class rice.pastry.rmi.RMIPastryNode
Constructor
RMIPastryNodeFactory - class rice.pastry.rmi.RMIPastryNodeFactory.
Pastry node factory for RMI-linked nodes.
RMIPastryNodeFactory(NodeIdFactory, int) - Constructor for class rice.pastry.rmi.RMIPastryNodeFactory
Constructor.
RMIPastrySecurityManager - class rice.pastry.rmi.RMIPastrySecurityManager.
Security manager for RMI connections between nodes.
RMIPastrySecurityManager(RMINodeHandle, RMINodeHandlePool) - Constructor for class rice.pastry.rmi.RMIPastrySecurityManager
Constructor.
rmiRegistry - Static variable in class rice.pastry.rmi.RMIPastryNodeFactory
Instance of RMI registry ever-created when using this factory.
RMIRemoteNodeI - interface rice.pastry.rmi.RMIRemoteNodeI.
A remote interface exported by Pastry nodes.
rmIsReady(RM) - Method in class rice.p2p.past.PastImpl
This upcall is simply to denote that the underlying replica manager (rm) is ready.
rmIsReady(RM) - Method in class rice.past.PASTServiceImpl
Deprecated. This upcall is simply to denote that the underlying replica manager (rm) is ready.
rmIsReady(RM) - Method in interface rice.rm.RMClient
This upcall is simply to denote that the underlying replica manager (rm) is ready.
rmIsReady(RM) - Method in class rice.rm.testing.DistRMRegrTestApp
 
rmIsReady(RM) - Method in class rice.rm.testing.RMRegrTestApp
 
RMMaintenanceMsg - class rice.rm.messaging.RMMaintenanceMsg.
 
RMMaintenanceMsg(NodeHandle, Address, Credentials, int) - Constructor for class rice.rm.messaging.RMMaintenanceMsg
Constructor
RMMessage - class rice.rm.messaging.RMMessage.
 
RMMessage.KEEntry - class rice.rm.messaging.RMMessage.KEEntry.
This class will be used by the messaging system.
RMMessage.KEEntry(IdRange, boolean) - Constructor for class rice.rm.messaging.RMMessage.KEEntry
 
RMMessage.KEEntry(IdRange, IdRange, int, boolean, Id, IdSet) - Constructor for class rice.rm.messaging.RMMessage.KEEntry
 
RMMessage(NodeHandle, Address, Credentials, int) - Constructor for class rice.rm.messaging.RMMessage
Constructor : Builds a new RM Message
RMRegrTestApp - class rice.rm.testing.RMRegrTestApp.
 
RMRegrTestApp.ReplicateEntry - class rice.rm.testing.RMRegrTestApp.ReplicateEntry.
 
RMRegrTestApp.ReplicateEntry(Object) - Constructor for class rice.rm.testing.RMRegrTestApp.ReplicateEntry
 
RMRegrTestApp(PastryNode, Credentials, String) - Constructor for class rice.rm.testing.RMRegrTestApp
Constructor
RMRequestKeysMsg - class rice.rm.messaging.RMRequestKeysMsg.
 
RMRequestKeysMsg.WrappedMsg - class rice.rm.messaging.RMRequestKeysMsg.WrappedMsg.
Contains the RMRequestKeysMsg and the destination to which it was being sent.
RMRequestKeysMsg.WrappedMsg(RMRequestKeysMsg, NodeHandle) - Constructor for class rice.rm.messaging.RMRequestKeysMsg.WrappedMsg
 
RMRequestKeysMsg(NodeHandle, Address, Credentials, int, Vector, int) - Constructor for class rice.rm.messaging.RMRequestKeysMsg
Constructor : Builds a new RM Message
RMResponseKeysMsg - class rice.rm.messaging.RMResponseKeysMsg.
 
RMResponseKeysMsg(NodeHandle, Address, Credentials, int, Vector, int) - Constructor for class rice.rm.messaging.RMResponseKeysMsg
Constructor : Builds a new RM Message
RMTimeoutMsg - class rice.rm.messaging.RMTimeoutMsg.
 
RMTimeoutMsg(NodeHandle, Address, Credentials, int, RMRequestKeysMsg.WrappedMsg) - Constructor for class rice.rm.messaging.RMTimeoutMsg
Constructor
rng - Variable in class rice.p2p.past.testing.PastRegrTest
 
rng - Variable in class rice.p2p.scribe.testing.ScribeRegrTest
DESCRIBE THE FIELD
rng - Variable in class rice.p2p.splitstream.testing.SplitStreamRegrTest
DESCRIBE THE FIELD
rootApp(NodeId) - Method in class rice.scribe.testing.DirectScribeMaintenanceTest
This returns the index of the application that is currently the root for the topic's multicast tree.
route(Id, Message, NodeHandle) - Method in interface rice.p2p.commonapi.Endpoint
This method makes an attempt to route the message to the root of the given id.
route(Id, Message, NodeHandle) - Method in class rice.pastry.client.CommonAPIAppl
This operation forwards a message towards the root of key.
route(Id, Message, NodeHandle) - Method in class rice.pastry.commonapi.PastryEndpoint
This operation forwards a message towards the root of key.
RouteMessage - interface rice.p2p.commonapi.RouteMessage.
 
RouteMessage - class rice.pastry.routing.RouteMessage.
A route message contains a pastry message that has been wrapped to be sent to another pastry node.
RouteMessage(Id, Message, Credentials) - Constructor for class rice.pastry.routing.RouteMessage
Constructor.
RouteMessage(Id, Message, Credentials, Address) - Constructor for class rice.pastry.routing.RouteMessage
Constructor.
RouteMessage(Id, Message, Credentials, SendOptions) - Constructor for class rice.pastry.routing.RouteMessage
Constructor.
RouteMessage(Id, Message, Credentials, SendOptions, Address) - Constructor for class rice.pastry.routing.RouteMessage
Constructor.
RouteMessage(Id, Message, NodeHandle, Address) - Constructor for class rice.pastry.routing.RouteMessage
Constructor.
RouteMessage(NodeHandle, Message, Credentials, SendOptions, Address) - Constructor for class rice.pastry.routing.RouteMessage
Constructor.
routeMessage(NodeId) - Method in class rice.pastry.routing.RouteMessage
Routes the messages if the next hop has been set up.
routeMsg(Id, Message, Credentials, SendOptions) - Method in class rice.pastry.client.PastryAppl
Routes a message to the live node D with nodeId numerically closest to key (at the time of delivery).
routeMsgDirect(NodeHandle, Message, Credentials, SendOptions) - Method in class rice.pastry.client.PastryAppl
Sends a message to the Pastry node identified by dest.
routeMultiRingMessage(RouteMessage) - Method in class rice.pastry.multiring.MultiRingAppl
 
routeMultiRingMessage(RouteMessage, RingId) - Method in class rice.pastry.multiring.MultiRingAppl
 
RouteProtocolAddress - class rice.pastry.routing.RouteProtocolAddress.
The address of the route protocol at a pastry node.
RouteProtocolAddress() - Constructor for class rice.pastry.routing.RouteProtocolAddress
Constructor.
RouterAddress - class rice.pastry.routing.RouterAddress.
The address of the router at a pastry node.
RouterAddress() - Constructor for class rice.pastry.routing.RouterAddress
Constructor.
RouteRowRequestMessage - class rice.pastry.wire.messaging.socket.RouteRowRequestMessage.
Message which represents a request to get the leafset from the remote node.
RouteRowRequestMessage(int) - Constructor for class rice.pastry.wire.messaging.socket.RouteRowRequestMessage
Constructor
RouteRowResponseMessage - class rice.pastry.wire.messaging.socket.RouteRowResponseMessage.
A response message to a RouteRowRequestMessage, containing the remote node's routerow.
RouteRowResponseMessage(RouteSet[]) - Constructor for class rice.pastry.wire.messaging.socket.RouteRowResponseMessage
Constructor
RouteSet - class rice.pastry.routing.RouteSet.
A set of nodes typically stored in the routing table.
RouteSet(int) - Constructor for class rice.pastry.routing.RouteSet
Constructor.
routeSetChange(NodeHandle, boolean) - Method in class rice.pastry.client.PastryAppl
Called by pastry when the route set changes.
routeSetChange(NodeHandle, boolean) - Method in class rice.pastry.testing.HelloWorldApp
Invoked upon change to routing table.
routeSetChange(NodeHandle, boolean) - Method in class rice.pastry.testing.Ping
 
routeSetChange(NodeHandle, boolean) - Method in class rice.pastry.testing.PingClient
 
routeSetChange(NodeHandle, boolean) - Method in class rice.pastry.testing.RegrTestApp
 
routeSetMaintFreq - Variable in class rice.pastry.dist.DistPastryNode
 
RoutingTable - class rice.pastry.routing.RoutingTable.
The Pastry routing table.
RoutingTable(NodeHandle, int) - Constructor for class rice.pastry.routing.RoutingTable
Constructor.
row - Variable in class rice.pastry.wire.messaging.socket.RouteRowRequestMessage
 
run() - Method in class rice.pastry.ScheduledMessage
deliver the message
run() - Method in class rice.pastry.wire.SelectorManager
This method starts the datagram manager listening for incoming datagrams.
runInsertChecks() - Method in class rice.past.testing.DistPASTRegrTest.TestPASTFunctions
Deprecated. Checks that a file is stored on the right number of nodes after being inserted.
runInsertTests() - Method in class rice.past.testing.DistPASTRegrTest.TestPASTFunctions
Deprecated. Checks that a file is not available until it is inserted, and that it can only be inserted once.
runReclaimTests() - Method in class rice.past.testing.DistPASTRegrTest.TestPASTFunctions
Deprecated. Checks that deleting a file works.
runTest() - Method in class rice.p2p.commonapi.testing.CommonAPITest
Method which should run the test - this is called once all of the nodes have been created and are ready.
runTest() - Method in class rice.p2p.past.testing.PastRegrTest
Method which should run the test - this is called once all of the nodes have been created and are ready.
runTest() - Method in class rice.p2p.scribe.testing.ScribeRegrTest
Method which should run the test - this is called once all of the nodes have been created and are ready.
runTest() - Method in class rice.p2p.splitstream.testing.SplitStreamRegrTest
Method which should run the test - this is called once all of the nodes have been created and are ready.
runTests() - Method in class rice.past.testing.DistPASTRegrTest
Deprecated. Initializes and runs all regression tests.

S

scan(IdRange) - Method in interface rice.p2p.past.Past
Return the ids of objects stored in this instance of Past on the *local* node, with ids in a given range.
scan(IdRange) - Method in class rice.p2p.past.PastImpl
Return the ids of objects stored in this instance of Past on the *local* node, with ids in a given range.
scan(IdRange) - Method in class rice.p2p.past.PastImpl
This upcall should return the set of keys that the application currently stores in this range.
scan(IdRange) - Method in class rice.past.PASTServiceImpl
Deprecated. This upcall should return the set of keys that the application currently stores in this range.
scan(IdRange) - Method in interface rice.persistence.Catalog
Return the objects identified by the given range of ids.
scan(IdRange) - Method in class rice.persistence.LRUCache
Return the objects identified by the given range of ids.
scan(IdRange) - Method in class rice.persistence.MemoryStorage
Return the objects identified by the given range of ids.
scan(IdRange) - Method in class rice.persistence.PersistentStorage
Return the objects identified by the given range of ids.
scan(IdRange) - Method in class rice.persistence.StorageManager
Return the objects identified by the given range of ids.
scan(IdRange) - Method in interface rice.rm.RMClient
This upcall should return the set of keys that the application currently stores in this range.
scan(IdRange) - Method in class rice.rm.testing.RMRegrTestApp
 
scan(IdRange, Continuation) - Method in interface rice.persistence.Catalog
Return the objects identified by the given range of ids.
scan(IdRange, Continuation) - Method in class rice.persistence.LRUCache
Return the objects identified by the given range of ids.
scan(IdRange, Continuation) - Method in class rice.persistence.MemoryStorage
Return the objects identified by the given range of ids.
scan(IdRange, Continuation) - Method in class rice.persistence.PersistentStorage
Return the objects identified by the given range of ids.
scan(IdRange, Continuation) - Method in class rice.persistence.StorageManager
Return the objects identified by the given range of ids.
ScheduledMessage - class rice.pastry.ScheduledMessage.
A class that represents scheduled message events
ScheduledMessage(PastryNode, Message) - Constructor for class rice.pastry.ScheduledMessage
Constructor
scheduleHB() - Method in interface rice.scribe.IScribe
Sends heartbeat messages to this local node's children for all the topics on this local scribe node.
scheduleHB() - Method in class rice.scribe.maintenance.ScribeMaintainer
Sends heartbeat messages to this local node's children for all the topics on this local scribe node.
scheduleHB() - Method in class rice.scribe.Scribe
Sends heartbeat messages to this local node's children for all the topics on this local scribe node.
scheduleHBOnAllNodes() - Method in class rice.scribe.testing.DirectScribeMaintenanceTest
Schedule a HeartBeat event on all nodes for all topics.
scheduleMessage(Message, long) - Method in interface rice.p2p.commonapi.Endpoint
Schedules a message to be delivered to this application after the provided number of milliseconds.
scheduleMessage(Message, long) - Method in class rice.pastry.commonapi.PastryEndpoint
Schedules a message to be delivered to this application after the provided number of milliseconds.
scheduleMsg(Message, long) - Method in class rice.pastry.direct.DirectPastryNode
Schedule the specified message to be sent to the local node after a specified delay.
scheduleMsg(Message, long) - Method in class rice.pastry.dist.DistPastryNode
Schedule the specified message to be sent to the local node after a specified delay.
scheduleMsg(Message, long) - Method in class rice.pastry.multiring.MultiRingPastryNode
 
scheduleMsg(Message, long) - Method in class rice.pastry.PastryNode
Schedule the specified message to be sent to the local node after a specified delay.
scheduleMsg(Message, long, long) - Method in class rice.pastry.direct.DirectPastryNode
Schedule the specified message for repeated fixed-delay delivery to the local node, beginning after the specified delay.
scheduleMsg(Message, long, long) - Method in class rice.pastry.dist.DistPastryNode
Schedule the specified message for repeated fixed-delay delivery to the local node, beginning after the specified delay.
scheduleMsg(Message, long, long) - Method in class rice.pastry.multiring.MultiRingPastryNode
 
scheduleMsg(Message, long, long) - Method in class rice.pastry.PastryNode
Schedule the specified message for repeated fixed-delay delivery to the local node, beginning after the specified delay.
scheduleMsgAtFixedRate(Message, long, long) - Method in class rice.pastry.direct.DirectPastryNode
Schedule the specified message for repeated fixed-rate delivery to the local node, beginning after the specified delay.
scheduleMsgAtFixedRate(Message, long, long) - Method in class rice.pastry.dist.DistPastryNode
Schedule the specified message for repeated fixed-rate delivery to the local node, beginning after the specified delay.
scheduleMsgAtFixedRate(Message, long, long) - Method in class rice.pastry.multiring.MultiRingPastryNode
 
scheduleMsgAtFixedRate(Message, long, long) - Method in class rice.pastry.PastryNode
Schedule the specified message for repeated fixed-rate delivery to the local node, beginning after the specified delay.
scheduleTR(Topic) - Method in class rice.scribe.maintenance.ScribeMaintainer
Starts a tree repair for a particular topic in the local node
scheduleTROnAllNodes() - Method in class rice.scribe.testing.DirectScribeMaintenanceTest
Schedule a TreeRepair event on all nodes for all the topics.
scribe - Variable in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribeClient
DESCRIBE THE FIELD
scribe - Variable in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribePolicy
 
scribe - Variable in class rice.p2p.splitstream.SplitStreamImpl
The scribe instance for this SplitStream Object
scribe - Variable in class rice.p2p.splitstream.SplitStreamScribePolicy
A reference to this policy's scribe object
scribe - Variable in class rice.p2p.splitstream.Stripe
The scribe object
Scribe - interface rice.p2p.scribe.Scribe.
 
Scribe - class rice.scribe.Scribe.
 
Scribe(PastryNode, Credentials) - Constructor for class rice.scribe.Scribe
Constructor.
ScribeClient - interface rice.p2p.scribe.ScribeClient.
 
scribeClients - Variable in class rice.scribe.testing.DirectScribeMaintenanceTest
 
ScribeContent - interface rice.p2p.scribe.ScribeContent.
 
ScribeImpl - class rice.p2p.scribe.ScribeImpl.
 
ScribeImpl.TopicManager - class rice.p2p.scribe.ScribeImpl.TopicManager.
Class which keeps track of a given topic
ScribeImpl.TopicManager(Topic) - Constructor for class rice.p2p.scribe.ScribeImpl.TopicManager
Constructor for TopicManager.
ScribeImpl.TopicManager(Topic, NodeHandle) - Constructor for class rice.p2p.scribe.ScribeImpl.TopicManager
Constructor for TopicManager.
ScribeImpl.TopicManager(Topic, ScribeClient) - Constructor for class rice.p2p.scribe.ScribeImpl.TopicManager
Constructor for TopicManager.
ScribeImpl(Node, ScribePolicy, String) - Constructor for class rice.p2p.scribe.ScribeImpl
Constructor for Scribe
ScribeImpl(Node, String) - Constructor for class rice.p2p.scribe.ScribeImpl
Constructor for Scribe, using the default policy.
scribeIsReady() - Method in class rice.pastry.multiring.MultiRingAppl
 
scribeIsReady() - Method in interface rice.scribe.IScribeApp
Invoked when the underlying Scribe substrate is ready.
scribeIsReady() - Method in class rice.scribe.testing.BasicScribeRegrTestApp
 
scribeIsReady() - Method in class rice.scribe.testing.DirectScribeMaintenanceTestApp
 
scribeIsReady() - Method in class rice.scribe.testing.DistScribeRegrTestApp
 
ScribeMaintainer - class rice.scribe.maintenance.ScribeMaintainer.
This is responsible for all the Scribe tree maintainance activities corresponding to all the topics in this local node.
ScribeMaintainer(Scribe) - Constructor for class rice.scribe.maintenance.ScribeMaintainer
 
ScribeMessage - class rice.p2p.scribe.messaging.ScribeMessage.
 
ScribeMessage - class rice.scribe.messaging.ScribeMessage.
This is an abstract implementation of a Scribe message object.
ScribeMessage(Address, NodeHandle, NodeId, Credentials) - Constructor for class rice.scribe.messaging.ScribeMessage
Constructor
ScribeMessage(NodeHandle, Topic) - Constructor for class rice.p2p.scribe.messaging.ScribeMessage
Constructor which takes a unique integer Id
ScribePolicy - interface rice.p2p.scribe.ScribePolicy.
 
ScribePolicy.DefaultScribePolicy - class rice.p2p.scribe.ScribePolicy.DefaultScribePolicy.
The default policy for Scribe, which always allows new children to join and adds children in the order in which they are provided, implicitly providing a depth-first search.
ScribePolicy.DefaultScribePolicy() - Constructor for class rice.p2p.scribe.ScribePolicy.DefaultScribePolicy
 
ScribePolicy.LimitedScribePolicy - class rice.p2p.scribe.ScribePolicy.LimitedScribePolicy.
An optional policy for Scribe, which allows up to a specified number of children per topic.
ScribePolicy.LimitedScribePolicy(int) - Constructor for class rice.p2p.scribe.ScribePolicy.LimitedScribePolicy
Construtor which takes a maximum number
ScribeRegrTest - class rice.p2p.scribe.testing.ScribeRegrTest.
 
ScribeRegrTest.TestRouteMessage - class rice.p2p.scribe.testing.ScribeRegrTest.TestRouteMessage.
Utility class which simulates a route message
ScribeRegrTest.TestRouteMessage(Id, NodeHandle, Message) - Constructor for class rice.p2p.scribe.testing.ScribeRegrTest.TestRouteMessage
Constructor for TestRouteMessage.
ScribeRegrTest.TestScribeClient - class rice.p2p.scribe.testing.ScribeRegrTest.TestScribeClient.
DESCRIBE THE CLASS
ScribeRegrTest.TestScribeClient(ScribeImpl, Topic, int) - Constructor for class rice.p2p.scribe.testing.ScribeRegrTest.TestScribeClient
Constructor for TestScribeClient.
ScribeRegrTest.TestScribeContent - class rice.p2p.scribe.testing.ScribeRegrTest.TestScribeContent.
Utility class for past content objects
ScribeRegrTest.TestScribeContent(Topic, int) - Constructor for class rice.p2p.scribe.testing.ScribeRegrTest.TestScribeContent
Constructor for TestScribeContent.
ScribeRegrTest.TestScribePolicy - class rice.p2p.scribe.testing.ScribeRegrTest.TestScribePolicy.
 
ScribeRegrTest.TestScribePolicy(Scribe) - Constructor for class rice.p2p.scribe.testing.ScribeRegrTest.TestScribePolicy
 
ScribeRegrTest() - Constructor for class rice.p2p.scribe.testing.ScribeRegrTest
Constructor which sets up all local variables
scribes - Variable in class rice.p2p.scribe.testing.ScribeRegrTest
DESCRIBE THE FIELD
sectionDone() - Method in class rice.p2p.commonapi.testing.CommonAPITest
Method which prints the end of a test section.
sectionEnd() - Method in class rice.persistence.testing.Test
 
sectionStart(String) - Method in class rice.p2p.commonapi.testing.CommonAPITest
Method which prints the beginning of a test section.
sectionStart(String) - Method in class rice.persistence.testing.Test
 
SELECT_WAIT_TIME - Variable in class rice.pastry.wire.SelectorManager
 
SelectionKeyHandler - interface rice.pastry.wire.SelectionKeyHandler.
This interface is designed to be a callback mechanism from the SelectorManager.
SelectorManager - class rice.pastry.wire.SelectorManager.
This class is the class which handles the selector, and listens for activity.
SelectorManager(WirePastryNode) - Constructor for class rice.pastry.wire.SelectorManager
Constructor.
sendGreetingResponse(HelloMessage) - Method in class rice.pastry.wire.WireNodeHandle
 
sendKeyRequestMessages(NodeSet, Vector) - Method in class rice.rm.RMImpl
We send RMRequestKeys messages to the the nodes in the 'set' asking for keys in the ranges specified in the 'rangeSet'.
sendMessage(Message) - Method in class rice.pastry.client.PastryAppl
Sends a message directly to the local pastry node.
sendMessage(PASTMessage) - Method in class rice.past.PASTServiceImpl
Deprecated. Sends a message to a remote PAST node (either a request or response).
sendMsg(NodeId) - Method in class rice.pastry.testing.RegrTestApp
 
SendOptions - class rice.pastry.routing.SendOptions.
This is the options for a client to send messages.
SendOptions() - Constructor for class rice.pastry.routing.SendOptions
Constructor.
SendOptions(boolean, boolean, boolean, boolean) - Constructor for class rice.pastry.routing.SendOptions
Constructor.
sendPing(NodeId) - Method in class rice.pastry.testing.Ping
 
sendPing(NodeId) - Method in class rice.pastry.testing.PingClient
 
sendPings(int) - Method in class rice.pastry.testing.PastryRegrTest
Send messages among random message pairs.
sendPings(int) - Method in class rice.pastry.testing.PastryTest
 
sendPings(int) - Method in class rice.pastry.testing.SinglePingTest
 
sendRndMsg(Random) - Method in class rice.pastry.testing.HelloWorldApp
Sends a message to a randomly chosen node.
sendTrace(NodeId) - Method in class rice.pastry.testing.PingClient
 
sendTrace(NodeId) - Method in class rice.pastry.testing.RegrTestApp
 
SerializationException - exception rice.pastry.wire.exception.SerializationException.
Class which represents an exception occuring during the serialization of a Pastry message.
SerializationException(String) - Constructor for class rice.pastry.wire.exception.SerializationException
Constructs an SerializationException with a given message
serialize(Object) - Static method in class rice.pastry.wire.DatagramManager
Method which serializes a given object into a ByteBuffer, in order to prepare it for writing.
serialize(Object) - Static method in class rice.pastry.wire.SocketChannelWriter
Method which serializes a given object into a ByteBuffer, in order to prepare it for writing.
setAlive(NodeId, boolean) - Method in class rice.pastry.direct.EuclideanNetwork
set the liveliness of a NodeId
setAlive(NodeId, boolean) - Method in interface rice.pastry.direct.NetworkSimulator
 
setAlive(NodeId, boolean) - Method in class rice.pastry.direct.SphereNetwork
set the liveliness of a NodeId
setBit(int, int) - Method in class rice.pastry.Id
Sets the ith bit to a given value i = 0 is the least significant bit.
setBootstrap(NodeHandle) - Method in class rice.pastry.multiring.MultiRingPastryNode
 
setCached() - Method in class rice.p2p.past.messaging.FetchMessage
Sets this message as having been cached.
setCached() - Method in class rice.p2p.past.messaging.LookupMessage
Sets this message as having been cached.
setChanged() - Method in class rice.pastry.dist.DistNodeHandle
 
setContent(ScribeContent) - Method in class rice.p2p.scribe.messaging.AnycastMessage
Sets the content
setCount(int) - Method in class rice.scribe.testing.DistTopicLog
 
setData(Serializable) - Method in class rice.scribe.messaging.ScribeMessage
Sets the data contained in the message.
setDestinationId(Id) - Method in interface rice.p2p.commonapi.RouteMessage
Sets the destination Id for this message
setDestinationId(Id) - Method in class rice.p2p.past.testing.PastRegrTest.TestRouteMessage
 
setDestinationId(Id) - Method in class rice.p2p.scribe.testing.ScribeRegrTest.TestRouteMessage
Sets the DestinationId attribute of the TestRouteMessage object
setDestinationId(Id) - Method in class rice.pastry.routing.RouteMessage
 
setDigit(int, int, int) - Method in class rice.pastry.Id
Sets the ith digit in base 2^b.
setDirectElements() - Method in class rice.pastry.direct.DirectPastryNode
 
setElements(NodeHandle, PastrySecurityManager, MessageDispatch, LeafSet, RoutingTable) - Method in class rice.pastry.multiring.MultiRingPastryNode
 
setElements(NodeHandle, PastrySecurityManager, MessageDispatch, LeafSet, RoutingTable) - Method in class rice.pastry.PastryNode
Combined accessor method for various members of PastryNode.
setID(PASTMessageID) - Method in class rice.past.messaging.PASTMessage
Deprecated. Sets this message's identifier.
setIsInPool(boolean) - Method in class rice.pastry.dist.DistNodeHandle
Sets whether or not this node handle is in the node handle pool.
setKey(SelectionKey, SocketCommandMessage) - Method in class rice.pastry.wire.WireNodeHandle
Method which sets the SelectionKey of this node handle.
setLastRecvTime(long) - Method in class rice.scribe.testing.DistTopicLog
 
setLastSeqNumRecv(int) - Method in class rice.scribe.testing.DistTopicLog
 
setLocalNode(PastryNode) - Method in class rice.pastry.LocalNode
Accessor method.
setLocalNode(PastryNode) - Method in interface rice.pastry.LocalNodeI
Accessor method.
setLocalNode(PastryNode) - Method in class rice.pastry.NodeHandle
Set the local PastryNode.
setLocalPastryNode(PastryNode) - Method in class rice.pastry.direct.DirectSecurityManager
Sets the local pastry node.
setLocalPastryNode(PastryNode) - Method in class rice.pastry.rmi.RMIPastrySecurityManager
Sets the local Pastry node after it is fully constructed.
setLocalPastryNode(PastryNode) - Method in class rice.pastry.wire.WirePastrySecurityManager
Sets the local Pastry node after it is fully constructed.
setMaxChildren(ChannelId, int) - Method in class rice.p2p.splitstream.SplitStreamScribePolicy
Adjust the max bandwidth for this channel.
setMaximumSize(int, Continuation) - Method in interface rice.persistence.Cache
Sets the maximum size of the cache, in bytes.
setMaximumSize(int, Continuation) - Method in class rice.persistence.LRUCache
Sets the maximum size of the cache, in bytes.
setMaximumSize(int, Continuation) - Method in class rice.persistence.StorageManager
Sets the maximum size of the cache, in bytes.
setMessage(Message) - Method in interface rice.p2p.commonapi.RouteMessage
Sets the internal message for this message
setMessage(Message) - Method in class rice.p2p.past.testing.PastRegrTest.TestRouteMessage
 
setMessage(Message) - Method in class rice.p2p.scribe.testing.ScribeRegrTest.TestRouteMessage
Sets the Message attribute of the TestRouteMessage object
setMessage(Message) - Method in class rice.pastry.commonapi.PastryEndpointMessage
Returns the internal message
setMessage(Message) - Method in class rice.pastry.routing.RouteMessage
 
setMessageDispatch(MessageDispatch) - Method in class rice.pastry.multiring.MultiRingPastryNode
 
setMessageDispatch(MessageDispatch) - Method in class rice.pastry.PastryNode
 
setmissingCount(int) - Method in class rice.rm.testing.ObjectState
 
setNextHop(NodeHandle) - Method in class rice.pastry.routing.RouteMessage
 
setNextHopHandle(NodeHandle) - Method in interface rice.p2p.commonapi.RouteMessage
Sets the next hop handle for this message
setNextHopHandle(NodeHandle) - Method in class rice.p2p.past.testing.PastRegrTest.TestRouteMessage
 
setNextHopHandle(NodeHandle) - Method in class rice.p2p.scribe.testing.ScribeRegrTest.TestRouteMessage
Sets the NextHopHandle attribute of the TestRouteMessage object
setNextHopHandle(NodeHandle) - Method in class rice.pastry.routing.RouteMessage
 
setNum(int) - Method in class rice.pastry.wire.messaging.datagram.DatagramMessage
Sets the "packet number" of this transmission
setParent(NodeHandle) - Method in class rice.p2p.scribe.ScribeImpl.TopicManager
Sets the Parent attribute of the TopicManager object
setParent(NodeHandle) - Method in class rice.scribe.Topic
Sets the local node's parent in this topic's multicast tree.
setParent(NodeHandle, NodeId) - Method in interface rice.scribe.IScribe
Sets the parent for the topic specified by topicId.
setParent(NodeHandle, NodeId) - Method in class rice.scribe.Scribe
Sets the parent for the topic specified by topicId.
setParentAndaddChildTest() - Method in class rice.scribe.testing.DirectScribeMaintenanceTest
Checks whether setParent and addChild works correctly.
setParentPastryNode(MultiRingPastryNode) - Method in class rice.pastry.multiring.MultiRingPastryNode
 
setPathToRoot(Id[]) - Method in class rice.p2p.scribe.ScribeImpl.TopicManager
Sets the PathToRoot attribute of the TopicManager object
setPending(ObjectInputStream, PastryNode) - Method in class rice.pastry.PendingLocalNodesList
Sets all of the pending local nodes read in by the given input stream.
setPolicy(ScribePolicy) - Method in interface rice.p2p.scribe.Scribe
Sets the current policy for this scribe object
setPolicy(ScribePolicy) - Method in class rice.p2p.scribe.ScribeImpl
Sets the current policy for this scribe object
setPresent(boolean) - Method in class rice.rm.testing.ObjectState
 
setPrevNode(NodeHandle) - Method in class rice.pastry.routing.RouteMessage
 
setPriority(boolean) - Method in class rice.pastry.messaging.Message
Set priority.
setProximity(int) - Method in class rice.pastry.dist.DistNodeHandle
Method which is designed to be called by subclassses whenever there is a change in the distance metric.
setReady() - Method in class rice.pastry.multiring.MultiRingPastryNode
 
setReady() - Method in class rice.pastry.PastryNode
 
setRemoteNode(RMIRemoteNodeI) - Method in class rice.pastry.rmi.RMINodeHandle
Remotenode accessor method.
setResponse() - Method in class rice.p2p.past.messaging.PastMessage
Method which builds a response for this message, using the provided object as a result.
setRingId(RingId) - Method in class rice.pastry.multiring.RingNodeId
 
setRMIElements(RMINodeHandlePool, int, int, int) - Method in class rice.pastry.rmi.RMIPastryNode
accessor method for elements in RMIPastryNode, called by RMIPastryNodeFactory.
setRoot(String) - Method in class rice.persistence.PersistentStorage
Sets the root directory that the persistence Manager uses
setSeed(int) - Static method in class rice.pastry.PastrySeed
 
setSenderId(NodeId) - Method in class rice.pastry.messaging.Message
Set sender Id.
setSeqNo(int) - Method in class rice.rm.messaging.RMRequestKeysMsg
Since this message has a timeout mechanism, the next time we resend the message as a result of Timeout we need to reflect the current seqNo used by the application in the message.
setSeqNumToPublish(int) - Method in class rice.scribe.testing.DistTopicLog
 
setSocketElements(InetSocketAddress, SelectorManager, DatagramManager, SocketManager, WireNodeHandlePool, int, int) - Method in class rice.pastry.wire.WirePastryNode
Helper method which allows the WirePastryNodeFactory to initialize a number of the pastry node's elements.
setSource(NodeHandle) - Method in class rice.p2p.scribe.messaging.ScribeMessage
Method which set this messages' source address
setstaleCount(int) - Method in class rice.rm.testing.ObjectState
 
setState(int) - Method in class rice.scribe.Topic
Set the state of topic to state
setStorageSize(int) - Method in class rice.persistence.PersistentStorage
Sets the amount of storage that the persistence Manager uses
setTestRecord(TestRecord) - Method in class rice.pastry.direct.EuclideanNetwork
set TestRecord
setTestRecord(TestRecord) - Method in interface rice.pastry.direct.NetworkSimulator
 
setTestRecord(TestRecord) - Method in class rice.pastry.direct.SphereNetwork
set TestRecord
setThread(Thread) - Method in class rice.pastry.wire.WirePastryNode
Sets the thread which the pastry node is running in.
setTreeRepairThreshold(int) - Method in interface rice.scribe.IScribe
The tree repair event for a particular topic in Scribe is triggered when a node misses a certain treeRepairThreshold number of heartbeat messages from its parent for the topic.
setTreeRepairThreshold(int) - Method in class rice.scribe.Scribe
The tree repair event for a particular topic in Scribe is triggered when a node misses a certain threshold number of heartbeat messages from its parent for the topic.
setType(int) - Method in class rice.past.messaging.PASTMessage
Deprecated. Sets this message's type.
setUnsubscribed(boolean) - Method in class rice.scribe.testing.DistTopicLog
 
setUp(Continuation) - Method in class rice.persistence.testing.LRUCacheTest
 
setUp(Continuation) - Method in class rice.persistence.testing.MemoryStorageTest
 
setupDone - Static variable in class rice.rm.testing.DirectRMRegrTest
 
shift(int, int) - Method in class rice.pastry.Id.Distance
Shift operator.
shift(int, int, boolean) - Method in class rice.pastry.Id.Distance
Shift operator.
shiftDistance(int, int) - Method in interface rice.p2p.commonapi.Id.Distance
Shift operator.
shiftDistance(int, int) - Method in class rice.pastry.Id.Distance
Shift operator.
SimilarSet - class rice.pastry.leafset.SimilarSet.
A set of nodes, ordered by numerical distance of their nodeId from the local nodeId
SimilarSet(NodeHandle, int, boolean) - Constructor for class rice.pastry.leafset.SimilarSet
Constructor.
simulate() - Method in class rice.p2p.commonapi.testing.CommonAPITest
In case we're using the direct simulator, this method simulates the message passing.
simulate() - Method in class rice.pastry.direct.EuclideanNetwork
DESCRIBE THE METHOD
simulate() - Method in interface rice.pastry.direct.NetworkSimulator
Simulate one message delivery.
simulate() - Method in class rice.pastry.direct.SphereNetwork
DESCRIBE THE METHOD
simulate() - Method in class rice.pastry.testing.DirectPastryRegrTest
send one simulated message
simulate() - Method in class rice.pastry.testing.DistPastryRegrTest
 
simulate() - Method in class rice.pastry.testing.PastryRegrTest
send one simulated message, or return false for a real wire protocol.
simulate() - Method in class rice.pastry.testing.PastryTest
 
simulate() - Method in class rice.pastry.testing.SinglePingTest
 
simulate() - Method in class rice.rm.testing.DirectRMRegrTest
 
simulate() - Method in class rice.scribe.testing.BasicScribeRegrTest
 
simulate() - Method in class rice.scribe.testing.DirectScribeMaintenanceTest
 
simulator - Variable in class rice.p2p.commonapi.testing.CommonAPITest
 
simulator - Static variable in class rice.rm.testing.DirectRMRegrTest
 
SIMULATOR - Static variable in class rice.p2p.commonapi.testing.CommonAPITest
 
SIMULATOR_EUCLIDEAN - Static variable in class rice.p2p.commonapi.testing.CommonAPITest
 
SIMULATOR_SPHERE - Static variable in class rice.p2p.commonapi.testing.CommonAPITest
 
SinglePingTest - class rice.pastry.testing.SinglePingTest.
SinglePingTest A performance test suite for pastry.
SinglePingTest(TestRecord) - Constructor for class rice.pastry.testing.SinglePingTest
 
size() - Method in interface rice.p2p.commonapi.NodeHandleSet
Gets the size of the set.
size() - Method in class rice.pastry.leafset.LeafSet
Gets the current size of the leaf set.
size() - Method in class rice.pastry.leafset.SimilarSet
Gets the current size of this set.
size() - Method in class rice.pastry.NodeSet
Gets the number of elements.
size() - Method in interface rice.pastry.NodeSetI
Gets the size of the set.
size() - Method in class rice.pastry.routing.RouteSet
Return the current size of the set.
sleep() - Method in class rice.Continuation.ExternalContinuation
 
SOCKET_BUFFER_SIZE - Static variable in class rice.pastry.wire.WireNodeHandle
 
SocketChannelReader - class rice.pastry.wire.SocketChannelReader.
Class which serves as an "reader" for messages sent across the wire via the Pastry socket protocol.
SocketChannelReader(WirePastryNode) - Constructor for class rice.pastry.wire.SocketChannelReader
Constructor which creates this SocketChannelReader and the WirePastryNode.
SocketChannelWriter - class rice.pastry.wire.SocketChannelWriter.
Class which serves as an "writer" for all of the messages sent across the wire in Pastry.
SocketChannelWriter(WirePastryNode, SocketCommandMessage) - Constructor for class rice.pastry.wire.SocketChannelWriter
Constructor which creates this SocketChannelWriter with a pastry node and an object to write out.
SocketCommandMessage - class rice.pastry.wire.messaging.socket.SocketCommandMessage.
Class which represents a "command" message sent across the socket-based pastry protocol.
SocketCommandMessage() - Constructor for class rice.pastry.wire.messaging.socket.SocketCommandMessage
 
SocketManager - class rice.pastry.wire.SocketManager.
Class which maintains all outgoing open sockets.
SocketManager(WirePastryNode, int, Selector) - Constructor for class rice.pastry.wire.SocketManager
Constructs a new SocketManager.
SocketMessage - class rice.pastry.wire.messaging.socket.SocketMessage.
Class which abstracts out a message sent across the socket-based pastry protocol.
SocketMessage() - Constructor for class rice.pastry.wire.messaging.socket.SocketMessage
 
SocketTransportMessage - class rice.pastry.wire.messaging.socket.SocketTransportMessage.
Class which represents a wrapper message sent across the socket-based protocol - it has another message inside of it.
SocketTransportMessage(Object, NodeId) - Constructor for class rice.pastry.wire.messaging.socket.SocketTransportMessage
Constructs a new message wrapping another object.
source - Variable in class rice.p2p.past.messaging.PastMessage
 
source - Variable in class rice.p2p.scribe.messaging.ScribeMessage
 
source - Variable in class rice.pastry.wire.messaging.datagram.DatagramMessage
 
SphereNetwork - class rice.pastry.direct.SphereNetwork.
Sphere network topology and idealized node life.
SphereNetwork() - Constructor for class rice.pastry.direct.SphereNetwork
Constructor.
SPLITFACTOR - Static variable in class rice.rm.RMImpl
This value represents the splitting factor by which a range is split into in the Keys Exchange Protocol.
splitPendingRanges(NodeId) - Method in class rice.rm.RMImpl
Iterates over the list of pending Ranges and splits the ranges if the expected number of keys in a range is greater than MAXKEYSINRANGE.
splitStream - Variable in class rice.p2p.splitstream.SplitStreamScribePolicy
A reference to this policy's splitstream object
SplitStream - interface rice.p2p.splitstream.SplitStream.
The interface defines the methods that a splitStream object must implement.
SplitStreamClient - interface rice.p2p.splitstream.SplitStreamClient.
This interface allows an application running on top of SplitStream to be notified of events.
SplitStreamContent - class rice.p2p.splitstream.SplitStreamContent.
This represents data sent through scribe for splitstream
SplitStreamContent(byte[]) - Constructor for class rice.p2p.splitstream.SplitStreamContent
Constructor taking in a byte[]
SplitStreamImpl - class rice.p2p.splitstream.SplitStreamImpl.
This is the implementing class of the ISplitStream interface.
SplitStreamImpl(Node, String) - Constructor for class rice.p2p.splitstream.SplitStreamImpl
The constructor for building the splitStream object which internally creates it's own Scribe.
SplitStreamRegrTest - class rice.p2p.splitstream.testing.SplitStreamRegrTest.
 
SplitStreamRegrTest() - Constructor for class rice.p2p.splitstream.testing.SplitStreamRegrTest
Constructor which sets up all local variables
splitstreams - Variable in class rice.p2p.splitstream.testing.SplitStreamRegrTest
DESCRIBE THE FIELD
SplitStreamScribePolicy - class rice.p2p.splitstream.SplitStreamScribePolicy.
This class represents SplitStream's policy for Scribe, which only allows children according to the bandwidth manager and makes anycasts first traverse all nodes who have the stripe in question as their primary stripe, and then the nodes who do not.
SplitStreamScribePolicy(Scribe, SplitStream) - Constructor for class rice.p2p.splitstream.SplitStreamScribePolicy
Constructor which takes a splitStream object
SplitStreamSubscribeContent - class rice.p2p.splitstream.SplitStreamSubscribeContent.
This represents data sent through scribe for splitstream during a subscribe
SplitStreamSubscribeContent(int) - Constructor for class rice.p2p.splitstream.SplitStreamSubscribeContent
Constructor taking in a byte[]
ssclients - Variable in class rice.p2p.splitstream.testing.SplitStreamRegrTest
 
stage - Variable in class rice.p2p.splitstream.SplitStreamSubscribeContent
The stage that the client attempting to join is in
STAGE_FINAL - Static variable in class rice.p2p.splitstream.SplitStreamSubscribeContent
The final stage of the join process
STAGE_NON_FINAL - Static variable in class rice.p2p.splitstream.SplitStreamSubscribeContent
The first stage of the join process
stamp(Date) - Method in class rice.pastry.messaging.Message
If the message has no timestamp, this will stamp the message.
StandardAddress - class rice.pastry.standard.StandardAddress.
Constructs an address for a specific class and instance name.
StandardAddress(Class, String) - Constructor for class rice.pastry.standard.StandardAddress
 
StandardJoinProtocol - class rice.pastry.standard.StandardJoinProtocol.
An implementation of a simple join protocol.
StandardJoinProtocol(PastryNode, NodeHandle, PastrySecurityManager, RoutingTable, LeafSet) - Constructor for class rice.pastry.standard.StandardJoinProtocol
Constructor.
StandardLeafSetProtocol - class rice.pastry.standard.StandardLeafSetProtocol.
An implementation of a simple leaf set protocol.
StandardLeafSetProtocol(PastryNode, NodeHandle, PastrySecurityManager, LeafSet, RoutingTable) - Constructor for class rice.pastry.standard.StandardLeafSetProtocol
 
StandardRouter - class rice.pastry.standard.StandardRouter.
An implementation of the standard Pastry routing algorithm.
StandardRouter(NodeHandle, RoutingTable, LeafSet, PastrySecurityManager) - Constructor for class rice.pastry.standard.StandardRouter
Constructor.
StandardRouteSetProtocol - class rice.pastry.standard.StandardRouteSetProtocol.
An implementation of a simple route set protocol.
StandardRouteSetProtocol(NodeHandle, PastrySecurityManager, RoutingTable) - Constructor for class rice.pastry.standard.StandardRouteSetProtocol
Constructor.
start() - Method in class rice.p2p.commonapi.testing.CommonAPITest
Method which starts the creation of nodes
start() - Method in class rice.past.testing.DistPASTRegrTest.TestPASTFunctions
Deprecated. Starts running this test.
start() - Method in class rice.pastry.testing.ClosestRegrTest
starts the testing process
start() - Method in class rice.pastry.testing.LeafSetTest
 
start() - Method in class rice.persistence.testing.LRUCacheTest
 
start() - Method in class rice.persistence.testing.MemoryStorageTest
 
start() - Method in class rice.persistence.testing.Test
 
start() - Static method in class rice.scribe.testing.BasicScribeRegrTest
Main entry point for the basic scribe regression test suite.
start() - Static method in class rice.scribe.testing.DirectScribeMaintenanceTest
Main entry point for the test suite.
startTest() - Method in class rice.pastry.multiring.testing.MultiRingPastryRegrTest
 
STATE_USING_TCP - Static variable in class rice.pastry.wire.WireNodeHandle
 
STATE_USING_UDP - Static variable in class rice.pastry.wire.WireNodeHandle
 
STATE_USING_UDP_WAITING_FOR_TCP_DISCONNECT - Static variable in class rice.pastry.wire.WireNodeHandle
 
STATE_USING_UDP_WAITING_TO_DISCONNECT - Static variable in class rice.pastry.wire.WireNodeHandle
 
stepDone() - Method in class rice.p2p.commonapi.testing.CommonAPITest
Method which prints the end of a test section step, with an assumed success.
stepDone(String) - Method in class rice.p2p.commonapi.testing.CommonAPITest
Method which prints the end of a test section step.
stepDone(String) - Method in class rice.persistence.testing.Test
 
stepDone(String, String) - Method in class rice.p2p.commonapi.testing.CommonAPITest
Method which prints the end of a test section step, as well as a message.
stepDone(String, String) - Method in class rice.persistence.testing.Test
 
stepException(Exception) - Method in class rice.p2p.commonapi.testing.CommonAPITest
Method which prints an exception which occured during testing.
stepException(Exception) - Method in class rice.persistence.testing.Test
 
stepStart(String) - Method in class rice.p2p.commonapi.testing.CommonAPITest
Method which prints the beginning of a test section step.
stepStart(String) - Method in class rice.persistence.testing.Test
 
storage - Variable in class rice.p2p.past.PastImpl
 
storage - Variable in class rice.persistence.testing.MemoryStorageTest
 
Storage - interface rice.persistence.Storage.
This interface is the abstraction of something which provides a local storage service, such as a persistence storage service or an in-memory storage service.
StorageManager - class rice.persistence.StorageManager.
This class provides both persistent and caching services to external applications.
StorageManager(IdFactory, Storage, Cache) - Constructor for class rice.persistence.StorageManager
Builds a StorageManager given a Storage object to provide storage services and a Cache object to provide caching services.
storages - Variable in class rice.p2p.past.testing.PastRegrTest
 
store - Variable in class rice.persistence.testing.MemoryStorageTest
 
store(Id, Object) - Method in class rice.rm.testing.RMRegrTestApp
 
store(Id, Serializable, Continuation) - Method in class rice.persistence.MemoryStorage
Stores the object under the key id.
store(Id, Serializable, Continuation) - Method in class rice.persistence.PersistentStorage
Makes the object persistent to disk and stored permanantly If the object is already persistent, this method will simply update the object's serialized image.
store(Id, Serializable, Continuation) - Method in interface rice.persistence.Storage
Stores an object in this storage.
store(Id, Serializable, Continuation) - Method in class rice.persistence.StorageManager
Stores an object in this storage.
Stripe - class rice.p2p.splitstream.Stripe.
This class encapsulates all data about an individual stripe.
STRIPE_BASE - Static variable in class rice.p2p.splitstream.Channel
The default number of stripes to create
Stripe(StripeId, Scribe, Channel) - Constructor for class rice.p2p.splitstream.Stripe
The constructor used when creating a stripe from scratch.
stripeId - Variable in class rice.p2p.splitstream.Stripe
The stripeId for this stripe
StripeId - class rice.p2p.splitstream.StripeId.
This class wraps the nodeId object so we can use type checking and allow more readable and understandable code.
StripeId(Id) - Constructor for class rice.p2p.splitstream.StripeId
Constructor that takes in a nodeId and makes a StripeId
stripes - Variable in class rice.p2p.splitstream.Channel
The list of stripeIds for this channel
subscribe(IScribeApp) - Method in class rice.scribe.Topic
Register an application as a subscriber to this Topic, so that the application receives events related to the Topic.
subscribe(SplitStreamClient) - Method in class rice.p2p.splitstream.Stripe
Adds a client to this stripe - the client will be informed whenever data arrives for this stripe
subscribe(Topic, ScribeClient) - Method in interface rice.p2p.scribe.Scribe
Subscribes the given client to the provided topic.
subscribe(Topic, ScribeClient) - Method in class rice.p2p.scribe.ScribeImpl
Subscribes the given client to the provided topic.
subscribe(Topic, ScribeClient, ScribeContent) - Method in interface rice.p2p.scribe.Scribe
Subscribes the given client to the provided topic.
subscribe(Topic, ScribeClient, ScribeContent) - Method in class rice.p2p.scribe.ScribeImpl
Subscribes the given client to the provided topic.
SubscribeAckMessage - class rice.p2p.scribe.messaging.SubscribeAckMessage.
 
SubscribeAckMessage(NodeHandle, Topic, Id[], int) - Constructor for class rice.p2p.scribe.messaging.SubscribeAckMessage
Constructor which takes a unique integer Id
subscribeFailed - Variable in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribeClient
Whether this client has had a subscribe fail
subscribeFailed(Topic) - Method in interface rice.p2p.scribe.ScribeClient
Informs the client that a subscribe on the given topic failed - the client should retry the subscribe or take appropriate action.
subscribeFailed(Topic) - Method in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribeClient
 
subscribeFailed(Topic) - Method in class rice.p2p.splitstream.Stripe
Informs this client that a subscription failed
SubscribeFailedMessage - class rice.p2p.scribe.messaging.SubscribeFailedMessage.
 
SubscribeFailedMessage(NodeHandle, Topic, int) - Constructor for class rice.p2p.scribe.messaging.SubscribeFailedMessage
Constructor which takes a unique integer Id
subscribeHandler(NodeId, NodeHandle, boolean, Serializable) - Method in class rice.pastry.multiring.MultiRingAppl
 
subscribeHandler(NodeId, NodeHandle, boolean, Serializable) - Method in interface rice.scribe.IScribeApp
Invoked by Scribe after a child is added to or removed from one of the node's children tables.
subscribeHandler(NodeId, NodeHandle, boolean, Serializable) - Method in class rice.scribe.testing.BasicScribeRegrTestApp
up-call invoked by scribe when a node is added/removed to the multicast tree.
subscribeHandler(NodeId, NodeHandle, boolean, Serializable) - Method in class rice.scribe.testing.DirectScribeMaintenanceTestApp
up-call invoked by scribe when a node is added/removed to the multicast tree.
subscribeHandler(NodeId, NodeHandle, boolean, Serializable) - Method in class rice.scribe.testing.DistScribeRegrTestApp
up-call invoked by scribe when a node is added/removed to the multicast tree.
SubscribeLostMessage - class rice.p2p.scribe.messaging.SubscribeLostMessage.
 
SubscribeLostMessage(NodeHandle, Topic, int) - Constructor for class rice.p2p.scribe.messaging.SubscribeLostMessage
Constructor which takes a unique integer Id
SubscribeMessage - class rice.p2p.scribe.messaging.SubscribeMessage.
 
SubscribeMessage(NodeHandle, Topic, Id, int, ScribeContent) - Constructor for class rice.p2p.scribe.messaging.SubscribeMessage
Constructor which takes a unique integer Id
SubscribeMessage(NodeHandle, Topic, int, ScribeContent) - Constructor for class rice.p2p.scribe.messaging.SubscribeMessage
Constructor which takes a unique integer Id
subscriber - Variable in class rice.p2p.scribe.messaging.SubscribeMessage
The original subscriber
subSet(Id, Id) - Method in class rice.pastry.IdSet
return a subset of this set, consisting of the member ids in a given range
subSet(IdRange) - Method in interface rice.p2p.commonapi.IdSet
return a subset of this set, consisting of the member ids in a given range
subSet(IdRange) - Method in class rice.pastry.IdSet
return a subset of this set, consisting of the member ids in a given range
subSet(IdRange) - Method in class rice.pastry.IdSet
return a subset of this set, consisting of the member ids in a given range
subtract(IdRange, boolean) - Method in class rice.pastry.IdRange
subtract the other range from this computes the ranges of keys that are in this but not in o subtracting a range may produce two ranges on the circle; this method produces one such ranges under control of the cwPart parameter
SUCCESS - Static variable in class rice.p2p.commonapi.testing.CommonAPITest
 
SUCCESS - Static variable in class rice.persistence.testing.Test
 
swap(int, int) - Method in class rice.pastry.leafset.SimilarSet
swap two elements

T

Test - class rice.persistence.testing.Test.
This class is a class which tests the Storage class in the rice.persistence package.
test() - Method in class rice.pastry.testing.SinglePingTest
 
Test() - Constructor for class rice.persistence.testing.Test
 
test(NodeHandle) - Method in class rice.pastry.leafset.LeafSet
Test if a put of the given NodeHandle would succeed.
test(NodeHandle) - Method in class rice.pastry.leafset.SimilarSet
Test if a NodeHandle belongs into the set.
testAPI() - Method in class rice.p2p.scribe.testing.ScribeRegrTest
Tests basic publish functionality
testBandwidthUsage() - Method in class rice.p2p.splitstream.testing.SplitStreamRegrTest
 
testBasic() - Method in class rice.p2p.splitstream.testing.SplitStreamRegrTest
Tests routing a Past request to a particular node.
testBasic(int, String) - Method in class rice.p2p.scribe.testing.ScribeRegrTest
Tests basic functionality
testCaching() - Method in class rice.p2p.past.testing.PastRegrTest
Tests the dynamic caching function in Past.
testCumulativeRange() - Method in class rice.pastry.testing.LeafSetTest
 
testExists(Continuation) - Method in class rice.persistence.testing.MemoryStorageTest
 
testFailure(int) - Method in class rice.p2p.splitstream.testing.SplitStreamRegrTest
 
testFailureNotification() - Method in class rice.p2p.scribe.testing.ScribeRegrTest
Tests failure notification
testFetch() - Method in class rice.p2p.past.testing.PastRegrTest
Tests the fetch function in Past.
testIndependence() - Method in class rice.p2p.splitstream.testing.SplitStreamRegrTest
 
testLookupHandles() - Method in class rice.p2p.past.testing.PastRegrTest
Tests the lookup handles function in Past.
testMaintenance() - Method in class rice.p2p.scribe.testing.ScribeRegrTest
Tests basic publish functionality
testMaintenance(int) - Method in class rice.p2p.splitstream.testing.SplitStreamRegrTest
 
TestMessage - class rice.rm.testing.TestMessage.
 
TestMessage(NodeHandle, Address, Credentials) - Constructor for class rice.rm.testing.TestMessage
 
testNonCumulativeRange() - Method in class rice.pastry.testing.LeafSetTest
 
testParameterChecks() - Method in class rice.p2p.past.testing.PastRegrTest
Tests the parameter checking in Past.
TestRecord - class rice.pastry.direct.TestRecord.
 
TestRecord(int, int) - Constructor for class rice.pastry.direct.TestRecord
Constructor.
testRetreival(Continuation) - Method in class rice.persistence.testing.MemoryStorageTest
 
testRouteRequest() - Method in class rice.p2p.past.testing.PastRegrTest
Tests routing a Past request to a particular node.
testRouteRequest() - Method in class rice.past.testing.DistPASTRegrTest
Deprecated. Tests routing a PAST request to a particular node.
testSingleRoot(String) - Method in class rice.p2p.scribe.testing.ScribeRegrTest
 
testVersionControl() - Method in class rice.p2p.past.testing.PastRegrTest
Tests overwriting an exiting object with a new one
thePastryNode - Variable in class rice.pastry.client.PastryAppl
 
TIMEOUT - Static variable in class rice.rm.messaging.RMRequestKeysMsg
The timeout period within which if the response to this message is not received, then the same message is resent.
toByteArray() - Method in interface rice.p2p.commonapi.Id
Returns a (mutable) byte array representing this Id
toByteArray() - Method in class rice.pastry.Id
Returns the byte array representation of this Id
toNodeId() - Method in class rice.pastry.multiring.RingId
Copy the ringId into a new Nodeid
topic - Variable in class rice.p2p.scribe.messaging.ScribeMessage
 
topic - Variable in class rice.p2p.scribe.ScribeImpl.TopicManager
DESCRIBE THE FIELD
topic - Variable in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribeContent
DESCRIBE THE FIELD
topic - Variable in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribeClient
The topic this client is listening for
topic - Variable in class rice.p2p.splitstream.Stripe
The topic corresponding to this stripeId
Topic - class rice.p2p.scribe.Topic.
 
Topic - class rice.scribe.Topic.
 
Topic(Id) - Constructor for class rice.p2p.scribe.Topic
Constructor which takes an Id for this topic
Topic(IdFactory, String) - Constructor for class rice.p2p.scribe.Topic
Constructor which takes a name for this topic
Topic(NodeId, Scribe) - Constructor for class rice.scribe.Topic
Constructs an empty Topic
topicManager(boolean) - Method in class rice.scribe.Topic
Sets the flag indicating whether the current node is topic manager for this topic
topics - Variable in class rice.p2p.scribe.ScribeImpl
the hashtable of topic -> TopicManager
toString() - Method in class rice.p2p.past.messaging.CacheMessage
Returns a string representation of this message
toString() - Method in class rice.p2p.past.messaging.FetchHandleMessage
Returns a string representation of this message
toString() - Method in class rice.p2p.past.messaging.FetchMessage
Returns a string representation of this message
toString() - Method in class rice.p2p.past.messaging.InsertMessage
Returns a string representation of this message
toString() - Method in class rice.p2p.past.messaging.LookupHandlesMessage
Returns a string representation of this message
toString() - Method in class rice.p2p.past.messaging.LookupMessage
Returns a string representation of this message
toString() - Method in class rice.p2p.past.messaging.MessageLostMessage
Returns a string representation of this message
toString() - Method in class rice.p2p.past.testing.PastRegrTest.TestPastContent
 
toString() - Method in class rice.p2p.past.testing.PastRegrTest.VersionedTestPastContent
 
toString() - Method in class rice.p2p.scribe.messaging.SubscribeMessage
Returns a String represneting this message
toString() - Method in class rice.p2p.scribe.testing.ScribeRegrTest.TestScribeContent
DESCRIBE THE METHOD
toString() - Method in class rice.p2p.scribe.Topic
Returns a String representation of this topic
toString() - Method in class rice.p2p.splitstream.ChannelId
 
toString() - Method in class rice.p2p.splitstream.Stripe
Returns a String representation of this Stripe
toString() - Method in class rice.p2p.splitstream.StripeId
 
toString() - Method in class rice.past.messaging.MessageExists
Deprecated. Display this message.
toString() - Method in class rice.past.messaging.MessageFetch
Deprecated. Display this message.
toString() - Method in class rice.past.messaging.MessageInsert
Deprecated. Display this message.
toString() - Method in class rice.past.messaging.MessageLookup
Deprecated. Display this message.
toString() - Method in class rice.past.messaging.MessageReclaim
Deprecated. Display this message.
toString() - Method in class rice.past.messaging.PASTMessage
Deprecated. Force subclasses to implement toString.
toString() - Method in interface rice.past.messaging.PASTMessageID
Deprecated. Returns the string representation of the node.
toString() - Method in class rice.past.messaging.PASTMessageIDImpl
Deprecated. Returns the string representation of the node.
toString() - Method in class rice.pastry.commonapi.PastryEndpointMessage
Returns the String representation of this message
toString() - Method in class rice.pastry.direct.DirectNodeHandle
DESCRIBE THE METHOD
toString() - Method in class rice.pastry.dist.DistNodeHandle
Returns a String representation of this DistNodeHandle.
toString() - Method in class rice.pastry.Id
Returns a string representation of the Id in base 16.
toString() - Method in class rice.pastry.Id.Distance
Returns a string representation of the distance The string is a byte string from most to least significant.
toString() - Method in class rice.pastry.IdRange
Returns a string representation of the range.
toString() - Method in class rice.pastry.IdSet
Returns a string representation of the IdSet.
toString() - Method in class rice.pastry.join.JoinAddress
 
toString() - Method in class rice.pastry.join.JoinRequest
 
toString() - Method in class rice.pastry.leafset.BroadcastLeafSet
 
toString() - Method in class rice.pastry.leafset.LeafSet
Returns a string representation of the leaf set
toString() - Method in class rice.pastry.leafset.LeafSetProtocolAddress
 
toString() - Method in class rice.pastry.leafset.RequestLeafSet
 
toString() - Method in class rice.pastry.multiring.MultiRingPastryNode
 
toString() - Method in class rice.pastry.multiring.RingId
Returns a string representation of the ringId in base 16.
toString() - Method in class rice.pastry.multiring.RingNodeId
 
toString() - Method in class rice.pastry.NodeSet
Returns a string representation of the NodeSet
toString() - Method in class rice.pastry.PastryNode
 
toString() - Method in class rice.pastry.routing.BroadcastRouteRow
 
toString() - Method in class rice.pastry.routing.RequestRouteRow
 
toString() - Method in class rice.pastry.routing.RouteMessage
 
toString() - Method in class rice.pastry.routing.RouteProtocolAddress
 
toString() - Method in class rice.pastry.routing.RouterAddress
 
toString() - Method in class rice.pastry.routing.RoutingTable
produces a String representation of the routing table, showing the number of node handles in each entry
toString() - Method in class rice.pastry.testing.LeafSetTest.TestNodeHandle
 
toString() - Method in class rice.pastry.testing.PingAddress
 
toString() - Method in class rice.pastry.testing.PingMessageNew
 
toString() - Method in class rice.pastry.wire.messaging.datagram.AcknowledgementMessage
 
toString() - Method in class rice.pastry.wire.messaging.datagram.DatagramMessage
 
toString() - Method in class rice.pastry.wire.messaging.datagram.DatagramTransportMessage
 
toString() - Method in class rice.pastry.wire.messaging.datagram.PingMessage
 
toString() - Method in class rice.pastry.wire.messaging.socket.DisconnectMessage
 
toString() - Method in class rice.pastry.wire.messaging.socket.HelloMessage
 
toString() - Method in class rice.pastry.wire.messaging.socket.HelloResponseMessage
 
toString() - Method in class rice.pastry.wire.messaging.socket.SocketTransportMessage
 
toString() - Method in class rice.pastry.wire.WireNodeHandlePool
 
toString() - Method in class rice.rm.messaging.RMMaintenanceMsg
 
toString() - Method in class rice.rm.messaging.RMMessage.KEEntry
 
toString() - Method in class rice.rm.messaging.RMTimeoutMsg
 
toString() - Method in class rice.rm.RMImpl.KEPenEntry
 
toString() - Method in class rice.rm.testing.DistRMRegrTestMessage
 
toString() - Method in class rice.rm.testing.DistRMRegrTestReplicateMessage
 
toString() - Method in class rice.rm.testing.InvariantCheckMsg
 
toString() - Method in class rice.rm.testing.ObjectInsertionMsg
 
toString() - Method in class rice.rm.testing.ObjectRefreshMsg
 
toString() - Method in class rice.rm.testing.ReplicateTimeoutMsg
 
toString() - Method in class rice.scribe.maintenance.MessageScribeMaintenance
 
toString() - Method in class rice.scribe.messaging.MessageAckOnSubscribe
 
toString() - Method in class rice.scribe.messaging.MessageAnycast
 
toString() - Method in class rice.scribe.messaging.MessageCreate
 
toString() - Method in class rice.scribe.messaging.MessageHeartBeat
 
toString() - Method in class rice.scribe.messaging.MessagePublish
 
toString() - Method in class rice.scribe.messaging.MessageReplyFromParent
 
toString() - Method in class rice.scribe.messaging.MessageRequestToParent
 
toString() - Method in class rice.scribe.messaging.MessageSubscribe
 
toString() - Method in class rice.scribe.messaging.MessageUnsubscribe
 
toString() - Method in class rice.scribe.messaging.ScribeMessage
 
toString() - Method in class rice.scribe.testing.DistScribeRegrTestMessage
 
toStringFull() - Method in interface rice.p2p.commonapi.Id
Returns a string representing the full length of this Id.
toStringFull() - Method in class rice.pastry.Id
Returns the complete represntation of this Id, in hex.
toStringImpl() - Method in class rice.pastry.dist.DistNodeHandle
Returns a String representation of this DistNodeHandle.
toStringImpl() - Method in class rice.pastry.rmi.RMINodeHandle
 
toStringImpl() - Method in class rice.pastry.wire.WireNodeHandle
 
toVisit - Variable in class rice.p2p.scribe.messaging.AnycastMessage
the list of nodes which we are going to visit
type() - Method in class rice.pastry.leafset.BroadcastLeafSet
Returns the type of leaf set.

U

uncache(Id, Continuation) - Method in interface rice.persistence.Cache
Removes the object from the list of cached objects.
uncache(Id, Continuation) - Method in class rice.persistence.LRUCache
Removes the object from the list of cached objects.
uncache(Id, Continuation) - Method in class rice.persistence.StorageManager
Removes the object from the list of cached objects.
unstore(Id, Continuation) - Method in class rice.persistence.MemoryStorage
Removes the object from the list of stored objects.
unstore(Id, Continuation) - Method in class rice.persistence.PersistentStorage
Request to remove the object from the list of persistend objects.
unstore(Id, Continuation) - Method in interface rice.persistence.Storage
Removes the object from the list of stored objects.
unstore(Id, Continuation) - Method in class rice.persistence.StorageManager
Removes the object from the list of stored objects.
UNSUBSCRIBE_LIMIT - Static variable in class rice.scribe.testing.DistScribeRegrTest
 
UNSUBSCRIBE_PROBABILITY - Static variable in class rice.scribe.testing.DistScribeRegrTest
 
unsubscribe(IScribeApp) - Method in class rice.scribe.Topic
Unregister an application as a Subscriber to this Topic, so that the application no longer receives events regarding this Topic.
unsubscribe(SplitStreamClient) - Method in class rice.p2p.splitstream.Stripe
Removes a client from this stripe - the client will no longer be informed whenever data arrives for this stripe
unsubscribe(Topic, ScribeClient) - Method in interface rice.p2p.scribe.Scribe
Unsubscribes the given client from the provided topic.
unsubscribe(Topic, ScribeClient) - Method in class rice.p2p.scribe.ScribeImpl
Unsubscribes the given client from the provided topic.
UnsubscribeMessage - class rice.p2p.scribe.messaging.UnsubscribeMessage.
 
UnsubscribeMessage(NodeHandle, Topic) - Constructor for class rice.p2p.scribe.messaging.UnsubscribeMessage
Constructor which takes a unique integer Id
unwrap() - Method in class rice.pastry.routing.RouteMessage
The wrapped message.
Update - Static variable in class rice.pastry.leafset.BroadcastLeafSet
 
update(NodeHandle, boolean) - Method in interface rice.p2p.commonapi.Application
This method is invoked to inform the application that the given node has either joined or left the neighbor set of the local node, as the set would be returned by the neighborSet call.
update(NodeHandle, boolean) - Method in class rice.p2p.past.PastImpl
This method is invoked to inform the application that the given node has either joined or left the neighbor set of the local node, as the set would be returned by the neighborSet call.
update(NodeHandle, boolean) - Method in class rice.p2p.scribe.ScribeImpl
This method is invoked to inform the application that the given node has either joined or left the neighbor set of the local node, as the set would be returned by the neighborSet call.
update(NodeHandle, boolean) - Method in class rice.past.PASTServiceImpl
Deprecated. This method is invoked to inform the application that the given node has either joined or left the neighbor set of the local node, as the set would be returned by the neighborSet call.
update(NodeHandle, boolean) - Method in class rice.pastry.client.CommonAPIAppl
Called by pastry when the neighbor set changes.
update(NodeHandle, boolean) - Method in class rice.pastry.testing.RegrTestApp
 
update(NodeHandle, boolean) - Method in class rice.rm.RMImpl
Implements the main algorithm for keeping the invariant that an object would be stored in k closest nodes to the objectKey while the nodes are coming up or going down.
update(Object) - Method in interface rice.scribe.IScribeObserver
Method called by underlying scribe layer whenever a topic data structure is created implicitly.
update(Object) - Method in class rice.scribe.testing.DirectScribeMaintenanceTestApp
Method called by underlying scribe whenever a topic object is created impliclity.
update(Observable, Object) - Method in class rice.p2p.scribe.ScribeImpl.TopicManager
DESCRIBE THE METHOD
update(Observable, Object) - Method in class rice.pastry.dist.DistNodeHandle
 
update(Observable, Object) - Method in class rice.pastry.leafset.SimilarSet
Is called by the Observer pattern whenever the liveness or proximity of a registered node handle is changed.
update(Observable, Object) - Method in class rice.pastry.routing.RouteSet
Is called by the Observer pattern whenever the liveness or proximity of a registered node handle is changed.
update(Observable, Object) - Method in class rice.pastry.routing.RoutingTable
Is called by the Observer pattern whenever a RouteSet in this table has changed.
update(Observable, Object) - Method in class rice.pastry.standard.StandardRouteSetProtocol
Observer update.
update(WireNodeHandle) - Method in class rice.pastry.wire.SocketManager
Method which is designed to be called whenever a node has network activity.
updateNumKeys(int) - Method in class rice.rm.RMImpl.KEPenEntry
 
updatePendingRange(NodeId, IdRange, int) - Method in class rice.rm.RMImpl
Used to update the state of a pending range to the m_pendingRanges hashtable.

V

verifyAddressBinding(Credentials, Address) - Method in class rice.pastry.direct.DirectSecurityManager
Checks to see if these credentials can be associated with the address.
verifyAddressBinding(Credentials, Address) - Method in class rice.pastry.rmi.RMIPastrySecurityManager
Checks to see if these credentials can be associated with the address.
verifyAddressBinding(Credentials, Address) - Method in interface rice.pastry.security.PastrySecurityManager
Checks to see if these credentials can be associated with the address.
verifyAddressBinding(Credentials, Address) - Method in class rice.pastry.security.PermissiveSecurityManager
 
verifyAddressBinding(Credentials, Address) - Method in class rice.pastry.wire.WirePastrySecurityManager
Checks to see if these credentials can be associated with the address.
verifyApplication(List, MRTracker, MRTracker) - Method in class rice.scribe.testing.BasicScribeRegrTestApp
This makes sure that if the current app was subscribed to a topic, it received all the messages published to it.
verifyCanCreate(NodeHandle, NodeId) - Method in interface rice.scribe.security.IScribeSecurityManager
Verify that the node handle has permission to create a topic.
verifyCanCreate(NodeHandle, NodeId) - Method in class rice.scribe.security.PSecurityManager
Verify that the node handle has permission to create a topic.
verifyCanPublish(NodeHandle, NodeId) - Method in interface rice.scribe.security.IScribeSecurityManager
Verify that the node handle has permission to publish to a topic.
verifyCanPublish(NodeHandle, NodeId) - Method in class rice.scribe.security.PSecurityManager
Verify that the node handle has permission to publish to a topic.
verifyCanSubscribe(NodeHandle, NodeId) - Method in interface rice.scribe.security.IScribeSecurityManager
Verify that the node handle has permission to subscribe to a topic.
verifyCanSubscribe(NodeHandle, NodeId) - Method in class rice.scribe.security.PSecurityManager
Verify that the node handle has permission to subscribe to a topic.
verifyMessage(Message) - Method in class rice.pastry.direct.DirectSecurityManager
This method takes a message and returns true if the message is safe and false otherwise.
verifyMessage(Message) - Method in class rice.pastry.rmi.RMIPastrySecurityManager
This method takes a message and returns true if the message is safe and false otherwise.
verifyMessage(Message) - Method in interface rice.pastry.security.PastrySecurityManager
This method takes a message and returns true if the message is safe and false otherwise.
verifyMessage(Message) - Method in class rice.pastry.security.PermissiveSecurityManager
 
verifyMessage(Message) - Method in class rice.pastry.wire.WirePastrySecurityManager
This method takes a message and returns true if the message is safe and false otherwise.
verifyNodeHandle(NodeHandle) - Method in class rice.pastry.direct.DirectSecurityManager
Verify node handle safety.
verifyNodeHandle(NodeHandle) - Method in class rice.pastry.rmi.RMIPastrySecurityManager
Verify node handle safety.
verifyNodeHandle(NodeHandle) - Method in interface rice.pastry.security.PastrySecurityManager
Verify node handle safety.
verifyNodeHandle(NodeHandle) - Method in class rice.pastry.security.PermissiveSecurityManager
 
verifyNodeHandle(NodeHandle) - Method in class rice.pastry.wire.WirePastrySecurityManager
Verify node handle safety.
version - Variable in class rice.p2p.past.testing.PastRegrTest.VersionedTestPastContent
 
visited - Variable in class rice.p2p.scribe.messaging.AnycastMessage
the list of nodes which we have visited

W

waitUnsubscribe(boolean) - Method in class rice.scribe.Topic
Sets flag indicating if the local node is waiting to be unsubscribed from this topic (because it does not yet know its parent)
wakeup() - Method in class rice.pastry.wire.DatagramManager
Called by the SelectorManager whenever it is awoken.
wakeup() - Method in class rice.pastry.wire.DatagramTransmissionManager
Designed to be called periodically in order for the Transmission Manager to decide if a packet has been lost.
wakeup() - Method in interface rice.pastry.wire.SelectionKeyHandler
Method which is called when every time the SelectorManager is woken up.
wakeup() - Method in class rice.pastry.wire.SocketManager
Specified by the SelectionKeyHandler interface - does nothing.
wakeup() - Method in class rice.pastry.wire.WireNodeHandle
Is called by the SelectorManager every time the manager is awakened.
wasAdded() - Method in class rice.pastry.NodeSetUpdate
Returns true if the handle was added to the set.
WireNodeHandle - class rice.pastry.wire.WireNodeHandle.
Class which represents a node handle in the socket-based pastry protocol.
WireNodeHandle(InetSocketAddress, NodeId) - Constructor for class rice.pastry.wire.WireNodeHandle
Constructor.
WireNodeHandle(InetSocketAddress, NodeId, PastryNode) - Constructor for class rice.pastry.wire.WireNodeHandle
Alternate constructor with local Pastry node.
WireNodeHandlePool - class rice.pastry.wire.WireNodeHandlePool.
The WireNodeHandlePool controls all of the node handles in use by the WirePastryNode.
WireNodeHandlePool(WirePastryNode) - Constructor for class rice.pastry.wire.WireNodeHandlePool
Constructor.
WirePastryNode - class rice.pastry.wire.WirePastryNode.
An Socket-based Pastry node, which has two threads - one thread for performing route set and leaf set maintainance, and another thread for listening on the sockets and performing all non-blocking I/O.
WirePastryNode(NodeId) - Constructor for class rice.pastry.wire.WirePastryNode
Constructor
WirePastryNodeFactory - class rice.pastry.wire.WirePastryNodeFactory.
Pastry node factory for Wire-linked nodes.
WirePastryNodeFactory(NodeIdFactory, int) - Constructor for class rice.pastry.wire.WirePastryNodeFactory
Constructor.
WirePastrySecurityManager - class rice.pastry.wire.WirePastrySecurityManager.
Security manager for wire connections between nodes.
WirePastrySecurityManager(WireNodeHandle, WireNodeHandlePool) - Constructor for class rice.pastry.wire.WirePastrySecurityManager
Constructor.
write(NodeId, InetSocketAddress, Object) - Method in class rice.pastry.wire.DatagramManager
Method designed for node handles to use when they wish to write to their remote node.
write(SelectionKey) - Method in class rice.pastry.wire.DatagramManager
Specified by the SelectionKeyHandler interface - is called when there is space in the DatagramChannel's buffer to write some data.
write(SelectionKey) - Method in interface rice.pastry.wire.SelectionKeyHandler
Method which is called when the key becomes writable.
write(SelectionKey) - Method in class rice.pastry.wire.SocketManager
Specified by the SelectionKeyHandler interface - should NEVER be called!
write(SelectionKey) - Method in class rice.pastry.wire.WireNodeHandle
Called by the socket manager whenever this node handle has registered interest in writing to it's remote node, and the socket is ready for writing.
write(SocketChannel) - Method in class rice.pastry.wire.SocketChannelWriter
Method which is designed to be called when this writer should write out its data.

X

xor(Id) - Method in class rice.pastry.Id
Xor operator for Ids.

_

_content - Variable in class rice.past.messaging.MessageFetch
Deprecated. Content to be returned
_content - Variable in class rice.past.messaging.MessageLookup
Deprecated. Content to be returned
_exists - Variable in class rice.past.messaging.MessageExists
Deprecated. Content to be returned
_file - Variable in class rice.past.messaging.MessageInsert
Deprecated. The file to insert.
_fileId - Variable in class rice.past.messaging.PASTMessage
Deprecated. The fileId of the file, to be used as destination.
_handleResponseMessage(PASTMessage) - Method in class rice.past.PASTServiceImpl
Deprecated. Receives a response message after a request has been sent and gives it to the appropriate command.
_messageID - Variable in class rice.past.messaging.PASTMessage
Deprecated. A key for uniquely identifying the message.
_messageType - Variable in class rice.past.messaging.PASTMessage
Deprecated. Whether this is a request or a response.
_senderId - Variable in class rice.past.messaging.PASTMessage
Deprecated. The id of the sender
_sendOptions - Variable in class rice.rm.RMImpl
The SendOptions object to be used for all messaging through Pastry.
_sendOptions - Variable in class rice.rm.testing.RMRegrTestApp
 
_sendRequestMessage(PASTMessage, Continuation) - Method in class rice.past.PASTServiceImpl
Deprecated. Sends a request message and stores the given command to be executed when the response is received.
_seqno - Variable in class rice.rm.messaging.RMMessage
for debugging purposes only
_source - Variable in class rice.rm.messaging.RMMessage
The ID of the source of this message.
_source - Variable in class rice.rm.testing.TestMessage
The ID of the source of this message.
_success - Variable in class rice.past.messaging.MessageInsert
Deprecated. Whether the insert was successful (on a response).
_success - Variable in class rice.past.messaging.MessageReclaim
Deprecated. Whether the reclaim request was successful

A B C D E F G H I J K L M N O P R S T U V W X _
Rice Pastry API

Copyright © 2001 - Rice Pastry.


Imprint-Dataprotection