Skip navigation links
A B C D E F G H I J K L M N O P R S T U V W 

A

AbortRequest - Class in edu.umass.cs.txn.txpackets
 
AbortRequest(String) - Constructor for class edu.umass.cs.txn.txpackets.AbortRequest
 
AbortRequest(String, String) - Constructor for class edu.umass.cs.txn.txpackets.AbortRequest
 
AbortRequest(String, String, String) - Constructor for class edu.umass.cs.txn.txpackets.AbortRequest
 
AbortRequest(JSONObject) - Constructor for class edu.umass.cs.txn.txpackets.AbortRequest
 
AbstractDemandProfile - Class in edu.umass.cs.reconfiguration.reconfigurationutils
 
AbstractDemandProfile(String) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.AbstractDemandProfile
 
AbstractDemandProfile.Keys - Enum in edu.umass.cs.reconfiguration.reconfigurationutils
 
AbstractJSONPacketDemultiplexer - Class in edu.umass.cs.nio
 
AbstractJSONPacketDemultiplexer(int) - Constructor for class edu.umass.cs.nio.AbstractJSONPacketDemultiplexer
 
AbstractJSONPacketDemultiplexer() - Constructor for class edu.umass.cs.nio.AbstractJSONPacketDemultiplexer
 
AbstractNIOSSL - Class in edu.umass.cs.nio
 
AbstractNIOSSL(SelectionKey, SSLEngine, Executor, String) - Constructor for class edu.umass.cs.nio.AbstractNIOSSL
 
AbstractPacketDemultiplexer<MessageType> - Class in edu.umass.cs.nio
 
AbstractPacketDemultiplexer(int) - Constructor for class edu.umass.cs.nio.AbstractPacketDemultiplexer
 
AbstractPacketDemultiplexer() - Constructor for class edu.umass.cs.nio.AbstractPacketDemultiplexer
 
AbstractPacketDemultiplexer.Tasker - Class in edu.umass.cs.nio
 
AbstractPaxosLogger - Class in edu.umass.cs.gigapaxos
 
AbstractPaxosLogger(int, String, PaxosMessenger<?>) - Constructor for class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
AbstractPaxosLogger.CheckpointTask - Class in edu.umass.cs.gigapaxos
 
AbstractPaxosLogger.PaxosPacketizer - Class in edu.umass.cs.gigapaxos
 
AbstractPaxosLogger.PaxosPacketStringifier - Class in edu.umass.cs.gigapaxos
 
AbstractPaxosManager<NodeIdType> - Class in edu.umass.cs.gigapaxos.deprecated
Deprecated.
AbstractPaxosManager() - Constructor for class edu.umass.cs.gigapaxos.deprecated.AbstractPaxosManager
Deprecated.
 
AbstractReconfigurablePaxosApp<NodeIDType> - Class in edu.umass.cs.reconfiguration.examples
 
AbstractReconfigurablePaxosApp() - Constructor for class edu.umass.cs.reconfiguration.examples.AbstractReconfigurablePaxosApp
 
AbstractReconfiguratorDB<NodeIDType> - Class in edu.umass.cs.reconfiguration
 
AbstractReconfiguratorDB(NodeIDType, ConsistentReconfigurableNodeConfig<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
AbstractReconfiguratorDB.RecordNames - Enum in edu.umass.cs.reconfiguration
Constant RC record name keys.
AbstractReplicaCoordinator<NodeIDType> - Class in edu.umass.cs.reconfiguration
 
AbstractReplicaCoordinator(Replicable) - Constructor for class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
AbstractReplicaCoordinator(Replicable, Messenger<NodeIDType, ?>) - Constructor for class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
AbstractReplicaCoordinatorPersistent<NodeIDType> - Class in edu.umass.cs.reconfiguration.deprecated
 
AbstractReplicaCoordinatorPersistent(Replicable, JSONMessenger<NodeIDType>, Stringifiable<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.deprecated.AbstractReplicaCoordinatorPersistent
 
AbstractTransactor<NodeIDType> - Class in edu.umass.cs.txn
 
AbstractTransactor(AbstractReplicaCoordinator<NodeIDType>) - Constructor for class edu.umass.cs.txn.AbstractTransactor
 
accBallot - Variable in class edu.umass.cs.gigapaxos.paxosutil.HotRestoreInfo
Ballot corresponding to most recent executed request.
acceptAndUpdateBallot(AcceptPacket, int) - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
accepted - Variable in class edu.umass.cs.gigapaxos.paxospackets.PrepareReplyPacket
Accepted pvalues from lower ballots.
acceptor - Variable in class edu.umass.cs.gigapaxos.paxospackets.AcceptReplyPacket
Sender node ID.
acceptor - Variable in class edu.umass.cs.gigapaxos.paxospackets.PrepareReplyPacket
Node ID of replier.
AcceptPacket - Class in edu.umass.cs.gigapaxos.paxospackets
 
AcceptPacket(int, PValuePacket, int) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.AcceptPacket
 
AcceptPacket(JSONObject) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.AcceptPacket
 
AcceptPacket(JSONObject) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.AcceptPacket
 
AcceptPacket(ByteBuffer) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.AcceptPacket
 
AcceptPacket(byte[]) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.AcceptPacket
 
AcceptReplyPacket - Class in edu.umass.cs.gigapaxos.paxospackets
 
AcceptReplyPacket(int, Ballot, int, int, long, AcceptReplyPacket) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.AcceptReplyPacket
 
AcceptReplyPacket(int, Ballot, int, int) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.AcceptReplyPacket
 
AcceptReplyPacket(int, Ballot, int, int, long) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.AcceptReplyPacket
 
AcceptReplyPacket(JSONObject) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.AcceptReplyPacket
 
AcceptReplyPacket(ByteBuffer) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.AcceptReplyPacket
 
accepts101 - Static variable in class edu.umass.cs.gigapaxos.testing.TESTPaxosShutdownThread
 
accepts102 - Static variable in class edu.umass.cs.gigapaxos.testing.TESTPaxosShutdownThread
 
accGCSlot - Variable in class edu.umass.cs.gigapaxos.paxosutil.HotRestoreInfo
Slot up to which acceptor can garbage collect logged messages.
accSlot - Variable in class edu.umass.cs.gigapaxos.paxosutil.HotRestoreInfo
Next unused request slot at acceptor.
AckDropEpochFinalState<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
AckDropEpochFinalState(NodeIDType, DropEpochFinalState<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.AckDropEpochFinalState
 
AckDropEpochFinalState(JSONObject, Stringifiable<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.AckDropEpochFinalState
 
AckStartEpoch<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
AckStartEpoch(NodeIDType, String, int, NodeIDType) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.AckStartEpoch
 
AckStartEpoch(JSONObject, Stringifiable<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.AckStartEpoch
 
AckStopEpoch<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
AckStopEpoch(NodeIDType, StopEpoch<NodeIDType>, String) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.AckStopEpoch
 
AckStopEpoch(NodeIDType, StopEpoch<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.AckStopEpoch
 
AckStopEpoch(JSONObject, Stringifiable<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.AckStopEpoch
 
ActivePaxosState - Class in edu.umass.cs.gigapaxos.paxosutil
Deprecated.
ActivePaxosState(String) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.ActivePaxosState
Deprecated.
 
ActiveReplica<NodeIDType> - Class in edu.umass.cs.reconfiguration
 
ActiveReplica(AbstractReplicaCoordinator<NodeIDType>, ReconfigurableNodeConfig<NodeIDType>, SSLMessenger<NodeIDType, ?>) - Constructor for class edu.umass.cs.reconfiguration.ActiveReplica
 
ActiveReplicaError - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
ActiveReplicaError(InetSocketAddress, String, long) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.ActiveReplicaError
 
ActiveReplicaError(String, long, ClientReconfigurationPacket) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.ActiveReplicaError
 
ActiveReplicaError(JSONObject) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.ActiveReplicaError
 
ActiveReplicaError(JSONObject, Stringifiable<?>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.ActiveReplicaError
 
ActiveReplicaProtocolTask<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationprotocoltasks
 
ActiveReplicaProtocolTask(NodeIDType, Stringifiable<NodeIDType>, ActiveReplica<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.ActiveReplicaProtocolTask
 
add(int, int, int, int, String, long, int) - Method in class edu.umass.cs.gigapaxos.paxosutil.LogIndex
 
add(LogIndex.LogIndexEntry) - Method in class edu.umass.cs.gigapaxos.paxosutil.LogIndex
 
add(NodeIDType, InetAddress) - Method in class edu.umass.cs.nio.nioutils.SampleNodeConfig
Add node with id mapped to IP and an auto-selected port number.
addAccept(AcceptPacket) - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedAccept
 
addAcceptReply(AcceptReplyPacket) - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedAcceptReply
 
addActiveReplica(Node, InetSocketAddress) - Method in interface edu.umass.cs.reconfiguration.interfaces.ModifiableActiveConfig
 
addActiveReplica(NodeIDType, InetSocketAddress, int) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
 
addActiveReplica(NodeIDType, InetSocketAddress) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
addActiveReplica(NodeIDType, InetSocketAddress) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DefaultNodeConfig
 
addActiveReplica(NodeIDType, InetSocketAddress) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.SimpleReconfiguratorNodeConfig
 
addActiveReplica(NodeIDType, InetSocketAddress, int) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
addBatchedAccept(BatchedAccept) - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedAccept
 
addBatchedCommit(BatchedCommit) - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedCommit
 
addCommit(PValuePacket) - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedCommit
 
addDebugInfo(String) - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
addDebugInfo(String, int) - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
addDebugInfo(JSONObject, String, int) - Static method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
addDebugInfoDeep(String) - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
addDebugInfoDeep(String, int) - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
addLocal(NodeIDType) - Method in class edu.umass.cs.nio.nioutils.SampleNodeConfig
 
addNotifiee(NodeIDType, String) - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitEpochFinalState
 
addPacketDemultiplexer(AbstractPacketDemultiplexer<?>) - Method in interface edu.umass.cs.nio.interfaces.InterfaceMessageExtractor
 
addPacketDemultiplexer(AbstractPacketDemultiplexer<?>) - Method in interface edu.umass.cs.nio.interfaces.InterfaceNIOTransport
 
addPacketDemultiplexer(AbstractPacketDemultiplexer<?>) - Method in class edu.umass.cs.nio.IOSSSLDataProcessingWorker
 
addPacketDemultiplexer(AbstractPacketDemultiplexer<?>) - Method in class edu.umass.cs.nio.JSONMessenger
 
addPacketDemultiplexer(AbstractPacketDemultiplexer<?>) - Method in class edu.umass.cs.nio.MessageExtractor
Note: Use with care.
addPacketDemultiplexer(AbstractPacketDemultiplexer<?>) - Method in class edu.umass.cs.nio.MessageNIOTransport
 
addPacketDemultiplexer(AbstractPacketDemultiplexer<?>) - Method in class edu.umass.cs.nio.SSLDataProcessingWorker
 
addReconfigurator(NodeIDType, InetSocketAddress) - Method in interface edu.umass.cs.reconfiguration.interfaces.ModifiableRCConfig
 
addReconfigurator(NodeIDType, InetSocketAddress, int) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
 
addReconfigurator(NodeIDType, InetSocketAddress) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
addReconfigurator(NodeIDType, InetSocketAddress) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DefaultNodeConfig
 
addReconfigurator(NodeIDType, InetSocketAddress) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.SimpleReconfiguratorNodeConfig
 
addReconfigurator(NodeIDType, InetSocketAddress, int) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
AddressMessenger<MessageType> - Interface in edu.umass.cs.nio.interfaces
 
addrToInt(InetAddress) - Static method in class edu.umass.cs.nio.nioutils.RTTEstimator
 
addrToPrefixInt(InetAddress) - Static method in class edu.umass.cs.nio.nioutils.RTTEstimator
 
addServers(Set<NodeIDType>) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
addStopNotifiee(StopEpoch<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.CallbackMap
 
addToMerge(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
addToOutstanding(String) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
afterMethod() - Method in class edu.umass.cs.utils.DefaultTest
 
afterTestMethod() - Method in class edu.umass.cs.reconfiguration.testing.TESTRCDebug
Deprecated.
 
AggregateDemandProfiler - Class in edu.umass.cs.reconfiguration.reconfigurationutils
 
AggregateDemandProfiler(ReconfigurableAppInfo) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.AggregateDemandProfiler
 
AggregateDemandProfiler() - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.AggregateDemandProfiler
 
aggressiveDeletionsAllowed() - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
aggressiveReconfigurationsAllowed() - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
allClientTests() - Method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationMain
 
allInt() - Static method in class edu.umass.cs.gigapaxos.paxosutil.IntegerMap
 
ALPHA - Static variable in class edu.umass.cs.utils.Util
 
alreadyHeardFrom(int) - Method in class edu.umass.cs.gigapaxos.paxosutil.WaitforUtility
 
alreadyHeardFrom(NodeIDType) - Method in class edu.umass.cs.utils.Waitfor
 
amAffected(NodeIDType) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
amObviated() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStartEpoch
 
amObviated() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStopEpoch
 
amObviated() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitPrimaryExecution
 
app - Variable in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
app - Variable in class edu.umass.cs.reconfiguration.reconfigurationutils.TrivialRepliconfigurable
The underlying app.
app - Variable in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
append(PaxosPacket) - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedPaxosPacket
 
append(PaxosPacket[]) - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedPaxosPacket
 
AppInstrumenter - Class in edu.umass.cs.reconfiguration.reconfigurationutils
 
AppInstrumenter() - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.AppInstrumenter
 
Application - Interface in edu.umass.cs.gigapaxos.deprecated
 
Application - Interface in edu.umass.cs.gigapaxos.interfaces
 
application - Static variable in class edu.umass.cs.gigapaxos.PaxosConfig
Paxos controlled application.
application - Static variable in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
apply(Statement, Description) - Method in class edu.umass.cs.utils.RepeatRule
 
appName - Static variable in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
AppRequest - Class in edu.umass.cs.reconfiguration.examples
 
AppRequest(String, String, IntegerPacketType, boolean) - Constructor for class edu.umass.cs.reconfiguration.examples.AppRequest
 
AppRequest(String, int, long, String, IntegerPacketType, boolean) - Constructor for class edu.umass.cs.reconfiguration.examples.AppRequest
 
AppRequest(String, long, String, IntegerPacketType, boolean) - Constructor for class edu.umass.cs.reconfiguration.examples.AppRequest
 
AppRequest(String, AppRequest) - Constructor for class edu.umass.cs.reconfiguration.examples.AppRequest
 
AppRequest(JSONObject) - Constructor for class edu.umass.cs.reconfiguration.examples.AppRequest
 
AppRequest.Keys - Enum in edu.umass.cs.reconfiguration.examples
These app keys by design need not be the same as those in BasicReconfigurationPacket
AppRequest.PacketType - Enum in edu.umass.cs.reconfiguration.examples
Packet type class for NoopApp requests.
AppRequest.ResponseCodes - Enum in edu.umass.cs.reconfiguration.examples
 
AppRequestParser - Interface in edu.umass.cs.gigapaxos.interfaces
 
AppRequestParserBytes - Interface in edu.umass.cs.gigapaxos.interfaces
 
areMergesAllDone() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
areRCChangesCompleteDebug() - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
arrayOfIntToString(int[]) - Static method in class edu.umass.cs.utils.Util
 
arrayOfIntToStringSet(int[]) - Static method in class edu.umass.cs.utils.Util
 
arrayOfObjectsToStringSet(Object[]) - Static method in class edu.umass.cs.utils.Util
 
arrayToIntSet(int[]) - Static method in class edu.umass.cs.utils.Util
 
assertAssertionsEnabled() - Static method in class edu.umass.cs.utils.Util
 
assertEnabled() - Method in class edu.umass.cs.utils.Util
 
assertPacketTypeChecks(ReconfigurationPacket.PacketType[], Class<?>, String) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
 
assertPacketTypeChecks(Map<ReconfigurationPacket.PacketType, Class<?>>, Class<?>, String) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
 
assertPacketTypeChecks(ReconfigurationPacket.PacketType, String, Class<?>, String) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
 
assertPacketTypeChecks(Map<ReconfigurationPacket.PacketType, Class<?>>, Class<?>) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
 
assertRSMInvariant(String) - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosMain
 
assertSlotInvariant() - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
autoInvokeMethod(Object, BasicReconfigurationPacket<?>, boolean, Stringifiable<?>) - Static method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
autoInvokeMethod(Object, ProtocolEvent<ReconfigurationPacket.PacketType, String>, ProtocolTask<?, ReconfigurationPacket.PacketType, String>[]) - Static method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.ReconfiguratorProtocolTask
 

B

ballot - Variable in class edu.umass.cs.gigapaxos.paxospackets.AcceptReplyPacket
Ballot in the ACCEPT request being replied to.
ballot - Variable in class edu.umass.cs.gigapaxos.paxospackets.BatchedAccept
 
ballot - Variable in class edu.umass.cs.gigapaxos.paxospackets.BatchedCommit
Note: The order of the fields can not be changed.
ballot - Variable in class edu.umass.cs.gigapaxos.paxospackets.PreparePacket
Ballot in the PREPARE message.
ballot - Variable in class edu.umass.cs.gigapaxos.paxospackets.PrepareReplyPacket
Ballot of the PREPARE being replied to.
ballot - Variable in class edu.umass.cs.gigapaxos.paxospackets.PValuePacket
A ballot is a <ballotNumber:ballotCoordinator> two-tuple.
ballot - Variable in class edu.umass.cs.gigapaxos.paxospackets.StatePacket
Ballot in which the request at the checkpointed slot was committed.
Ballot - Class in edu.umass.cs.gigapaxos.paxosutil
 
Ballot(int, int) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.Ballot
 
Ballot(String) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.Ballot
 
ballotnum - Variable in class edu.umass.cs.gigapaxos.paxosutil.SlotBallotState
 
ballotNumber - Variable in class edu.umass.cs.gigapaxos.paxosutil.Ballot
Ballot number that increases monotonically at acceptors for a given coordinator ID.
BasicReconfigurationPacket<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
BasicReconfigurationPacket(NodeIDType, ReconfigurationPacket.PacketType, String, int) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.BasicReconfigurationPacket
 
BasicReconfigurationPacket(JSONObject, Stringifiable<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.BasicReconfigurationPacket
 
BasicReconfigurationPacket.Keys - Enum in edu.umass.cs.reconfiguration.reconfigurationpackets
 
BatchedAccept - Class in edu.umass.cs.gigapaxos.paxospackets
 
BatchedAccept(AcceptPacket, Set<Integer>) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.BatchedAccept
 
BatchedAccept(JSONObject) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.BatchedAccept
 
BatchedAcceptReply - Class in edu.umass.cs.gigapaxos.paxospackets
 
BatchedAcceptReply(AcceptReplyPacket) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.BatchedAcceptReply
 
BatchedAcceptReply(JSONObject) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.BatchedAcceptReply
 
BatchedAcceptReply(ByteBuffer) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.BatchedAcceptReply
 
BatchedCommit - Class in edu.umass.cs.gigapaxos.paxospackets
 
BatchedCommit(PValuePacket, Set<Integer>) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.BatchedCommit
 
BatchedCommit(JSONObject) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.BatchedCommit
 
BatchedCommit(ByteBuffer) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.BatchedCommit
 
BatchedCreateServiceName - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
BatchedCreateServiceName(InetSocketAddress, String, int, String) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.BatchedCreateServiceName
 
BatchedCreateServiceName(InetSocketAddress, String[], int, String[]) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.BatchedCreateServiceName
 
BatchedCreateServiceName(JSONObject) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.BatchedCreateServiceName
 
BatchedCreateServiceName(JSONObject, Stringifiable<?>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.BatchedCreateServiceName
 
BatchedCreateServiceName.BatchKeys - Enum in edu.umass.cs.reconfiguration.reconfigurationpackets
 
BatchedCreateServiceNameTest - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
BatchedCreateServiceNameTest() - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.BatchedCreateServiceNameTest
 
BatchedPaxosPacket - Class in edu.umass.cs.gigapaxos.paxospackets
 
BatchedPaxosPacket(PaxosPacket) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.BatchedPaxosPacket
 
BatchedPaxosPacket(PaxosPacket[]) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.BatchedPaxosPacket
 
BatchedPaxosPacket(JSONObject) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.BatchedPaxosPacket
 
BatchedPaxosPacket(JSONObject) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.BatchedPaxosPacket
 
batchSize() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
beforeMethod() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationPolicyTest
 
beforeMethod() - Method in class edu.umass.cs.utils.DefaultTest
 
beforeTestMethod() - Method in class edu.umass.cs.reconfiguration.testing.TESTRCDebug
Deprecated.
 
Byteable - Interface in edu.umass.cs.nio.interfaces
 
BYTEIFICATION - Static variable in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
BYTES - Static variable in class edu.umass.cs.nio.nioutils.NIOHeader
Size in bytes.
bytesToLong(byte[]) - Static method in class edu.umass.cs.utils.Util
 

C

Callback<R,V> - Interface in edu.umass.cs.gigapaxos.interfaces
 
callback(AcceptPacket) - Method in class edu.umass.cs.gigapaxos.paxosutil.PendingDigests.PendingDigestCallback
 
callbackGC(Object, Object) - Method in interface edu.umass.cs.utils.GCConcurrentHashMapCallback
 
CallbackMap<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationutils
 
CallbackMap() - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.CallbackMap
 
callCallback(Request, boolean, ExecutedCallback) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
cancel(ProtocolTask<?, ?, ?>) - Static method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
canSync(long) - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
canSync() - Method in class edu.umass.cs.gigapaxos.paxosutil.ActivePaxosState
Deprecated.
 
capacity() - Method in class edu.umass.cs.utils.MultiArrayMap
 
caughtUp() - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
caughtUp() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
caughtUp(PaxosCoordinator) - Static method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
caughtUp() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
changeActiveDBNodeConfig(int) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
changeDBNodeConfig(int) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
CHARSET - Static variable in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
CHARSET - Static variable in class edu.umass.cs.gigapaxos.SQLPaxosLogger
Encoding used by the logger.
CHARSET - Static variable in class edu.umass.cs.nio.nioutils.NIOHeader
Character set used by NIO for encoding bytes to String and back.
CHARSET - Variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
Default charset used to encode this packet to bytes.
CHARSET - Static variable in class edu.umass.cs.utils.Stringer
Default encoding.
checkConnectivity(long, InetSocketAddress) - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
Connectivity check with reconfigurator address that will block for up to timeout duration.
checkConnectivity(long, int, InetSocketAddress) - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
Connectivity check that will be attempted up to numAttempts times each with a timeout of attemptTimeout with the reconfigurator address.
checkConnectivity() - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
A connectivity check with every known reconfigurator each with a default timeout of ReconfigurableAppClientAsync.CONNECTIVITY_CHECK_TIMEOUT.
checkpoint(AbstractPaxosLogger, boolean, String, int, Set<String>, int, Ballot, String, int) - Static method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
checkpoint() - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger.CheckpointTask
 
checkpoint(String) - Method in class edu.umass.cs.gigapaxos.deprecated.DefaultPaxosInterfaceApp
 
checkpoint(String) - Method in interface edu.umass.cs.gigapaxos.deprecated.ReplicableDeprecated
 
checkpoint(String) - Method in class edu.umass.cs.gigapaxos.examples.noop.NoopPaxosApp
 
checkpoint(String) - Method in interface edu.umass.cs.gigapaxos.interfaces.Replicable
Checkpoints the current application state and returns it.
checkpoint(String) - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosApp
 
checkpoint(String) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
checkpoint(String) - Method in class edu.umass.cs.reconfiguration.examples.noop.NoopApp
 
checkpoint(String) - Method in class edu.umass.cs.reconfiguration.examples.noopsimple.NoopApp
 
checkpoint(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.TrivialRepliconfigurable
 
checkpoint(String) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
Incomplete paxos methods below
checkpoint(String) - Method in class edu.umass.cs.reconfiguration.testing.NoopAppTesting
 
checkpoint(String) - Method in class edu.umass.cs.txn.AbstractTransactor
 
checkpoint(String) - Method in class edu.umass.cs.txn.testing.NoopAppTX
 
checkSameGroup(Set<String>) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
ClassFinder - Class in edu.umass.cs.utils
 
ClassFinder() - Constructor for class edu.umass.cs.utils.ClassFinder
 
clean() - Method in class edu.umass.cs.nio.AbstractNIOSSL
 
cleanup(SelectionKey) - Static method in class edu.umass.cs.nio.NIOTransport
 
cleanup() - Static method in class edu.umass.cs.reconfiguration.testing.ReconfigurableAppCapacityTest
Removes all account and sub-guids created during the test.
clear() - Method in class edu.umass.cs.nio.nioutils.SampleNodeConfig
 
clear() - Static method in class edu.umass.cs.utils.DelayProfiler
 
clear() - Method in class edu.umass.cs.utils.DiskMap
 
clear() - Method in class edu.umass.cs.utils.MultiArrayMap
Resets the map.
clear() - Method in class edu.umass.cs.utils.NullIfEmptyMap
 
clearMerged(String, int) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
Clear all merged state in RC record.
clearMerged() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
clearMerged(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
clearMerged(String, int) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
CLIENT_REQ_RTX_TIMEOUT - Static variable in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
default retransmission timeout
CLIENT_REQ_RTX_TIMEOUT - Static variable in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationConfig
default retransmission timeout
ClientMessenger - Interface in edu.umass.cs.gigapaxos.interfaces
 
clientPacketTypes - Static variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
 
ClientReconfigurationPacket - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
ClientReconfigurationPacket(InetSocketAddress, ReconfigurationPacket.PacketType, String, int) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
ClientReconfigurationPacket(InetSocketAddress, ReconfigurationPacket.PacketType, String, int, InetSocketAddress) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
myReceiver may need to be set at creation time in create/delete responses.
ClientReconfigurationPacket(String, ClientReconfigurationPacket) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
ClientReconfigurationPacket(JSONObject, Stringifiable<?>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
ClientReconfigurationPacket(JSONObject) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
ClientReconfigurationPacket.Keys - Enum in edu.umass.cs.reconfiguration.reconfigurationpackets
 
ClientReconfigurationPacket.ResponseCodes - Enum in edu.umass.cs.reconfiguration.reconfigurationpackets
 
ClientRequest - Interface in edu.umass.cs.gigapaxos.interfaces
 
clobToString(Clob) - Static method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
clone() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.AbstractDemandProfile
Deprecated.
clone() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ProximateBalance
 
close() - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
close() - Method in class edu.umass.cs.gigapaxos.FailureDetection
 
close() - Method in class edu.umass.cs.gigapaxos.PaxosClientAsync
 
close() - Method in class edu.umass.cs.gigapaxos.PaxosManager
Gracefully closes PaxosManager.
close() - Method in class edu.umass.cs.gigapaxos.paxosutil.LargeCheckpointer
 
close() - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosNode
 
close() - Method in class edu.umass.cs.reconfiguration.ActiveReplica
For graceful closure.
close() - Method in class edu.umass.cs.reconfiguration.http.HttpReconfigurator
Close server and workers gracefully.
close() - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
Close gracefully.
close() - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
close() - Method in class edu.umass.cs.reconfiguration.ReconfigurableNode
Close gracefully.
close() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.CommitWorker
 
close() - Method in class edu.umass.cs.reconfiguration.Reconfigurator
Close gracefully.
close() - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
close() - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
close() - Method in class edu.umass.cs.reconfiguration.testing.TESTRCDebug
Deprecated.
 
close() - Method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
 
close(boolean) - Method in class edu.umass.cs.utils.DiskMap
Will stop the GC thread but will have no other effect.
close() - Method in class edu.umass.cs.utils.DiskMap
 
closeAll() - Static method in class edu.umass.cs.reconfiguration.http.HttpReconfigurator
To close all instances.
closeGracefully() - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
Closes the database and the connection.
closeImpl() - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
Closes all connections to the database.
closeImpl() - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
closeReadActiveRecords() - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
 
closeReadActiveRecords() - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
closeReadAll() - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
Closes the recovery cursor.
closeReadAll() - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
closeServers() - Static method in class edu.umass.cs.reconfiguration.testing.TESTRCDebug
Deprecated.
 
closeServers() - Static method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
 
closeServers() - Static method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationMain
 
closest(InetSocketAddress, Map<InetAddress, Long>) - Static method in class edu.umass.cs.nio.nioutils.RTTEstimator
 
coalesce(MessagingTask) - Method in class edu.umass.cs.gigapaxos.PaxosPacketBatcher
 
combine(PrepareReplyPacket) - Method in class edu.umass.cs.gigapaxos.paxospackets.PrepareReplyPacket
 
combine(MessagingTask[], MessagingTask[]) - Static method in class edu.umass.cs.gigapaxos.paxosutil.MessagingTask
 
combine(MessagingTask, MessagingTask[]) - Static method in class edu.umass.cs.gigapaxos.paxosutil.MessagingTask
 
combine(AbstractDemandProfile) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.AbstractDemandProfile
Combine the new information in update into this.
combine(AbstractDemandProfile) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.AggregateDemandProfiler
 
combine(AbstractDemandProfile) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DemandProfile
 
combine(AbstractDemandProfile) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ProximateBalance
 
combinePValuesOntoProposals(int[], String, int) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
combinePValuesOntoProposals(int[], String, int) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
commit(int) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
Deprecated.
commit(Map<K, V>) - Method in interface edu.umass.cs.utils.Diskable
This method should return only after successfully persisting the key,value pair, otherwise it should throw an exception.
commit(Map<K, V>) - Method in class edu.umass.cs.utils.DiskMap
This method should return only after successfully persisting the key,value pair, otherwise it should throw an exception.
commit(K) - Method in class edu.umass.cs.utils.DiskMap
 
commit() - Method in class edu.umass.cs.utils.DiskMap
Commits all in-memory entries in the map.
CommitRequest - Class in edu.umass.cs.txn.txpackets
 
CommitRequest(Transaction) - Constructor for class edu.umass.cs.txn.txpackets.CommitRequest
 
CommitRequest(String, Transaction) - Constructor for class edu.umass.cs.txn.txpackets.CommitRequest
 
CommitRequest(JSONObject) - Constructor for class edu.umass.cs.txn.txpackets.CommitRequest
 
CommitWorker<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationprotocoltasks
 
CommitWorker(AbstractReplicaCoordinator<?>, ReconfiguratorCallback) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.CommitWorker
 
compareTo(Ballot) - Method in class edu.umass.cs.gigapaxos.paxosutil.Ballot
 
compareTo(int, int) - Method in class edu.umass.cs.gigapaxos.paxosutil.Ballot
 
concatenate(ReconfigurationPacket.PacketType[]...) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
 
concurrentIterator() - Method in class edu.umass.cs.utils.MultiArrayMap
 
Config - Class in edu.umass.cs.utils
 
Config.CLIOption - Interface in edu.umass.cs.utils
An interface that makes it convenient to use commons-CLI style option while defining all fields as an enum at one place.
Config.ConfigurableEnum - Interface in edu.umass.cs.utils
 
Config.DefaultValueEnum - Interface in edu.umass.cs.utils
 
Config.Disableable - Interface in edu.umass.cs.utils
Used to disallow some parameters from being configured during production runs but allow them to be configured for testing or instrumentation purposes.
CONNECTIVITY_CHECK_TIMEOUT - Static variable in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
Default connectivity check timeout.
ConsistentHashing<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationutils
 
ConsistentHashing(NodeIDType[]) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentHashing
 
ConsistentHashing(NodeIDType[], int) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentHashing
 
ConsistentHashing(Set<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentHashing
 
ConsistentHashing(Set<NodeIDType>, boolean) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentHashing
 
consistentNodeConfig - Variable in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
ConsistentNodeConfig<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationutils
This class isn't really used for anything other than as a parent for ConsistentReconfigurableNodeConfig, so it has been declared abstract (even though it has no abstract methods).
ConsistentNodeConfig(NodeConfig<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentNodeConfig
 
consistentNodeConfig - Variable in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
ConsistentReconfigurableNodeConfig<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationutils
 
ConsistentReconfigurableNodeConfig(ReconfigurableNodeConfig<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
ConsumerBatchTask<TaskType> - Class in edu.umass.cs.gigapaxos.paxosutil
 
ConsumerBatchTask(Collection<TaskType>, TaskType[]) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.ConsumerBatchTask
 
ConsumerBatchTask(Map<?, TaskType>, TaskType[]) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.ConsumerBatchTask
 
ConsumerBatchTask(Collection<TaskType>, TaskType[], boolean) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.ConsumerBatchTask
 
ConsumerBatchTask(Map<?, TaskType>, TaskType[], boolean) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.ConsumerBatchTask
 
ConsumerTask<TaskType> - Class in edu.umass.cs.gigapaxos.paxosutil
 
ConsumerTask(Object) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.ConsumerTask
 
contains(TaskType) - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerBatchTask
 
contains(int) - Method in class edu.umass.cs.gigapaxos.paxosutil.WaitforUtility
 
contains(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.AggregateDemandProfiler
 
contains(int, int[]) - Static method in class edu.umass.cs.utils.Util
 
containsKey(String) - Method in class edu.umass.cs.utils.Config
 
containsKey(Object) - Method in class edu.umass.cs.utils.DiskMap
 
containsKey(Object) - Method in class edu.umass.cs.utils.MultiArrayMap
 
containsKey(KeyType) - Method in class edu.umass.cs.utils.NullIfEmptyMap
 
containsValue(Object) - Method in class edu.umass.cs.utils.DiskMap
 
containsValue(Object) - Method in class edu.umass.cs.utils.MultiArrayMap
 
containsValue(ValueType) - Method in class edu.umass.cs.utils.NullIfEmptyMap
 
coordBallot - Variable in class edu.umass.cs.gigapaxos.paxosutil.HotRestoreInfo
Ballot at acceptor.
coordinate(RCRecordRequest<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.CommitWorker
 
coordinateRequest(Request, ExecutedCallback) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
Start of abstract methods
coordinateRequest(Request, ExecutedCallback) - Method in class edu.umass.cs.reconfiguration.examples.noop.NoopAppCoordinator
 
coordinateRequest(Request, ExecutedCallback) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReplicaCoordinator
This method performs whatever replica coordination action is necessary to handle the request.
coordinateRequest(Request, ExecutedCallback) - Method in class edu.umass.cs.reconfiguration.PaxosReplicaCoordinator
 
coordinateRequest(String, Request, ExecutedCallback) - Method in class edu.umass.cs.reconfiguration.PaxosReplicaCoordinator
 
coordinateRequest(Request, ExecutedCallback) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DynamoReplicaCoordinator
 
coordinateRequest(Request, ExecutedCallback) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
coordinateRequest(Request, ExecutedCallback) - Method in class edu.umass.cs.txn.AbstractTransactor
 
coordinateRequestSuppressExceptions(Request, ExecutedCallback) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
coordinator - Variable in class edu.umass.cs.gigapaxos.paxosutil.SlotBallotState
 
coordinatorID - Variable in class edu.umass.cs.gigapaxos.paxosutil.Ballot
Ballot coordinator that breaks ordering ties at acceptors when the ballot number is the same.
copyEpochFinalCheckpointState(String, int) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
Copies the final state at the end of an epoch (or version) into a separate place.
copyEpochFinalCheckpointState(String, int) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
couldBeJSON(String) - Static method in class edu.umass.cs.nio.JSONPacket
 
couldBeJSON(byte[]) - Static method in class edu.umass.cs.nio.JSONPacket
 
couldBeJSON(byte[], int) - Static method in class edu.umass.cs.nio.JSONPacket
 
couldBeJSONArray(String) - Static method in class edu.umass.cs.nio.JSONPacket
 
couldBeJSONObject(String) - Static method in class edu.umass.cs.nio.JSONPacket
 
COUNTER - Static variable in class edu.umass.cs.protocoltask.examples.PingPongPacket
 
crash(int) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
crash(int) - Static method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationConfig
 
crashAndRecover(PaxosInstanceStateMachine) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
createApp(String[]) - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
createAppCoordinator() - Method in class edu.umass.cs.reconfiguration.examples.noop.NoopReconfigurableNode
 
createAppCoordinator() - Method in class edu.umass.cs.reconfiguration.ReconfigurableNode
 
createAppCoordinator() - Method in class edu.umass.cs.reconfiguration.ReconfigurableNode.DefaultReconfigurableNode
 
createCheckpointHandle(String) - Static method in class edu.umass.cs.gigapaxos.paxosutil.LargeCheckpointer
Replicable applications can use this method to create a checkpoint handle after they have created a checkpoint in the file filename.
createCoordinator(int, int, int[], int, boolean, String) - Static method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
createDefaultGroupInstances() - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosNode
 
createDemandProfile(String) - Static method in class edu.umass.cs.reconfiguration.reconfigurationutils.AbstractDemandProfile
 
createDemandProfile(Class<?>, String) - Static method in class edu.umass.cs.reconfiguration.reconfigurationutils.AbstractDemandProfile
 
createDemandProfile(JSONObject) - Static method in class edu.umass.cs.reconfiguration.reconfigurationutils.AbstractDemandProfile
 
createDemandProfile(String) - Static method in class edu.umass.cs.reconfiguration.reconfigurationutils.DemandProfile
 
createGroup(String, int[]) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
createHRI(String, int[], int) - Static method in class edu.umass.cs.gigapaxos.paxosutil.HotRestoreInfo
 
createNonDefaultGroupInstanes(int) - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosNode
 
createNonDefaultGroupInstanes(int, int) - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosNode
 
createPaxosInstance(String, short, Set<NodeIdType>, Replicable) - Method in class edu.umass.cs.gigapaxos.deprecated.AbstractPaxosManager
Deprecated.
 
createPaxosInstance(String, Set<NodeIDType>, String) - Method in class edu.umass.cs.gigapaxos.PaxosManager
A method that specifies the minimum number of necessary arguments to create a paxos instance.
createPaxosInstance(String, int, Set<NodeIDType>, Replicable, String) - Method in class edu.umass.cs.gigapaxos.PaxosManager
Paxos instance creation with an initial state specified.
createPaxosInstance(Map<String, String>, Set<NodeIDType>) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
createPaxosInstanceForcibly(String, int, Set<NodeIDType>, Replicable, String, long) - Method in class edu.umass.cs.gigapaxos.PaxosManager
This is a common default create paxos instance creation method, i.e., we wait for lower versions to be killed if necessary but, after a timeout, create the new instance forcibly anyway.
createReconfigurationRecord(ReconfigurationRecord<NodeIDType>) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
 
createReconfigurationRecord(ReconfigurationRecord<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
createReconfigurationRecords(Map<String, String>, Set<NodeIDType>, ReconfigurationConfig.ReconfigureUponActivesChange) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
 
createReconfigurationRecords(Map<String, String>, Set<NodeIDType>, ReconfigurationConfig.ReconfigureUponActivesChange) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
createReplicaGroup(String, int, String, Set<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
createReplicaGroup(Map<String, String>, Set<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
Default implementation that can be overridden for more batching optimization.
createReplicaGroup(String, int, String, Set<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.deprecated.AbstractReplicaCoordinatorPersistent
 
createReplicaGroup(String, int, String, Set<String>) - Method in class edu.umass.cs.reconfiguration.examples.noop.NoopAppCoordinator
 
createReplicaGroup(String, int, String, Set<NodeIDType>) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReplicaCoordinator
This method should return true if the replica group is successfully created or one already exists with the same set of nodes.
createReplicaGroup(String, int, String, Set<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.PaxosReplicaCoordinator
 
createReplicaGroup(Map<String, String>, Set<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.PaxosReplicaCoordinator
 
createReplicaGroup(String, int, String, Set<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DynamoReplicaCoordinator
 
createReplicaGroup(String, int, String, Set<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
createReplicaGroup(String, int, String, Set<NodeIDType>) - Method in class edu.umass.cs.txn.AbstractTransactor
 
CreateServiceName - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
CreateServiceName(String, String) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
 
CreateServiceName(String, String, Set<InetSocketAddress>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
A constructor that allows the caller to specify an initial group.
CreateServiceName(String, String, ReconfigurationConfig.ReconfigureUponActivesChange) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
 
CreateServiceName(String, String, Set<InetSocketAddress>, ReconfigurationConfig.ReconfigureUponActivesChange) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
A constructor to specify both an initial group and a policy for reconfiguration upon addition or deletion of active replicas.
CreateServiceName(InetSocketAddress, String, int, String, Map<String, String>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
 
CreateServiceName(InetSocketAddress, String, int, String) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
 
CreateServiceName(InetSocketAddress, String, int, String, InetSocketAddress) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
For internal use only.
CreateServiceName(Map<String, String>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
 
CreateServiceName(Map<String, String>, ReconfigurationConfig.ReconfigureUponActivesChange) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
 
CreateServiceName(Map<String, String>, CreateServiceName) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
FIXME: need to document the reliance on the consistent ordering of the head element in nameStates.
CreateServiceName(Map<String, String>, Set<String>, CreateServiceName) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
 
CreateServiceName(JSONObject, Stringifiable<?>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
 
CreateServiceName(JSONObject) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
 
CreateServiceName.Keys - Enum in edu.umass.cs.reconfiguration.reconfigurationpackets
 
CreateServiceNameTest - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
CreateServiceNameTest() - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceNameTest
 
createTime - Variable in class edu.umass.cs.gigapaxos.paxosutil.SlotBallotState
 
creator - Variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.ServerReconfigurationPacket
Requester address to send the confirmation.
creator - Variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
Sender address.
curEpochGroup - Variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
Group members in the current epoch being started.

D

DataProcessingWorker - Interface in edu.umass.cs.nio.interfaces
 
DataProcessingWorkerDefault - Class in edu.umass.cs.nio.nioutils
 
DataProcessingWorkerDefault() - Constructor for class edu.umass.cs.nio.nioutils.DataProcessingWorkerDefault
 
DB - Variable in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStopEpoch
 
DEBUG - Static variable in class edu.umass.cs.gigapaxos.paxosutil.RequestInstrumenter
This class is a no-op unless DEBUG is turned on
decimalFormat - Static variable in class edu.umass.cs.utils.Util
 
decisions101 - Static variable in class edu.umass.cs.gigapaxos.testing.TESTPaxosShutdownThread
 
decisions102 - Static variable in class edu.umass.cs.gigapaxos.testing.TESTPaxosShutdownThread
 
decode(byte[]) - Static method in class edu.umass.cs.nio.MessageExtractor
 
decode(byte[], int, int) - Static method in class edu.umass.cs.nio.MessageExtractor
 
decrInstanceCount() - Static method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
DEFAULT_APP_REQUEST_TIMEOUT - Static variable in class edu.umass.cs.reconfiguration.testing.TESTRCDebug
Deprecated.
 
DEFAULT_APP_REQUEST_TIMEOUT - Static variable in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
 
DEFAULT_CAPACITY - Static variable in class edu.umass.cs.utils.DiskMap
 
DEFAULT_COORDINATION_MODE - Static variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
 
DEFAULT_GC_TIMEOUT - Static variable in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
The default timeout for ClientRequest as well as ClientReconfigurationPacket requests.
DEFAULT_GIGAPAXOS_CONFIG_FILE - Static variable in class edu.umass.cs.gigapaxos.PaxosConfig
Default file name for gigapaxos config parameters.
DEFAULT_RECONFIGURATOR_PREFIX - Static variable in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
DEFAULT_RESTART_PERIOD - Static variable in class edu.umass.cs.protocoltask.ProtocolExecutor
 
DEFAULT_RTX_TIMEOUT - Static variable in class edu.umass.cs.reconfiguration.testing.TESTRCDebug
Deprecated.
 
DEFAULT_RTX_TIMEOUT - Static variable in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
 
DEFAULT_SERVER_PREFIX - Static variable in class edu.umass.cs.gigapaxos.PaxosConfig
 
DEFAULT_SSL_MODE - Static variable in class edu.umass.cs.nio.NIOTransport
A flag to easily enable or disable SSL by default.
DEFAULT_START_PORT - Static variable in class edu.umass.cs.nio.nioutils.SampleNodeConfig
The default starting port number beyond which nodes automatically get port numbers assigned.
DEFAULT_TESTING_CONFIG_FILE - Static variable in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
DEFAULT_THREAD_POOL_SIZE - Static variable in class edu.umass.cs.nio.AbstractPacketDemultiplexer
The default thread pool size.
DefaultAppRequest - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
DefaultAppRequest(String, int, boolean) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.DefaultAppRequest
 
DefaultAppRequest(JSONObject) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.DefaultAppRequest
 
DefaultAppRequest.Keys - Enum in edu.umass.cs.reconfiguration.reconfigurationpackets
 
DefaultNodeConfig<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationutils
 
DefaultNodeConfig(Map<NodeIDType, InetSocketAddress>, Map<NodeIDType, InetSocketAddress>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.DefaultNodeConfig
 
DefaultPaxosInterfaceApp - Class in edu.umass.cs.gigapaxos.deprecated
 
DefaultReconfigurableNode(String, ReconfigurableNodeConfig<String>, String[], boolean) - Constructor for class edu.umass.cs.reconfiguration.ReconfigurableNode.DefaultReconfigurableNode
 
DefaultTest - Class in edu.umass.cs.utils
 
DefaultTest() - Constructor for class edu.umass.cs.utils.DefaultTest
 
deflate(byte[]) - Static method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
DELAY_STR - Static variable in class edu.umass.cs.nio.JSONDelayEmulator
The JSON key for the delay value.
delayedDeleteComplete() - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
 
delayedDeleteComplete() - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
delayedDeleteComplete() - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
DelayProfiler - Class in edu.umass.cs.utils
 
DelayProfiler() - Constructor for class edu.umass.cs.utils.DelayProfiler
 
deletedNodes - Variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.ServerReconfigurationPacket
Set of RC nodes being deleted.
deleteEpochFinalCheckpointState(String, int) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
deleteEpochFinalCheckpointState(String, int) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
deleteFinalState(String, int) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
deleteFinalState(String, int) - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
deleteFinalState(String, int) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
deleteFinalState(String, int) - Method in class edu.umass.cs.reconfiguration.examples.AbstractReconfigurablePaxosApp
 
deleteFinalState(String, int) - Method in class edu.umass.cs.reconfiguration.examples.noop.NoopApp
 
deleteFinalState(String, int) - Method in interface edu.umass.cs.reconfiguration.interfaces.Reconfigurable
Garbage-collects the final state for name, epoch.
deleteFinalState(String, int) - Method in class edu.umass.cs.reconfiguration.PaxosReplicaCoordinator
 
deleteFinalState(String, int) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.TrivialRepliconfigurable
 
deleteFinalState(String, int) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
deleteFinalState(String, int) - Method in class edu.umass.cs.txn.AbstractTransactor
 
deleteReconfigurationRecord(String, int) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
 
deleteReconfigurationRecord(String, int) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
deleteReplicaGroup(String, int) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
deleteReplicaGroup(String, int) - Method in class edu.umass.cs.reconfiguration.deprecated.AbstractReplicaCoordinatorPersistent
 
deleteReplicaGroup(String, int) - Method in class edu.umass.cs.reconfiguration.examples.noop.NoopAppCoordinator
 
deleteReplicaGroup(String, int) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReplicaCoordinator
This method should result in all state corresponding to serviceName being deleted
deleteReplicaGroup(String, int) - Method in class edu.umass.cs.reconfiguration.PaxosReplicaCoordinator
 
deleteReplicaGroup(String, int) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DynamoReplicaCoordinator
 
deleteReplicaGroup(String, int) - Method in class edu.umass.cs.txn.AbstractTransactor
 
DeleteServiceName - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
DeleteServiceName(String) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.DeleteServiceName
 
DeleteServiceName(InetSocketAddress, String, int) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.DeleteServiceName
 
DeleteServiceName(InetSocketAddress, String, int, InetSocketAddress) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.DeleteServiceName
 
DeleteServiceName(JSONObject, Stringifiable<?>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.DeleteServiceName
 
DeleteServiceName(JSONObject) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.DeleteServiceName
 
deleteStoppedPaxosInstance(String, int) - Method in class edu.umass.cs.gigapaxos.PaxosManager
We are only allowed to delete a stopped paxos instance.
DemandProfile - Class in edu.umass.cs.reconfiguration.reconfigurationutils
 
DemandProfile(String) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.DemandProfile
The string argument name is the service name for which this demand profile is being maintained.
DemandProfile(DemandProfile) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.DemandProfile
Deep copy constructor.
DemandProfile(JSONObject) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.DemandProfile
All AbstractDemandProfile instances must be constructible from a JSONObject.
DemandProfile.Keys - Enum in edu.umass.cs.reconfiguration.reconfigurationutils
 
DemandReport<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
DemandReport(NodeIDType, String, int, JSONObject) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.DemandReport
 
DemandReport(NodeIDType, String, int, AbstractDemandProfile) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.DemandReport
 
DemandReport(JSONObject, Stringifiable<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.DemandReport
 
demultiplexMessage(Object) - Method in interface edu.umass.cs.nio.interfaces.DataProcessingWorker
 
demultiplexMessage(Object) - Method in interface edu.umass.cs.nio.interfaces.InterfaceMessageExtractor
 
demultiplexMessage(Object) - Method in class edu.umass.cs.nio.IOSSSLDataProcessingWorker
 
demultiplexMessage(Object) - Method in class edu.umass.cs.nio.MessageExtractor
 
demultiplexMessage(Object) - Method in class edu.umass.cs.nio.nioutils.DataProcessingWorkerDefault
 
demultiplexMessage(Object) - Method in class edu.umass.cs.nio.SSLDataProcessingWorker
 
dequeueAll() - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerBatchTask
 
dequeueImpl() - Method in class edu.umass.cs.gigapaxos.PaxosPacketBatcher
 
dequeueImpl() - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerBatchTask
 
dequeueImpl() - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerTask
 
dequeueImpl() - Method in class edu.umass.cs.gigapaxos.RequestBatcher
 
DETERMINISTIC_DROP - Static variable in class edu.umass.cs.protocoltask.TESTProtocolTaskConfig
 
DETERMINISTIC_DROP_FREQUENCY - Static variable in class edu.umass.cs.protocoltask.TESTProtocolTaskConfig
 
df(double) - Static method in class edu.umass.cs.utils.Util
 
diff(Set<?>, Set<?>) - Static method in class edu.umass.cs.utils.Util
 
digest(AcceptPacket) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
digest(MessageDigest) - Method in class edu.umass.cs.gigapaxos.paxospackets.AcceptPacket
 
digest - Variable in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
digestEquals(RequestPacket, MessageDigest) - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
disable() - Method in class edu.umass.cs.nio.nioutils.NIOInstrumenter
 
disable() - Static method in class edu.umass.cs.utils.DelayProfiler
Will disable instrumentation (true by default).
disableCommandLine(Class<?>) - Static method in class edu.umass.cs.utils.Config
Disable command-line input for type.
disk - Variable in class edu.umass.cs.gigapaxos.PaxosManager
 
Diskable<K,V> - Interface in edu.umass.cs.utils
 
DiskMap<K,V> - Class in edu.umass.cs.utils
 
DiskMap(long) - Constructor for class edu.umass.cs.utils.DiskMap
 
DiskMap(ConcurrentMap<K, V>) - Constructor for class edu.umass.cs.utils.DiskMap
The supplied map will be used as the underlying in-memory map.
DiskMap.LastActive - Class in edu.umass.cs.utils
 
DiskMapTest - Class in edu.umass.cs.utils
Test class for DiskMap.
DiskMapTest() - Constructor for class edu.umass.cs.utils.DiskMapTest
 
DistTransactor<NodeIDType> - Class in edu.umass.cs.txn
 
DistTransactor(AbstractReplicaCoordinator<NodeIDType>) - Constructor for class edu.umass.cs.txn.DistTransactor
 
dontSendKeepAlive(NodeIDType) - Method in class edu.umass.cs.gigapaxos.FailureDetection
 
doubleCheckFields() - Static method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
DropEpochFinalState<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
DropEpochFinalState(NodeIDType, String, int, boolean) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.DropEpochFinalState
 
DropEpochFinalState(JSONObject, Stringifiable<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.DropEpochFinalState
 
dropState(String) - Static method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
dropState(String, ConsistentReconfigurableNodeConfig<String>) - Static method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
dropTable(String) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
DUPLICATE_KEY - Static variable in class edu.umass.cs.gigapaxos.paxosutil.SQL
 
DUPLICATE_TABLE - Static variable in class edu.umass.cs.gigapaxos.paxosutil.SQL
 
DynamoReplicaCoordinator<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationutils
 
DynamoReplicaCoordinator(Replicable, NodeIDType, ConsistentNodeConfig<NodeIDType>, JSONMessenger<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.DynamoReplicaCoordinator
 

E

E2ELatencyAwareRedirector - Class in edu.umass.cs.gigapaxos.paxosutil
 
E2ELatencyAwareRedirector() - Constructor for class edu.umass.cs.gigapaxos.paxosutil.E2ELatencyAwareRedirector
 
E2ELatencyAwareRedirector(InetSocketAddress) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.E2ELatencyAwareRedirector
 
E2ELatencyAwareRedirectorTest - Class in edu.umass.cs.gigapaxos.paxosutil
 
E2ELatencyAwareRedirectorTest() - Constructor for class edu.umass.cs.gigapaxos.paxosutil.E2ELatencyAwareRedirectorTest
 
EchoRequest - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
EchoRequest(InetSocketAddress, Map<InetAddress, Long>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.EchoRequest
 
EchoRequest(InetSocketAddress) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.EchoRequest
 
EchoRequest(JSONObject, Stringifiable<?>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.EchoRequest
 
EchoRequest(JSONObject) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.EchoRequest
 
edu.umass.cs.gigapaxos - package edu.umass.cs.gigapaxos
 
edu.umass.cs.gigapaxos.async - package edu.umass.cs.gigapaxos.async
 
edu.umass.cs.gigapaxos.deprecated - package edu.umass.cs.gigapaxos.deprecated
 
edu.umass.cs.gigapaxos.examples - package edu.umass.cs.gigapaxos.examples
 
edu.umass.cs.gigapaxos.examples.noop - package edu.umass.cs.gigapaxos.examples.noop
 
edu.umass.cs.gigapaxos.interfaces - package edu.umass.cs.gigapaxos.interfaces
 
edu.umass.cs.gigapaxos.paxospackets - package edu.umass.cs.gigapaxos.paxospackets
 
edu.umass.cs.gigapaxos.paxosutil - package edu.umass.cs.gigapaxos.paxosutil
 
edu.umass.cs.gigapaxos.testing - package edu.umass.cs.gigapaxos.testing
 
edu.umass.cs.nio - package edu.umass.cs.nio
 
edu.umass.cs.nio.interfaces - package edu.umass.cs.nio.interfaces
 
edu.umass.cs.nio.nioutils - package edu.umass.cs.nio.nioutils
 
edu.umass.cs.protocoltask - package edu.umass.cs.protocoltask
 
edu.umass.cs.protocoltask.examples - package edu.umass.cs.protocoltask.examples
 
edu.umass.cs.protocoltask.examples.pingpong - package edu.umass.cs.protocoltask.examples.pingpong
 
edu.umass.cs.protocoltask.examples.thresholdfetch - package edu.umass.cs.protocoltask.examples.thresholdfetch
 
edu.umass.cs.protocoltask.json - package edu.umass.cs.protocoltask.json
 
edu.umass.cs.reconfiguration - package edu.umass.cs.reconfiguration
 
edu.umass.cs.reconfiguration.deprecated - package edu.umass.cs.reconfiguration.deprecated
 
edu.umass.cs.reconfiguration.examples - package edu.umass.cs.reconfiguration.examples
 
edu.umass.cs.reconfiguration.examples.noop - package edu.umass.cs.reconfiguration.examples.noop
 
edu.umass.cs.reconfiguration.examples.noopsimple - package edu.umass.cs.reconfiguration.examples.noopsimple
 
edu.umass.cs.reconfiguration.http - package edu.umass.cs.reconfiguration.http
 
edu.umass.cs.reconfiguration.interfaces - package edu.umass.cs.reconfiguration.interfaces
 
edu.umass.cs.reconfiguration.reconfigurationpackets - package edu.umass.cs.reconfiguration.reconfigurationpackets
 
edu.umass.cs.reconfiguration.reconfigurationprotocoltasks - package edu.umass.cs.reconfiguration.reconfigurationprotocoltasks
 
edu.umass.cs.reconfiguration.reconfigurationutils - package edu.umass.cs.reconfiguration.reconfigurationutils
 
edu.umass.cs.reconfiguration.testing - package edu.umass.cs.reconfiguration.testing
 
edu.umass.cs.txn - package edu.umass.cs.txn
 
edu.umass.cs.txn.exceptions - package edu.umass.cs.txn.exceptions
 
edu.umass.cs.txn.interfaces - package edu.umass.cs.txn.interfaces
 
edu.umass.cs.txn.testing - package edu.umass.cs.txn.testing
 
edu.umass.cs.txn.txpackets - package edu.umass.cs.txn.txpackets
 
edu.umass.cs.utils - package edu.umass.cs.utils
 
emulateConfigFileDelays(InterfaceDelayEmulator<?>, double) - Static method in class edu.umass.cs.nio.JSONDelayEmulator
 
emulateDelays() - Static method in class edu.umass.cs.nio.AbstractPacketDemultiplexer
Turns on delay emulation.
emulateDelays() - Static method in class edu.umass.cs.nio.JSONDelayEmulator
Enables delay emulation at receiver.
enable() - Method in class edu.umass.cs.nio.nioutils.NIOInstrumenter
 
ENABLE_CLIENT_REQ_RTX - Static variable in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
to enable retransmission of requests by TESTPaxosClient
ENABLE_CLIENT_REQ_RTX - Static variable in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationConfig
to enable retransmission of requests by TESTPaxosClient
ENABLE_INT_STRING_CONVERSION - Static variable in class edu.umass.cs.gigapaxos.paxosutil.PaxosMessenger
 
ENABLE_NULL_CHECKPOINT_STATE - Static variable in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
enableJSONPackets() - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
If true, the app will only be handed JSON formatted packets via getJSONRequest(), not via AppRequestParser.getRequest(String).
enablePriorityQueue() - Method in class edu.umass.cs.utils.DiskMap
 
encodedStringToLong(String) - Static method in class edu.umass.cs.utils.Util
 
enqueue(TaskType) - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerTask
 
enqueue(Request, boolean) - Method in class edu.umass.cs.txn.AbstractTransactor
 
enqueue(Request, boolean) - Method in class edu.umass.cs.txn.DistTransactor
 
enqueueAndWait(TaskType) - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerBatchTask
 
enqueueCancel(Object) - Static method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
enqueueForExecution(RCRecordRequest<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.CommitWorker
 
enqueueForExecution(RCRecordRequest<NodeIDType>, long) - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.CommitWorker
Should be used sparingly only for non-default restart periods, not for all names.
enqueueImpl(MessagingTask[]) - Method in class edu.umass.cs.gigapaxos.PaxosPacketBatcher
 
enqueueImpl(TaskType) - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerBatchTask
 
enqueueImpl(TaskType) - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerTask
 
enqueueImpl(RequestPacket) - Method in class edu.umass.cs.gigapaxos.RequestBatcher
 
ensureFileHandlerDirExists() - Static method in class edu.umass.cs.gigapaxos.PaxosConfig
 
entrySet() - Method in class edu.umass.cs.utils.DiskMap
This method only returns the in-memory entry set.
entrySet() - Method in class edu.umass.cs.utils.MultiArrayMap
 
entrySet() - Method in class edu.umass.cs.utils.NullIfEmptyMap
 
EpochFinalState<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
EpochFinalState(NodeIDType, String, int, String, NodeIDType) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.EpochFinalState
 
EpochFinalState(JSONObject, Stringifiable<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.EpochFinalState
 
epochNumber - Variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.BasicReconfigurationPacket
 
equalOrHigherVersionExists(String, int) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
equals(Object) - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
equals(Object) - Method in class edu.umass.cs.gigapaxos.paxosutil.Ballot
 
equals(Object) - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
 
equals(Object) - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
 
ExampleNode - Class in edu.umass.cs.protocoltask.examples
 
ExamplePacketDemultiplexer - Class in edu.umass.cs.protocoltask.examples
 
execpool - Variable in class edu.umass.cs.nio.JSONMessenger
 
execute(Request) - Method in class edu.umass.cs.gigapaxos.deprecated.DefaultPaxosInterfaceApp
 
execute(Request, boolean) - Method in class edu.umass.cs.gigapaxos.deprecated.DefaultPaxosInterfaceApp
 
execute(Request) - Method in class edu.umass.cs.gigapaxos.examples.noop.NoopPaxosApp
 
execute(Request, boolean) - Method in class edu.umass.cs.gigapaxos.examples.noop.NoopPaxosApp
 
execute(Request) - Method in interface edu.umass.cs.gigapaxos.interfaces.Application
 
execute(Request, boolean) - Method in interface edu.umass.cs.gigapaxos.interfaces.Replicable
This method must handle the request atomically and return true if successful or throw an exception or return false.
execute(PaxosInstanceStateMachine, PaxosManager<?>, Replicable, RequestPacket, boolean) - Static method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
Helper method used above in EEC as well as by PaxosManager for emulating unreplicated execution for testing purposes.
execute(Request) - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosApp
 
execute(Request, boolean) - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosApp
 
execute(long) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
execute(Request, boolean) - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
Paxos related methods below
execute(Request) - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
execute(Request) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
execute(Request, boolean) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
execute(Request, boolean, ExecutedCallback) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
This method is a wrapper for Application.handleRequest and meant to be invoked by the class that implements this AbstractReplicaCoordinator or its helper classes.
execute(Request, boolean) - Method in class edu.umass.cs.reconfiguration.examples.AbstractReconfigurablePaxosApp
 
execute(Request, boolean) - Method in class edu.umass.cs.reconfiguration.examples.noop.NoopApp
 
execute(Request) - Method in class edu.umass.cs.reconfiguration.examples.noop.NoopApp
 
execute(Request, boolean) - Method in class edu.umass.cs.reconfiguration.examples.noopsimple.NoopApp
 
execute(Request) - Method in class edu.umass.cs.reconfiguration.examples.noopsimple.NoopApp
 
execute(Request) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.TrivialRepliconfigurable
 
execute(Request, boolean) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.TrivialRepliconfigurable
 
execute(Request, boolean) - Method in class edu.umass.cs.reconfiguration.testing.NoopAppTesting
 
execute(Request) - Method in class edu.umass.cs.reconfiguration.testing.NoopAppTesting
 
execute(Request, boolean) - Method in class edu.umass.cs.txn.AbstractTransactor
 
execute(Request) - Method in class edu.umass.cs.txn.AbstractTransactor
 
execute(Request, boolean) - Method in class edu.umass.cs.txn.testing.NoopAppTX
 
execute(Request) - Method in class edu.umass.cs.txn.testing.NoopAppTX
 
executed(Request, boolean) - Method in interface edu.umass.cs.gigapaxos.interfaces.ExecutedCallback
 
executed(RequestPacket, Request, boolean) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
executed(Request, boolean) - Method in class edu.umass.cs.reconfiguration.ActiveReplica
 
executed(Request, boolean) - Method in class edu.umass.cs.reconfiguration.Reconfigurator
Reconfiguration is initiated using a callback because the intent to conduct a reconfiguration must be persistently committed before initiating the reconfiguration.
executed(Request, boolean) - Method in class edu.umass.cs.txn.TxCallback
Default callback for transaction operations at an active replica.
ExecutedCallback - Interface in edu.umass.cs.gigapaxos.interfaces
 
executedCallback(RCRecordRequest<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.CommitWorker
 
executedCallback(RCRecordRequest<NodeIDType>, boolean) - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.CommitWorker
We process some failed (handled = false) execution notifications to solve the early notify issue with complete requests for service names, i.e., the notify arrives before the pending request is enqueued but the pending request has been obviated anyway.
exists(PaxosCoordinator) - Static method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
exists(PaxosCoordinator, Ballot) - Static method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
existsDB(SQL.SQLType, String, String) - Static method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
This method will connect to the DB while creating it if it did not already exist.
existsGroup(String, int) - Method in class edu.umass.cs.reconfiguration.examples.noop.NoopAppCoordinator
 
existsOrHigher(String, int) - Method in class edu.umass.cs.reconfiguration.PaxosReplicaCoordinator
 
extractExecuteAndCheckpoint(PValuePacket) - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 

F

FailureDetection<NodeIDType> - Class in edu.umass.cs.gigapaxos
 
FailureDetectionPacket<NodeIDType> - Class in edu.umass.cs.gigapaxos.paxospackets
 
FailureDetectionPacket(NodeIDType, NodeIDType, boolean) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.FailureDetectionPacket
 
FailureDetectionPacket(JSONObject, Stringifiable<NodeIDType>) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.FailureDetectionPacket
 
fatalExit(UnsupportedEncodingException) - Static method in class edu.umass.cs.nio.MessageExtractor
 
fetchAndAggregateMergeeStates(Map<String, String>, String, int) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
 
fetchAndAggregateMergeeStates(Map<String, String>, String, int) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
FIELD1 - Static variable in class edu.umass.cs.protocoltask.examples.PingPongPacket
 
field1 - Variable in class edu.umass.cs.protocoltask.examples.PingPongPacket
 
fileLock(Object) - Static method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
filter(int[], int) - Static method in class edu.umass.cs.utils.Util
 
filterDeletedActives(Set<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
find(String) - Static method in class edu.umass.cs.utils.ClassFinder
 
findMyIP(Integer) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
findRegex(String) - Static method in class edu.umass.cs.utils.ClassFinder
 
FindReplicaGroupPacket - Class in edu.umass.cs.gigapaxos.paxospackets
 
FindReplicaGroupPacket(int, JSONObject) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.FindReplicaGroupPacket
 
FindReplicaGroupPacket(int, PaxosPacket) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.FindReplicaGroupPacket
 
FindReplicaGroupPacket(int[], FindReplicaGroupPacket) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.FindReplicaGroupPacket
 
FindReplicaGroupPacket(JSONObject) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.FindReplicaGroupPacket
 
findRest(Class<?>) - Static method in class edu.umass.cs.utils.ClassFinder
 
fine(Object...) - Method in class edu.umass.cs.utils.MyLogger
 
finer(Object...) - Method in class edu.umass.cs.utils.MyLogger
 
finest(Object...) - Method in class edu.umass.cs.utils.MyLogger
 
finitePingPong() - Method in class edu.umass.cs.protocoltask.examples.ExampleNode
 
firstKey() - Method in class edu.umass.cs.utils.NullIfEmptyMap
 
firstUndecidedSlot - Variable in class edu.umass.cs.gigapaxos.paxospackets.PreparePacket
First undecided slot at coordinator.
fix(GenericMessagingTask<NodeIDType, ?>[]) - Method in class edu.umass.cs.protocoltask.ThresholdProtocolTask
 
fixNodeIntToString(JSONObject) - Method in class edu.umass.cs.gigapaxos.paxosutil.PaxosMessenger
 
fixNodeIntToString(JSONObject) - Method in class edu.umass.cs.gigapaxos.paxosutil.PaxosMessenger
 
flip(int) - Method in class edu.umass.cs.protocoltask.examples.PingPongPacket
 
flip(NodeIDType) - Method in class edu.umass.cs.protocoltask.json.ProtocolPacket
 
forceCheckpoint() - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
forceCheckpoint(String) - Method in class edu.umass.cs.gigapaxos.PaxosManager
Forces a checkpoint, but not guaranteed to happen immediately.
forceCheckpoint(String) - Method in class edu.umass.cs.reconfiguration.PaxosReplicaCoordinator
 
forceClear(String) - Static method in class edu.umass.cs.reconfiguration.ReconfigurableNode
For testing.
forceStop() - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
forceStop(PaxosCoordinator) - Static method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
forceStop() - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
FORMAT - Static variable in class edu.umass.cs.utils.MyLogger
 
fragment(int) - Method in class edu.umass.cs.gigapaxos.paxospackets.PrepareReplyPacket
 
fragment(PrepareReplyPacket) - Static method in class edu.umass.cs.gigapaxos.paxosutil.PrepareReplyAssembler
 

G

garbageCollectDecisions(int) - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
garbageCollectDecisions(int) - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
garbageCollectDeletedNode(NodeIDType) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
garbageCollectedDeletedNode(NodeIDType) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
 
garbageCollectedDeletedNode(NodeIDType) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
garbageCollectOldFileSystemBasedCheckpoints() - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
garbageCollectOldReconfigurators(int) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
 
garbageCollectOldReconfigurators(int) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
GC() - Method in class edu.umass.cs.gigapaxos.paxosutil.LogIndex
 
GCConcurrentHashMap<K,V> - Class in edu.umass.cs.utils
 
GCConcurrentHashMap(GCConcurrentHashMapCallback, long) - Constructor for class edu.umass.cs.utils.GCConcurrentHashMap
 
GCConcurrentHashMap(long) - Constructor for class edu.umass.cs.utils.GCConcurrentHashMap
 
GCConcurrentHashMap.GCConcurrentHashMapTest - Class in edu.umass.cs.utils
 
GCConcurrentHashMapCallback - Interface in edu.umass.cs.utils
 
GCConcurrentHashMapTest() - Constructor for class edu.umass.cs.utils.GCConcurrentHashMap.GCConcurrentHashMapTest
 
GenericMessagingTask<NodeIDType,MessageType> - Class in edu.umass.cs.nio
 
GenericMessagingTask() - Constructor for class edu.umass.cs.nio.GenericMessagingTask
Null recipients and messages.
GenericMessagingTask(NodeIDType, MessageType) - Constructor for class edu.umass.cs.nio.GenericMessagingTask
Unicast
GenericMessagingTask(Object[], MessageType) - Constructor for class edu.umass.cs.nio.GenericMessagingTask
Multicast
GenericMessagingTask(NodeIDType, Object[]) - Constructor for class edu.umass.cs.nio.GenericMessagingTask
Unicast multiple packets
GenericMessagingTask(Object[], Object[]) - Constructor for class edu.umass.cs.nio.GenericMessagingTask
Multicast multiple packets.
get() - Method in class edu.umass.cs.gigapaxos.async.RequestCallbackFuture
 
get(long, TimeUnit) - Method in class edu.umass.cs.gigapaxos.async.RequestCallbackFuture
 
get() - Method in interface edu.umass.cs.gigapaxos.interfaces.RequestFuture
 
get(long, TimeUnit) - Method in interface edu.umass.cs.gigapaxos.interfaces.RequestFuture
 
get(int) - Method in class edu.umass.cs.gigapaxos.paxosutil.IntegerMap
 
get(Set<Integer>) - Method in class edu.umass.cs.gigapaxos.paxosutil.IntegerMap
 
get(Enum<?>) - Method in class edu.umass.cs.utils.Config
 
get(Object) - Method in class edu.umass.cs.utils.Config
 
get(String) - Static method in class edu.umass.cs.utils.DelayProfiler
 
get(Object) - Method in class edu.umass.cs.utils.DiskMap
 
get(Object) - Method in class edu.umass.cs.utils.MultiArrayMap
 
get(KeyType) - Method in class edu.umass.cs.utils.NullIfEmptyMap
 
get(String) - Method in class edu.umass.cs.utils.StringLocker
 
GET_ACCEPTED_PVALUES_FROM_DISK - Static variable in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
getAccept(int) - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
getAcceptedSlots() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedAcceptReply
 
getAcceptSlots() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedAccept
 
getACK() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getAckStarts() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitEpochFinalState
 
getActiveCount() - Method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
getActiveReplicas() - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfigurableNodeConfig
 
getActiveReplicas() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
getActiveReplicas() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DefaultNodeConfig
 
getActiveReplicas() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurableSampleNodeConfig
 
getActiveReplicas(String, int) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
getActiveReplicas() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
getActiveReplicas() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.SimpleReconfiguratorNodeConfig
 
getActiveReplicas(String) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
getActiveReplicasMap() - Method in interface edu.umass.cs.reconfiguration.interfaces.ModifiableActiveConfig
 
getActiveReplicaSocketAddresses() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
getActiveReplicaSocketAddresses(int) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
This method tries to return a limited number of active replica socket addresses that to the extent possible have distinct IPs.
getActiveReplicasReadOnly() - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfigurableNodeConfig
 
getActiveReplicasReadOnly() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DefaultNodeConfig
 
getActives() - Static method in class edu.umass.cs.gigapaxos.PaxosConfig
 
getActives() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RequestActiveReplicas
 
getAddedNodeIDs() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ServerReconfigurationPacket
 
getAggregateOutput(long) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosClient
 
getAggregateOutput(long) - Static method in class edu.umass.cs.reconfiguration.testing.TESTPaxosClient
 
getAllActiveReplicas() - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfigurableAppInfo
 
getAllActiveReplicas() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
getAlphanumericAsBytes() - Static method in class edu.umass.cs.utils.Util
 
getAlterString(String, SQL.SQLType) - Static method in class edu.umass.cs.gigapaxos.paxosutil.SQL
 
getAmazonIPToRegionFile() - Static method in class edu.umass.cs.nio.nioutils.RTTEstimator
 
getApp() - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
getApp(String) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
getAppRequestTypes() - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
Need to return just app's request types.
getAppState(String) - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosNode
 
getARARNodesAsString() - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
getArgName() - Method in interface edu.umass.cs.utils.Config.CLIOption
 
getARRCNodesAsString() - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
getAsProperties() - Static method in class edu.umass.cs.gigapaxos.PaxosConfig
 
getBallot() - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
getBallot(PaxosCoordinator) - Static method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
getBallot() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
End of Phase2b methods
getBallotCoord() - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
getBallotCoord() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
getBallotCoordLog() - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
getBallotCoordString(String) - Static method in class edu.umass.cs.gigapaxos.paxosutil.Ballot
 
getBallotLog() - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
getBallotNum() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
getBallotnum() - Method in class edu.umass.cs.gigapaxos.paxosutil.SlotBallotState
 
getBallotNumString(String) - Static method in class edu.umass.cs.gigapaxos.paxosutil.Ballot
 
getBallotSlot() - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
getBallotStr(PaxosCoordinator) - Static method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
getBallotStr() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
getBallotString(int, int) - Static method in class edu.umass.cs.gigapaxos.paxosutil.Ballot
 
getBallotString(int, Object) - Static method in class edu.umass.cs.gigapaxos.paxosutil.Ballot
 
getBatched() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getBindAddress(NodeIDType) - Method in interface edu.umass.cs.nio.interfaces.NodeConfig
 
getBindAddress(NodeIDType) - Method in class edu.umass.cs.nio.nioutils.SampleNodeConfig
 
getBindAddress(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentNodeConfig
 
getBindAddress(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DefaultNodeConfig
 
getBindAddress(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.SimpleReconfiguratorNodeConfig
 
getBindSocketAddress(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
Returns the bindable socket address of the public host corresponding to this id.
getBlobString(int, SQL.SQLType) - Static method in class edu.umass.cs.gigapaxos.paxosutil.SQL
 
getBoolean(Enum<?>) - Method in class edu.umass.cs.utils.Config
 
getByteifiedSelf() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getCallback() - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
getCheckpointBallot(String) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
getCheckpointBallot(String) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
getCheckpointSlot(String) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
getCheckpointSlot(String) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
getCheckpointState(String) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
getCheckpointState(String) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
Gets current checkpoint.
getCleanDB() - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
getCleanDB() - Static method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationConfig
 
getClientAddress() - Method in class edu.umass.cs.gigapaxos.examples.PaxosAppRequest
 
getClientAddress() - Method in interface edu.umass.cs.gigapaxos.interfaces.ClientRequest
Deprecated.
getClientAddress() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getClientAddress() - Method in class edu.umass.cs.reconfiguration.examples.AppRequest
 
getClientAddress() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.EchoRequest
 
getClientAddress() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
 
getClientFacingClearPort(int) - Static method in class edu.umass.cs.reconfiguration.ActiveReplica
 
getClientFacingClearPort(int) - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
getClientFacingClearPort(int) - Static method in class edu.umass.cs.reconfiguration.Reconfigurator
 
getClientFacingPort(int) - Static method in class edu.umass.cs.reconfiguration.ActiveReplica
 
getClientFacingPort(int) - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
getClientFacingSSLPort(int) - Static method in class edu.umass.cs.reconfiguration.ActiveReplica
 
getClientFacingSSLPort(int) - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
getClientFacingSSLPort(int) - Static method in class edu.umass.cs.reconfiguration.Reconfigurator
getClientID() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getClientMessenger() - Method in interface edu.umass.cs.nio.interfaces.SSLMessenger
 
getClientMessenger(InetSocketAddress) - Method in interface edu.umass.cs.nio.interfaces.SSLMessenger
 
getClientMessenger() - Method in class edu.umass.cs.nio.JSONMessenger
 
getClientMessenger(InetSocketAddress) - Method in class edu.umass.cs.nio.JSONMessenger
 
getClientPortClearOffset() - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
getClientPortOffset() - Static method in class edu.umass.cs.gigapaxos.PaxosConfig
 
getClientPortOffset() - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
getClientPortSSLOffset() - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
getClientSSLMode() - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
getClosest(InetAddress) - Static method in class edu.umass.cs.nio.nioutils.RTTEstimator
 
getClosest() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.EchoRequest
 
getCode() - Method in exception edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync.ReconfigurationException
 
getCode() - Method in exception edu.umass.cs.txn.exceptions.TXException
 
getCommaSeparated(List<?>) - Static method in class edu.umass.cs.utils.Util
 
getCommitted(int) - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
getCommitted(Collection<Integer>) - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
getCommittedSlots() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedCommit
 
getCommonMembers() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
getCompletedTaskCount() - Method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
getCompression() - Static method in class edu.umass.cs.nio.NIOTransport
 
getCompressionThreshold() - Static method in class edu.umass.cs.nio.NIOTransport
 
getConfDirArg(String[]) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
getConfDirArg(String[]) - Static method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationConfig
 
getConfig(Class<?>) - Static method in class edu.umass.cs.utils.Config
 
getConfigFileKey() - Method in enum edu.umass.cs.gigapaxos.PaxosConfig.PC
 
getConfigFileKey() - Method in enum edu.umass.cs.gigapaxos.testing.TESTPaxosConfig.TC
 
getConfigFileKey() - Method in enum edu.umass.cs.reconfiguration.ReconfigurationConfig.RC
 
getConfigFileKey() - Method in enum edu.umass.cs.reconfiguration.testing.TESTReconfigurationConfig.TRC
 
getConfigFileKey() - Method in interface edu.umass.cs.utils.Config.ConfigurableEnum
 
getCoordinator() - Method in class edu.umass.cs.gigapaxos.paxosutil.SlotBallotState
 
getCoordinatorRequestTypes() - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
getCounter() - Method in class edu.umass.cs.protocoltask.examples.PingPongPacket
 
getCreateTime() - Method in class edu.umass.cs.gigapaxos.paxospackets.PrepareReplyPacket
 
getCreateTime() - Method in class edu.umass.cs.gigapaxos.paxosutil.SlotBallotState
 
getCreateTime() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
getCreator() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
getCurEpochGroup() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
getCurNCEpoch() - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
getDBAsString(String) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
Start of testing methods
getDeactivationPeriod() - Static method in class edu.umass.cs.gigapaxos.PaxosManager
 
getDeadTime(NodeIDType) - Method in class edu.umass.cs.gigapaxos.FailureDetection
 
getDeadTime(int) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
getDebugInfo(boolean) - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getDefaultCallback() - Method in class edu.umass.cs.reconfiguration.Reconfigurator
 
getDefaultConfigFile() - Method in enum edu.umass.cs.gigapaxos.PaxosConfig.PC
 
getDefaultConfigFile() - Method in enum edu.umass.cs.gigapaxos.testing.TESTPaxosConfig.TC
 
getDefaultConfigFile() - Method in enum edu.umass.cs.reconfiguration.ReconfigurationConfig.RC
 
getDefaultConfigFile() - Method in enum edu.umass.cs.reconfiguration.testing.TESTReconfigurationConfig.TRC
 
getDefaultConfigFile() - Method in interface edu.umass.cs.utils.Config.ConfigurableEnum
 
getDefaultGroup() - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
getDefaultGroupSet() - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
getDefaultNodeConfig() - Static method in class edu.umass.cs.gigapaxos.PaxosConfig
 
getDefaultReconfigureUponActivesChangePolicy() - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
getDefaultServers() - Static method in class edu.umass.cs.gigapaxos.PaxosServer
 
getDefaultServers() - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
getDefaultServiceName() - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
getDefaultServiceNameInitialState() - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
getDefaultTypes() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.ActiveReplicaProtocolTask
 
getDefaultTypes() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.ReconfiguratorProtocolTask
 
getDefaultValue() - Method in enum edu.umass.cs.gigapaxos.PaxosConfig.PC
 
getDefaultValue() - Method in enum edu.umass.cs.gigapaxos.testing.TESTPaxosConfig.TC
 
getDefaultValue() - Method in enum edu.umass.cs.reconfiguration.ReconfigurationConfig.RC
 
getDefaultValue() - Method in enum edu.umass.cs.reconfiguration.testing.TESTReconfigurationConfig.TRC
 
getDefaultValue() - Method in interface edu.umass.cs.utils.Config.DefaultValueEnum
 
getDelayedDeleteWaitDuration() - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
The time for which we must wait before finally deleting a name's reconfiguration record (i.e., all memory of that name is lost) must be at least as high as paxos' MAX_FINAL_STATE_AGE, otherwise it can cause the creation of a name or addition of a reconfigurator to stall for arbitrarily long, or worse, violate safety by using incorrect state from previous incarnations.
getDeletedNodeIDs() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ServerReconfigurationPacket
 
getDeletedNodes() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
getDeleteTime() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
getDemandProfile() - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
getDemandStats(String) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
 
getDemandStats() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.AbstractDemandProfile
All relevant stats must be serializable into JSONObject.
getDemandStats() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DemandProfile
 
getDemandStats() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ProximateBalance
 
getDemandStats(String) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
getDemandStats(String) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
getDescriptio() - Method in interface edu.umass.cs.utils.Config.CLIOption
 
getDigest(Integer) - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedAccept
 
getDigest(MessageDigest) - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getDriver(SQL.SQLType) - Static method in class edu.umass.cs.gigapaxos.paxosutil.SQL
 
getEmulatedDelay(JSONObject) - Static method in class edu.umass.cs.nio.JSONDelayEmulator
Receiver calls this method to toString delay that is to be emulated, and delays processing the packet by that amount.
getEmulatedDelay(String) - Static method in class edu.umass.cs.nio.JSONDelayEmulator
 
getEmulatedDelay() - Static method in class edu.umass.cs.nio.JSONDelayEmulator
 
getEmulatedDelay(NodeIDType) - Method in interface edu.umass.cs.nio.nioutils.InterfaceDelayEmulator
 
getEncoded(boolean) - Method in class edu.umass.cs.utils.SessionKeys.SecretKeyCertificate
 
getEncryptedSecretKeyTimestamp(byte[]) - Static method in class edu.umass.cs.utils.SessionKeys
 
getEntryReplica() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getEntryReplica() - Method in class edu.umass.cs.reconfiguration.examples.noop.NoopAppRequest
 
getEntryReplicaRequestsAsBatch(int) - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getEntryServer() - Method in class edu.umass.cs.txn.Transaction
 
getEntryTime() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getEpoch(String) - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
getEpoch(String) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
getEpoch(String) - Method in class edu.umass.cs.reconfiguration.examples.AbstractReconfigurablePaxosApp
 
getEpoch(String) - Method in class edu.umass.cs.reconfiguration.examples.noop.NoopApp
 
getEpoch(String) - Method in interface edu.umass.cs.reconfiguration.interfaces.Reconfigurable
Returns the current (unique) epoch for name.
getEpoch(String) - Method in class edu.umass.cs.reconfiguration.PaxosReplicaCoordinator
 
getEpoch() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
getEpoch(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.TrivialRepliconfigurable
 
getEpoch(String) - Method in class edu.umass.cs.txn.AbstractTransactor
 
getEpochFinalCheckpointState(String, int) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
getEpochFinalCheckpointState(String, int) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
getEpochFinalCheckpointVersion(String) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
getEpochFinalCheckpointVersion(String) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
getEpochNumber() - Method in class edu.umass.cs.reconfiguration.examples.AppRequest
 
getEpochNumber() - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfigurableRequest
 
getEpochNumber() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.BasicReconfigurationPacket
 
getEpochNumber() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.DefaultAppRequest
 
getEpochNumber() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
 
getEventTypes() - Method in class edu.umass.cs.protocoltask.examples.PingPongServer
 
getEventTypes() - Method in class edu.umass.cs.protocoltask.examples.thresholdfetch.MajorityFetchProtocolTask
 
getEventTypes() - Method in interface edu.umass.cs.protocoltask.ProtocolTask
 
getEventTypes() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.ActiveReplicaProtocolTask
 
getEventTypes() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.ReconfiguratorProtocolTask
 
getEventTypes() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckDropEpoch
 
getEventTypes() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStartEpoch
 
getEventTypes() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStopEpoch
 
getEventTypes() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitEpochFinalState
 
getEventTypes() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitPrimaryExecution
 
getFinalState(String, int) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
getFinalState(String, int) - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
getFinalState(String, int) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
getFinalState(String, int) - Method in class edu.umass.cs.reconfiguration.examples.AbstractReconfigurablePaxosApp
 
getFinalState(String, int) - Method in class edu.umass.cs.reconfiguration.examples.noop.NoopApp
 
getFinalState(String, int) - Method in interface edu.umass.cs.reconfiguration.interfaces.Reconfigurable
Return the final checkpointed state for name, epoch.
getFinalState(String, int) - Method in class edu.umass.cs.reconfiguration.PaxosReplicaCoordinator
 
getFinalState() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.AckStopEpoch
 
getFinalState() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStopEpoch
 
getFinalState(String, int) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.TrivialRepliconfigurable
 
getFinalState(String, int) - Method in class edu.umass.cs.txn.AbstractTransactor
 
getFinalStateContainer(String, int) - Method in class edu.umass.cs.reconfiguration.PaxosReplicaCoordinator
Used by ActiveReplica and similar to getFinalState but wraps it in a container so that we can distinguish between null final state (a possibly legitimate value of the state) and no state at all (because the paxos group has moved on and deleted the state or never created it in the first place.
getFirstOnly() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getFirstPrevEpochCandidate() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
getFirstReconfigurator(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
getForwader() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
getForwardCount() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getForwardee() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
getForwarder() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
getForwarderID() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getFromPaxosConfig() - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
getFromPaxosConfig(boolean) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
FIXME: should not be public.
getGCSlot() - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
getGibberish() - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosClient
 
getGibberish() - Static method in class edu.umass.cs.reconfiguration.testing.TESTPaxosClient
 
getGlobal(Enum<?>) - Static method in class edu.umass.cs.utils.Config
 
getGlobalBoolean(Enum<?>) - Static method in class edu.umass.cs.utils.Config
 
getGlobalDouble(Enum<?>) - Static method in class edu.umass.cs.utils.Config
 
getGlobalInt(Enum<?>) - Static method in class edu.umass.cs.utils.Config
 
getGlobalLong(Enum<?>) - Static method in class edu.umass.cs.utils.Config
 
getGlobalShort(Enum<?>) - Static method in class edu.umass.cs.utils.Config
 
getGlobalString(Enum<?>) - Static method in class edu.umass.cs.utils.Config
 
getGPClient(AppRequestParser) - Static method in class edu.umass.cs.txn.TXUtils
Creates an async gigapaxos client without checking connectivity (because the reconfigurators may not yet have been initialized.
getGroup() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedAccept
 
getGroup() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedCommit
 
getGroup(String) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
getGroup(int) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
getGroupName(int) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
getGroups() - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
getGroupSet() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedAccept
 
getGroupSet() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedCommit
 
getHandleMessageReport(long) - Static method in class edu.umass.cs.nio.AbstractPacketDemultiplexer
 
getHash(String) - Method in class edu.umass.cs.gigapaxos.deprecated.DefaultPaxosInterfaceApp
 
getHash(String) - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosApp
 
getHashRCs() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
getHeadOnly() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
 
getHeardCount() - Method in class edu.umass.cs.gigapaxos.paxosutil.WaitforUtility
 
getHeardCount() - Method in class edu.umass.cs.utils.Waitfor
 
getHTTPPort(int) - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
getHTTPPortClearOffset() - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
getHTTPPortSSLOffset() - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
getHTTPSPort(int) - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
getInetAddressFromString(String) - Static method in class edu.umass.cs.utils.Util
 
getInetSocketAddressFromString(String) - Static method in class edu.umass.cs.utils.Util
 
getInetSocketAddressFromStringStrict(String) - Static method in class edu.umass.cs.utils.Util
 
getInitGroup() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
Returns the initGroup specified in this message.
getInitialState() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
 
getInitialState() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
getInitiator() - Method in class edu.umass.cs.protocoltask.json.ProtocolPacket
 
getInitiatorAsSet() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
getInitTime() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
getInt() - Method in enum edu.umass.cs.gigapaxos.examples.PaxosAppRequest.PacketType
 
getInt() - Method in enum edu.umass.cs.gigapaxos.paxospackets.PaxosPacket.PaxosPacketType
END static code block to ensure correct initialization
getInt() - Method in enum edu.umass.cs.protocoltask.examples.PingPongPacket.PacketType
 
getInt() - Method in enum edu.umass.cs.reconfiguration.examples.AppRequest.PacketType
 
getInt() - Method in enum edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket.PacketType
 
getInt() - Method in enum edu.umass.cs.txn.txpackets.TXPacket.PacketType
 
getInt(Enum<?>) - Method in class edu.umass.cs.utils.Config
 
getInt() - Method in interface edu.umass.cs.utils.IntegerType
 
getIntArrayAsNodeSet(int[]) - Method in class edu.umass.cs.gigapaxos.paxosutil.IntegerMap
 
getInterCheckpointInterval() - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
getIPToActiveReplicaIDs(ArrayList<InetAddress>, Set<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
This method maps a set of addresses, newAddresses, to a set of nodes such that there is maximal overlap with the specified set of nodes, oldNodes.
getIssuer() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ServerReconfigurationPacket
 
getJSONArray(Set<InetSocketAddress>) - Static method in class edu.umass.cs.utils.Util
 
getJSONStats() - Static method in class edu.umass.cs.nio.nioutils.NIOInstrumenter
 
getKey() - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
getKey() - Method in class edu.umass.cs.gigapaxos.paxosutil.LogIndex
 
getKey() - Method in class edu.umass.cs.protocoltask.examples.pingpong.PingPongProtocolTask
Start of overridden methods
getKey() - Method in class edu.umass.cs.protocoltask.examples.PingPongServer
Start of overridden methods
getKey() - Method in class edu.umass.cs.protocoltask.examples.thresholdfetch.MajorityFetchProtocolTask
Start of overridden methods
getKey() - Method in class edu.umass.cs.protocoltask.json.ProtocolPacket
 
getKey() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.ActiveReplicaProtocolTask
 
getKey() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.ReconfiguratorProtocolTask
 
getKey() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckDropEpoch
 
getKey() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStartEpoch
 
getKey() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStopEpoch
 
getKey() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitEpochFinalState
 
getKey() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitPrimaryExecution
 
getKey() - Method in class edu.umass.cs.utils.DiskMap.LastActive
 
getKey() - Method in interface edu.umass.cs.utils.Keyable
 
getLabel() - Method in enum edu.umass.cs.gigapaxos.paxospackets.PaxosPacket.PaxosPacketType
 
getLabel() - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
getLastActive() - Method in class edu.umass.cs.gigapaxos.paxosutil.LogIndex
 
getLength() - Method in class edu.umass.cs.gigapaxos.paxosutil.LogIndex.LogIndexEntry
 
getLengthEstimate() - Method in class edu.umass.cs.gigapaxos.paxospackets.PrepareReplyPacket
 
getListenAddress() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getListeningAddress() - Method in class edu.umass.cs.nio.NIOTransport
 
getListeningAddress() - Method in class edu.umass.cs.reconfiguration.http.HttpReconfigurator
 
getListeningPort() - Method in class edu.umass.cs.nio.NIOTransport
 
getListeningSocketAddress() - Method in interface edu.umass.cs.nio.interfaces.InterfaceNIOTransport
 
getListeningSocketAddress() - Method in class edu.umass.cs.nio.JSONMessenger
 
getListeningSocketAddress() - Method in class edu.umass.cs.nio.NIOTransport
 
getLocalActives() - Static method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationConfig
 
getLocalAddress() - Static method in class edu.umass.cs.nio.nioutils.SampleNodeConfig
 
getLocalReconfigurators() - Static method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationConfig
 
getLockID() - Method in class edu.umass.cs.txn.txpackets.LockRequest
 
getLockList() - Method in interface edu.umass.cs.txn.interfaces.TXRequest
 
getLockList() - Method in class edu.umass.cs.txn.Transaction
 
getLocksDir() - Static method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
getLog(long) - Static method in class edu.umass.cs.gigapaxos.paxosutil.RequestInstrumenter
 
getLog() - Static method in class edu.umass.cs.gigapaxos.paxosutil.RequestInstrumenter
 
getLogfile() - Method in class edu.umass.cs.gigapaxos.paxosutil.LogIndex.LogIndexEntry
 
getLogfiles() - Method in class edu.umass.cs.gigapaxos.paxosutil.LogIndex
 
getLoggedAccepts(String, int, int, Integer) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
We must supply the version here for safety.
getLoggedAccepts(String, int, int) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
getLoggedAccepts(int, Integer) - Method in class edu.umass.cs.gigapaxos.paxosutil.LogIndex
 
getLoggedAccepts(String, int, int, Integer) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
getLoggedDecisions(String, int, int, int) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
We must supply the version here for safety.
getLoggedDecisions(int, int) - Method in class edu.umass.cs.gigapaxos.paxosutil.LogIndex
 
getLoggedDecisions(String, int, int, int) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
getLoggedMessages(String) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
Gets a list of all logged messages for the paxos group paxosID.
getLoggedMessages(String) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
getLogger() - Static method in class edu.umass.cs.gigapaxos.PaxosConfig
 
getLogger() - Static method in class edu.umass.cs.nio.NIOTransport
 
getLogger() - Static method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
getLogger() - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
getLogger() - Static method in class edu.umass.cs.utils.Config
 
getLogger(String) - Static method in class edu.umass.cs.utils.MyLogger
 
getLong(Enum<?>) - Method in class edu.umass.cs.utils.Config
 
getLoopback(MessagingTask, int) - Static method in class edu.umass.cs.gigapaxos.paxosutil.MessagingTask
 
getMajorityCommittedSlot() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
getMajorityCommittedSlot(PaxosCoordinator) - Static method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
getMajorityCommittedSlot() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
Start of stand-alone'ish utility methods ************************* These private methods are not synchronized even though some of them take synchronization requiring structures as arguments because the callers above are *all* synchronized.
getMap() - Method in class edu.umass.cs.utils.NullIfEmptyMap
Make a copy and return.
getMatchingFiles(String, String...) - Static method in class edu.umass.cs.utils.Util
 
getMaxAcceptedSlot() - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
getMaxCommittedSlot() - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
getMaxFinalStateAge() - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
Necessary to ensure safety under name re-creations (see ReconfigurationConfig.getDelayedDeleteWaitDuration() below).
getMaxLoggedDecisionMap(MessagingTask[]) - Static method in class edu.umass.cs.gigapaxos.PaxosPacketBatcher
 
getMaxOutstandingCRPRequests(int) - Static method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
getMaxSyncDecisionsGap() - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
getMedianCheckpointedSlot() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedAccept
 
getMedianCheckpointedSlot() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedCommit
 
getMedianCheckpointedSlot() - Method in class edu.umass.cs.gigapaxos.paxospackets.PValuePacket
 
getMembers() - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
getMembers() - Method in class edu.umass.cs.gigapaxos.paxosutil.RecoveryInfo
 
getMembers() - Method in class edu.umass.cs.gigapaxos.paxosutil.WaitforUtility
 
getMembers() - Method in class edu.umass.cs.utils.Waitfor
 
getMembersHeardFrom() - Method in class edu.umass.cs.gigapaxos.paxosutil.WaitforUtility
 
getMembersHeardFrom() - Method in class edu.umass.cs.utils.Waitfor
 
getMergees() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
getMergeList(String) - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
getMergeList(String) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
Reconfigurator reconfiguration methods
getMergeLists() - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
getMergeLists() - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
getMessage() - Method in class edu.umass.cs.protocoltask.examples.PingPongPacket
 
getMessage() - Method in class edu.umass.cs.protocoltask.json.ProtocolPacket
 
getMessage() - Method in interface edu.umass.cs.protocoltask.ProtocolEvent
 
getMessage() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
 
getMessageDigest() - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
getMessageDigest() - Static method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getMessenger() - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
getMessenger() - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
getMetaDecision() - Method in class edu.umass.cs.gigapaxos.paxospackets.PValuePacket
 
getMetaRequestPacket(byte[]) - Static method in class edu.umass.cs.reconfiguration.testing.MetaRequestPacket
 
getMinLogfile() - Method in class edu.umass.cs.gigapaxos.paxosutil.LogIndex
 
getMinResyncDelay() - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
getMinSlot() - Method in class edu.umass.cs.gigapaxos.paxospackets.PrepareReplyPacket
 
getMissing() - Static method in class edu.umass.cs.nio.nioutils.NIOInstrumenter
 
getMissingCommittedSlots(int) - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
getMissingRequests(TESTPaxosClient[]) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosClient
 
getMissingRequests(TESTPaxosClient[]) - Static method in class edu.umass.cs.reconfiguration.testing.TESTPaxosClient
 
getMutualAuthAppRequestTypes() - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
getMutualAuthRequestTypes() - Method in interface edu.umass.cs.gigapaxos.interfaces.AppRequestParser
 
getMutualAuthRequestTypes() - Method in class edu.umass.cs.reconfiguration.examples.noopsimple.NoopApp
 
getMutualAuthRequestTypes() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.TrivialRepliconfigurable
 
getMyID() - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
getMyID() - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
getMyID() - Method in interface edu.umass.cs.nio.interfaces.InterfaceNIOTransport
 
getMyID() - Method in class edu.umass.cs.nio.IOSSSLDataProcessingWorker
 
getMyID() - Method in class edu.umass.cs.nio.JSONMessenger
 
getMyID() - Method in class edu.umass.cs.nio.MessageNIOTransport
 
getMyID() - Method in class edu.umass.cs.nio.SSLDataProcessingWorker
 
getMyID() - Method in class edu.umass.cs.protocoltask.examples.ExampleNode
 
getMyID() - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
getMyID() - Method in class edu.umass.cs.reconfiguration.ReconfigurableNode
 
getMyReceiver() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
getMyReceiver() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ServerReconfigurationPacket
 
getMyReceiver() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
getNACK() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getName() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.AbstractDemandProfile
 
getName() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
getNames(JSONObject) - Static method in class edu.umass.cs.utils.Util
Get an array of field names from a JSONObject.
getNameStateJSONArray(Map<String, String>) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
 
getNameStateMap(JSONObject) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
 
getNameStates() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
 
getNameStates() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
getNearest(Set<InetSocketAddress>) - Method in interface edu.umass.cs.gigapaxos.interfaces.NearestServerSelector
 
getNearest(Set<InetSocketAddress>) - Method in class edu.umass.cs.gigapaxos.paxosutil.E2ELatencyAwareRedirector
 
getNewActives() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
getNewConsistentHashRing() - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
getNewConsistentHashRing() - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
getNewGroup(String) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
getNewlyAddedNodes() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
getNewRCGroups() - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
getNewRCGroups() - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
getNextProposalSlot() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
getNextProposalSlot(PaxosCoordinator) - Static method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
getNextProposalSlot() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
getNIOHeader(byte[]) - Static method in class edu.umass.cs.nio.nioutils.NIOHeader
 
getNIOTransport() - Method in class edu.umass.cs.nio.JSONMessenger
 
getNode(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentHashing
 
getNodeAddress(NodeIDType) - Method in interface edu.umass.cs.nio.interfaces.NodeConfig
 
getNodeAddress() - Method in class edu.umass.cs.nio.NIOTransport
 
getNodeAddress(NodeIDType) - Method in class edu.umass.cs.nio.nioutils.SampleNodeConfig
 
getNodeAddress(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentNodeConfig
 
getNodeAddress(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DefaultNodeConfig
 
getNodeAddress(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.SimpleReconfiguratorNodeConfig
 
getNodeConfig() - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
getNodeConfig() - Method in interface edu.umass.cs.nio.interfaces.InterfaceNIOTransport
 
getNodeConfig() - Method in class edu.umass.cs.nio.JSONMessenger
 
getNodeConfig() - Method in class edu.umass.cs.nio.MessageNIOTransport
 
getNodeConfigRecords(ConsistentReconfigurableNodeConfig<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
getNodeID() - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
getNodeID() - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
getNodeID(JSONObject) - Static method in class edu.umass.cs.gigapaxos.paxospackets.FindReplicaGroupPacket
 
getNodeID(PaxosPacket) - Static method in class edu.umass.cs.gigapaxos.paxospackets.FindReplicaGroupPacket
 
getNodeIDs() - Method in interface edu.umass.cs.nio.interfaces.NodeConfig
 
getNodeIDs() - Method in class edu.umass.cs.nio.nioutils.SampleNodeConfig
 
getNodeIDs() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentNodeConfig
 
getNodeIDs() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
getNodeIDs(Set<String>) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
getNodeIDs() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DefaultNodeConfig
 
getNodeIDs() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.SimpleReconfiguratorNodeConfig
 
getNodeIPs(Set<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
Consistent coz it always consults nodeConfig.
getNodePort(NodeIDType) - Method in interface edu.umass.cs.nio.interfaces.NodeConfig
 
getNodePort() - Method in class edu.umass.cs.nio.NIOTransport
 
getNodePort(NodeIDType) - Method in class edu.umass.cs.nio.nioutils.SampleNodeConfig
Maps each node ID to a port number.
getNodePort(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentNodeConfig
 
getNodePort(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DefaultNodeConfig
 
getNodePort(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.SimpleReconfiguratorNodeConfig
 
getNodes() - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
getNodes() - Method in class edu.umass.cs.nio.nioutils.SampleNodeConfig
 
getNodeSetAsStringSet(Set<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
getNodesFromStringSet(Set<String>) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
getNodeSlots() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
getNodeSlots(PaxosCoordinator) - Static method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
getNodeSlots() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
getNodeSocketAddress(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentNodeConfig
 
getNodeSocketAddress(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
Returns the socket address of the public host corresponding to this id.
getNonLoopback(MessagingTask, int) - Static method in class edu.umass.cs.gigapaxos.paxosutil.MessagingTask
 
getNoopRequest(String) - Static method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
getNumCommitted(String) - Method in class edu.umass.cs.gigapaxos.deprecated.DefaultPaxosInterfaceApp
 
getNumCommitted(String) - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosApp
 
getNumExecuted(String) - Method in class edu.umass.cs.gigapaxos.deprecated.DefaultPaxosInterfaceApp
 
getNumExecuted(String) - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosApp
 
getNumRequests() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DemandProfile
 
getNumRequests() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ProximateBalance
 
getNumTotalRequests() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DemandProfile
 
getNumTotalRequests() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ProximateBalance
 
getObj() - Method in class edu.umass.cs.nio.JSONMessenger.JSONObjectWrapper
 
getObliviousPaxosStopRequest(String, int) - Static method in class edu.umass.cs.reconfiguration.examples.AppRequest
Deprecated.
getOffset() - Method in class edu.umass.cs.gigapaxos.paxosutil.LogIndex.LogIndexEntry
 
getOffsettedAddress(InetSocketAddress, int) - Static method in class edu.umass.cs.utils.Util
 
getOldConsistentHashRing() - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
getOldConsistentHashRing() - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
getOldGroup(String) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
getOldGroupName(String) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
getOldRCGroups() - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
getOldRCGroups() - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
getOptionName() - Method in interface edu.umass.cs.utils.Config.CLIOption
 
getOrGenerateSecretKey(PublicKey, PrivateKey) - Static method in class edu.umass.cs.utils.SessionKeys
 
getOtherThan(Set<?>, Object) - Static method in class edu.umass.cs.utils.Util
 
getOtherThanString(Set<?>, Object) - Static method in class edu.umass.cs.utils.Util
 
getOutOfOrderLimit() - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
getPacketizer() - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
getPacketType(int) - Static method in enum edu.umass.cs.gigapaxos.examples.PaxosAppRequest.PacketType
 
getPacketType(Object) - Method in class edu.umass.cs.gigapaxos.paxosutil.PaxosPacketDemultiplexerFast
 
getPacketType(JSONObject) - Method in class edu.umass.cs.nio.AbstractJSONPacketDemultiplexer
 
getPacketType(MessageType) - Method in class edu.umass.cs.nio.AbstractPacketDemultiplexer
 
getPacketType(JSONObject) - Static method in class edu.umass.cs.nio.JSONPacket
 
getPacketType(JSONObject) - Method in class edu.umass.cs.protocoltask.examples.PingPongPacket
 
getPacketType(JSONObject) - Method in class edu.umass.cs.protocoltask.json.ProtocolPacket
 
getPacketType(int) - Static method in enum edu.umass.cs.reconfiguration.examples.AppRequest.PacketType
 
getPacketType(JSONObject) - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
 
getPacketType(Request) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationPacketDemultiplexer
 
getPacketTypeCanonicalClassName(ReconfigurationPacket.PacketType) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
 
getPacketTypeClass(ReconfigurationPacket.PacketType) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
 
getPacketTypeClassName(ReconfigurationPacket.PacketType) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
 
getPacketTypes(boolean) - Method in class edu.umass.cs.reconfiguration.ActiveReplica
 
getPacketTypes() - Method in class edu.umass.cs.reconfiguration.ActiveReplica
 
getPacketTypes() - Method in class edu.umass.cs.reconfiguration.Reconfigurator
 
getPassword() - Static method in class edu.umass.cs.gigapaxos.paxosutil.SQL
 
getPaxosID() - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
getPaxosID() - Method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
getPaxosID() - Method in class edu.umass.cs.gigapaxos.paxosutil.RecoveryInfo
 
getPaxosIDVersion() - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
getPaxosIDVersion() - Method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
getPaxosLogger() - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
getPaxosManager() - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
getPaxosManager() - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosNode
 
getPaxosManager() - Method in class edu.umass.cs.reconfiguration.deprecated.AbstractReplicaCoordinatorPersistent
 
getPaxosNodeIDs(String) - Method in class edu.umass.cs.gigapaxos.deprecated.AbstractPaxosManager
Deprecated.
 
getPaxosPacket(String) - Static method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
Returns a PaxosPacket if parseable from a string.
getPaxosPacket(JSONObject) - Static method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
getPaxosPackets() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedPaxosPacket
 
getPaxosPacketStringifier() - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
getPaxosPacketType(JSONObject) - Static method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
getPaxosPacketType(JSONObject) - Static method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
getPaxosPacketType(int) - Static method in enum edu.umass.cs.gigapaxos.paxospackets.PaxosPacket.PaxosPacketType
 
getPaxosPacketType(String) - Static method in enum edu.umass.cs.gigapaxos.paxospackets.PaxosPacket.PaxosPacketType
 
getPayloadLength(ByteBuffer) - Static method in class edu.umass.cs.nio.NIOTransport
 
getPendingReconfigurations() - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
Names for which reconfiguration is incomplete, needed for recovery
getPendingReconfigurations() - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
getPendingReconfigurations() - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
getPendingSize() - Method in class edu.umass.cs.nio.NIOTransport
 
getPeriod() - Method in interface edu.umass.cs.protocoltask.SchedulableProtocolTask
 
getPeriod() - Method in class edu.umass.cs.protocoltask.ThresholdProtocolTask
The current restart period.
getPeriod() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.CommitWorker
 
getPeriod() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStartEpoch
 
getPeriod() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitPrimaryExecution
 
getPessimismOffset() - Static method in class edu.umass.cs.gigapaxos.FailureDetection
 
getPort(int) - Static method in class edu.umass.cs.nio.nioutils.SampleNodeConfig
 
getPreActiveProposals() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
getPreActiveProposals() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
getPreActivesIfPreempted(PaxosCoordinator, PrepareReplyPacket, int[]) - Static method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
getPrevEpochGroup() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
getPrevEpochNumber() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
getPrevGroupName() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
getPreviouslyIssuedAccept(RequestPacket) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
getProcessing() - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerTask
 
getProperties(Class<?>, String, String) - Static method in class edu.umass.cs.utils.Config
 
getPropertiesFile() - Static method in class edu.umass.cs.gigapaxos.PaxosConfig
 
getProperty(String) - Method in class edu.umass.cs.utils.Config
 
getProperty(String, String) - Method in class edu.umass.cs.utils.Config
 
getProtocolOrURL(SQL.SQLType) - Static method in class edu.umass.cs.gigapaxos.paxosutil.SQL
 
getQueueSize() - Method in class edu.umass.cs.gigapaxos.RequestBatcher
 
getRandomActiveReplica() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
getRandomAlphanumericBytes() - Static method in class edu.umass.cs.utils.Util
 
getRandomAlphanumericBytes(int) - Static method in class edu.umass.cs.utils.Util
 
getRandomOtherThan(Set<?>, Set<?>) - Static method in class edu.umass.cs.utils.Util
 
getRandomOtherThan(Set<?>, Object) - Static method in class edu.umass.cs.utils.Util
 
getRandomPValue(String, int, int, Ballot) - Static method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getRate(String) - Static method in class edu.umass.cs.utils.DelayProfiler
 
getRCEpoch(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
To get the RC epoch upon a node config change completion.
getRCEpoch(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
getRCGroupName(NodeIDType) - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
getRCGroupName(String) - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
getRCGroupName() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
getRCGroupName(String) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
getRCGroupName(NodeIDType) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
RC group name of node is just node.toString().
getRCGroupNames() - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
 
getRCGroupNames() - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
getRCGroups(NodeIDType, Set<NodeIDType>, boolean) - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
getRCGroups(NodeIDType, Set<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
getRCGroups() - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
Get current RC group names from the DB
getRCGroups() - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
getRCRequestType() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
 
getRCRequestTypeCompact(RCRecordRequest.RequestTypes) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
 
getRCTableString() - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
getReceiverAddress(byte[]) - Static method in class edu.umass.cs.nio.MessageNIOTransport
 
getReceiverAddress(JSONObject) - Static method in class edu.umass.cs.nio.MessageNIOTransport
 
getReceiverAddressJSONSmart(JSONObject) - Static method in class edu.umass.cs.nio.MessageNIOTransport
 
getReconfigurableReconfiguratorAsActiveReplica() - Method in class edu.umass.cs.reconfiguration.Reconfigurator
This treats the reconfigurator itself as an "active replica" in order to be able to reconfigure reconfigurator groups.
getReconfigurationPacket(JSONObject, Stringifiable<?>) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
 
getReconfigurationPacket(Request, Stringifiable<?>) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
 
getReconfigurationPacket(JSONObject) - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.ActiveReplicaProtocolTask
 
getReconfigurationPacketSuppressExceptions(JSONObject, Stringifiable<?>) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
 
getReconfigurationPacketSuppressExceptions(String, Stringifiable<?>) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
 
getReconfigurationPacketType() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
 
getReconfigurationPacketType(JSONObject) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
 
getReconfigurationRecord(String, int) - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
getReconfigurationRecord(String) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
 
getReconfigurationRecord(String) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
Allows uncoordinated access to DB state.
getReconfigurationRecord(String) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
Start of overridden methods
getReconfiguratorAddresses() - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
getReconfiguratorHash(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
Deprecated.
getReconfiguratorIDs() - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
getReconfigurators() - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfigurableNodeConfig
 
getReconfigurators() - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
getReconfigurators() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
getReconfigurators() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DefaultNodeConfig
 
getReconfigurators() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurableSampleNodeConfig
 
getReconfigurators() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.SimpleReconfiguratorNodeConfig
 
getReconfiguratorsAsAddresses(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
getReconfiguratorsReadOnly() - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfigurableNodeConfig
 
getReconfigureUponActivesChangePolicy() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
 
getReconfigureUponActivesChangePolicy() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
getReconfigureUponActivesChangePolicy() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
getRecovered(int, String) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
Deprecated.
getRecoveryInfo(String) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
getRecoveryInfo(String) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
getReplicaGroup(String, int) - Method in class edu.umass.cs.gigapaxos.PaxosManager
Returns members of this paxos instance if it is active, and null otherwise.
getReplicaGroup(String) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
getReplicaGroup(String) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
getReplicaGroup(String) - Method in class edu.umass.cs.reconfiguration.deprecated.AbstractReplicaCoordinatorPersistent
 
getReplicaGroup(String) - Method in class edu.umass.cs.reconfiguration.examples.noop.NoopAppCoordinator
 
getReplicaGroup(String) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfigurableAppInfo
 
getReplicaGroup(String) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReplicaCoordinator
This method must return the replica group that was most recently successfully created for the serviceName using createReplicaGroup.
getReplicaGroup(String) - Method in class edu.umass.cs.reconfiguration.PaxosReplicaCoordinator
 
getReplicaGroup(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DynamoReplicaCoordinator
 
getReplicaGroup(String) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
getReplicaGroup(String) - Method in class edu.umass.cs.txn.AbstractTransactor
 
getReplicatedActives(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
getReplicatedActivesIPs(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
getReplicatedReconfigurators(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
getReplicatedServers(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentHashing
 
getReplicatedServers(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentNodeConfig
 
getReplicatedServersArray(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentHashing
 
getReplicatedServersArray(String, int) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentHashing
 
getRequest() - Method in class edu.umass.cs.gigapaxos.async.RequestCallbackFuture
 
getRequest(String, int) - Method in class edu.umass.cs.gigapaxos.deprecated.DefaultPaxosInterfaceApp
 
getRequest(String) - Method in class edu.umass.cs.gigapaxos.deprecated.DefaultPaxosInterfaceApp
 
getRequest(String) - Method in class edu.umass.cs.gigapaxos.examples.noop.NoopPaxosApp
Needed only if app uses request types other than RequestPacket.
getRequest(String) - Method in interface edu.umass.cs.gigapaxos.interfaces.AppRequestParser
An application must support string-to-Request conversion and back.
getRequest(byte[], NIOHeader) - Method in interface edu.umass.cs.gigapaxos.interfaces.AppRequestParser
The implementation of this method is tied to and must be the inverse of Request.toBytes(), , i.e., invoking getRequest(request.toBytes(), header).equals(request).
getRequest(byte[], NIOHeader) - Method in interface edu.umass.cs.gigapaxos.interfaces.AppRequestParserBytes
 
getRequest(String) - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosApp
 
getRequest(String) - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
getRequest(String) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
getRequest(byte[], NIOHeader) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
getRequest(ReplicableClientRequest, NIOHeader) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
getRequest(String) - Method in class edu.umass.cs.reconfiguration.examples.noop.NoopApp
 
getRequest(String) - Method in class edu.umass.cs.reconfiguration.examples.NoopAppClient
 
getRequest(byte[], NIOHeader) - Method in class edu.umass.cs.reconfiguration.examples.NoopAppClient
 
getRequest(String) - Method in class edu.umass.cs.reconfiguration.examples.noopsimple.NoopApp
 
getRequest(byte[], NIOHeader) - Method in class edu.umass.cs.reconfiguration.examples.noopsimple.NoopApp
 
getRequest(AppRequestParser) - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
 
getRequest() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
 
getRequest(AppRequestParserBytes, NIOHeader) - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
 
getRequest(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.TrivialRepliconfigurable
 
getRequest(byte[], NIOHeader) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.TrivialRepliconfigurable
 
getRequest(String) - Method in class edu.umass.cs.reconfiguration.testing.NoopAppTesting
 
getRequest(byte[], NIOHeader) - Method in class edu.umass.cs.reconfiguration.testing.NoopAppTesting
 
getRequest(String) - Method in class edu.umass.cs.txn.testing.NoopAppTX
 
getRequest(byte[], NIOHeader) - Method in class edu.umass.cs.txn.testing.NoopAppTX
 
getRequestAsString() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
 
getRequestFromJSON(JSONObject) - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
getRequestID() - Method in class edu.umass.cs.gigapaxos.examples.PaxosAppRequest
 
getRequestID() - Method in interface edu.umass.cs.gigapaxos.interfaces.RequestIdentifier
The uniqueness of this identifier across all requests to a replica group is important for safety when PaxosConfig.PC.PREVENT_DOUBLE_EXECUTION is enabled as gigapaxos may otherwise assume that the duplicate request identifier corresponds to a retransmission and will send back the response if any corresponding to the first execution.
getRequestID() - Method in class edu.umass.cs.gigapaxos.paxospackets.AcceptReplyPacket
 
getRequestID(Integer) - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedAccept
 
getRequestID(int) - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedAcceptReply
 
getRequestID() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getRequestID() - Method in class edu.umass.cs.reconfiguration.examples.AppRequest
 
getRequestID() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ActiveReplicaError
 
getRequestID() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.DefaultAppRequest
 
getRequestID() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.DemandReport
 
getRequestID() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.EchoRequest
 
getRequestID() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
 
getRequestID() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
 
getRequestID() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RequestActiveReplicas
 
getRequestID() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StopEpoch
 
getRequestID() - Method in class edu.umass.cs.txn.txpackets.TXPacket
 
getRequestPacket() - Method in class edu.umass.cs.gigapaxos.PaxosManager.RequestAndCallback
 
getRequestPacket(byte[], NIOHeader) - Static method in class edu.umass.cs.gigapaxos.paxosutil.PaxosPacketDemultiplexerFast
 
getRequestPackets() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getRequestRate() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DemandProfile
 
getRequestRate() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ProximateBalance
 
getRequestType() - Method in class edu.umass.cs.gigapaxos.examples.PaxosAppRequest
 
getRequestType() - Method in interface edu.umass.cs.gigapaxos.interfaces.Request
 
getRequestType() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getRequestType() - Method in class edu.umass.cs.reconfiguration.examples.AppRequest
 
getRequestType() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.AckDropEpochFinalState
 
getRequestType() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.AckStartEpoch
 
getRequestType() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.AckStopEpoch
 
getRequestType() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.BasicReconfigurationPacket
 
getRequestType() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
getRequestType() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.DefaultAppRequest
 
getRequestType() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.DemandReport
 
getRequestType() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
 
getRequestType() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
 
getRequestType() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ServerReconfigurationPacket
 
getRequestType() - Method in class edu.umass.cs.reconfiguration.testing.MetaRequestPacket
 
getRequestType() - Method in class edu.umass.cs.txn.txpackets.TXPacket
 
getRequestTypes() - Method in class edu.umass.cs.gigapaxos.deprecated.DefaultPaxosInterfaceApp
 
getRequestTypes() - Method in class edu.umass.cs.gigapaxos.examples.noop.NoopPaxosApp
Needed only if app uses request types other than RequestPacket.
getRequestTypes() - Method in interface edu.umass.cs.gigapaxos.interfaces.AppRequestParser
 
getRequestTypes() - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosApp
 
getRequestTypes() - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
getRequestTypes() - Method in class edu.umass.cs.reconfiguration.examples.noop.NoopApp
 
getRequestTypes() - Method in class edu.umass.cs.reconfiguration.examples.noop.NoopAppCoordinator
 
getRequestTypes() - Method in class edu.umass.cs.reconfiguration.examples.NoopAppClient
 
getRequestTypes() - Method in class edu.umass.cs.reconfiguration.examples.noopsimple.NoopApp
 
getRequestTypes() - Method in class edu.umass.cs.reconfiguration.PaxosReplicaCoordinator
 
getRequestTypes() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DynamoReplicaCoordinator
 
getRequestTypes() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.TrivialRepliconfigurable
 
getRequestTypes() - Method in class edu.umass.cs.reconfiguration.testing.NoopAppTesting
 
getRequestTypes() - Method in class edu.umass.cs.txn.AbstractTransactor
 
getRequestTypes() - Method in class edu.umass.cs.txn.testing.NoopAppTX
 
getRequestValue() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getRequestValues() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getResponded() - Method in class edu.umass.cs.utils.Waitfor
 
getResponse() - Method in class edu.umass.cs.gigapaxos.examples.PaxosAppRequest
 
getResponse() - Method in interface edu.umass.cs.gigapaxos.interfaces.ClientRequest
 
getResponse() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getResponse() - Method in class edu.umass.cs.reconfiguration.examples.AppRequest
 
getResponse() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.EchoRequest
 
getResponse() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
 
getResponse() - Method in class edu.umass.cs.reconfiguration.testing.MetaRequestPacket
 
getResponse() - Method in class edu.umass.cs.txn.txpackets.TXPacket
 
getResponseCode() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
getResponseCode() - Method in class edu.umass.cs.txn.txpackets.TXPacket
 
getResponseMessage() - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorRequest
 
getResponseMessage() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
getResponseMessage() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ServerReconfigurationPacket
 
getRetransmissionCount() - Method in class edu.umass.cs.gigapaxos.paxosutil.WaitforUtility
 
getRetransmissionCount() - Method in class edu.umass.cs.utils.Waitfor
 
getRTT(InetAddress) - Static method in class edu.umass.cs.nio.nioutils.RTTEstimator
 
getSamplePValue() - Static method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getSchemaString(String, SQL.SQLType) - Static method in class edu.umass.cs.gigapaxos.paxosutil.SQL
 
getSecretKey(PublicKey, Long) - Static method in class edu.umass.cs.utils.SessionKeys
 
getSecretKey(PublicKey) - Static method in class edu.umass.cs.utils.SessionKeys
 
getSecretKeyCertificate(PublicKey) - Static method in class edu.umass.cs.utils.SessionKeys
 
getSecretKeyFromCertificate(byte[]) - Static method in class edu.umass.cs.utils.SessionKeys
 
getSecretKeyFromCertificate(byte[], PublicKey) - Static method in class edu.umass.cs.utils.SessionKeys
 
getSender() - Method in class edu.umass.cs.gigapaxos.paxospackets.FailureDetectionPacket
 
getSender() - Method in class edu.umass.cs.protocoltask.json.ProtocolPacket
 
getSender() - Method in interface edu.umass.cs.protocoltask.ThresholdProtocolEvent
 
getSenderAddress() - Method in class edu.umass.cs.gigapaxos.examples.PaxosAppRequest
 
getSenderAddress(JSONObject) - Static method in class edu.umass.cs.nio.MessageNIOTransport
 
getSenderAddress(byte[]) - Static method in class edu.umass.cs.nio.MessageNIOTransport
 
getSenderAddress() - Method in class edu.umass.cs.reconfiguration.examples.AppRequest
 
getSenderAddressAsString(JSONObject) - Static method in class edu.umass.cs.nio.MessageNIOTransport
 
getSenderAddressJSONSmart(JSONObject) - Static method in class edu.umass.cs.nio.MessageNIOTransport
 
getSenderInetAddress(JSONObject) - Static method in class edu.umass.cs.nio.MessageNIOTransport
 
getSendReplyToClient() - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
getServerAuthRequestTypes() - Method in interface edu.umass.cs.gigapaxos.interfaces.AppRequestParser
 
getServerSSLMode() - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
getServiceName() - Method in class edu.umass.cs.gigapaxos.examples.PaxosAppRequest
 
getServiceName() - Method in interface edu.umass.cs.gigapaxos.interfaces.Request
 
getServiceName() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getServiceName() - Method in class edu.umass.cs.reconfiguration.examples.AppRequest
 
getServiceName() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.BasicReconfigurationPacket
 
getServiceName() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.DefaultAppRequest
 
getServiceName() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigureActiveNodeConfig
 
getServiceName() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigureRCNodeConfig
 
getServiceName() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
 
getServiceName() - Method in class edu.umass.cs.txn.txpackets.LockRequest
 
getServiceName() - Method in class edu.umass.cs.txn.txpackets.TXPacket
 
getShort(Enum<?>) - Method in class edu.umass.cs.utils.Config
 
getSlot() - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
getSlot() - Method in class edu.umass.cs.gigapaxos.paxosutil.SlotBallotState
 
getSlotBallot(PaxosPacket) - Static method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
getSlotBallotState(String) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
getSlotBallotState(String, int) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
getSlotBallotState(String, String, int, boolean) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
Methods to get slot, ballotnum, coordinator, state, and version of checkpoint
getSlotBallotState(String, int, boolean) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
getSlotBallotState(String) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
getSlotBallotState(String, int) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
getSlotLog() - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
getSocketAddresses(JSONArray) - Static method in class edu.umass.cs.utils.Util
 
getSSLClientMessenger() - Method in interface edu.umass.cs.nio.interfaces.SSLMessenger
 
getSSLClientMessenger() - Method in class edu.umass.cs.nio.JSONMessenger
 
getSSLMode() - Method in interface edu.umass.cs.nio.interfaces.InterfaceNIOTransport
 
getSSLMode() - Method in class edu.umass.cs.nio.JSONMessenger
 
getSSLMode() - Method in class edu.umass.cs.nio.NIOTransport
 
getState() - Method in class edu.umass.cs.gigapaxos.paxosutil.RecoveryInfo
 
getState() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.EpochFinalState
 
getState() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
getState() - Method in class edu.umass.cs.txn.txpackets.TxStateRequest
 
getStatePacket(String) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
getStatePacket(SlotBallotState) - Static method in class edu.umass.cs.gigapaxos.paxospackets.StatePacket
 
getStatePacket(String) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
getStats() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.DemandReport
 
getStats() - Static method in class edu.umass.cs.reconfiguration.reconfigurationutils.AppInstrumenter
 
getStats() - Static method in class edu.umass.cs.utils.DelayProfiler
 
getStats(Set<String>) - Static method in class edu.umass.cs.utils.DelayProfiler
 
getStatsLog() - Static method in class edu.umass.cs.utils.DelayProfiler
 
getStopRequest(String, int) - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
getStopRequest(String, int) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
getStopRequest(String, int) - Method in class edu.umass.cs.reconfiguration.examples.AbstractReconfigurablePaxosApp
This class returns a default no-op stop request.
getStopRequest(String, int) - Method in class edu.umass.cs.reconfiguration.examples.noop.NoopApp
 
getStopRequest(String, int) - Method in class edu.umass.cs.reconfiguration.examples.noop.NoopAppCoordinator
 
getStopRequest(String, int) - Method in interface edu.umass.cs.reconfiguration.interfaces.Reconfigurable
Returns a stop request that when executed by the app ensures that no subsequent request after the stop is executed in that epoch.
getStopRequest(String, int) - Method in class edu.umass.cs.reconfiguration.PaxosReplicaCoordinator
 
getStopRequest(String, int) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.TrivialRepliconfigurable
 
getStopRequest(String, int) - Method in class edu.umass.cs.txn.AbstractTransactor
 
getString(Enum<?>) - Method in class edu.umass.cs.utils.Config
 
getStringifiedSelf() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getStringNodesFromIntArray(int[]) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
getSummary() - Method in interface edu.umass.cs.gigapaxos.interfaces.Request
 
getSummary() - Method in interface edu.umass.cs.gigapaxos.interfaces.SummarizableRequest
 
getSummary() - Method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
getSummary(boolean) - Method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
getSummary() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getSummary(boolean) - Method in class edu.umass.cs.gigapaxos.paxosutil.LogIndex
 
getSummary() - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfigurableRequest
 
getSummary(ClientRequest, boolean) - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
getSummary(ClientRequest) - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
getSummary() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.AckDropEpochFinalState
 
getSummary() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ActiveReplicaError
 
getSummary() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.BasicReconfigurationPacket
 
getSummary() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.BatchedCreateServiceName
 
getSummary() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
getSummary() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
 
getSummary() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.EchoRequest
 
getSummary() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.EpochFinalState
 
getSummary() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
 
getSummary(Level) - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
 
getSummary() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RequestActiveReplicas
 
getSummary() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ServerReconfigurationPacket
 
getSummary() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
getSummary() - Method in interface edu.umass.cs.utils.Summarizable
Implementations are encouraged to return an inline created new Object() whose toString() method will return the actual String instead of just returning the String directly.
getSummary(boolean) - Method in interface edu.umass.cs.utils.Summarizable
 
getSummaryString() - Method in class edu.umass.cs.gigapaxos.paxospackets.AcceptPacket
 
getSummaryString() - Method in class edu.umass.cs.gigapaxos.paxospackets.AcceptReplyPacket
 
getSummaryString() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedAccept
 
getSummaryString() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedAcceptReply
 
getSummaryString() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedCommit
 
getSummaryString() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedPaxosPacket
 
getSummaryString() - Method in class edu.umass.cs.gigapaxos.paxospackets.FailureDetectionPacket
 
getSummaryString() - Method in class edu.umass.cs.gigapaxos.paxospackets.FindReplicaGroupPacket
 
getSummaryString() - Method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
getSummaryString() - Method in class edu.umass.cs.gigapaxos.paxospackets.PreparePacket
 
getSummaryString() - Method in class edu.umass.cs.gigapaxos.paxospackets.PrepareReplyPacket
 
getSummaryString() - Method in class edu.umass.cs.gigapaxos.paxospackets.ProposalPacket
 
getSummaryString() - Method in class edu.umass.cs.gigapaxos.paxospackets.PValuePacket
 
getSummaryString() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
getSummaryString() - Method in class edu.umass.cs.gigapaxos.paxospackets.StatePacket
 
getSummaryString() - Method in class edu.umass.cs.gigapaxos.paxospackets.SyncDecisionsPacket
 
getTask(KeyType) - Method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
getTaskCount() - Method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
getTaskKey(Class<?>, BasicReconfigurationPacket<?>, String) - Static method in class edu.umass.cs.reconfiguration.Reconfigurator
 
getTaskKeyPrev(Class<?>, BasicReconfigurationPacket<?>, String) - Static method in class edu.umass.cs.reconfiguration.Reconfigurator
 
getThreadPoolSize() - Static method in class edu.umass.cs.nio.AbstractPacketDemultiplexer
 
getThroughput(String) - Static method in class edu.umass.cs.utils.DelayProfiler
 
getTimeout() - Method in interface edu.umass.cs.gigapaxos.interfaces.TimeoutRequestCallback
 
getTotalNoopCount() - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosClient
 
getTotalNoopCount() - Static method in class edu.umass.cs.reconfiguration.testing.TESTPaxosClient
 
getTxGroup(String) - Method in class edu.umass.cs.txn.DistTransactor
 
getTxGroupName() - Method in class edu.umass.cs.txn.Transaction
The transaction group name must be globally unique, otherwise the transaction will fail in the very first tx_group creation step.
getTXID() - Method in interface edu.umass.cs.txn.interfaces.TXInterface
 
getTXID() - Method in class edu.umass.cs.txn.Transaction
 
getTxID() - Method in class edu.umass.cs.txn.txpackets.TxOpRequest
 
getTXID() - Method in class edu.umass.cs.txn.txpackets.TXPacket
 
getTXID() - Method in class edu.umass.cs.txn.txpackets.UnlockRequest
 
getTxInitState() - Method in class edu.umass.cs.txn.Transaction
 
getTxOps() - Method in class edu.umass.cs.txn.Transaction
 
getTXPacketType() - Method in class edu.umass.cs.txn.txpackets.TXPacket
 
getTxState(GigaPaxosClient<Request>, Transaction) - Method in class edu.umass.cs.txn.TXUtils
 
getType() - Method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
getType(byte[]) - Static method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
getType() - Method in class edu.umass.cs.protocoltask.json.ProtocolPacket
 
getType() - Method in interface edu.umass.cs.protocoltask.ProtocolEvent
 
getUnclean() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
getUnderlyingNodeConfig() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
This method should not be used.
getUser() - Static method in class edu.umass.cs.gigapaxos.paxosutil.SQL
 
getValue() - Method in class edu.umass.cs.gigapaxos.examples.PaxosAppRequest
 
getValue() - Method in class edu.umass.cs.reconfiguration.examples.AppRequest
 
getValuesFromJSONArray(JSONArray) - Method in interface edu.umass.cs.nio.interfaces.Stringifiable
 
getValuesFromJSONArray(JSONArray) - Method in class edu.umass.cs.nio.nioutils.SampleNodeConfig
 
getValuesFromJSONArray(JSONArray) - Method in class edu.umass.cs.nio.nioutils.StringifiableDefault
 
getValuesFromJSONArray(JSONArray) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentNodeConfig
 
getValuesFromJSONArray(JSONArray) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
getValuesFromJSONArray(JSONArray) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DefaultNodeConfig
 
getValuesFromJSONArray(JSONArray) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurableSampleNodeConfig
 
getValuesFromJSONArray(JSONArray) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.SimpleReconfiguratorNodeConfig
 
getValuesFromStringSet(Set<String>) - Method in interface edu.umass.cs.nio.interfaces.Stringifiable
Converts a set of string node ids using valueOf.
getValuesFromStringSet(Set<String>) - Method in class edu.umass.cs.nio.nioutils.SampleNodeConfig
 
getValuesFromStringSet(Set<String>) - Method in class edu.umass.cs.nio.nioutils.StringifiableDefault
 
getValuesFromStringSet(Set<String>) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentNodeConfig
 
getValuesFromStringSet(Set<String>) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
getValuesFromStringSet(Set<String>) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DefaultNodeConfig
 
getValuesFromStringSet(Set<String>) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurableSampleNodeConfig
 
getValuesFromStringSet(Set<String>) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.SimpleReconfiguratorNodeConfig
 
getVarcharSize(SQL.SQLType) - Static method in class edu.umass.cs.gigapaxos.paxosutil.SQL
 
getVersion() - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
getVersion(String) - Method in class edu.umass.cs.gigapaxos.PaxosManager
The Integer return value as opposed to int is convenient to say that there is no epoch.
getVersion() - Method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
getVersion() - Method in class edu.umass.cs.gigapaxos.paxosutil.RecoveryInfo
 
getVersion() - Method in class edu.umass.cs.gigapaxos.paxosutil.SlotBallotState
 
getVersion() - Method in interface edu.umass.cs.reconfiguration.interfaces.ModifiableActiveConfig
Unused.
getVersion() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
getVersion() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DefaultNodeConfig
 
getVersion() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.SimpleReconfiguratorNodeConfig
 
gibberish - Static variable in class edu.umass.cs.nio.nioutils.NIOTester
 
gibberish - Static variable in class edu.umass.cs.nio.nioutils.NIOTesterD
 
GIGAPAXOS_CONFIG_FILE_KEY - Static variable in class edu.umass.cs.gigapaxos.PaxosConfig
Gigapaxos config file information can be specified using -DgigapaxosConfig= as a JVM argument.
GigaPaxosClient<V> - Interface in edu.umass.cs.reconfiguration.interfaces
 
GigapaxosShutdownable - Interface in edu.umass.cs.gigapaxos.interfaces
 
group - Variable in class edu.umass.cs.gigapaxos.paxospackets.FindReplicaGroupPacket
Replica group if known.

H

handleAcceptReply(PaxosCoordinator, int[], AcceptReplyPacket) - Static method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
handleAcceptReply(int[], AcceptReplyPacket) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
handleAcceptReplyHigherBallot(AcceptReplyPacket) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
handleAcceptReplyHigherBallot(AcceptReplyPacket) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
handleAcceptReplyMyBallot(int[], AcceptReplyPacket) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
handleAcceptReplyMyBallot(int[], AcceptReplyPacket) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
Start of Phase2b methods
handleCreateServiceName(CreateServiceName, ProtocolTask<NodeIDType, ReconfigurationPacket.PacketType, String>[]) - Method in class edu.umass.cs.reconfiguration.Reconfigurator
Create service name is a special case of reconfiguration where the previous group is non-existent.
handleCreateServiceName(CreateServiceName, ProtocolTask<NodeIDType, ReconfigurationPacket.PacketType, String>[], Callback<Request, ReconfiguratorRequest>) - Method in class edu.umass.cs.reconfiguration.Reconfigurator
 
handleDecision(String, String, boolean) - Method in interface edu.umass.cs.gigapaxos.deprecated.Application
An atomic operation that either completes and returns true or throws an exception.
handleDecision(String, String, boolean) - Method in class edu.umass.cs.gigapaxos.deprecated.DefaultPaxosInterfaceApp
 
handleDecision(String, String, boolean) - Method in interface edu.umass.cs.gigapaxos.deprecated.ReplicableDeprecated
 
handleDeleteServiceName(DeleteServiceName, ProtocolTask<NodeIDType, ReconfigurationPacket.PacketType, String>[]) - Method in class edu.umass.cs.reconfiguration.Reconfigurator
We need to ensure that both the stop/drop at actives happens atomically with the removal of the record at reconfigurators.
handleDeleteServiceName(DeleteServiceName, ProtocolTask<NodeIDType, ReconfigurationPacket.PacketType, String>[], Callback<Request, ReconfiguratorRequest>) - Method in class edu.umass.cs.reconfiguration.Reconfigurator
 
handleDemandReport(DemandReport<NodeIDType>, boolean) - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
handleDemandReport(DemandReport<NodeIDType>, ProtocolTask<NodeIDType, ReconfigurationPacket.PacketType, String>[]) - Method in class edu.umass.cs.reconfiguration.Reconfigurator
Incorporates demand reports (possibly but not necessarily with replica coordination), checks for reconfiguration triggers, and initiates reconfiguration if needed.
handleDropEpochFinalState(DropEpochFinalState<NodeIDType>, ProtocolTask<NodeIDType, ReconfigurationPacket.PacketType, String>[]) - Method in class edu.umass.cs.reconfiguration.ActiveReplica
 
handleEchoRequest(EchoRequest, ProtocolTask<NodeIDType, ReconfigurationPacket.PacketType, String>[]) - Method in class edu.umass.cs.reconfiguration.ActiveReplica
 
handleEchoRequest(EchoRequest, ProtocolTask<NodeIDType, ReconfigurationPacket.PacketType, String>[]) - Method in class edu.umass.cs.reconfiguration.Reconfigurator
 
handleEvent(ProtocolEvent<PingPongPacket.PacketType, String>, ProtocolTask<Integer, PingPongPacket.PacketType, String>[]) - Method in class edu.umass.cs.protocoltask.examples.pingpong.PingPongProtocolTask
 
handleEvent(ProtocolEvent<PingPongPacket.PacketType, String>, ProtocolTask<Integer, PingPongPacket.PacketType, String>[]) - Method in class edu.umass.cs.protocoltask.examples.PingPongServer
 
handleEvent(ProtocolEvent<PingPongPacket.PacketType, String>) - Method in class edu.umass.cs.protocoltask.examples.thresholdfetch.MajorityFetchProtocolTask
 
handleEvent(ProtocolEvent<EventType, KeyType>) - Method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
handleEvent(ProtocolEvent<EventType, KeyType>, ProtocolTask<NodeIDType, EventType, KeyType>[]) - Method in interface edu.umass.cs.protocoltask.ProtocolTask
The action handling the event may return messaging tasks that will be automatically handled by this interface.
handleEvent(ProtocolEvent<EventType, KeyType>) - Method in class edu.umass.cs.protocoltask.ThresholdProtocolTask
 
handleEvent(ProtocolEvent<EventType, KeyType>, ProtocolTask<NodeIDType, EventType, KeyType>[]) - Method in class edu.umass.cs.protocoltask.ThresholdProtocolTask
This method automatically keeps track of senders from which we have already received valid responses in order to keep track of whether the threshold has been reached, and if so, it invokes handleThresholdEvent
handleEvent(ProtocolEvent<ReconfigurationPacket.PacketType, String>, ProtocolTask<NodeIDType, ReconfigurationPacket.PacketType, String>[]) - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.ActiveReplicaProtocolTask
 
handleEvent(ProtocolEvent<ReconfigurationPacket.PacketType, String>, ProtocolTask<NodeIDType, ReconfigurationPacket.PacketType, String>[]) - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.ReconfiguratorProtocolTask
 
handleEvent(ProtocolEvent<ReconfigurationPacket.PacketType, String>, ProtocolTask<NodeIDType, ReconfigurationPacket.PacketType, String>[], Callback<Request, ReconfiguratorRequest>) - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.ReconfiguratorProtocolTask
 
handleEvent(ProtocolEvent<ReconfigurationPacket.PacketType, String>) - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckDropEpoch
 
handleEvent(ProtocolEvent<ReconfigurationPacket.PacketType, String>) - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStartEpoch
 
handleEvent(ProtocolEvent<ReconfigurationPacket.PacketType, String>) - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStopEpoch
 
handleEvent(ProtocolEvent<ReconfigurationPacket.PacketType, String>) - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitEpochFinalState
 
handleIncoming(JSONObject) - Method in class edu.umass.cs.protocoltask.examples.ExampleNode
 
handleIncoming(Request, ExecutedCallback) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
Coordinate if needed, else hand over to app.
handleIncomingPacket(JSONObject) - Method in class edu.umass.cs.gigapaxos.deprecated.AbstractPaxosManager
Deprecated.
Handle incoming message for any Paxos instance as well as failure detection messages.
handleMessage(Object, NIOHeader) - Method in class edu.umass.cs.gigapaxos.paxosutil.PaxosPacketDemultiplexerFast
 
handleMessage(MessageType, NIOHeader) - Method in interface edu.umass.cs.nio.interfaces.PacketDemultiplexer
 
handleMessage(JSONObject, NIOHeader) - Method in class edu.umass.cs.nio.nioutils.PacketDemultiplexerDefault
 
handleMessage(JSONObject, NIOHeader) - Method in class edu.umass.cs.protocoltask.examples.ExamplePacketDemultiplexer
 
handleMessage(Request, NIOHeader) - Method in class edu.umass.cs.reconfiguration.ActiveReplica
 
handleMessage(Request, NIOHeader) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationPacketDemultiplexer
 
handleMessage(Request, NIOHeader) - Method in class edu.umass.cs.reconfiguration.Reconfigurator
 
handleMessageSuper(byte[], NIOHeader) - Method in class edu.umass.cs.nio.AbstractPacketDemultiplexer
 
handlePaxosMessage(PaxosPacket) - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
This is the main entry point into this class and is used by PaxosManager to supply incoming packets.
handlePrepare(PreparePacket, int) - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
handlePrepareReply(PaxosCoordinator, PrepareReplyPacket, int[]) - Static method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
handlePrepareReply(PrepareReplyPacket, int[]) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
HANDLER_METHOD_PREFIX - Static variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
Used for reflection for invoking packet handling methods.
handleRCRecordRequest(RCRecordRequest<NodeIDType>, boolean) - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
If a reconfiguration intent is being registered, a protocol task must be started that ensures that the reconfiguration completes successfully.
handleRCRecordRequest(RCRecordRequest<NodeIDType>, ProtocolTask<NodeIDType, ReconfigurationPacket.PacketType, String>[]) - Method in class edu.umass.cs.reconfiguration.Reconfigurator
Simply hand over DB request to DB.
handleReconfigureActiveNodeConfig(ReconfigureActiveNodeConfig<NodeIDType>, ProtocolTask<NodeIDType, ReconfigurationPacket.PacketType, String>[]) - Method in class edu.umass.cs.reconfiguration.Reconfigurator
 
handleReconfigureRCNodeConfig(ReconfigureRCNodeConfig<NodeIDType>, ProtocolTask<NodeIDType, ReconfigurationPacket.PacketType, String>[]) - Method in class edu.umass.cs.reconfiguration.Reconfigurator
Handles a request to add or delete a reconfigurator from the set of all reconfigurators in NodeConfig.
handleRequestActiveReplicas(RequestActiveReplicas, boolean) - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
handleRequestActiveReplicas(RequestActiveReplicas, ProtocolTask<NodeIDType, ReconfigurationPacket.PacketType, String>[]) - Method in class edu.umass.cs.reconfiguration.Reconfigurator
This method simply looks up and returns the current set of active replicas.
handleRequestActiveReplicas(RequestActiveReplicas, ProtocolTask<NodeIDType, ReconfigurationPacket.PacketType, String>[], Callback<Request, ReconfiguratorRequest>) - Method in class edu.umass.cs.reconfiguration.Reconfigurator
 
handleRequestEpochFinalState(RequestEpochFinalState<NodeIDType>, ProtocolTask<NodeIDType, ReconfigurationPacket.PacketType, String>[]) - Method in class edu.umass.cs.reconfiguration.ActiveReplica
 
handleResponse(Request) - Method in interface edu.umass.cs.gigapaxos.interfaces.RequestCallback
 
handleResponse(Request) - Method in interface edu.umass.cs.txn.interfaces.TxOp
 
handleResponse(Request) - Method in class edu.umass.cs.txn.txpackets.TxOpRequest
 
handleStartEpoch(StartEpoch<NodeIDType>, ProtocolTask<NodeIDType, ReconfigurationPacket.PacketType, String>[]) - Method in class edu.umass.cs.reconfiguration.ActiveReplica
Will spawn FetchEpochFinalState to fetch the final state of the previous epoch if one existed, else will locally create the current epoch with an empty initial state.
handleStopEpoch(StopEpoch<NodeIDType>, boolean) - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
handleStopEpoch(StopEpoch<NodeIDType>, ProtocolTask<NodeIDType, ReconfigurationPacket.PacketType, String>[]) - Method in class edu.umass.cs.reconfiguration.ActiveReplica
 
handleThresholdEvent(ProtocolTask<Integer, PingPongPacket.PacketType, String>[]) - Method in class edu.umass.cs.protocoltask.examples.thresholdfetch.MajorityFetchProtocolTask
 
handleThresholdEvent(ProtocolTask<NodeIDType, EventType, KeyType>[]) - Method in class edu.umass.cs.protocoltask.ThresholdProtocolTask
Default action is to cancel the protocol task when the threshold is reached.
handleThresholdEvent(ProtocolTask<NodeIDType, ReconfigurationPacket.PacketType, String>[]) - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckDropEpoch
We should delete the record currently pending deletion.
handleThresholdEvent(ProtocolTask<NodeIDType, ReconfigurationPacket.PacketType, String>[]) - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStartEpoch
 
handleThresholdEvent(ProtocolTask<NodeIDType, ReconfigurationPacket.PacketType, String>[]) - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStopEpoch
 
handleThresholdEvent(ProtocolTask<NodeIDType, ReconfigurationPacket.PacketType, String>[]) - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitEpochFinalState
 
HandshakeCallback - Interface in edu.umass.cs.nio.interfaces
 
handshakeComplete(SelectionKey) - Method in interface edu.umass.cs.nio.interfaces.HandshakeCallback
 
handshakeComplete(SelectionKey) - Method in class edu.umass.cs.nio.NIOTransport
 
hasAddedNodes() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ServerReconfigurationPacket
 
hasArg() - Method in interface edu.umass.cs.utils.Config.CLIOption
 
hasBeenMerged(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
hasBeenMerged(Set<String>) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
hasClosest() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.EchoRequest
 
hasCurEpochGroup() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
hasDeletedNodes() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ServerReconfigurationPacket
 
hashCode() - Method in class edu.umass.cs.gigapaxos.paxosutil.Ballot
 
hashCode() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
 
hashmapSize() - Method in class edu.umass.cs.utils.MultiArrayMap
 
hasLargeCheckpoints() - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
hasMergees() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
hasNewlyAddedNodes() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
hasPrevEpochGroup() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
hasRecovered() - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
hasRecovered(PaxosInstanceStateMachine) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
hasRequestValue() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
heardFrom(NodeIDType) - Method in class edu.umass.cs.gigapaxos.FailureDetection
 
heardFrom(int) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
heardFromMajority() - Method in class edu.umass.cs.gigapaxos.paxosutil.WaitforUtility
 
heardFromMajority() - Method in class edu.umass.cs.utils.Waitfor
 
hibernate(PaxosInstanceStateMachine) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
hintRestore(K, V) - Method in class edu.umass.cs.utils.DiskMap
 
hotRestore(HotRestoreInfo) - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
hotRestore(PaxosCoordinator, HotRestoreInfo) - Static method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
HotRestoreInfo - Class in edu.umass.cs.gigapaxos.paxosutil
 
HotRestoreInfo(String, int, int[], int, Ballot, int, Ballot, int, int[]) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.HotRestoreInfo
 
HotRestoreInfo(String) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.HotRestoreInfo
 
HotRestoreInfo.HotRestoreInfoTest - Class in edu.umass.cs.gigapaxos.paxosutil
 
HotRestoreInfoTest() - Constructor for class edu.umass.cs.gigapaxos.paxosutil.HotRestoreInfo.HotRestoreInfoTest
 
HTTPException - Exception in edu.umass.cs.reconfiguration.http
 
HttpReconfigurator - Class in edu.umass.cs.reconfiguration.http
 
HttpReconfigurator(ReconfiguratorFunctions, InetSocketAddress, boolean) - Constructor for class edu.umass.cs.reconfiguration.http.HttpReconfigurator
 
HttpReconfigurator.HTTPKeys - Enum in edu.umass.cs.reconfiguration.http
String keys for URI keys.
HttpReconfigurator.HTTPRequestTypes - Enum in edu.umass.cs.reconfiguration.http
 

I

incrAccepted() - Static method in class edu.umass.cs.nio.nioutils.NIOInstrumenter
 
incrBytesRcvd(int) - Static method in class edu.umass.cs.nio.nioutils.NIOInstrumenter
 
incrBytesSent(int) - Static method in class edu.umass.cs.nio.nioutils.NIOInstrumenter
 
incrCounter() - Method in class edu.umass.cs.protocoltask.examples.PingPongPacket
 
incrEncrBytesRcvd(int) - Static method in class edu.umass.cs.nio.nioutils.NIOInstrumenter
 
incrEncrBytesSent(int) - Static method in class edu.umass.cs.nio.nioutils.NIOInstrumenter
 
incrEpoch(int) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
incrInitiated() - Static method in class edu.umass.cs.nio.nioutils.NIOInstrumenter
 
incrJSONRcvd() - Static method in class edu.umass.cs.nio.nioutils.NIOInstrumenter
 
incrOutstanding(RequestPacket) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
incrRcvd() - Static method in class edu.umass.cs.nio.nioutils.NIOInstrumenter
 
incrRetransmissonCount() - Method in class edu.umass.cs.gigapaxos.paxosutil.WaitforUtility
 
incrRetransmissonCount(boolean) - Method in class edu.umass.cs.gigapaxos.paxosutil.WaitforUtility
 
incrRetransmissonCount() - Method in class edu.umass.cs.utils.Waitfor
 
incrSent() - Static method in class edu.umass.cs.nio.nioutils.NIOInstrumenter
 
inflate(byte[]) - Static method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
info(Object...) - Method in class edu.umass.cs.utils.MyLogger
 
initClientMessenger(InetSocketAddress, InterfaceNIOTransport<NodeIDType, ?>) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
initialState - Variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
Initial state.
initialState - Variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
Initial state of epoch being started.
initiateReadActiveRecords(NodeIDType) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
 
initiateReadActiveRecords(NodeIDType) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
initiateReadCheckpoints(boolean) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
Prepares a cursor in the DB so that the caller can start reading checkpoints one at a time.
initiateReadCheckpoints(boolean) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
Start of incremental checkpoint read methods
initiateReadMessages() - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
initiateReadMessages() - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
initInstrumenter() - Method in class edu.umass.cs.reconfiguration.ActiveReplica
 
insertInitialCheckpoints(Map<String, String>, Set<String>, int[]) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
insertMerged(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
instrument(int) - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
INSTRUMENT_SERIALIZATION - Static variable in class edu.umass.cs.gigapaxos.paxosutil.PaxosMessenger
 
IntegerMap<NodeIDType> - Class in edu.umass.cs.gigapaxos.paxosutil
 
IntegerMap() - Constructor for class edu.umass.cs.gigapaxos.paxosutil.IntegerMap
 
IntegerPacketType - Interface in edu.umass.cs.nio.interfaces
 
IntegerPacketTypeMap<V extends IntegerPacketType> - Class in edu.umass.cs.utils
 
IntegerPacketTypeMap(V[]) - Constructor for class edu.umass.cs.utils.IntegerPacketTypeMap
 
IntegerType - Interface in edu.umass.cs.utils
 
INTER_CHECKPOINT_INTERVAL - Static variable in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
interArrivalTime - Variable in class edu.umass.cs.reconfiguration.reconfigurationutils.DemandProfile
 
InterfaceDelayEmulator<NodeIDType> - Interface in edu.umass.cs.nio.nioutils
 
InterfaceMessageExtractor - Interface in edu.umass.cs.nio.interfaces
 
InterfaceNIOTransport<NodeIDType,MessageType> - Interface in edu.umass.cs.nio.interfaces
 
intToIntegerArray(int[]) - Static method in class edu.umass.cs.utils.Util
 
intToString(int) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
intToType - Static variable in enum edu.umass.cs.protocoltask.examples.PingPongPacket.PacketType
 
intToType - Static variable in enum edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket.PacketType
 
intToType - Static variable in enum edu.umass.cs.txn.txpackets.TXPacket.PacketType
 
IOSSSLDataProcessingWorker - Class in edu.umass.cs.nio
 
IOSSSLDataProcessingWorker(DataProcessingWorker, SSLDataProcessingWorker.SSL_MODES, String) - Constructor for class edu.umass.cs.nio.IOSSSLDataProcessingWorker
 
IPv4Prefix(InetAddress, int) - Constructor for class edu.umass.cs.nio.nioutils.RTTEstimator.IPv4Prefix
 
IPv4Prefix(String) - Constructor for class edu.umass.cs.nio.nioutils.RTTEstimator.IPv4Prefix
 
isActive() - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
isActive() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
isActive(PaxosCoordinator) - Static method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
isActive() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
isActive() - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
isActiveNodeConfigChange() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
 
isActiveNodeConfigChange() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
isAffected(NodeIDType, NodeIDType) - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
isAggregatedMergeSplit() - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
Default true now for an improved merge/split implementation.
isBatched() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
 
isBatchedCreate() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
isBeingAdded(String) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
isBeingDeleted(String) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
isBlocking() - Method in interface edu.umass.cs.txn.interfaces.TxOp
 
isBlocking() - Method in class edu.umass.cs.txn.txpackets.TxOpRequest
 
isBroadcasted() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
isCheckpointHandle(String) - Static method in class edu.umass.cs.gigapaxos.paxosutil.LargeCheckpointer
 
isClosed() - Method in class edu.umass.cs.reconfiguration.http.HttpReconfigurator
 
isCoalescable() - Method in class edu.umass.cs.gigapaxos.paxospackets.AcceptReplyPacket
 
isCoalescable() - Method in class edu.umass.cs.gigapaxos.paxospackets.PValuePacket
 
isCommandering(int) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
isCommandering(int) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
isCommitted(long) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
Deprecated.
isCommitted() - Method in class edu.umass.cs.txn.txpackets.AbortRequest
 
isComplete() - Method in class edu.umass.cs.gigapaxos.paxospackets.PrepareReplyPacket
 
isCongested() - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
isCongested(NIOHeader) - Method in class edu.umass.cs.nio.AbstractJSONPacketDemultiplexer
 
isCongested(NIOHeader) - Method in class edu.umass.cs.nio.AbstractPacketDemultiplexer
 
isCrashed(Object) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
isCrashed(Object) - Static method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationConfig
 
isCreateHRI() - Method in class edu.umass.cs.gigapaxos.paxosutil.HotRestoreInfo
 
isCreateRequest() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
isCurrent(String, int) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
isDelayEmulated() - Static method in class edu.umass.cs.nio.JSONDelayEmulator
 
isDeletable() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
isDeleteIntent() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
 
isDeleteIntentOrPrevDropComplete() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
 
isDeleteName() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.DropEpochFinalState
 
isDeletePending() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
isDeleteRequest() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
isDisabled() - Method in enum edu.umass.cs.gigapaxos.PaxosConfig.PC
 
isDisabled() - Method in interface edu.umass.cs.utils.Config.Disableable
 
isDisconnected(NodeIDType) - Method in interface edu.umass.cs.nio.interfaces.InterfaceNIOTransport
 
isDisconnected(NodeIDType) - Method in class edu.umass.cs.nio.JSONMessenger
 
isDisconnected(NodeIDType) - Method in class edu.umass.cs.nio.NIOTransport
 
isDone() - Method in class edu.umass.cs.gigapaxos.async.RequestCallbackFuture
 
isDone() - Method in interface edu.umass.cs.gigapaxos.interfaces.RequestFuture
 
isDone() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitEpochFinalState
 
isEmpty() - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerTask
 
isEmpty() - Method in class edu.umass.cs.gigapaxos.paxosutil.LogMessagingTask
 
isEmpty() - Method in class edu.umass.cs.gigapaxos.paxosutil.MessagingTask
 
isEmpty() - Method in class edu.umass.cs.nio.GenericMessagingTask
 
isEmpty(GenericMessagingTask<?, ?>[]) - Static method in class edu.umass.cs.nio.GenericMessagingTask
 
isEmpty() - Method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
isEmpty() - Method in class edu.umass.cs.utils.DiskMap
 
isEmpty() - Method in class edu.umass.cs.utils.MultiArrayMap
 
isEmpty() - Method in class edu.umass.cs.utils.NullIfEmptyMap
 
isEmptyMessaging() - Method in class edu.umass.cs.gigapaxos.paxosutil.MessagingTask
 
isFailed() - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorRequest
 
isFailed() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
isFailed() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ServerReconfigurationPacket
 
isFailed() - Method in class edu.umass.cs.txn.txpackets.TXPacket
 
isForwardable() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
isForwarded() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
isHandshakeComplete(SocketChannel) - Method in class edu.umass.cs.nio.IOSSSLDataProcessingWorker
 
isHandshakeComplete(SocketChannel) - Method in class edu.umass.cs.nio.SSLDataProcessingWorker
 
isIdempotent() - Method in interface edu.umass.cs.txn.interfaces.TxOp
 
isInitEpoch() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
isInserted(String, int[], int, Ballot, String) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
isInserted(String, String, int[], int, Ballot, String) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
isJournalingEnabled() - Static method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
isLargeCheckpoint - Variable in class edu.umass.cs.gigapaxos.paxospackets.StatePacket
 
isLocked(String) - Method in class edu.umass.cs.txn.AbstractTransactor
 
isLocked(String) - Method in class edu.umass.cs.txn.DistTransactor
 
isLogged(PaxosPacket) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
isLoggingEnabled() - Static method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
isLogMsgNeeded(int, int, int, int) - Method in class edu.umass.cs.gigapaxos.paxosutil.LogIndex
 
isLongIdle() - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
isLongIdle() - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
isLongIdle() - Method in class edu.umass.cs.gigapaxos.paxosutil.ActivePaxosState
Deprecated.
 
isMerge - Variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
Whether the corresponding reconfiguration is a merge (used in RC group reconfiguration when RC nodes are deleted).
isMerge() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
isMetaValue() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
isNCRecord(String) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
isNodeConfigChange() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
 
isNodeConfigChange() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
isNodeUp(NodeIDType) - Method in class edu.umass.cs.gigapaxos.FailureDetection
 
isNodeUp(int) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
isNonLocal() - Method in interface edu.umass.cs.reconfiguration.interfaces.RequestType
 
isNoop() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
isNullCheckpointStateEnabled() - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
isOrderPreserving(Object) - Method in class edu.umass.cs.gigapaxos.paxosutil.PaxosPacketDemultiplexerFast
 
isOrderPreserving(MessageType) - Method in class edu.umass.cs.nio.AbstractPacketDemultiplexer
 
isParseable(byte[]) - Static method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
isPassive() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
isPausable() - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
isPausable() - Method in class edu.umass.cs.gigapaxos.paxosutil.LogIndex
 
isPausable() - Method in interface edu.umass.cs.utils.Pausable
 
isPingPonging(JSONObject) - Static method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
isPingPonging() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
isPreemptable(PrepareReplyPacket) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
isPreemptable(PrepareReplyPacket) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
Start of Phase1b methods
isPrepareAcceptedByMajority(PrepareReplyPacket, int[]) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
isPrepareAcceptedByMajority(PrepareReplyPacket, int[]) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
isPresent(int) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
isRCGroupName(String) - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
isRCGroupName(String) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
Checks if RC group name is name itself by consulting the soft copy of node config.
isRCNodeConfigChange() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
isReady() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
isReconfigurationComplete() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
 
isReconfigurationIntent() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
 
isReconfigurationMerge() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
 
isReconfigurationPacket(JSONObject) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
 
isReconfigurationPrevDropComplete() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
 
isReconfigurationReady() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
isRecovering() - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
isRecovery(JSONObject) - Static method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
isRecovery(PaxosPacket) - Static method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
Only prepare, accept, and decision can be recovery packets.
isRecovery() - Method in class edu.umass.cs.gigapaxos.paxospackets.PreparePacket
 
isRecovery() - Method in class edu.umass.cs.gigapaxos.paxospackets.PValuePacket
 
isRecursiveRedirectEnabled() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
isRedirectedResponse() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
The sender will be different from the forwarder.
isRequest() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
isRequest() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.EchoRequest
 
isRunning(KeyType) - Method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
isSplit() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
isSplitIntent() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
 
isSplitOrMerge() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
isStarted() - Method in class edu.umass.cs.nio.NIOTransport
 
isStatic(Field) - Static method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
isStop() - Method in class edu.umass.cs.reconfiguration.examples.AppRequest
 
isStop() - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfigurableRequest
 
isStop() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.DefaultAppRequest
 
isStop() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
 
isStop() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
 
isStop() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StopEpoch
 
isStopped() - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
isStopped() - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
isStopped()==true means that this paxos instance is dead and completely harmless (even if the underlying object has not been garbage collected by the JVM.
isStopped() - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerTask
 
isStopped() - Method in interface edu.umass.cs.nio.interfaces.InterfaceNIOTransport
 
isStopped() - Method in class edu.umass.cs.nio.JSONMessenger
 
isStopped() - Method in class edu.umass.cs.nio.NIOTransport
 
isStopRequest() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
isTLSEnabled() - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
isTransaction() - Method in interface edu.umass.cs.reconfiguration.interfaces.RequestType
 
isUndigestRequest() - Method in class edu.umass.cs.gigapaxos.paxospackets.AcceptReplyPacket
 
isWrapperType(Class<?>) - Static method in class edu.umass.cs.utils.Util
 
iterator() - Method in class edu.umass.cs.txn.Transaction
 
iterator() - Method in class edu.umass.cs.utils.MultiArrayMap
 

J

JSONArrayToArrayListInteger(JSONArray) - Static method in class edu.umass.cs.utils.Util
 
JSONArrayToList(JSONArray) - Static method in class edu.umass.cs.utils.Util
 
JSONDelayEmulator - Class in edu.umass.cs.nio
 
JSONDelayEmulator() - Constructor for class edu.umass.cs.nio.JSONDelayEmulator
 
JSONMessenger<NodeIDType> - Class in edu.umass.cs.nio
 
JSONMessenger(InterfaceNIOTransport<NodeIDType, JSONObject>) - Constructor for class edu.umass.cs.nio.JSONMessenger
 
JSONMessenger(InterfaceNIOTransport<NodeIDType, JSONObject>, int) - Constructor for class edu.umass.cs.nio.JSONMessenger
 
JSONMessenger.JSONObjectByteableWrapper - Class in edu.umass.cs.nio
 
JSONMessenger.JSONObjectWrapper - Class in edu.umass.cs.nio
 
JSONNIOTransport<NodeIDType> - Interface in edu.umass.cs.nio.interfaces
Deprecated.
JSONNIOTransport<NodeIDType> - Class in edu.umass.cs.nio
 
JSONNIOTransport(NodeIDType, NodeConfig<NodeIDType>) - Constructor for class edu.umass.cs.nio.JSONNIOTransport
Initiates transporter with id and nodeConfig.
JSONNIOTransport(NodeIDType, NodeConfig<NodeIDType>, SSLDataProcessingWorker.SSL_MODES) - Constructor for class edu.umass.cs.nio.JSONNIOTransport
 
JSONNIOTransport(NodeIDType, NodeConfig<NodeIDType>, AbstractPacketDemultiplexer<?>, boolean) - Constructor for class edu.umass.cs.nio.JSONNIOTransport
 
JSONNIOTransport(NodeIDType, NodeConfig<NodeIDType>, AbstractPacketDemultiplexer<?>, SSLDataProcessingWorker.SSL_MODES) - Constructor for class edu.umass.cs.nio.JSONNIOTransport
 
JSONObjectByteableWrapper(Object) - Constructor for class edu.umass.cs.nio.JSONMessenger.JSONObjectByteableWrapper
 
JSONObjectToMap(JSONObject) - Static method in class edu.umass.cs.utils.Util
 
JSONObjectWrapper(Object) - Constructor for class edu.umass.cs.nio.JSONMessenger.JSONObjectWrapper
 
JSONPacket - Class in edu.umass.cs.nio
 
JSONPacket(IntegerPacketType) - Constructor for class edu.umass.cs.nio.JSONPacket
 
JSONPacket(JSONObject) - Constructor for class edu.umass.cs.nio.JSONPacket
 
jsonToStringArray(String) - Static method in class edu.umass.cs.utils.Util
 
jumpSlot(int) - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
justActive() - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
justActive() - Method in class edu.umass.cs.gigapaxos.paxosutil.ActivePaxosState
Deprecated.
 
justReconfigured() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.AbstractDemandProfile
Tells this that the current demand profile was just used to perform reconfiguration.
justReconfigured() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DemandProfile
 
justReconfigured() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ProximateBalance
 
justSyncd() - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
justSyncd() - Method in class edu.umass.cs.gigapaxos.paxosutil.ActivePaxosState
Deprecated.
 

K

Keyable<KeyType> - Interface in edu.umass.cs.utils
 
keyPairAlgorithm - Static variable in class edu.umass.cs.utils.SessionKeys
 
keySet() - Method in class edu.umass.cs.utils.DiskMap
This method only returns the in-memory key set.
keySet() - Method in class edu.umass.cs.utils.MultiArrayMap
 
keySet() - Method in class edu.umass.cs.utils.NullIfEmptyMap
 
kill(AbstractPaxosLogger, String, int) - Static method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
kill(boolean) - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
kill(PaxosInstanceStateMachine, boolean) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 

L

label - Variable in enum edu.umass.cs.reconfiguration.http.HttpReconfigurator.HTTPKeys
 
LargeCheckpointer - Class in edu.umass.cs.gigapaxos.paxosutil
 
LargeCheckpointer(String, String) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.LargeCheckpointer
 
LargeCheckpointer(String) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.LargeCheckpointer
 
LargeCheckpointer.Keys - Enum in edu.umass.cs.gigapaxos.paxosutil
The random number suffixes below are in order to make it unlikely that an application checkpoint is JSON-formatted exactly as a checkpoint handle.
LargeCheckpointer.LargeCheckpointerTest - Class in edu.umass.cs.gigapaxos.paxosutil
 
LargeCheckpointerTest() - Constructor for class edu.umass.cs.gigapaxos.paxosutil.LargeCheckpointer.LargeCheckpointerTest
 
lastCoordinatorLongDead(NodeIDType) - Method in class edu.umass.cs.gigapaxos.FailureDetection
 
lastCoordinatorLongDead(int) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
lastKey() - Method in class edu.umass.cs.utils.NullIfEmptyMap
 
lastReconfiguredProfile - Variable in class edu.umass.cs.reconfiguration.reconfigurationutils.DemandProfile
 
lastRequestTime - Variable in class edu.umass.cs.reconfiguration.reconfigurationutils.DemandProfile
 
latchToBatch(RequestPacket[]) - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
learnSample(InetSocketAddress, double) - Method in class edu.umass.cs.gigapaxos.paxosutil.E2ELatencyAwareRedirector
 
lengthEstimate() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
lessThan(RCRecordRequest<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
 
listToString(ArrayList<PaxosPacket>) - Static method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
load(Class<?>) - Static method in class edu.umass.cs.gigapaxos.PaxosConfig
Loads from a default file or file name specified as a system property.
load() - Static method in class edu.umass.cs.gigapaxos.PaxosConfig
By default, PaxosConfig.PC will be registered.
load() - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
load() - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
load() - Static method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationConfig
 
localSetup(Set<NodeIDType>) - Method in class edu.umass.cs.nio.nioutils.SampleNodeConfig
Maps each element in members to the local IP address.
localSetup(int, int) - Method in class edu.umass.cs.nio.nioutils.SampleNodeConfig
The caller can either specify the number of nodes, nNodes, or specify a set of integer node IDs explicitly.
localSetup(int) - Method in class edu.umass.cs.nio.nioutils.SampleNodeConfig
 
localSetup(int) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurableSampleNodeConfig
 
localSetupARRC(int, int) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurableSampleNodeConfig
 
lock - Variable in class edu.umass.cs.gigapaxos.paxosutil.ConsumerTask
 
lock(String) - Method in class edu.umass.cs.txn.DistTransactor
A blocking call that returns upon successfully locking lockID or throws a TXException.
lock(String[]) - Method in class edu.umass.cs.txn.DistTransactor
Acquires the locks in the order specified by lockIDs.
lock(String) - Method in interface edu.umass.cs.txn.interfaces.TXLocker
A blocking call that returns upon successfully locking lockID or throws a TXException.
lock(String) - Method in class edu.umass.cs.txn.TXLockerMap
A blocking call that returns upon successfully locking lockID or throws a TXException.
lock(String[]) - Method in class edu.umass.cs.txn.TXLockerMap
Acquires the locks in the order specified by lockIDs.
lockNotify() - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerTask
 
LockRequest - Class in edu.umass.cs.txn.txpackets
 
LockRequest(String, Transaction) - Constructor for class edu.umass.cs.txn.txpackets.LockRequest
 
LockRequest(JSONObject) - Constructor for class edu.umass.cs.txn.txpackets.LockRequest
 
lockWait() - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerTask
 
log(PaxosPacket) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
Logs a single PaxosPacket.
log(PaxosPacket) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
Logs the given packet.
log - Static variable in class edu.umass.cs.nio.AbstractPacketDemultiplexer
 
log - Static variable in class edu.umass.cs.reconfiguration.PaxosReplicaCoordinator
 
log - Static variable in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStopEpoch
 
LOG_DIRECTORY - Static variable in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
logAndMessage(AbstractPaxosLogger, LogMessagingTask) - Static method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
Logs a message **before** sending the reply message.
logBatch(LogMessagingTask[]) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
logBatch(LogMessagingTask[]) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
logDecision(AbstractPaxosLogger, PValuePacket) - Static method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
logDirectory - Variable in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
logDirectory - Variable in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
LogIndex - Class in edu.umass.cs.gigapaxos.paxosutil
 
LogIndex(String, int) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.LogIndex
 
LogIndex(JSONArray) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.LogIndex
 
LogIndex.LogIndexEntry - Class in edu.umass.cs.gigapaxos.paxosutil
 
LogIndex.LogIndexTest - Class in edu.umass.cs.gigapaxos.paxosutil
 
LogIndexEntry(int, int, int, int, String, long, int) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.LogIndex.LogIndexEntry
 
LogIndexTest() - Constructor for class edu.umass.cs.gigapaxos.paxosutil.LogIndex.LogIndexTest
 
LogMessagingTask - Class in edu.umass.cs.gigapaxos.paxosutil
 
LogMessagingTask(int, PaxosPacket, PaxosPacket) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.LogMessagingTask
 
LogMessagingTask(int, PaxosPacket[], PaxosPacket) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.LogMessagingTask
 
LogMessagingTask(PaxosPacket) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.LogMessagingTask
 
logMsg - Variable in class edu.umass.cs.gigapaxos.paxosutil.LogMessagingTask
The logMessage that needs to be persistently logged and then transmitted upon successful logging.
longToBytes(long) - Static method in class edu.umass.cs.utils.Util
 
longToEncodedString(long) - Static method in class edu.umass.cs.utils.Util
 
loopback(Object) - Method in class edu.umass.cs.nio.AbstractPacketDemultiplexer
 

M

main(String[]) - Static method in class edu.umass.cs.gigapaxos.examples.noop.NoopPaxosAppClient
A simple example of asynchronously sending a few requests with a callback method that is invoked when the request has been executed or is known to have failed.
main(String[]) - Static method in class edu.umass.cs.gigapaxos.examples.PaxosAppRequest
 
main(String[]) - Static method in class edu.umass.cs.gigapaxos.FailureDetection
 
main(String[]) - Static method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
main(String[]) - Static method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
main(String[]) - Static method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
main(String[]) - Static method in class edu.umass.cs.gigapaxos.PaxosPacketBatcher
 
main(String[]) - Static method in class edu.umass.cs.gigapaxos.paxospackets.AcceptPacket
 
main(String[]) - Static method in class edu.umass.cs.gigapaxos.paxospackets.AcceptReplyPacket
 
main(String[]) - Static method in class edu.umass.cs.gigapaxos.paxospackets.BatchedAcceptReply
 
main(String[]) - Static method in class edu.umass.cs.gigapaxos.paxospackets.BatchedCommit
 
main(String[]) - Static method in class edu.umass.cs.gigapaxos.paxospackets.FindReplicaGroupPacket
 
main(String[]) - Static method in class edu.umass.cs.gigapaxos.paxospackets.PValuePacket
 
main(String[]) - Static method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
main(String[]) - Static method in class edu.umass.cs.gigapaxos.PaxosServer
 
main(String[]) - Static method in class edu.umass.cs.gigapaxos.paxosutil.IntegerMap
 
main(String[]) - Static method in class edu.umass.cs.gigapaxos.paxosutil.LargeCheckpointer
 
main(String[]) - Static method in class edu.umass.cs.gigapaxos.paxosutil.MessagingTask
 
main(String[]) - Static method in class edu.umass.cs.gigapaxos.paxosutil.WaitforUtility
 
main(String[]) - Static method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
main(String[]) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosClient
 
main(String[]) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
main(String[]) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosMain
 
main(String[]) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosNode
 
main(String[]) - Static method in class edu.umass.cs.nio.MessageNIOTransport
 
main(String[]) - Static method in class edu.umass.cs.nio.NIOTransport
 
main(String[]) - Static method in class edu.umass.cs.nio.nioutils.NIOBSTester
 
main(String[]) - Static method in class edu.umass.cs.nio.nioutils.NIOTester
 
main(String[]) - Static method in class edu.umass.cs.nio.nioutils.NIOTesterD
 
main(String[]) - Static method in class edu.umass.cs.nio.nioutils.RTTEstimator
 
main(String[]) - Static method in class edu.umass.cs.nio.nioutils.SSLNIOTester
 
main(String[]) - Static method in class edu.umass.cs.protocoltask.examples.thresholdfetch.MajorityFetchProtocolTask
 
main(String[]) - Static method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
main(String[]) - Static method in class edu.umass.cs.protocoltask.TESTProtocolTaskConfig
 
main(String[]) - Static method in class edu.umass.cs.reconfiguration.deprecated.ReconfigurableClient
Deprecated.
Simple test client for the reconfiguration package.
main(String[]) - Static method in class edu.umass.cs.reconfiguration.deprecated.ReconfigurableClientCreateTester
Simple test client for the reconfiguration package.
main(String[]) - Static method in class edu.umass.cs.reconfiguration.examples.AppRequest
 
main(String[]) - Static method in class edu.umass.cs.reconfiguration.examples.noop.NoopAppRequest
 
main(String[]) - Static method in class edu.umass.cs.reconfiguration.examples.noop.NoopReconfigurableNode
 
main(String[]) - Static method in class edu.umass.cs.reconfiguration.examples.NoopAppClient
This simple client creates a bunch of names and sends a bunch of requests to each of them.
main(String[]) - Static method in class edu.umass.cs.reconfiguration.http.HttpReconfigurator
 
main(String[]) - Static method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
main(String[]) - Static method in class edu.umass.cs.reconfiguration.ReconfigurableNode
args contains a list of app arguments followed by a list of active or reconfigurator node IDs at the end.
main(String[]) - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
main(String[]) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.BatchedCreateServiceNameTest
 
main(String[]) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceNameTest
 
main(String[]) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.DemandReport
 
main(String[]) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.EpochFinalState
 
main(String[]) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RequestActiveReplicas
 
main(String[]) - Static method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.CommitWorker
Sanity checking equals and hashCode for RCRecordRequest.
main(String[]) - Static method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentHashing
 
main(String[]) - Static method in class edu.umass.cs.reconfiguration.reconfigurationutils.DemandProfile
 
main(String[]) - Static method in class edu.umass.cs.reconfiguration.reconfigurationutils.ProximateBalance
 
main(String[]) - Static method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
main(String[]) - Static method in class edu.umass.cs.reconfiguration.testing.ReconfigurableAppCapacityTest
 
main(String[]) - Static method in class edu.umass.cs.reconfiguration.testing.TESTPaxosClient
 
main(String[]) - Static method in class edu.umass.cs.reconfiguration.testing.TESTRCDebug
Deprecated.
 
main(String[]) - Static method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
 
main(String[]) - Static method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationConfig
 
main(String[]) - Static method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationMain
 
main(String[]) - Static method in class edu.umass.cs.utils.ClassFinder
 
main(String[]) - Static method in class edu.umass.cs.utils.Config
Runtime usage of Config through explicit object instance creation.
main(String[]) - Static method in class edu.umass.cs.utils.DiskMapTest
 
main(String[]) - Static method in class edu.umass.cs.utils.GCConcurrentHashMap
 
main(String[]) - Static method in class edu.umass.cs.utils.MultiArrayMap
 
main(String[]) - Static method in class edu.umass.cs.utils.MultiArrayMapTest
 
main(String[]) - Static method in class edu.umass.cs.utils.NullIfEmptyMap
 
main(String[]) - Static method in class edu.umass.cs.utils.SessionKeys
 
main(String[]) - Static method in class edu.umass.cs.utils.Stringer
 
main(String[]) - Static method in class edu.umass.cs.utils.Util
 
main(String[]) - Static method in class edu.umass.cs.utils.Waitfor
 
MajorityFetchProtocolTask - Class in edu.umass.cs.protocoltask.examples.thresholdfetch
 
MajorityFetchProtocolTask(int, Set<Integer>) - Constructor for class edu.umass.cs.protocoltask.examples.thresholdfetch.MajorityFetchProtocolTask
 
makeAndSendRequest(String) - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosClient
 
makeAndSendRequest(String) - Method in class edu.umass.cs.reconfiguration.testing.TESTPaxosClient
 
makeAndSendRequestCallable(String) - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosClient
 
makeAndSendRequestCallable(String) - Method in class edu.umass.cs.reconfiguration.testing.TESTPaxosClient
 
makeCoordinator(PaxosCoordinator, int, int, int[], int, boolean) - Static method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
makeCreateNameRequest(String, String, int) - Method in class edu.umass.cs.reconfiguration.deprecated.ReconfigurableClientCreateTester
Deprecated.
makeCreateNameRequest(Map<String, String>, int) - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
makeCreateNameRequest(Map<String, String>, int, Set<String>) - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
makeCreateNameRequest(Map<String, String>, int) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
 
makeCreateNameRequest(Map<String, String>, int, Set<String>) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
 
makeDecision(int) - Method in class edu.umass.cs.gigapaxos.paxospackets.PValuePacket
 
makeNewRequest() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
makeNoop() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
makeResponse() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
makeResponse(InetSocketAddress) - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.EchoRequest
 
markActive() - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
markDeleteReconfigurationRecord(String, int) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
 
markDeleteReconfigurationRecord(String, int) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
markRecovered(PaxosPacket) - Static method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
match(AcceptPacket) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
match(AcceptPacket) - Method in class edu.umass.cs.gigapaxos.paxosutil.PendingDigests
 
matchesType(Object) - Method in class edu.umass.cs.nio.AbstractJSONPacketDemultiplexer
 
matchesType(Object) - Method in class edu.umass.cs.nio.AbstractPacketDemultiplexer
 
matchesType(Object) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationPacketDemultiplexer
 
MAX_BATCH_SIZE - Static variable in class edu.umass.cs.gigapaxos.paxospackets.BatchedAcceptReply
 
MAX_FINAL_STATE_AGE - Static variable in class edu.umass.cs.gigapaxos.SQLPaxosLogger
The epoch final state checkpoint should have been taken not too long back as it should roughly reflect the time to take the checkpoint itself.
MAX_GROUP_STR_LENGTH - Static variable in class edu.umass.cs.gigapaxos.SQLPaxosLogger
Maximum length of a comma separated set of int members of a paxos group.
MAX_LOG_MESSAGE_SIZE - Static variable in class edu.umass.cs.gigapaxos.SQLPaxosLogger
Maximum size of a log message; depends on RequestBatcher.MAX_BATCH_SIZE
MAX_NODE_ID - Static variable in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
MAX_NODE_ID - Static variable in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationConfig
 
MAX_PAXOS_ID_SIZE - Static variable in class edu.umass.cs.gigapaxos.SQLPaxosLogger
Maximum character length of a paxos group name.
MAX_PAYLOAD_SIZE - Static variable in class edu.umass.cs.nio.NIOTransport
Invoked only by the selector thread.
MAX_PINGS - Static variable in class edu.umass.cs.protocoltask.examples.pingpong.PingPongProtocolTask
Max number of pings in PingPong example.
MAX_QUEUED_SENDS - Static variable in class edu.umass.cs.nio.NIOTransport
Number of sends that can be queued because the connection was established but the remote end crashed before the send was complete.
MAX_SYNC_DECISIONS_GAP - Static variable in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
MAX_TASKS - Static variable in class edu.umass.cs.protocoltask.ProtocolExecutor
 
MAX_THREADS - Static variable in class edu.umass.cs.protocoltask.ProtocolExecutor
 
maxCheckpointedSlot - Variable in class edu.umass.cs.gigapaxos.paxospackets.AcceptReplyPacket
Maximum slot up to which this node has checkpointed state, a value that is used for garbage collection of logs.
maxDecisionSlot - Variable in class edu.umass.cs.gigapaxos.paxospackets.SyncDecisionsPacket
Maximum slot up to which decisions have been received by the sending node.
members - Variable in class edu.umass.cs.gigapaxos.paxosutil.HotRestoreInfo
Paxos group members.
members - Variable in class edu.umass.cs.gigapaxos.paxosutil.SlotBallotState
 
mergees - Variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
The list of deleted nodes that must be merged with this node.
mergeIntent(String, int, String) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
 
mergeIntent(String, int, String) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
mergeState(String, int, String, int, String) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
Merge state, i.e., append instead of replacing state, exactly once.
mergeState(String, int, String, int, String) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
MessageExtractor - Class in edu.umass.cs.nio
 
MessageExtractor(AbstractPacketDemultiplexer<?>) - Constructor for class edu.umass.cs.nio.MessageExtractor
 
MessageExtractor() - Constructor for class edu.umass.cs.nio.MessageExtractor
 
MessageNIOTransport<NodeIDType,MessageType> - Class in edu.umass.cs.nio
 
MessageNIOTransport(NodeIDType, NodeConfig<NodeIDType>) - Constructor for class edu.umass.cs.nio.MessageNIOTransport
Initiates transporter with id and nodeConfig.
MessageNIOTransport(NodeIDType, NodeConfig<NodeIDType>, SSLDataProcessingWorker.SSL_MODES) - Constructor for class edu.umass.cs.nio.MessageNIOTransport
 
MessageNIOTransport(InetSocketAddress, NodeConfig<NodeIDType>, SSLDataProcessingWorker.SSL_MODES) - Constructor for class edu.umass.cs.nio.MessageNIOTransport
 
MessageNIOTransport(NodeIDType, NodeConfig<NodeIDType>, AbstractPacketDemultiplexer<?>, boolean) - Constructor for class edu.umass.cs.nio.MessageNIOTransport
 
MessageNIOTransport(NodeIDType, NodeConfig<NodeIDType>, AbstractPacketDemultiplexer<?>, boolean, SSLDataProcessingWorker.SSL_MODES) - Constructor for class edu.umass.cs.nio.MessageNIOTransport
 
MessageNIOTransport(InetAddress, int, AbstractPacketDemultiplexer<?>, SSLDataProcessingWorker.SSL_MODES) - Constructor for class edu.umass.cs.nio.MessageNIOTransport
 
MessagingTask - Class in edu.umass.cs.gigapaxos.paxosutil
 
MessagingTask(int, PaxosPacket) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.MessagingTask
Unicast
MessagingTask(int[], PaxosPacket) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.MessagingTask
Multicast
MessagingTask(int, PaxosPacket[]) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.MessagingTask
Unicast multiple packets
MessagingTask(int[], PaxosPacket[]) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.MessagingTask
Multicast multiple packets.
MessagingTask - Class in edu.umass.cs.nio.nioutils
 
MessagingTask(int, Object) - Constructor for class edu.umass.cs.nio.nioutils.MessagingTask
Unicast
MessagingTask(int[], Object) - Constructor for class edu.umass.cs.nio.nioutils.MessagingTask
Multicast
MessagingTask(int, Object[]) - Constructor for class edu.umass.cs.nio.nioutils.MessagingTask
Unicast multiple packets
MessagingTask(int[], Object[]) - Constructor for class edu.umass.cs.nio.nioutils.MessagingTask
Multicast multiple packets.
Messenger<NodeIDType,MessageType> - Interface in edu.umass.cs.nio.interfaces
 
messenger - Variable in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
messenger - Variable in class edu.umass.cs.reconfiguration.ReconfigurableNode
 
MetaRequestPacket - Class in edu.umass.cs.reconfiguration.testing
 
MetaRequestPacket(String, String) - Constructor for class edu.umass.cs.reconfiguration.testing.MetaRequestPacket
 
MetaRequestPacket(long, String, boolean) - Constructor for class edu.umass.cs.reconfiguration.testing.MetaRequestPacket
 
MetaRequestPacket(byte[]) - Constructor for class edu.umass.cs.reconfiguration.testing.MetaRequestPacket
 
MetaRequestPacket(JSONObject) - Constructor for class edu.umass.cs.reconfiguration.testing.MetaRequestPacket
 
MetaRequestPacket(RequestPacket) - Constructor for class edu.umass.cs.reconfiguration.testing.MetaRequestPacket
 
MIN_INTER_CONNECT_TIME - Static variable in class edu.umass.cs.nio.NIOTransport
Milliseconds before reconnection attempts.
MIN_RESYNC_DELAY - Static variable in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
MIN_RESYNC_DELAY - Static variable in class edu.umass.cs.gigapaxos.paxosutil.ActivePaxosState
Deprecated.
Minimum delay between successive sync decisions requests.
minReconfigurationInterval - Static variable in class edu.umass.cs.reconfiguration.reconfigurationutils.DemandProfile
The minimum amount of time (ms) that must elapse since the previous reconfiguration before the next reconfiguration can happen.
minRequestsBeforeDemandReport - Static variable in class edu.umass.cs.reconfiguration.reconfigurationutils.DemandProfile
The minimum number of requests after which a demand report will be sent to reconfigurators.
minRequestsBeforeReconfiguration - Static variable in class edu.umass.cs.reconfiguration.reconfigurationutils.DemandProfile
The minimum number of requests between two successive reconfigurations.
missingSlotNumbers - Variable in class edu.umass.cs.gigapaxos.paxospackets.SyncDecisionsPacket
Missing decision slot numbers beyond maxDecisionSlot.
ModifiableActiveConfig<Node> - Interface in edu.umass.cs.reconfiguration.interfaces
 
ModifiableRCConfig<NodeIDType> - Interface in edu.umass.cs.reconfiguration.interfaces
This class exists primarily to introduce methods needed but missing in InterfaceReconfigurableNodeConfig in a backwards compatible manner.
ModifiableReconfigurableNodeConfig<NodeIDType> - Interface in edu.umass.cs.reconfiguration.interfaces
 
modify(LogIndex.LogIndexEntry) - Method in class edu.umass.cs.gigapaxos.paxosutil.LogIndex
 
monitorHandleMessage() - Static method in class edu.umass.cs.nio.nioutils.NIOInstrumenter
monitorHandleMessageEnabled() - Static method in class edu.umass.cs.nio.nioutils.NIOInstrumenter
 
movingAverage(double, double, double) - Static method in class edu.umass.cs.utils.Util
 
movingAverage(double, double) - Static method in class edu.umass.cs.utils.Util
 
movingAverage(long, double) - Static method in class edu.umass.cs.utils.Util
 
movingAverage(long, double, double) - Static method in class edu.umass.cs.utils.Util
 
ms(double) - Static method in class edu.umass.cs.utils.Util
 
msgs - Variable in class edu.umass.cs.gigapaxos.paxosutil.MessagingTask
List of paxos packets to be sent.
msgs - Variable in class edu.umass.cs.nio.GenericMessagingTask
The list of messages.
mu(double) - Static method in class edu.umass.cs.utils.Util
 
MultiArrayMap<K,V extends Keyable<K>> - Class in edu.umass.cs.utils
 
MultiArrayMap(int, int) - Constructor for class edu.umass.cs.utils.MultiArrayMap
 
MultiArrayMap(int) - Constructor for class edu.umass.cs.utils.MultiArrayMap
 
MultiArrayMapTest - Class in edu.umass.cs.utils
 
MultiArrayMapTest() - Constructor for class edu.umass.cs.utils.MultiArrayMapTest
 
myID - Variable in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
myID - Variable in class edu.umass.cs.nio.NIOTransport
Usually an id that corresponds to a socket address as specified in NodeConfig.
myID - Variable in class edu.umass.cs.protocoltask.examples.PingPongServer
 
myID - Variable in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
myID - Variable in class edu.umass.cs.reconfiguration.ReconfigurableNode
 
MyLogger - Class in edu.umass.cs.utils
 
MyLogger(Logger) - Constructor for class edu.umass.cs.utils.MyLogger
 
myReceiver - Variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.EchoRequest
 

N

name - Variable in class edu.umass.cs.reconfiguration.reconfigurationutils.AbstractDemandProfile
 
nameStates - Variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
Map of name,state pairs for batched creates.
NearestServerSelector - Interface in edu.umass.cs.gigapaxos.interfaces
 
needsCoordination() - Method in class edu.umass.cs.gigapaxos.examples.PaxosAppRequest
 
needsCoordination() - Method in class edu.umass.cs.reconfiguration.examples.AppRequest
 
needsCoordination() - Method in interface edu.umass.cs.reconfiguration.interfaces.ReplicableRequest
 
needsCoordination() - Method in interface edu.umass.cs.reconfiguration.interfaces.RequestType
 
needsCoordination() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.DefaultAppRequest
 
needsCoordination() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.DemandReport
 
needsCoordination() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
 
needsCoordination() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
 
needsCoordination() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RequestActiveReplicas
 
needsCoordination() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StopEpoch
 
needsCoordination() - Method in class edu.umass.cs.reconfiguration.testing.MetaRequestPacket
 
needsCoordination() - Method in class edu.umass.cs.txn.txpackets.TXPacket
 
newlyAddedNodes - Variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.ServerReconfigurationPacket
Map used for adding new RC nodes.
newlyAddedNodes - Variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
Socket address map for new RC nodes being added.
nextProposalSlot - Variable in class edu.umass.cs.gigapaxos.paxosutil.HotRestoreInfo
Next proposal slot at coordinator.
NIO_CHARSET_ENCODING - Static variable in class edu.umass.cs.nio.MessageNIOTransport
We send even byte arrays encoded as strings because it is easier to do demultiplexing (in JSONMesageExtractor) working with strings than byte arrays.
NIOBSTester - Class in edu.umass.cs.nio.nioutils
 
NIOBSTester() - Constructor for class edu.umass.cs.nio.nioutils.NIOBSTester
 
NIOHeader - Class in edu.umass.cs.nio.nioutils
 
NIOHeader(InetSocketAddress, InetSocketAddress) - Constructor for class edu.umass.cs.nio.nioutils.NIOHeader
 
NIOInstrumenter - Class in edu.umass.cs.nio.nioutils
 
NIOInstrumenter() - Constructor for class edu.umass.cs.nio.nioutils.NIOInstrumenter
 
nioSend(ByteBuffer) - Method in class edu.umass.cs.nio.AbstractNIOSSL
To wrap encrypt-and-send outgoing data.
NIOTester - Class in edu.umass.cs.nio.nioutils
 
NIOTester() - Constructor for class edu.umass.cs.nio.nioutils.NIOTester
 
NIOTesterD - Class in edu.umass.cs.nio.nioutils
 
NIOTesterD() - Constructor for class edu.umass.cs.nio.nioutils.NIOTesterD
 
NIOTransport<NodeIDType> - Class in edu.umass.cs.nio
 
NIOTransport(NodeIDType, NodeConfig<NodeIDType>, DataProcessingWorker) - Constructor for class edu.umass.cs.nio.NIOTransport
The constructor to use for ID-based communication.
NIOTransport(NodeIDType, NodeConfig<NodeIDType>, DataProcessingWorker, boolean, SSLDataProcessingWorker.SSL_MODES) - Constructor for class edu.umass.cs.nio.NIOTransport
 
NIOTransport(InetSocketAddress, NodeConfig<NodeIDType>, DataProcessingWorker, boolean, SSLDataProcessingWorker.SSL_MODES) - Constructor for class edu.umass.cs.nio.NIOTransport
 
NIOTransport(NodeIDType, NodeConfig<NodeIDType>, DataProcessingWorker, SSLDataProcessingWorker.SSL_MODES) - Constructor for class edu.umass.cs.nio.NIOTransport
 
NIOTransport(int, DataProcessingWorker) - Constructor for class edu.umass.cs.nio.NIOTransport
 
NIOTransport(InetAddress, int, DataProcessingWorker, SSLDataProcessingWorker.SSL_MODES) - Constructor for class edu.umass.cs.nio.NIOTransport
 
NIOTransport.AlternatingByteBuffer - Class in edu.umass.cs.nio
 
nmu(double) - Static method in class edu.umass.cs.utils.Util
 
NO_OP - Static variable in interface edu.umass.cs.gigapaxos.interfaces.Request
A string representing a special no-op request.
NO_OP - Static variable in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
noCurEpochGroup() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
NodeConfig<NodeIDType> - Interface in edu.umass.cs.nio.interfaces
 
nodeConfig - Variable in class edu.umass.cs.nio.NIOTransport
 
nodeConfig - Variable in class edu.umass.cs.reconfiguration.ReconfigurableNode
 
nodeExists(NodeIDType) - Method in interface edu.umass.cs.nio.interfaces.NodeConfig
 
nodeExists(NodeIDType) - Method in class edu.umass.cs.nio.nioutils.SampleNodeConfig
 
nodeExists(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentNodeConfig
 
nodeExists(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DefaultNodeConfig
 
nodeExists(Integer) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurableSampleNodeConfig
 
nodeExists(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.SimpleReconfiguratorNodeConfig
 
nodeID - Variable in class edu.umass.cs.gigapaxos.paxospackets.FindReplicaGroupPacket
Node ID sending the request.
nodeID - Variable in class edu.umass.cs.gigapaxos.paxospackets.SyncDecisionsPacket
Node sending the sync decisions request.
nodeSlots - Variable in class edu.umass.cs.gigapaxos.paxosutil.HotRestoreInfo
An array at the coordinator indicating which nodes have executed or checkpointed up which slot numbers in order to do garbage collection.
NONEXISTENT_TABLE - Static variable in class edu.umass.cs.gigapaxos.paxosutil.SQL
 
NoopApp - Class in edu.umass.cs.reconfiguration.examples.noop
 
NoopApp() - Constructor for class edu.umass.cs.reconfiguration.examples.noop.NoopApp
Default constructor used to create app replica via reflection.
NoopApp(String) - Constructor for class edu.umass.cs.reconfiguration.examples.noop.NoopApp
 
NoopApp - Class in edu.umass.cs.reconfiguration.examples.noopsimple
 
NoopApp(String[]) - Constructor for class edu.umass.cs.reconfiguration.examples.noopsimple.NoopApp
Constructor used to create app replica via reflection.
NoopAppClient - Class in edu.umass.cs.reconfiguration.examples
 
NoopAppClient() - Constructor for class edu.umass.cs.reconfiguration.examples.NoopAppClient
 
NoopAppCoordinator - Class in edu.umass.cs.reconfiguration.examples.noop
 
NoopAppCoordinator.CoordType - Enum in edu.umass.cs.reconfiguration.examples.noop
Intended to support two types of coordination policies: lazy and paxos.
NoopAppRequest - Class in edu.umass.cs.reconfiguration.examples.noop
 
NoopAppRequest(String, int, int, String, IntegerPacketType, boolean) - Constructor for class edu.umass.cs.reconfiguration.examples.noop.NoopAppRequest
Can define IntegerPacketType types here other than those defined in AppRequest.
NoopAppRequest(String, int, String, IntegerPacketType, boolean) - Constructor for class edu.umass.cs.reconfiguration.examples.noop.NoopAppRequest
 
NoopAppRequest(JSONObject) - Constructor for class edu.umass.cs.reconfiguration.examples.noop.NoopAppRequest
 
NoopAppTesting - Class in edu.umass.cs.reconfiguration.testing
 
NoopAppTesting(String[]) - Constructor for class edu.umass.cs.reconfiguration.testing.NoopAppTesting
Constructor used to create app replica via reflection.
NoopAppTX - Class in edu.umass.cs.txn.testing
 
NoopAppTX(String[]) - Constructor for class edu.umass.cs.txn.testing.NoopAppTX
Constructor used to create app replica via reflection.
NoopPaxosApp - Class in edu.umass.cs.gigapaxos.examples.noop
 
NoopPaxosApp() - Constructor for class edu.umass.cs.gigapaxos.examples.noop.NoopPaxosApp
 
NoopPaxosAppClient - Class in edu.umass.cs.gigapaxos.examples.noop
 
NoopPaxosAppClient() - Constructor for class edu.umass.cs.gigapaxos.examples.noop.NoopPaxosAppClient
 
NoopReconfigurableNode - Class in edu.umass.cs.reconfiguration.examples.noop
 
NoopReconfigurableNode(String, ReconfigurableNodeConfig<String>, boolean) - Constructor for class edu.umass.cs.reconfiguration.examples.noop.NoopReconfigurableNode
 
NoopReconfigurableNode(String, ReconfigurableNodeConfig<String>) - Constructor for class edu.umass.cs.reconfiguration.examples.noop.NoopReconfigurableNode
 
noOutstanding(TESTPaxosClient[]) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosClient
 
noOutstanding(TESTPaxosClient[]) - Static method in class edu.umass.cs.reconfiguration.testing.TESTPaxosClient
 
noPrevEpochGroup() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
notifyOutstanding(String) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
notifyReceived(ByteBuffer) - Method in class edu.umass.cs.nio.AbstractNIOSSL
To unwrap (decrypt) data received from the network.
notifyStop(String, int) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.CallbackMap
 
notifyUponCreation() - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
notifyUponKill() - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
NULL_INT_NODE - Static variable in class edu.umass.cs.gigapaxos.paxosutil.IntegerMap
-1 can not be used as a node ID.
NULL_SOCKADDR - Static variable in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
We use this address instead of a null client socket address or listen address so that a null address doesn't get overwritten by a bad legitimate address when a request is forwarded across servers.
NULL_STR_NODE - Static variable in class edu.umass.cs.gigapaxos.paxosutil.IntegerMap
 
NullIfEmptyMap<KeyType,ValueType> - Class in edu.umass.cs.utils
 
NullIfEmptyMap() - Constructor for class edu.umass.cs.utils.NullIfEmptyMap
 
numRequests - Variable in class edu.umass.cs.reconfiguration.reconfigurationutils.DemandProfile
 
numTotalRequests - Variable in class edu.umass.cs.reconfiguration.reconfigurationutils.DemandProfile
 

O

offsetPort(InetSocketAddress, int) - Static method in class edu.umass.cs.utils.Util
 
offsetSocketAddresses(Set<InetSocketAddress>, int) - Static method in class edu.umass.cs.gigapaxos.PaxosConfig
 
onClosed() - Method in class edu.umass.cs.nio.AbstractNIOSSL
 
oneIn(int) - Static method in class edu.umass.cs.utils.Util
 
onHandshakeFailure(Exception) - Method in class edu.umass.cs.nio.AbstractNIOSSL
 
onHandshakeSuccess() - Method in class edu.umass.cs.nio.AbstractNIOSSL
 
onInboundData(ByteBuffer) - Method in class edu.umass.cs.nio.AbstractNIOSSL
 
onOutboundData(ByteBuffer) - Method in class edu.umass.cs.nio.AbstractNIOSSL
 
otherGroupMembers() - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
outOfRange(int) - Static method in class edu.umass.cs.nio.NIOTransport
 
outstandingAppRequest(int, ClientRequest) - Static method in class edu.umass.cs.reconfiguration.reconfigurationutils.AppInstrumenter
 
outstandingContains(String) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
OverloadException - Exception in edu.umass.cs.gigapaxos.paxosutil
 
OverloadException(String) - Constructor for exception edu.umass.cs.gigapaxos.paxosutil.OverloadException
 

P

PACKET_TYPE - Static variable in class edu.umass.cs.nio.JSONPacket
JSON key for the integer packet type.
PACKET_TYPE - Static variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
Reconfiguration packet type JSON key.
PacketDemultiplexer<MessageType> - Interface in edu.umass.cs.nio.interfaces
 
PacketDemultiplexerDefault - Class in edu.umass.cs.nio.nioutils
 
PacketDemultiplexerDefault() - Constructor for class edu.umass.cs.nio.nioutils.PacketDemultiplexerDefault
 
packetType - Variable in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
parseJSON(String, boolean) - Static method in class edu.umass.cs.nio.MessageExtractor
String to JSON conversion
parseJSON(String) - Static method in class edu.umass.cs.nio.MessageExtractor
 
parseJSONSmart(String) - Static method in class edu.umass.cs.nio.MessageExtractor
 
Pausable - Interface in edu.umass.cs.utils
 
pause(String, String) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
pause(Map<String, HotRestoreInfo>) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
pause(PaxosInstanceStateMachine) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
pause(Map<String, PaxosInstanceStateMachine>, boolean) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
pause(Map<String, HotRestoreInfo>) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
pause(String, String) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
PAXOS_MANAGER_UNIT_TEST - Static variable in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
PAXOS_MANAGER_UNIT_TEST - Static variable in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationConfig
 
PaxosAcceptor - Class in edu.umass.cs.gigapaxos
 
PaxosAcceptor.STATES - Enum in edu.umass.cs.gigapaxos
 
PaxosAppRequest - Class in edu.umass.cs.gigapaxos.examples
 
PaxosAppRequest(String, int, long, String, IntegerPacketType, boolean) - Constructor for class edu.umass.cs.gigapaxos.examples.PaxosAppRequest
 
PaxosAppRequest(String, long, String, IntegerPacketType, boolean) - Constructor for class edu.umass.cs.gigapaxos.examples.PaxosAppRequest
 
PaxosAppRequest(String, String, IntegerPacketType, boolean) - Constructor for class edu.umass.cs.gigapaxos.examples.PaxosAppRequest
 
PaxosAppRequest(JSONObject) - Constructor for class edu.umass.cs.gigapaxos.examples.PaxosAppRequest
 
PaxosAppRequest.Keys - Enum in edu.umass.cs.gigapaxos.examples
These app keys by design need not be the same as those in BasicReconfigurationPacket
PaxosAppRequest.PacketType - Enum in edu.umass.cs.gigapaxos.examples
Packet type class for NoopApp requests.
PaxosClientAsync - Class in edu.umass.cs.gigapaxos
 
PaxosClientAsync(Set<InetSocketAddress>) - Constructor for class edu.umass.cs.gigapaxos.PaxosClientAsync
 
PaxosClientAsync() - Constructor for class edu.umass.cs.gigapaxos.PaxosClientAsync
 
PaxosConfig - Class in edu.umass.cs.gigapaxos
 
PaxosConfig() - Constructor for class edu.umass.cs.gigapaxos.PaxosConfig
 
PaxosConfig.PC - Enum in edu.umass.cs.gigapaxos
All gigapaxos config parameters that can be specified via a configuration file.
PaxosCoordinator - Class in edu.umass.cs.gigapaxos
 
PaxosCoordinator() - Constructor for class edu.umass.cs.gigapaxos.PaxosCoordinator
 
PaxosCoordinatorState - Class in edu.umass.cs.gigapaxos
 
paxosID - Variable in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
paxosID - Variable in class edu.umass.cs.gigapaxos.paxosutil.ActivePaxosState
Deprecated.
ID of paxos group.
paxosID - Variable in class edu.umass.cs.gigapaxos.paxosutil.HotRestoreInfo
Paxos group name.
paxosID - Variable in class edu.umass.cs.gigapaxos.paxosutil.LogIndex
 
PaxosInstanceCreationException - Exception in edu.umass.cs.gigapaxos.paxosutil
 
PaxosInstanceCreationException(String) - Constructor for exception edu.umass.cs.gigapaxos.paxosutil.PaxosInstanceCreationException
 
PaxosInstanceDestructionException - Exception in edu.umass.cs.gigapaxos.paxosutil
 
PaxosInstanceDestructionException(String) - Constructor for exception edu.umass.cs.gigapaxos.paxosutil.PaxosInstanceDestructionException
 
PaxosInstanceStateMachine - Class in edu.umass.cs.gigapaxos
 
PaxosManager<NodeIDType> - Class in edu.umass.cs.gigapaxos
 
PaxosManager(NodeIDType, Stringifiable<NodeIDType>, InterfaceNIOTransport<NodeIDType, JSONObject>, Replicable, String, boolean) - Constructor for class edu.umass.cs.gigapaxos.PaxosManager
 
PaxosManager(NodeIDType, Stringifiable<NodeIDType>, InterfaceNIOTransport<NodeIDType, JSONObject>, Replicable) - Constructor for class edu.umass.cs.gigapaxos.PaxosManager
PaxosManager.RequestAndCallback - Class in edu.umass.cs.gigapaxos
 
PaxosMessenger<NodeIDType> - Class in edu.umass.cs.gigapaxos.paxosutil
 
PaxosMessenger(InterfaceNIOTransport<NodeIDType, JSONObject>, IntegerMap<NodeIDType>) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.PaxosMessenger
 
PaxosMessenger(InterfaceNIOTransport<NodeIDType, JSONObject>, IntegerMap<NodeIDType>, int) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.PaxosMessenger
 
PaxosMessenger(PaxosMessenger<NodeIDType>) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.PaxosMessenger
 
PaxosPacket - Class in edu.umass.cs.gigapaxos.paxospackets
 
PaxosPacket(PaxosPacket) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
PaxosPacket(String, int) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
PaxosPacket(JSONObject) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
PaxosPacket(JSONObject) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
PaxosPacket(ByteBuffer) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
PaxosPacket.Keys - Enum in edu.umass.cs.gigapaxos.paxospackets
Keys used in json packets.
PaxosPacket.NodeIDKeys - Enum in edu.umass.cs.gigapaxos.paxospackets
These are keys involving NodeIDType that need to be "fixed" by Messenger just before sending and by PaxosPacketDemultiplexer just after being received.
PaxosPacket.PaxosPacketType - Enum in edu.umass.cs.gigapaxos.paxospackets
The paxos packet type class.
PaxosPacketBatcher - Class in edu.umass.cs.gigapaxos
 
PaxosPacketBatcher(PaxosManager<?>) - Constructor for class edu.umass.cs.gigapaxos.PaxosPacketBatcher
 
PaxosPacketDemultiplexer - Class in edu.umass.cs.gigapaxos.paxosutil
 
PaxosPacketDemultiplexer() - Constructor for class edu.umass.cs.gigapaxos.paxosutil.PaxosPacketDemultiplexer
 
PaxosPacketDemultiplexerFast - Class in edu.umass.cs.gigapaxos.paxosutil
 
PaxosPacketDemultiplexerFast(int) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.PaxosPacketDemultiplexerFast
 
PaxosPacketizer() - Constructor for class edu.umass.cs.gigapaxos.AbstractPaxosLogger.PaxosPacketizer
 
PaxosPacketStringifier() - Constructor for class edu.umass.cs.gigapaxos.AbstractPaxosLogger.PaxosPacketStringifier
 
paxosPacketToString(PaxosPacket) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger.PaxosPacketStringifier
 
PaxosReplicaCoordinator<NodeIDType> - Class in edu.umass.cs.reconfiguration
 
PaxosReplicaCoordinator(Replicable, NodeIDType, Stringifiable<NodeIDType>, Messenger<NodeIDType, ?>) - Constructor for class edu.umass.cs.reconfiguration.PaxosReplicaCoordinator
 
PaxosReplicaCoordinator(Replicable, NodeIDType, Stringifiable<NodeIDType>, Messenger<NodeIDType, ?>, int) - Constructor for class edu.umass.cs.reconfiguration.PaxosReplicaCoordinator
 
PaxosServer - Class in edu.umass.cs.gigapaxos
 
peekAll() - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerBatchTask
 
PendingDigestCallback() - Constructor for class edu.umass.cs.gigapaxos.paxosutil.PendingDigests.PendingDigestCallback
 
PendingDigests - Class in edu.umass.cs.gigapaxos.paxosutil
 
PendingDigests(Map<Long, PaxosManager.RequestAndCallback>, int, PendingDigests.PendingDigestCallback) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.PendingDigests
 
PendingDigests.PendingDigestCallback - Class in edu.umass.cs.gigapaxos.paxosutil
 
ping(InetAddress) - Static method in class edu.umass.cs.nio.nioutils.RTTEstimator
 
PingPongPacket - Class in edu.umass.cs.protocoltask.examples
 
PingPongPacket(int, PingPongPacket.PacketType) - Constructor for class edu.umass.cs.protocoltask.examples.PingPongPacket
 
PingPongPacket(JSONObject) - Constructor for class edu.umass.cs.protocoltask.examples.PingPongPacket
 
PingPongPacket.PacketType - Enum in edu.umass.cs.protocoltask.examples
Packet type used by PingPong example.
PingPongProtocolTask - Class in edu.umass.cs.protocoltask.examples.pingpong
 
PingPongProtocolTask(int, Set<Integer>, int) - Constructor for class edu.umass.cs.protocoltask.examples.pingpong.PingPongProtocolTask
 
PingPongServer - Class in edu.umass.cs.protocoltask.examples
 
PingPongServer(int) - Constructor for class edu.umass.cs.protocoltask.examples.PingPongServer
 
pkPair - Static variable in class edu.umass.cs.utils.SessionKeys
Implementations on some devices require us to completely specify the transformation in the form of "ALGORITHM/MODE/PADDING" since the mode and padding defaults are not necessarily same across providers.
pluckDemandProfile(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.AggregateDemandProfiler
 
poke(boolean) - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
poke() - Method in class edu.umass.cs.nio.AbstractNIOSSL
To flush stuck data if any.
poke() - Method in class edu.umass.cs.nio.SSLDataProcessingWorker
 
populateAWSIPToRegionMap() - Static method in class edu.umass.cs.nio.nioutils.RTTEstimator
 
precedePacketDemultiplexer(AbstractPacketDemultiplexer<?>) - Method in interface edu.umass.cs.nio.interfaces.InterfaceMessageExtractor
 
precedePacketDemultiplexer(AbstractPacketDemultiplexer<?>) - Method in interface edu.umass.cs.nio.interfaces.InterfaceNIOTransport
 
precedePacketDemultiplexer(AbstractPacketDemultiplexer<?>) - Method in class edu.umass.cs.nio.IOSSSLDataProcessingWorker
 
precedePacketDemultiplexer(AbstractPacketDemultiplexer<?>) - Method in class edu.umass.cs.nio.JSONMessenger
 
precedePacketDemultiplexer(AbstractPacketDemultiplexer<?>) - Method in class edu.umass.cs.nio.MessageExtractor
Note: Use with care.
precedePacketDemultiplexer(AbstractPacketDemultiplexer<?>) - Method in class edu.umass.cs.nio.MessageNIOTransport
 
precedePacketDemultiplexer(AbstractPacketDemultiplexer<?>) - Method in class edu.umass.cs.nio.SSLDataProcessingWorker
 
preCheckpoint(String) - Method in class edu.umass.cs.reconfiguration.ActiveReplica
 
preCheckpoint(String) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorCallback
 
preempt() - Method in class edu.umass.cs.gigapaxos.paxospackets.PValuePacket
 
preemptedFully() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
preemptedFully() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
preExecuted(Request) - Method in class edu.umass.cs.reconfiguration.ActiveReplica
 
preExecuted(Request) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorCallback
 
preExecuted(Request) - Method in class edu.umass.cs.reconfiguration.Reconfigurator
 
prefix(String, int) - Static method in class edu.umass.cs.utils.Util
 
prefixMatch(InetAddress, InetAddress) - Static method in class edu.umass.cs.gigapaxos.paxosutil.E2ELatencyAwareRedirector
 
prepare(int[]) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
prepare(int[]) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
PreparePacket - Class in edu.umass.cs.gigapaxos.paxospackets
 
PreparePacket(Ballot) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.PreparePacket
 
PreparePacket(Ballot, int) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.PreparePacket
 
PreparePacket(int, int, Ballot, int) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.PreparePacket
 
PreparePacket(JSONObject) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.PreparePacket
 
PrepareReplyAssembler - Class in edu.umass.cs.gigapaxos.paxosutil
 
PrepareReplyAssembler() - Constructor for class edu.umass.cs.gigapaxos.paxosutil.PrepareReplyAssembler
 
PrepareReplyAssembler.PrepareReplyAssemblerTest - Class in edu.umass.cs.gigapaxos.paxosutil
Test class for PreprareReplyAssembler
PrepareReplyAssemblerTest() - Constructor for class edu.umass.cs.gigapaxos.paxosutil.PrepareReplyAssembler.PrepareReplyAssemblerTest
 
PrepareReplyPacket - Class in edu.umass.cs.gigapaxos.paxospackets
 
PrepareReplyPacket(int, Ballot, Map<Integer, PValuePacket>, int, int, int) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.PrepareReplyPacket
 
PrepareReplyPacket(int, Ballot, Map<Integer, PValuePacket>, int) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.PrepareReplyPacket
 
PrepareReplyPacket(JSONObject) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.PrepareReplyPacket
 
PrepareReplyPacket(int, Ballot, HashMap<Integer, PValuePacket>, int, int) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.PrepareReplyPacket
 
preRestore(String, String) - Method in class edu.umass.cs.reconfiguration.ActiveReplica
 
preRestore(String, String) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorCallback
 
prevEpoch - Variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
For supporting RC group merge or split operations wherein the previous epoch group may have a different name and epoch number.
prevEpochGroup - Variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
Group members in the epoch just before the one being started.
prevGroupName - Variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
For supporting RC group merge or split operations wherein the previous epoch group may have a different name.
print() - Static method in class edu.umass.cs.nio.nioutils.RTTEstimator
 
printBatched() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
printOutput(TESTPaxosClient[]) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosClient
 
printOutput(TESTPaxosClient[]) - Static method in class edu.umass.cs.reconfiguration.testing.TESTPaxosClient
 
printRCTable() - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
printThisLine() - Static method in class edu.umass.cs.utils.Util
 
printThisLine(Boolean) - Static method in class edu.umass.cs.utils.Util
 
PROBE_RATIO - Static variable in class edu.umass.cs.gigapaxos.paxosutil.E2ELatencyAwareRedirector
The fraction of requests that are sent to a random replica as probes in order to maintain an up-to-date map of latencies to different replicas.
process(MessagingTask[]) - Method in class edu.umass.cs.gigapaxos.PaxosPacketBatcher
 
process(TaskType) - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerBatchTask
 
process(TaskType[]) - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerBatchTask
 
process(TaskType) - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerTask
 
process(RequestPacket) - Method in class edu.umass.cs.gigapaxos.RequestBatcher
 
processData(SocketChannel, ByteBuffer) - Method in interface edu.umass.cs.nio.interfaces.DataProcessingWorker
 
processData(SocketChannel, ByteBuffer) - Method in class edu.umass.cs.nio.IOSSSLDataProcessingWorker
 
processData(SocketChannel, ByteBuffer) - Method in class edu.umass.cs.nio.MessageExtractor
Incoming data has to be associated with a socket channel, not a nodeID, because the sending node's id is not known until the message is parsed.
processData(SocketChannel, ByteBuffer) - Method in class edu.umass.cs.nio.nioutils.DataProcessingWorkerDefault
 
processData(SocketChannel, ByteBuffer) - Method in class edu.umass.cs.nio.SSLDataProcessingWorker
 
processHeader(byte[], NIOHeader) - Method in class edu.umass.cs.gigapaxos.paxosutil.PaxosPacketDemultiplexerFast
 
processHeader(byte[], NIOHeader) - Method in class edu.umass.cs.nio.AbstractJSONPacketDemultiplexer
 
processHeader(byte[], NIOHeader, boolean) - Method in class edu.umass.cs.nio.AbstractJSONPacketDemultiplexer
 
processHeader(byte[], int, NIOHeader, boolean) - Method in class edu.umass.cs.nio.AbstractJSONPacketDemultiplexer
 
processHeader(byte[], NIOHeader) - Method in class edu.umass.cs.nio.AbstractPacketDemultiplexer
 
processHeader(byte[], NIOHeader) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationPacketDemultiplexer
 
processHeaderStatic(byte[], int, NIOHeader, boolean) - Static method in class edu.umass.cs.nio.AbstractJSONPacketDemultiplexer
 
processHeaderUtil(byte[], NIOHeader) - Static method in class edu.umass.cs.gigapaxos.paxosutil.PaxosPacketDemultiplexerFast
 
processIncoming(PrepareReplyPacket) - Static method in class edu.umass.cs.gigapaxos.paxosutil.PrepareReplyAssembler
 
processLocalMessage(InetSocketAddress, byte[]) - Method in interface edu.umass.cs.nio.interfaces.InterfaceMessageExtractor
 
processLocalMessage(InetSocketAddress, byte[]) - Method in class edu.umass.cs.nio.IOSSSLDataProcessingWorker
 
processLocalMessage(InetSocketAddress, byte[]) - Method in class edu.umass.cs.nio.MessageExtractor
 
processLocalMessage(InetSocketAddress, byte[]) - Method in class edu.umass.cs.nio.SSLDataProcessingWorker
 
processResponse(Request) - Method in class edu.umass.cs.gigapaxos.async.RequestCallbackFuture
 
processResponse(R) - Method in interface edu.umass.cs.gigapaxos.interfaces.Callback
 
processResponse(Request) - Method in interface edu.umass.cs.gigapaxos.interfaces.RequestCallback
 
processResponse(Request) - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync.BlockingRequestCallback
 
ProposalPacket - Class in edu.umass.cs.gigapaxos.paxospackets
 
ProposalPacket(int, RequestPacket) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.ProposalPacket
 
ProposalPacket(ProposalPacket) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.ProposalPacket
 
ProposalPacket(JSONObject) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.ProposalPacket
 
ProposalPacket(JSONObject) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.ProposalPacket
 
ProposalPacket(ByteBuffer) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.ProposalPacket
 
propose(String, String) - Method in class edu.umass.cs.gigapaxos.deprecated.AbstractPaxosManager
Deprecated.
Propose requestPacket in the paxos instance with the given paxosID.
propose(int[], RequestPacket) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
propose(PaxosCoordinator, int[], RequestPacket) - Static method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
propose(int[], RequestPacket) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
propose(String, String, ExecutedCallback) - Method in class edu.umass.cs.gigapaxos.PaxosManager
Propose a request to the paxos group with name paxosID.
propose(String, Request, ExecutedCallback) - Method in class edu.umass.cs.gigapaxos.PaxosManager
Avoids unnecessary conversion to string and back if request happens to be RequestPacket.
proposeBatched(RequestPacket) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
proposeStop(String, String, short) - Method in class edu.umass.cs.gigapaxos.deprecated.AbstractPaxosManager
Deprecated.
 
proposeStop(String, Request, ExecutedCallback) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
proposeStop(String, int, Request, ExecutedCallback) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
proposeStop(String, int, String, ExecutedCallback) - Method in class edu.umass.cs.gigapaxos.PaxosManager
Proposes a request to stop a specific version of paxosID.
proposeStop(String, String, ExecutedCallback) - Method in class edu.umass.cs.gigapaxos.PaxosManager
Stop the paxos instance named paxosID on this machine irrespective of the version.
ProtocolEvent<EventType,KeyType> - Interface in edu.umass.cs.protocoltask
 
ProtocolExecutor<NodeIDType,EventType,KeyType> - Class in edu.umass.cs.protocoltask
 
ProtocolExecutor(Messenger<NodeIDType, ?>) - Constructor for class edu.umass.cs.protocoltask.ProtocolExecutor
 
ProtocolPacket<NodeIDType,EventType> - Class in edu.umass.cs.protocoltask.json
 
ProtocolPacket(NodeIDType) - Constructor for class edu.umass.cs.protocoltask.json.ProtocolPacket
 
ProtocolPacket(ProtocolPacket<NodeIDType, EventType>) - Constructor for class edu.umass.cs.protocoltask.json.ProtocolPacket
 
ProtocolPacket(JSONObject, Stringifiable<NodeIDType>) - Constructor for class edu.umass.cs.protocoltask.json.ProtocolPacket
 
ProtocolPacket(JSONObject) - Constructor for class edu.umass.cs.protocoltask.json.ProtocolPacket
 
ProtocolPacket.Keys - Enum in edu.umass.cs.protocoltask.json
 
ProtocolTask<NodeIDType,EventType,KeyType> - Interface in edu.umass.cs.protocoltask
 
protocolTask - Variable in class edu.umass.cs.reconfiguration.Reconfigurator
 
ProtocolTaskCreationException - Exception in edu.umass.cs.protocoltask
 
ProximateBalance - Class in edu.umass.cs.reconfiguration.reconfigurationutils
 
ProximateBalance(String) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.ProximateBalance
Required String constructor.
ProximateBalance(JSONObject) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.ProximateBalance
Required JSONObject constructor.
put(NodeIDType) - Method in class edu.umass.cs.gigapaxos.paxosutil.IntegerMap
Maps NodeIDType to int and stores the mapping
put(Set<NodeIDType>) - Method in class edu.umass.cs.gigapaxos.paxosutil.IntegerMap
 
put(Object, Object) - Method in class edu.umass.cs.utils.Config
The methods Config.put(Object, Object), Config.getProperty(String), and Config.getProperty(String, String) below make this Config case-insensitive.
put(K, V) - Method in class edu.umass.cs.utils.DiskMap
 
put(K, V) - Method in class edu.umass.cs.utils.GCConcurrentHashMap
 
put(K, V) - Method in class edu.umass.cs.utils.MultiArrayMap
 
put(KeyType, ValueType) - Method in class edu.umass.cs.utils.NullIfEmptyMap
 
put(ByteBuffer, ByteBuffer, int) - Static method in class edu.umass.cs.utils.Util
Transfer from src to dst without throwing exception if src.remaining() > dst.remaining() but copying dst.remaining() bytes from src instead.
put(ByteBuffer, ByteBuffer) - Static method in class edu.umass.cs.utils.Util
 
putActiveReplicas(String, int, Set<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
putAll(Map<? extends K, ? extends V>) - Method in class edu.umass.cs.utils.DiskMap
 
putAll(Map<? extends K, ? extends V>) - Method in class edu.umass.cs.utils.GCConcurrentHashMap
 
putAll(Map<? extends K, ? extends V>) - Method in class edu.umass.cs.utils.MultiArrayMap
 
putAndRemoveNextExecutable(PValuePacket) - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
putCheckpointState(String, int, Set<String>, int, Ballot, String, int) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
putCheckpointState(AbstractPaxosLogger.CheckpointTask[], boolean) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
putCheckpointState(AbstractPaxosLogger.CheckpointTask[]) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
putCheckpointState(String, int, Set<String>, int, Ballot, String, int) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
putCheckpointState(AbstractPaxosLogger.CheckpointTask[]) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
putCheckpointState(AbstractPaxosLogger.CheckpointTask[], boolean) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
Batched version of putCheckpointState.
putEmulatedDelay(Object, JSONObject) - Static method in class edu.umass.cs.nio.JSONDelayEmulator
Sender calls this method to put delay value in the json object before json object is sent.
putIfAbsent(K, V) - Method in class edu.umass.cs.utils.DiskMap
 
putIfAbsent(K, V) - Method in class edu.umass.cs.utils.GCConcurrentHashMap
 
putIfAbsent(K, V) - Method in class edu.umass.cs.utils.MultiArrayMap
 
putIfEmpty(AbstractDemandProfile) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.AggregateDemandProfiler
 
putInitialState(String, int, String) - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
putInitialState(String, int, String) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
putInitialState(String, int, String) - Method in class edu.umass.cs.reconfiguration.examples.AbstractReconfigurablePaxosApp
 
putInitialState(String, int, String) - Method in class edu.umass.cs.reconfiguration.examples.noop.NoopApp
 
putInitialState(String, int, String) - Method in interface edu.umass.cs.reconfiguration.interfaces.Reconfigurable
Inserts the specified state as the initial state for name, epoch.
putInitialState(String, int, String) - Method in class edu.umass.cs.reconfiguration.PaxosReplicaCoordinator
 
putInitialState(String, int, String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.TrivialRepliconfigurable
 
putInitialState(String, int, String) - Method in class edu.umass.cs.txn.AbstractTransactor
 
putPacketType(JSONObject, int) - Static method in class edu.umass.cs.nio.JSONPacket
Puts type into json.
putPacketType(JSONObject, IntegerPacketType) - Static method in class edu.umass.cs.nio.JSONPacket
Puts type.getInt() into json.
putPacketType(JSONObject, PingPongPacket.PacketType) - Method in class edu.umass.cs.protocoltask.examples.PingPongPacket
 
putPacketType(JSONObject, EventType) - Method in class edu.umass.cs.protocoltask.json.ProtocolPacket
 
putPacketType(JSONObject, ReconfigurationPacket.PacketType) - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
 
putPaxosID(String, int) - Method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
putPaxosIDVersion(String, int) - Method in class edu.umass.cs.gigapaxos.paxosutil.LogMessagingTask
 
putPaxosIDVersion(String, int) - Method in class edu.umass.cs.gigapaxos.paxosutil.MessagingTask
 
putSecretKey(SecretKey, SessionKeys.SecretKeyCertificate) - Static method in class edu.umass.cs.utils.SessionKeys
 
PValuePacket - Class in edu.umass.cs.gigapaxos.paxospackets
 
PValuePacket(Ballot, ProposalPacket) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.PValuePacket
 
PValuePacket(PValuePacket) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.PValuePacket
 
PValuePacket(JSONObject) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.PValuePacket
 
PValuePacket(JSONObject) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.PValuePacket
 
PValuePacket(ByteBuffer) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.PValuePacket
 

R

RANDOM_DROP_RATE - Static variable in class edu.umass.cs.protocoltask.TESTProtocolTaskConfig
 
ranRecently() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
ranRecently(PaxosCoordinator) - Static method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
ranRecently() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
RateLimiter - Class in edu.umass.cs.gigapaxos.paxosutil
 
RateLimiter(double) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.RateLimiter
 
RCRecordRequest<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
RCRecordRequest(NodeIDType, StartEpoch<NodeIDType>, RCRecordRequest.RequestTypes) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
 
RCRecordRequest(JSONObject, Stringifiable<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
 
RCRecordRequest.RequestTypes - Enum in edu.umass.cs.reconfiguration.reconfigurationpackets
RCRecordRequest sub-types.
rcvdJSONPacket(JSONObject) - Static method in class edu.umass.cs.nio.nioutils.NIOInstrumenter
 
rcvdRequest(Request) - Static method in class edu.umass.cs.reconfiguration.reconfigurationutils.AppInstrumenter
 
rcvdSSLPacket() - Static method in class edu.umass.cs.reconfiguration.reconfigurationutils.AppInstrumenter
 
rcvr - Variable in class edu.umass.cs.nio.nioutils.NIOHeader
 
RCVR_ADDRESS_FIELD - Static variable in class edu.umass.cs.nio.MessageNIOTransport
JSON key corresponding to receiver socket address.
RCVR_IP_FIELD - Static variable in class edu.umass.cs.nio.MessageNIOTransport
Deprecated.
RCVR_PORT_FIELD - Static variable in class edu.umass.cs.nio.MessageNIOTransport
Deprecated.
readFileAsString(String) - Static method in class edu.umass.cs.utils.UtilServer
 
readNextActiveRecord(boolean) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
 
readNextActiveRecord(boolean) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
readNextCheckpoint(boolean) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
Reads the next checkpoint after the cursor has been created by AbstractPaxosLogger.initiateReadCheckpoints(boolean).
readNextCheckpoint(boolean) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
readNextMessage() - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
Reads the next log message after the cursor has been initialized by AbstractPaxosLogger.initiateReadMessages().
readNextMessage() - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
receive(FailureDetectionPacket<NodeIDType>) - Method in class edu.umass.cs.gigapaxos.FailureDetection
 
received(RequestPacket, int, int) - Static method in class edu.umass.cs.gigapaxos.paxosutil.RequestInstrumenter
 
received(AcceptReplyPacket, int, int) - Static method in class edu.umass.cs.gigapaxos.paxosutil.RequestInstrumenter
 
receiver - Variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
Receiver address.
recipients - Variable in class edu.umass.cs.gigapaxos.paxosutil.MessagingTask
List of recipients.
recipients - Variable in class edu.umass.cs.nio.GenericMessagingTask
The list of recipients.
Reconfigurable - Interface in edu.umass.cs.reconfiguration.interfaces
 
ReconfigurableAppCapacityTest - Class in edu.umass.cs.reconfiguration.testing
 
ReconfigurableAppCapacityTest() - Constructor for class edu.umass.cs.reconfiguration.testing.ReconfigurableAppCapacityTest
 
ReconfigurableAppClientAsync<V> - Class in edu.umass.cs.reconfiguration
 
ReconfigurableAppClientAsync(Set<InetSocketAddress>, SSLDataProcessingWorker.SSL_MODES, int, boolean) - Constructor for class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
The constructor specifies the default set of reconfigurators.
ReconfigurableAppClientAsync(Set<InetSocketAddress>) - Constructor for class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
ReconfigurableAppClientAsync(Set<InetSocketAddress>, boolean) - Constructor for class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
ReconfigurableAppClientAsync() - Constructor for class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
ReconfigurableAppClientAsync.BlockingRequestCallback - Class in edu.umass.cs.reconfiguration
[ *
ReconfigurableAppClientAsync.ReconfigurationException - Exception in edu.umass.cs.reconfiguration
 
ReconfigurableAppInfo - Interface in edu.umass.cs.reconfiguration.interfaces
 
ReconfigurableClient - Class in edu.umass.cs.reconfiguration.deprecated
Deprecated.
ReconfigurableClientCreateTester - Class in edu.umass.cs.reconfiguration.deprecated
 
ReconfigurableNode<NodeIDType> - Class in edu.umass.cs.reconfiguration
 
ReconfigurableNode(NodeIDType, ReconfigurableNodeConfig<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.ReconfigurableNode
 
ReconfigurableNode(NodeIDType, ReconfigurableNodeConfig<NodeIDType>, String[], boolean) - Constructor for class edu.umass.cs.reconfiguration.ReconfigurableNode
 
ReconfigurableNode.DefaultReconfigurableNode - Class in edu.umass.cs.reconfiguration
 
ReconfigurableNodeConfig<NodeIDType> - Interface in edu.umass.cs.reconfiguration.interfaces
 
ReconfigurableRequest - Interface in edu.umass.cs.reconfiguration.interfaces
 
ReconfigurableSampleNodeConfig - Class in edu.umass.cs.reconfiguration.reconfigurationutils
 
ReconfigurableSampleNodeConfig() - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurableSampleNodeConfig
 
ReconfigurableSampleNodeConfig(int) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurableSampleNodeConfig
 
ReconfigurationConfig - Class in edu.umass.cs.reconfiguration
 
ReconfigurationConfig() - Constructor for class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
ReconfigurationConfig.CommandArgs - Enum in edu.umass.cs.reconfiguration
Command-line options
ReconfigurationConfig.RC - Enum in edu.umass.cs.reconfiguration
Reconfiguration config parameters.
ReconfigurationConfig.ReconfigureUponActivesChange - Enum in edu.umass.cs.reconfiguration
This enum specifies the reconfiguration behavior when active replicas are added or removed.
ReconfigurationException() - Constructor for exception edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync.ReconfigurationException
 
ReconfigurationException(ClientReconfigurationPacket.ResponseCodes, String, String) - Constructor for exception edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync.ReconfigurationException
 
ReconfigurationException(ClientReconfigurationPacket.ResponseCodes, String) - Constructor for exception edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync.ReconfigurationException
 
ReconfigurationException(String, Throwable) - Constructor for exception edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync.ReconfigurationException
 
ReconfigurationException(String) - Constructor for exception edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync.ReconfigurationException
 
ReconfigurationException(Throwable) - Constructor for exception edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync.ReconfigurationException
 
ReconfigurationException(ClientReconfigurationPacket.ResponseCodes, String, Throwable) - Constructor for exception edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync.ReconfigurationException
 
ReconfigurationPacket<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
ReconfigurationPacket(NodeIDType) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
End of ReconfigurationpacketType class map
ReconfigurationPacket(JSONObject, Stringifiable<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
 
ReconfigurationPacket.PacketType - Enum in edu.umass.cs.reconfiguration.reconfigurationpackets
End of ReconfigurationpacketType
ReconfigurationPacketDemultiplexer - Class in edu.umass.cs.reconfiguration.reconfigurationutils
 
ReconfigurationPacketDemultiplexer(Stringifiable<?>, AppRequestParser) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationPacketDemultiplexer
 
ReconfigurationPacketDemultiplexer(Stringifiable<?>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationPacketDemultiplexer
 
ReconfigurationPolicyTest - Class in edu.umass.cs.reconfiguration.reconfigurationutils
 
ReconfigurationPolicyTest() - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationPolicyTest
 
ReconfigurationRecord<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationutils
 
ReconfigurationRecord(String, int, Set<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
ReconfigurationRecord(String, int, Set<NodeIDType>, ReconfigurationConfig.ReconfigureUponActivesChange) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
ReconfigurationRecord(String, int, Set<NodeIDType>, Set<NodeIDType>, ReconfigurationConfig.ReconfigureUponActivesChange) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
ReconfigurationRecord(JSONObject, Stringifiable<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
ReconfigurationRecord.Keys - Enum in edu.umass.cs.reconfiguration.reconfigurationutils
 
ReconfigurationRecord.RCStates - Enum in edu.umass.cs.reconfiguration.reconfigurationutils
RC record states.
Reconfigurator<NodeIDType> - Class in edu.umass.cs.reconfiguration
 
Reconfigurator(ReconfigurableNodeConfig<NodeIDType>, SSLMessenger<NodeIDType, JSONObject>, boolean) - Constructor for class edu.umass.cs.reconfiguration.Reconfigurator
 
Reconfigurator.ProfilerKeys - Enum in edu.umass.cs.reconfiguration
For profiling statistics in DelayProfiler.
ReconfiguratorCallback - Interface in edu.umass.cs.reconfiguration.interfaces
 
ReconfiguratorDB<NodeIDType> - Interface in edu.umass.cs.reconfiguration.interfaces
 
ReconfiguratorFunctions - Interface in edu.umass.cs.reconfiguration.interfaces
 
ReconfiguratorProtocolTask<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationprotocoltasks
 
ReconfiguratorProtocolTask(NodeIDType, Reconfigurator<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.ReconfiguratorProtocolTask
 
ReconfiguratorRequest - Interface in edu.umass.cs.reconfiguration.interfaces
 
reconfigure(Set<String>, ReconfigurableAppInfo) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.AbstractDemandProfile
The main reconfiguration policy invoked at reconfigurators (not active replicas).
reconfigure(String, Set<String>) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.AggregateDemandProfiler
 
reconfigure(Set<String>, ReconfigurableAppInfo) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DemandProfile
 
reconfigure(Set<String>, ReconfigurableAppInfo) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ProximateBalance
 
ReconfigureActiveNodeConfig<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
ReconfigureActiveNodeConfig(NodeIDType, NodeIDType, InetSocketAddress) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigureActiveNodeConfig
 
ReconfigureActiveNodeConfig(NodeIDType, Map<NodeIDType, InetSocketAddress>, Set<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigureActiveNodeConfig
 
ReconfigureActiveNodeConfig(JSONObject, Stringifiable<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigureActiveNodeConfig
 
ReconfigureRCNodeConfig<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
ReconfigureRCNodeConfig(NodeIDType, NodeIDType, InetSocketAddress) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigureRCNodeConfig
 
ReconfigureRCNodeConfig(NodeIDType, Map<NodeIDType, InetSocketAddress>, Set<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigureRCNodeConfig
 
ReconfigureRCNodeConfig(JSONObject, Stringifiable<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigureRCNodeConfig
 
reconstructDecision(int) - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
record() - Method in class edu.umass.cs.gigapaxos.paxosutil.RateLimiter
To be invoked each time the action is done.
record(InetAddress) - Static method in class edu.umass.cs.nio.nioutils.RTTEstimator
Relies on Java implementation of (typically) ICMP echo.
record(InetAddress, long) - Static method in class edu.umass.cs.nio.nioutils.RTTEstimator
 
recover(int) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
recover(int) - Static method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationConfig
 
recovering - Variable in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
RecoveryInfo - Class in edu.umass.cs.gigapaxos.paxosutil
 
RecoveryInfo(String, int, String[]) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.RecoveryInfo
 
RecoveryInfo(String, int, String[], String) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.RecoveryInfo
 
recursiveFind(String, String) - Static method in class edu.umass.cs.utils.Util
 
recursiveRemove(File) - Static method in class edu.umass.cs.utils.Util
 
recursiveRemove(String, String...) - Static method in class edu.umass.cs.utils.Util
 
recvdAppPacket() - Static method in class edu.umass.cs.reconfiguration.reconfigurationutils.AppInstrumenter
Packets received by processHeader, the first step after NIO.
recvdResponse(ClientRequest) - Static method in class edu.umass.cs.reconfiguration.reconfigurationutils.AppInstrumenter
 
refresh() - Method in class edu.umass.cs.gigapaxos.paxosutil.RateLimiter
To be invoked to start a new send spell.
refresh(NodeIDType[], int) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentHashing
 
refresh(Set<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentHashing
 
refresh(Set<NodeIDType>, int) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentHashing
 
refreshKey() - Method in class edu.umass.cs.protocoltask.examples.pingpong.PingPongProtocolTask
 
refreshKey() - Method in class edu.umass.cs.protocoltask.examples.PingPongServer
 
refreshKey() - Method in class edu.umass.cs.protocoltask.examples.thresholdfetch.MajorityFetchProtocolTask
 
refreshKey() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.ActiveReplicaProtocolTask
 
refreshKey() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.ReconfiguratorProtocolTask
 
refreshKey() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckDropEpoch
 
refreshKey() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStartEpoch
 
refreshKey() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStopEpoch
Note: Trying to start this task when one is already running will cause the executor to get stuck.
refreshKey() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitEpochFinalState
 
refreshKey() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitPrimaryExecution
 
register(TESTPaxosClient[]) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosShutdownThread
 
register(TESTPaxosApp) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosShutdownThread
 
register(IntegerPacketType) - Method in class edu.umass.cs.nio.AbstractPacketDemultiplexer
Registers type with this.
register(IntegerPacketType, PacketDemultiplexer<MessageType>) - Method in class edu.umass.cs.nio.AbstractPacketDemultiplexer
Registers type with pd.
register(Set<IntegerPacketType>, PacketDemultiplexer<MessageType>) - Method in class edu.umass.cs.nio.AbstractPacketDemultiplexer
Registers types with pd;
register(Set<IntegerPacketType>) - Method in class edu.umass.cs.nio.AbstractPacketDemultiplexer
Registers types with this.
register(IntegerPacketType[], PacketDemultiplexer<MessageType>) - Method in class edu.umass.cs.nio.AbstractPacketDemultiplexer
Registers types with this.
register(IntegerPacketType[]) - Method in class edu.umass.cs.nio.AbstractPacketDemultiplexer
Registers types with this.
register(SelectionKey, boolean) - Method in class edu.umass.cs.nio.IOSSSLDataProcessingWorker
 
register(SelectionKey, boolean) - Method in class edu.umass.cs.nio.SSLDataProcessingWorker
 
register(EventType, ProtocolTask<NodeIDType, EventType, KeyType>) - Method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
register(Set<EventType>, ProtocolTask<NodeIDType, EventType, KeyType>) - Method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
register(ProtocolTask<NodeIDType, EventType, KeyType>) - Method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
register(Class<?>, String, String) - Static method in class edu.umass.cs.utils.Config
Will first look for the file name specified in systemProperty and then try the configFile.
register(String[]) - Static method in class edu.umass.cs.utils.Config
For registering command-line args.
register(String, ConcurrentMap<String, Double>) - Static method in class edu.umass.cs.utils.DelayProfiler
 
registerCoordination(IntegerPacketType...) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
registerOrderPreserving(IntegerPacketType) - Method in class edu.umass.cs.nio.AbstractPacketDemultiplexer
 
reInitCommander(int) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
reInitCommander(int) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
reissueAcceptIfWaitingTooLong(PaxosCoordinator, int) - Static method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
release(RequestPacket, boolean) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
release(RequestPacket) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
release(RequestPacket, boolean) - Method in class edu.umass.cs.gigapaxos.paxosutil.PendingDigests
 
release(RequestPacket, boolean, boolean) - Method in class edu.umass.cs.gigapaxos.paxosutil.PendingDigests
 
releaseTxid(long) - Static method in class edu.umass.cs.txn.Transaction
 
reliableSend(int) - Method in class edu.umass.cs.protocoltask.examples.ExampleNode
 
remakeCoordinator(PaxosCoordinator, int[]) - Static method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
remove(String, int) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
Removes all state for the paxos group paxosID
remove(TaskType[]) - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerBatchTask
 
remove(RequestPacket) - Method in class edu.umass.cs.gigapaxos.paxosutil.PendingDigests
 
remove(long) - Static method in class edu.umass.cs.gigapaxos.paxosutil.RequestInstrumenter
 
remove(String, int) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
Removes all state for paxosID except epoch final state.
remove(SelectionKey) - Method in class edu.umass.cs.nio.IOSSSLDataProcessingWorker
 
remove(SelectionKey) - Method in class edu.umass.cs.nio.SSLDataProcessingWorker
 
remove(KeyType) - Method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
remove(Object) - Method in class edu.umass.cs.utils.DiskMap
 
remove(Object, Object) - Method in class edu.umass.cs.utils.DiskMap
 
remove(Object) - Method in class edu.umass.cs.utils.GCConcurrentHashMap
 
remove(Object, Object) - Method in class edu.umass.cs.utils.GCConcurrentHashMap
 
remove(Object) - Method in class edu.umass.cs.utils.MultiArrayMap
 
remove(Object, Object) - Method in class edu.umass.cs.utils.MultiArrayMap
 
remove(KeyType) - Method in class edu.umass.cs.utils.NullIfEmptyMap
 
remove(String) - Method in class edu.umass.cs.utils.StringLocker
Removes key when no one is using it for synchronization.
removeActiveReplica(Node) - Method in interface edu.umass.cs.reconfiguration.interfaces.ModifiableActiveConfig
 
removeActiveReplica(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
removeActiveReplica(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DefaultNodeConfig
 
removeActiveReplica(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.SimpleReconfiguratorNodeConfig
 
removeActivesSlatedForRemoval() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
removeAll() - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
removeAll() - Static method in class edu.umass.cs.gigapaxos.paxosutil.RequestInstrumenter
 
removeAll() - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
removeDead(Set<NodeIDType>) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
removeDead(Set<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.PaxosReplicaCoordinator
 
removeFromSet(Set<?>, Object) - Static method in class edu.umass.cs.utils.Util
 
removeFromSetCopy(Set<?>, Object) - Static method in class edu.umass.cs.utils.Util
 
removePending(String) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
 
removePending(String) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
removePending(String) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
removeReconfigurator(NodeIDType) - Method in interface edu.umass.cs.reconfiguration.interfaces.ModifiableRCConfig
 
removeReconfigurator(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
removeReconfigurator(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DefaultNodeConfig
 
removeReconfigurator(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.SimpleReconfiguratorNodeConfig
 
removeReconfiguratorsSlatedForRemoval() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
Repeat - Annotation Type in edu.umass.cs.utils
Taken from https://gist.github.com/fappel/8bcb2aea4b39ff9cfb6e
repeatRule - Variable in class edu.umass.cs.utils.DefaultTest
To repeat a test a given number of times.
RepeatRule - Class in edu.umass.cs.utils
Taken from https://gist.github.com/fappel/8bcb2aea4b39ff9cfb6e
RepeatRule() - Constructor for class edu.umass.cs.utils.RepeatRule
 
replace(K, V, V) - Method in class edu.umass.cs.utils.DiskMap
 
replace(K, V) - Method in class edu.umass.cs.utils.DiskMap
 
replace(K, V, V) - Method in class edu.umass.cs.utils.MultiArrayMap
 
replace(K, V) - Method in class edu.umass.cs.utils.MultiArrayMap
 
Replicable - Interface in edu.umass.cs.gigapaxos.interfaces
 
ReplicableClientRequest - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
ReplicableClientRequest(byte[], NIOHeader, AppRequestParserBytes) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
 
ReplicableClientRequest(byte[], AppRequestParser) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
 
ReplicableClientRequest(JSONObject, Stringifiable<?>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
 
ReplicableDeprecated - Interface in edu.umass.cs.gigapaxos.deprecated
 
ReplicableRequest - Interface in edu.umass.cs.reconfiguration.interfaces
 
ReplicaCoordinator<NodeIDType> - Interface in edu.umass.cs.reconfiguration.interfaces
 
Repliconfigurable - Interface in edu.umass.cs.reconfiguration.interfaces
 
RepliconfigurableReconfiguratorDB<NodeIDType> - Class in edu.umass.cs.reconfiguration
 
RepliconfigurableReconfiguratorDB(AbstractReconfiguratorDB<NodeIDType>, NodeIDType, ConsistentReconfigurableNodeConfig<NodeIDType>, Messenger<NodeIDType, JSONObject>, boolean) - Constructor for class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
Request - Interface in edu.umass.cs.gigapaxos.interfaces
 
RequestActiveReplicas - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
RequestActiveReplicas(String) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.RequestActiveReplicas
 
RequestActiveReplicas(InetSocketAddress, String, int) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.RequestActiveReplicas
 
RequestActiveReplicas(JSONObject, Stringifiable<?>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.RequestActiveReplicas
 
RequestActiveReplicas(JSONObject) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.RequestActiveReplicas
 
requestActiveReplicas(GigaPaxosClient<Request>, Transaction) - Static method in class edu.umass.cs.txn.TXUtils
This method fetches the union set of the set of active replica addresses for all participant groups in a transaction by issuing an async task for the lock list of the transaction.
RequestActiveReplicas.Keys - Enum in edu.umass.cs.reconfiguration.reconfigurationpackets
 
RequestBatcher - Class in edu.umass.cs.gigapaxos
 
RequestBatcher(PaxosManager<?>) - Constructor for class edu.umass.cs.gigapaxos.RequestBatcher
 
RequestCallback - Interface in edu.umass.cs.gigapaxos.interfaces
 
RequestCallbackFuture<V> - Class in edu.umass.cs.gigapaxos.async
 
RequestCallbackFuture(Request, Callback<Request, V>) - Constructor for class edu.umass.cs.gigapaxos.async.RequestCallbackFuture
 
RequestEpochFinalState<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
RequestEpochFinalState(NodeIDType, String, int) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.RequestEpochFinalState
 
RequestEpochFinalState(JSONObject, Stringifiable<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.RequestEpochFinalState
 
RequestFuture<V> - Interface in edu.umass.cs.gigapaxos.interfaces
 
requestID - Variable in class edu.umass.cs.gigapaxos.paxospackets.AcceptReplyPacket
 
requestID - Variable in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
A unique requestID for each request.
requestID - Variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.EchoRequest
 
RequestIdentifier - Interface in edu.umass.cs.gigapaxos.interfaces
 
RequestInstrumenter - Class in edu.umass.cs.gigapaxos.paxosutil
 
RequestInstrumenter() - Constructor for class edu.umass.cs.gigapaxos.paxosutil.RequestInstrumenter
 
requestPacket - Variable in class edu.umass.cs.gigapaxos.PaxosManager.RequestAndCallback
 
RequestPacket - Class in edu.umass.cs.gigapaxos.paxospackets
 
RequestPacket(String, boolean) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
RequestPacket(long, String, boolean) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
RequestPacket(long, String, boolean, InetSocketAddress) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
RequestPacket(String, boolean, InetSocketAddress) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
RequestPacket(RequestPacket) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
RequestPacket(long, String, boolean, RequestPacket) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
RequestPacket(JSONObject) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
RequestPacket(JSONObject) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
RequestPacket(byte[]) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
RequestPacket(ByteBuffer) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
RequestPacket.Keys - Enum in edu.umass.cs.gigapaxos.paxospackets
These JSON keys are rather specific to RequestPacket or for debugging, so they are here as opposed to PaxosPacket.
RequestPacket.ResponseCodes - Enum in edu.umass.cs.gigapaxos.paxospackets
 
RequestPacketTest - Class in edu.umass.cs.gigapaxos.paxospackets
Created by kanantharamu on 2/20/17.
RequestPacketTest() - Constructor for class edu.umass.cs.gigapaxos.paxospackets.RequestPacketTest
 
RequestParseException - Exception in edu.umass.cs.reconfiguration.reconfigurationutils
 
RequestParseException(Exception) - Constructor for exception edu.umass.cs.reconfiguration.reconfigurationutils.RequestParseException
Meant to be thrown when AppRequestParser.getRequest(String) can not parse the supplied string into an InterfaceRequest object.
RequestType - Interface in edu.umass.cs.reconfiguration.interfaces
 
requestValue - Variable in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
The actual request body.
requestZerothMissingDecision() - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
reset() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.AbstractDemandProfile
Deprecated.
resetAll() - Method in class edu.umass.cs.gigapaxos.deprecated.AbstractPaxosManager
Deprecated.
Deletes all paxos instances and paxos logs.
resetAll() - Method in class edu.umass.cs.gigapaxos.PaxosManager
Deprecated.
resetLatencyComputation(TESTPaxosClient[]) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosClient
 
resetLatencyComputation(TESTPaxosClient[]) - Static method in class edu.umass.cs.reconfiguration.testing.TESTPaxosClient
 
ResponseCode - Enum in edu.umass.cs.txn.exceptions
 
restart() - Method in class edu.umass.cs.protocoltask.examples.thresholdfetch.MajorityFetchProtocolTask
 
restart() - Method in interface edu.umass.cs.protocoltask.SchedulableProtocolTask
 
restart() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckDropEpoch
 
restart() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStartEpoch
 
restart() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStopEpoch
 
restart() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitEpochFinalState
 
restart() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitPrimaryExecution
 
RESTART_PERIOD - Static variable in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStopEpoch
Retransmission timeout.
restartCount - Variable in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStopEpoch
 
restore(String, String) - Method in class edu.umass.cs.gigapaxos.deprecated.DefaultPaxosInterfaceApp
 
restore(String, String) - Method in interface edu.umass.cs.gigapaxos.deprecated.ReplicableDeprecated
 
restore(String, String) - Method in class edu.umass.cs.gigapaxos.examples.noop.NoopPaxosApp
 
restore(String, String) - Method in interface edu.umass.cs.gigapaxos.interfaces.Replicable
Resets the current application state for name to state.
restore(String, String) - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosApp
 
restore(String, String) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
restore(String, String) - Method in class edu.umass.cs.reconfiguration.examples.noop.NoopApp
 
restore(String, String) - Method in class edu.umass.cs.reconfiguration.examples.noopsimple.NoopApp
 
restore(String, String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.TrivialRepliconfigurable
 
restore(String, String) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
restore(String, String) - Method in class edu.umass.cs.reconfiguration.testing.NoopAppTesting
 
restore(String, String) - Method in class edu.umass.cs.txn.AbstractTransactor
 
restore(String, String) - Method in class edu.umass.cs.txn.testing.NoopAppTX
 
restore(K) - Method in interface edu.umass.cs.utils.Diskable
 
restore(K) - Method in class edu.umass.cs.utils.DiskMap
 
restoreCheckpointHandle(String, String) - Static method in class edu.umass.cs.gigapaxos.paxosutil.LargeCheckpointer
Replicable applications can use this method to fetch the checkpoint represented by the handle to a local file localFilename.
retransmittedRequest(RequestPacket) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
rollForward(AbstractPaxosLogger, String, PaxosMessenger<?>) - Static method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
roundRobinCoordinator(String, int[], int) - Static method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
roundToInt(double) - Static method in class edu.umass.cs.utils.Util
 
RTTEstimator - Class in edu.umass.cs.nio.nioutils
 
RTTEstimator() - Constructor for class edu.umass.cs.nio.nioutils.RTTEstimator
 
RTTEstimator.IPv4Prefix - Class in edu.umass.cs.nio.nioutils
An IPv4 address and a netmask length in the standard CIDR notation.
RTTEstimatorTest - Class in edu.umass.cs.nio.nioutils
RTTEstimator test class.
RTTEstimatorTest() - Constructor for class edu.umass.cs.nio.nioutils.RTTEstimatorTest
 
run() - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerBatchTask
 
run() - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerTask
 
run() - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosShutdownThread
 
run() - Method in class edu.umass.cs.nio.AbstractNIOSSL
 
run() - Method in class edu.umass.cs.nio.AbstractPacketDemultiplexer.Tasker
 
run() - Method in class edu.umass.cs.nio.NIOTransport
 
run() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.CommitWorker
 

S

SampleNodeConfig<NodeIDType> - Class in edu.umass.cs.nio.nioutils
 
SampleNodeConfig(int) - Constructor for class edu.umass.cs.nio.nioutils.SampleNodeConfig
 
SampleNodeConfig(int, int, int) - Constructor for class edu.umass.cs.nio.nioutils.SampleNodeConfig
 
SampleNodeConfig() - Constructor for class edu.umass.cs.nio.nioutils.SampleNodeConfig
 
sanityCheck() - Static method in class edu.umass.cs.gigapaxos.PaxosConfig
 
sanityCheck(NodeConfig) - Static method in class edu.umass.cs.gigapaxos.PaxosConfig
 
SchedulableProtocolTask<NodeIDType,EventType,KeyType> - Interface in edu.umass.cs.protocoltask
 
schedule(SchedulableProtocolTask<NodeIDType, EventType, KeyType>, long) - Method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
schedule(SchedulableProtocolTask<NodeIDType, EventType, KeyType>) - Method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
scheduleSimple(Runnable, long, TimeUnit) - Method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
selectRandom(Collection<?>) - Static method in class edu.umass.cs.utils.Util
 
send(MessagingTask, boolean, boolean) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
send(MessagingTask) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
send(InetSocketAddress, Request, InetSocketAddress) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
send(MessagingTask[]) - Method in class edu.umass.cs.gigapaxos.paxosutil.PaxosMessenger
 
send(MessagingTask) - Method in class edu.umass.cs.gigapaxos.paxosutil.PaxosMessenger
 
send(GenericMessagingTask<NodeIDType, ?>) - Method in interface edu.umass.cs.nio.interfaces.Messenger
 
send(GenericMessagingTask<NodeIDType, ?>) - Method in class edu.umass.cs.nio.JSONMessenger
 
send(GenericMessagingTask<NodeIDType, ?>, boolean) - Method in class edu.umass.cs.nio.JSONMessenger
Send returns void because it is the "ultimate" send.
send(NodeIDType, byte[]) - Method in class edu.umass.cs.nio.NIOTransport
send() methods are called by external application threads.
send(InetSocketAddress, byte[]) - Method in class edu.umass.cs.nio.NIOTransport
 
send(InetSocketAddress, byte[], int) - Method in class edu.umass.cs.nio.NIOTransport
For performance testing.
sendAllLazy(Request) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
Request propagation helper methods
sendClient(InetSocketAddress, Object, InetSocketAddress) - Method in class edu.umass.cs.nio.JSONMessenger
A hack that relies on the fact that NIO treats JSONObject as no different from any other object in that it invokes toString() and then getBytes(.) to serialize and send it over the network.
sendClient(InetSocketAddress, Object) - Method in class edu.umass.cs.nio.JSONMessenger
 
sender - Variable in class edu.umass.cs.gigapaxos.paxospackets.AcceptPacket
Sender node ID.
senderNodeID - Variable in class edu.umass.cs.gigapaxos.paxospackets.FailureDetectionPacket
Node ID of sender sending this keep-alive packet.
sendKeepAlive(NodeIDType[]) - Method in class edu.umass.cs.gigapaxos.FailureDetection
 
sendKeepAlive(Set<NodeIDType>) - Method in class edu.umass.cs.gigapaxos.FailureDetection
 
sendKeepAlive(NodeIDType) - Method in class edu.umass.cs.gigapaxos.FailureDetection
 
sendMessagingTask(MessagingTask) - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
sendReconfigurationRequest(ReconfigurationPacket.PacketType, String, String, RequestCallback) - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
sendRequest(String, String, InetSocketAddress, RequestCallback) - Method in class edu.umass.cs.gigapaxos.PaxosClientAsync
 
sendRequest(String, String, RequestCallback) - Method in class edu.umass.cs.gigapaxos.PaxosClientAsync
 
sendRequest(RequestPacket, InetSocketAddress, RequestCallback) - Method in class edu.umass.cs.gigapaxos.PaxosClientAsync
 
sendRequest(RequestPacket, RequestCallback) - Method in class edu.umass.cs.gigapaxos.PaxosClientAsync
 
sendRequest(int, RequestPacket) - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosClient
 
sendRequest(Request) - Method in interface edu.umass.cs.reconfiguration.interfaces.GigaPaxosClient
A blocking method to retrieve the result of executing request.
sendRequest(Request, Callback<Request, V>) - Method in interface edu.umass.cs.reconfiguration.interfaces.GigaPaxosClient
This method will automatically convert request to ClientRequest via ReplicableClientRequest if necessary.
sendRequest(ClientRequest, Callback<Request, V>) - Method in interface edu.umass.cs.reconfiguration.interfaces.GigaPaxosClient
 
sendRequest(ClientRequest, Callback<Request, V>, NearestServerSelector) - Method in interface edu.umass.cs.reconfiguration.interfaces.GigaPaxosClient
Sends request to the nearest server as determined by redirector, an interface that returns the nearest server from a set of server addresses.
sendRequest(ClientRequest, InetSocketAddress, Callback<Request, V>) - Method in interface edu.umass.cs.reconfiguration.interfaces.GigaPaxosClient
Sends request to the specified server.
sendRequest(ReconfiguratorRequest, Callback<Request, ReconfiguratorRequest>) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorFunctions
 
sendRequest(ReconfiguratorRequest) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorFunctions
 
sendRequest(Request) - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
sendRequest(Request, long) - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
sendRequest(Request, Callback<Request, V>) - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
This method will convert an app request to a ReplicableClientRequest and then send the request.
sendRequest(ClientRequest, InetSocketAddress) - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
sendRequest(ClientRequest, InetSocketAddress, long) - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
sendRequest(ClientRequest, InetSocketAddress, Callback<Request, V>) - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
sendRequest(ServerReconfigurationPacket<?>, RequestCallback) - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
Server reconfiguration packets have to be privileged, so we authenticate them implicitly by listening for them only on the server-server MUTUAL_AUTH port.
sendRequest(ClientReconfigurationPacket) - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
sendRequest(ClientReconfigurationPacket, long) - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
sendRequest(ClientReconfigurationPacket, RequestCallback) - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
This method exists for backwards compatibility and is slated for deprecation.
sendRequest(ClientRequest, Callback<Request, V>) - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
sendRequest(ClientRequest, Callback<Request, V>, NearestServerSelector) - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
sendRequest(ReconfiguratorRequest) - Method in class edu.umass.cs.reconfiguration.Reconfigurator
 
sendRequest(ReconfiguratorRequest, Callback<Request, ReconfiguratorRequest>) - Method in class edu.umass.cs.reconfiguration.Reconfigurator
 
sendRequest(int, RequestPacket) - Method in class edu.umass.cs.reconfiguration.testing.TESTPaxosClient
 
sendRequestAnycast(ClientRequest) - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
sendRequestAnycast(ClientRequest, long) - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
sendRequestAnycast(ClientRequest, Callback<Request, V>) - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
sendTestRequests(int, TESTPaxosClient[], double) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosClient
 
sendTestRequests(int, TESTPaxosClient[], double) - Static method in class edu.umass.cs.reconfiguration.testing.TESTPaxosClient
 
sendToAddress(InetSocketAddress, MessageType) - Method in interface edu.umass.cs.nio.interfaces.AddressMessenger
 
sendToAddress(InetSocketAddress, byte[]) - Method in interface edu.umass.cs.nio.interfaces.AddressMessenger
 
sendToAddress(InetSocketAddress, MessageType) - Method in interface edu.umass.cs.nio.interfaces.InterfaceNIOTransport
 
sendToAddress(InetSocketAddress, byte[]) - Method in interface edu.umass.cs.nio.interfaces.InterfaceNIOTransport
 
sendToAddress(InetSocketAddress, JSONObject) - Method in class edu.umass.cs.nio.JSONMessenger
Sends jsonData to address.
sendToAddress(InetSocketAddress, byte[]) - Method in class edu.umass.cs.nio.JSONMessenger
 
sendToAddress(InetSocketAddress, MessageType) - Method in class edu.umass.cs.nio.MessageNIOTransport
Send a JSON packet to an inet socket address (ip and port).
sendToAddress(InetSocketAddress, byte[]) - Method in class edu.umass.cs.nio.MessageNIOTransport
 
sendToID(NodeIDType, MessageType) - Method in interface edu.umass.cs.nio.interfaces.InterfaceNIOTransport
 
sendToID(NodeIDType, byte[]) - Method in interface edu.umass.cs.nio.interfaces.InterfaceNIOTransport
 
sendToID(NodeIDType, JSONObject) - Method in class edu.umass.cs.nio.JSONMessenger
Sends jsonData to node id.
sendToID(NodeIDType, byte[]) - Method in class edu.umass.cs.nio.JSONMessenger
 
sendToID(NodeIDType, MessageType) - Method in class edu.umass.cs.nio.MessageNIOTransport
Send a JSON packet to a node id.
sendToID(NodeIDType, byte[]) - Method in class edu.umass.cs.nio.MessageNIOTransport
 
sendToIDInternal(NodeIDType, MessageType) - Method in class edu.umass.cs.nio.MessageNIOTransport
 
sent(AcceptReplyPacket, int, int) - Static method in class edu.umass.cs.gigapaxos.paxosutil.RequestInstrumenter
 
sent(RequestPacket, int, int) - Static method in class edu.umass.cs.gigapaxos.paxosutil.RequestInstrumenter
 
SENT_TIME - Static variable in class edu.umass.cs.nio.JSONMessenger
The JSON key for the time when the message was sent.
sentActiveReplicaError() - Static method in class edu.umass.cs.reconfiguration.reconfigurationutils.AppInstrumenter
 
sentRequest(ClientRequest) - Static method in class edu.umass.cs.reconfiguration.reconfigurationutils.AppInstrumenter
 
sentResponseCoordinated(Request) - Static method in class edu.umass.cs.reconfiguration.reconfigurationutils.AppInstrumenter
 
sentResponseLocal(Request) - Static method in class edu.umass.cs.reconfiguration.reconfigurationutils.AppInstrumenter
 
sentTime - Variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.EchoRequest
 
serverPacketTypes - Static variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
 
ServerReconfigurationPacket<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
ServerReconfigurationPacket(NodeIDType, ReconfigurationPacket.PacketType, NodeIDType, InetSocketAddress) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.ServerReconfigurationPacket
 
ServerReconfigurationPacket(NodeIDType, ReconfigurationPacket.PacketType, Map<NodeIDType, InetSocketAddress>, Set<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.ServerReconfigurationPacket
 
ServerReconfigurationPacket(JSONObject, Stringifiable<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.ServerReconfigurationPacket
 
servers - Variable in class edu.umass.cs.gigapaxos.PaxosClientAsync
 
serviceName - Variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.BasicReconfigurationPacket
 
SessionKeys - Class in edu.umass.cs.utils
 
SessionKeys() - Constructor for class edu.umass.cs.utils.SessionKeys
 
SessionKeys.Events - Enum in edu.umass.cs.utils
Events associated with secret session keys.
SessionKeys.SecretKeyAndCertificate - Class in edu.umass.cs.utils
 
SessionKeys.SecretKeyCertificate - Class in edu.umass.cs.utils
A secret key certificate consists of a [secretKey, timestamp] 2-tuple signed by the corresponding public key, and all three of these together form the certificate.
SessionKeysTest - Class in edu.umass.cs.utils
 
SessionKeysTest() - Constructor for class edu.umass.cs.utils.SessionKeysTest
 
setAcceptPacket(AcceptPacket) - Method in class edu.umass.cs.gigapaxos.PaxosManager.RequestAndCallback
 
setActive() - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
setActive() - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
setActives(Set<InetSocketAddress>) - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RequestActiveReplicas
 
setActivesToNewActives(Set<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
setActivesToNewActives() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
setAppRequestParser(AppRequestParser) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationPacketDemultiplexer
 
setAssertRSMInvariant(boolean) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
setBaseDelay(long) - Static method in class edu.umass.cs.nio.JSONDelayEmulator
 
setBroadcasted() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
setByteifiedSelf(byte[]) - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
setCallback(ReconfiguratorCallback) - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
setCallback(ReconfiguratorCallback) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
This "default" callback will be called after every request execution.
setCallback(ReconfiguratorCallback) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
 
setCaseSensitive(boolean) - Static method in class edu.umass.cs.utils.Config
Makes Config keys case-sensitive if b is true.
setCharset(String) - Static method in class edu.umass.cs.utils.Stringer
 
setCleanDB(boolean) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
setCleanDB(boolean) - Static method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationConfig
 
setClient() - Static method in class edu.umass.cs.utils.SessionKeys
Sets maximum number of secret keys per public key to 1.
setClientAddress(InetSocketAddress) - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
 
setClientMessenger(SSLMessenger<?, JSONObject>) - Method in interface edu.umass.cs.gigapaxos.interfaces.ClientMessenger
An interface to supply a messenger to the app so that it can directly send responses for executed requests back to the app.
setClientMessenger(SSLMessenger<?, JSONObject>) - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosApp
 
setClientMessenger(AddressMessenger<?>) - Method in interface edu.umass.cs.nio.interfaces.SSLMessenger
 
setClientMessenger(AddressMessenger<?>) - Method in class edu.umass.cs.nio.JSONMessenger
 
setClientMessenger(SSLMessenger<?, JSONObject>) - Method in class edu.umass.cs.reconfiguration.examples.noop.NoopApp
 
setClientMessenger(SSLMessenger<?, JSONObject>) - Method in class edu.umass.cs.reconfiguration.examples.noopsimple.NoopApp
 
setClientMessenger(SSLMessenger<?, JSONObject>) - Method in class edu.umass.cs.reconfiguration.testing.NoopAppTesting
 
setClientMessenger(SSLMessenger<?, JSONObject>) - Method in class edu.umass.cs.txn.testing.NoopAppTX
 
setClientSSLMode(SSLDataProcessingWorker.SSL_MODES) - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
Deprecated.
setCompression(boolean) - Static method in class edu.umass.cs.nio.NIOTransport
 
setCompressionThreshold(int) - Static method in class edu.umass.cs.nio.NIOTransport
 
setConsoleHandler(Level) - Static method in class edu.umass.cs.gigapaxos.PaxosConfig
 
setConsoleHandler() - Static method in class edu.umass.cs.gigapaxos.PaxosConfig
 
setConsoleHandler(Level) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
setConsoleHandler() - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
setConsoleHandler(Level) - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
setConsoleHandler() - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
setConsoleHandler(Level) - Static method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationConfig
 
setConsoleHandler() - Static method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationConfig
 
setCoordinatorActive() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
setCoordinatorActive() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
setDefaultCallback(RequestCallback) - Method in class edu.umass.cs.gigapaxos.PaxosClientAsync
 
setDefaultGroups(int) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
setDemandProfile(Class<?>) - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
setDigest(byte[]) - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
setDigestRequest() - Method in class edu.umass.cs.gigapaxos.paxospackets.AcceptReplyPacket
 
setDistribtedTest() - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
setDrop(boolean) - Static method in class edu.umass.cs.protocoltask.TESTProtocolTaskConfig
 
setDropPreviousEpochCompleted() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
setEntryReplica(int) - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
setEntryReplica(String) - Method in class edu.umass.cs.reconfiguration.examples.noop.NoopAppRequest
 
setEntryReplicaAndReturnCount(int) - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
setEntryTime() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
setEpoch(int) - Method in class edu.umass.cs.reconfiguration.examples.AppRequest
 
setEpoch(int) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
setFailed() - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorRequest
 
setFailed(ClientReconfigurationPacket.ResponseCodes) - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
Sets as failed and marks as response.
setFailed() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
setFailed() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ServerReconfigurationPacket
 
setFailed() - Method in class edu.umass.cs.txn.txpackets.TXPacket
 
setFirstPrevEpochCandidate(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
setForwader(InetSocketAddress) - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
setForwardee(InetSocketAddress) - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
setForwarderID(int) - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
setGCSlot(int) - Method in class edu.umass.cs.gigapaxos.paxosutil.LogIndex
 
setGCSlotAfterPuttingInitialSlot() - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
setGCThresholdSize(int) - Method in class edu.umass.cs.utils.GCConcurrentHashMap
 
setGCTimeout(long) - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
setGCTimeout(long) - Method in class edu.umass.cs.utils.GCConcurrentHashMap
 
setGroup(String, Set<Integer>) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
setGroup(String, int[]) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
setHandshakeCallback(HandshakeCallback) - Method in class edu.umass.cs.nio.IOSSSLDataProcessingWorker
 
setHandshakeCallback(HandshakeCallback) - Method in class edu.umass.cs.nio.SSLDataProcessingWorker
 
setHashRCs(Set<InetSocketAddress>) - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
setIdleThreshold(long) - Method in class edu.umass.cs.utils.DiskMap
Minimum idle time in order to be pausable.
setInterCheckpointInterval(int) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
setIssuedAccept(AcceptPacket) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
setKey(String) - Method in class edu.umass.cs.protocoltask.json.ProtocolPacket
 
setKey(KeyType) - Method in interface edu.umass.cs.protocoltask.ProtocolEvent
Sets the protocol key.
setLargeCheckpoints() - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
Enables large checkpoints.
setLogger(Logger) - Static method in class edu.umass.cs.nio.nioutils.NIOInstrumenter
 
setLoopbackMode(boolean) - Static method in class edu.umass.cs.reconfiguration.testing.TESTRCDebug
Deprecated.
 
setLoopbackMode(boolean) - Static method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
 
setMaxOutstandingAppRequests(int) - Static method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
setMaxPublicKeys(int) - Static method in class edu.umass.cs.utils.SessionKeys
 
setMaxQueuedSends(int) - Method in class edu.umass.cs.nio.NIOTransport
 
setMaxSecretKeys(int) - Static method in class edu.umass.cs.utils.SessionKeys
Maximum number of secret keys per public key.
setMaxSyncDecisionsGap(int) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
setMedianCheckpointedSlot(int) - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedCommit
 
setMedianCheckpointedSlot(int) - Method in class edu.umass.cs.gigapaxos.paxospackets.PValuePacket
 
setMessenger(Messenger<NodeIDType, ?>) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
 
setMinInterConnectTime(int) - Method in class edu.umass.cs.nio.NIOTransport
 
setMinProbeTime(long) - Method in class edu.umass.cs.gigapaxos.paxosutil.E2ELatencyAwareRedirector
 
setMinResyncDelay(long) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
setMyID(String) - Method in class edu.umass.cs.nio.IOSSSLDataProcessingWorker
 
setMyID(String) - Method in class edu.umass.cs.nio.SSLDataProcessingWorker
 
setName(String) - Method in class edu.umass.cs.nio.MessageNIOTransport
 
setName(String) - Method in class edu.umass.cs.nio.NIOTransport
 
setNeedsCoordination(boolean) - Method in class edu.umass.cs.gigapaxos.examples.PaxosAppRequest
 
setNeedsCoordination(boolean) - Method in class edu.umass.cs.reconfiguration.examples.AppRequest
 
setNeedsCoordination(boolean) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReplicableRequest
Deprecated.
setNeedsCoordination(boolean) - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.DefaultAppRequest
 
setNeedsCoordination(boolean) - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.DemandReport
 
setNeedsCoordination(boolean) - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
 
setNeedsCoordination() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RequestActiveReplicas
 
setNeedsCoordination(boolean) - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StopEpoch
 
setNoCoalesce() - Method in class edu.umass.cs.gigapaxos.paxospackets.PValuePacket
 
setNodeSlots(int[]) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
setNodeSlots(int[]) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
setNoPropertiesFile() - Static method in class edu.umass.cs.gigapaxos.PaxosConfig
Used mainly for testing.
setNumDemultiplexerThreads(int) - Method in class edu.umass.cs.nio.AbstractPacketDemultiplexer
Sets the number of packet demultiplexing threads.
setOutOfOrderLimit(int) - Method in class edu.umass.cs.gigapaxos.PaxosManager
Specifies the level of reordering of decisions that prompts a sync-decisions request.
setOutOfOrderLimit(int) - Method in class edu.umass.cs.reconfiguration.PaxosReplicaCoordinator
 
setOutstanding(NodeIDType) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
setPacketizer(AbstractPaxosLogger.PaxosPacketizer) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
setParanoid() - Static method in class edu.umass.cs.gigapaxos.FailureDetection
 
setPauseThreadPeriod(long) - Method in class edu.umass.cs.utils.DiskMap
Period after which a pausing attempt is made by the GC thread.
setPaxosPacketStringifier(AbstractPaxosLogger.PaxosPacketStringifier) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
setPeriod(long) - Method in class edu.umass.cs.protocoltask.ThresholdProtocolTask
 
setPessimistic() - Static method in class edu.umass.cs.gigapaxos.FailureDetection
 
setProbeRatio(double) - Method in class edu.umass.cs.gigapaxos.paxosutil.E2ELatencyAwareRedirector
 
setProcessing(boolean) - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerTask
 
setRandomGroups(int) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
Sets consistent, random groups starting with the same random seed.
setRCEpochs(Set<NodeIDType>, Set<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
setRCEpochs(ReconfigurationRecord<NodeIDType>) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
Sets RC epochs so that we know the epoch numbers for each reconfigurator group.
setRCEpochs(Set<NodeIDType>, Set<NodeIDType>, Set<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
setRCEpochs(Set<NodeIDType>, Set<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
setRCEpochs(ReconfigurationRecord<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
setRCGroupName(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
setRecovered(int, String, boolean) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
Deprecated.
setRecovering(boolean) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
setRecovery() - Method in class edu.umass.cs.gigapaxos.paxospackets.PreparePacket
 
setRecovery() - Method in class edu.umass.cs.gigapaxos.paxospackets.PValuePacket
 
setRecovery(boolean) - Method in class edu.umass.cs.gigapaxos.paxospackets.PValuePacket
 
setRecursiveRedirect(boolean) - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
setResponse(String) - Method in class edu.umass.cs.gigapaxos.examples.PaxosAppRequest
 
setResponse(String) - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
setResponse(String) - Method in class edu.umass.cs.reconfiguration.examples.AppRequest
 
setResponseCode(ResponseCode) - Method in class edu.umass.cs.txn.txpackets.TXPacket
 
setResponseMessage(String) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorRequest
 
setResponseMessage(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
Sets response message and marks as response.
setResponseMessage(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ServerReconfigurationPacket
 
setReturnRequestValue() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
setSecretKeyLifetime(long) - Static method in class edu.umass.cs.utils.SessionKeys
 
setSender(NodeIDType) - Method in class edu.umass.cs.protocoltask.json.ProtocolPacket
 
setSendReplyToClient(boolean) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
setServerSSLMode(SSLDataProcessingWorker.SSL_MODES) - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
Deprecated.
setSingleNodeTest() - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
setSleepDuration(double) - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerTask
 
setSSLClientMessenger(AddressMessenger<?>) - Method in interface edu.umass.cs.nio.interfaces.SSLMessenger
 
setSSLClientMessenger(AddressMessenger<?>) - Method in class edu.umass.cs.nio.JSONMessenger
 
setState(String, int, ReconfigurationRecord.RCStates) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
Set epoch and state as specified.
setState(String, int, ReconfigurationRecord.RCStates) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
setState(String, int, ReconfigurationRecord.RCStates, Set<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
setState(String, int, ReconfigurationRecord.RCStates) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
setStateInitReconfiguration(String, int, ReconfigurationRecord.RCStates, Set<NodeIDType>) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
Set epoch, state, newActives, primary only if current state is READY
setStateInitReconfiguration(Map<String, String>, int, ReconfigurationRecord.RCStates, Set<NodeIDType>) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
 
setStateInitReconfiguration(String, int, ReconfigurationRecord.RCStates, Set<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
setStateInitReconfiguration(Map<String, String>, int, ReconfigurationRecord.RCStates, Set<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
setStateMerge(String, int, ReconfigurationRecord.RCStates, Set<NodeIDType>, Set<String>) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
 
setStateMerge(Map<String, String>, int, ReconfigurationRecord.RCStates, Set<NodeIDType>) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
 
setStateMerge(String, int, ReconfigurationRecord.RCStates, Set<String>) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
setStateMerge(String, int, ReconfigurationRecord.RCStates, Set<NodeIDType>, Set<String>) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
setStateMerge(Map<String, String>, int, ReconfigurationRecord.RCStates, Set<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
setStopCallback(ReconfiguratorCallback) - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
Used only at active replicas.
setStringifiedSelf(String) - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
setSystemProperties() - Method in class edu.umass.cs.utils.Config
 
setThreadName(String) - Method in class edu.umass.cs.nio.AbstractPacketDemultiplexer
 
setThreadName(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationPacketDemultiplexer
 
setThreadPoolSize(int) - Static method in class edu.umass.cs.nio.AbstractPacketDemultiplexer
 
setToIntArray(Set<Integer>) - Static method in class edu.umass.cs.utils.Util
 
setToIntegerArray(Set<Integer>) - Static method in class edu.umass.cs.utils.Util
 
setToNodeIdArray(Set<?>) - Static method in class edu.umass.cs.utils.Util
 
setToStringSet(Set<?>) - Static method in class edu.umass.cs.utils.Util
 
setType(EventType) - Method in class edu.umass.cs.protocoltask.json.ProtocolPacket
 
setup() - Static method in class edu.umass.cs.reconfiguration.testing.ReconfigurableAppCapacityTest
 
setupClients(NodeConfig<Integer>) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosClient
 
setupClients(NodeConfig<Integer>) - Static method in class edu.umass.cs.reconfiguration.testing.TESTPaxosClient
 
setUseSenderTask(boolean) - Static method in class edu.umass.cs.nio.NIOTransport
 
setVariation(double) - Static method in class edu.umass.cs.nio.JSONDelayEmulator
 
severe(Object...) - Method in class edu.umass.cs.utils.MyLogger
 
shouldAssertRSMInvariant() - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
shouldBroadcast() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
shouldCleanDB(String[]) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
Cleans DB if -c command line arg is specified.
shouldCleanDB(String[]) - Static method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationConfig
Cleans DB if -c command line arg is specified.
shouldDigest() - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
shouldDigest() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
shouldDrop(int) - Static method in class edu.umass.cs.protocoltask.TESTProtocolTaskConfig
 
shouldEnqueue() - Static method in class edu.umass.cs.gigapaxos.RequestBatcher
 
shouldExecuteStop() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StopEpoch
 
shouldGetFinalState() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StopEpoch
 
shouldReconfigureInPlace() - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
shouldReportDemandStats(Request, InetAddress, ReconfigurableAppInfo) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.AbstractDemandProfile
This method incorporates new information about client requests, i.e., request was received from sender.
shouldReportDemandStats(Request, InetAddress, ReconfigurableAppInfo) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DemandProfile
This method is used to inform the reconfiguration policy that request received from a client at IP address sender.
shouldReportDemandStats(Request, InetAddress, ReconfigurableAppInfo) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ProximateBalance
This method is used to inform the reconfiguration policy that request received from a client at IP address sender.
shouldReturnRequestValue() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
shouldSendDemandReport(Request, InetAddress) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.AggregateDemandProfiler
 
shouldSendSecretKey(SessionKeys.SecretKeyAndCertificate) - Static method in class edu.umass.cs.utils.SessionKeys
 
shutdown() - Method in interface edu.umass.cs.gigapaxos.interfaces.GigapaxosShutdownable
 
shutdown() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.TrivialRepliconfigurable
 
SimpleReconfiguratorNodeConfig<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationutils
 
SimpleReconfiguratorNodeConfig(ReconfigurableNodeConfig<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.SimpleReconfiguratorNodeConfig
 
size() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedAccept
 
size() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedAcceptReply
 
size() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedCommit
 
size() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedPaxosPacket
 
size() - Method in class edu.umass.cs.gigapaxos.paxosutil.PendingDigests
 
size() - Method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
size() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
 
size() - Method in class edu.umass.cs.utils.DiskMap
 
size() - Method in class edu.umass.cs.utils.MultiArrayMap
 
size() - Method in class edu.umass.cs.utils.NullIfEmptyMap
 
SIZE_ESTIMATE - Static variable in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
We need this estimate to use it in RequestBatcher.dequeueImpl().
SIZEOF_ACCEPT - Static variable in class edu.umass.cs.gigapaxos.paxospackets.AcceptPacket
 
SIZEOF_ACCEPTREPLY - Static variable in class edu.umass.cs.gigapaxos.paxospackets.AcceptReplyPacket
 
SIZEOF_BATCHEDACCEPTREPLY - Static variable in class edu.umass.cs.gigapaxos.paxospackets.AcceptReplyPacket
 
SIZEOF_BATCHEDCOMMIT_FIXED - Static variable in class edu.umass.cs.gigapaxos.paxospackets.BatchedCommit
Includes everything without BatchedCommit.slots, BatchedCommit.group and the two integers for their respective sizes.
SIZEOF_PAXOSPACKET_FIXED - Static variable in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
SIZEOF_PROPOSAL - Static variable in class edu.umass.cs.gigapaxos.paxospackets.ProposalPacket
 
SIZEOF_PVALUE - Static variable in class edu.umass.cs.gigapaxos.paxospackets.PValuePacket
 
SIZEOF_REQUEST_FIXED - Static variable in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
slateForRemovalActive(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
slateForRemovalReconfigurator(NodeIDType) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
slot - Variable in class edu.umass.cs.gigapaxos.paxospackets.ProposalPacket
Slot number assigned to the request.
slot - Variable in class edu.umass.cs.gigapaxos.paxosutil.LogIndex.LogIndexEntry
 
slot - Variable in class edu.umass.cs.gigapaxos.paxosutil.SlotBallotState
 
SlotBallotState - Class in edu.umass.cs.gigapaxos.paxosutil
 
SlotBallotState(int, int, int, String, int, long, Set<String>) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.SlotBallotState
 
slotNumber - Variable in class edu.umass.cs.gigapaxos.paxospackets.AcceptReplyPacket
Slot number in the ACCEPT request being replied to.
slotNumber - Variable in class edu.umass.cs.gigapaxos.paxospackets.StatePacket
Slot number of the request immediately after executing which the checkpoint was taken.
snapshot(String) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfigurableAppInfo
 
sndr - Variable in class edu.umass.cs.nio.nioutils.NIOHeader
 
SNDR_ADDRESS_FIELD - Static variable in class edu.umass.cs.nio.MessageNIOTransport
JSON key corresponding to sender socket address.
SNDR_IP_FIELD - Static variable in class edu.umass.cs.nio.MessageNIOTransport
Deprecated.
SNDR_PORT_FIELD - Static variable in class edu.umass.cs.nio.MessageNIOTransport
Deprecated.
socketAddressesToInetAddresses(InetSocketAddress[]) - Static method in class edu.umass.cs.utils.Util
 
sortByValue(Map<K, V>) - Static method in class edu.umass.cs.utils.Util
Sorts a map by value.
spawn(ProtocolTask<NodeIDType, EventType, KeyType>) - Method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
spawnCommandersForProposals() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
spawnCommandersForProposals() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
spawnIfNotRunning(ProtocolTask<NodeIDType, EventType, KeyType>) - Method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
splitIntoRCGroups(Set<String>, Set<?>) - Static method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
A utility method to split a collection of names into batches wherein names in each batch map to the same reconfigurator group.
SQL - Class in edu.umass.cs.gigapaxos.paxosutil
 
SQL() - Constructor for class edu.umass.cs.gigapaxos.paxosutil.SQL
 
SQL.SQLType - Enum in edu.umass.cs.gigapaxos.paxosutil
 
SQLPaxosLogger - Class in edu.umass.cs.gigapaxos
 
SQLPaxosLogger.SQLPaxosLoggerTester - Class in edu.umass.cs.gigapaxos
For testing SQLPaxosLogger.
SQLPaxosLoggerTester() - Constructor for class edu.umass.cs.gigapaxos.SQLPaxosLogger.SQLPaxosLoggerTester
 
SQLReconfiguratorDB<NodeIDType> - Class in edu.umass.cs.reconfiguration
 
SQLReconfiguratorDB(NodeIDType, ConsistentReconfigurableNodeConfig<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
SSLDataProcessingWorker - Class in edu.umass.cs.nio
 
SSLDataProcessingWorker(DataProcessingWorker, SSLDataProcessingWorker.SSL_MODES, String) - Constructor for class edu.umass.cs.nio.SSLDataProcessingWorker
 
SSLDataProcessingWorker.SSL_MODES - Enum in edu.umass.cs.nio
SSL modes supported.
SSLMessenger<NodeIDType,MessageType> - Interface in edu.umass.cs.nio.interfaces
 
sslMode - Variable in class edu.umass.cs.nio.IOSSSLDataProcessingWorker
 
sslMode - Variable in class edu.umass.cs.nio.SSLDataProcessingWorker
 
SSLNIOTester - Class in edu.umass.cs.nio.nioutils
 
SSLNIOTester() - Constructor for class edu.umass.cs.nio.nioutils.SSLNIOTester
 
stampAddressIntoJSONObject(InetSocketAddress, InetSocketAddress, JSONObject) - Static method in class edu.umass.cs.nio.MessageExtractor
 
stampAddressIntoJSONObject(InetSocketAddress, InetSocketAddress, JSONObject) - Static method in class edu.umass.cs.nio.MessageExtractor
For comparing json-smart with org.json.
start() - Method in class edu.umass.cs.gigapaxos.PaxosPacketBatcher
 
start() - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerTask
 
start(String) - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerTask
 
start() - Method in class edu.umass.cs.gigapaxos.RequestBatcher
 
start() - Method in class edu.umass.cs.protocoltask.examples.pingpong.PingPongProtocolTask
 
start() - Method in class edu.umass.cs.protocoltask.examples.PingPongServer
 
start() - Method in class edu.umass.cs.protocoltask.examples.thresholdfetch.MajorityFetchProtocolTask
 
start() - Method in interface edu.umass.cs.protocoltask.ProtocolTask
Actions executed in the beginning.
start() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.ActiveReplicaProtocolTask
 
start() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.ReconfiguratorProtocolTask
 
start() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckDropEpoch
We skip the first period before sending out drop epochs.
start() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStartEpoch
 
start() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStopEpoch
 
start() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitEpochFinalState
 
start() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitPrimaryExecution
 
startEpoch - Variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
The start epoch request that started this reconfiguration.
StartEpoch<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
StartEpoch(NodeIDType, String, int, Set<NodeIDType>, boolean) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
StartEpoch(NodeIDType, String, int, Set<NodeIDType>, Set<NodeIDType>, Set<String>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
StartEpoch(NodeIDType, String, int, Set<NodeIDType>, Set<NodeIDType>, String, boolean, int) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
StartEpoch(NodeIDType, String, int, Set<NodeIDType>, Set<NodeIDType>, InetSocketAddress, InetSocketAddress, InetSocketAddress, String, Map<String, String>, Map<NodeIDType, InetSocketAddress>, ReconfigurationConfig.ReconfigureUponActivesChange) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
StartEpoch(StartEpoch<NodeIDType>, String) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
Just to reset final field initialState.
StartEpoch(NodeIDType, StartEpoch<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
Just to reset final field initiator.
StartEpoch(JSONObject, Stringifiable<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
startEpoch - Variable in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStopEpoch
 
StartEpoch.Keys - Enum in edu.umass.cs.reconfiguration.reconfigurationpackets
 
startLocalServers() - Static method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationMain
 
startServers() - Static method in class edu.umass.cs.reconfiguration.testing.TESTRCDebug
Deprecated.
 
startServers() - Static method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
 
startWithCleanDB(boolean) - Static method in class edu.umass.cs.gigapaxos.PaxosManager
If set to true, PaxosManager will clear the DB upon creation.
state - Variable in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
state - Variable in class edu.umass.cs.gigapaxos.paxospackets.StatePacket
The checkpoint state encoded as a string.
state - Variable in class edu.umass.cs.gigapaxos.paxosutil.SlotBallotState
The checkpointed state.
state - Variable in class edu.umass.cs.gigapaxos.paxosutil.StringContainer
The contained string.
StatePacket - Class in edu.umass.cs.gigapaxos.paxospackets
 
StatePacket(Ballot, int, String) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.StatePacket
 
StatePacket(JSONObject) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.StatePacket
 
staticGetMutualAuthRequestTypes() - Static method in class edu.umass.cs.reconfiguration.examples.noopsimple.NoopApp
 
staticGetRequest(String) - Static method in class edu.umass.cs.reconfiguration.examples.noopsimple.NoopApp
We use this method also at the client, so it is static.
staticGetRequest(byte[], NIOHeader) - Static method in class edu.umass.cs.reconfiguration.examples.noopsimple.NoopApp
 
staticGetRequest(String) - Static method in class edu.umass.cs.reconfiguration.testing.NoopAppTesting
We use this method also at the client, so it is static.
staticGetRequest(byte[], NIOHeader) - Static method in class edu.umass.cs.reconfiguration.testing.NoopAppTesting
 
staticGetRequest(String) - Static method in class edu.umass.cs.txn.testing.NoopAppTX
We use this method also at the client, so it is static.
staticGetRequest(byte[], NIOHeader) - Static method in class edu.umass.cs.txn.testing.NoopAppTX
 
staticGetRequestTypes() - Static method in class edu.umass.cs.reconfiguration.examples.noopsimple.NoopApp
We use this method also at the client, so it is static.
staticGetRequestTypes() - Static method in class edu.umass.cs.reconfiguration.testing.NoopAppTesting
We use this method also at the client, so it is static.
staticGetRequestTypes() - Static method in class edu.umass.cs.txn.testing.NoopAppTX
We use this method also at the client, so it is static.
stop() - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
stop - Variable in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
Whether this request is a stop request.
stop() - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerTask
 
stop() - Method in class edu.umass.cs.nio.AbstractPacketDemultiplexer
Any created instance of AbstractPacketDemultiplexer or its inheritors must be cleanly closed by invoking this stop method.
stop() - Method in interface edu.umass.cs.nio.interfaces.InterfaceMessageExtractor
 
stop() - Method in interface edu.umass.cs.nio.interfaces.InterfaceNIOTransport
Needs to be called to close NIO gracefully.
stop() - Method in class edu.umass.cs.nio.IOSSSLDataProcessingWorker
 
stop() - Static method in class edu.umass.cs.nio.JSONDelayEmulator
Stops the underlying timer thread.
stop() - Method in class edu.umass.cs.nio.JSONMessenger
 
stop() - Method in class edu.umass.cs.nio.MessageExtractor
 
stop() - Method in class edu.umass.cs.nio.MessageNIOTransport
 
stop() - Method in class edu.umass.cs.nio.NIOTransport
To close NIOTransport instances gracefully.
stop() - Method in class edu.umass.cs.nio.SSLDataProcessingWorker
 
stop() - Method in class edu.umass.cs.protocoltask.examples.ExampleNode
 
stop() - Method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
stop() - Method in class edu.umass.cs.reconfiguration.AbstractReplicaCoordinator
End of private helper methods
STOP - Static variable in interface edu.umass.cs.reconfiguration.interfaces.ReconfigurableRequest
Used internally.
stop() - Method in class edu.umass.cs.reconfiguration.PaxosReplicaCoordinator
 
StopEpoch<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationpackets
 
StopEpoch(NodeIDType, String, int, boolean, boolean) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.StopEpoch
 
StopEpoch(NodeIDType, String, int) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.StopEpoch
 
StopEpoch(JSONObject, Stringifiable<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationpackets.StopEpoch
 
stopFailureMonitoring(NodeIDType) - Method in class edu.umass.cs.gigapaxos.PaxosManager
When a node is being permanently deleted.
stopFailureMonitoring(NodeIDType) - Method in class edu.umass.cs.reconfiguration.PaxosReplicaCoordinator
 
stopServer(String) - Static method in class edu.umass.cs.reconfiguration.ReconfigurableNode
 
StringContainer - Class in edu.umass.cs.gigapaxos.paxosutil
 
StringContainer(String) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.StringContainer
 
Stringer - Class in edu.umass.cs.utils
 
Stringer(byte[]) - Constructor for class edu.umass.cs.utils.Stringer
 
Stringer(byte[], int, int) - Constructor for class edu.umass.cs.utils.Stringer
 
Stringer(Object) - Constructor for class edu.umass.cs.utils.Stringer
 
Stringifiable<ObjectType> - Interface in edu.umass.cs.nio.interfaces
 
StringifiableDefault<ObjectType> - Class in edu.umass.cs.nio.nioutils
 
StringifiableDefault(Object) - Constructor for class edu.umass.cs.nio.nioutils.StringifiableDefault
 
STRINGIFIED - Static variable in class edu.umass.cs.nio.MessageExtractor
 
StringLocker - Class in edu.umass.cs.utils
 
StringLocker() - Constructor for class edu.umass.cs.utils.StringLocker
 
stringSetToIntegerSet(Set<String>) - Static method in class edu.umass.cs.utils.Util
 
stringToIntArray(String) - Static method in class edu.umass.cs.utils.Util
 
stringToPaxosPacket(String) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger.PaxosPacketizer
 
stringToPaxosPacket(byte[]) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger.PaxosPacketizer
 
stringToStringSet(String) - Static method in class edu.umass.cs.utils.Util
 
submit(Runnable) - Method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
subRequests() - Method in interface edu.umass.cs.reconfiguration.interfaces.RequestType
 
suicide(Logger, String) - Static method in class edu.umass.cs.utils.Util
 
suicide(String) - Static method in class edu.umass.cs.utils.Util
 
Summarizable - Interface in edu.umass.cs.gigapaxos.interfaces
 
Summarizable - Interface in edu.umass.cs.utils
 
SummarizableRequest - Interface in edu.umass.cs.gigapaxos.interfaces
 
SYNC_THRESHOLD - Static variable in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
SyncDecisionsPacket - Class in edu.umass.cs.gigapaxos.paxospackets
 
SyncDecisionsPacket(int, int, ArrayList<Integer>, boolean) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.SyncDecisionsPacket
 
SyncDecisionsPacket(JSONObject) - Constructor for class edu.umass.cs.gigapaxos.paxospackets.SyncDecisionsPacket
 
synchronizedNoop() - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
Forces a synchronization wait.

T

test() - Method in class edu.umass.cs.utils.DefaultTest
 
test000_debug() - Method in class edu.umass.cs.reconfiguration.testing.TESTRCDebug
Deprecated.
Specifically for testing the creation of four names and an update to the first.
test00_AnycastRequest() - Method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
 
test00_CreateExistsDelete() - Method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
Tests creation and deletion of a single name.
test00_RandomNameAppRequestFails() - Method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
Tests that a request to a random app name fails as expected.
test00_RandomNameDeleteFails() - Method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
Tests that a delete of a random (non-existent) name fails.
test00_RandomNameNotExists() - Method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
Tests that a random name does not exist.
test00_RequestRandomActive() - Method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
 
test01_BasicSequence() - Method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
Tests creation, existence, app requests, deletion, and non-existence of a set of names.
test01_Remove() - Method in class edu.umass.cs.utils.DiskMapTest
 
test02_MutualAuthRequest() - Method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
 
test02_NonDefaultRequest() - Method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
Method to test AppRequest.PacketType.APP_REQUEST3 that is a transaction.
test02_ReplicableClientRequest() - Method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
 
test03_BasicSequenceBatched() - Method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
Same as TESTReconfigurationClient.test01_BasicSequence() but with batch created names.
test04_ReconfigurationRate() - Method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
 
test20_RandomActiveReplicaDelete() - Method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
Deletion of a non-existent active replica succeeds.
test20_RandomActiveReplicaDeleteAfterAdd() - Method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
Addition of a random active replica succeeds (as it appears to other nodes as simply failed).
test21_DeleteActiveReplica() - Method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
 
test22_AddActiveReplica() - Method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
 
test31_AddReconfigurator() - Method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
 
test32_DeleteReconfigurator() - Method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
 
test99_Main() - Method in class edu.umass.cs.utils.DiskMapTest
 
test_01_JSONArrayToMap() - Method in class edu.umass.cs.utils.UtilTest
 
test_01_JSONObjectToMap() - Method in class edu.umass.cs.utils.UtilTest
 
test_01_SingleWrite() - Method in class edu.umass.cs.reconfiguration.testing.ReconfigurableAppCapacityTest
Verifies a single write is successful.
test_02_SequentialReadCapacity() - Method in class edu.umass.cs.reconfiguration.testing.ReconfigurableAppCapacityTest
 
test_04_ParallelReadCapacity() - Method in class edu.umass.cs.reconfiguration.testing.ReconfigurableAppCapacityTest
 
test_checkpoint() - Method in class edu.umass.cs.gigapaxos.paxosutil.LargeCheckpointer.LargeCheckpointerTest
 
test_DecodePerformance() - Method in class edu.umass.cs.utils.SessionKeysTest
 
test_EncodeDecode() - Method in class edu.umass.cs.utils.SessionKeysTest
 
test_Generate() - Method in class edu.umass.cs.utils.SessionKeysTest
 
test_Learning() - Method in class edu.umass.cs.gigapaxos.paxosutil.E2ELatencyAwareRedirectorTest
 
TEST_PORT - Static variable in class edu.umass.cs.reconfiguration.deprecated.ReconfigurableClient
Deprecated.
 
TEST_PORT - Static variable in class edu.umass.cs.reconfiguration.deprecated.ReconfigurableClientCreateTester
 
test_PrefixMatchLength() - Method in class edu.umass.cs.gigapaxos.paxosutil.E2ELatencyAwareRedirectorTest
 
test_ProbeAndClosest() - Method in class edu.umass.cs.gigapaxos.paxosutil.E2ELatencyAwareRedirectorTest
 
test_remoteCheckpointTransfer() - Method in class edu.umass.cs.gigapaxos.paxosutil.LargeCheckpointer.LargeCheckpointerTest
 
test_restore() - Method in class edu.umass.cs.gigapaxos.paxosutil.LargeCheckpointer.LargeCheckpointerTest
 
test_SignVerifySecretKey() - Method in class edu.umass.cs.utils.SessionKeysTest
 
testAll(List<Class<?>>) - Static method in class edu.umass.cs.utils.DefaultTest
 
testAll(Class<?>...) - Static method in class edu.umass.cs.utils.DefaultTest
 
testAndSetReconfigured(String, Set<String>, ReconfigurableAppInfo) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.AggregateDemandProfiler
 
testAndSetWaitingTooLong() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
testAndSetWaitingTooLong(int) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
testAndSetWaitingTooLong() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
testAndSetWaitingTooLong(int) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
testCheckFields() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacketTest
 
testFragmentAndReassembly() - Method in class edu.umass.cs.gigapaxos.paxosutil.PrepareReplyAssembler.PrepareReplyAssemblerTest
Unit testing code.
TESTING_CONFIG_FILE_KEY - Static variable in class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
testingInit(int) - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
testingInitCoord(int) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
testingInitCoord(int) - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
 
testingInitInstance(int) - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
testJSONConstructor() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationPolicyTest
 
testMain() - Method in class edu.umass.cs.utils.GCConcurrentHashMap.GCConcurrentHashMapTest
 
testMain() - Method in class edu.umass.cs.utils.MultiArrayMapTest
 
testMakeCreateNameRequest(String, String, int, int) - Static method in class edu.umass.cs.reconfiguration.ReconfigurationConfig
 
testMemory() - Static method in class edu.umass.cs.gigapaxos.PaxosAcceptor
 
testName - Variable in class edu.umass.cs.reconfiguration.testing.TESTRCDebug
Deprecated.
 
testName - Variable in class edu.umass.cs.utils.DefaultTest
 
testPackage() - Method in class edu.umass.cs.utils.DefaultTest
 
testPaxos(boolean) - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosMain
 
testPaxosAfterRecovery() - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosMain
 
TESTPaxosApp - Class in edu.umass.cs.gigapaxos.testing
 
TESTPaxosApp(InterfaceNIOTransport<Integer, JSONObject>) - Constructor for class edu.umass.cs.gigapaxos.testing.TESTPaxosApp
 
TESTPaxosApp() - Constructor for class edu.umass.cs.gigapaxos.testing.TESTPaxosApp
 
TESTPaxosClient - Class in edu.umass.cs.gigapaxos.testing
 
TESTPaxosClient(int, NodeConfig<Integer>) - Constructor for class edu.umass.cs.gigapaxos.testing.TESTPaxosClient
 
TESTPaxosClient - Class in edu.umass.cs.reconfiguration.testing
 
TESTPaxosClient(int, NodeConfig<Integer>) - Constructor for class edu.umass.cs.reconfiguration.testing.TESTPaxosClient
 
TESTPaxosConfig - Class in edu.umass.cs.gigapaxos.testing
 
TESTPaxosConfig() - Constructor for class edu.umass.cs.gigapaxos.testing.TESTPaxosConfig
 
TESTPaxosConfig.TC - Enum in edu.umass.cs.gigapaxos.testing
Gigapaxos testing config parameters.
TESTPaxosMain - Class in edu.umass.cs.gigapaxos.testing
 
TESTPaxosMain() - Constructor for class edu.umass.cs.gigapaxos.testing.TESTPaxosMain
 
TESTPaxosNode - Class in edu.umass.cs.gigapaxos.testing
 
TESTPaxosNode(int) - Constructor for class edu.umass.cs.gigapaxos.testing.TESTPaxosNode
 
TESTPaxosShutdownThread - Class in edu.umass.cs.gigapaxos.testing
 
TESTPaxosShutdownThread() - Constructor for class edu.umass.cs.gigapaxos.testing.TESTPaxosShutdownThread
 
testPerformance() - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger.SQLPaxosLoggerTester
An old, somewhat outdated test to test DB performance wrt checkpointing and logging messages.
testPolicyImplementation(Class<?>) - Static method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationPolicyTest
Sanity checks the implementation of a reconfiguration policy using a trivial default Request implementation.
TESTProtocolTaskConfig - Class in edu.umass.cs.protocoltask
 
TESTProtocolTaskConfig() - Constructor for class edu.umass.cs.protocoltask.TESTProtocolTaskConfig
 
TESTRCDebug - Class in edu.umass.cs.reconfiguration.testing
Deprecated.
TESTRCDebug() - Constructor for class edu.umass.cs.reconfiguration.testing.TESTRCDebug
Deprecated.
 
TESTRCDebug(Map<String, InetSocketAddress>) - Constructor for class edu.umass.cs.reconfiguration.testing.TESTRCDebug
Deprecated.
 
TESTReconfigurationClient - Class in edu.umass.cs.reconfiguration.testing
 
TESTReconfigurationClient() - Constructor for class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
 
TESTReconfigurationClient(Map<String, InetSocketAddress>) - Constructor for class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
 
TESTReconfigurationConfig - Class in edu.umass.cs.reconfiguration.testing
 
TESTReconfigurationConfig() - Constructor for class edu.umass.cs.reconfiguration.testing.TESTReconfigurationConfig
 
TESTReconfigurationConfig.TRC - Enum in edu.umass.cs.reconfiguration.testing
Reconfiguration testing config parameters.
TESTReconfigurationMain - Class in edu.umass.cs.reconfiguration.testing
 
TESTReconfigurationMain() - Constructor for class edu.umass.cs.reconfiguration.testing.TESTReconfigurationMain
 
testRecord() - Method in class edu.umass.cs.nio.nioutils.RTTEstimatorTest
 
testRestore() - Method in class edu.umass.cs.gigapaxos.paxosutil.LogIndex.LogIndexTest
 
testStringConstructor() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationPolicyTest
 
testToInt() - Method in class edu.umass.cs.nio.nioutils.RTTEstimatorTest
 
testToStringAndBack() - Method in class edu.umass.cs.gigapaxos.paxosutil.HotRestoreInfo.HotRestoreInfoTest
 
testWithRecovery() - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosMain
 
thresholdFetch() - Method in class edu.umass.cs.protocoltask.examples.ExampleNode
 
ThresholdProtocolEvent<NodeIDType,EventType,KeyType> - Interface in edu.umass.cs.protocoltask
 
ThresholdProtocolTask<NodeIDType,EventType,KeyType> - Class in edu.umass.cs.protocoltask
 
ThresholdProtocolTask(Set<NodeIDType>) - Constructor for class edu.umass.cs.protocoltask.ThresholdProtocolTask
Set of nodes from which we expect to hear back.
ThresholdProtocolTask(Set<NodeIDType>, int) - Constructor for class edu.umass.cs.protocoltask.ThresholdProtocolTask
Set of nodes out of which we expect to hear back from threshold number of nodes.
ThresholdProtocolTask(Set<NodeIDType>, int, boolean) - Constructor for class edu.umass.cs.protocoltask.ThresholdProtocolTask
Set of nodes out of which we expect to hear back from threshold number of nodes.
throttleExcessiveLoad() - Static method in class edu.umass.cs.gigapaxos.paxosutil.PaxosPacketDemultiplexer
 
TimeoutRequestCallback - Interface in edu.umass.cs.gigapaxos.interfaces
 
times() - Method in class edu.umass.cs.utils.RepeatRule
 
toArray() - Method in class edu.umass.cs.gigapaxos.paxosutil.MessagingTask
 
toArray(GenericMessagingTask<?, ?>, GenericMessagingTask<?, ?>) - Static method in class edu.umass.cs.nio.GenericMessagingTask
Converts the two parameters into an array of size two.
toArray() - Method in class edu.umass.cs.nio.GenericMessagingTask
 
toArray() - Method in class edu.umass.cs.nio.nioutils.MessagingTask
Converts this messaging task to an array of size one.
toArray(MessagingTask, MessagingTask) - Static method in class edu.umass.cs.nio.nioutils.MessagingTask
 
toBytes() - Method in interface edu.umass.cs.gigapaxos.interfaces.Request
The implementation of this method is tied to and must be the inverse of AppRequestParser.getRequest(byte[], edu.umass.cs.nio.nioutils.NIOHeader) , i.e., invoking getRequest(request.toBytes(), header).equals(request).
toBytes() - Method in class edu.umass.cs.gigapaxos.paxospackets.AcceptPacket
 
toBytes(ByteBuffer) - Method in class edu.umass.cs.gigapaxos.paxospackets.AcceptReplyPacket
 
toBytes() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedAcceptReply
 
toBytes() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedCommit
 
toBytes(ByteBuffer) - Method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
toBytes() - Method in class edu.umass.cs.gigapaxos.paxospackets.ProposalPacket
 
toBytes() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
toBytes(boolean) - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
The weird constant above is to try to avoid mistakes in the painful (but totally worth it) byte'ification method below.
toBytes() - Method in interface edu.umass.cs.nio.interfaces.Byteable
The recommendation that the first four bytes contain the integer packet type is for bring able to write efficient demultiplexers that will not attempt to decode an incoming packet unless the type matches one of the types they expect to receive.
toBytes() - Method in class edu.umass.cs.nio.JSONMessenger.JSONObjectByteableWrapper
 
toBytes() - Method in class edu.umass.cs.nio.nioutils.NIOHeader
 
toBytes() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
 
toBytes() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
 
toBytes() - Method in class edu.umass.cs.reconfiguration.testing.MetaRequestPacket
 
toBytesInstrument() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
toIntSet(int) - Static method in class edu.umass.cs.utils.Util
 
toJSONObject() - Method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
toJSONObject(JSONObject) - Static method in class edu.umass.cs.gigapaxos.paxosutil.PaxosPacketDemultiplexerFast
 
toJSONObject() - Method in class edu.umass.cs.nio.JSONPacket
 
toJSONObject() - Method in class edu.umass.cs.protocoltask.json.ProtocolPacket
 
toJSONObject() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.DefaultAppRequest
 
toJSONObject() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
toJSONObject(String) - Static method in class edu.umass.cs.utils.Util
 
toJSONObjectImpl() - Method in class edu.umass.cs.gigapaxos.examples.PaxosAppRequest
 
toJSONObjectImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.AcceptPacket
 
toJSONObjectImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.AcceptReplyPacket
 
toJSONObjectImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedAccept
 
toJSONObjectImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedAcceptReply
 
toJSONObjectImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedCommit
 
toJSONObjectImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedPaxosPacket
 
toJSONObjectImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.FailureDetectionPacket
 
toJSONObjectImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.FindReplicaGroupPacket
 
toJSONObjectImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
toJSONObjectImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.PreparePacket
 
toJSONObjectImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.PrepareReplyPacket
 
toJSONObjectImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.ProposalPacket
 
toJSONObjectImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.PValuePacket
 
toJSONObjectImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
toJSONObjectImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.StatePacket
 
toJSONObjectImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.SyncDecisionsPacket
 
toJSONObjectImpl() - Method in class edu.umass.cs.nio.JSONPacket
 
toJSONObjectImpl() - Method in class edu.umass.cs.protocoltask.examples.PingPongPacket
 
toJSONObjectImpl() - Method in class edu.umass.cs.protocoltask.json.ProtocolPacket
 
toJSONObjectImpl() - Method in class edu.umass.cs.reconfiguration.examples.AppRequest
 
toJSONObjectImpl() - Method in class edu.umass.cs.reconfiguration.examples.noop.NoopAppRequest
 
toJSONObjectImpl() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.AckStopEpoch
 
toJSONObjectImpl() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ActiveReplicaError
 
toJSONObjectImpl() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.BasicReconfigurationPacket
 
toJSONObjectImpl() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.BatchedCreateServiceName
 
toJSONObjectImpl() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
 
toJSONObjectImpl() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
 
toJSONObjectImpl() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.DeleteServiceName
 
toJSONObjectImpl() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.DemandReport
 
toJSONObjectImpl() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.EchoRequest
 
toJSONObjectImpl() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.EpochFinalState
 
toJSONObjectImpl() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest
 
toJSONObjectImpl() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
 
toJSONObjectImpl() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
 
toJSONObjectImpl() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RequestActiveReplicas
 
toJSONObjectImpl() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ServerReconfigurationPacket
 
toJSONObjectImpl() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch
 
toJSONObjectImpl() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.StopEpoch
 
toJSONObjectImpl() - Method in class edu.umass.cs.reconfiguration.testing.MetaRequestPacket
 
toJSONObjectImpl() - Method in class edu.umass.cs.txn.txpackets.LockRequest
 
toJSONObjectImpl() - Method in class edu.umass.cs.txn.txpackets.TXPacket
 
toJSONObjectImpl() - Method in class edu.umass.cs.txn.txpackets.UnlockRequest
 
toJSONSmart() - Method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
toJSONSmartImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.AcceptPacket
 
toJSONSmartImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.AcceptReplyPacket
 
toJSONSmartImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedAccept
 
toJSONSmartImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedAcceptReply
 
toJSONSmartImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedCommit
 
toJSONSmartImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.BatchedPaxosPacket
 
toJSONSmartImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
toJSONSmartImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.ProposalPacket
 
toJSONSmartImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.PValuePacket
 
toJSONSmartImpl() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
 
toJSONString(Collection<?>) - Static method in class edu.umass.cs.utils.Util
 
toJSONString(int[]) - Static method in class edu.umass.cs.utils.Util
 
toLong(Object) - Static method in class edu.umass.cs.utils.Util
 
toMergeContains(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
TOO_MANY_TASKS_CHECK_PERIOD - Static variable in class edu.umass.cs.protocoltask.ProtocolExecutor
 
toPaxosPacket(JSONObject, Stringifiable<?>) - Static method in class edu.umass.cs.gigapaxos.paxosutil.PaxosPacketDemultiplexer
 
toPaxosPacket(JSONObject) - Static method in class edu.umass.cs.gigapaxos.paxosutil.PaxosPacketDemultiplexer
 
toPaxosPacket(JSONObject, Stringifiable<?>) - Static method in class edu.umass.cs.gigapaxos.paxosutil.PaxosPacketDemultiplexerFast
 
toPaxosPacketArray(Object[]) - Static method in class edu.umass.cs.gigapaxos.paxosutil.MessagingTask
FIXME: The comment below is incorrect and this method is unnecessary.
toPaxosPacketArray(PaxosPacket[], PaxosPacket[]) - Static method in class edu.umass.cs.gigapaxos.paxosutil.MessagingTask
 
toSingletonArray() - Method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
toString() - Method in interface edu.umass.cs.gigapaxos.interfaces.Request
Serializes the request to a String.
toString() - Method in class edu.umass.cs.gigapaxos.PaxosAcceptor
Start of testing methods
toString() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
toString() - Method in class edu.umass.cs.gigapaxos.PaxosCoordinatorState
Start of testing methods
toString() - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
toString() - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
toString() - Method in class edu.umass.cs.gigapaxos.PaxosPacketBatcher
 
toString() - Method in enum edu.umass.cs.gigapaxos.paxospackets.PaxosPacket.PaxosPacketType
 
toString() - Method in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
toString() - Method in class edu.umass.cs.gigapaxos.paxospackets.RequestPacket
Learned the hard way that using org.json to stringify is an order of magnitude slower with large request values compared to manually inserting the string like below.
toString() - Method in class edu.umass.cs.gigapaxos.paxosutil.Ballot
 
toString() - Method in class edu.umass.cs.gigapaxos.paxosutil.E2ELatencyAwareRedirector
 
toString() - Method in class edu.umass.cs.gigapaxos.paxosutil.HotRestoreInfo
 
toString() - Method in class edu.umass.cs.gigapaxos.paxosutil.LargeCheckpointer
 
toString() - Method in class edu.umass.cs.gigapaxos.paxosutil.LogIndex
The ordering of fields below is important for correctness as we are not using keys for fields here.
toString() - Method in class edu.umass.cs.gigapaxos.paxosutil.LogMessagingTask
 
toString() - Method in class edu.umass.cs.gigapaxos.paxosutil.MessagingTask
Just for pretty printing.
toString() - Method in class edu.umass.cs.gigapaxos.paxosutil.PendingDigests
 
toString() - Method in class edu.umass.cs.gigapaxos.paxosutil.RecoveryInfo
 
toString() - Method in class edu.umass.cs.gigapaxos.paxosutil.SlotBallotState
 
toString() - Method in class edu.umass.cs.gigapaxos.paxosutil.WaitforUtility
 
toString() - Method in class edu.umass.cs.gigapaxos.RequestBatcher
 
toString() - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
toString() - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosApp
 
toString() - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosNode
 
toString() - Method in class edu.umass.cs.nio.AbstractNIOSSL
 
toString() - Method in class edu.umass.cs.nio.AbstractPacketDemultiplexer
 
toString() - Method in class edu.umass.cs.nio.GenericMessagingTask
For pretty printing
toString() - Method in class edu.umass.cs.nio.IOSSSLDataProcessingWorker
 
toString() - Method in class edu.umass.cs.nio.JSONMessenger.JSONObjectWrapper
 
toString() - Method in class edu.umass.cs.nio.JSONMessenger
 
toString() - Method in class edu.umass.cs.nio.JSONPacket
 
toString() - Method in class edu.umass.cs.nio.MessageExtractor
 
toString() - Method in class edu.umass.cs.nio.NIOTransport
 
toString() - Method in class edu.umass.cs.nio.nioutils.NIOHeader
 
toString() - Method in class edu.umass.cs.nio.nioutils.NIOInstrumenter
 
toString() - Method in class edu.umass.cs.nio.nioutils.RTTEstimator.IPv4Prefix
 
toString() - Method in class edu.umass.cs.nio.nioutils.SampleNodeConfig
Pretty prints this node config information.
toString() - Method in class edu.umass.cs.nio.SSLDataProcessingWorker
 
toString() - Method in class edu.umass.cs.protocoltask.json.ProtocolPacket
 
toString() - Method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
toString() - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
toString() - Method in class edu.umass.cs.reconfiguration.ActiveReplica
 
toString() - Method in class edu.umass.cs.reconfiguration.examples.noopsimple.NoopApp
 
toString() - Method in class edu.umass.cs.reconfiguration.http.HttpReconfigurator
 
toString() - Method in class edu.umass.cs.reconfiguration.PaxosReplicaCoordinator
 
toString() - Method in class edu.umass.cs.reconfiguration.ReconfigurableAppClientAsync
 
toString() - Method in class edu.umass.cs.reconfiguration.ReconfigurableNode.DefaultReconfigurableNode
 
toString() - Method in class edu.umass.cs.reconfiguration.ReconfigurableNode
 
toString() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.DefaultAppRequest
 
toString() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket
 
toString() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
Note: This method returns the stringified form of the underlying request.
toString() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.CommitWorker
 
toString() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStartEpoch
 
toString() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStopEpoch
 
toString() - Method in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitEpochFinalState
 
toString() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentReconfigurableNodeConfig
 
toString() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DefaultNodeConfig
 
toString() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DynamoReplicaCoordinator
 
toString() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
toString() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.TrivialRepliconfigurable
 
toString() - Method in class edu.umass.cs.reconfiguration.Reconfigurator
 
toString() - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
toString() - Method in class edu.umass.cs.reconfiguration.testing.MetaRequestPacket
 
toString() - Method in class edu.umass.cs.reconfiguration.testing.NoopAppTesting
 
toString() - Method in class edu.umass.cs.reconfiguration.testing.TESTRCDebug
Deprecated.
 
toString() - Method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationClient
 
toString() - Method in class edu.umass.cs.txn.testing.NoopAppTX
 
toString() - Method in class edu.umass.cs.utils.DiskMap
 
toString() - Method in class edu.umass.cs.utils.SessionKeys.SecretKeyCertificate
 
toString() - Method in class edu.umass.cs.utils.Stringer
 
toString(InetSocketAddress) - Static method in class edu.umass.cs.utils.Util
 
toString() - Method in class edu.umass.cs.utils.Waitfor
 
toStringLong() - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
totalWaitTime() - Method in class edu.umass.cs.gigapaxos.paxosutil.WaitforUtility
 
totalWaitTime() - Method in class edu.umass.cs.utils.Waitfor
 
transact(Transaction) - Method in class edu.umass.cs.txn.DistTransactor
This method is the top-level method initiating a transaction and consists of the following sequence of steps: (1) create transaction group; (2) acquire participant group locks; (3) execute transaction operations in order; (4) issue commit to transaction group; (5) release participant group locks; (6) delete transaction group.
transact(TXRequest) - Method in interface edu.umass.cs.txn.interfaces.Transactor
 
transact(TXRequest) - Method in class edu.umass.cs.txn.TXUtils
 
Transaction - Class in edu.umass.cs.txn
 
Transaction(InetSocketAddress, TXInterface) - Constructor for class edu.umass.cs.txn.Transaction
 
Transaction(InetSocketAddress, TXRequest) - Constructor for class edu.umass.cs.txn.Transaction
 
Transaction.Keys - Enum in edu.umass.cs.txn
 
Transactor - Interface in edu.umass.cs.txn.interfaces
 
trim() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.AggregateDemandProfiler
If aggregate size becomes more than DEFAULT_MAX_SIZE, this method will pluck DEFAULT_PLUCK_SIZE out so that an active replica can report it to reconfigurators.
trimRCEpochs() - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
Needed to trim the rcEpochs map when reconfigurator nodes get deleted.
TrivialRepliconfigurable - Class in edu.umass.cs.reconfiguration.reconfigurationutils
 
TrivialRepliconfigurable(Application) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationutils.TrivialRepliconfigurable
 
truncate(Object, int) - Static method in class edu.umass.cs.utils.Util
 
truncate(Object, int, int) - Static method in class edu.umass.cs.utils.Util
 
truncatedLog(Collection<?>, int) - Static method in class edu.umass.cs.utils.Util
 
tryFinishAsyncTasks(GigaPaxosClient<Request>, ArrayList<Request>) - Static method in class edu.umass.cs.txn.TXUtils
 
tryFinishAsyncTasks(GigaPaxosClient<Request>, ArrayList<Request>, int) - Static method in class edu.umass.cs.txn.TXUtils
Blocks and retries in parallel until all of a set of transaction steps have successfully completed.
tryForcedCheckpointAndStop() - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
tryGC(long) - Method in class edu.umass.cs.utils.GCConcurrentHashMap
 
tryPause() - Method in class edu.umass.cs.gigapaxos.PaxosInstanceStateMachine
 
TWO_PAXOS_RC - Static variable in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
twoPhaseTest(int, TESTPaxosClient[]) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosClient
 
twoPhaseTest(int, TESTPaxosClient[]) - Static method in class edu.umass.cs.reconfiguration.testing.TESTPaxosClient
 
TxCallback - Class in edu.umass.cs.txn
 
TxCallback(GigaPaxosClient<Request>) - Constructor for class edu.umass.cs.txn.TxCallback
 
TXException - Exception in edu.umass.cs.txn.exceptions
 
TXException(ResponseCode, String) - Constructor for exception edu.umass.cs.txn.exceptions.TXException
 
TXException(ResponseCode, String, Throwable) - Constructor for exception edu.umass.cs.txn.exceptions.TXException
 
TXException(ResponseCode, Throwable) - Constructor for exception edu.umass.cs.txn.exceptions.TXException
 
TXException(TXException) - Constructor for exception edu.umass.cs.txn.exceptions.TXException
 
txid - Variable in class edu.umass.cs.txn.txpackets.TXPacket
 
TXInterface - Interface in edu.umass.cs.txn.interfaces
 
TXLocker - Interface in edu.umass.cs.txn.interfaces
 
TXLockerMap - Class in edu.umass.cs.txn
 
TXLockerMap() - Constructor for class edu.umass.cs.txn.TXLockerMap
 
TxOp - Interface in edu.umass.cs.txn.interfaces
 
TxOpRequest - Class in edu.umass.cs.txn.txpackets
 
TxOpRequest(String, Request) - Constructor for class edu.umass.cs.txn.txpackets.TxOpRequest
 
TxOpRequest(JSONObject, AppRequestParser) - Constructor for class edu.umass.cs.txn.txpackets.TxOpRequest
The parser should be able to convert a serialized request to either an app request or client reconfiguration packet as appropriate.
TXPacket - Class in edu.umass.cs.txn.txpackets
 
TXPacket(IntegerPacketType, String) - Constructor for class edu.umass.cs.txn.txpackets.TXPacket
 
TXPacket(JSONObject) - Constructor for class edu.umass.cs.txn.txpackets.TXPacket
 
TXPacket.PacketType - Enum in edu.umass.cs.txn.txpackets
Transaction packet types.
TXRequest - Interface in edu.umass.cs.txn.interfaces
 
TxStateRequest - Class in edu.umass.cs.txn.txpackets
 
TxStateRequest(String) - Constructor for class edu.umass.cs.txn.txpackets.TxStateRequest
 
TxStateRequest(JSONObject) - Constructor for class edu.umass.cs.txn.txpackets.TxStateRequest
 
TxStateRequest.State - Enum in edu.umass.cs.txn.txpackets
 
txTryFinish(Transaction, String) - Method in class edu.umass.cs.txn.TxCallback
This method is invoked at a participant group to check on the status of the transaction and complete the local abort or commit steps if necessary.
TXUtils - Class in edu.umass.cs.txn
 
TXUtils() - Constructor for class edu.umass.cs.txn.TXUtils
 
type - Variable in class edu.umass.cs.nio.JSONPacket
 
type - Variable in class edu.umass.cs.protocoltask.json.ProtocolPacket
 
types - Static variable in class edu.umass.cs.reconfiguration.http.HttpReconfigurator
types - Static variable in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckDropEpoch
Packet types handled.
types - Static variable in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStartEpoch
Packet types handled.
types - Static variable in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStopEpoch
Packet types handled.
types - Static variable in class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitEpochFinalState
 

U

undigest(RequestPacket) - Method in class edu.umass.cs.gigapaxos.paxospackets.AcceptPacket
 
unlock(String) - Method in class edu.umass.cs.txn.DistTransactor
A blocking call that returns upon successfully release lockID or throws a TXException .
unlock(String[]) - Method in class edu.umass.cs.txn.DistTransactor
Releases the locks in the order specified by lockIDs.
unlock(String) - Method in class edu.umass.cs.txn.TXLockerMap
A blocking call that returns upon successfully release lockID or throws a TXException .
unlock(String[]) - Method in class edu.umass.cs.txn.TXLockerMap
Releases the locks in the order specified by lockIDs.
UnlockRequest - Class in edu.umass.cs.txn.txpackets
 
UnlockRequest(String, String) - Constructor for class edu.umass.cs.txn.txpackets.UnlockRequest
 
UnlockRequest(JSONObject) - Constructor for class edu.umass.cs.txn.txpackets.UnlockRequest
 
unpause(String) - Method in class edu.umass.cs.gigapaxos.AbstractPaxosLogger
 
unpause(String) - Method in class edu.umass.cs.gigapaxos.SQLPaxosLogger
 
unRegister(EventType, ProtocolTask<NodeIDType, EventType, KeyType>) - Method in class edu.umass.cs.protocoltask.ProtocolExecutor
 
unsetNeedsCoordination() - Method in class edu.umass.cs.reconfiguration.reconfigurationpackets.RequestActiveReplicas
 
unstringer - Static variable in class edu.umass.cs.protocoltask.examples.PingPongPacket
 
unstringer - Static variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket
Unstringer needed to handle client InetSocketAddresses as opposed to NodeIDType.
unstringer - Static variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName
Unstringer needed to handle client InetSocketAddresses as opposed to NodeIDType.
unstringer - Static variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.DeleteServiceName
Needed for unstringing InetSocketAddresses.
unstringer - Static variable in class edu.umass.cs.reconfiguration.reconfigurationpackets.RequestActiveReplicas
Unstringer for InetSocketAddress of sender.
updateActiveDBNodeConfig(int) - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
updateCount(String, int) - Static method in class edu.umass.cs.utils.DelayProfiler
 
updateDBNodeConfig(int) - Method in class edu.umass.cs.reconfiguration.AbstractReconfiguratorDB
 
updateDelay(String, double, double) - Static method in class edu.umass.cs.utils.DelayProfiler
 
updateDelay(String, double) - Static method in class edu.umass.cs.utils.DelayProfiler
 
updateDelay(String, long, int) - Static method in class edu.umass.cs.utils.DelayProfiler
 
updateDelayNano(String, double) - Static method in class edu.umass.cs.utils.DelayProfiler
 
updateDelayNano(String, long, int) - Static method in class edu.umass.cs.utils.DelayProfiler
 
updateDemandStats(DemandReport<NodeIDType>) - Method in interface edu.umass.cs.reconfiguration.interfaces.ReconfiguratorDB
Update demand statistics.
updateDemandStats(DemandReport<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.SQLReconfiguratorDB
 
updateHeardFrom(int) - Method in class edu.umass.cs.gigapaxos.paxosutil.WaitforUtility
 
updateHeardFrom(NodeIDType) - Method in class edu.umass.cs.utils.Waitfor
 
updateInterArrivalTime(String, int, int) - Static method in class edu.umass.cs.utils.DelayProfiler
 
updateInterArrivalTime(String, int, int, double) - Static method in class edu.umass.cs.utils.DelayProfiler
 
updateInterArrivalTime(String, int) - Static method in class edu.umass.cs.utils.DelayProfiler
 
updateMovAvg(String, double) - Static method in class edu.umass.cs.utils.DelayProfiler
 
updateMovAvg(String, double, double) - Static method in class edu.umass.cs.utils.DelayProfiler
 
updateRate(String, int, int) - Static method in class edu.umass.cs.utils.DelayProfiler
 
updateRate(String, int) - Static method in class edu.umass.cs.utils.DelayProfiler
 
updateSleepDuration(long) - Static method in class edu.umass.cs.gigapaxos.RequestBatcher
 
updateStats(DemandReport<NodeIDType>) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord
 
updateValue(String, double) - Static method in class edu.umass.cs.utils.DelayProfiler
 
USE_HEX_TIMESTAMP - Static variable in class edu.umass.cs.gigapaxos.SQLPaxosLogger
Used also by reconfiguration.
useJSONSmart() - Static method in class edu.umass.cs.gigapaxos.paxosutil.PaxosMessenger
 
Util - Class in edu.umass.cs.utils
 
Util() - Constructor for class edu.umass.cs.utils.Util
 
UtilServer - Class in edu.umass.cs.utils
Created by kanantharamu on 2/21/17.
UtilServer() - Constructor for class edu.umass.cs.utils.UtilServer
 
UtilTest - Class in edu.umass.cs.utils
 
UtilTest() - Constructor for class edu.umass.cs.utils.UtilTest
 

V

valueOf(String) - Static method in enum edu.umass.cs.gigapaxos.examples.PaxosAppRequest.Keys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.gigapaxos.examples.PaxosAppRequest.PacketType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.gigapaxos.PaxosAcceptor.STATES
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.gigapaxos.PaxosConfig.PC
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.gigapaxos.paxospackets.PaxosPacket.Keys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.gigapaxos.paxospackets.PaxosPacket.NodeIDKeys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.gigapaxos.paxospackets.PaxosPacket.PaxosPacketType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.gigapaxos.paxospackets.RequestPacket.Keys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.gigapaxos.paxospackets.RequestPacket.ResponseCodes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.gigapaxos.paxosutil.LargeCheckpointer.Keys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.gigapaxos.paxosutil.SQL.SQLType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.gigapaxos.testing.TESTPaxosConfig.TC
Returns the enum constant of this type with the specified name.
valueOf(String) - Method in interface edu.umass.cs.nio.interfaces.Stringifiable
Converts a string representation of a node id into the appropriate node id type.
valueOf(String) - Method in class edu.umass.cs.nio.nioutils.SampleNodeConfig
 
valueOf(String) - Method in class edu.umass.cs.nio.nioutils.StringifiableDefault
 
valueOf(String) - Static method in enum edu.umass.cs.nio.SSLDataProcessingWorker.SSL_MODES
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.protocoltask.examples.PingPongPacket.PacketType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.protocoltask.json.ProtocolPacket.Keys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.AbstractReconfiguratorDB.RecordNames
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.examples.AppRequest.Keys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.examples.AppRequest.PacketType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.examples.AppRequest.ResponseCodes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.examples.noop.NoopAppCoordinator.CoordType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.http.HttpReconfigurator.HTTPKeys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.http.HttpReconfigurator.HTTPRequestTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.ReconfigurationConfig.CommandArgs
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.ReconfigurationConfig.RC
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.ReconfigurationConfig.ReconfigureUponActivesChange
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.reconfigurationpackets.BasicReconfigurationPacket.Keys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.reconfigurationpackets.BatchedCreateServiceName.BatchKeys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket.Keys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket.ResponseCodes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName.Keys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.reconfigurationpackets.DefaultAppRequest.Keys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest.RequestTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket.PacketType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.reconfigurationpackets.RequestActiveReplicas.Keys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch.Keys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.reconfigurationutils.AbstractDemandProfile.Keys
Returns the enum constant of this type with the specified name.
valueOf(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.ConsistentNodeConfig
 
valueOf(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.DefaultNodeConfig
 
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.reconfigurationutils.DemandProfile.Keys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord.Keys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord.RCStates
Returns the enum constant of this type with the specified name.
valueOf(String) - Method in class edu.umass.cs.reconfiguration.reconfigurationutils.SimpleReconfiguratorNodeConfig
 
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.Reconfigurator.ProfilerKeys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.reconfiguration.testing.TESTReconfigurationConfig.TRC
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.txn.exceptions.ResponseCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.txn.Transaction.Keys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.txn.txpackets.TXPacket.PacketType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.txn.txpackets.TxStateRequest.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.umass.cs.utils.SessionKeys.Events
Returns the enum constant of this type with the specified name.
values() - Static method in enum edu.umass.cs.gigapaxos.examples.PaxosAppRequest.Keys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.gigapaxos.examples.PaxosAppRequest.PacketType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.gigapaxos.PaxosAcceptor.STATES
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.gigapaxos.PaxosConfig.PC
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.gigapaxos.paxospackets.PaxosPacket.Keys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.gigapaxos.paxospackets.PaxosPacket.NodeIDKeys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.gigapaxos.paxospackets.PaxosPacket.PaxosPacketType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.gigapaxos.paxospackets.RequestPacket.Keys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.gigapaxos.paxospackets.RequestPacket.ResponseCodes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.gigapaxos.paxosutil.LargeCheckpointer.Keys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.gigapaxos.paxosutil.SQL.SQLType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.gigapaxos.testing.TESTPaxosConfig.TC
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.nio.SSLDataProcessingWorker.SSL_MODES
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.protocoltask.examples.PingPongPacket.PacketType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.protocoltask.json.ProtocolPacket.Keys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.AbstractReconfiguratorDB.RecordNames
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.examples.AppRequest.Keys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.examples.AppRequest.PacketType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.examples.AppRequest.ResponseCodes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.examples.noop.NoopAppCoordinator.CoordType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.http.HttpReconfigurator.HTTPKeys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.http.HttpReconfigurator.HTTPRequestTypes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.ReconfigurationConfig.CommandArgs
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.ReconfigurationConfig.RC
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.ReconfigurationConfig.ReconfigureUponActivesChange
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.reconfigurationpackets.BasicReconfigurationPacket.Keys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.reconfigurationpackets.BatchedCreateServiceName.BatchKeys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket.Keys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.reconfigurationpackets.ClientReconfigurationPacket.ResponseCodes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.reconfigurationpackets.CreateServiceName.Keys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.reconfigurationpackets.DefaultAppRequest.Keys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.reconfigurationpackets.RCRecordRequest.RequestTypes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.reconfigurationpackets.ReconfigurationPacket.PacketType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.reconfigurationpackets.RequestActiveReplicas.Keys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.reconfigurationpackets.StartEpoch.Keys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.reconfigurationutils.AbstractDemandProfile.Keys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.reconfigurationutils.DemandProfile.Keys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord.Keys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.reconfigurationutils.ReconfigurationRecord.RCStates
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.Reconfigurator.ProfilerKeys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.reconfiguration.testing.TESTReconfigurationConfig.TRC
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.txn.exceptions.ResponseCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.txn.Transaction.Keys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.txn.txpackets.TXPacket.PacketType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.umass.cs.txn.txpackets.TxStateRequest.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class edu.umass.cs.utils.DiskMap
This method only returns the in-memory value set.
values() - Method in class edu.umass.cs.utils.MultiArrayMap
 
values() - Method in class edu.umass.cs.utils.NullIfEmptyMap
 
values() - Static method in enum edu.umass.cs.utils.SessionKeys.Events
Returns an array containing the constants of this enum type, in the order they are declared.
verify(SessionKeys.SecretKeyCertificate) - Static method in class edu.umass.cs.utils.SessionKeys
 
version - Variable in class edu.umass.cs.gigapaxos.paxospackets.PaxosPacket
 
version - Variable in class edu.umass.cs.gigapaxos.paxosutil.HotRestoreInfo
Paxos group epoch number.
version - Variable in class edu.umass.cs.gigapaxos.paxosutil.LogIndex
 
version - Variable in class edu.umass.cs.gigapaxos.paxosutil.SlotBallotState
 
viaJSONSmart(JSONObject) - Static method in class edu.umass.cs.utils.Util
 

W

WaitAckDropEpoch<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationprotocoltasks
 
WaitAckDropEpoch(StartEpoch<NodeIDType>, Set<NodeIDType>, RepliconfigurableReconfiguratorDB<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckDropEpoch
 
WaitAckDropEpoch(StartEpoch<NodeIDType>, RepliconfigurableReconfiguratorDB<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckDropEpoch
 
WaitAckStartEpoch<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationprotocoltasks
 
WaitAckStartEpoch(StartEpoch<NodeIDType>, RepliconfigurableReconfiguratorDB<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStartEpoch
 
WaitAckStopEpoch<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationprotocoltasks
 
WaitAckStopEpoch(StartEpoch<NodeIDType>, RepliconfigurableReconfiguratorDB<NodeIDType>, Object) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStopEpoch
 
WaitAckStopEpoch(StartEpoch<NodeIDType>, RepliconfigurableReconfiguratorDB<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitAckStopEpoch
 
waitCanCreateOrExistsOrHigher(String, int) - Method in class edu.umass.cs.gigapaxos.PaxosManager
 
WaitEpochFinalState<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationprotocoltasks
 
WaitEpochFinalState(NodeIDType, StartEpoch<NodeIDType>, AbstractReplicaCoordinator<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitEpochFinalState
 
waitfor - Variable in class edu.umass.cs.protocoltask.ThresholdProtocolTask
 
Waitfor<NodeIDType> - Class in edu.umass.cs.utils
 
Waitfor(NodeIDType[]) - Constructor for class edu.umass.cs.utils.Waitfor
 
Waitfor(Set<NodeIDType>) - Constructor for class edu.umass.cs.utils.Waitfor
 
waitForNotEmptyOrStopped() - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerTask
 
waitForResponses(TESTPaxosClient[], long, int) - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosClient
 
waitForResponses(TESTPaxosClient[], long, int) - Static method in class edu.umass.cs.reconfiguration.testing.TESTPaxosClient
 
WaitforUtility - Class in edu.umass.cs.gigapaxos.paxosutil
 
WaitforUtility(int[]) - Constructor for class edu.umass.cs.gigapaxos.paxosutil.WaitforUtility
 
waitingTooLong(PaxosCoordinator) - Static method in class edu.umass.cs.gigapaxos.PaxosCoordinator
 
waitOutstanding(int) - Method in class edu.umass.cs.reconfiguration.RepliconfigurableReconfiguratorDB
 
WaitPrimaryExecution<NodeIDType> - Class in edu.umass.cs.reconfiguration.reconfigurationprotocoltasks
 
WaitPrimaryExecution(NodeIDType, StartEpoch<NodeIDType>, RepliconfigurableReconfiguratorDB<NodeIDType>, Set<NodeIDType>) - Constructor for class edu.umass.cs.reconfiguration.reconfigurationprotocoltasks.WaitPrimaryExecution
 
waitTime() - Method in class edu.umass.cs.gigapaxos.paxosutil.WaitforUtility
 
waitToFinish() - Method in class edu.umass.cs.gigapaxos.deprecated.DefaultPaxosInterfaceApp
 
waitToFinish() - Method in class edu.umass.cs.gigapaxos.paxosutil.ConsumerTask
 
waitToFinish() - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosApp
 
waitToFinish(String, int) - Method in class edu.umass.cs.gigapaxos.testing.TESTPaxosApp
 
waitToFinishAll() - Static method in class edu.umass.cs.gigapaxos.PaxosManager
 
waitUntilRunDone() - Static method in class edu.umass.cs.gigapaxos.testing.TESTPaxosClient
 
waitUntilRunDone() - Static method in class edu.umass.cs.reconfiguration.testing.TESTPaxosClient
 
warning(Object...) - Method in class edu.umass.cs.utils.MyLogger
 
watcher - Variable in class edu.umass.cs.utils.DefaultTest
 
wipeoutFile(String) - Static method in class edu.umass.cs.utils.Util
 
wipeoutServers() - Static method in class edu.umass.cs.reconfiguration.testing.TESTReconfigurationMain
 
worker - Variable in class edu.umass.cs.nio.NIOTransport
 
wrap(Replicable, LargeCheckpointer) - Static method in class edu.umass.cs.gigapaxos.paxosutil.LargeCheckpointer
 
wrap(SocketChannel, ByteBuffer) - Method in class edu.umass.cs.nio.IOSSSLDataProcessingWorker
 
wrap(SocketChannel, ByteBuffer) - Method in class edu.umass.cs.nio.SSLDataProcessingWorker
 
wrap(Request) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
 
wrap(Request, long) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
 
wrap(Request, boolean) - Static method in class edu.umass.cs.reconfiguration.reconfigurationpackets.ReplicableClientRequest
 
wrapCoordinator(AbstractReplicaCoordinator<?>) - Static method in class edu.umass.cs.reconfiguration.ActiveReplica
 
WRITE_BUFFER_SIZE - Static variable in class edu.umass.cs.nio.NIOTransport
 
writeProperty(String, String, String, String) - Static method in class edu.umass.cs.utils.UtilServer
 
A B C D E F G H I J K L M N O P R S T U V W 
Skip navigation links