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

A

ACCEPT_READY - Static variable in interface seda.nbio.Selectable
Event mask specifying that a new incoming connection is pending.
AFile - class seda.sandStorm.lib.aDisk.AFile.
This class represents an asynchronous file I/O interface.
AFile(String, SinkIF, boolean, boolean) - Constructor for class seda.sandStorm.lib.aDisk.AFile
Open the file with the given pathname.
AFileCloseRequest - class seda.sandStorm.lib.aDisk.AFileCloseRequest.
A request to close the given file.
AFileCloseRequest(AFile, SinkIF) - Constructor for class seda.sandStorm.lib.aDisk.AFileCloseRequest
 
AFileCloseRequest(SinkIF) - Constructor for class seda.sandStorm.lib.aDisk.AFileCloseRequest
 
AFileCompletion - class seda.sandStorm.lib.aDisk.AFileCompletion.
Abstract base class of AFile I/O completion events.
AFileCompletion(AFileRequest) - Constructor for class seda.sandStorm.lib.aDisk.AFileCompletion
 
AFileEOFReached - class seda.sandStorm.lib.aDisk.AFileEOFReached.
A completion event indicating that EOF was reached on the given file during an attempted I/O operation.
AFileEOFReached(AFileRequest) - Constructor for class seda.sandStorm.lib.aDisk.AFileEOFReached
 
AFileFlushRequest - class seda.sandStorm.lib.aDisk.AFileFlushRequest.
A request to flush all pending I/O events on the given file.
AFileFlushRequest(AFile, SinkIF) - Constructor for class seda.sandStorm.lib.aDisk.AFileFlushRequest
 
AFileFlushRequest(SinkIF) - Constructor for class seda.sandStorm.lib.aDisk.AFileFlushRequest
 
AFileIOCompleted - class seda.sandStorm.lib.aDisk.AFileIOCompleted.
Completion event indicating that a previous I/O request on the file completed.
AFileIOCompleted(AFileRequest, int) - Constructor for class seda.sandStorm.lib.aDisk.AFileIOCompleted
 
AFileIOExceptionOccurred - class seda.sandStorm.lib.aDisk.AFileIOExceptionOccurred.
A completion event indicating that an IOException occurred during the corresponding I/O request.
AFileIOExceptionOccurred(AFileRequest, IOException) - Constructor for class seda.sandStorm.lib.aDisk.AFileIOExceptionOccurred
 
AFileImpl - class seda.sandStorm.lib.aDisk.AFileImpl.
Package-access only abstract class representing an implementation of the AFile interface.
AFileImpl() - Constructor for class seda.sandStorm.lib.aDisk.AFileImpl
 
AFileMgr - class seda.sandStorm.lib.aDisk.AFileMgr.
The AFileMgr is an internal class used to provide an interface between the Sandstorm runtime and the aDisk library.
AFileMgr() - Constructor for class seda.sandStorm.lib.aDisk.AFileMgr
 
AFileReadRequest - class seda.sandStorm.lib.aDisk.AFileReadRequest.
A request to read data from a file.
AFileReadRequest(BufferElement, SinkIF) - Constructor for class seda.sandStorm.lib.aDisk.AFileReadRequest
Create a read request to fill in the given BufferElement.
AFileRequest - class seda.sandStorm.lib.aDisk.AFileRequest.
Abstract base class of I/O requests which can be posted to the AFile enqueue() methods.
AFileRequest(SinkIF) - Constructor for class seda.sandStorm.lib.aDisk.AFileRequest
 
AFileRequest(AFile, SinkIF) - Constructor for class seda.sandStorm.lib.aDisk.AFileRequest
 
AFileSeekRequest - class seda.sandStorm.lib.aDisk.AFileSeekRequest.
A request to seek to the given offset of the given file.
AFileSeekRequest(int, SinkIF) - Constructor for class seda.sandStorm.lib.aDisk.AFileSeekRequest
Seek to the given offset.
AFileStat - class seda.sandStorm.lib.aDisk.AFileStat.
This class provides information about a file.
AFileStat() - Constructor for class seda.sandStorm.lib.aDisk.AFileStat
 
AFileTM - class seda.sandStorm.lib.aDisk.AFileTM.
Internal abstract class used to represent an AFile thread manager.
AFileTM() - Constructor for class seda.sandStorm.lib.aDisk.AFileTM
 
AFileTPEventHandler - class seda.sandStorm.lib.aDisk.AFileTPEventHandler.
The event handler used by the AFileTPImpl stage.
AFileTPEventHandler() - Constructor for class seda.sandStorm.lib.aDisk.AFileTPEventHandler
 
AFileTPImpl - class seda.sandStorm.lib.aDisk.AFileTPImpl.
This is an implementation of AFile which uses a pool of threads which perform blocking I/O (through the java.io.RandomAccessFile class) on files.
AFileTPImpl(AFile, String, SinkIF, boolean, boolean, AFileTPTM) - Constructor for class seda.sandStorm.lib.aDisk.AFileTPImpl
Create an AFileTPIMpl with the given AFile, filename, completion queue, create/readOnly flags, and Thread Manager.
AFileTPStageWrapper - class seda.sandStorm.lib.aDisk.AFileTPStageWrapper.
Internal stage wrapper implementation for AFileTPImpl.
AFileTPStageWrapper(String, EventHandlerIF, ConfigDataIF, ThreadManagerIF) - Constructor for class seda.sandStorm.lib.aDisk.AFileTPStageWrapper
 
AFileTPTM - class seda.sandStorm.lib.aDisk.AFileTPTM.
This is the ThreadManager implementation for AFileTPImpl.
AFileTPTM(ManagerIF, SystemManagerIF) - Constructor for class seda.sandStorm.lib.aDisk.AFileTPTM
 
AFileTPTM.AFileTPThread - class seda.sandStorm.lib.aDisk.AFileTPTM.AFileTPThread.
Internal class representing a single AFileTPTM-managed thread.
AFileTPTM.AFileTPThread(AFileTPStageWrapper) - Constructor for class seda.sandStorm.lib.aDisk.AFileTPTM.AFileTPThread
 
AFileTPTM.fileQueueEntry - class seda.sandStorm.lib.aDisk.AFileTPTM.fileQueueEntry.
 
AFileTPTM.fileQueueEntry(AFileTPImpl) - Constructor for class seda.sandStorm.lib.aDisk.AFileTPTM.fileQueueEntry
 
AFileWriteRequest - class seda.sandStorm.lib.aDisk.AFileWriteRequest.
A request to write to a file.
AFileWriteRequest(BufferElement, SinkIF) - Constructor for class seda.sandStorm.lib.aDisk.AFileWriteRequest
Create a write request using the given buffer and completion queue.
ATcpClientSocket - class seda.sandStorm.lib.aSocket.ATcpClientSocket.
An ATcpClientSocket implements an asynchronous outgoing socket connection.
ATcpClientSocket(InetAddress, int, SinkIF) - Constructor for class seda.sandStorm.lib.aSocket.ATcpClientSocket
Create a socket connecting to the given address and port.
ATcpClientSocket(String, int, SinkIF) - Constructor for class seda.sandStorm.lib.aSocket.ATcpClientSocket
Create a socket connecting to the given host and port.
ATcpClientSocket(InetAddress, int, SinkIF, int, int) - Constructor for class seda.sandStorm.lib.aSocket.ATcpClientSocket
Create a socket connecting to the given address and port with the given writeClogThreshold value.
ATcpClientSocket(String, int, SinkIF, int, int) - Constructor for class seda.sandStorm.lib.aSocket.ATcpClientSocket
Create a socket connecting to the given host and port with the given writeClogThreshold value.
ATcpClientSocket() - Constructor for class seda.sandStorm.lib.aSocket.ATcpClientSocket
 
ATcpCloseRequest - class seda.sandStorm.lib.aSocket.ATcpCloseRequest.
Request to close a connection.
ATcpCloseRequest(ATcpConnection, SinkIF) - Constructor for class seda.sandStorm.lib.aSocket.ATcpCloseRequest
 
ATcpCloseServerRequest - class seda.sandStorm.lib.aSocket.ATcpCloseServerRequest.
Request to close a server socket.
ATcpCloseServerRequest(ATcpServerSocket) - Constructor for class seda.sandStorm.lib.aSocket.ATcpCloseServerRequest
 
ATcpConnectFailedEvent - class seda.sandStorm.lib.aSocket.ATcpConnectFailedEvent.
ATcpConnectFailedEvent objects will be passed to the SinkIF associated with an ATcpClientSocket when a connection attempt fails.
ATcpConnectFailedEvent(ATcpClientSocket, String) - Constructor for class seda.sandStorm.lib.aSocket.ATcpConnectFailedEvent
 
ATcpConnectRequest - class seda.sandStorm.lib.aSocket.ATcpConnectRequest.
Request to establish a connection.
ATcpConnectRequest(ATcpClientSocket, InetAddress, int, SinkIF, int, int) - Constructor for class seda.sandStorm.lib.aSocket.ATcpConnectRequest
 
ATcpConnection - class seda.sandStorm.lib.aSocket.ATcpConnection.
An ATcpConnection represents an established connection on an asynchronous socket.
ATcpConnection(ATcpClientSocket, InetAddress, int) - Constructor for class seda.sandStorm.lib.aSocket.ATcpConnection
 
ATcpConnection(ATcpServerSocket, InetAddress, int) - Constructor for class seda.sandStorm.lib.aSocket.ATcpConnection
 
ATcpConnection() - Constructor for class seda.sandStorm.lib.aSocket.ATcpConnection
 
ATcpFlushRequest - class seda.sandStorm.lib.aSocket.ATcpFlushRequest.
Request to flush a connection.
ATcpFlushRequest(ATcpConnection, SinkIF) - Constructor for class seda.sandStorm.lib.aSocket.ATcpFlushRequest
 
ATcpInPacket - class seda.sandStorm.lib.aSocket.ATcpInPacket.
An ATcpInPacket represents a packet which was received from an asynchronous socket.
ATcpInPacket(ATcpConnection, BufferElement) - Constructor for class seda.sandStorm.lib.aSocket.ATcpInPacket
 
ATcpInPacket(ATcpConnection, BufferElement, long) - Constructor for class seda.sandStorm.lib.aSocket.ATcpInPacket
 
ATcpInPacket(ATcpConnection, byte[], int) - Constructor for class seda.sandStorm.lib.aSocket.ATcpInPacket
 
ATcpInPacket(ATcpConnection, byte[], int, long) - Constructor for class seda.sandStorm.lib.aSocket.ATcpInPacket
 
ATcpInPacket(ATcpConnection, byte[], int, boolean) - Constructor for class seda.sandStorm.lib.aSocket.ATcpInPacket
 
ATcpInPacket(ATcpConnection, byte[], int, boolean, long) - Constructor for class seda.sandStorm.lib.aSocket.ATcpInPacket
 
ATcpListenFailedEvent - class seda.sandStorm.lib.aSocket.ATcpListenFailedEvent.
ATcpListenFailedEvent objects will be passed to the SinkIF associated with an ATcpServerSocket when an attempt to create that server socket fails.
ATcpListenFailedEvent(ATcpServerSocket, String) - Constructor for class seda.sandStorm.lib.aSocket.ATcpListenFailedEvent
 
ATcpListenRequest - class seda.sandStorm.lib.aSocket.ATcpListenRequest.
Request to listen on a TCP port.
ATcpListenRequest(ATcpServerSocket, int, SinkIF, int) - Constructor for class seda.sandStorm.lib.aSocket.ATcpListenRequest
 
ATcpListenSuccessEvent - class seda.sandStorm.lib.aSocket.ATcpListenSuccessEvent.
ATcpListenSuccessEvent objects will be passed to the SinkIF associated with an ATcpServerSocket when the socket successfully listens on the requested port.
ATcpListenSuccessEvent(ATcpServerSocket) - Constructor for class seda.sandStorm.lib.aSocket.ATcpListenSuccessEvent
 
ATcpResumeAcceptRequest - class seda.sandStorm.lib.aSocket.ATcpResumeAcceptRequest.
Request to resume accepting new connections on a server socket.
ATcpResumeAcceptRequest(ATcpServerSocket) - Constructor for class seda.sandStorm.lib.aSocket.ATcpResumeAcceptRequest
 
ATcpServerSocket - class seda.sandStorm.lib.aSocket.ATcpServerSocket.
This class represents an asynchronous server socket.
ATcpServerSocket(int, SinkIF) - Constructor for class seda.sandStorm.lib.aSocket.ATcpServerSocket
Open a server socket listening on the given port.
ATcpServerSocket(int, SinkIF, int) - Constructor for class seda.sandStorm.lib.aSocket.ATcpServerSocket
Open a server socket listening on the given port.
ATcpServerSocket() - Constructor for class seda.sandStorm.lib.aSocket.ATcpServerSocket
 
ATcpServerSocketClosedEvent - class seda.sandStorm.lib.aSocket.ATcpServerSocketClosedEvent.
ATcpServerSocketClosedEvent objects will be passed up to the SinkIF associated with an ATcpServerSocket when a server socket dies.
ATcpServerSocketClosedEvent() - Constructor for class seda.sandStorm.lib.aSocket.ATcpServerSocketClosedEvent
 
ATcpServerSocketClosedEvent(ATcpServerSocket) - Constructor for class seda.sandStorm.lib.aSocket.ATcpServerSocketClosedEvent
 
ATcpStartReadRequest - class seda.sandStorm.lib.aSocket.ATcpStartReadRequest.
Request to initiate read events on a connection.
ATcpStartReadRequest(ATcpConnection, SinkIF, int) - Constructor for class seda.sandStorm.lib.aSocket.ATcpStartReadRequest
 
ATcpSuspendAcceptRequest - class seda.sandStorm.lib.aSocket.ATcpSuspendAcceptRequest.
Request to suspend accepting new connections on a server socket.
ATcpSuspendAcceptRequest(ATcpServerSocket) - Constructor for class seda.sandStorm.lib.aSocket.ATcpSuspendAcceptRequest
 
ATcpWriteRequest - class seda.sandStorm.lib.aSocket.ATcpWriteRequest.
Request to write data to a connection.
ATcpWriteRequest(ATcpConnection, BufferElement) - Constructor for class seda.sandStorm.lib.aSocket.ATcpWriteRequest
 
AUdpCloseRequest - class seda.sandStorm.lib.aSocket.AUdpCloseRequest.
Request to close a UDP socket.
AUdpCloseRequest(AUdpSocket, SinkIF) - Constructor for class seda.sandStorm.lib.aSocket.AUdpCloseRequest
 
AUdpConnectEvent - class seda.sandStorm.lib.aSocket.AUdpConnectEvent.
AUdpConnectEvent objects will be passed to the SinkIF associated with an AUdpSocket when the socket successfully connects.
AUdpConnectEvent(AUdpSocket) - Constructor for class seda.sandStorm.lib.aSocket.AUdpConnectEvent
 
AUdpConnectRequest - class seda.sandStorm.lib.aSocket.AUdpConnectRequest.
Request to connect a UDP socket.
AUdpConnectRequest(AUdpSocket, InetAddress, int) - Constructor for class seda.sandStorm.lib.aSocket.AUdpConnectRequest
 
AUdpDisconnectEvent - class seda.sandStorm.lib.aSocket.AUdpDisconnectEvent.
AUdpDisconnectEvent objects will be passed to the SinkIF associated with an AUdpSocket when the socket successfully disconnects.
AUdpDisconnectEvent(AUdpSocket) - Constructor for class seda.sandStorm.lib.aSocket.AUdpDisconnectEvent
 
AUdpDisconnectRequest - class seda.sandStorm.lib.aSocket.AUdpDisconnectRequest.
Request to disconnect a UDP socket.
AUdpDisconnectRequest(AUdpSocket) - Constructor for class seda.sandStorm.lib.aSocket.AUdpDisconnectRequest
 
AUdpFlushRequest - class seda.sandStorm.lib.aSocket.AUdpFlushRequest.
Request to flush a connection.
AUdpFlushRequest(AUdpSocket, SinkIF) - Constructor for class seda.sandStorm.lib.aSocket.AUdpFlushRequest
 
AUdpInPacket - class seda.sandStorm.lib.aSocket.AUdpInPacket.
An AUdpInPacket represents a packet which was received from a datagram socket.
AUdpInPacket(AUdpSocket, DatagramPacket) - Constructor for class seda.sandStorm.lib.aSocket.AUdpInPacket
 
AUdpInPacket(AUdpSocket, DatagramPacket, long) - Constructor for class seda.sandStorm.lib.aSocket.AUdpInPacket
 
AUdpPacket - class seda.sandStorm.lib.aSocket.AUdpPacket.
An AUdpPacket is an extension to BufferElement that supports specifying the destination address and port for a given packet.
AUdpPacket(byte[]) - Constructor for class seda.sandStorm.lib.aSocket.AUdpPacket
Create an AUdpPacket with the given data, an offset of 0, and a size of data.length.
AUdpPacket(byte[], SinkIF) - Constructor for class seda.sandStorm.lib.aSocket.AUdpPacket
Create an AUdpPacket with the given data, an offset of 0, and a size of data.length, with the given completion queue.
AUdpPacket(byte[], int, int) - Constructor for class seda.sandStorm.lib.aSocket.AUdpPacket
Create an AUdpPacket with the given data, offset, and size.
AUdpPacket(byte[], int, int, SinkIF) - Constructor for class seda.sandStorm.lib.aSocket.AUdpPacket
Create an AUdpPacket with the given data, offset, size, and completion queue.
AUdpPacket(byte[], int, int, SinkIF, InetAddress, int) - Constructor for class seda.sandStorm.lib.aSocket.AUdpPacket
Create an AUdpPacket with the given data, offset, size, completion queue, destination address, and port.
AUdpPacket(int) - Constructor for class seda.sandStorm.lib.aSocket.AUdpPacket
Create an AUdpPacket with a new data array of the given size.
AUdpSocket - class seda.sandStorm.lib.aSocket.AUdpSocket.
An AUdpSocket implements an asynchronous datagram socket.
AUdpSocket(SinkIF) - Constructor for class seda.sandStorm.lib.aSocket.AUdpSocket
Create a socket bound to any available local port.
AUdpSocket(int, SinkIF) - Constructor for class seda.sandStorm.lib.aSocket.AUdpSocket
Create a socket bound to the given local port.
AUdpSocket(InetAddress, int, SinkIF, int, int) - Constructor for class seda.sandStorm.lib.aSocket.AUdpSocket
Create a socket bound to the given local address and local port.
AUdpStartReadRequest - class seda.sandStorm.lib.aSocket.AUdpStartReadRequest.
Request to initiate read events on a UDP socket.
AUdpStartReadRequest(AUdpSocket, SinkIF, int) - Constructor for class seda.sandStorm.lib.aSocket.AUdpStartReadRequest
 
AUdpWriteRequest - class seda.sandStorm.lib.aSocket.AUdpWriteRequest.
Request to write data to a connection.
AUdpWriteRequest(AUdpSocket, BufferElement) - Constructor for class seda.sandStorm.lib.aSocket.AUdpWriteRequest
 
AggTPSThreadManager - class seda.sandStorm.internal.AggTPSThreadManager.
AggTPSThreadManager is a refinement of the TPSTM; it attempts to schedule stages to improve aggregation.
AggTPSThreadManager(SandstormConfig) - Constructor for class seda.sandStorm.internal.AggTPSThreadManager
 
AggTPSThreadManager.appThread - class seda.sandStorm.internal.AggTPSThreadManager.appThread.
Internal class representing a single AggTPSTM-managed thread.
AggTPSThreadManager.appThread(StageWrapperIF, SourceIF, String, AggTPSThreadManager.threadPool) - Constructor for class seda.sandStorm.internal.AggTPSThreadManager.appThread
 
AggTPSThreadManager.governorThread - class seda.sandStorm.internal.AggTPSThreadManager.governorThread.
Internal class implementing a thread governor - analyses appThread queue lengths and adjusts thread pool sizes accordingly.
AggTPSThreadManager.governorThread() - Constructor for class seda.sandStorm.internal.AggTPSThreadManager.governorThread
 
AggTPSThreadManager.stageInfo - class seda.sandStorm.internal.AggTPSThreadManager.stageInfo.
Internal class representing state for a given stage.
AggTPSThreadManager.stageInfo(StageWrapperIF) - Constructor for class seda.sandStorm.internal.AggTPSThreadManager.stageInfo
 
AggTPSThreadManager.threadPool - class seda.sandStorm.internal.AggTPSThreadManager.threadPool.
 
AggTPSThreadManager.threadPool(StageWrapperIF, SourceIF) - Constructor for class seda.sandStorm.internal.AggTPSThreadManager.threadPool
 
AggThrottle - class seda.sandStorm.internal.AggThrottle.
AggThrottle is used by thread managers to adjust their aggregation level based on observations of stage throughput.
AggThrottle(StageWrapperIF, ManagerIF) - Constructor for class seda.sandStorm.internal.AggThrottle
 
aSocketConst - interface seda.sandStorm.lib.aSocket.aSocketConst.
Internal constants used by the aSocket implementation.
aSocketErrorEvent - class seda.sandStorm.lib.aSocket.aSocketErrorEvent.
This is the base class for all error events passed up by the aSocket library.
aSocketErrorEvent(String) - Constructor for class seda.sandStorm.lib.aSocket.aSocketErrorEvent
 
aSocketEventHandler - class seda.sandStorm.lib.aSocket.aSocketEventHandler.
Abstract superclass of the event handlers used by aSocket.
aSocketEventHandler() - Constructor for class seda.sandStorm.lib.aSocket.aSocketEventHandler
 
aSocketImplFactory - class seda.sandStorm.lib.aSocket.aSocketImplFactory.
aSocketImplFactory is an internal abstract class used to represent the interface between the aSocket library and a provider implementation.
aSocketImplFactory() - Constructor for class seda.sandStorm.lib.aSocket.aSocketImplFactory
 
aSocketInputStream - class seda.sandStorm.lib.aSocket.aSocketInputStream.
This is a utility class that allows you to push multiple ATcpInPackets in, and read bytes out as a stream.
aSocketInputStream() - Constructor for class seda.sandStorm.lib.aSocket.aSocketInputStream
Create an aSocketInputStream with an initial sequence number of 1.
aSocketInputStream(long) - Constructor for class seda.sandStorm.lib.aSocket.aSocketInputStream
Create an aSocketInputStream using the given initial sequence number.
aSocketInputStream.seqNumComparator - class seda.sandStorm.lib.aSocket.aSocketInputStream.seqNumComparator.
 
aSocketInputStream.seqNumComparator() - Constructor for class seda.sandStorm.lib.aSocket.aSocketInputStream.seqNumComparator
 
aSocketMgr - class seda.sandStorm.lib.aSocket.aSocketMgr.
The aSocketMgr is an internal class used to provide an interface between the Sandstorm runtime and the aSocket library.
aSocketMgr() - Constructor for class seda.sandStorm.lib.aSocket.aSocketMgr
 
aSocketRCTMSleep - class seda.sandStorm.lib.aSocket.aSocketRCTMSleep.
aSocketRCTMSleep is a version of aSocketThreadManager that incorporates a rate controller: given a target packet-processing rate, it adjusts its schedule to attempt to match that rate.
aSocketRCTMSleep(ManagerIF) - Constructor for class seda.sandStorm.lib.aSocket.aSocketRCTMSleep
 
aSocketRCTMSleep.aSocketRCThread - class seda.sandStorm.lib.aSocket.aSocketRCTMSleep.aSocketRCThread.
Internal class representing a single aSocketTM-managed thread.
aSocketRCTMSleep.aSocketRCThread(aSocketStageWrapper) - Constructor for class seda.sandStorm.lib.aSocket.aSocketRCTMSleep.aSocketRCThread
 
aSocketRequest - class seda.sandStorm.lib.aSocket.aSocketRequest.
This is the superclass for the various requests that can be issued to the aSocketMgr.
aSocketRequest() - Constructor for class seda.sandStorm.lib.aSocket.aSocketRequest
 
aSocketStageWrapper - class seda.sandStorm.lib.aSocket.aSocketStageWrapper.
Internal stage wrapper implementation for aSocket.
aSocketStageWrapper(String, EventHandlerIF, ConfigDataIF, ThreadManagerIF) - Constructor for class seda.sandStorm.lib.aSocket.aSocketStageWrapper
 
aSocketThreadManager - class seda.sandStorm.lib.aSocket.aSocketThreadManager.
aSocketThreadManager provides a thread manager for the aSocket layer: one thread for each of the read, write, and listen stages.
aSocketThreadManager(ManagerIF) - Constructor for class seda.sandStorm.lib.aSocket.aSocketThreadManager
 
aSocketThreadManager.aSocketThread - class seda.sandStorm.lib.aSocket.aSocketThreadManager.aSocketThread.
Internal class representing a single aSocketTM-managed thread.
aSocketThreadManager.aSocketThread(aSocketStageWrapper) - Constructor for class seda.sandStorm.lib.aSocket.aSocketThreadManager.aSocketThread
 
accept() - Method in class seda.nbio.NonblockingServerSocket
Accept a connection on this server socket.
accept(NonblockingSocketImpl) - Method in class seda.nbio.NonblockingSocketImpl
 
accept(QueueElementIF) - Method in interface seda.sandStorm.api.EnqueuePredicateIF
Tests the given element for acceptance onto the queue.
accept(QueueElementIF) - Method in class seda.sandStorm.core.MulticlassRateLimitingPredicate
Returns true if the given element can be accepted into the queue.
accept(QueueElementIF) - Method in class seda.sandStorm.core.QueueThresholdPredicate
Returns true if the given element can be accepted into the queue.
accept(QueueElementIF) - Method in class seda.sandStorm.core.RateLimitingPredicate
Returns true if the given element can be accepted into the queue.
accept() - Method in class seda.sandStorm.lib.aSocket.ListenSockState
 
accept() - Method in class seda.sandStorm.lib.aSocket.nbio.ListenSockState
 
accept() - Method in class seda.sandStorm.lib.aSocket.nio.ListenSockState
 
add(long) - Method in class StatsGatherer
 
add(SelectItem) - Method in class seda.nbio.SelectSet
Add a SelectItem to this SelectSet.
add(SelectItem[]) - Method in class seda.nbio.SelectSet
Add all of the SelectItems in the given array to the SelectSet.
add(SelectItem) - Method in class seda.nbio.SelectSetDevPollImpl
Add a SelectItem to this SelectSetDevPollImpl.
add(SelectItem[]) - Method in class seda.nbio.SelectSetDevPollImpl
Add all of the SelectItems in the given array to the SelectSetDevPollImpl.
add(SelectItem) - Method in class seda.nbio.SelectSetImpl
 
add(SelectItem[]) - Method in class seda.nbio.SelectSetImpl
 
add(SelectItem) - Method in class seda.nbio.SelectSetPollImpl
Add a SelectItem to this SelectSetPollImpl.
add(SelectItem[]) - Method in class seda.nbio.SelectSetPollImpl
Add all of the SelectItems in the given array to the SelectSetPollImpl.
add(String, ProfilableIF) - Method in interface seda.sandStorm.api.ProfilerIF
Add a class to the profile.
add(StageGraphEdge) - Method in class seda.sandStorm.internal.StageGraph.stageList
 
add(String, ProfilableIF) - Method in class seda.sandStorm.internal.sandStormProfiler
Add a class to this profiler.
add(double) - Method in class seda.util.StatsGatherer
 
addArray(byte[]) - Method in class seda.sandStorm.lib.util.MultiByteArrayInputStream
Add an array to this MultiByteArrayInputStream.
addEdge(StageGraphEdge) - Method in class seda.sandStorm.internal.StageGraph
 
addMeasurement(long) - Method in class seda.sandStorm.internal.ResponseTimeControllerMulticlass.cinfo
 
addPacket(ATcpInPacket) - Method in class seda.sandStorm.lib.aSocket.aSocketInputStream
Add a packet to this aSocketInputStream.
addStage(StageWrapperIF) - Method in class seda.sandStorm.internal.StageGraph
 
addStage(String, String, String[]) - Method in class seda.sandStorm.main.SandstormConfig
Add a stage to this SandstormConfig.
addSubsection(SandstormConfig.configSection) - Method in class seda.sandStorm.main.SandstormConfig.configSection
 
addThread(Thread, StageWrapperIF) - Method in class seda.sandStorm.internal.StageGraph
 
addThreadManager(String, ThreadManagerIF) - Method in interface seda.sandStorm.api.internal.SystemManagerIF
Add a thread manager to the system.
addThreadManager(String, ThreadManagerIF) - Method in class seda.sandStorm.internal.sandStormMgr
Add a thread manager with the given name.
addThreads(int, boolean) - Method in class seda.sandStorm.internal.AggTPSThreadManager.threadPool
 
addThreads(int, boolean) - Method in class seda.sandStorm.internal.ThreadPool
Add threads to this pool.
addWriteRequest(aSocketRequest, SourceIF) - Method in class seda.sandStorm.lib.aSocket.DatagramSockState
 
addWriteRequest(aSocketRequest, SelectSourceIF) - Method in class seda.sandStorm.lib.aSocket.SockState
 
addWriteRequest(aSocketRequest, SourceIF) - Method in class seda.sandStorm.lib.aSocket.nbio.DatagramSockState
 
addWriteRequest(aSocketRequest, SelectSourceIF) - Method in class seda.sandStorm.lib.aSocket.nbio.SockState
 
addWriteRequest(aSocketRequest, SourceIF) - Method in class seda.sandStorm.lib.aSocket.nio.DatagramSockState
 
addWriteRequest(aSocketRequest, SelectSourceIF) - Method in class seda.sandStorm.lib.aSocket.nio.SockState
 
add_to_head(Object) - Method in class seda.sandStorm.core.ssLinkedList
Adds an object to the head (start) of the linked list.
add_to_tail(Object) - Method in class seda.sandStorm.core.ssLinkedList
Adds an object to the tail (end) of the linked list.
addr - Variable in class seda.sandStorm.lib.aSocket.ATcpConnectRequest
 
addr - Variable in class seda.sandStorm.lib.aSocket.AUdpConnectRequest
 
address - Variable in class seda.sandStorm.lib.Gnutella.GnutellaConnectFailedEvent
 
address - Variable in class seda.sandStorm.lib.Gnutella.GnutellaQueryHitsPacket
 
address - Variable in class seda.sandStorm.lib.aSocket.AUdpPacket
 
adjtime - Variable in class seda.sandStorm.internal.ResponseTimeControllerMulticlass.cinfo
 
adjust - Variable in class seda.sandStorm.internal.ResponseTimeControllerMulticlass.cinfo
 
adjust(long) - Method in class seda.sandStorm.internal.ResponseTimeControllerMulticlass.cinfo
 
adjustThreshold(QueueElementIF[], long) - Method in interface seda.sandStorm.api.internal.ResponseTimeControllerIF
Invoked by the stage's thread manager to adjust admission control parameters.
adjustThreshold(QueueElementIF[], long) - Method in class seda.sandStorm.internal.ResponseTimeController
 
adjustThreshold(QueueElementIF[], long) - Method in class seda.sandStorm.internal.ResponseTimeControllerDirect
 
adjustThreshold(QueueElementIF[], long, long, boolean, int) - Method in class seda.sandStorm.internal.ResponseTimeControllerMM1
 
adjustThreshold(QueueElementIF[], long) - Method in class seda.sandStorm.internal.ResponseTimeControllerMM1
 
adjustThreshold(QueueElementIF[], long) - Method in class seda.sandStorm.internal.ResponseTimeControllerMulticlass
 
adjustThreshold(QueueElementIF[], long) - Method in class seda.sandStorm.internal.ResponseTimeControllerPID
 
adjust_count - Variable in class seda.sandStorm.internal.ThreadPoolController.controllerThread
 
afile - Variable in class seda.sandStorm.lib.aDisk.AFileRequest
 
afile - Variable in class seda.sandStorm.lib.aDisk.AFileStat
The AFile corresponding to this AFileStat.
aggTarget - Variable in class seda.sandStorm.internal.TPSThreadManager.stageRunnable
 
arrivals - Variable in class ClientStage
 
available() - Method in class seda.nbio.NonblockingInputStream
 
available() - Method in class seda.nbio.NonblockingSocketImpl
 
available() - Method in class seda.nbio.NonblockingSocketInputStream
 
available() - Method in class seda.sandStorm.lib.util.MultiByteArrayInputStream
Return the number of bytes available for reading.
avgThreads - Variable in class seda.sandStorm.internal.ThreadPoolController.tpcClient
 
avgThroughput - Variable in class seda.sandStorm.internal.ThreadPoolController.tpcClient
 

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