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

A

a - Variable in class versus.meeting.RLearner
 
AbstractAttributeRecord - class solar.impl.AbstractAttributeRecord.
An abstract implementation of attribute record.
AbstractAttributeRecord() - Constructor for class solar.impl.AbstractAttributeRecord
 
AbstractDanService - class solar.service.dan.AbstractDanService.
The abstract implementation (mostly dealing with clients) of DAN (Data Aggregation Network) service.
AbstractDanService() - Constructor for class solar.service.dan.AbstractDanService
 
accept(SelectionKey) - Method in class rice.pastry.wire.SocketManager
Specified by the SelectionKeyHandler interface.
accept(SelectionKey) - Method in class rice.pastry.wire.WireNodeHandle
Requeired by the SelectionKeyHandler interface.
accessFailed(RemoteObject) - Method in interface solar.service.rmtobj.RemoteObjectListener
The remote object is not accessable due to network problem, it is explicitly removed from the other end.
AccessPoint - class campus.AccessPoint.
Contains information about an access point.
AccessPoint() - Constructor for class campus.AccessPoint
 
AckEvent - class solar.service.pack.comm.AckEvent.
Acknowledge event by subscribers.
AckEvent(Event) - Constructor for class solar.service.pack.comm.AckEvent
 
AckEvent(long, Id, Id) - Constructor for class solar.service.pack.comm.AckEvent
 
action - Variable in class versus.meeting.RLearner
 
actions - Variable in class versus.meeting.RLPolicy
 
actionSelection - Variable in class versus.meeting.RLearner
 
add_to_head(Object) - Method in class solar.util.ssLinkedList
Adds an object to the head (start) of the linked list.
add_to_tail(Object) - Method in class solar.util.ssLinkedList
Adds an object to the tail (end) of the linked list.
addArgument(String, String) - Method in class solar.service.pack.lang.FilterConfig
 
addArgument(String, String) - Method in class solar.service.dan.lang.FilterSpec
 
addArgument(String, String) - Method in class campus.sysnort.TriggerConfig
 
addChild(NameNode) - Method in class solar.service.directory.NameNode
Add a child, either another name node or a name record.
addConnection(SocketAddress, TcpConnection) - Method in class solar.service.transport.TcpTransport
Add a new connection to peer address.
addFakeId(Id, Id) - Method in class solar.service.pack.ScribePackService
 
addGraphManager(GraphManager) - Method in class solar.service.dan.NodeManager
Add a graph manager containing a graph of nodes.
addInput(String) - Method in class solar.service.dan.lang.FilterSpec
 
addInputPort(String) - Method in class solar.service.dan.lang.FilterSpec
 
addIpLocation(String, Location) - Static method in class campus.compass.CompassService
 
addListener(Cache.CacheListener) - Method in class solar.module.cache.BaseCache
 
addListener(Cache.CacheListener) - Method in interface solar.module.cache.Cache
Add a listener to the cache.
addListener(MobileHostListener) - Method in class solar.service.mhost.SolarMobileHostService
 
addListener(MobileHostListener) - Method in interface solar.service.mhost.MobileHostService
Add a listener to client mobililty.
addListener(Name, DirectoryListener) - Method in class solar.service.directory.DistDirectoryService
 
addListener(Name, DirectoryListener) - Method in class solar.service.directory.FlatDirectory
 
addListener(Name, DirectoryListener) - Method in class solar.service.directory.CentralDirectoryService
 
addListener(Name, DirectoryListener) - Method in interface solar.service.directory.Directory
Add a directory observer for the specified pattern.
addListener(Name, DirectoryListener) - Method in interface solar.service.directory.DirectoryService
Add a directory listener for the specified pattern.
AddListenerRequest - class solar.service.directory.comm.AddListenerRequest.
Request to add a directory listener.
AddListenerRequest(Name, DirectoryListener) - Constructor for class solar.service.directory.comm.AddListenerRequest
 
addMember(MulticastMember) - Method in class solar.service.multicast.MulticastGroup
 
addObject(Object, Object) - Method in class solar.module.cache.RefreshableCache
Note if objectId exists in the cache, the previous cached object will be discarded and replaced by this one if they are different.
addObject(Object, Object) - Method in class solar.module.cache.BaseCache
If the objectId already exists in the cache, this add operation does override the previous cached object with the one supplied in parameter.
addObject(Object, Object) - Method in interface solar.module.cache.Cache
Put an object into the cache.
addOutput(String) - Method in class solar.service.dan.lang.FilterSpec
 
addOutputPort(String) - Method in class solar.service.dan.lang.FilterSpec
 
addPollTask(String, String, long) - Method in class campus.snmp.SnmpLocator
generate a polling task and hand over to thread pool.
addPublisher(Id) - Method in class solar.service.pack.proto.BaseProtocol
Add a publisher that may put events in this buffer manager.
addPublisher(Id, Publisher) - Method in class solar.service.pubsub.ScribePubSubService
 
addPublisher(Id, Publisher) - Method in class solar.service.pubsub.ClientPubSubService
 
addPublisher(Id, Publisher) - Method in interface solar.service.pubsub.PubSubService
Register a publisher with the service.
addPublisher(Id, Publisher) - Method in class solar.service.pubsub.client.PubSubClient
 
addRecord(NameRecord) - Method in class solar.service.directory.NameNode
Add a name record to this name node.
address - Variable in class rice.pastry.socket.HelloResponseMessage
 
address - Variable in class rice.pastry.socket.HelloMessage
 
Address - interface solar.api.Address.
Interface of various network address, such as socket address or P2P keys.
ADDRESS - Static variable in class solar.service.dan.lang.XmlSpecParser
 
AddressFactory - class solar.service.transport.AddressFactory.
Address factory that parses different format of addresses.
AddressFactory() - Constructor for class solar.service.transport.AddressFactory
 
addRootTask(Id, ScribePackService.RootTask) - Method in class solar.service.pack.ScribePackService
 
addScribeProxy(Id, Address) - Method in class solar.service.pack.ScribePackService
 
addScribeRoot(Id, Address) - Method in class solar.service.pack.ScribePackService
 
addSubscriber(Id, Id, Object) - Method in class solar.service.pack.proto.ForwardProtocol
 
addSubscriber(Id, Id, Object) - Method in class solar.service.pack.proto.OutputProtocol
 
addSubscriber(Id, Id, Object) - Method in class solar.service.pack.proto.BaseProtocol
Add a local subscriber that may get events from this manager.
addSubscriber(Id, Id, Object, Address) - Method in class solar.service.pack.proto.InputProtocol
 
addSubscriber(Id, Id, Object, Address) - Method in class solar.service.pack.proto.BaseProtocol
Add a remote subscriber that may get events from this manager.
addSubscriber(Id, Object, Buffer) - Method in class solar.service.pack.proto.GroupBufferHandle
 
addSubscriber(Id, Object, Buffer) - Method in class solar.service.pack.proto.SingleBufferHandle
 
addSubscriber(Id, Object, Buffer) - Method in interface solar.service.pack.proto.BufferHandle
Add a subscriber with specified policy.
addSubscriber(Id, Subscriber) - Method in class solar.service.pubsub.ScribePubSubService
 
addSubscriber(Id, Subscriber) - Method in class solar.service.pubsub.ClientPubSubService
 
addSubscriber(Id, Subscriber) - Method in interface solar.service.pubsub.PubSubService
Register a subscriber with the service.
addSubscriber(Id, Subscriber) - Method in class solar.service.pubsub.client.PubSubClient
 
addSubscribeTask(Id, Id, ScribePackService.SubscribeTask) - Method in class solar.service.pack.ScribePackService
 
addToQueue(Object) - Method in class rice.pastry.wire.SocketChannelWriter
Adds an entry into the queue, taking message prioritization into account
addTransportListener(TransportListener) - Method in class solar.service.transport.UdpTransport
 
addTransportListener(TransportListener) - Method in class solar.service.transport.TcpTransport
 
addTransportListener(TransportListener) - Method in class solar.service.transport.BaseTransportService
 
addTransportListener(TransportListener) - Method in class solar.service.transport.PastryTransport
 
addTransportListener(TransportListener) - Method in interface solar.service.transport.Transport
Add a transport listener.
addTransportListener(TransportListener) - Method in interface solar.service.transport.TransportService
Add a transport listener.
Adu - interface solar.api.Adu.
The interface for the ADU (Application Data Unit).
AduFactory - interface solar.api.AduFactory.
Interface for ADU factory, that produces appropriate ADU from byte array.
advertise(AdvertiseRequest) - Method in class solar.service.dan.AbstractDanService
 
advertise(Guid, Name, Object) - Method in class solar.service.dan.Monitor
 
advertise(Name, Id, Object) - Method in class solar.service.directory.DistDirectoryService
 
advertise(Name, Id, Object) - Method in class solar.service.directory.CentralDirectoryService
 
advertise(Name, Id, Object) - Method in interface solar.service.directory.DirectoryService
Advertise a name to the name space, with an app-specific object.
advertise(Name, NameRecord) - Method in class solar.service.directory.FlatDirectory
 
advertise(Name, NameRecord) - Method in interface solar.service.directory.Directory
Advertise a name to the name space.
advertise(String, Object, Source) - Method in class solar.Client
Advertise a static name for a Solar source.
advertise(String, Object, Source) - Method in class solar.service.dan.DanClientService
Advertise a static name with a name object and return an ID.
advertise(String, Source) - Method in class solar.Client
Advertise a static name for a Solar source.
advertise(String, String, Object, Source) - Method in class solar.Client
Advertise a dynamic name for a Solar source.
advertise(String, String, Object, Source) - Method in class solar.service.dan.DanClientService
Advertise a dynamic name with a name object and return an ID.
Advertisement - class solar.service.directory.Advertisement.
A directory advertisement includes a full name and corresponding name record.
ADVERTISEMENT_SVID - Static variable in interface solar.SolarConstants
 
Advertisement(Name, NameRecord) - Constructor for class solar.service.directory.Advertisement
 
AdvertiseRequest - class solar.service.dan.comm.AdvertiseRequest.
A request to make advertisement.
AdvertiseRequest - class solar.service.directory.comm.AdvertiseRequest.
Request to make an advertisement.
AdvertiseRequest(Name, NameRecord) - Constructor for class solar.service.directory.comm.AdvertiseRequest
 
AdvertiseRequest(String, String, Object, Guid) - Constructor for class solar.service.dan.comm.AdvertiseRequest
 
alloc_lle(Object) - Method in class solar.util.ssLinkedList
 
alpha - Variable in class versus.meeting.RLearner
 
antennaType - Variable in class campus.syslog.APConfiguration
 
anycastHandler(ScribeMessage) - Method in class solar.service.pack.ScribeManager
Invoked by underlying scribe when it receives a anycast Message, to check if there is a local application which can take care of this anycast message.
anycastHandler(ScribeMessage) - Method in class solar.service.pubsub.ScribeManager
Invoked by underlying scribe when it receives a anycast Message, to check if there is a local application which can take care of this anycast message.
anycastHandler(ScribeMessage) - Method in class solar.service.multicast.ScribeMulticastService.ScribeMember
Invoked by underlying scribe when it receives a anycast Message, to check if there is a local application which can take care of this anycast message.
APCONFIG - Static variable in class campus.CampusMap
 
APConfiguration - class campus.syslog.APConfiguration.
A structure for AP's Configuration infomation
APConfiguration(String, String, int, String, String, int, int, String, String, String) - Constructor for class campus.syslog.APConfiguration
Constructs a AP Configuration structure with specified parameters.
aPConfigurationTable - Variable in class campus.syslog.APMapping
 
aPConfigurationTableByaPName - Variable in class campus.syslog.APMapping
 
aPConfigurationTableBymACAddress - Variable in class campus.syslog.APMapping
 
APInfoOperator - class campus.syslog.APInfoOperator.
An operator which added the some important infomation of APs and publishes it.
APInfoOperator() - Constructor for class campus.syslog.APInfoOperator
 
APLOCATE - Static variable in class campus.CampusMap
 
APLocation - class campus.syslog.APLocation.
A structure for AP's location infomation
APLocation(String, double, double, double, int) - Constructor for class campus.syslog.APLocation
Constructs a AP location structure with specified parameters.
APLocationOperator - class campus.syslog.APLocationOperator.
An operator which adds the lcoation information of AP and publishes it.
APLocationOperator() - Constructor for class campus.syslog.APLocationOperator
 
aPLocationTable - Variable in class campus.syslog.APMapping
 
aPMapping - Variable in class campus.syslog.APLocationOperator
 
aPMapping - Variable in class campus.syslog.APInfoOperator
 
APMapping - class campus.syslog.APMapping.
A mapping object holding Category of building conversion table parsed from a data file.
APMapping(String, String) - Constructor for class campus.syslog.APMapping
Constructs the table with specified local data mapping files.
aPName - Variable in class campus.syslog.APLocation
 
aPName - Variable in class campus.syslog.APConfiguration
 
appendCompassTag(String) - Method in class org.doit.muffin.filter.CompassFilter
 
Application - class solar.service.dan.Application.
A base class for Solar applications.
Application() - Constructor for class solar.service.dan.Application
 
ApStat - class campus.snmp.ApStat.
Some statistics about AP based on SNMP poll results.
ApStat(String, String, int) - Constructor for class campus.snmp.ApStat
 
aPType - Variable in class campus.syslog.APConfiguration
 
ARGUMENT - Static variable in class solar.service.pack.lang.XmlPolicyParser
 
ARGUMENT - Static variable in class solar.service.dan.lang.XmlSpecParser
 
ARGUMENT - Static variable in class campus.sysnort.XmlConfigParser
 
array - Variable in class solar.test.MutateOperator
 
assertAttached() - Method in class solar.service.pack.ClientPackService
 
assertAttached(Id) - Method in class solar.service.pack.EndPointManager
 
assertEquals(String, String) - Method in class solar.service.pack.lang.XmlPolicyParser
 
assertEquals(String, String) - Method in class solar.service.dan.lang.XmlSpecParser
 
assertEquals(String, String) - Method in class campus.sysnort.XmlConfigParser
 
assertInited() - Method in class solar.service.BaseService
Check whether the service has been initialized.
assertNotAttached(Id) - Method in class solar.service.pack.EndPointManager
 
assertNotRegistered(Id) - Method in class solar.service.pubsub.ScribePubSubService
 
assertNotRegistered(Id) - Method in class solar.service.pubsub.ClientPubSubService
 
assertPubRegistered(Id) - Method in class solar.service.pack.proto.BaseProtocol
 
assertRegistered(Id) - Method in class solar.service.pubsub.ScribePubSubService
 
assertRegistered(Id) - Method in class solar.service.pubsub.ClientPubSubService
 
attach(Address) - Method in class solar.service.mhost.SolarMobileHostService
 
attach(Address) - Method in interface solar.service.mhost.MobileHostService
Have the client explicitly attch to a Planet.
attach(Id, Id, Address, EndPoint) - Method in class solar.service.pack.EndPointManager
 
attachDataSink(DataSink, InputPort) - Method in class solar.service.fap.LocalSinkChannel
 
attachDataSink(DataSink, InputPort) - Method in class solar.service.fap.RemoteSinkChannel
 
attachDataSink(DataSink, InputPort) - Method in interface solar.service.fap.SinkChannel
Attach a data sink to this pipe.
attachDataSource(DataSource, OutputPort) - Method in class solar.service.fap.LocalSourceChannel
 
attachDataSource(DataSource, OutputPort) - Method in class solar.service.fap.RemoteSourceChannel
 
attachDataSource(DataSource, OutputPort) - Method in interface solar.service.fap.SourceChannel
Attach a data source to this pipe.
attachInputPipe(Pipe, InputPort) - Method in class solar.service.dan.NodeHandler
 
attachInputPipe(Pipe, InputPort) - Method in interface solar.service.fap.DataSink
Attach an input pipe to this data sink.
attachOutputPipe(Pipe, OutputPort) - Method in class solar.service.dan.NodeHandler
 
attachOutputPipe(Pipe, OutputPort) - Method in interface solar.service.fap.DataSource
Attach an output pipe to this data source at a specific port.
attachPublisher(Id, Publisher) - Method in class solar.service.pack.ScribePackService
 
attachPublisher(Id, Publisher) - Method in class solar.service.pack.ClientPackService
 
attachPublisher(Id, Publisher) - Method in interface solar.service.pack.PackService
Attach a PACK publisher to the service.
attachPublisher(Id, Publisher) - Method in class solar.service.pack.client.PackClient
 
AttachPublisherRequest - class solar.service.pack.comm.AttachPublisherRequest.
Reuqest to attach a PACK publisher to server.
AttachPublisherRequest(Id) - Constructor for class solar.service.pack.comm.AttachPublisherRequest
 
AttachRequest - class solar.service.mhost.comm.AttachRequest.
A request to attach a client to a server, issued either by the client or the server.
AttachRequest(Address, Address) - Constructor for class solar.service.mhost.comm.AttachRequest
 
attachSinkChannel(SinkChannel) - Method in class solar.service.fap.Pipe
Attach a sink channel to this pipe.
attachSourceChannel(SourceChannel) - Method in class solar.service.fap.Pipe
Attach the source channel to this pipe.
attachSubscriber(Id, Subscriber) - Method in class solar.service.pack.ScribePackService
 
attachSubscriber(Id, Subscriber) - Method in class solar.service.pack.ClientPackService
 
attachSubscriber(Id, Subscriber) - Method in interface solar.service.pack.PackService
Attach a PACK subscriber to the service.
attachSubscriber(Id, Subscriber) - Method in class solar.service.pack.client.PackClient
 
AttachSubscriberRequest - class solar.service.pack.comm.AttachSubscriberRequest.
Reuqest to attach a PACK subscriber to server.
AttachSubscriberRequest(Id) - Constructor for class solar.service.pack.comm.AttachSubscriberRequest
 
Attribute - class solar.api.Attribute.
An attribute is a key-value pair.
ATTRIBUTE_RECORD_SVID - Static variable in interface solar.SolarConstants
 
ATTRIBUTE_SVID - Static variable in interface solar.SolarConstants
 
Attribute(String, Object) - Constructor for class solar.api.Attribute
Construcst an attribute with a key and a value.
AttributeRecord - interface solar.api.AttributeRecord.
An attribute record contains a list of attributes.

B

BADGE_HEADER - Static variable in class versus.VersusSource
 
BADGE_ID - Static variable in class versus.VersusSource
 
BASE - Static variable in interface campus.syslog.SyslogConstants
 
BaseCache - class solar.module.cache.BaseCache.
A base implementation of cache interface.
BaseCache() - Constructor for class solar.module.cache.BaseCache
 
BaseCache(int, long) - Constructor for class solar.module.cache.BaseCache
 
BaseProtocol - class solar.service.pack.proto.BaseProtocol.
The base class for PACK protocol suit.
BaseProtocol.ProtocolState - class solar.service.pack.proto.BaseProtocol.ProtocolState.
 
BaseProtocol.ProtocolState(int, int, int) - Constructor for class solar.service.pack.proto.BaseProtocol.ProtocolState
 
BaseProtocol(int, int, int) - Constructor for class solar.service.pack.proto.BaseProtocol
 
BaseService - class solar.service.BaseService.
A base service implementation.
BaseService() - Constructor for class solar.service.BaseService
 
BaseServiceManager - class solar.service.BaseServiceManager.
A base implementation of service manager.
BaseServiceManager() - Constructor for class solar.service.BaseServiceManager
 
BaseTransportService - class solar.service.transport.BaseTransportService.
The base implementation of transport service.
BaseTransportService() - Constructor for class solar.service.transport.BaseTransportService
 
batchFinished() - Method in class solar.service.fork.SolarForkService
 
batchFinished() - Method in interface solar.service.fork.TaskBatch.BatchListener
 
batchrun(String) - Method in class solar.service.fork.SolarForkService
 
batchrun(String) - Method in interface solar.service.fork.ForkService
 
batchrun(String) - Method in class solar.service.fork.client.ForkClient
 
Block - class solar.service.rpc.Block.
A blocking object that other objects can wait on till time out or a reply is ready.
Block() - Constructor for class solar.service.rpc.Block
Prevent object initialization.
buffer - Variable in class rice.pastry.wire.SocketChannelWriter
 
Buffer - class solar.module.protocol.Buffer.
A buffer contains an individual queue for one receiver or an aggregated queue for multiple receivers.
Buffer() - Constructor for class solar.module.protocol.Buffer
 
Buffer(Collection) - Constructor for class solar.module.protocol.Buffer
 
Buffer(int) - Constructor for class solar.module.protocol.Buffer
 
BufferedEvent - class solar.service.pack.proto.BufferedEvent.
Container event output from buffer manager, for internal use instead of wired transfer.
BufferedEvent(Id, Address, Event) - Constructor for class solar.service.pack.proto.BufferedEvent
 
BufferedEvent(Id, Id, Event) - Constructor for class solar.service.pack.proto.BufferedEvent
 
BufferFullException - exception solar.module.protocol.BufferFullException.
A generic exception thrown by cache module.
BufferFullException(String) - Constructor for class solar.module.protocol.BufferFullException
Construct an BufferFullException with specified detail message.
BufferFullException(String, Throwable) - Constructor for class solar.module.protocol.BufferFullException
Construct an BufferFullException with specified detail message and nested Throwable.
BufferFullException(Throwable) - Constructor for class solar.module.protocol.BufferFullException
Construct an BufferFullException with specified nested Throwable.
BufferHandle - interface solar.service.pack.proto.BufferHandle.
Interface for subscription hanle and its associated buffers.
BufferManagerFactory - class solar.service.pack.proto.BufferManagerFactory.
Factory produces input/output buffer managers used in protocol suits.
BufferManagerFactory() - Constructor for class solar.service.pack.proto.BufferManagerFactory
 
BufferPacker - interface solar.service.pack.proto.BufferPacker.
Interface for various buffer packing strategies.
BufferPackerFactory - class solar.service.pack.proto.BufferPackerFactory.
Factory to produce buffer packing strategies.
BufferPackerFactory() - Constructor for class solar.service.pack.proto.BufferPackerFactory
 
BUFSIZE - Static variable in class rice.pastry.wire.SocketChannelWriter
 
Building - class campus.Building.
Contains information about a building.
Building() - Constructor for class campus.Building
 
buildingName - Variable in class campus.syslog.APConfiguration
 
BuildingNameConvertor - class campus.syslog.BuildingNameConvertor.
A mapping object holding Category of building conversion table parsed from a data file.
BuildingNameConvertor(String) - Constructor for class campus.syslog.BuildingNameConvertor
Constructs the table with specified local XML mapping file.
BUILDINGS - Static variable in class campus.CampusMap
 
ByteArrayAdu - class solar.impl.ByteArrayAdu.
Application data unit contains only a byte array.
ByteArrayAdu(byte[]) - Constructor for class solar.impl.ByteArrayAdu
Constructs a byte array ADU.

C

Cache - interface solar.module.cache.Cache.
Interface for a cache.
CACHE_CAPACITY_DEFAULT - Static variable in interface solar.module.cache.CacheConstants
Default cache capacity.
CACHE_CAPACITY_INFINIT - Static variable in interface solar.module.cache.CacheConstants
Unlimited cache capacity.
CACHE_TTL_DEFAULT - Static variable in interface solar.module.cache.CacheConstants
Default object age/ttl (30 minutes).
CACHE_TTL_FOREVER - Static variable in interface solar.module.cache.CacheConstants
Do not expire the object
Cache.CacheListener - interface solar.module.cache.Cache.CacheListener.
Interface for receiving cache events.
CacheConstants - interface solar.module.cache.CacheConstants.
Constants used by cache service.
CachedObject - class solar.module.cache.CachedObject.
A container class for the object in the cache.
CachedObject(Object, Object) - Constructor for class solar.module.cache.CachedObject
 
CacheException - exception solar.module.cache.CacheException.
A generic exception thrown by cache module.
CacheException(String) - Constructor for class solar.module.cache.CacheException
Construct an CacheException with specified detail message.
CacheException(String, Throwable) - Constructor for class solar.module.cache.CacheException
Construct an CacheException with specified detail message and nested Throwable.
CacheException(Throwable) - Constructor for class solar.module.cache.CacheException
Construct an CacheException with specified nested Throwable.
callRpc(Address, Request) - Method in class solar.service.pack.ScribePackService
 
callRpc(Address, Request) - Method in class solar.service.rmtobj.SolarRemoteObjectService
 
callRpc(Address, Request) - Method in class solar.service.dan.PipeConnector
Invoke a RPC call with specified request.
callRpc(Address, Request) - Method in class solar.service.mhost.SolarMobileHostService
 
callRpc(Request) - Method in class solar.service.pack.ClientPackService
 
callRpc(Request) - Method in class solar.service.dan.DanClientService
Invoke a RPC call with specified request.
callRpc(Request) - Method in class solar.service.pubsub.ClientPubSubService
 
callRpc(Request) - Method in class solar.service.directory.RemoteDirectoryListener
 
callRpc(Request) - Method in class solar.service.directory.CentralDirectoryService
 
campus - package campus
Contains Solar sources, operators, and applications developed for campus-wide wireless network.
campus.compass - package campus.compass
Contains Solar service for Compass application.
campus.snmp - package campus.snmp
Contains Solar source and operators to use SNMP retrieving information about WLAN.
campus.syslog - package campus.syslog
Contains Solar source and operators to use Syslog message stream inferring information about WLAN.
campus.sysnort - package campus.sysnort
Contains the Sysnort application that can be used to monitor the wireless network.
campus.sysnort.trigger - package campus.sysnort.trigger
Contains some predefined Sysnort triggers.
CampusMap - class campus.CampusMap.
Contains mapping information about APs and buidings.
CampusMap(String) - Constructor for class campus.CampusMap
 
CancelButton - Variable in class versus.meeting.MeetingRecorder
 
CancelButtonActionPerformed(ActionEvent) - Method in class versus.meeting.MeetingRecorder
 
CatalogBuildingMapping - class campus.syslog.CatalogBuildingMapping.
A mapping object holding Category of building conversion table parsed from a data file.
CatalogBuildingMapping(String) - Constructor for class campus.syslog.CatalogBuildingMapping
Constructs the table with specified local data mapping file.
catalogBuildingTable - Variable in class campus.syslog.CatalogBuildingMapping
 
catalogBuildingTable - Variable in class campus.syslog.BuildingNameConvertor
 
CategoryOperator - class campus.syslog.CategoryOperator.
An operator which added category of building and publishes it.
CategoryOperator() - Constructor for class campus.syslog.CategoryOperator
 
CentralDirectoryService - class solar.service.directory.CentralDirectoryService.
A centralized directory service, which requires a rpc and a transport services.
CentralDirectoryService() - Constructor for class solar.service.directory.CentralDirectoryService
 
charToNibble(char) - Static method in class solar.util.StringUtil
 
checkCondition(Event) - Method in class campus.sysnort.Trigger
Check whether the new event satisfy this trigger's condition.
checkCondition(Event) - Method in class campus.sysnort.trigger.HotspotTrigger
 
checkCondition(Event) - Method in class campus.sysnort.trigger.FlickerTrigger
 
checkCondition(Event) - Method in class campus.sysnort.trigger.MissingCardTrigger
 
checkError(String) - Method in class campus.syslog.SyslogParser
 
CLASSNAME - Static variable in class solar.service.dan.lang.XmlSpecParser
 
CLASSNAME - Static variable in class campus.sysnort.XmlConfigParser
 
CLASSNAME_SUFFIX - Static variable in class solar.service.BaseServiceManager
A service property determining its implementing class name.
clean(String) - Method in class campus.syslog.SyslogParser
 
clear() - Method in class solar.module.protocol.Buffer
Clear out the whole buffer.
clear() - Method in class campus.sysnort.trigger.FlickerTrigger.ClientState
 
clearConnections() - Method in class solar.service.transport.TcpTransport
Remove all the connections.
Client - class solar.Client.
The facade class to interact with Solar system.
Client(Options) - Constructor for class solar.Client
 
Client(String) - Constructor for class solar.Client
 
Client(String, int) - Constructor for class solar.Client
 
Client(String, int, Options) - Constructor for class solar.Client
 
clientAttached(Address) - Method in class solar.service.pack.ClientPackService
 
clientAttached(Address) - Method in interface solar.service.mhost.MobileHostListener
Handler when a client is attached to a Planet.
clientDetached(Address) - Method in class solar.service.pack.ClientPackService
 
clientDetached(Address) - Method in interface solar.service.mhost.MobileHostListener
Handler when a client is detached from a Planet.
ClientPackService - class solar.service.pack.ClientPackService.
The PACK service that runs at the client side.
ClientPackService.Handler - class solar.service.pack.ClientPackService.Handler.
 
ClientPackService.Handler() - Constructor for class solar.service.pack.ClientPackService.Handler
 
ClientPackService.Sender - class solar.service.pack.ClientPackService.Sender.
 
ClientPackService.Sender() - Constructor for class solar.service.pack.ClientPackService.Sender
 
ClientPackService() - Constructor for class solar.service.pack.ClientPackService
 
ClientPubSubService - class solar.service.pubsub.ClientPubSubService.
The PACK service that runs at the client side.
ClientPubSubService() - Constructor for class solar.service.pubsub.ClientPubSubService
 
ClockSource - class solar.test.ClockSource.
A source periodically publishes events containing current timestamp.
ClockSource(int) - Constructor for class solar.test.ClockSource
 
close(LinkedList) - Method in class rice.pastry.wire.WireNodeHandle
Private method used for closing the socket (if there is one present).
closeDialog(WindowEvent) - Method in class versus.meeting.MeetingRecorder
Closes the dialog
closeSocket(WireNodeHandle) - Method in class rice.pastry.wire.SocketManager
Method which is designed to be called by node handles which have been disconnected by the remote node.
coalesce(DistNodeHandle) - Method in class rice.pastry.socket.SocketNodeHandlePool
 
CODEBASE - Static variable in class solar.service.dan.lang.XmlSpecParser
 
CODEBASE - Static variable in class campus.sysnort.XmlConfigParser
 
COLLECTOR_NO - Static variable in class versus.VersusSource
 
command(String) - Static method in class solar.util.SystemUtil
 
command(String, String) - Static method in class solar.util.SystemUtil
 
command(String, String[], File) - Static method in class solar.util.SystemUtil
 
compare(Object, Object) - Method in class solar.util.ssLinkedListEqualityComparator
 
compare(Object, Object) - Method in interface solar.util.ssLinkedListComparator
Returns true if the comparison is successful, false otherwise.
Compass - class org.doit.muffin.filter.Compass.
Factory for compass filters.
COMPASS_COLOR - Static variable in class org.doit.muffin.filter.CompassFilter
 
Compass() - Constructor for class org.doit.muffin.filter.Compass
 
CompassFilter - class org.doit.muffin.filter.CompassFilter.
A compass filter impose location-dependent information on top of the replied page to client.
CompassFilter() - Constructor for class org.doit.muffin.filter.CompassFilter
 
CompassMain - class org.doit.muffin.CompassMain.
A wrapper class for Muffin proxy.
CompassMain(Options) - Constructor for class org.doit.muffin.CompassMain
 
CompassService - class campus.compass.CompassService.
Compass service provides a Web proxy that impose location-dependent information on the pages viewed by the clients.
CompassService() - Constructor for class campus.compass.CompassService
 
compose() - Method in class campus.syslog.SyslogParser
 
composeName(Name, Event) - Method in class solar.service.dan.Monitor
 
configLogger(Logger, Options) - Static method in class solar.Planet
 
connect(int, Guid, String, Guid, String) - Method in class solar.service.dan.DanClientService
 
connect(int, Guid, String, Guid, String) - Method in class solar.service.dan.SolarDanService
 
connect(int, Guid, String, Guid, String) - Method in interface solar.service.dan.DanService
Connect two nodes (at least one local) with a pipe.
connect(SelectionKey) - Method in class rice.pastry.wire.SocketManager
Specified by the SelectionKeyHandler interface - should NEVER be called!
connect(SelectionKey) - Method in class rice.pastry.wire.WireNodeHandle
Called by the socket manager whnever this node handle needs to complete it's connection to it's remote node.
connectionClosed(Address) - Method in class solar.service.transport.BaseTransportService
 
connectionClosed(Address) - Method in interface solar.service.transport.TransportListener
Called when an connection closed.
connectionClosed(Address) - Method in class solar.service.dispatch.SolarDispatchService.NetListener
 
connectionClosed(Address) - Method in class solar.test.GroundHog
 
connectionClosed(Address) - Method in class rice.pastry.socket.SocketPastryNodeFactory
 
connectionClosed(Address) - Method in class rice.pastry.socket.SocketNodeHandle
 
connectionOpened(Address) - Method in class solar.service.transport.BaseTransportService
 
connectionOpened(Address) - Method in interface solar.service.transport.TransportListener
Called when an connection opened.
connectionOpened(Address) - Method in class solar.service.dispatch.SolarDispatchService.NetListener
 
connectionOpened(Address) - Method in class solar.test.GroundHog
 
connectionOpened(Address) - Method in class rice.pastry.socket.SocketPastryNodeFactory
 
connectionOpened(Address) - Method in class rice.pastry.socket.SocketNodeHandle
 
connectors - Variable in class rice.pastry.wire.SocketManager
 
connectToRemoteNode(LinkedList) - Method in class rice.pastry.wire.WireNodeHandle
Method which initiates a connection to a remote node.
construct(Options) - Method in class solar.Client
Common operations needed by constructors.
construct(Options) - Method in class solar.service.pack.client.PackClient
Common operations needed by constructors.
construct(Options) - Method in class solar.service.fork.client.ForkClient
 
construct(Options) - Method in class solar.service.pubsub.client.PubSubClient
Common operations needed by constructors.
construction() - Method in class solar.service.transport.SocketAddress
common constructor operations.
construction() - Method in class solar.service.transport.PastryAddress
Common constructor operatoions.
contains(Id) - Method in class solar.service.pack.EndPointManager
 
contains(Id) - Method in class solar.service.pubsub.EndPointManager
 
convert(String) - Method in class campus.CampusMap
 
convertMac(String) - Method in class campus.snmp.SnmpLocator
Convert mac address from snmp format to syslog format.
convertor - Variable in class campus.syslog.CatalogBuildingMapping
 
COOKIE - Variable in class solar.service.transport.TcpConnection
The cookie identifying our protocol handshake.
counter - Static variable in class solar.test.GroundHog
 
Counter - class solar.util.Counter.
An integer counter with some convenient methods.
Counter() - Constructor for class solar.util.Counter
 
Counter(int) - Constructor for class solar.util.Counter
 
CountryCode - class campus.compass.CountryCode.
Manages the mapping of the country name to its 2-char code.
CountryCode() - Constructor for class campus.compass.CountryCode
 
create(Id) - Method in class solar.service.pack.ScribeManager
Create a mutlicast tree for specified topic.
create(Id) - Method in class solar.service.pubsub.ScribeManager
 
create(Id) - Method in class solar.service.multicast.ScribeMulticastService
 
create(Id) - Method in class solar.service.multicast.NaiveMulticastService
 
create(Id) - Method in interface solar.service.multicast.MulticastService
Create a multicast group.
createChild(String) - Method in class solar.service.directory.NameNode
Create a new child with specified label.
createFilter() - Method in class org.doit.muffin.filter.Logger
 
createFilter() - Method in class org.doit.muffin.filter.Compass
 
curElement - Variable in class solar.util.ssLinkedList.ssLinkedListEnumeration
 

D

DAN_INPORT - Static variable in interface solar.service.dan.DanConstants
 
DAN_OUTPORT - Static variable in interface solar.service.dan.DanConstants
 
DanClientService - class solar.service.dan.DanClientService.
The client interface for DAN (Data Aggregation Network) service.
DanClientService() - Constructor for class solar.service.dan.DanClientService
 
DanConstants - interface solar.service.dan.DanConstants.
Constants for DAN service.
DanException - exception solar.service.dan.DanException.
An exception thrown by the operator-graph service.
DanException(String) - Constructor for class solar.service.dan.DanException
Construct an DanException with specified detail message.
DanException(String, Throwable) - Constructor for class solar.service.dan.DanException
Construct an DanException with specified detail message and nested Throwable.
DanException(Throwable) - Constructor for class solar.service.dan.DanException
Construct an DanException with specified nested Throwable.
DanService - interface solar.service.dan.DanService.
Interface for DAN (Data Aggregation Network) service.
dataReceived(Adu, Header) - Method in class solar.service.transport.BaseTransportService
 
dataReceived(Adu, Header) - Method in interface solar.service.transport.TransportListener
Called when new data is received.
dataReceived(Adu, Header) - Method in class solar.service.dispatch.SolarDispatchService.NetListener
 
dataReceived(Adu, Header) - Method in class solar.test.GroundHog
 
dataReceived(Adu, Header) - Method in class rice.pastry.socket.SocketPastryNodeFactory
 
dataReceived(Adu, Header) - Method in class rice.pastry.socket.SocketNodeHandle
 
DataSink - interface solar.service.fap.DataSink.
A data sink is the ending point of a pipe.
DataSource - interface solar.service.fap.DataSource.
A data source is the starting point of a pipe.
debug(String) - Method in class rice.pastry.wire.SocketManager.SocketConnector
 
debug(String) - Method in class rice.pastry.wire.SocketManager
 
debug(String) - Method in class rice.pastry.wire.SocketChannelWriter
 
debug(String) - Method in class rice.pastry.wire.UdpPastryNodeFactory
 
debug(String) - Method in class rice.pastry.wire.TcpPastryNodeFactory
 
debug(String) - Method in class rice.pastry.socket.SocketPastryNodeFactory
 
debug(String) - Method in class rice.pastry.socket.SocketNodeHandlePool
 
decodeCity(String) - Static method in class campus.compass.ZipCodeSource
Decode city from region represtation.
decodeSerializable(byte[]) - Static method in class solar.impl.SerializedAdu
 
decodeSerializable(byte[], int, int) - Static method in class solar.impl.SerializedAdu
 
decodeState(String) - Static method in class campus.compass.ZipCodeSource
Decode state from region represtation.
DELIMIT - Static variable in class solar.impl.PlainAttributeRecord
 
deliver(Id, Message) - Method in class solar.service.transport.PastryObjectTransport
 
deliver(Id, Message) - Method in class solar.service.transport.PastryTransport
 
dequeue() - Method in class solar.util.JavaUnsyncQueue
 
dequeue() - Method in class solar.util.JavaSyncQueue
 
dequeue() - Method in class solar.util.FastUnsyncQueue
 
dequeue() - Method in class solar.util.FastSyncQueue
 
dequeue() - Method in interface solar.util.Queue
Dequeue one data item.
dequeue(long) - Method in class solar.util.JavaUnsyncQueue
 
dequeue(long) - Method in class solar.util.JavaSyncQueue
 
dequeue(long) - Method in class solar.util.FastUnsyncQueue
 
dequeue(long) - Method in class solar.util.FastSyncQueue
 
dequeue(long) - Method in interface solar.util.Queue
Dequeue one data item within timeout period.
dequeueAll() - Method in class solar.util.JavaUnsyncQueue
 
dequeueAll() - Method in class solar.util.JavaSyncQueue
 
dequeueAll() - Method in class solar.util.FastUnsyncQueue
 
dequeueAll() - Method in class solar.util.FastSyncQueue
 
dequeueAll() - Method in interface solar.util.Queue
Dequeue all the data items currently in the queue.
dest - Variable in class rice.pastry.socket.HelloResponseMessage
 
dest - Variable in class rice.pastry.socket.HelloMessage
 
destroy() - Method in class solar.service.transport.TcpConnection
Destory this connection.
destroy(Id) - Method in class solar.service.multicast.ScribeMulticastService
 
destroy(Id) - Method in class solar.service.multicast.NaiveMulticastService
 
destroy(Id) - Method in interface solar.service.multicast.MulticastService
Destroy a multicast group.
destroy(Id, Address) - Method in class solar.service.fork.SolarForkService
 
destroy(Id, Address) - Method in interface solar.service.fork.ForkService
Execute a previously created process at specified address.
DestroyRequest - class solar.service.fork.comm.DestroyRequest.
Request to destroy a previously created process on remote host.
DestroyRequest() - Constructor for class solar.service.fork.comm.DestroyRequest
 
detach(Address) - Method in class solar.service.mhost.SolarMobileHostService
 
detach(Address) - Method in interface solar.service.mhost.MobileHostService
Have the client explicitly detach from a Planet.
detach(Id) - Method in class solar.service.pack.EndPointManager
 
detachPublisher(Id) - Method in class solar.service.pack.ScribePackService
 
detachPublisher(Id) - Method in class solar.service.pack.ClientPackService
 
detachPublisher(Id) - Method in interface solar.service.pack.PackService
Detach a PACK publisher from the service.
detachPublisher(Id) - Method in class solar.service.pack.client.PackClient
 
DetachPublisherRequest - class solar.service.pack.comm.DetachPublisherRequest.
Reuqest to detach a PACK publisher from server.
DetachPublisherRequest(Id) - Constructor for class solar.service.pack.comm.DetachPublisherRequest
 
DetachRequest - class solar.service.mhost.comm.DetachRequest.
A request to deattach a client from a server, issued either by the client or the server.
DetachRequest(Address, Address) - Constructor for class solar.service.mhost.comm.DetachRequest
 
detachSubscriber(Id) - Method in class solar.service.pack.ScribePackService
 
detachSubscriber(Id) - Method in class solar.service.pack.ClientPackService
 
detachSubscriber(Id) - Method in interface solar.service.pack.PackService
Detach a PACK subscriber from the service.
detachSubscriber(Id) - Method in class solar.service.pack.client.PackClient
 
DetachSubscriberRequest - class solar.service.pack.comm.DetachSubscriberRequest.
Reuqest to detach a PACK subscriber from server.
DetachSubscriberRequest(Id) - Constructor for class solar.service.pack.comm.DetachSubscriberRequest
 
dimSize - Variable in class versus.meeting.RLPolicy
 
dimSize - Variable in class versus.meeting.RLearner
 
DIR_ADD_OBSERVER - Static variable in interface solar.service.directory.DirectoryConstants
 
DIR_ADVERTISE - Static variable in interface solar.service.directory.DirectoryConstants
 
DIR_ID - Static variable in interface solar.service.directory.DirectoryConstants
 
DIR_LOOKUP - Static variable in interface solar.service.directory.DirectoryConstants
 
DIR_NAME - Static variable in interface solar.service.directory.DirectoryConstants
 
DIR_NAME_ADDED - Static variable in interface solar.service.directory.DirectoryConstants
 
DIR_NAME_MIGRATED - Static variable in interface solar.service.directory.DirectoryConstants
 
DIR_NAME_REMOVED - Static variable in interface solar.service.directory.DirectoryConstants
 
DIR_NAME_UPDATED - Static variable in interface solar.service.directory.DirectoryConstants
 
DIR_NEWNAME - Static variable in interface solar.service.directory.DirectoryConstants
 
DIR_NEWREC - Static variable in interface solar.service.directory.DirectoryConstants
 
DIR_OBSERVER - Static variable in interface solar.service.directory.DirectoryConstants
 
DIR_OLDNAME - Static variable in interface solar.service.directory.DirectoryConstants
 
DIR_OLDREC - Static variable in interface solar.service.directory.DirectoryConstants
 
DIR_PATTERN - Static variable in interface solar.service.directory.DirectoryConstants
 
DIR_RECORD - Static variable in interface solar.service.directory.DirectoryConstants
 
DIR_REMOVE_OBSERVER - Static variable in interface solar.service.directory.DirectoryConstants
 
DIR_UNADVERTISE - Static variable in interface solar.service.directory.DirectoryConstants
 
DIR_UPDATE - Static variable in interface solar.service.directory.DirectoryConstants
 
Directory - interface solar.service.directory.Directory.
Interface for directory containing advertisements.
DirectoryConstants - interface solar.service.directory.DirectoryConstants.
Constants for directory service.
DirectoryException - exception solar.service.directory.DirectoryException.
An exception thrown by directory services.
DirectoryException(String) - Constructor for class solar.service.directory.DirectoryException
Construct an DirectoryException with specified detail message.
DirectoryException(String, Throwable) - Constructor for class solar.service.directory.DirectoryException
Construct an DirectoryException with specified detail message and nested Throwable.
DirectoryException(Throwable) - Constructor for class solar.service.directory.DirectoryException
Construct an DirectoryException with specified nested Throwable.
DirectoryListener - interface solar.service.directory.DirectoryListener.
An observer for the directory events, such as the arrival of new names and removal of existing names, et al.
DirectoryService - interface solar.service.directory.DirectoryService.
Directory service handles naming and resource discovery.
DirectPipe - class solar.service.fap.DirectPipe.
A direct pipe has no buffer inside.
DirectPipe(Id, int, FapService) - Constructor for class solar.service.fap.DirectPipe
 
DirectRoutingService - class solar.service.routing.DirectRoutingService.
The direct routing service uses same routing contruction as ManualRoutingService, only to gain knowledge of all live hosts.
DirectRoutingService() - Constructor for class solar.service.routing.DirectRoutingService
 
disconnect() - Method in class rice.pastry.wire.WireNodeHandle
Method that is designed to be called by the SocketManager when it wishes for this node handle to disconnect.
DispatchConstants - interface solar.service.dispatch.DispatchConstants.
Constants for routing service.
dispatchEvent(Event, Address, String, String) - Method in class solar.service.dispatch.SolarDispatchService
 
dispatchEvent(Event, Address, String, String) - Method in interface solar.service.dispatch.DispatchService
Dispatch an event to specified destination using a transport service.
DispatchService - interface solar.service.dispatch.DispatchService.
The dispatching service receives events from one or more transports and dispatches them to local services.
DispatchUnit - class solar.service.dispatch.DispatchUnit.
A wrapper class contains a received ADU and related information.
DispatchUnit(Adu, String, String, Address) - Constructor for class solar.service.dispatch.DispatchUnit
 
DistDirectoryService - class solar.service.directory.DistDirectoryService.
A distributed implementation of directory service.
DistDirectoryService() - Constructor for class solar.service.directory.DistDirectoryService
 
DistGraphManager - class solar.service.dan.DistGraphManager.
A distributed graph manager that loads operators randomly across Planets to achieve some level of load balancing.
DistGraphManager(GraphSpec) - Constructor for class solar.service.dan.DistGraphManager
 
doAddListener(Name, DirectoryListener) - Method in class solar.service.directory.CentralDirectoryService
 
doAdvertise(Name, NameRecord) - Method in class solar.service.directory.CentralDirectoryService
 
doAttachPublisher(Id, Id, Address, Publisher) - Method in class solar.service.pack.ScribePackService
 
doAttachSubscriber(Id, Id, Address, Subscriber) - Method in class solar.service.pack.ScribePackService
 
doDetachPublisher(Id) - Method in class solar.service.pack.ScribePackService
 
doDetachSubscriber(Id) - Method in class solar.service.pack.ScribePackService
 
dohandleReply(ReplyEvent) - Method in class solar.service.rpc.SolarRpcService
 
doHandleRequest(RequestEvent, Address) - Method in class solar.service.rpc.SolarRpcService
 
doJoin(Id, MulticastMember, boolean) - Method in class solar.service.multicast.NaiveMulticastService
 
doLeave(Id, MulticastMember, boolean) - Method in class solar.service.multicast.NaiveMulticastService
 
doLookup(Name) - Method in class solar.service.directory.CentralDirectoryService
 
doMulticast(Id, Event, boolean) - Method in class solar.service.multicast.NaiveMulticastService
 
doneNode(NodeHandle) - Method in class rice.pastry.socket.SocketPastryNode
 
doPoll(String, String, long) - Method in class campus.snmp.SnmpLocator
Actually poll the access point using a script.
doPublish(Id, Event) - Method in class solar.service.pack.ScribePackService
 
doPublish(Id, Event) - Method in class solar.service.pubsub.ScribePubSubService
 
doPubRegister(Id, Id, Address, Publisher) - Method in class solar.service.pubsub.ScribePubSubService
 
doRemoveListener(Name, DirectoryListener) - Method in class solar.service.directory.CentralDirectoryService
 
doSend(Adu, Address, Id) - Method in class solar.service.transport.BaseTransportService
 
doSend(Adu, Header) - Method in class solar.service.transport.TcpConnection
 
doSubRegister(Id, Id, Address, Subscriber) - Method in class solar.service.pubsub.ScribePubSubService
 
doSubscribe(Id, Id, Object) - Method in class solar.service.pack.ScribePackService
 
doSubscribe(Id, Id, Object) - Method in class solar.service.pubsub.ScribePubSubService
 
doUnadvertise(Name, NameRecord) - Method in class solar.service.directory.CentralDirectoryService
 
doUpdate(long, String, String, String, String, String) - Method in class campus.snmp.SnmpLocator
update the locator with a syslog message.
doUpdate(Name, NameRecord, Name, NameRecord) - Method in class solar.service.directory.CentralDirectoryService
 
dropHead() - Method in class solar.module.protocol.Buffer
 
dropTail() - Method in class solar.module.protocol.Buffer
 
DropTailIBM - class solar.service.pack.proto.DropTailIBM.
This input buffer manager drops incoming events if buffer space reaches memory limit.
DropTailIBM(BaseProtocol.ProtocolState) - Constructor for class solar.service.pack.proto.DropTailIBM
 

E

E_GREEDY - Static variable in class versus.meeting.RLearner
 
elements() - Method in class solar.util.ssLinkedList
Returns a java.util.Enumeration enumeration over the elements of the linked list.
EmailUtil - class solar.util.EmailUtil.
Contains common actions using email system.
EmailUtil() - Constructor for class solar.util.EmailUtil
 
enableFilter(String) - Method in class org.doit.muffin.CompassMain
 
encodeRegion(String, String) - Static method in class campus.compass.ZipCodeSource
Encode city and state into region representation.
encodeSerializable(Serializable) - Static method in class solar.impl.SerializedAdu
 
endDocument() - Method in class solar.service.dan.lang.XmlSpecParser
 
endElement(String, String, String) - Method in class solar.service.pack.lang.XmlPolicyParser
 
endElement(String, String, String) - Method in class solar.service.dan.lang.XmlSpecParser
 
endElement(String, String, String) - Method in class versus.XmlVersusParser
Triggered whenever a XML tag has been parsed.
endElement(String, String, String) - Method in class campus.sysnort.XmlConfigParser
 
endFilter() - Method in class solar.service.pack.lang.XmlPolicyParser
 
endFilter() - Method in class solar.service.dan.lang.XmlSpecParser
 
EndPoint - interface solar.service.pubsub.EndPoint.
Interface for the clients publishing or subscribing to event stream.
EndPointManager - class solar.service.pack.EndPointManager.
A class manages all known end points and their related information.
EndPointManager - class solar.service.pubsub.EndPointManager.
A class manages all known end points and their related information.
EndPointManager.EP - class solar.service.pack.EndPointManager.EP.
 
EndPointManager.EP - class solar.service.pubsub.EndPointManager.EP.
 
EndPointManager.EP(Id, Address, EndPoint) - Constructor for class solar.service.pack.EndPointManager.EP
 
EndPointManager.EP(Id, Address, EndPoint) - Constructor for class solar.service.pubsub.EndPointManager.EP
 
EndPointManager() - Constructor for class solar.service.pack.EndPointManager
 
EndPointManager() - Constructor for class solar.service.pubsub.EndPointManager
 
endPolicy() - Method in class solar.service.pack.lang.XmlPolicyParser
 
endSession(PackSession) - Method in class solar.service.pack.PackFilter
End a packing session.
endSession(PackSession) - Method in class solar.service.pack.filter.RANDOM
 
endSession(PackSession) - Method in class solar.service.pack.filter.EVEN
 
endSession(PackSession) - Method in class solar.service.pack.filter.ODD
 
endSession(PackSession) - Method in class solar.service.pack.filter.GE
 
endState() - Method in class versus.meeting.RLMeetingWorld
 
endState() - Method in interface versus.meeting.RLWorld
Returns true if current state is absorbing state, false if not.
endTrigger() - Method in class campus.sysnort.XmlConfigParser
 
enqueue(Object) - Method in class solar.util.JavaUnsyncQueue
 
enqueue(Object) - Method in class solar.util.JavaSyncQueue
 
enqueue(Object) - Method in class solar.util.FastUnsyncQueue
 
enqueue(Object) - Method in class solar.util.FastSyncQueue
 
enqueue(Object) - Method in interface solar.util.Queue
Enqueue one data item.
enqueue(Object) - Method in class rice.pastry.wire.SocketChannelWriter
Adds an object to this SocketChannelWriter's queue of pending objects to write.
enqueueAll(Object[]) - Method in class solar.util.JavaUnsyncQueue
 
enqueueAll(Object[]) - Method in class solar.util.JavaSyncQueue
 
enqueueAll(Object[]) - Method in class solar.util.FastUnsyncQueue
 
enqueueAll(Object[]) - Method in class solar.util.FastSyncQueue
 
enqueueAll(Object[]) - Method in interface solar.util.Queue
Enqueue an array of data items.
epochs - Variable in class versus.meeting.RLearner
 
epochsdone - Variable in class versus.meeting.RLearner
 
epsilon - Variable in class versus.meeting.RLearner
 
equals(Object) - Method in class solar.api.Guid
 
equals(Object) - Method in class solar.api.Id
 
equals(Object) - Method in interface solar.api.Address
Test whether two addresses are equals.
equals(Object) - Method in class solar.api.Attribute
 
equals(Object) - Method in interface solar.api.AttributeRecord
Determine whether two objects are equal.
equals(Object) - Method in class solar.impl.SerializedEvent
 
equals(Object) - Method in class solar.impl.PlainAttributeRecord
 
equals(Object) - Method in class solar.service.transport.PastryTransport.MultiplexAddress
 
equals(Object) - Method in class solar.service.transport.SocketAddress
 
equals(Object) - Method in class solar.service.transport.PastryAddress
 
equals(Object) - Method in class solar.service.rmtobj.RemoteObject
 
equals(Object) - Method in class solar.service.directory.NameRecord
Check whether two objects are equivalent name records.
EVEN - class solar.service.pack.filter.EVEN.
The PACK filter throws events whose value is not odd.
EVEN() - Constructor for class solar.service.pack.filter.EVEN
 
Event - interface solar.api.Event.
The interface for Solar events.
EVENT_PLAIN - Static variable in interface solar.api.Event
 
EVENT_SERIALIZED - Static variable in interface solar.api.Event
 
EventFactory - class solar.impl.EventFactory.
Event factory produces events based on their types, or by calling a particular method on particular event format.
EventFactory() - Constructor for class solar.impl.EventFactory
 
EventHandler - interface solar.api.EventHandler.
Interface for event handler.
EventPrinter - class solar.test.EventPrinter.
A simple Solar application that make subscriptions to print all receive events.
EventPrinter() - Constructor for class solar.test.EventPrinter
 
eventReceived(Event) - Method in interface solar.service.pack.ScribeManager.ScribeListener
 
eventReceived(Event) - Method in class solar.service.pubsub.ScribePubSubService
 
eventReceived(Event) - Method in interface solar.service.pubsub.ScribeManager.ScribeListener
 
EVT_ACTION - Static variable in interface campus.syslog.SyslogConstants
 
EVT_APNAME - Static variable in interface campus.syslog.SyslogConstants
 
EVT_CLIENTHOST - Static variable in interface campus.syslog.SyslogConstants
 
EVT_CLIENTMAC - Static variable in interface campus.syslog.SyslogConstants
 
EVT_DAY - Static variable in interface campus.syslog.SyslogConstants
 
EVT_MONTH - Static variable in interface campus.syslog.SyslogConstants
 
EVT_MSGTYPE - Static variable in interface campus.syslog.SyslogConstants
 
EVT_NOTE - Static variable in interface campus.syslog.SyslogConstants
 
EVT_TIME - Static variable in interface campus.syslog.SyslogConstants
 
EVT_TIMESTAMP - Static variable in interface campus.syslog.SyslogConstants
 
EVT_YEAR - Static variable in interface campus.syslog.SyslogConstants
 

F

FairQueueOBM - class solar.service.pack.proto.FairQueueOBM.
This output buffer manager takes all currently non-empty buffers and dequeue one of them with uniform probability.
FairQueueOBM(BaseProtocol.ProtocolState) - Constructor for class solar.service.pack.proto.FairQueueOBM
 
FAP_DATA - Static variable in interface solar.service.fap.FapConstants
 
FAP_MIXED - Static variable in interface solar.service.fap.FapConstants
 
FAP_PID - Static variable in interface solar.service.fap.FapConstants
 
FAP_PULL - Static variable in interface solar.service.fap.FapConstants
 
FAP_PUSH - Static variable in interface solar.service.fap.FapConstants
 
FapClientService - class solar.service.fap.FapClientService.
Implementation of Filter-and-Pipe (FAP) service.
FapClientService() - Constructor for class solar.service.fap.FapClientService
 
FapConstants - interface solar.service.fap.FapConstants.
Constants used by FAP service.
FapException - exception solar.service.fap.FapException.
An exception thrown by Filter-and-Pipe (FAP) service.
FapException(String) - Constructor for class solar.service.fap.FapException
Construct an FapException with specified detail message.
FapException(String, Throwable) - Constructor for class solar.service.fap.FapException
Construct an FapException with specified detail message and nested Throwable.
FapException(Throwable) - Constructor for class solar.service.fap.FapException
Construct an FapException with specified nested Throwable.
FapService - interface solar.service.fap.FapService.
A distributed service implementing Filter-and-Pipe (FAP) architectural pattern.
FastSyncQueue - class solar.util.FastSyncQueue.
A synchronized blocking queue based on a fast linked-list.
FastSyncQueue() - Constructor for class solar.util.FastSyncQueue
 
FastUnsyncQueue - class solar.util.FastUnsyncQueue.
A not synchronized non-blocking queue based on a fast linked-list.
FastUnsyncQueue() - Constructor for class solar.util.FastUnsyncQueue
 
faultHandler(ScribeMessage, NodeHandle) - Method in class solar.service.pack.ScribeManager
Invoked by Scribe just before the "repair" SUBSCRIBE message is sent when a node suspects its parent is faulty.
faultHandler(ScribeMessage, NodeHandle) - Method in class solar.service.pubsub.ScribeManager
Invoked by Scribe just before the "repair" SUBSCRIBE message is sent when a node suspects its parent is faulty.
faultHandler(ScribeMessage, NodeHandle) - Method in class solar.service.multicast.ScribeMulticastService.ScribeMember
Invoked by Scribe just before the "repair" SUBSCRIBE message is sent when a node suspects its parent is faulty.
FIELDS_NUM - Static variable in class versus.VersusSource
 
FileUtil - class solar.util.FileUtil.
Some utilities regarding files.
FileUtil() - Constructor for class solar.util.FileUtil
 
fillStrandsFromAR(AttributeRecord, String, List) - Method in class solar.service.directory.PlainName
 
Filter - class solar.service.dan.Filter.
Filter class can be used interchangably with Operator class.
Filter - interface solar.service.fap.Filter.
Filter is one component that processes one or more incoming data streams and produces another one.
FILTER - Static variable in class solar.service.pack.lang.XmlPolicyParser
 
FILTER - Static variable in class solar.service.dan.lang.XmlSpecParser
 
FILTER_CONFIG_SVID - Static variable in interface solar.SolarConstants
 
FILTER_SPEC_SVID - Static variable in interface solar.SolarConstants
 
Filter() - Constructor for class solar.service.dan.Filter
 
filter(Event) - Method in class solar.service.pack.PackFilter
Drop the event on floor if the filter returns false.
filter(Event) - Method in class solar.service.pack.filter.RANDOM
 
filter(Event) - Method in class solar.service.pack.filter.EVEN
 
filter(Event) - Method in class solar.service.pack.filter.ODD
 
filter(Event) - Method in class solar.service.pack.filter.GE
 
filter(Reply) - Method in class org.doit.muffin.filter.LoggerFilter
 
filter(Request) - Method in class org.doit.muffin.filter.LoggerFilter
 
FilterConfig - class solar.service.pack.lang.FilterConfig.
A configuration of a PACK filter, such as its parameters.
FilterConfig() - Constructor for class solar.service.pack.lang.FilterConfig
 
FilterSpec - class solar.service.dan.lang.FilterSpec.
The spec for a filter node as either source or sink of a connecting pipe.
FilterSpec() - Constructor for class solar.service.dan.lang.FilterSpec
 
first - Variable in class solar.util.ssLinkedList
 
FlatDirectory - class solar.service.directory.FlatDirectory.
A flat directory is a hashtable with name strands as the keys.
FlatDirectory.NameInfo - class solar.service.directory.FlatDirectory.NameInfo.
 
FlatDirectory.NameInfo() - Constructor for class solar.service.directory.FlatDirectory.NameInfo
 
FlatDirectory() - Constructor for class solar.service.directory.FlatDirectory
Constructs an empty flat name space.
FlickerTrigger - class campus.sysnort.trigger.FlickerTrigger.
A Sysnort trigger that detects a flickering card, which is associated with an AP for a short time before next rotation.
FlickerTrigger.ClientState - class campus.sysnort.trigger.FlickerTrigger.ClientState.
 
FlickerTrigger.ClientState(String) - Constructor for class campus.sysnort.trigger.FlickerTrigger.ClientState
 
FlickerTrigger() - Constructor for class campus.sysnort.trigger.FlickerTrigger
 
floor - Variable in class campus.syslog.APLocation
 
FLOW - Static variable in class solar.service.dan.lang.XmlSpecParser
 
flush() - Method in class solar.module.cache.BaseCache
 
flush() - Method in interface solar.module.cache.Cache
Flush all the objects in the cache.
FORK_TASK - Static variable in interface solar.service.fork.ForkConstants
 
ForkClient - class solar.service.fork.client.ForkClient.
The interface to interact with Fork service.
ForkClient(Options) - Constructor for class solar.service.fork.client.ForkClient
 
ForkConstants - interface solar.service.fork.ForkConstants.
Constants for FORK service.
ForkException - exception solar.service.fork.ForkException.
A generic exception thrown by mobile host services.
ForkException(String) - Constructor for class solar.service.fork.ForkException
Construct an ForkException with specified detail message.
ForkException(String, Throwable) - Constructor for class solar.service.fork.ForkException
Construct an ForkException with specified detail message and nested Throwable.
ForkException(Throwable) - Constructor for class solar.service.fork.ForkException
Construct an ForkException with specified nested Throwable.
ForkService - interface solar.service.fork.ForkService.
It allows on-demand process creation, for instance, to create another Planet.
format(LogRecord) - Method in class versus.meeting.LogFormatter
 
formatTime() - Method in class campus.snmp.SnmpLocator
Format current time for logging.
formatTime(long) - Method in class campus.snmp.SnmpLocator
 
forwardHandler(ScribeMessage) - Method in class solar.service.pack.ScribeManager
Called by Scribe before the node forwards a message to its children in the multicast tree.
forwardHandler(ScribeMessage) - Method in class solar.service.pubsub.ScribeManager
Called by Scribe before the node forwards a message to its children in the multicast tree.
forwardHandler(ScribeMessage) - Method in class solar.service.multicast.ScribeMulticastService.ScribeMember
Called by Scribe before the node forwards a message to its children in the multicast tree.
ForwardProtocol - class solar.service.pack.proto.ForwardProtocol.
Protocol handles forwarding events to next server on the path.
ForwardProtocol(int, int, int) - Constructor for class solar.service.pack.proto.ForwardProtocol
 
free_lle(ssLinkedList.ssLinkedListElement) - Method in class solar.util.ssLinkedList
 
frequency - Variable in class campus.syslog.APConfiguration
 
fromHexString(String) - Static method in class solar.util.StringUtil
Convert a hex string to byte array.

G

gamma - Variable in class versus.meeting.RLearner
 
gateway - Variable in class campus.syslog.APConfiguration
 
GE - class solar.service.pack.filter.GE.
The PACK filter implements greater-equal operator.
GE() - Constructor for class solar.service.pack.filter.GE
 
generateNodeHandle(InetSocketAddress) - Method in class rice.pastry.wire.UdpPastryNodeFactory
Method which contructs a node handle (using the wire protocol) for the node at address NodeHandle.
generateNodeHandle(InetSocketAddress) - Method in class rice.pastry.wire.TcpPastryNodeFactory
Method which contructs a node handle (using the wire protocol) for the node at address NodeHandle.
generateNodeHandle(InetSocketAddress) - Method in class rice.pastry.socket.SocketPastryNodeFactory
Method which contructs a node handle (using the wire protocol) for the node at address NodeHandle.
GeobytesSource - class campus.compass.GeobytesSource.
Given an IP address, determine its geo location using a Web site.
GeobytesSource() - Constructor for class campus.compass.GeobytesSource
 
get_comparator(Object, ssLinkedListComparator) - Method in class solar.util.ssLinkedList
Gets the first object to match according to the comparator function.
get_head() - Method in class solar.util.ssLinkedList
Gets the head object from the linked list.
get_item(Object) - Method in class solar.util.ssLinkedList
Returns the first object that is "equal" to the given object, based on the response of the Object.equals() method.
get_tail() - Method in class solar.util.ssLinkedList
Gets the tail object from the linked list.
get() - Method in class solar.module.protocol.Buffer
Get and remove an event from the buffer.
get(NodeId) - Method in class rice.pastry.socket.SocketNodeHandlePool
 
getAck() - Method in class solar.service.pack.comm.AckEvent
 
getActionObject() - Method in class campus.sysnort.Trigger
Get the object containing all necessary info to take an action.
getActionSelection() - Method in class versus.meeting.RLearner
 
getAddress() - Method in class solar.service.transport.PastryTransport
 
getAddress() - Method in class solar.service.rmtobj.RemoteObject
 
getAddress() - Method in class solar.service.rmtobj.comm.PingEvent
 
getAddress() - Method in class solar.service.dan.comm.PipeConnectRequest
 
getAddress() - Method in class solar.service.dan.lang.FilterSpec
 
getAddress() - Method in class solar.service.directory.RemoteDirectoryListener
 
getAddress() - Method in class solar.service.directory.NameRecord
Return the current contact address of corresponding name.
getAddress() - Method in class rice.pastry.socket.HelloResponseMessage
Returns the address of the source of this message.
getAddress() - Method in class rice.pastry.socket.HelloMessage
Returns the address of the source of this message.
getAddress(Guid) - Method in class solar.service.dan.GraphManager
Return the currrent address of the node with specified guid.
getAddress(Id) - Method in class solar.service.pack.EndPointManager
 
getAddress(Id) - Method in class solar.service.pubsub.EndPointManager
 
getAddress(InetAddress) - Method in class rice.pastry.wire.WireNodeHandle
Utility method for converting an InetAddress to an int (for comparison purposes).
getAddress(int) - Method in class rice.pastry.wire.UdpPastryNodeFactory
Method which constructs an InetSocketAddres for the local host with the specifed port number.
getAddress(int) - Method in class rice.pastry.wire.TcpPastryNodeFactory
Method which constructs an InetSocketAddres for the local host with the specifed port number.
getAddress(int) - Method in class rice.pastry.socket.SocketPastryNodeFactory
Method which constructs an InetSocketAddres for the local host with the specifed port number.
getAddressByKey(String) - Method in class solar.service.transport.UdpTransport
 
getAddressByKey(String) - Method in class solar.service.transport.TcpTransport
 
getAddressByKey(String) - Method in class solar.service.transport.BaseTransportService
 
getAddressByKey(String) - Method in class solar.service.transport.PastryTransport
 
getAddressByKey(String) - Method in interface solar.service.transport.Transport
Return a peer address by specified key.
getAddressByKey(String) - Method in interface solar.service.transport.TransportService
Return a peer address based on the specified key.
getAdu() - Method in class solar.service.transport.PastryMessage
 
getAdu() - Method in class solar.service.dispatch.DispatchUnit
 
getAdu(int) - Method in class solar.test.GroundHog
 
getAduFactory() - Method in class solar.service.transport.TcpTransport
Return the factory producing Adu from byte array.
getAduSize(Adu) - Method in class solar.test.GroundHog
 
getAll() - Method in class solar.module.protocol.Buffer
 
getAlpha() - Method in class versus.meeting.RLearner
 
getAntenna() - Method in class campus.AccessPoint
 
getAPBuildingByMACAddress(String) - Method in class campus.syslog.APMapping
Return a building name for AP given the MAC address of AP.
getApByIp(String) - Method in class campus.snmp.SnmpLocator
Return the current AP of the specified IP address.
getApByIp(String) - Static method in class campus.compass.CompassService
 
getApByMac(String) - Method in class campus.snmp.SnmpLocator
Return the current AP of the specified MAC.
getAPConfigurationByMACAddress(String) - Method in class campus.syslog.APMapping
Return a AP configuration given MAC address of AP.
getAPFloorByMACAddress(String) - Method in class campus.syslog.APMapping
Return a AP's floor # given MAC address of AP.
getAPLocationByAPName(String) - Method in class campus.syslog.APMapping
Return a AP Location clasee given the name of AP.
getAPLocationByMACAddress(String) - Method in class campus.syslog.APMapping
Return a AP Location clasee given MAC address of AP.
getApName() - Method in class campus.snmp.ApStat
 
getAPNameByMACAddress(String) - Method in class campus.syslog.APMapping
Return a AP name given MAC address of AP.
getApStat(String) - Method in class campus.snmp.SnmpLocator
Return some statistics of the specified AP.
getApStatByIp(String) - Static method in class campus.compass.CompassService
 
getArguments() - Method in class solar.service.pack.lang.FilterConfig
 
getArguments() - Method in class solar.service.dan.lang.FilterSpec
 
getArguments() - Method in class campus.sysnort.TriggerConfig
 
getAttachedClients() - Method in class solar.service.mhost.SolarMobileHostService
 
getAttachedClients() - Method in interface solar.service.mhost.MobileHostService
Get all the clients currently attached to this Planet.
getAttachedServer() - Method in class solar.service.mhost.SolarMobileHostService
 
getAttachedServer() - Method in interface solar.service.mhost.MobileHostService
Get the Planet address to which this client is attached.
getAttribute(String) - Method in interface solar.api.AttributeRecord
Return the first attribute with specified key.
getAttribute(String) - Method in class solar.impl.AbstractAttributeRecord
 
getAttributes() - Method in interface solar.api.AttributeRecord
Return the list of all attributes.
getAttributes() - Method in class solar.impl.AbstractAttributeRecord
 
getAttributes(NameNode) - Method in class solar.service.directory.FlatDirectory
 
getAttributes(String) - Method in interface solar.api.AttributeRecord
Return all the attributes with specified key.
getAttributes(String) - Method in class solar.impl.AbstractAttributeRecord
 
getBadges() - Method in class versus.XmlVersusParser
Return the parsed badge mapping.
getBestAction(int[]) - Method in class versus.meeting.RLPolicy
 
getBlock() - Method in class solar.service.rpc.comm.ReplyEvent
 
getBlock() - Method in class solar.service.rpc.comm.RequestEvent
 
getBlock(Object) - Static method in class solar.service.rpc.Block
Get the block EQUALS to specified key from repository.
getBufferedEvent() - Method in class solar.service.pack.proto.GroupBufferHandle
 
getBufferedEvent() - Method in class solar.service.pack.proto.SingleBufferHandle
 
getBufferedEvent() - Method in interface solar.service.pack.proto.BufferHandle
Return the next event from buffers in this handle.
getBuilding() - Method in class campus.AccessPoint
 
getBuildingByAp(String) - Method in class campus.CampusMap
 
getBuildingCode(String) - Static method in class campus.AccessPoint
Convert an AP name to a code representing one building.
getBytes() - Method in class solar.service.transport.PastryMessage
 
getCachedObject(Object) - Method in class solar.module.cache.BaseCache
 
getCachedObject(Object) - Method in interface solar.module.cache.Cache
Get the container for an object from the cache.
getCachedObjects() - Method in class solar.module.cache.BaseCache
 
getCachedObjects() - Method in interface solar.module.cache.Cache
Get the list of the cached objects from the cache.
getCapacity() - Method in class solar.module.cache.BaseCache
 
getCapacity() - Method in interface solar.module.cache.Cache
Get the capacity of the cache.
getCategory() - Method in class campus.Building
 
getCategory(String) - Method in class campus.syslog.CatalogBuildingMapping
function to convert building name to category of the building.
getCertainty() - Method in class campus.Location
 
getChannel() - Method in class campus.AccessPoint
 
getChild(String) - Method in class solar.service.directory.NameNode
Return a child node with specified label.
getChildren() - Method in class solar.service.directory.NameNode
Return the set of children of this name node.
getChildren(Id) - Method in class solar.service.pack.ScribeManager
Get the children address of this node for specified topic.
getCity() - Method in class campus.Location
 
getCity(String) - Static method in class campus.compass.ZipCodeSource
Return the city for specified zipcode.
getCityHtml() - Method in class campus.Location
 
getCityUrl() - Method in class campus.Location
 
getClassname() - Method in class solar.service.dan.lang.FilterSpec
 
getClassname() - Method in class campus.sysnort.TriggerConfig
 
getClient() - Method in class solar.service.mhost.comm.DetachRequest
 
getClient() - Method in class solar.service.mhost.comm.AttachRequest
 
getClientIp() - Method in class org.doit.muffin.filter.CompassFilter
 
getClientIpAddress(Request) - Method in class org.doit.muffin.filter.Logger
 
getClientLocation() - Method in class org.doit.muffin.filter.CompassFilter
 
getCode() - Method in class campus.Building
 
getCodebase() - Method in class solar.service.dan.lang.FilterSpec
 
getCodebase() - Method in class campus.sysnort.TriggerConfig
 
getCompassBody() - Method in class org.doit.muffin.filter.CompassFilter
 
getCompassFooter() - Method in class org.doit.muffin.filter.CompassFilter
 
getCompassHeader() - Method in class org.doit.muffin.filter.CompassFilter
 
getCompassHtml() - Method in class org.doit.muffin.filter.CompassFilter
 
getCompassTab(String, String) - Method in class org.doit.muffin.filter.CompassFilter
 
getConnection(SocketAddress) - Method in class solar.service.transport.TcpTransport
Get the connection for specified peer address.
getContent(File) - Static method in class solar.util.FileUtil
Return the content of a file as a string.
getContent(FileReader) - Static method in class solar.util.FileUtil
 
getContent(String) - Static method in class solar.util.FileUtil
Return the content of a file as a string.
getCoolFilter() - Method in class solar.service.pack.PackPolicy
 
getCountry() - Method in class campus.Location
 
getCountryCode(String) - Static method in class campus.compass.CountryCode
Get 2-digit code of a country for specified name.
getCountryName(String) - Static method in class campus.compass.CountryCode
Get full name of a country for specified code.
getCreated() - Method in class solar.module.cache.CachedObject
Returns the creation time for the object.
getCredentials() - Method in class solar.service.transport.PastryTransport
 
getData() - Method in class solar.service.fap.comm.PipePushEvent
 
getDataSink() - Method in class solar.service.fap.LocalSinkChannel
 
getDataSink() - Method in class solar.service.fap.RemoteSinkChannel
 
getDataSink() - Method in interface solar.service.fap.SinkChannel
Return the data sink of this pipe.
getDataSource() - Method in class solar.service.fap.LocalSourceChannel
 
getDataSource() - Method in class solar.service.fap.RemoteSourceChannel
 
getDataSource() - Method in interface solar.service.fap.SourceChannel
Return the data source of this pipe.
getDefaultOptions() - Method in class solar.Client
 
getDefaultOptions() - Method in class solar.service.pack.client.PackClient
 
getDefaultOptions() - Method in class solar.service.fork.client.ForkClient
 
getDefaultOptions() - Method in class solar.service.pubsub.client.PubSubClient
 
getDependentService(String, String) - Method in class solar.service.BaseService
This method is provided so service can specify a different name key for other services used by it.
getDestination() - Method in class solar.service.pack.proto.BufferedEvent
If return null, then it is multicast event otherwise it is unicast.
getDestination() - Method in class solar.service.transport.Header
 
getDestination() - Method in class solar.service.fork.Task
 
getDestination() - Method in class rice.pastry.socket.HelloResponseMessage
Returns the NodeId of the source
getDestination() - Method in class rice.pastry.socket.HelloMessage
Returns the NodeId of the source
getDimension() - Method in class versus.meeting.RLMeetingWorld
 
getDimension() - Method in interface versus.meeting.RLWorld
Returns the array containing the information about the number of states in each dimension ( [0] - [array.length - 2] ) and the number of possible actions ( [array.length - 1] ).
getDirectoryService() - Method in class solar.service.dan.DanClientService
 
getDirectoryService() - Method in class solar.service.dan.AbstractDanService
 
getDirectoryService() - Method in interface solar.service.dan.DanService
Get the directory service used by DAN.
getDispatchService() - Method in class solar.service.fap.FapClientService
 
getDispatchService() - Method in interface solar.service.fap.FapService
Return the dispatch service.
getEncoding() - Method in interface solar.api.Address
Return the encoding of this address.
getEncoding() - Method in interface solar.api.Event
Return the encoding type.
getEncoding() - Method in class solar.impl.SerializedEvent
 
getEncoding() - Method in class solar.impl.PlainEvent
 
getEncoding() - Method in class solar.service.transport.SocketAddress
 
getEncoding() - Method in class solar.service.transport.PastryAddress
 
getEndPoint(Id) - Method in class solar.service.pack.EndPointManager
 
getEndPoint(Id) - Method in class solar.service.pubsub.EndPointManager
 
getEndTime() - Method in class solar.service.fork.Task
 
getEpisodes() - Method in class versus.meeting.RLearner
 
getEpsilon() - Method in class versus.meeting.RLearner
 
getEvent() - Method in interface solar.module.protocol.Protocol
Get an event from protocol buffers for processing.
getEvent() - Method in class solar.service.pack.proto.FairQueueOBM
 
getEvent() - Method in interface solar.service.pack.proto.OutputBufferManager
 
getEvent() - Method in class solar.service.pack.proto.BufferedEvent
Return the contained event for wire transfer.
getEvent() - Method in class solar.service.pack.proto.BaseProtocol
 
getEvent() - Method in class solar.service.pack.comm.PackEvent
 
getEvent() - Method in class solar.service.pubsub.comm.PubEvent
 
getEvent() - Method in class solar.service.multicast.comm.ReceiveRequest
 
getExpires() - Method in class solar.module.cache.CachedObject
Returns the expiration time for the object.
getExtra() - Method in class solar.service.pubsub.comm.SubscribeRequest
 
getFactory(boolean, NodeIdFactory, int, int) - Static method in class rice.pastry.socket.SocketPastryNodeFactory
Static method which is designed to be used by clients needing a distrubuted pastry node factory.
getFactory(boolean, NodeIdFactory, int, int) - Static method in class rice.pastry.dist.NewDistPastryNodeFactory
Static method which is designed to be used by clients needing a distrubuted pastry node factory.
getFakeIds(Id) - Method in class solar.service.pack.ScribePackService
 
getFapService() - Method in class solar.service.dan.DanClientService
 
getFapService() - Method in class solar.service.dan.AbstractDanService
 
getFapService() - Method in interface solar.service.dan.DanService
Get the fap service used by DAN.
getFilter(String) - Method in class solar.service.dan.lang.GraphSpec
 
getFilters() - Method in class solar.service.pack.PackPolicy
Get the ordered PACK filters encoded in their handlers.
getFloor() - Method in class campus.AccessPoint
 
getFloorplan() - Method in class versus.XmlVersusParser
Return the parsed floorplan.
getFlow() - Method in class solar.service.dan.lang.PipeSpec
 
getFullCommand() - Method in class solar.service.fork.Task
 
getGamma() - Method in class versus.meeting.RLearner
 
getGateway() - Method in class campus.AccessPoint
 
getGoogleTab() - Method in class org.doit.muffin.filter.CompassFilter
 
getGraphRoot() - Method in class solar.service.dan.comm.SubscribeRequest
 
getGraphSpec() - Method in class solar.service.dan.comm.AdvertiseRequest
 
getGraphSpec() - Method in class solar.service.dan.comm.SubscribeRequest
 
getGraphSpec() - Method in class solar.service.dan.lang.XmlSpecParser
Return recent parsed graph spec.
getGroupId() - Method in class solar.service.multicast.MulticastGroup
 
getGroupId() - Method in class solar.service.multicast.comm.MulticastRequest
 
getGroupId() - Method in class solar.service.multicast.comm.LeaveRequest
 
getGroupId() - Method in class solar.service.multicast.comm.JoinRequest
 
getGroupKeys() - Method in class solar.service.pack.PackPolicy
Get the group attributes for the stream.
getGuid() - Method in class solar.service.dan.comm.AdvertiseRequest
 
getGuid() - Method in class solar.service.dan.comm.SubscribeRequest
 
getGuid(String) - Method in class solar.service.dan.GraphManager
Return the guid for loaded operator defined in graph spec.
getHandler() - Method in class solar.service.rpc.comm.RequestEvent
 
getHeader() - Method in class solar.service.transport.PastryMessage
 
getHost() - Method in class solar.service.routing.comm.RoutingEvent
 
getHotFilter() - Method in class solar.service.pack.PackPolicy
 
getId() - Method in interface solar.api.Identifiable
Return the ID of this object.
getId() - Method in class solar.service.pack.PackFilter
 
getId() - Method in class solar.service.pack.comm.ScribeRootRequest
 
getId() - Method in class solar.service.rmtobj.RemoteObject
 
getId() - Method in class solar.service.rmtobj.comm.RegisterRequest
 
getId() - Method in class solar.service.rmtobj.comm.UnregisterRequest
 
getId() - Method in class solar.service.dan.GraphNode
 
getId() - Method in class solar.service.multicast.comm.ReceiveRequest
 
getId() - Method in class solar.service.fap.Pipe
 
getId() - Method in class solar.service.directory.RemoteDirectoryListener
 
getId() - Method in class solar.service.directory.NameRecord
Return the guid of corresponding name.
getId() - Method in class solar.service.directory.comm.NameMigratedRequest
 
getId() - Method in class solar.service.directory.comm.NameUpdatedRequest
 
getId() - Method in class solar.service.directory.comm.NameRemovedRequest
 
getId() - Method in class solar.service.directory.comm.NameAddedRequest
 
getIds() - Method in class solar.service.rmtobj.comm.PingEvent
 
getInetAddress() - Method in class solar.service.transport.SocketAddress
Return IP address.
getInetAddress(String) - Static method in class solar.util.NetUtil
Get the InetAddress from host name, special treat on localhost.
getInfo() - Method in class campus.AccessPoint
 
getInitValues() - Method in class versus.meeting.RLMeetingWorld
 
getInitValues() - Method in interface versus.meeting.RLWorld
Gets the initial value for the policy.
getInputFilter() - Method in class solar.service.dan.lang.PipeSpec
 
getInputPipes() - Method in class solar.service.dan.NodeHandler
 
getInputPipes() - Method in interface solar.service.fap.DataSink
Return all the input pipes in an array.
getInputPort() - Method in class solar.service.dan.lang.PipeSpec
 
getInputPort() - Method in class solar.service.fap.LocalSinkChannel
 
getInputPort() - Method in class solar.service.fap.RemoteSinkChannel
 
getInputPort() - Method in interface solar.service.fap.SinkChannel
Return the input port of the connected sink.
getInputPort() - Method in class solar.service.fap.Pipe
Return the name of the input port for this pipe.
getInputPorts() - Method in class solar.service.dan.Source
 
getInputPorts() - Method in class solar.service.dan.GraphNode
Return a list of input ports of this node.
getInputPorts() - Method in class solar.service.dan.NodeHandler
 
getInputPorts() - Method in class solar.service.dan.lang.FilterSpec
 
getInputPorts() - Method in interface solar.service.fap.DataSink
Return all the input ports in an array.
getInputQuery() - Method in class solar.service.dan.lang.PipeSpec
 
getInputs() - Method in class solar.service.dan.lang.FilterSpec
 
getInstance() - Static method in class solar.service.SolarServices
 
getInstance() - Static method in class solar.service.pack.proto.BufferManagerFactory
 
getIpAddress() - Method in class campus.AccessPoint
 
getIpAddress(InetAddress) - Static method in class solar.util.NetUtil
Get the digital IP address (no host name) in string format.
getKey() - Method in class solar.api.Attribute
Return the attribute key.
getKeys() - Method in interface solar.api.AttributeRecord
Return the list of all keys.
getKeys() - Method in class solar.impl.AbstractAttributeRecord
 
getLabel() - Method in class solar.service.directory.NameNode
Return the label of this name node.
getLastHop() - Method in class solar.service.pack.comm.SubscribeEvent
 
getLastHop() - Method in class solar.service.routing.comm.RoutingEvent
 
getLearningMethod() - Method in class versus.meeting.RLearner
 
getListener() - Method in class solar.service.directory.comm.RemoveListenerRequest
 
getListener() - Method in class solar.service.directory.comm.AddListenerRequest
 
getLocal(Guid) - Method in class solar.service.dan.NodeManager
Get a local node (handler) with specified guid.
getLocalAddress() - Method in class solar.service.transport.UdpTransport
 
getLocalAddress() - Method in class solar.service.transport.TcpTransport
 
getLocalAddress() - Method in class solar.service.transport.BaseTransportService
 
getLocalAddress() - Method in class solar.service.transport.PastryTransport
 
getLocalAddress() - Method in interface solar.service.transport.Transport
Return the local address of this transport layer.
getLocalAddress() - Method in interface solar.service.transport.TransportService
Return local address for this transport service.
getLocalAddress() - Method in class solar.service.dan.DanClientService
 
getLocalAddress() - Method in class solar.service.dan.AbstractDanService
 
getLocalAddress() - Method in interface solar.service.dan.DanService
Return the local address of the resident Planet.
getLocation(String, String) - Method in class versus.VersusMapping
Return a location name given collector and sensor numbers, return null if not found.
getLocationByIp(String) - Static method in class campus.compass.CompassService
 
getLocationByIp(String) - Static method in class campus.compass.GeobytesSource
 
getLocationByIp(String) - Static method in class campus.compass.WhoisSource
 
getLocationHtml(Location) - Method in class org.doit.muffin.filter.CompassFilter
 
getLogger() - Method in class solar.service.transport.TcpTransport
Return the logger of this transport.
getMacAddress() - Method in class campus.AccessPoint
 
getMACAddressByAPName(String) - Method in class campus.syslog.APMapping
Return a MAC address of AP given the name of AP.
getMaxQValue(int[]) - Method in class versus.meeting.RLPolicy
 
getMembers() - Method in class solar.service.multicast.MulticastGroup
 
getMobileHostService() - Method in class solar.service.pack.client.PackClient
 
getModel() - Method in class campus.AccessPoint
 
getMulticastEvent() - Method in class solar.service.multicast.comm.MulticastRequest
 
getMultiplexId() - Method in class solar.service.transport.Header
 
getName() - Method in class solar.service.BaseService
 
getName() - Method in interface solar.service.Service
Return the name of this service.
getName() - Method in class solar.service.dan.comm.AdvertiseRequest
 
getName() - Method in class solar.service.dan.lang.FilterSpec
 
getName() - Method in class solar.service.dan.lang.PipeSpec
 
getName() - Method in class solar.service.fap.Port
 
getName() - Method in class solar.service.directory.Advertisement
Return the name in this advertisement.
getName() - Method in class solar.service.directory.comm.NameMigratedRequest
 
getName() - Method in class solar.service.directory.comm.NameRemovedRequest
 
getName() - Method in class solar.service.directory.comm.NameAddedRequest
 
getName() - Method in class solar.service.directory.comm.UnadvertiseRequest
 
getName() - Method in class solar.service.directory.comm.AdvertiseRequest
 
getName() - Method in class campus.AccessPoint
 
getName() - Method in class campus.Building
 
getName() - Method in class campus.sysnort.Trigger
Get the name of this trigger.
getName() - Method in class campus.sysnort.TriggerConfig
 
getName(String) - Method in class versus.VersusMapping
Return a symbolic name given a badge number, return null if not found.
getNameByGroupId(Id) - Method in class solar.service.multicast.NaiveMulticastService
 
getNameExtra() - Method in class solar.service.dan.comm.AdvertiseRequest
 
getNameHtml() - Method in class campus.Building
 
getNameRecord() - Method in class solar.service.directory.Advertisement
Return the name record in this advertisement.
getNameRecord() - Method in class solar.service.directory.comm.NameRemovedRequest
 
getNameRecord() - Method in class solar.service.directory.comm.NameAddedRequest
 
getNameRecord() - Method in class solar.service.directory.comm.UnadvertiseRequest
 
getNameRecord() - Method in class solar.service.directory.comm.AdvertiseRequest
 
getNewBuildingName(String) - Method in class campus.syslog.BuildingNameConvertor
 
getNewName() - Method in class solar.service.directory.comm.NameUpdatedRequest
 
getNewName() - Method in class solar.service.directory.comm.UpdateRequest
 
getNewNameRecord() - Method in class solar.service.directory.comm.NameMigratedRequest
 
getNewNameRecord() - Method in class solar.service.directory.comm.NameUpdatedRequest
 
getNewNameRecord() - Method in class solar.service.directory.comm.UpdateRequest
 
getNextEvent() - Method in class versus.meeting.RLMeetingAgent
 
getNextHop(Address) - Method in class solar.service.routing.DirectRoutingService
 
getNextHop(Address) - Method in class solar.service.routing.ManualRoutingService
 
getNextHop(Address) - Method in interface solar.service.routing.RoutingService
Return the next hop for the messages with specified destination.
getNextInt() - Static method in class solar.api.Id
 
getNextInterval(Exponential) - Method in class solar.test.GroundHog
 
getNextInterval(Exponential) - Method in class solar.test.PackSender
 
getNextState(int) - Method in class versus.meeting.RLMeetingWorld
 
getNextState(int) - Method in interface versus.meeting.RLWorld
Returns a new instance of the new state that results from applying the given action to the current state.
getNextState(int[]) - Method in class versus.meeting.RLPolicy
 
getNodeAddress(Id) - Method in class solar.service.pack.ScribeManager
Convert a Solar ID to Pastry address.
getNodeAddress(NodeId) - Method in class solar.service.pack.ScribeManager
Convert a Pastry NodeID to Pastry address.
getNodeHandlePool() - Method in class rice.pastry.socket.SocketPastryNode
 
getNodeId() - Method in class solar.service.transport.PastryAddress
Return the pastry node ID for this address.
getNodeId() - Method in class rice.pastry.socket.HelloResponseMessage
Returns the NodeId of the source
getNodeId() - Method in class rice.pastry.socket.HelloMessage
Returns the NodeId of the source
getNodeId(Id) - Method in class solar.service.pack.ScribeManager
Get/Update the Id-NodeId mapping from cache.
getNodeManager() - Method in class solar.service.dan.DanClientService
 
getNodeManager() - Method in class solar.service.dan.AbstractDanService
 
getNodeManager() - Method in interface solar.service.dan.DanService
Return the node manager for this DAN service.
getNumClients() - Method in class campus.snmp.ApStat
 
getObject() - Method in class solar.module.cache.CachedObject
Return the cached object.
getObject() - Method in class solar.service.directory.NameRecord
Get the app-specific object registed with this name.
getObject(Object) - Method in class solar.module.cache.BaseCache
 
getObject(Object) - Method in interface solar.module.cache.Cache
Get an object from the cache.
getObjectId() - Method in class solar.module.cache.CachedObject
Return the id of the cached object.
getObjectIds() - Method in class solar.module.cache.BaseCache
 
getObjectIds() - Method in interface solar.module.cache.Cache
Get the list of the object ids from the cache.
getObjects() - Method in class solar.module.cache.BaseCache
 
getObjects() - Method in interface solar.module.cache.Cache
Get the list of the objects from the cache.
getOldName() - Method in class solar.service.directory.comm.NameUpdatedRequest
 
getOldName() - Method in class solar.service.directory.comm.UpdateRequest
 
getOldNameRecord() - Method in class solar.service.directory.comm.NameMigratedRequest
 
getOldNameRecord() - Method in class solar.service.directory.comm.NameUpdatedRequest
 
getOldNameRecord() - Method in class solar.service.directory.comm.UpdateRequest
 
getOpVariable(Name) - Static method in class solar.service.dan.lang.GraphSpec
Return the operator variable used by specified CS name.
getOutput() - Method in class solar.service.dan.lang.PipeSpec
 
getOutputPipes() - Method in class solar.service.dan.NodeHandler
 
getOutputPipes() - Method in interface solar.service.fap.DataSource
Return all the output pipes in an array.
getOutputPort() - Method in class solar.service.dan.lang.PipeSpec
 
getOutputPort() - Method in class solar.service.fap.LocalSourceChannel
 
getOutputPort() - Method in class solar.service.fap.RemoteSourceChannel
 
getOutputPort() - Method in interface solar.service.fap.SourceChannel
Return the output port of connected data source.
getOutputPort() - Method in class solar.service.fap.Pipe
Return the name of the output port for this pipe.
getOutputPorts() - Method in class solar.service.dan.Application
 
getOutputPorts() - Method in class solar.service.dan.GraphNode
Return a list of output ports of this node.
getOutputPorts() - Method in class solar.service.dan.NodeHandler
 
getOutputPorts() - Method in class solar.service.dan.lang.FilterSpec
 
getOutputPorts() - Method in interface solar.service.fap.DataSource
Return all the output ports in an array.
getOutputs() - Method in class solar.service.dan.lang.FilterSpec
 
getPackPolicy() - Method in class solar.service.pack.lang.XmlPolicyParser
Return recent parsed PACK policy.
getPackPolicy() - Method in class campus.sysnort.Trigger
Return the PACK policy for this trigger, default as empty.
getParent() - Method in class solar.service.directory.NameNode
Return the parent node of this name node.
getParent(Id) - Method in class solar.service.pack.ScribeManager
Get the parent address of this node for specified topic.
getPastryNode() - Method in class solar.service.transport.PastryTransport
 
getPastryTransport(SocketAddress) - Method in class solar.service.transport.PastryTransportService
Return the instance of Pastry transport layer.
getPattern() - Method in class solar.service.directory.comm.RemoveListenerRequest
 
getPattern() - Method in class solar.service.directory.comm.AddListenerRequest
 
getPattern() - Method in class solar.service.directory.comm.LookupRequest
 
getPipe(Id) - Method in class solar.service.fap.FapClientService
 
getPipe(Id) - Method in interface solar.service.fap.FapService
Return a pipe given its ID.
getPipe(String) - Method in class solar.service.dan.lang.GraphSpec
 
getPipeId() - Method in class solar.service.dan.comm.PipeConnectRequest
 
getPipeId() - Method in class solar.service.fap.comm.PipePushEvent
 
getPipeId() - Method in class solar.service.fap.comm.PipePullRequest
 
getPipeType() - Method in class solar.service.dan.comm.PipeConnectRequest
 
getPlainEvent(List) - Static method in class solar.impl.EventFactory
Return a plain event with a list of attributes.
getPlainEvent(String) - Static method in class solar.impl.EventFactory
Return a plain event by parsing a string.
getPolicy() - Method in class solar.service.pack.comm.SubscribeEvent
 
getPolicy() - Method in class solar.service.pack.comm.SubscribeRequest
 
getPolicy() - Method in class solar.test.PackReceiver
 
getPolicy() - Method in class versus.meeting.RLearner
 
getPort() - Method in class solar.service.transport.TcpTransport
Return the port number listened by this transport.
getPort() - Method in class solar.service.transport.SocketAddress
Return port number.
getPower() - Method in class campus.AccessPoint
 
getPrefs() - Method in class org.doit.muffin.filter.Logger
 
getPrefs() - Method in class org.doit.muffin.filter.Compass
 
getPubId() - Method in class solar.service.pack.proto.GroupBufferHandle
 
getPubId() - Method in class solar.service.pack.proto.SingleBufferHandle
 
getPubId() - Method in interface solar.service.pack.proto.BufferHandle
Return the publisher ID of this handle.
getPubId() - Method in class solar.service.pack.proto.BufferedEvent
Return the ID of the publisher for this event.
getPubId() - Method in class solar.service.pack.comm.AckEvent
 
getPubId() - Method in class solar.service.pack.comm.PackEvent
 
getPubId() - Method in class solar.service.pack.comm.SubscribeEvent
 
getPubId() - Method in class solar.service.pack.comm.SubscribeRequest
 
getPubId() - Method in class solar.service.pack.comm.AttachPublisherRequest
 
getPubId() - Method in class solar.service.pack.comm.DetachPublisherRequest
 
getPubId() - Method in class solar.service.pubsub.comm.PubEvent
 
getPubId() - Method in class solar.service.pubsub.comm.PubRegisterRequest
 
getPubId() - Method in class solar.service.pubsub.comm.SubscribeRequest
 
getQuery() - Method in class solar.service.dan.comm.LookupRequest
 
getQuery() - Method in class solar.service.fap.comm.PipePullRequest
 
getQueue() - Method in class rice.pastry.wire.SocketChannelWriter
Returns the queue of writes for the remote address
getQValue(int[], int) - Method in class versus.meeting.RLPolicy
 
getQValuesAt(int[]) - Method in class versus.meeting.RLPolicy
 
getRecords() - Method in class solar.service.directory.NameNode
Return the set of name records for this name node.
getRegion(String) - Static method in class campus.compass.ZipCodeSource
Return the region (city and state) for specified zipcode.
getRemote(Guid) - Method in class solar.service.dan.NodeManager
Get the address of a remote node.
getRemoteAddress() - Method in class solar.service.fap.RemoteSinkChannel
Return the address of remote source.
getRemoteAddress() - Method in class solar.service.fap.RemoteSourceChannel
Return the address of remote source.
getRemoteInputPort() - Method in class solar.service.fap.RemoteSinkChannel
Return the input port of the remote sink.
getRemoteMulticastMember() - Method in class solar.service.multicast.comm.LeaveRequest
 
getRemoteMulticastMember() - Method in class solar.service.multicast.comm.JoinRequest
 
getRemoteOutputPort() - Method in class solar.service.fap.RemoteSourceChannel
Return the output port of the remote source.
getRemotePipeId() - Method in class solar.service.fap.RemoteSinkChannel
Return the ID of remote pipe.
getRemotePipeId() - Method in class solar.service.fap.RemoteSourceChannel
Return the ID of remote pipe.
getReply() - Method in class solar.service.rpc.comm.ReplyEvent
 
getRequest() - Method in class solar.service.rpc.comm.RequestEvent
 
getResponse(SocketPastryNode) - Method in class rice.pastry.socket.HelloMessage
Returns the appropriate response for this HelloMessage
getReward() - Method in class versus.meeting.RLMeetingWorld
 
getReward() - Method in interface versus.meeting.RLWorld
Returns the value for the last reward received from calling the method getNextState( int action ).
getRpcService() - Method in class solar.service.dan.DanClientService
 
getRpcService() - Method in class solar.service.dan.AbstractDanService
 
getRpcService() - Method in interface solar.service.dan.DanService
Get the rpc service used by DAN.
getRpcService(Id) - Method in class solar.service.fap.SolarFapService
 
getRpcService(Id) - Method in class solar.service.fap.FapClientService
 
getRpcService(Id) - Method in interface solar.service.fap.FapService
Return the RPC service used by a particular pipe.
getScribeProxy(Id) - Method in class solar.service.pack.ScribePackService
 
getScribeRoot(Id) - Method in class solar.service.pack.ScribePackService
 
getSerializedEvent(byte[], int, int) - Static method in class solar.impl.EventFactory
Return a serialized event by parsing a byte array.
getSerializedEvent(List) - Static method in class solar.impl.EventFactory
Return a serialized event with a list of attributes.
getServer() - Method in class solar.service.mhost.comm.DetachRequest
 
getServer() - Method in class solar.service.mhost.comm.AttachRequest
 
getService(String) - Method in class solar.service.BaseServiceManager
 
getService(String) - Method in interface solar.service.ServiceManager
Return an instance of specified service.
getServiceConfig(String) - Method in class solar.service.BaseServiceManager
 
getServiceConfig(String) - Method in interface solar.service.ServiceManager
Return the configuration of a specified service.
getServiceInstance(String) - Method in class solar.service.BaseServiceManager
Retrieves an instance of a service without triggering late initialization.
getServiceManager() - Method in class solar.service.BaseService
 
getServiceManager() - Method in interface solar.service.Service
Get the service manager for this service.
getServiceName() - Method in class solar.service.dispatch.DispatchUnit
 
getServiceObject(String) - Method in class solar.service.BaseServiceManager
 
getServiceObject(String) - Method in interface solar.service.ServiceManager
Get an application-specific service object.
getSession(Id) - Method in class solar.service.pack.EndPointManager
 
getSession(Id) - Method in class solar.service.pubsub.EndPointManager
 
getSinkChannel() - Method in class solar.service.fap.Pipe
Return the sink channel of this pipe.
getSinkGuid() - Method in class solar.service.dan.comm.PipeConnectRequest
 
getSize() - Method in class solar.module.cache.BaseCache
 
getSize() - Method in interface solar.module.cache.Cache
Get the number of objects in the cache.
getSource() - Method in class solar.service.transport.Header
 
getSource() - Method in class solar.service.routing.comm.RoutingEvent
 
getSource() - Method in class solar.service.fork.Task
 
getSourceAddress() - Method in class solar.api.Request
 
getSourceAddress() - Method in class solar.service.dispatch.DispatchUnit
 
getSourceChannel() - Method in class solar.service.fap.Pipe
Return the source channel of this pipe.
getSourceGuid() - Method in class solar.service.dan.comm.PipeConnectRequest
 
getStartTime() - Method in class solar.service.fork.Task
 
getState() - Method in class campus.Location
 
getState() - Method in class rice.pastry.wire.WireNodeHandle
Returns the state of this WireNodeHandle
getState(String) - Static method in class campus.compass.ZipCodeSource
Return the state for specified zipcode.
getStateAbbr(String) - Static method in class campus.compass.ZipCodeSource
Get abbr name of a state for specified full name.
getStateName(String) - Static method in class campus.compass.ZipCodeSource
Get full name of a state for specified abbreviation.
getStrands() - Method in class solar.service.directory.PlainName
Return the list of all strands.
getStrands() - Method in interface solar.service.directory.Name
Return the list of all strands.
getStreet() - Method in class campus.Location
 
getStyleHtml() - Method in class org.doit.muffin.filter.CompassFilter
 
getSubId() - Method in class solar.service.pack.proto.BufferedEvent
If return null, then it is multicast event otherwise it is unicast.
getSubId() - Method in class solar.service.pack.comm.AckEvent
 
getSubId() - Method in class solar.service.pack.comm.PackEvent
 
getSubId() - Method in class solar.service.pack.comm.SubscribeEvent
 
getSubId() - Method in class solar.service.pack.comm.SubscribeRequest
 
getSubId() - Method in class solar.service.pack.comm.AttachSubscriberRequest
 
getSubId() - Method in class solar.service.pack.comm.DetachSubscriberRequest
 
getSubId() - Method in class solar.service.pubsub.comm.PubEvent
 
getSubId() - Method in class solar.service.pubsub.comm.SubRegisterRequest
 
getSubId() - Method in class solar.service.pubsub.comm.SubscribeRequest
 
getSubKey() - Method in class solar.service.pack.proto.GroupBufferHandle
 
getSubKey() - Method in class solar.service.pack.proto.SingleBufferHandle
 
getSubKey() - Method in interface solar.service.pack.proto.BufferHandle
Return the key of subscription, ID or link address.
getSysnortConfig() - Method in class campus.sysnort.XmlConfigParser
Return recent parsed graph spec.
getTask() - Method in class solar.service.fork.comm.StartTaskRequest
 
getTask() - Method in class solar.service.fork.comm.TaskFinishEvent
 
getTaskId() - Method in class solar.service.fork.Task
 
getTimestamp() - Method in class rice.pastry.socket.SocketPastrySecurityManager
Gets the current time for a timestamp.
getTimeStamp() - Method in class campus.syslog.SyslogParser
 
getTransport() - Method in class solar.service.transport.BaseTransportService
 
getTransport() - Method in interface solar.service.transport.TransportService
Return the transport module (dealing with individual protocol).
getTransport() - Method in class rice.pastry.socket.SocketPastryNode
 
getTransportAddress(String) - Method in class solar.service.dispatch.SolarDispatchService
 
getTransportAddress(String) - Method in interface solar.service.dispatch.DispatchService
Return local address of a transport service with specified name.
getTransportName() - Method in class solar.service.dispatch.DispatchUnit
 
getTransportService(Id) - Method in class solar.service.fap.SolarFapService
 
getTransportService(Id) - Method in class solar.service.fap.FapClientService
 
getTransportService(Id) - Method in interface solar.service.fap.FapService
Return the transport service used by a particular pipe.
getTransportService(String) - Method in class solar.service.dispatch.SolarDispatchService
 
getTransportService(String) - Method in interface solar.service.dispatch.DispatchService
Return a transport service with specified name.
getTrigger(String) - Method in class campus.sysnort.SysnortConfig
 
getTvUrl() - Method in class org.doit.muffin.filter.CompassFilter
 
getType() - Method in class solar.service.dan.lang.PipeSpec
 
getType() - Method in class solar.service.fap.Pipe
Return whether this is a push or pull pipe.
getUpTime() - Method in class campus.snmp.ApStat
 
getUrl() - Method in class campus.Building
 
getValue() - Method in class solar.api.Attribute
Return the attribute value.
getValue(String) - Method in interface solar.api.AttributeRecord
Return the value of an attribute with the specified key.
getValue(String) - Method in class solar.impl.AbstractAttributeRecord
 
getValueFromLine(String) - Static method in class campus.compass.GeobytesSource
 
getValues() - Method in interface solar.api.AttributeRecord
Return the list of all values.
getValues() - Method in class solar.impl.AbstractAttributeRecord
 
getValues(String) - Method in interface solar.api.AttributeRecord
Return the values of all attributes with the specified key.
getValues(String) - Method in class solar.impl.AbstractAttributeRecord
 
getWarmFilter() - Method in class solar.service.pack.PackPolicy
 
getWeatherUrl() - Method in class org.doit.muffin.filter.CompassFilter
 
getX() - Method in class campus.AccessPoint
 
getY() - Method in class campus.AccessPoint
 
getYahooUrl() - Method in class org.doit.muffin.filter.CompassFilter
 
getZ() - Method in class campus.AccessPoint
 
getZipCode() - Method in class campus.Location
 
getZipCode(String, String) - Static method in class campus.compass.ZipCodeSource
Return the zipcode for specified region (city and state).
goExponential(double, int) - Method in class solar.test.PackSender
 
goExponential(int, Address, double, int) - Method in class solar.test.GroundHog
 
goUniform(int) - Method in class solar.test.PackSender
 
goUniform(int, Address, int) - Method in class solar.test.GroundHog
 
GRAPH - Static variable in class solar.service.dan.lang.XmlSpecParser
 
GRAPH_SPEC_SVID - Static variable in interface solar.SolarConstants
 
GraphManager - class solar.service.dan.GraphManager.
A graph manager maintains individual DAN graph that is potentially distributed across several Planets.
GraphManager(GraphSpec) - Constructor for class solar.service.dan.GraphManager
Constructs the manager with its reponsible graph spec.
GraphNode - class solar.service.dan.GraphNode.
The interface for all nodes in the graph.
GraphNode() - Constructor for class solar.service.dan.GraphNode
 
GraphSpec - class solar.service.dan.lang.GraphSpec.
The parsed specification of operator graph.
GraphSpec() - Constructor for class solar.service.dan.lang.GraphSpec
 
greetingReceived() - Method in class rice.pastry.wire.SocketChannelWriter
 
GroundHog - class solar.test.GroundHog.
This class can be used to produce background network traffic.
GroundHog(Options) - Constructor for class solar.test.GroundHog
 
GROUP - Static variable in class solar.service.pack.lang.XmlPolicyParser
 
GROUP_ID - Static variable in interface solar.service.multicast.MulticastConstants
 
GroupBufferHandle - class solar.service.pack.proto.GroupBufferHandle.
Manages a group of subscriptions, such as those coming from same link.
GroupBufferHandle(Id, Object, int) - Constructor for class solar.service.pack.proto.GroupBufferHandle
 
Guid - class solar.api.Guid.
An object ID that is unique in global distributed system.
GUID_SVID - Static variable in interface solar.SolarConstants
 
Guid(Address) - Constructor for class solar.api.Guid
 
Guid(Address, Id) - Constructor for class solar.api.Guid
 
Guid(Address, String) - Constructor for class solar.api.Guid
 

H

handleDispatchUnit(DispatchUnit) - Method in class solar.service.BaseService
 
handleDispatchUnit(DispatchUnit) - Method in interface solar.service.Service
Handle the data unit delivered by dispatch service.
handleDispatchUnit(DispatchUnit) - Method in class solar.service.dispatch.SolarDispatchService
 
handleDispatchUnit(DispatchUnit) - Method in class solar.service.rpc.SolarRpcService
 
handleEvent(Event) - Method in interface solar.api.EventHandler
Processing an event.
handleEvent(Event) - Method in class solar.service.BaseService
 
handleEvent(Event) - Method in class solar.service.pack.ScribePackService
 
handleEvent(Event) - Method in class solar.service.pack.ClientPackService
 
handleEvent(Event) - Method in class solar.service.routing.ManualRoutingService
 
handleEvent(Event) - Method in class solar.service.rmtobj.SolarRemoteObjectService
 
handleEvent(Event) - Method in class solar.service.dan.ProxyOperator
 
handleEvent(Event) - Method in class solar.service.dan.Monitor
 
handleEvent(Event) - Method in class solar.service.dan.RelayOperator
 
handleEvent(Event) - Method in class solar.service.dan.Source
 
handleEvent(Event) - Method in class solar.service.dan.GraphNode
Handle the event being actively pushed/published to this operator.
handleEvent(Event) - Method in class solar.service.fork.SolarForkService
 
handleEvent(Event) - Method in class solar.service.pubsub.ScribePubSubService
 
handleEvent(Event) - Method in class solar.service.pubsub.ClientPubSubService
 
handleEvent(Event) - Method in class solar.service.fap.FapClientService
 
handleEvent(Event) - Method in class solar.test.ScribeReceiver.Profiler
 
handleEvent(Event) - Method in class solar.test.PackReceiver.Profiler
 
handleEvent(Event) - Method in class solar.test.EventPrinter
 
handleEvent(Event) - Method in class solar.test.MutateOperator
 
handleEvent(Event) - Method in class versus.VersusTracker
 
handleEvent(Event) - Method in class versus.VersusTransformer
Convert tag and sensor ID numbers to symbolic values.
handleEvent(Event) - Method in class versus.VersusFilter
 
handleEvent(Event) - Method in class versus.meeting.MeetingApp
 
handleEvent(Event) - Method in class versus.meeting.MeetingDetector
 
handleEvent(Event) - Method in class campus.sysnort.TriggerHandler
 
handleEvent(Event) - Method in class campus.syslog.CategoryOperator
Convert aPname ->building -> category of building and public it.
handleEvent(Event) - Method in class campus.syslog.APLocationOperator
get APname and then search AP's lOCATION info and publish them.
handleEvent(Event) - Method in class campus.syslog.APInfoOperator
get APname and then search AP's info and publish them.
handleEvent(Event, Address) - Method in class solar.service.BaseService
 
handleEvent(Event, String) - Method in class solar.service.dan.GraphNode
Handle the event coming from the specified input port.
handleMessage(String) - Method in interface campus.LogTracer.TracerObserver
feed the output to the observer.
handleMessage(String) - Method in class campus.sysnort.SysnortSensor
 
handleMulticastEvent(Event) - Method in class solar.Planet
 
handleMulticastEvent(Event) - Method in class solar.service.multicast.RemoteMulticastMember
 
handleMulticastEvent(Event) - Method in interface solar.service.multicast.MulticastMember
Handle received multicast events.
handlePackEvent(PackEvent) - Method in class solar.service.pack.ScribePackService
 
handlePackEvent(PackEvent) - Method in class solar.service.pack.ClientPackService
 
handleQuery(Request) - Method in class solar.service.dan.ProxyOperator
 
handleQuery(Request) - Method in class solar.service.dan.RelayOperator
 
handleQuery(Request) - Method in class solar.service.dan.Application
 
handleQuery(Request) - Method in class solar.service.dan.GraphNode
Handle the query being actively pulled by downstream operators.
handleQuery(Request) - Method in class solar.test.MutateOperator
 
handleQuery(Request) - Method in class solar.test.ClockSource
 
handleQuery(Request) - Method in class versus.VersusTracker
 
handleQuery(Request) - Method in class versus.VersusTransformer
 
handleQuery(Request) - Method in class versus.VersusFilter
 
handleQuery(Request) - Method in class versus.VersusSource
 
handleQuery(Request) - Method in class versus.meeting.MeetingDetector
 
handleQuery(Request) - Method in class campus.syslog.SyslogSource
 
handleQuery(Request) - Method in class campus.syslog.CategoryOperator
 
handleQuery(Request) - Method in class campus.syslog.APLocationOperator
 
handleQuery(Request) - Method in class campus.syslog.APInfoOperator
 
handleQuery(Request) - Method in class campus.snmp.SnmpSource
 
handleQuery(Request, String) - Method in class solar.service.dan.GraphNode
Handle the query coming from the specified output port.
handleRequest(Request) - Method in interface solar.api.RequestHandler
Processing a request.
handleRequest(Request) - Method in class solar.service.BaseService
 
handleRequest(Request) - Method in class solar.service.pack.ScribePackService
 
handleRequest(Request) - Method in class solar.service.dispatch.SolarDispatchService
 
handleRequest(Request) - Method in class solar.service.rmtobj.SolarRemoteObjectService
 
handleRequest(Request) - Method in class solar.service.dan.SolarDanService
 
handleRequest(Request) - Method in class solar.service.dan.AbstractDanService
 
handleRequest(Request) - Method in class solar.service.fork.SolarForkService
 
handleRequest(Request) - Method in class solar.service.pubsub.ScribePubSubService
 
handleRequest(Request) - Method in class solar.service.pubsub.ClientPubSubService
 
handleRequest(Request) - Method in class solar.service.rpc.SolarRpcService
 
handleRequest(Request) - Method in class solar.service.multicast.NaiveMulticastService
 
handleRequest(Request) - Method in class solar.service.fap.FapClientService
 
handleRequest(Request) - Method in class solar.service.directory.DistDirectoryService
 
handleRequest(Request) - Method in class solar.service.directory.CentralDirectoryService
 
handles - Variable in class rice.pastry.socket.SocketNodeHandlePool
 
handleSubscribeEvent(SubscribeEvent) - Method in class solar.service.pack.ScribePackService
 
handleSubscribeEvent(SubscribeEvent) - Method in class solar.service.pack.ClientPackService
 
hashCode() - Method in class solar.api.Guid
 
hashCode() - Method in class solar.api.Id
 
hashCode() - Method in interface solar.api.Address
Return the hash code of this address.
hashCode() - Method in class solar.service.transport.PastryTransport.MultiplexAddress
 
hashCode() - Method in class solar.service.transport.SocketAddress
 
hashCode() - Method in class solar.service.transport.PastryAddress
 
hashCode() - Method in class solar.service.rmtobj.RemoteObject
 
hasInited() - Method in class solar.service.BaseService
 
hasInited() - Method in interface solar.service.Service
Return whether the service has been initialized.
hasMoreElements() - Method in class solar.util.ssLinkedList.ssLinkedListEnumeration
 
hasParameter(String) - Method in class solar.service.fork.Task
 
hasPublisher(Id) - Method in class solar.service.pack.proto.BaseProtocol
Whether this manager contains the specified publisher.
hasRegistered(String) - Method in class solar.service.BaseServiceManager
 
hasRegistered(String) - Method in interface solar.service.ServiceManager
Determines whether a service is registered.
hasSubscriber(Id) - Method in class solar.service.pack.proto.GroupBufferHandle
 
hasSubscriber(Id) - Method in class solar.service.pack.proto.SingleBufferHandle
 
hasSubscriber(Id) - Method in interface solar.service.pack.proto.BufferHandle
Return whether this handle contains specified subscriber.
Header - class solar.service.transport.Header.
The header for each ADU sent or received.
HEADER_SVID - Static variable in interface solar.SolarConstants
 
Header() - Constructor for class solar.service.transport.Header
 
Header(Id) - Constructor for class solar.service.transport.Header
 
HEAP_ALLOC_NUM - Static variable in class solar.util.ssLinkedList
 
HelloMessage - class rice.pastry.socket.HelloMessage.
Class which represents a greeting in the socket-based pastry protocol.
HelloMessage(SocketPastryNode, NodeId) - Constructor for class rice.pastry.socket.HelloMessage
Constructor
HelloResponseMessage - class rice.pastry.socket.HelloResponseMessage.
Class which represents a greeting response in the socket-based pastry protocol.
HelloResponseMessage(SocketPastryNode, NodeId) - Constructor for class rice.pastry.socket.HelloResponseMessage
Constructor
hexChar - Static variable in class solar.util.StringUtil
 
HITS_THRESHOLD - Static variable in class campus.sysnort.trigger.FlickerTrigger
 
HotspotTrigger - class campus.sysnort.trigger.HotspotTrigger.
Monitors the number of clients on the APs and update the hotspot plots periodically.
HotspotTrigger() - Constructor for class campus.sysnort.trigger.HotspotTrigger
 

I

i - Variable in class campus.syslog.CatalogBuildingMapping
 
i - Variable in class campus.syslog.BuildingNameConvertor
 
i - Variable in class campus.syslog.APMapping
 
Id - class solar.api.Id.
An object ID that is unique in local JVM.
ID_BASE - Static variable in class solar.api.Id
 
ID_SVID - Static variable in interface solar.SolarConstants
 
Id() - Constructor for class solar.api.Id
 
Id(byte[]) - Constructor for class solar.api.Id
 
Id(Id) - Constructor for class solar.api.Id
 
Id(String) - Constructor for class solar.api.Id
 
Identifiable - interface solar.api.Identifiable.
Interface for all objects that have an ID.
IDX_ACTION - Static variable in interface campus.syslog.SyslogConstants
 
IDX_APNAME - Static variable in interface campus.syslog.SyslogConstants
 
IDX_CLIENTHOST - Static variable in interface campus.syslog.SyslogConstants
 
IDX_CLIENTMAC - Static variable in interface campus.syslog.SyslogConstants
 
IDX_DAY - Static variable in interface campus.syslog.SyslogConstants
 
IDX_MONTH - Static variable in interface campus.syslog.SyslogConstants
 
IDX_MSGTYPE - Static variable in interface campus.syslog.SyslogConstants
 
IDX_NOTE - Static variable in interface campus.syslog.SyslogConstants
 
IDX_TIME - Static variable in interface campus.syslog.SyslogConstants
 
IDX_TIMESTAMP - Static variable in interface campus.syslog.SyslogConstants
 
IDX_YEAR - Static variable in interface campus.syslog.SyslogConstants
 
in - Variable in class org.doit.muffin.filter.CompassFilter
 
INIT_VALS - Static variable in class versus.meeting.RLMeetingWorld
 
init() - Method in class solar.service.BaseService
 
init() - Method in interface solar.service.Service
Initiate the service, do not try to init dependent services here.
init() - Method in class solar.service.pack.ScribePackService
 
init() - Method in class solar.service.pack.ClientPackService
 
init() - Method in class solar.service.transport.UdpTransportService
 
init() - Method in class solar.service.transport.TcpTransportService
 
init() - Method in class solar.service.transport.PastryTransportService
 
init() - Method in class solar.service.routing.DirectRoutingService
 
init() - Method in class solar.service.routing.ManualRoutingService
 
init() - Method in class solar.service.rmtobj.SolarRemoteObjectService
 
init() - Method in class solar.service.dan.DanClientService
 
init() - Method in class solar.service.dan.AbstractDanService
 
init() - Method in class solar.service.fork.SolarForkService
 
init() - Method in class solar.service.pubsub.ScribePubSubService
 
init() - Method in class solar.service.pubsub.ClientPubSubService
 
init() - Method in class solar.service.mhost.SolarMobileHostService
 
init() - Method in class solar.service.rpc.SolarRpcService
 
init() - Method in class solar.service.directory.CentralDirectoryService
 
init() - Method in class campus.compass.CompassService
 
init(DanService) - Method in class solar.service.dan.GraphManager
Init the graph manager.
init(NodeHandler) - Method in class solar.service.dan.GraphNode
Initialize the source with a handler.
init(Object) - Method in class solar.service.BaseService
 
init(Options) - Method in class solar.service.BaseServiceManager
 
init(Options) - Method in interface solar.service.ServiceManager
Init the service manager with configurations of all services.
init(Options) - Method in class solar.service.pack.PackFilter
Init the filter with specified arguments.
init(Options) - Method in class solar.service.pack.filter.RANDOM
 
init(Options) - Method in class solar.service.pack.filter.EVEN
 
init(Options) - Method in class solar.service.pack.filter.ODD
 
init(Options) - Method in class solar.service.pack.filter.GE
 
init(Options) - Method in class solar.service.dan.GraphNode
Customized initialization derived from graph spec.
init(Options) - Method in class solar.test.MutateOperator
 
init(Options) - Method in class versus.VersusTransformer
Init the operator's floorplan and badge mapping tables specified in an XML file.
init(Options) - Method in class versus.VersusFilter
 
init(Options) - Method in class versus.meeting.MeetingDetector
 
init(Options) - Method in class campus.sysnort.Trigger
Init the trigger with customized arguments in configuration.
init(Options) - Method in class campus.sysnort.trigger.HotspotTrigger
 
init(Options) - Method in class campus.sysnort.trigger.FlickerTrigger
 
init(Options) - Method in class campus.sysnort.trigger.MissingCardTrigger
 
init(Options) - Method in class campus.syslog.CategoryOperator
Init the operator's data specified in an data file.
init(Options) - Method in class campus.syslog.APLocationOperator
Init the operator's floorplan and badge mapping tables specified in an XML file.
init(Options) - Method in class campus.syslog.APInfoOperator
Init the operator's floorplan and badge mapping tables specified in an XML file.
init(String, int) - Method in class versus.VersusSource
Open the connection to the badge server, and creates the input stream.
init(TcpTransport) - Method in class solar.service.transport.TcpConnection
Initialize this connection.
initComponents() - Method in class versus.meeting.MeetingRecorder
This method is called from within the constructor to initialize the form.
initCookie(byte[]) - Method in class solar.service.transport.TcpConnection
 
initCountryMapping() - Static method in class campus.compass.CountryCode
 
initDependents() - Method in class solar.service.BaseService
 
initDependents() - Method in interface solar.service.Service
Initialize dependent services here.
initDependents() - Method in class solar.service.pack.ScribePackService
 
initDependents() - Method in class solar.service.pack.ClientPackService
 
initDependents() - Method in class solar.service.transport.UdpTransportService
 
initDependents() - Method in class solar.service.transport.TcpTransportService
 
initDependents() - Method in class solar.service.routing.DirectRoutingService
 
initDependents() - Method in class solar.service.routing.ManualRoutingService
 
initDependents() - Method in class solar.service.dispatch.SolarDispatchService
 
initDependents() - Method in class solar.service.rmtobj.SolarRemoteObjectService
 
initDependents() - Method in class solar.service.dan.DanClientService
 
initDependents() - Method in class solar.service.dan.AbstractDanService
 
initDependents() - Method in class solar.service.fork.SolarForkService
 
initDependents() - Method in class solar.service.pubsub.ScribePubSubService
 
initDependents() - Method in class solar.service.pubsub.ClientPubSubService
 
initDependents() - Method in class solar.service.mhost.SolarMobileHostService
 
initDependents() - Method in class solar.service.rpc.SolarRpcService
 
initDependents() - Method in class solar.service.multicast.ScribeMulticastService
 
initDependents() - Method in class solar.service.multicast.NaiveMulticastService
 
initDependents() - Method in class solar.service.fap.SolarFapService
 
initDependents() - Method in class solar.service.fap.FapClientService
 
initDependents() - Method in class solar.service.directory.DistDirectoryService
 
initDependents() - Method in class solar.service.directory.CentralDirectoryService
 
initMapping() - Method in class solar.service.BaseServiceManager
Creates a mapping between service names and class names.
initServices() - Method in class solar.service.BaseServiceManager
Performs early initialization of all needed services.
initStateMapping() - Static method in class campus.compass.ZipCodeSource
Init state name to abbrev mapping.
initValues(double) - Method in class versus.meeting.RLPolicy
 
INPORT - Static variable in class solar.service.dan.lang.XmlSpecParser
 
InputBufferManager - interface solar.service.pack.proto.InputBufferManager.
Interface for algorithms that determines actions when event arrives.
InputPort - class solar.service.fap.InputPort.
An input port of a sink filter to a pipe.
InputPort(String) - Constructor for class solar.service.fap.InputPort
 
InputProtocol - class solar.service.pack.proto.InputProtocol.
Protocol handles input events for local resident subscribers.
InputProtocol(int, int, int) - Constructor for class solar.service.pack.proto.InputProtocol
 
InputRelay - class campus.InputRelay.
The relayer allows other hosts to read live syslog stream.
InputRelay() - Constructor for class campus.InputRelay
 
inThread() - Method in class rice.pastry.socket.SocketPastryNode
 
invoke(Address, String, Request) - Method in class solar.service.rpc.SolarRpcService
 
invoke(Address, String, Request) - Method in interface solar.service.rpc.RpcService
Send the request to remote party and wait for the result.
invoke(Address, String, Request, long) - Method in class solar.service.rpc.SolarRpcService
 
invoke(Address, String, Request, long) - Method in interface solar.service.rpc.RpcService
Send the request and wait for the result for a fixed period.
iPAddress - Variable in class campus.syslog.APConfiguration
 
isAckEvent(Event) - Static method in class solar.service.pack.comm.AckEvent
 
isAttached() - Method in class solar.service.mhost.SolarMobileHostService
 
isAttached() - Method in interface solar.service.mhost.MobileHostService
Detemine whether this client is attched.
isAttached(Address) - Method in class solar.service.mhost.SolarMobileHostService
 
isAttached(Address) - Method in interface solar.service.mhost.MobileHostService
Detemine whether the specified client is attched to this Planet.
isClient() - Method in class solar.service.dan.comm.PipeConnectRequest
 
isEmpty() - Method in class rice.pastry.wire.SocketChannelWriter
Returns whether or not there are objects in the queue on in writing.
isFinished() - Method in class solar.service.fork.Task
 
isForwarding() - Method in class solar.service.pack.comm.PackEvent
 
isForwarding() - Method in class solar.service.pack.comm.SubscribeEvent
 
isInputQuery() - Method in class solar.service.dan.lang.PipeSpec
 
isLeaf() - Method in class solar.service.directory.NameNode
Return whether this name node is a leaf of name tree.
isLocal(Address) - Method in class solar.service.pack.ScribePackService
Is the specified address actually same as local address.
isNewRoot(NodeId) - Method in class solar.service.pack.ScribeManager
Upcall made by scribe to registered applications to inform them that local node is now the root for some topic, and hence can take appropriate action.
isNewRoot(NodeId) - Method in class solar.service.pubsub.ScribeManager
Upcall made by scribe to registered applications to inform them that local node is now the root for some topic, and hence can take appropriate action.
isNewRoot(NodeId) - Method in class solar.service.multicast.ScribeMulticastService.ScribeMember
Upcall made by scribe to registered applications to inform them that local node is now the root for some topic, and hence can take appropriate action.
isPackEvent(Event) - Static method in class solar.service.pack.comm.PackEvent
 
isPingEvent(Event) - Static method in class solar.service.rmtobj.comm.PingEvent
 
isPipePushEvent(Event) - Static method in class solar.service.fap.comm.PipePushEvent
 
isPubEvent(Event) - Static method in class solar.service.pubsub.comm.PubEvent
 
isRemote() - Method in class solar.service.fap.LocalSinkChannel
 
isRemote() - Method in class solar.service.fap.LocalSourceChannel
 
isRemote() - Method in class solar.service.fap.RemoteSinkChannel
 
isRemote() - Method in class solar.service.fap.RemoteSourceChannel
 
isRemote() - Method in interface solar.service.fap.SourceChannel
Return whether the source is on remote site.
isRemote() - Method in interface solar.service.fap.SinkChannel
Return whether the sink is on remote site.
isReplyEvent(Event) - Static method in class solar.service.rpc.comm.ReplyEvent
 
isRequestEvent(Event) - Static method in class solar.service.rpc.comm.RequestEvent
 
isRoot() - Method in class solar.service.directory.NameNode
Return whether this name node is the root of name tree.
isRoot(Id) - Method in class solar.service.pack.ScribeManager
Is this node the root of specified topic.
isRoutingEvent(Event) - Static method in class solar.service.routing.comm.RoutingEvent
 
isStale() - Method in class solar.module.cache.CachedObject
Is the object stale?
isSubscribeEvent(Event) - Static method in class solar.service.pack.comm.SubscribeEvent
 
isSuspended() - Method in class solar.service.pack.proto.GroupBufferHandle
 
isSuspended() - Method in class solar.service.pack.proto.SingleBufferHandle
 
isSuspended() - Method in interface solar.service.pack.proto.BufferHandle
Return whether this handle is suspended.
isTaskFinishEvent(Event) - Static method in class solar.service.fork.comm.TaskFinishEvent
 

J

JavaSyncQueue - class solar.util.JavaSyncQueue.
A synchronized blocking queue based on a Java linked-list.
JavaSyncQueue() - Constructor for class solar.util.JavaSyncQueue
 
JavaUnsyncQueue - class solar.util.JavaUnsyncQueue.
A not synchronized non-blocking queue based on a Java linked-list.
JavaUnsyncQueue() - Constructor for class solar.util.JavaUnsyncQueue
 
jLabel1 - Variable in class versus.meeting.MeetingRecorder
 
join(Id) - Method in class solar.service.pack.ScribeManager
Join the mutlicast tree of specified topic.
join(Id) - Method in class solar.service.pubsub.ScribeManager
 
join(Id, MulticastMember) - Method in class solar.service.multicast.ScribeMulticastService
 
join(Id, MulticastMember) - Method in class solar.service.multicast.NaiveMulticastService
 
join(Id, MulticastMember) - Method in interface solar.service.multicast.MulticastService
Join a multicast group.
JoinRequest - class solar.service.multicast.comm.JoinRequest.
A request to join a multicast group.
JoinRequest(Id, RemoteMulticastMember) - Constructor for class solar.service.multicast.comm.JoinRequest
 

K

key - Variable in class rice.pastry.wire.SocketManager.SocketConnector
 
key - Variable in class rice.pastry.wire.SocketManager
 
key - Variable in class rice.pastry.wire.WireNodeHandle
 
KEY - Static variable in class solar.impl.PlainAttributeRecord
 
KEYS - Static variable in class solar.service.pack.lang.XmlPolicyParser
 
kill() - Method in class rice.pastry.socket.SocketPastryNode
 

L

lambda - Variable in class versus.meeting.RLearner
 
last - Variable in class solar.util.ssLinkedList
 
lastpingtime - Variable in class rice.pastry.wire.WireNodeHandle
 
lastpingtime - Variable in class rice.pastry.socket.SocketNodeHandle
 
leafSetMaintFreq - Static variable in class rice.pastry.wire.UdpPastryNodeFactory
 
leafSetMaintFreq - Static variable in class rice.pastry.wire.TcpPastryNodeFactory
 
leafSetMaintFreq - Static variable in class rice.pastry.socket.SocketPastryNodeFactory
 
LEARNING_STEPS - Static variable in class versus.meeting.RLMeetingAgent
 
learningMethod - Variable in class versus.meeting.RLearner
 
leave(Id, MulticastMember) - Method in class solar.service.multicast.ScribeMulticastService
 
leave(Id, MulticastMember) - Method in class solar.service.multicast.NaiveMulticastService
 
leave(Id, MulticastMember) - Method in interface solar.service.multicast.MulticastService
Leave a multicast group.
LeaveRequest - class solar.service.multicast.comm.LeaveRequest.
A request to leave a multicast group.
LeaveRequest(Id, RemoteMulticastMember) - Constructor for class solar.service.multicast.comm.LeaveRequest
 
ll_equality_comparator - Static variable in class solar.util.ssLinkedList
 
lle_heap - Variable in class solar.util.ssLinkedList
 
loadAccessPoints() - Method in class campus.CampusMap
 
loadBuilding() - Method in class campus.CampusMap
 
loadFilter() - Method in class solar.service.pack.lang.FilterConfig
 
loadGraph(GraphSpec, String) - Method in class solar.service.dan.AbstractDanService
 
loadObject(String, String) - Static method in class solar.util.NetUtil
Create a new object instance of specified class.
loadOperator(String) - Method in class solar.service.dan.DistGraphManager
 
loadOperator(String) - Method in class solar.service.dan.LocalGraphManager
 
loadOperator(String) - Method in class solar.service.dan.GraphManager
Load the root operator and all its children as defined in the graph.
loadTriggers() - Method in class campus.sysnort.SysnortConfig
 
LocalGraphManager - class solar.service.dan.LocalGraphManager.
This graph manager simply loads the whole graph (except sources) onto the local Planet from which the request is received.
LocalGraphManager(GraphSpec) - Constructor for class solar.service.dan.LocalGraphManager
 
localhandle - Variable in class rice.pastry.socket.SocketPastrySecurityManager
 
localnode - Variable in class rice.pastry.socket.SocketPastrySecurityManager
 
LocalSinkChannel - class solar.service.fap.LocalSinkChannel.
The data sink of this channel is on the local site.
LocalSinkChannel() - Constructor for class solar.service.fap.LocalSinkChannel
Constructs an empty sink channel.
LocalSinkChannel(DataSink, InputPort) - Constructor for class solar.service.fap.LocalSinkChannel
Constructs a sink channel wit specified data source attached.
LocalSourceChannel - class solar.service.fap.LocalSourceChannel.
The data source of this channel is on the local site.
LocalSourceChannel() - Constructor for class solar.service.fap.LocalSourceChannel
Constructs an empty source channel.
LocalSourceChannel(DataSource, OutputPort) - Constructor for class solar.service.fap.LocalSourceChannel
Constructs a source channel wit specified data source attached.
location - Variable in class campus.syslog.APConfiguration
 
Location - class campus.Location.
The construct for a location representation.
Location() - Constructor for class campus.Location
 
Location(String, String, String, String, String, int) - Constructor for class campus.Location
 
log(Request, long, Reply) - Method in class org.doit.muffin.filter.Logger
 
LogFormatter - class versus.meeting.LogFormatter.
 
LogFormatter() - Constructor for class versus.meeting.LogFormatter
Creates a new instance of LogFormatter
logger - Static variable in class versus.meeting.MeetingRecorder
 
Logger - class org.doit.muffin.filter.Logger.
Factory for logging filters.
Logger() - Constructor for class org.doit.muffin.filter.Logger
 
LoggerFilter - class org.doit.muffin.filter.LoggerFilter.
This filter doing the request/reply logging for analysis later.
LoggerFilter(Logger) - Constructor for class org.doit.muffin.filter.LoggerFilter
 
LogTracer - class campus.LogTracer.
A tracer that outputs raw log messages from STDIN or a log file, roughly respecting the timestamp.
LogTracer.TracerObserver - interface campus.LogTracer.TracerObserver.
An observer who takes tracer's output.
LogTracer(Options) - Constructor for class campus.LogTracer
 
lookup(LookupRequest) - Method in class solar.service.dan.AbstractDanService
 
lookup(Name) - Method in class solar.service.directory.DistDirectoryService
 
lookup(Name) - Method in class solar.service.directory.FlatDirectory
 
lookup(Name) - Method in class solar.service.directory.CentralDirectoryService
 
lookup(Name) - Method in interface solar.service.directory.Directory
Return a list of advertisement whose name matches the pattern.
lookup(Name) - Method in interface solar.service.directory.DirectoryService
Return a list of advertisement whose name matches the pattern.
lookup(String) - Method in class solar.Client
Return a list of names and name records matching the name query.
lookup(String) - Method in class solar.service.dan.DanClientService
Resolve a name query in the name space.
LookupRequest - class solar.service.dan.comm.LookupRequest.
A request to lookup naming directory.
LookupRequest - class solar.service.directory.comm.LookupRequest.
Request to lookup a name pattern.
LookupRequest(Name) - Constructor for class solar.service.directory.comm.LookupRequest
 
LookupRequest(String) - Constructor for class solar.service.dan.comm.LookupRequest
 
lSetSize - Static variable in class rice.pastry.wire.UdpPastryNodeFactory
 
lSetSize - Static variable in class rice.pastry.wire.TcpPastryNodeFactory
 
lSetSize - Static variable in class rice.pastry.socket.SocketPastryNodeFactory
 

M

m_startOid - Variable in class campus.snmp.SnmpTest
 
m_stopAt - Variable in class campus.snmp.SnmpTest
 
mACAddress - Variable in class campus.syslog.APConfiguration
 
MAGIC_NUMBER - Static variable in class rice.pastry.wire.SocketChannelWriter
 
main(String[]) - Static method in class solar.Shell
 
main(String[]) - Static method in class solar.Client
Start the client and make name lookups.
main(String[]) - Static method in class solar.Planet
 
main(String[]) - Static method in class solar.util.Counter
 
main(String[]) - Static method in class solar.util.ssLinkedList
 
main(String[]) - Static method in class solar.service.pack.lang.XmlPolicyParser
 
main(String[]) - Static method in class solar.service.pack.client.PackClient
 
main(String[]) - Static method in class solar.service.dan.lang.XmlSpecParser
 
main(String[]) - Static method in class solar.service.fork.client.ForkClient
 
main(String[]) - Static method in class solar.service.pubsub.client.PubSubClient
Start the client and make name lookups.
main(String[]) - Static method in class solar.test.GroundHog
 
main(String[]) - Static method in class solar.test.ScribeSender
 
main(String[]) - Static method in class solar.test.ScribeReceiver
 
main(String[]) - Static method in class solar.test.PackSender
 
main(String[]) - Static method in class solar.test.PackReceiver
 
main(String[]) - Static method in class solar.test.EventPrinter
Start the event printer and make subscription.
main(String[]) - Static method in class solar.test.ClockSource
Start the clock source and advertise a name for it.
main(String[]) - Static method in class versus.VersusTransformer
Method used for standalone test, not used when in Solar Operator mode.
main(String[]) - Static method in class versus.VersusMapping
Standalone test, with mapping table constructed from an URL.
main(String[]) - Static method in class versus.VersusSource
Read the configuration from command line and start the source as Versus client or a standalone program.
main(String[]) - Static method in class versus.meeting.MeetingApp
 
main(String[]) - Static method in class versus.meeting.MeetingDetector
 
main(String[]) - Static method in class versus.meeting.RLMeetingAgent
 
main(String[]) - Static method in class versus.meeting.MeetingRecorder
 
main(String[]) - Static method in class campus.InputRelay
 
main(String[]) - Static method in class campus.CampusMap
 
main(String[]) - Static method in class campus.LogTracer
 
main(String[]) - Static method in class campus.sysnort.SysnortSensor
 
main(String[]) - Static method in class campus.sysnort.XmlConfigParser
 
main(String[]) - Static method in class campus.sysnort.SysnortApp
 
main(String[]) - Static method in class campus.syslog.SyslogParser
 
main(String[]) - Static method in class campus.syslog.SyslogSource
Read the configuration from command line and start the source as Syslog client or a standalone program.
main(String[]) - Static method in class campus.syslog.CategoryOperator
Method used for test, not used when in Operator mode.
main(String[]) - Static method in class campus.syslog.CatalogBuildingMapping
just for test.
main(String[]) - Static method in class campus.syslog.BuildingNameConvertor
 
main(String[]) - Static method in class campus.syslog.APLocationOperator
Method used for standalone test, not used when in Operator mode.
main(String[]) - Static method in class campus.syslog.APMapping
Standalone test, with mapping table constructed .
main(String[]) - Static method in class campus.syslog.APInfoOperator
Method used for standalone test, not used when Operator mode.
main(String[]) - Static method in class campus.snmp.SnmpLocator
 
main(String[]) - Static method in class campus.snmp.SnmpSource
Start the snmp source and advertise a name for it.
main(String[]) - Static method in class campus.snmp.SnmpTest
 
main(String[]) - Static method in class campus.compass.ZipCodeSource
 
makeBufferPacker() - Static method in class solar.service.pack.proto.BufferPackerFactory
 
makeCopy() - Method in class campus.sysnort.trigger.FlickerTrigger.ClientState
 
makeEvent(List) - Static method in class solar.impl.EventFactory
Return an event with specified attributes, using default format.
makeFakeId(Id, Id) - Static method in class solar.service.pack.ScribePackService
 
makeGraphManager(GraphSpec) - Method in class solar.service.dan.AbstractDanService
 
makeGuid() - Method in class solar.service.dan.DanClientService
 
makeGuid() - Method in class solar.service.dan.AbstractDanService
 
makeGuid() - Method in interface solar.service.dan.DanService
Create a global unique ID.
makeGuid(Address) - Static method in class solar.api.Guid
Return a fresh Guid.
makeGuid(Id) - Method in class solar.service.pack.ScribePackService
 
makeGuid(Id) - Method in class solar.service.pack.ClientPackService
 
makeGuid(Id) - Method in interface solar.service.pack.PackService
Return a global unique ID.
makeGuid(Id) - Method in class solar.service.pack.client.PackClient
 
makeGuid(Id) - Method in class solar.service.pubsub.ScribePubSubService
 
makeGuid(Id) - Method in class solar.service.pubsub.ClientPubSubService
 
makeId() - Static method in class solar.api.Id
Return a fresh ID.
makeId() - Static method in class solar.util.StringUtil
 
makeId(String) - Static method in class solar.api.Id
Return a fresh ID with specified prefix.
makeId(String) - Static method in class solar.util.StringUtil
 
makeInputBufferManager(BaseProtocol.ProtocolState) - Static method in class solar.service.pack.proto.BufferManagerFactory
 
makeOutputBufferManager(BaseProtocol.ProtocolState) - Static method in class solar.service.pack.proto.BufferManagerFactory
 
makePipe(Id, int, FapService) - Static method in class solar.service.fap.PipeFactory
Make a supported pipe.
makePipeId() - Method in class solar.service.dan.PipeConnector
 
makePipeId() - Method in class solar.service.fap.FapClientService
 
makeQueue() - Static method in class solar.util.QueueFactory
Make a new synchronized queue.
makeSession() - Method in class solar.service.pack.ScribePackService
Return a new session ID.
makeSession() - Method in class solar.service.pubsub.ScribePubSubService
 
makeSyncQueue() - Static method in class solar.util.QueueFactory
Make a new synchronized queue.
makeTcpConnection(Socket, SocketAddress) - Method in class solar.service.transport.TcpObjectTransport
 
makeTcpConnection(Socket, SocketAddress) - Method in class solar.service.transport.TcpTransport
Create a TcpConenction based on the socket and peer address.
makeUnsyncQueue() - Static method in class solar.util.QueueFactory
Make a new synchronized queue.
manager - Variable in class org.doit.muffin.filter.Logger
 
manager - Variable in class org.doit.muffin.filter.Compass
 
ManualRoutingService - class solar.service.routing.ManualRoutingService.
The routing table is manually setup as the overlay network is being constructed.
ManualRoutingService.RoutingTask - class solar.service.routing.ManualRoutingService.RoutingTask.
A periodic routing task.
ManualRoutingService.RoutingTask() - Constructor for class solar.service.routing.ManualRoutingService.RoutingTask
 
ManualRoutingService() - Constructor for class solar.service.routing.ManualRoutingService
 
mapping - Variable in class campus.syslog.CategoryOperator
 
matchCookie(byte[]) - Method in class solar.service.transport.TcpConnection
 
MAX_OPEN_SOCKETS - Static variable in class rice.pastry.wire.SocketManager
 
MAX_UDP_MESSAGE_SIZE - Static variable in class rice.pastry.wire.WireNodeHandle
 
MAXIMUM_QUEUE_LENGTH - Static variable in class rice.pastry.wire.SocketChannelWriter
 
maxOpenSockets - Static variable in class rice.pastry.wire.UdpPastryNodeFactory
 
maxOpenSockets - Static variable in class rice.pastry.wire.TcpPastryNodeFactory
 
maxOpenSockets - Static variable in class rice.pastry.socket.SocketPastryNodeFactory
 
MeetingApp - class versus.meeting.MeetingApp.
This application simply receives events from MeetingDetector and notify some users by email.
MeetingApp() - Constructor for class versus.meeting.MeetingApp
 
MeetingDetector - class versus.meeting.MeetingDetector.
A primitive operator that detects the ongoing meeting based on badges attached to chairs.
MeetingDetector() - Constructor for class versus.meeting.MeetingDetector
 
MeetingRecorder - class versus.meeting.MeetingRecorder.
The recorder provides an user interface for user to record meeting starts and ends.
MeetingRecorder(Frame, boolean) - Constructor for class versus.meeting.MeetingRecorder
Creates new form MeetingController
MeetingResource - class versus.meeting.MeetingResource.
Meeting resource bundle for meeting recorder.
MeetingResource() - Constructor for class versus.meeting.MeetingResource
 
mergeStrands(Set) - Method in class solar.service.directory.FlatDirectory
 
messageSize(Object) - Method in class rice.pastry.wire.WireNodeHandle
Method which returns the size of an object about to be sent over the wire.
minus(int) - Method in class solar.util.Counter
 
MissingCardTrigger - class campus.sysnort.trigger.MissingCardTrigger.
A Sysnort trigger that sends email when a reported stolen/missing card is associated with the network.
MissingCardTrigger() - Constructor for class campus.sysnort.trigger.MissingCardTrigger
 
MIXED - Static variable in class solar.service.dan.lang.XmlSpecParser
 
mminus() - Method in class solar.util.Counter
 
MobileCode - interface solar.service.mcode.MobileCode.
Interface for mobile code (moveable objects).
MobileCodeException - exception solar.service.mcode.MobileCodeException.
A generic exception thrown by mobile code services.
MobileCodeException(String) - Constructor for class solar.service.mcode.MobileCodeException
Construct an MobileCodeException with specified detail message.
MobileCodeException(String, Throwable) - Constructor for class solar.service.mcode.MobileCodeException
Construct an MobileCodeException with specified detail message and nested Throwable.
MobileCodeException(Throwable) - Constructor for class solar.service.mcode.MobileCodeException
Construct an MobileCodeException with specified nested Throwable.
MobileCodeService - interface solar.service.mcode.MobileCodeService.
The service supports code migration among Planets.
MobileHostException - exception solar.service.mhost.MobileHostException.
A generic exception thrown by mobile host services.
MobileHostException(String) - Constructor for class solar.service.mhost.MobileHostException
Construct an MobileHostException with specified detail message.
MobileHostException(String, Throwable) - Constructor for class solar.service.mhost.MobileHostException
Construct an MobileHostException with specified detail message and nested Throwable.
MobileHostException(Throwable) - Constructor for class solar.service.mhost.MobileHostException
Construct an MobileHostException with specified nested Throwable.
MobileHostListener - interface solar.service.mhost.MobileHostListener.
Listener interface for the mobile clients.
MobileHostService - interface solar.service.mhost.MobileHostService.
An interface for the client that may migrate from one Planet to the other.
Monitor - class solar.service.dan.Monitor.
A monitor is attached to some operator to manage its subscriptions or advertisement.
Monitor(DanService) - Constructor for class solar.service.dan.Monitor
 
multicast(Id, Event) - Method in class solar.service.pack.ScribeManager
Multicast an event to the tree of specified topic.
multicast(Id, Event) - Method in class solar.service.pubsub.ScribeManager
 
multicast(Id, Event) - Method in class solar.service.multicast.ScribeMulticastService
 
multicast(Id, Event) - Method in class solar.service.multicast.NaiveMulticastService
 
multicast(Id, Event) - Method in interface solar.service.multicast.MulticastService
Multicast an application-data unit to all group memebers.
MulticastConstants - interface solar.service.multicast.MulticastConstants.
Constants for multicast service.
MulticastException - exception solar.service.multicast.MulticastException.
An exception thrown by multicast services.
MulticastException(String) - Constructor for class solar.service.multicast.MulticastException
Construct an MulticastException with specified detail message.
MulticastException(String, Throwable) - Constructor for class solar.service.multicast.MulticastException
Construct an MulticastException with specified detail message and nested Throwable.
MulticastException(Throwable) - Constructor for class solar.service.multicast.MulticastException
Construct an MulticastException with specified nested Throwable.
MulticastGroup - class solar.service.multicast.MulticastGroup.
A multicast group maintains a list of participants.
MulticastGroup(Id) - Constructor for class solar.service.multicast.MulticastGroup
 
MulticastMember - interface solar.service.multicast.MulticastMember.
Interface for a multicast group member.
MulticastRequest - class solar.service.multicast.comm.MulticastRequest.
A request to multicast an event to all group members.
MulticastRequest(Id, Event) - Constructor for class solar.service.multicast.comm.MulticastRequest
 
MulticastService - interface solar.service.multicast.MulticastService.
The interface for multicast services.
MutateOperator - class solar.test.MutateOperator.
This operator mutates the received events by adding random attributes.
MutateOperator() - Constructor for class solar.test.MutateOperator
 
myCode - Variable in class solar.service.transport.PastryTransport.MultiplexAddress
 
myQValues(int[]) - Method in class versus.meeting.RLPolicy
 

N

NaiveMulticastService - class solar.service.multicast.NaiveMulticastService.
A naive multicast service does not attempt to build a dissemination tree and simply sends the message directly to every subscriber in best-effort.
NaiveMulticastService() - Constructor for class solar.service.multicast.NaiveMulticastService
 
Name - interface solar.service.directory.Name.
The interface for the names stored in the directory.
NAME - Static variable in class solar.service.pack.lang.XmlPolicyParser
 
NAME - Static variable in class solar.service.dan.lang.XmlSpecParser
 
NAME - Static variable in class campus.sysnort.XmlConfigParser
 
NAME_RECORD_SVID - Static variable in interface solar.SolarConstants
 
nameAdded(Name, NameRecord) - Method in class solar.Planet
 
nameAdded(Name, NameRecord) - Method in class solar.service.dan.Monitor
 
nameAdded(Name, NameRecord) - Method in class solar.service.directory.RemoteDirectoryListener
 
nameAdded(Name, NameRecord) - Method in interface solar.service.directory.DirectoryListener
Handle event about the addition of a name.
NameAddedRequest - class solar.service.directory.comm.NameAddedRequest.
Request to name added notification.
NameAddedRequest(Id, Name, NameRecord) - Constructor for class solar.service.directory.comm.NameAddedRequest
 
nameMigrated(Name, NameRecord, NameRecord) - Method in class solar.Planet
 
nameMigrated(Name, NameRecord, NameRecord) - Method in class solar.service.dan.Monitor
 
nameMigrated(Name, NameRecord, NameRecord) - Method in class solar.service.directory.RemoteDirectoryListener
 
nameMigrated(Name, NameRecord, NameRecord) - Method in interface solar.service.directory.DirectoryListener
Handle event about the migration of a name (named resource).
NameMigratedRequest - class solar.service.directory.comm.NameMigratedRequest.
Request to name migration notification.
NameMigratedRequest(Id, Name, NameRecord, NameRecord) - Constructor for class solar.service.directory.comm.NameMigratedRequest
 
NameNode - class solar.service.directory.NameNode.
A node in the directory tree, either an internal node or a leaf node.
NameNode(String) - Constructor for class solar.service.directory.NameNode
 
NameRecord - class solar.service.directory.NameRecord.
A record kept corresponding to a named resource, including its guid and current address.
NameRecord(Id, Address) - Constructor for class solar.service.directory.NameRecord
Construct a name record with its guid and current contact address.
NameRecord(Id, Address, Object) - Constructor for class solar.service.directory.NameRecord
Construct a name record with additional application-specific object.
nameRemoved(Name, NameRecord) - Method in class solar.Planet
 
nameRemoved(Name, NameRecord) - Method in class solar.service.dan.Monitor
 
nameRemoved(Name, NameRecord) - Method in class solar.service.directory.RemoteDirectoryListener
 
nameRemoved(Name, NameRecord) - Method in interface solar.service.directory.DirectoryListener
Handle event about the removal of a name.
NameRemovedRequest - class solar.service.directory.comm.NameRemovedRequest.
Request to name removed notification.
NameRemovedRequest(Id, Name, NameRecord) - Constructor for class solar.service.directory.comm.NameRemovedRequest
 
nameUpdated(Name, NameRecord, Name, NameRecord) - Method in class solar.Planet
 
nameUpdated(Name, NameRecord, Name, NameRecord) - Method in class solar.service.dan.Monitor
 
nameUpdated(Name, NameRecord, Name, NameRecord) - Method in class solar.service.directory.RemoteDirectoryListener
 
nameUpdated(Name, NameRecord, Name, NameRecord) - Method in interface solar.service.directory.DirectoryListener
Handle event about the change of a name.
NameUpdatedRequest - class solar.service.directory.comm.NameUpdatedRequest.
Request to name updated notification.
NameUpdatedRequest(Id, Name, NameRecord, Name, NameRecord) - Constructor for class solar.service.directory.comm.NameUpdatedRequest
 
needsFiltration(Request, Reply) - Method in class org.doit.muffin.filter.CompassFilter
 
NetUtil - class solar.util.NetUtil.
Some utility methods about networking.
NetUtil() - Constructor for class solar.util.NetUtil
Prevent object initialization.
NewDistPastryNodeFactory - class rice.pastry.dist.NewDistPastryNodeFactory.
A replacement of original DistPastryNodeFactory class.
NewDistPastryNodeFactory() - Constructor for class rice.pastry.dist.NewDistPastryNodeFactory
 
newNode(NodeHandle) - Method in class rice.pastry.wire.UdpPastryNodeFactory
Method which creates a Pastry node from the next port with a randomly generated NodeId.
newNode(NodeHandle) - Method in class rice.pastry.wire.TcpPastryNodeFactory
Method which creates a Pastry node from the next port with a randomly generated NodeId.
newNode(NodeHandle) - Method in class rice.pastry.socket.SocketPastryNodeFactory
Method which creates a Pastry node from the next port with a randomly generated NodeId.
newNode(NodeHandle, NodeId) - Method in class rice.pastry.wire.UdpPastryNodeFactory
Method which creates a Pastry node from the next port with a randomly generated NodeId.
newNode(NodeHandle, NodeId) - Method in class rice.pastry.wire.TcpPastryNodeFactory
Method which creates a Pastry node from the next port with a randomly generated NodeId.
newNode(NodeHandle, NodeId) - Method in class rice.pastry.socket.SocketPastryNodeFactory
Method which creates a Pastry node from the next port with a randomly generated NodeId.
newParent(NodeId, NodeHandle, Serializable) - Method in class solar.service.pack.ScribeManager
Upcall made by scribe to the registered applications to inform them that a new parent is found for local node in the topic tree.
newParent(NodeId, NodeHandle, Serializable) - Method in class solar.service.pubsub.ScribeManager
Upcall made by scribe to the registered applications to inform them that a new parent is found for local node in the topic tree.
newParent(NodeId, NodeHandle, Serializable) - Method in class solar.service.multicast.ScribeMulticastService.ScribeMember
Upcall made by scribe to the registered applications to inform them that a new parent is found for local node in the topic tree.
newPolicy() - Method in class versus.meeting.RLearner
 
newstate - Variable in class versus.meeting.RLearner
 
next - Variable in class solar.util.ssLinkedList.ssLinkedListElement
 
nextElement() - Method in class solar.util.ssLinkedList.ssLinkedListEnumeration
 
NodeHandler - class solar.service.dan.NodeHandler.
The wrapper class of graph nodes through which the resident sources and operators interact with other services of the local Planet.
NodeHandler(GraphNode) - Constructor for class solar.service.dan.NodeHandler
 
nodeId - Variable in class rice.pastry.socket.HelloResponseMessage
 
nodeId - Variable in class rice.pastry.socket.HelloMessage
 
nodeIsReady() - Method in class rice.pastry.socket.SocketPastryNode
 
NodeManager - class solar.service.dan.NodeManager.
This class manages all the local graph nodes.
NodeManager() - Constructor for class solar.service.dan.NodeManager
 
notifyClientAttached(Address) - Method in class solar.service.mhost.SolarMobileHostService
 
notifyClientDetached(Address) - Method in class solar.service.mhost.SolarMobileHostService
 
notifyConnectionClosed(SocketAddress) - Method in class solar.service.transport.TcpTransport
Notify transport listeners about closed connection.
notifyConnectionOpened(SocketAddress) - Method in class solar.service.transport.TcpTransport
Notify transport listeners about new connection.
notifyDataReceived(Adu, Header) - Method in class solar.service.transport.UdpObjectTransport
Notify transport listeners about received message.
notifyDataReceived(Adu, Header) - Method in class solar.service.transport.UdpTransport
Notify transport listeners about received message.
notifyDataReceived(Adu, Header) - Method in class solar.service.transport.TcpTransport
Notify transport listeners about received data.
notifyDataReceived(Adu, Header) - Method in class solar.service.transport.BaseTransportService
 
notifyDataReceived(Adu, Header) - Method in class solar.service.transport.PastryTransport
Notify transport listeners about received data.
notifyObjectExpired(CachedObject) - Method in class solar.module.cache.BaseCache
 
notifyObjectExpired(CachedObject) - Method in interface solar.module.cache.Cache.CacheListener
Notify when an object has expired from the cache.
notifyObjectExpired(CachedObject) - Method in class solar.service.routing.ManualRoutingService
 
notifyObjectExpired(CachedObject) - Method in class solar.service.rmtobj.SolarRemoteObjectService
 
NUM_ACTIONS - Static variable in class versus.meeting.RLMeetingWorld
 
num_in_list - Variable in class solar.util.ssLinkedList
 
num_in_lle_heap - Variable in class solar.util.ssLinkedList
 
NUM_IT - Static variable in class solar.util.ssLinkedList
Test code for the ssLinkedList
NUM_OBJECTS - Static variable in class versus.meeting.RLMeetingWorld
 
NUM_STATES - Static variable in class versus.meeting.RLMeetingWorld
 

O

obj - Variable in class solar.util.ssLinkedList.ssLinkedListElement
 
ODD - class solar.service.pack.filter.ODD.
The PACK filter throws events whose value is not odd.
ODD() - Constructor for class solar.service.pack.filter.ODD
 
openConnection(SocketAddress) - Method in class solar.service.transport.TcpTransport
Open a new connection to a specified address.
openSocket(WireNodeHandle) - Method in class rice.pastry.wire.SocketManager
Method which is designed to be called by node handles when they wish to open a socket to their remote node.
openSockets - Variable in class rice.pastry.wire.SocketManager
 
Operator - class solar.service.dan.Operator.
An abstract class for all Solar operators.
Operator() - Constructor for class solar.service.dan.Operator
 
OptimisticBufferPacker - class solar.service.pack.proto.OptimisticBufferPacker.
An optimistic buffer packer always runs a single filter in the policy trying to drop as few events as possible.
OptimisticBufferPacker() - Constructor for class solar.service.pack.proto.OptimisticBufferPacker
 
org.doit.muffin - package org.doit.muffin
Contains wrapper class for Muffin, used by Compass application.
org.doit.muffin.filter - package org.doit.muffin.filter
Contains some predefined Muffin filters used by Compass application.
out - Variable in class org.doit.muffin.filter.CompassFilter
 
OUTPORT - Static variable in class solar.service.dan.lang.XmlSpecParser
 
OutputBufferManager - interface solar.service.pack.proto.OutputBufferManager.
Interface for algorithms that determine when and which event to transmit.
OutputPort - class solar.service.fap.OutputPort.
An output port of a source filter to a pipe.
OutputPort(String) - Constructor for class solar.service.fap.OutputPort
 
OutputProtocol - class solar.service.pack.proto.OutputProtocol.
Protocol sends events to directly connected clients/proxy.
OutputProtocol(int, int, int) - Constructor for class solar.service.pack.proto.OutputProtocol
 
outputZones() - Method in class versus.VersusMapping
 

P

PACK - Static variable in class solar.service.pack.lang.XmlPolicyParser
 
PACK_ACK - Static variable in interface solar.service.pack.PackConstants
 
PACK_BUFFER_LIMIT - Static variable in interface solar.service.pack.PackConstants
 
PACK_EVENT - Static variable in interface solar.service.pack.PackConstants
 
PACK_FORWARD - Static variable in interface solar.service.pack.PackConstants
 
PACK_LASTHOP - Static variable in interface solar.service.pack.PackConstants
 
PACK_MEMORY_LIMIT - Static variable in interface solar.service.pack.PackConstants
 
PACK_POLICY - Static variable in interface solar.service.pack.PackConstants
 
PACK_POLICY_SVID - Static variable in interface solar.SolarConstants
 
PACK_PUBID - Static variable in interface solar.service.pack.PackConstants
 
PACK_SUBID - Static variable in interface solar.service.pack.PackConstants
 
PACK_SUSPEND_LIMIT - Static variable in interface solar.service.pack.PackConstants
 
pack() - Method in class solar.service.pack.proto.GroupBufferHandle
 
pack() - Method in class solar.service.pack.proto.SingleBufferHandle
 
pack() - Method in interface solar.service.pack.proto.BufferHandle
Pack the buffers in this handle.
pack(Buffer, PackPolicy) - Method in class solar.service.pack.proto.PessimisticBufferPacker
 
pack(Buffer, PackPolicy) - Method in class solar.service.pack.proto.OptimisticBufferPacker
 
pack(Buffer, PackPolicy) - Method in interface solar.service.pack.proto.BufferPacker
 
PackClient - class solar.service.pack.client.PackClient.
The facade class to interact with Solar system for PACK service.
PackClient(Options) - Constructor for class solar.service.pack.client.PackClient
 
PackClient(String) - Constructor for class solar.service.pack.client.PackClient
 
PackClient(String, int) - Constructor for class solar.service.pack.client.PackClient
 
PackClient(String, int, Options) - Constructor for class solar.service.pack.client.PackClient
 
PackConstants - interface solar.service.pack.PackConstants.
Constants definition for PACK service.
PackEvent - class solar.service.pack.comm.PackEvent.
A wrapper class for PACK event that is used for wire transfer.
PackEvent(Event) - Constructor for class solar.service.pack.comm.PackEvent
 
PackEvent(Id, Id, Event, boolean) - Constructor for class solar.service.pack.comm.PackEvent
 
PackException - exception solar.service.pack.PackException.
An exception thrown by PACK services.
PackException(String) - Constructor for class solar.service.pack.PackException
Construct an PackException with specified detail message.
PackException(String, Throwable) - Constructor for class solar.service.pack.PackException
Construct an PackException with specified detail message and nested Throwable.
PackException(Throwable) - Constructor for class solar.service.pack.PackException
Construct an PackException with specified nested Throwable.
PackFilter - class solar.service.pack.PackFilter.
PACK filters are the elements of flow-control policies.
PackFilter() - Constructor for class solar.service.pack.PackFilter
 
PackFilter(Id) - Constructor for class solar.service.pack.PackFilter
 
PackPolicy - class solar.service.pack.PackPolicy.
A flow-control policy for PACK service.
PackPolicy() - Constructor for class solar.service.pack.PackPolicy
 
PackReceiver - class solar.test.PackReceiver.
A standalone event subscriber using PACK service.
PackReceiver.Profiler - class solar.test.PackReceiver.Profiler.
 
PackReceiver.Profiler(boolean) - Constructor for class solar.test.PackReceiver.Profiler
 
PackReceiver() - Constructor for class solar.test.PackReceiver
 
PackSender - class solar.test.PackSender.
A standalone event publisher using PACK service.
PackSender() - Constructor for class solar.test.PackSender
 
PackService - interface solar.service.pack.PackService.
PACK service allows application to customize the flow-control policies.
PackSession - class solar.service.pack.PackSession.
A packing session handles intermediate results such as event summaries.
PackSession() - Constructor for class solar.service.pack.PackSession
 
PackTailIBM - class solar.service.pack.proto.PackTailIBM.
This input buffer manager packs the buffer of incoming events if buffer space reaches memory limit.
PackTailIBM(BaseProtocol.ProtocolState) - Constructor for class solar.service.pack.proto.PackTailIBM
 
parse(byte[]) - Method in interface solar.api.AduFactory
Parse received byte array into an ADU.
parse(byte[]) - Method in class solar.impl.EventFactory
 
parse(byte[], int, int) - Method in interface solar.api.AduFactory
Parse part of the received byte array into an ADU.
parse(byte[], int, int) - Method in class solar.impl.EventFactory
 
parse(File) - Method in class solar.service.pack.lang.XmlPolicyParser
 
parse(File) - Method in interface solar.service.pack.lang.PolicyParser
Parse the PACK policy from a file.
parse(File) - Method in class solar.service.dan.lang.XmlSpecParser
 
parse(File) - Method in interface solar.service.dan.lang.SpecParser
Parse the graph spec from a file.
parse(File) - Method in class versus.XmlVersusParser
Parse Versus configuration in an XML file.
parse(File) - Method in class campus.sysnort.XmlConfigParser
 
parse(InputSource) - Static method in class solar.service.pack.lang.XmlPolicyParser
 
parse(InputSource) - Static method in class solar.service.dan.lang.XmlSpecParser
 
parse(InputSource) - Method in class versus.XmlVersusParser
Parse Versus configuration in an XML input source.
parse(InputSource) - Static method in class campus.sysnort.XmlConfigParser
 
parse(InputStream) - Method in class solar.service.pack.lang.XmlPolicyParser
 
parse(InputStream) - Method in interface solar.service.pack.lang.PolicyParser
Parse the PACK policy from an input stream.
parse(InputStream) - Method in class solar.service.dan.lang.XmlSpecParser
 
parse(InputStream) - Method in interface solar.service.dan.lang.SpecParser
Parse the graph spec from an input stream.
parse(InputStream) - Method in class versus.XmlVersusParser
Parse Versus configuration in an XML stream.
parse(InputStream) - Method in class campus.sysnort.XmlConfigParser
 
parse(Reader) - Method in class solar.service.pack.lang.XmlPolicyParser
 
parse(Reader) - Method in interface solar.service.pack.lang.PolicyParser
Parse the PACK policy from a reader.
parse(Reader) - Method in class solar.service.dan.lang.XmlSpecParser
 
parse(Reader) - Method in interface solar.service.dan.lang.SpecParser
Parse the graph spec from a reader.
parse(Reader) - Method in class campus.sysnort.XmlConfigParser
 
parse(String) - Method in class solar.service.pack.lang.XmlPolicyParser
 
parse(String) - Method in interface solar.service.pack.lang.PolicyParser
Parse the PACK policy from a string.
parse(String) - Method in class solar.service.dan.lang.XmlSpecParser
 
parse(String) - Method in interface solar.service.dan.lang.SpecParser
Parse the graph spec from a string.
parse(String) - Method in class solar.service.fork.TaskBatch
 
parse(String) - Method in class campus.sysnort.XmlConfigParser
 
parse(String) - Method in class campus.syslog.SyslogParser
 
parseAddress(byte[]) - Static method in class solar.service.transport.AddressFactory
Parse an address from a byte array.
parseAddress(byte[], int, int) - Static method in class solar.service.transport.AddressFactory
Parse an address from a byte array.
parseClient(String) - Method in class campus.syslog.SyslogParser
 
parseEvent(byte[]) - Static method in class solar.impl.EventFactory
Parse the byte array into a particular event, the first byte indicates the event type.
parseEvent(byte[], int, int) - Static method in class solar.impl.EventFactory
Parse the byte array into a particular event, the first byte indicates the event type.
parseLogString(String) - Static method in class campus.Location
 
parseMsgType(String) - Method in class campus.syslog.SyslogParser
 
parseNote(String) - Method in class campus.syslog.SyslogParser
 
parsePlainAttributeRecord(String) - Method in class solar.impl.PlainAttributeRecord
Parse an attribute record encoded in a string.
parseSerializedEvent(byte[], int, int) - Method in class solar.impl.SerializedEvent
 
ParsingException - exception solar.api.ParsingException.
The exception thrown by a (such as name, event, and others) parser.
ParsingException(String) - Constructor for class solar.api.ParsingException
Construct an ParsingException with specified detail message.
ParsingException(String, Throwable) - Constructor for class solar.api.ParsingException
Construct an ParsingException with specified detail message and nested Throwable.
ParsingException(Throwable) - Constructor for class solar.api.ParsingException
Construct an ParsingException with nested Throwable.
PASTRY_ADDRESS - Static variable in interface solar.service.transport.TransportConstants
 
PastryAddress - class solar.service.transport.PastryAddress.
Network address for Pastry substrate.
PastryAddress() - Constructor for class solar.service.transport.PastryAddress
Construct a Pastry address with a random Node ID.
PastryAddress(byte[]) - Constructor for class solar.service.transport.PastryAddress
Construct a Pastry address with specified Node ID in byte array.
PastryAddress(Id) - Constructor for class solar.service.transport.PastryAddress
Construct a Pastry address with specified Node ID.
PastryMessage - class solar.service.transport.PastryMessage.
Message object to route through Pastry substrate.
PastryMessage(Adu, Address) - Constructor for class solar.service.transport.PastryMessage
 
PastryMessage(byte[], Address) - Constructor for class solar.service.transport.PastryMessage
 
pastryNode - Variable in class rice.pastry.wire.SocketManager
 
pastryNode - Variable in class rice.pastry.wire.SocketChannelWriter
 
pastryNode - Variable in class rice.pastry.socket.SocketNodeHandlePool
 
PastryObjectTransport - class solar.service.transport.PastryObjectTransport.
A Pastry transport layer using object serialization.
PastryObjectTransport(PastryNode) - Constructor for class solar.service.transport.PastryObjectTransport
 
PastryTransport - class solar.service.transport.PastryTransport.
A Pastry transport application interfacing with Pastry routing substrate.
PastryTransport.MultiplexAddress - class solar.service.transport.PastryTransport.MultiplexAddress.
 
PastryTransport.MultiplexAddress() - Constructor for class solar.service.transport.PastryTransport.MultiplexAddress
 
PastryTransport(PastryNode) - Constructor for class solar.service.transport.PastryTransport
 
PastryTransportService - class solar.service.transport.PastryTransportService.
Transport service using Pastry routing substrate.
PastryTransportService() - Constructor for class solar.service.transport.PastryTransportService
 
pconnect(Id, int, Address, Id, OutputPort, DataSink, InputPort, boolean) - Method in class solar.service.fap.FapClientService
 
pconnect(Id, int, Address, Id, OutputPort, DataSink, InputPort, boolean) - Method in interface solar.service.fap.FapService
Setup a pipe that has a remote source.
pconnect(Id, int, DataSource, OutputPort, Address, Id, InputPort, boolean) - Method in class solar.service.fap.FapClientService
 
pconnect(Id, int, DataSource, OutputPort, Address, Id, InputPort, boolean) - Method in interface solar.service.fap.FapService
Setup a pipe that has a remote sink.
pconnect(Id, int, DataSource, OutputPort, DataSink, InputPort) - Method in class solar.service.fap.FapClientService
 
pconnect(Id, int, DataSource, OutputPort, DataSink, InputPort) - Method in interface solar.service.fap.FapService
Setup a local pipe and return the pipe ID.
pconnect(int, Address, Guid, String, Guid, String, boolean) - Method in class solar.service.dan.PipeConnector
Connects a remote source to a local sink.
pconnect(int, Guid, String, Address, Guid, String, boolean) - Method in class solar.service.dan.PipeConnector
Connects a local source to a remote sink.
pconnect(int, Guid, String, Guid, String) - Method in class solar.service.dan.PipeConnector
Connects a local source to a local sink.
pconnect(Request) - Method in class solar.service.dan.PipeConnector
Handle the pconnect request.
PessimisticBufferPacker - class solar.service.pack.proto.PessimisticBufferPacker.
A pessimistic buffer packer always runs all the filters in the policy trying to drop as much events as possible.
PessimisticBufferPacker() - Constructor for class solar.service.pack.proto.PessimisticBufferPacker
 
PING_THROTTLE - Static variable in class rice.pastry.wire.WireNodeHandle
 
PING_THROTTLE - Static variable in class rice.pastry.socket.SocketNodeHandle
 
PingEvent - class solar.service.rmtobj.comm.PingEvent.
A wrapper event to notify interested parties about local objects.
PingEvent(Address, Set) - Constructor for class solar.service.rmtobj.comm.PingEvent
 
PingEvent(Event) - Constructor for class solar.service.rmtobj.comm.PingEvent
 
pingImpl() - Method in class rice.pastry.wire.WireNodeHandle
Ping the remote node now, and update the proximity metric.
pingImpl() - Method in class rice.pastry.socket.SocketNodeHandle
 
pingResponse() - Method in class rice.pastry.wire.WireNodeHandle
Method which is called by the SocketPingManager when a ping response comes back for this node.
pingStarted() - Method in class rice.pastry.wire.WireNodeHandle
Method which is called by the PingMessage right before it is going to be sent across the wire.
Pipe - class solar.service.fap.Pipe.
A pipe consists of a pair of channels: A writable sink channel and a readable source channel.
PIPE - Static variable in class solar.service.dan.lang.XmlSpecParser
 
PIPE_SPEC_SVID - Static variable in interface solar.SolarConstants
 
Pipe(Id, int) - Constructor for class solar.service.fap.Pipe
Constructs a pipe with specified ID and pull/push type.
Pipe(Id, int, SourceChannel, SinkChannel) - Constructor for class solar.service.fap.Pipe
Constructs a pipe with additional pair of source/sink channels.
PipeConnector - class solar.service.dan.PipeConnector.
A pipe connector is responsible to set up a pipe between a data source and a data sink.
PipeConnector(DanService) - Constructor for class solar.service.dan.PipeConnector
 
PipeConnectRequest - class solar.service.dan.comm.PipeConnectRequest.
A request to set up a pipe.
PipeConnectRequest(Guid, Guid, Address, Id, int, boolean) - Constructor for class solar.service.dan.comm.PipeConnectRequest
 
PipeFactory - class solar.service.fap.PipeFactory.
The factory produces new pipe objects.
PipeFactory() - Constructor for class solar.service.fap.PipeFactory
 
PipePullRequest - class solar.service.fap.comm.PipePullRequest.
A request to pull data from the pipe.
PipePullRequest(Id, Object) - Constructor for class solar.service.fap.comm.PipePullRequest
 
PipePushEvent - class solar.service.fap.comm.PipePushEvent.
A wrapper event encoding the data pushed down the pipe.
PipePushEvent(Event) - Constructor for class solar.service.fap.comm.PipePushEvent
 
PipePushEvent(Id, Object) - Constructor for class solar.service.fap.comm.PipePushEvent
 
PipeSpec - class solar.service.dan.lang.PipeSpec.
The spec for a pipe connecting two filters.
PipeSpec() - Constructor for class solar.service.dan.lang.PipeSpec
 
PlainAttributeRecord - class solar.impl.PlainAttributeRecord.
Plain attribute record encodes string attributes in square brackets.
PlainAttributeRecord() - Constructor for class solar.impl.PlainAttributeRecord
Constructs an empty attribute record.
PlainAttributeRecord(AttributeRecord) - Constructor for class solar.impl.PlainAttributeRecord
Constructs an atribute record by copying from another one.
PlainAttributeRecord(List) - Constructor for class solar.impl.PlainAttributeRecord
Constructs an atribute record with a list of attributes.
PlainAttributeRecord(String) - Constructor for class solar.impl.PlainAttributeRecord
Constructs an attribute record by parsing an encoded string.
PlainEvent - class solar.impl.PlainEvent.
An event with plain encoding of square brackets.
PlainEvent() - Constructor for class solar.impl.PlainEvent
Constructs an empty plain event.
PlainEvent(AttributeRecord) - Constructor for class solar.impl.PlainEvent
Constructs an event with a list of attributes.
PlainEvent(Event) - Constructor for class solar.impl.PlainEvent
Constructs an event by copying from another one.
PlainEvent(List) - Constructor for class solar.impl.PlainEvent
Constructs an event with a list of attributes.
PlainEvent(String) - Constructor for class solar.impl.PlainEvent
Constructs an event by parsing an encoded string.
PlainName - class solar.service.directory.PlainName.
A name with strings encoded in square brackets.
PlainName(AttributeRecord) - Constructor for class solar.service.directory.PlainName
Constructs a name with a list of attributes.
PlainName(List) - Constructor for class solar.service.directory.PlainName
Constructs a name with a list of attributes.
PlainName(Name) - Constructor for class solar.service.directory.PlainName
Constructs a name by copying from another one.
PlainName(String) - Constructor for class solar.service.directory.PlainName
Constructs a name by parsing an encoded string.
Planet - class solar.Planet.
A service platform for Solar, which contains an overlay of Planets.
Planet() - Constructor for class solar.Planet
 
plus(int) - Method in class solar.util.Counter
 
policy - Variable in class versus.meeting.RLearner
 
PolicyParser - interface solar.service.pack.lang.PolicyParser.
Interface for the parser of PACK policy.
POLL_INTERVAL - Static variable in class campus.snmp.SnmpLocator
 
pool - Variable in class rice.pastry.socket.SocketPastrySecurityManager
 
port - Variable in class rice.pastry.wire.SocketManager
 
Port - class solar.service.fap.Port.
A port is a connection point between filters and pipes.
Port(String) - Constructor for class solar.service.fap.Port
 
power - Variable in class campus.syslog.APConfiguration
 
pplus() - Method in class solar.util.Counter
 
prefs - Variable in class org.doit.muffin.filter.Logger
 
prefs - Variable in class org.doit.muffin.filter.LoggerFilter
 
prefs - Variable in class org.doit.muffin.filter.Compass
 
prefs - Variable in class org.doit.muffin.filter.CompassFilter
 
prev - Variable in class solar.util.ssLinkedList.ssLinkedListElement
 
printAccessPoints() - Method in class campus.CampusMap
 
printTime(long, long, int) - Static method in class solar.util.ssLinkedList
 
process(Options) - Method in class solar.Shell
 
processOneLine(String) - Method in class campus.LogTracer
 
Protocol - interface solar.module.protocol.Protocol.
Interface for event transfer protocols.
PROTOCOL_TCP - Static variable in class rice.pastry.socket.SocketPastryNodeFactory
 
PROTOCOL_TCP - Static variable in class rice.pastry.dist.NewDistPastryNodeFactory
 
PROTOCOL_UDP - Static variable in class rice.pastry.socket.SocketPastryNodeFactory
 
PROTOCOL_UDP - Static variable in class rice.pastry.dist.NewDistPastryNodeFactory
 
ProtocolEvent - interface solar.module.protocol.ProtocolEvent.
Interface for protocol-specific control events, such as ACK and NACK.
ProtocolListener - interface solar.module.protocol.ProtocolListener.
Interface for protocol listeners.
ProxyOperator - class solar.service.dan.ProxyOperator.
A proxy operator deligates the duty to its assgined event handler.
ProxyOperator(EventHandler) - Constructor for class solar.service.dan.ProxyOperator
 
PubEvent - class solar.service.pubsub.comm.PubEvent.
A wrapper class for published event.
PubEvent(Event) - Constructor for class solar.service.pubsub.comm.PubEvent
 
PubEvent(Id, Id, Event) - Constructor for class solar.service.pubsub.comm.PubEvent
 
publish(Event) - Method in class solar.service.dan.GraphNode
 
publish(Event) - Method in class solar.service.dan.NodeHandler
Publish an event to all its subscribers.
publish(Event, String) - Method in class solar.service.dan.GraphNode
 
publish(Event, String) - Method in class solar.service.dan.NodeHandler
Publish an event to all its subscribers through a specified port.
publish(Id, Event) - Method in class solar.service.pack.ScribePackService
 
publish(Id, Event) - Method in class solar.service.pack.ClientPackService
 
publish(Id, Event) - Method in interface solar.service.pack.PackService
Publish an event to all subscribers.
publish(Id, Event) - Method in class solar.service.pack.client.PackClient
 
publish(Id, Event) - Method in class solar.service.pubsub.ScribePubSubService
 
publish(Id, Event) - Method in class solar.service.pubsub.ClientPubSubService
 
publish(Id, Event) - Method in interface solar.service.pubsub.PubSubService
Publish an event to all subscribers.
publish(Id, Event) - Method in class solar.service.pubsub.client.PubSubClient
 
publish(long) - Method in class solar.test.PackSender
 
Publisher - interface solar.service.pubsub.Publisher.
Interface for the publishers who sends out an event stream.
PubRegisterRequest - class solar.service.pubsub.comm.PubRegisterRequest.
A reuqest to register a PACK publisher.
PubRegisterRequest(Id) - Constructor for class solar.service.pubsub.comm.PubRegisterRequest
 
PUBSUB_EVENT - Static variable in interface solar.service.pubsub.PubSubConstants
 
PUBSUB_PUBID - Static variable in interface solar.service.pubsub.PubSubConstants
 
PUBSUB_SUBID - Static variable in interface solar.service.pubsub.PubSubConstants
 
PubSubClient - class solar.service.pubsub.client.PubSubClient.
The facade class to interact with Solar system for Pub/Sub service.
PubSubClient(Options) - Constructor for class solar.service.pubsub.client.PubSubClient
 
PubSubClient(String) - Constructor for class solar.service.pubsub.client.PubSubClient
 
PubSubClient(String, int) - Constructor for class solar.service.pubsub.client.PubSubClient
 
PubSubClient(String, int, Options) - Constructor for class solar.service.pubsub.client.PubSubClient
 
PubSubConstants - interface solar.service.pubsub.PubSubConstants.
Constants definition for Pub/Sub service.
PubSubException - exception solar.service.pubsub.PubSubException.
An exception thrown by PubSub services.
PubSubException(String) - Constructor for class solar.service.pubsub.PubSubException
Construct an PubSubException with specified detail message.
PubSubException(String, Throwable) - Constructor for class solar.service.pubsub.PubSubException
Construct an PubSubException with specified detail message and nested Throwable.
PubSubException(Throwable) - Constructor for class solar.service.pubsub.PubSubException
Construct an PubSubException with specified nested Throwable.
PubSubService - interface solar.service.pubsub.PubSubService.
Interface for publish/subscribe service.
PULL - Static variable in class solar.service.dan.lang.XmlSpecParser
 
pullData(Object) - Method in class solar.service.fap.DirectPipe
 
pullData(Object) - Method in class solar.service.fap.LocalSourceChannel
 
pullData(Object) - Method in class solar.service.fap.RemoteSourceChannel
 
pullData(Object) - Method in interface solar.service.fap.SourceChannel
Pull the data from upstream filter (data source).
pullData(Object) - Method in class solar.service.fap.Pipe
Pull data from this pipe.
pullData(Object, OutputPort) - Method in class solar.service.dan.NodeHandler
 
pullData(Object, OutputPort) - Method in interface solar.service.fap.DataSource
Pull data from this data source at a specific port.
PUSH - Static variable in class solar.service.dan.lang.XmlSpecParser
 
pushData(Object) - Method in class solar.service.fap.DirectPipe
 
pushData(Object) - Method in class solar.service.fap.LocalSinkChannel
 
pushData(Object) - Method in class solar.service.fap.RemoteSinkChannel
 
pushData(Object) - Method in interface solar.service.fap.SinkChannel
Push the data to the downstream filter (data sink).
pushData(Object) - Method in class solar.service.fap.Pipe
Push data through this pipe.
pushData(Object, InputPort) - Method in class solar.service.dan.NodeHandler
 
pushData(Object, InputPort) - Method in interface solar.service.fap.DataSink
Push data to this data sink at a specific port.
put(Event) - Method in class solar.module.protocol.Buffer
Add an event to the buffer, return false if limit is exceeded.
putAll(Collection) - Method in class solar.module.protocol.Buffer
 
putBlock(Object) - Static method in class solar.service.rpc.Block
Add one block into repository.
putEndPoint(Id, Id, Address, EndPoint) - Method in class solar.service.pubsub.EndPointManager
 
putEvent(Event, Address) - Method in interface solar.module.protocol.Protocol
Put a received event into protocol buffers.
putEvent(Event, Address) - Method in class solar.service.pack.proto.BaseProtocol
 
putEvent(Id, Id, Event) - Method in class solar.service.pack.proto.DropTailIBM
 
putEvent(Id, Id, Event) - Method in class solar.service.pack.proto.PackTailIBM
 
putEvent(Id, Id, Event) - Method in class solar.service.pack.proto.GroupBufferHandle
 
putEvent(Id, Id, Event) - Method in class solar.service.pack.proto.SingleBufferHandle
 
putEvent(Id, Id, Event) - Method in interface solar.service.pack.proto.BufferHandle
Put a subscribed event into this handle.
putEvent(Id, Id, Event) - Method in interface solar.service.pack.proto.InputBufferManager
 
putEvents(Id, Id, Buffer) - Method in class solar.service.pack.proto.GroupBufferHandle
 
putEvents(Id, Id, Buffer) - Method in class solar.service.pack.proto.SingleBufferHandle
 
putEvents(Id, Id, Buffer) - Method in interface solar.service.pack.proto.BufferHandle
Put a list of events into this handle.
putFilter(String, FilterSpec) - Method in class solar.service.dan.lang.GraphSpec
 
putLocal(Guid, NodeHandler) - Method in class solar.service.dan.NodeManager
Put a local node (handler) with specified guid.
putPipe(String, PipeSpec) - Method in class solar.service.dan.lang.GraphSpec
 
putRemote(Guid, Address) - Method in class solar.service.dan.NodeManager
Put a remove node with specified address.
putSubEvent(Id, Event) - Method in class solar.service.pack.proto.GroupBufferHandle
 
putSubEvents(Id, Buffer) - Method in class solar.service.pack.proto.GroupBufferHandle
 
putTrigger(String, TriggerConfig) - Method in class campus.sysnort.SysnortConfig
 

Q

Q_LAMBDA - Static variable in class versus.meeting.RLearner
 
Q_LEARNING - Static variable in class versus.meeting.RLearner
 
QUALIFIERS - Static variable in class versus.VersusSource
 
queue - Variable in class rice.pastry.wire.SocketChannelWriter
 
Queue - interface solar.util.Queue.
A queue interface with standard enqueue/dequeue operations.
QueueFactory - class solar.util.QueueFactory.
A factory produces appropriate type of queues.
QueueFactory() - Constructor for class solar.util.QueueFactory
 
qValues - Variable in class versus.meeting.RLPolicy
 
qValuesTable - Variable in class versus.meeting.RLPolicy
 

R

ran - Static variable in class solar.util.StringUtil
 
random - Variable in class versus.meeting.RLearner
 
RANDOM - class solar.service.pack.filter.RANDOM.
This filter uniformly drop certain percent of buffered events.
RANDOM() - Constructor for class solar.service.pack.filter.RANDOM
 
read() - Method in class rice.pastry.wire.SocketManager.SocketConnector
Reads from the socket attached to this connector.
read(DataInputStream) - Method in class solar.service.transport.Header
 
read(ObjectInputStream) - Method in class solar.service.transport.Header
 
read(SelectionKey) - Method in class rice.pastry.wire.SocketManager
Specified by the SelectionKeyHandler interface - is called whenever a key has data available.
read(SelectionKey) - Method in class rice.pastry.wire.WireNodeHandle
Called by the socket manager whenever there is data to be read from this node handle's remote node.
reader - Variable in class rice.pastry.wire.SocketManager.SocketConnector
 
reader - Variable in class rice.pastry.wire.WireNodeHandle
 
readObject(ObjectInputStream) - Method in class rice.pastry.wire.WireNodeHandle
Overridden in order to specify the default state (using UDP)
receiveMessage(ScribeMessage) - Method in class solar.service.pack.ScribeManager
up-call invoked by scribe when a publish message is 'delivered'.
receiveMessage(ScribeMessage) - Method in class solar.service.pubsub.ScribeManager
up-call invoked by scribe when a publish message is 'delivered'.
receiveMessage(ScribeMessage) - Method in class solar.service.multicast.ScribeMulticastService.ScribeMember
up-call invoked by scribe when a publish message is 'delivered'.
receiveMessageImpl(Message) - Method in class rice.pastry.wire.UdpNodeHandle
Called to send a message to the node corresponding to this handle.
receiveMessageImpl(Message) - Method in class rice.pastry.wire.TcpNodeHandle
Called to send a message to the node corresponding to this handle.
receiveMessageImpl(Message) - Method in class rice.pastry.wire.WireNodeHandle
Called to send a message to the node corresponding to this handle.
receiveMessageImpl(Message) - Method in class rice.pastry.socket.SocketNodeHandle
Called to send a message to the node corresponding to this handle.
receivePeerAddress() - Method in class solar.service.transport.TcpConnection
Receive peer address from this connection.
ReceiveRequest - class solar.service.multicast.comm.ReceiveRequest.
A notification request about a received multicast event.
ReceiveRequest(Id, Event) - Constructor for class solar.service.multicast.comm.ReceiveRequest
 
receiveSocketMessage(SocketCommandMessage) - Method in class rice.pastry.wire.WireNodeHandle
Method which is called when a SocketCommandMessage comes across an open socket for this node handle.
receiveSocketMessage(SocketCommandMessage) - Method in class rice.pastry.socket.SocketNodeHandle
Method which is called when a SocketCommandMessage comes across an open socket for this node handle.
record(String, String, String) - Method in class campus.snmp.SnmpLocator
Record location mapping in tables.
RefreshableCache - class solar.module.cache.RefreshableCache.
Objects in a refreshable cache can be refreshed by adding them again.
RefreshableCache() - Constructor for class solar.module.cache.RefreshableCache
 
RefreshableCache(int, long) - Constructor for class solar.module.cache.RefreshableCache
 
register(Id) - Method in class solar.service.rmtobj.SolarRemoteObjectService
 
register(Id) - Method in interface solar.service.rmtobj.RemoteObjectService
Register a local object for remote monitoring.
register(Id, RequestHandler) - Method in class solar.service.rmtobj.SolarRemoteObjectService
 
register(Id, RequestHandler) - Method in interface solar.service.rmtobj.RemoteObjectService
Register a local object for remote monitoring.
register(RemoteObject, RemoteObjectListener) - Method in class solar.service.rmtobj.SolarRemoteObjectService
 
register(RemoteObject, RemoteObjectListener) - Method in interface solar.service.rmtobj.RemoteObjectService
Register a remote object to monitor.
registerPipe(Id, Pipe) - Method in class solar.service.fap.FapClientService
 
registerPipeId(Id) - Method in class solar.service.fap.FapClientService
 
RegisterRequest - class solar.service.rmtobj.comm.RegisterRequest.
A request to register interest on a remote object.
RegisterRequest(Id) - Constructor for class solar.service.rmtobj.comm.RegisterRequest
 
RelayOperator - class solar.service.dan.RelayOperator.
A simple operator relay events and requests.
RelayOperator() - Constructor for class solar.service.dan.RelayOperator
 
RemoteDirectoryListener - class solar.service.directory.RemoteDirectoryListener.
A proxy class for remote name observer.
RemoteDirectoryListener(Id, Address) - Constructor for class solar.service.directory.RemoteDirectoryListener
 
RemoteMulticastMember - class solar.service.multicast.RemoteMulticastMember.
A proxy class for remote multicast member.
RemoteMulticastMember(Id, Address) - Constructor for class solar.service.multicast.RemoteMulticastMember
 
RemoteObject - class solar.service.rmtobj.RemoteObject.
A wrapper handle represents a remote object.
RemoteObject(Address, Id) - Constructor for class solar.service.rmtobj.RemoteObject
 
RemoteObjectConstants - interface solar.service.rmtobj.RemoteObjectConstants.
Constants used by remote object service.
RemoteObjectException - exception solar.service.rmtobj.RemoteObjectException.
An exception thrown by the remote object service.
RemoteObjectException(String) - Constructor for class solar.service.rmtobj.RemoteObjectException
Construct an RemoteObjectException with specified detail message.
RemoteObjectException(String, Throwable) - Constructor for class solar.service.rmtobj.RemoteObjectException
Construct an RemoteObjectException with specified detail message and nested Throwable.
RemoteObjectException(Throwable) - Constructor for class solar.service.rmtobj.RemoteObjectException
Construct an RemoteObjectException with specified nested Throwable.
RemoteObjectListener - interface solar.service.rmtobj.RemoteObjectListener.
Listener interface invoked when certain events happened on remtoe handle.
RemoteObjectService - interface solar.service.rmtobj.RemoteObjectService.
A service that allows monitoring the liveness of a remote object.
RemoteSinkChannel - class solar.service.fap.RemoteSinkChannel.
The data sink of this channel is on a remote site.
RemoteSinkChannel(Address, Id, InputPort) - Constructor for class solar.service.fap.RemoteSinkChannel
Constructs a remote channel with remote address and pipe ID (for sink).
RemoteSourceChannel - class solar.service.fap.RemoteSourceChannel.
The data source of this channel is on a remote site.
RemoteSourceChannel(Address, Id, OutputPort) - Constructor for class solar.service.fap.RemoteSourceChannel
Constructs a remote channel with remote address and pipe ID (for source).
remove_all() - Method in class solar.util.ssLinkedList
 
remove_comparator(Object, ssLinkedListComparator) - Method in class solar.util.ssLinkedList
Removes the first object to match according to the comparator function, and returns it.
remove_head() - Method in class solar.util.ssLinkedList
Removes the head object from the linked list, and returns it.
remove_item(Object) - Method in class solar.util.ssLinkedList
Removes the first object that is "equal" to the given object, based on the response of the Object.equals() method.
remove_tail() - Method in class solar.util.ssLinkedList
Removes the tail object from the linked list, and returns it.
removeBlock(Object) - Static method in class solar.service.rpc.Block
Remove one block from repository.
removeConnection(SocketAddress) - Method in class solar.service.transport.TcpTransport
Remove a connection to a peer address.
removeGraphManager(GraphManager) - Method in class solar.service.dan.NodeManager
Remove a graph manager from this node manager.
removeListener(Cache.CacheListener) - Method in class solar.module.cache.BaseCache
 
removeListener(Cache.CacheListener) - Method in interface solar.module.cache.Cache
Remove a listener from the cache.
removeListener(MobileHostListener) - Method in class solar.service.mhost.SolarMobileHostService
 
removeListener(MobileHostListener) - Method in interface solar.service.mhost.MobileHostService
Remove a listener to client mobililty.
removeListener(Name, DirectoryListener) - Method in class solar.service.directory.DistDirectoryService
 
removeListener(Name, DirectoryListener) - Method in class solar.service.directory.FlatDirectory
 
removeListener(Name, DirectoryListener) - Method in class solar.service.directory.CentralDirectoryService
 
removeListener(Name, DirectoryListener) - Method in interface solar.service.directory.Directory
Remove a directory observer for the specified pattern.
removeListener(Name, DirectoryListener) - Method in interface solar.service.directory.DirectoryService
Remove a directory listener for the specified pattern.
RemoveListenerRequest - class solar.service.directory.comm.RemoveListenerRequest.
Request to add a directory listener.
RemoveListenerRequest(Name, DirectoryListener) - Constructor for class solar.service.directory.comm.RemoveListenerRequest
 
removeMember(MulticastMember) - Method in class solar.service.multicast.MulticastGroup
 
removeObject(Object) - Method in class solar.module.cache.BaseCache
 
removeObject(Object) - Method in interface solar.module.cache.Cache
Remove an object from a cache.
removePublisher(Id) - Method in class solar.service.pack.proto.BaseProtocol
Cancel all the buffers for specified publisher.
removeRecord(NameRecord) - Method in class solar.service.directory.NameNode
Remove a name record from this name node.
removeRootTask(Id) - Method in class solar.service.pack.ScribePackService
 
removeScribeProxy(Id) - Method in class solar.service.pack.ScribePackService
 
removeScribeRoot(Id) - Method in class solar.service.pack.ScribePackService
 
removeSubscriber(Id) - Method in class solar.service.pack.proto.GroupBufferHandle
 
removeSubscriber(Id) - Method in class solar.service.pack.proto.SingleBufferHandle
 
removeSubscriber(Id) - Method in interface solar.service.pack.proto.BufferHandle
Remove an existing subscriber and return its associated buffer.
removeSubscriber(Id) - Method in class solar.service.pack.proto.BaseProtocol
Cancel all the buffers for specified subscriber.
removeSubscribeTask(Id) - Method in class solar.service.pack.ScribePackService
 
removeSubscribeTask(Id, Id) - Method in class solar.service.pack.ScribePackService
 
removeTransportListener(TransportListener) - Method in class solar.service.transport.UdpTransport
 
removeTransportListener(TransportListener) - Method in class solar.service.transport.TcpTransport
 
removeTransportListener(TransportListener) - Method in class solar.service.transport.BaseTransportService
 
removeTransportListener(TransportListener) - Method in class solar.service.transport.PastryTransport
 
removeTransportListener(TransportListener) - Method in interface solar.service.transport.Transport
Remove a transport listener.
removeTransportListener(TransportListener) - Method in interface solar.service.transport.TransportService
Remove a transport listener.
replaceValue(AttributeRecord, Event) - Method in class solar.service.dan.Monitor
 
reply - Variable in class org.doit.muffin.filter.CompassFilter
 
ReplyEvent - class solar.service.rpc.comm.ReplyEvent.
An event encoding RPC request.
ReplyEvent(Event) - Constructor for class solar.service.rpc.comm.ReplyEvent
 
ReplyEvent(Object, Id) - Constructor for class solar.service.rpc.comm.ReplyEvent
 
request - Variable in class org.doit.muffin.filter.CompassFilter
 
Request - class solar.api.Request.
A request contains a method name with a list of arguments.
REQUEST_SVID - Static variable in interface solar.SolarConstants
 
Request() - Constructor for class solar.api.Request
 
request(RemoteObject, Request) - Method in class solar.service.rmtobj.SolarRemoteObjectService
 
request(RemoteObject, Request) - Method in interface solar.service.rmtobj.RemoteObjectService
Invoke a request on the remote object.
requestAll(Name, Request) - Method in class solar.service.directory.DistDirectoryService
 
RequestEvent - class solar.service.rpc.comm.RequestEvent.
An event encoding RPC request.
RequestEvent(Event) - Constructor for class solar.service.rpc.comm.RequestEvent
 
RequestEvent(Request, String, Id) - Constructor for class solar.service.rpc.comm.RequestEvent
 
RequestHandler - interface solar.api.RequestHandler.
Interface for a request handler.
reset() - Method in class campus.syslog.SyslogParser
 
reset(SocketCommandMessage) - Method in class rice.pastry.wire.SocketChannelWriter
Resets the SocketChannelWriter, by clearing both the buffer and the queue.
resetState() - Method in class versus.meeting.RLMeetingWorld
 
resetState() - Method in interface versus.meeting.RLWorld
Resets the current state to the start position and returns that state.
resume() - Method in class solar.service.pack.proto.GroupBufferHandle
 
resume() - Method in class solar.service.pack.proto.SingleBufferHandle
 
resume() - Method in interface solar.service.pack.proto.BufferHandle
Resume all buffers in this handle to output.
resume(State) - Method in interface solar.service.mcode.MobileCode
Resume the code with previously captured state after migration.
resumeSubscriber(Object) - Method in class solar.service.pack.proto.FairQueueOBM
 
resumeSubscriber(Object) - Method in interface solar.service.pack.proto.OutputBufferManager
 
resumeSubscriber(Object) - Method in class solar.service.pack.proto.BaseProtocol
Restart delivering events to specified subscriber.
reward - Variable in class versus.meeting.RLearner
 
rice.pastry.dist - package rice.pastry.dist
Contains a new DistPastryNodeFactory that produces PastryNodeFactory based on specified protocol, either TCP or UDP.
rice.pastry.socket - package rice.pastry.socket
TCP under rice.pastry.wire package is implemented using java.nio package and has some known problems particularly under high stress.
rice.pastry.wire - package rice.pastry.wire
Contains updates to original rice.pastry.wire package, so Pastry can use either UDP or TCP, but not both.
RLearner - class versus.meeting.RLearner.
Code from http://www.cse.unsw.edu.au/~aek/catmouse.
RLearner(RLWorld) - Constructor for class versus.meeting.RLearner
 
RLMeetingAgent - class versus.meeting.RLMeetingAgent.
Meeting agent takes a stream of versus events and uses RL policy to determine whether there is a meeting at the current moment.
RLMeetingAgent(int, BufferedReader) - Constructor for class versus.meeting.RLMeetingAgent
Construct the meeting agent with a versus event source.
RLMeetingWorld - class versus.meeting.RLMeetingWorld.
Implementation of meeting world for reinforcement learning environment.
RLMeetingWorld(RLMeetingAgent) - Constructor for class versus.meeting.RLMeetingWorld
 
RLPolicy - class versus.meeting.RLPolicy.
Code from http://www.cse.unsw.edu.au/~aek/catmouse.
RLPolicy(int[]) - Constructor for class versus.meeting.RLPolicy
 
RLWorld - interface versus.meeting.RLWorld.
Code from http://www.cse.unsw.edu.au/~aek/catmouse.
RMTOBJ_ADDRESS - Static variable in interface solar.service.rmtobj.RemoteObjectConstants
 
RMTOBJ_CAPACITY - Static variable in interface solar.service.rmtobj.RemoteObjectConstants
 
RMTOBJ_IDS - Static variable in interface solar.service.rmtobj.RemoteObjectConstants
 
RMTOBJ_INTERVAL - Static variable in interface solar.service.rmtobj.RemoteObjectConstants
 
RMTOBJ_TTL - Static variable in interface solar.service.rmtobj.RemoteObjectConstants
 
routeSetMaintFreq - Static variable in class rice.pastry.wire.UdpPastryNodeFactory
 
routeSetMaintFreq - Static variable in class rice.pastry.wire.TcpPastryNodeFactory
 
routeSetMaintFreq - Static variable in class rice.pastry.socket.SocketPastryNodeFactory
 
ROUTING_HOST - Static variable in interface solar.service.routing.RoutingConstants
 
ROUTING_INTERVAL - Static variable in interface solar.service.routing.RoutingConstants
 
ROUTING_LASTHOP - Static variable in interface solar.service.routing.RoutingConstants
 
ROUTING_SOURCE - Static variable in interface solar.service.routing.RoutingConstants
 
RoutingConstants - interface solar.service.routing.RoutingConstants.
Constants for routing service.
RoutingEvent - class solar.service.routing.comm.RoutingEvent.
A periodic event containing routing information.
RoutingEvent(Address, Address, Address) - Constructor for class solar.service.routing.comm.RoutingEvent
 
RoutingEvent(Event) - Constructor for class solar.service.routing.comm.RoutingEvent
 
RoutingException - exception solar.service.routing.RoutingException.
A generic exception thrown by routing services.
RoutingException(String) - Constructor for class solar.service.routing.RoutingException
Construct an RoutingException with specified detail message.
RoutingException(String, Throwable) - Constructor for class solar.service.routing.RoutingException
Construct an RoutingException with specified detail message and nested Throwable.
RoutingException(Throwable) - Constructor for class solar.service.routing.RoutingException
Construct an RoutingException with specified nested Throwable.
RoutingService - interface solar.service.routing.RoutingService.
Routing service maintains the routing/forwarding table.
RPC_BLOCK - Static variable in interface solar.service.rpc.RpcConstants
 
RPC_HANDLER - Static variable in interface solar.service.rpc.RpcConstants
 
RPC_REPLY - Static variable in interface solar.service.rpc.RpcConstants
 
RPC_REQUEST - Static variable in interface solar.service.rpc.RpcConstants
 
RPC_TIMEOUT - Static variable in interface solar.service.rpc.RpcConstants
 
RpcAck - class solar.service.rpc.RpcAck.
Empty object to acknowledge a RPC request.
RPCACK_SVID - Static variable in interface solar.SolarConstants
 
RpcAck() - Constructor for class solar.service.rpc.RpcAck
 
RpcConstants - interface solar.service.rpc.RpcConstants.
Constants for RPC service.
RpcException - exception solar.service.rpc.RpcException.
A generic exception thrown by RPC services.
RpcException(String) - Constructor for class solar.service.rpc.RpcException
Construct an RpcException with specified detail message.
RpcException(String, Throwable) - Constructor for class solar.service.rpc.RpcException
Construct an RpcException with specified detail message and nested Throwable.
RpcException(Throwable) - Constructor for class solar.service.rpc.RpcException
Construct an RpcException with specified nested Throwable.
RpcService - interface solar.service.rpc.RpcService.
A service emulates the remote procedure calls.
rtMax - Static variable in class rice.pastry.wire.UdpPastryNodeFactory
 
rtMax - Static variable in class rice.pastry.wire.TcpPastryNodeFactory
 
rtMax - Static variable in class rice.pastry.socket.SocketPastryNodeFactory
 
run() - Method in class solar.Shell
 
run() - Method in class solar.module.cache.BaseCache
 
run() - Method in class solar.service.pack.ScribePackService.Handler
 
run() - Method in class solar.service.pack.ScribePackService.Sender
 
run() - Method in class solar.service.pack.ScribePackService.Forwarder
 
run() - Method in class solar.service.pack.ScribePackService.SubscribeTask
 
run() - Method in class solar.service.pack.ScribePackService.RootTask
 
run() - Method in class solar.service.pack.ClientPackService.Handler
 
run() - Method in class solar.service.pack.ClientPackService.Sender
 
run() - Method in class solar.service.transport.UdpObjectTransport
 
run() - Method in class solar.service.transport.UdpTransport
 
run() - Method in class solar.service.transport.TcpConnection
 
run() - Method in class solar.service.transport.TcpTransport
 
run() - Method in class solar.service.routing.ManualRoutingService.RoutingTask
 
run() - Method in class solar.service.dispatch.SolarDispatchService
 
run() - Method in class solar.service.rmtobj.SolarRemoteObjectService.PingTask
 
run() - Method in class solar.service.dan.Source
The execution body of this source.
run() - Method in class solar.service.dan.NodeHandler
 
run() - Method in class solar.service.fork.SolarForkService.KillTask
 
run() - Method in class solar.service.fork.SolarForkService.StartTask
 
run() - Method in class solar.service.fork.TaskBatch
 
run() - Method in class solar.service.rpc.SolarRpcService.RpcWorker
 
run() - Method in class solar.test.GroundHog
 
run() - Method in class solar.test.ClockSource
 
run() - Method in class versus.VersusSource
 
run() - Method in class versus.meeting.RLMeetingAgent
 
run() - Method in class campus.LogTracer
 
run() - Method in class campus.sysnort.SysnortSensor
 
run() - Method in class campus.sysnort.SysnortApp
 
run() - Method in class campus.syslog.SyslogSource
 
run() - Method in class campus.snmp.SnmpLocator.SnmpTask
 
run() - Method in class campus.snmp.SnmpLocator
Periodically poll the APs on the waiting list.
run() - Method in class campus.snmp.SnmpSource
 
run() - Method in class campus.compass.CompassService
 
run() - Method in class org.doit.muffin.filter.CompassFilter
 
run(Options) - Method in class solar.Planet
 
run(PackClient, Options) - Method in class solar.test.PackSender
 
run(PackClient, Options) - Method in class solar.test.PackReceiver
 
run(PubSubClient, Options) - Method in class solar.test.ScribeSender
 
run(PubSubClient, Options) - Method in class solar.test.ScribeReceiver
 
runEpoch() - Method in class versus.meeting.RLearner
 
running - Variable in class versus.meeting.RLearner
 
runOneRound(String, String) - Method in class solar.service.fork.TaskBatch
 
runTrial() - Method in class versus.meeting.RLearner
 

S

saPair - Variable in class versus.meeting.RLearner
 
SARSA - Static variable in class versus.meeting.RLearner
 
save() - Method in class org.doit.muffin.filter.Logger
 
save() - Method in class org.doit.muffin.filter.Compass
 
scribeIsReady() - Method in class solar.service.pack.ScribeManager
Invoked when the underlying Scribe substrate is ready.
scribeIsReady() - Method in class solar.service.pubsub.ScribeManager
Invoked when the underlying Scribe substrate is ready.
scribeIsReady() - Method in class solar.service.multicast.ScribeMulticastService.ScribeMember
Invoked when the underlying Scribe substrate is ready.
ScribeManager - class solar.service.pack.ScribeManager.
This is the only Scribe application that multiplexes events among PACK end-points.
ScribeManager - class solar.service.pubsub.ScribeManager.
This is the only Scribe application that multiplexes events among end-points.
ScribeManager.ScribeListener - interface solar.service.pack.ScribeManager.ScribeListener.
 
ScribeManager.ScribeListener - interface solar.service.pubsub.ScribeManager.ScribeListener.
 
ScribeManager(PastryNode, Credentials) - Constructor for class solar.service.pack.ScribeManager
 
ScribeManager(ScribeManager.ScribeListener, PastryNode, Credentials) - Constructor for class solar.service.pack.ScribeManager
 
ScribeManager(ScribeManager.ScribeListener, PastryNode, Credentials) - Constructor for class solar.service.pubsub.ScribeManager
 
ScribeMulticastService - class solar.service.multicast.ScribeMulticastService.
This multicast service adapts the Scribe substrate based on Pastry.
ScribeMulticastService.ScribeMember - class solar.service.multicast.ScribeMulticastService.ScribeMember.
 
ScribeMulticastService.ScribeMember(MulticastMember) - Constructor for class solar.service.multicast.ScribeMulticastService.ScribeMember
 
ScribeMulticastService() - Constructor for class solar.service.multicast.ScribeMulticastService
 
ScribePackService - class solar.service.pack.ScribePackService.
The PACK service that runs at the server side and is built on top of Scribe.
ScribePackService.Forwarder - class solar.service.pack.ScribePackService.Forwarder.
Responsible to delivery events to children in multicast tree.
ScribePackService.Forwarder(Protocol) - Constructor for class solar.service.pack.ScribePackService.Forwarder
 
ScribePackService.Handler - class solar.service.pack.ScribePackService.Handler.
Responsible to delivery events to local subscribers only.
ScribePackService.Handler() - Constructor for class solar.service.pack.ScribePackService.Handler
 
ScribePackService.RootTask - class solar.service.pack.ScribePackService.RootTask.
Periodically update the (pubId, rootAddress) mapping.
ScribePackService.RootTask(Id) - Constructor for class solar.service.pack.ScribePackService.RootTask
 
ScribePackService.Sender - class solar.service.pack.ScribePackService.Sender.
Responsible to delivery events to attached clients only.
ScribePackService.Sender() - Constructor for class solar.service.pack.ScribePackService.Sender
 
ScribePackService.SubscribeTask - class solar.service.pack.ScribePackService.SubscribeTask.
Periodically refresh the subscription in the Scribe network.
ScribePackService.SubscribeTask(Id, SubscribeEvent) - Constructor for class solar.service.pack.ScribePackService.SubscribeTask
 
ScribePackService() - Constructor for class solar.service.pack.ScribePackService
 
ScribePubSubService - class solar.service.pubsub.ScribePubSubService.
The Pub/Sub service that runs at the server side and is built on top of Scribe.
ScribePubSubService() - Constructor for class solar.service.pubsub.ScribePubSubService
 
ScribeReceiver - class solar.test.ScribeReceiver.
A standalone event subscriber using Pub/Sub service.
ScribeReceiver.Profiler - class solar.test.ScribeReceiver.Profiler.
 
ScribeReceiver.Profiler() - Constructor for class solar.test.ScribeReceiver.Profiler
 
ScribeReceiver() - Constructor for class solar.test.ScribeReceiver
 
ScribeRootRequest - class solar.service.pack.comm.ScribeRootRequest.
A request to set up root for some publishing topic.
ScribeRootRequest(Id) - Constructor for class solar.service.pack.comm.ScribeRootRequest
 
ScribeSender - class solar.test.ScribeSender.
A standalone event publisher using Pub/Sub service.
ScribeSender() - Constructor for class solar.test.ScribeSender
 
select() - Method in class solar.service.dan.Monitor
 
selectAction(int[]) - Method in class versus.meeting.RLearner
 
send(Adu, Address) - Method in class solar.service.transport.UdpObjectTransport
 
send(Adu, Address) - Method in class solar.service.transport.UdpTransport
 
send(Adu, Address) - Method in class solar.service.transport.TcpObjectTransport
 
send(Adu, Address) - Method in class solar.service.transport.TcpTransport
 
send(Adu, Address) - Method in class solar.service.transport.PastryObjectTransport
 
send(Adu, Address) - Method in class solar.service.transport.BaseTransportService
 
send(Adu, Address) - Method in class solar.service.transport.PastryTransport
 
send(Adu, Address) - Method in interface solar.service.transport.Transport
Send the adu over transport to destination.
send(Adu, Address) - Method in interface solar.service.transport.TransportService
Send an application data unit to destination address.
send(Adu, Address, Id) - Method in class solar.service.transport.UdpObjectTransport
 
send(Adu, Address, Id) - Method in class solar.service.transport.UdpTransport
 
send(Adu, Address, Id) - Method in class solar.service.transport.TcpObjectTransport
 
send(Adu, Address, Id) - Method in class solar.service.transport.TcpTransport
 
send(Adu, Address, Id) - Method in class solar.service.transport.PastryObjectTransport
 
send(Adu, Address, Id) - Method in class solar.service.transport.BaseTransportService
 
send(Adu, Address, Id) - Method in class solar.service.transport.PastryTransport
 
send(Adu, Address, Id) - Method in interface solar.service.transport.Transport
Send the adu over transport to destination, with a multipex ID.
send(Adu, Address, Id) - Method in interface solar.service.transport.TransportService
Send an application data unit to destination address.
send(Adu, Header) - Method in class solar.service.transport.TcpConnection
Send a message through this connection.
send(byte[], Address) - Method in class solar.service.transport.UdpObjectTransport
 
send(byte[], Address) - Method in class solar.service.transport.UdpTransport
 
send(byte[], Address) - Method in class solar.service.transport.TcpObjectTransport
 
send(byte[], Address) - Method in class solar.service.transport.TcpTransport
 
send(byte[], Address) - Method in class solar.service.transport.PastryObjectTransport
 
send(byte[], Address) - Method in class solar.service.transport.PastryTransport
 
send(byte[], Address) - Method in interface solar.service.transport.Transport
Send an data unit to destination address.
send(byte[], Address, Id) - Method in class solar.service.transport.UdpObjectTransport
 
send(byte[], Address, Id) - Method in class solar.service.transport.UdpTransport
 
send(byte[], Address, Id) - Method in class solar.service.transport.TcpObjectTransport
 
send(byte[], Address, Id) - Method in class solar.service.transport.TcpTransport
 
send(byte[], Address, Id) - Method in class solar.service.transport.PastryObjectTransport
 
send(byte[], Address, Id) - Method in class solar.service.transport.PastryTransport
 
send(byte[], Address, Id) - Method in interface solar.service.transport.Transport
Send an data unit to destination address with a multiplexer.
send(byte[], Header) - Method in class solar.service.transport.TcpConnection
Send a message through this connection.
sendEmail(String) - Static method in class versus.meeting.MeetingRecorder
 
sendGreetingResponse(HelloMessage) - Method in class rice.pastry.wire.WireNodeHandle
 
sendLocalAddress(SocketAddress) - Method in class solar.service.transport.TcpConnection
Send local address to peer through this connection.
sendmail(String, String, String, String) - Static method in class solar.util.EmailUtil
Basic sendmail function, multiple receivers separated by space.
sendToClient(Address, Event) - Method in class solar.service.pack.ScribePackService
Send an event to client using edge_transport.
sendToParent(Id, Event) - Method in class solar.service.pack.ScribePackService
Send an event to a topic's parent, return false if parent is null.
sendToProxy(Id, Event) - Method in class solar.service.pack.ScribePackService
Send an event to a topic's proxy, return false if proxy is local.
sendToRoot(Id, Event) - Method in class solar.service.pack.ScribePackService
Send an event to a topic's root, return false if root is local.
SENSOR_NO - Static variable in class versus.VersusSource
 
SEPARATOR - Static variable in class versus.VersusSource
 
serialize(Object) - Static method in class rice.pastry.wire.SocketChannelWriter
Method which serializes a given object into a ByteBuffer, in order to prepare it for writing.
SerializedAdu - class solar.impl.SerializedAdu.
Wrapper ADU for arbituary serializable object.
SerializedAdu(Serializable) - Constructor for class solar.impl.SerializedAdu
 
SerializedEvent - class solar.impl.SerializedEvent.
SerializedEvent containts attributes whose value are arbituary objects and will be serialized into byte array before transmission.
SerializedEvent(byte[]) - Constructor for class solar.impl.SerializedEvent
Constructs an event by parsing an encoded byte array.
SerializedEvent(byte[], int, int) - Constructor for class solar.impl.SerializedEvent
Constructs an event by parsing an encoded byte array.
SerializedEvent(Event) - Constructor for class solar.impl.SerializedEvent
Constructs an event by copying from another one.
SerializedEvent(List) - Constructor for class solar.impl.SerializedEvent
Constructs an event with a list of attributes.
serialVersionUID - Static variable in class solar.api.Id
 
serialVersionUID - Static variable in class solar.api.Request
 
serialVersionUID - Static variable in class solar.api.Attribute
 
serialVersionUID - Static variable in class solar.impl.AbstractAttributeRecord
 
serialVersionUID - Static variable in class solar.service.pack.PackPolicy
 
serialVersionUID - Static variable in class solar.service.pack.lang.FilterConfig
 
serialVersionUID - Static variable in class solar.service.transport.Header
 
serialVersionUID - Static variable in class solar.service.dan.lang.FilterSpec
 
serialVersionUID - Static variable in class solar.service.dan.lang.PipeSpec
 
serialVersionUID - Static variable in class solar.service.dan.lang.GraphSpec
 
serialVersionUID - Static variable in class solar.service.rpc.RpcAck
 
serialVersionUID - Static variable in class solar.service.directory.NameRecord
 
serialVersionUID - Static variable in class solar.service.directory.Advertisement
 
Service - interface solar.service.Service.
Service is an independent module that has a name and a set of configuration options.
SERVICE_PREFIX - Static variable in class solar.service.BaseServiceManager
A prefix for service properties configuration file.
ServiceException - exception solar.service.ServiceException.
A generic exception thrown by Solar services.
ServiceException(String) - Constructor for class solar.service.ServiceException
Construct an ServiceException with specified detail message.
ServiceException(String, Throwable) - Constructor for class solar.service.ServiceException
Construct an ServiceException with specified detail message and nested Throwable.
ServiceException(Throwable) - Constructor for class solar.service.ServiceException
Construct an ServiceException with specified nested Throwable.
ServiceManager - interface solar.service.ServiceManager.
Interface for the manager of a set of services.
ServiceRuntimeException - exception solar.service.ServiceRuntimeException.
Thrown as error ocurred during service execution.
ServiceRuntimeException(String) - Constructor for class solar.service.ServiceRuntimeException
Construct an ServiceRuntimeException with specified detail message.
ServiceRuntimeException(String, Throwable) - Constructor for class solar.service.ServiceRuntimeException
Construct an ServiceRuntimeException with specified detail message and nested Throwable.
ServiceRuntimeException(Throwable) - Constructor for class solar.service.ServiceRuntimeException
Construct an ServiceRuntimeException with specified nested Throwable.
setActionSelection(int) - Method in class versus.meeting.RLearner
 
setAddress(String) - Method in class solar.service.dan.lang.FilterSpec
 
setAduFactory(AduFactory) - Method in class solar.service.transport.UdpTransport
 
setAduFactory(AduFactory) - Method in class solar.service.transport.TcpTransport
 
setAduFactory(AduFactory) - Method in class solar.service.transport.PastryTransport
 
setAduFactory(AduFactory) - Method in interface solar.service.transport.Transport
Set the factory that parse the received bytes into data unit.
setAlpha(double) - Method in class versus.meeting.RLearner
 
setAntenna(String) - Method in class campus.AccessPoint
 
setBuilding(String) - Method in class campus.AccessPoint
 
setCategory(String) - Method in class campus.Building
 
setCertainty(int) - Method in class campus.Location
 
setChannel(String) - Method in class campus.AccessPoint
 
setCity(String) - Method in class campus.Location
 
setCityUrl(String) - Method in class campus.Location
 
setClassname(String) - Method in class solar.service.dan.lang.FilterSpec
 
setClassname(String) - Method in class campus.sysnort.TriggerConfig
 
setCode(String) - Method in class campus.Building
 
setCodebase(String) - Method in class solar.service.dan.lang.FilterSpec
 
setCodebase(String) - Method in class campus.sysnort.TriggerConfig
 
setCommand(String) - Method in class solar.service.fork.Task
 
setCoolFilter(FilterConfig) - Method in class solar.service.pack.PackPolicy
 
setCountry(String) - Method in class campus.Location
 
setCreated() - Method in class solar.module.cache.CachedObject
Set the creation time.
setDestination(Address) - Method in class solar.service.transport.Header
 
setDestination(Address) - Method in class solar.service.fork.Task
 
setEndState(boolean) - Method in class versus.meeting.RLMeetingWorld
 
setEndTime(int) - Method in class solar.service.fork.Task
 
setEpisodes(int) - Method in class versus.meeting.RLearner
 
setEpsilon(double) - Method in class versus.meeting.RLearner
 
setExpires(long) - Method in class solar.module.cache.CachedObject
Set the expiration interval for the object.
setFilters(List) - Method in class solar.service.pack.PackPolicy
Set and load the ordered PACK filters for the stream.
setFinished(boolean) - Method in class solar.service.fork.Task
 
setFloor(int) - Method in class campus.AccessPoint
 
setFlow(String) - Method in class solar.service.dan.lang.PipeSpec
 
setGamma(double) - Method in class versus.meeting.RLearner
 
setGateway(String) - Method in class campus.AccessPoint
 
setGroupKeys(String[]) - Method in class solar.service.pack.PackPolicy
Set the group attributes for the stream.
setHeader(Header) - Method in class solar.service.transport.PastryMessage
 
setHotFilter(FilterConfig) - Method in class solar.service.pack.PackPolicy
 
setId(Id) - Method in interface solar.api.Identifiable
Set the ID of this object.
setId(Id) - Method in class solar.service.pack.PackFilter
 
setId(Id) - Method in class solar.service.dan.GraphNode
 
setId(Id) - Method in class solar.service.fap.Pipe
 
setInfo(String) - Method in class campus.AccessPoint
 
setInited(boolean) - Method in class solar.service.BaseService
 
setInput(Name, String) - Method in class solar.service.dan.lang.PipeSpec
 
setInput(String, String) - Method in class solar.service.dan.lang.PipeSpec
 
setInputObjectStream(InputObjectStream) - Method in class org.doit.muffin.filter.CompassFilter
 
setIpAddress(String) - Method in class campus.AccessPoint
 
setKey(SelectionKey, SocketCommandMessage) - Method in class rice.pastry.wire.WireNodeHandle
Method which sets the SelectionKey of this node handle.
setLambda(double) - Method in class versus.meeting.RLearner
 
setLearningMethod(int) - Method in class versus.meeting.RLearner
 
setLocalPastryNode(PastryNode) - Method in class rice.pastry.socket.SocketPastrySecurityManager
Sets the local Pastry node after it is fully constructed.
setLogger(Logger) - Method in class solar.service.multicast.RemoteMulticastMember
 
setLogger(Logger) - Method in class solar.service.directory.RemoteDirectoryListener
 
setMacAddress(String) - Method in class campus.AccessPoint
 
setManager(FilterManager) - Method in class org.doit.muffin.filter.Logger
 
setManager(FilterManager) - Method in class org.doit.muffin.filter.Compass
 
setModel(String) - Method in class campus.AccessPoint
 
setMultiplexId(Id) - Method in class solar.service.transport.Header
 
setName(String) - Method in class solar.service.BaseService
 
setName(String) - Method in interface solar.service.Service
Set the name of this service.
setName(String) - Method in class solar.service.pack.lang.FilterConfig
 
setName(String) - Method in class solar.service.dan.lang.FilterSpec
 
setName(String) - Method in class solar.service.dan.lang.PipeSpec
 
setName(String) - Method in class campus.AccessPoint
 
setName(String) - Method in class campus.Building
 
setName(String) - Method in class campus.sysnort.Trigger
Set the name of this trigger.
setName(String) - Method in class campus.sysnort.TriggerConfig
 
setObject(Object) - Method in class solar.module.cache.CachedObject
Set the cached object.
setObserver(LogTracer.TracerObserver) - Method in class campus.LogTracer
 
setOutput(String, String) - Method in class solar.service.dan.lang.PipeSpec
 
setOutputObjectStream(OutputObjectStream) - Method in class org.doit.muffin.filter.CompassFilter
 
setParameter(String, String) - Method in class solar.service.fork.Task
 
setParent(NameNode) - Method in class solar.service.directory.NameNode
Set the parent node of this name node.
setPower(String) - Method in class campus.AccessPoint
 
setPrefs(Prefs) - Method in class org.doit.muffin.filter.Logger
 
setPrefs(Prefs) - Method in class org.doit.muffin.filter.LoggerFilter
 
setPrefs(Prefs) - Method in class org.doit.muffin.filter.Compass
 
setPrefs(Prefs) - Method in class org.doit.muffin.filter.CompassFilter
 
setQValue(int[], int, double) - Method in class versus.meeting.RLPolicy
 
setRpcService(RpcService, String) - Method in class solar.service.multicast.RemoteMulticastMember
 
setRpcService(String, RpcService) - Method in class solar.service.directory.RemoteDirectoryListener
 
setServiceManager(ServiceManager) - Method in class solar.service.BaseService
 
setServiceManager(ServiceManager) - Method in interface solar.service.Service
Set the service manager for this service.
setServiceObject(String, Object) - Method in class solar.service.BaseServiceManager
 
setServiceObject(String, Object) - Method in interface solar.service.ServiceManager
Set application-specific service object.
setSocketElements(InetSocketAddress, Transport, SocketNodeHandlePool, int, int) - Method in class rice.pastry.socket.SocketPastryNode
 
setSource(Address) - Method in class solar.service.transport.Header
 
setSource(Address) - Method in class solar.service.fork.Task
 
setSourceAddress(Address) - Method in class solar.api.Request
 
setStartTime(int) - Method in class solar.service.fork.Task
 
setState(String) - Method in class campus.Location
 
setStreet(String) - Method in class campus.Location
 
setSubId(Id) - Method in class solar.service.pubsub.comm.PubEvent
 
setThread(Thread) - Method in class rice.pastry.socket.SocketPastryNode
 
setType(int) - Method in class solar.service.dan.lang.PipeSpec
 
setUrl(String) - Method in class campus.Building
 
setWarmFilter(FilterConfig) - Method in class solar.service.pack.PackPolicy
 
setX(double) - Method in class campus.AccessPoint
 
setY(double) - Method in class campus.AccessPoint
 
setZ(double) - Method in class campus.AccessPoint
 
setZipCode(String) - Method in class campus.Location
 
Shell - class solar.Shell.
An interactive shell to probe Solar system.
Shell(Options) - Constructor for class solar.Shell
 
shutdown() - Method in class org.doit.muffin.filter.Logger
 
shutdown() - Method in class org.doit.muffin.filter.Compass
 
SingleBufferHandle - class solar.service.pack.proto.SingleBufferHandle.
Manages a single subscription.
SingleBufferHandle(Id, Object, int) - Constructor for class solar.service.pack.proto.SingleBufferHandle
 
SINK - Static variable in class solar.service.dan.lang.XmlSpecParser
 
SinkChannel - interface solar.service.fap.SinkChannel.
A sink channel is for filter to send data.
size() - Method in class solar.util.JavaUnsyncQueue
 
size() - Method in class solar.util.JavaSyncQueue
 
size() - Method in class solar.util.FastUnsyncQueue
 
size() - Method in class solar.util.FastSyncQueue
 
size() - Method in class solar.util.ssLinkedList
Returns the number of elements in the list
size() - Method in interface solar.util.Queue
Return the size of the queue.
size() - Method in class solar.module.protocol.Buffer
Get current size of the buffer.
size() - Method in class solar.service.pack.proto.GroupBufferHandle
 
size() - Method in class solar.service.pack.proto.SingleBufferHandle
 
size() - Method in interface solar.service.pack.proto.BufferHandle
Total number of events in this handle.
snmpInternalError(SnmpSession, int, SnmpSyntax) - Method in class campus.snmp.SnmpTest
 
SnmpLocator - class campus.snmp.SnmpLocator.
This locator monitors the Syslog messages and polls APs to fill the ip-ap and mac-ap mapping tables.
SnmpLocator.SnmpTask - class campus.snmp.SnmpLocator.SnmpTask.
A single snmp polling task.
SnmpLocator.SnmpTask(SnmpLocator, String, String, long) - Constructor for class campus.snmp.SnmpLocator.SnmpTask
 
SnmpLocator(String) - Constructor for class campus.snmp.SnmpLocator
 
SnmpLocator(String, String) - Constructor for class campus.snmp.SnmpLocator
 
snmpReceivedPdu(SnmpSession, int, SnmpPduPacket) - Method in class campus.snmp.SnmpTest
 
SnmpSource - class campus.snmp.SnmpSource.
A Solar source that polls access points to get MAC-IP mapping using SNMP.
SnmpSource(Options) - Constructor for class campus.snmp.SnmpSource
 
SnmpTest - class campus.snmp.SnmpTest.
A SNMP test using joesnmp library.
SnmpTest() - Constructor for class campus.snmp.SnmpTest
 
snmpTimeoutError(SnmpSession, SnmpSyntax) - Method in class campus.snmp.SnmpTest
 
SOCKET_ADDRESS - Static variable in interface solar.service.transport.TransportConstants
 
SOCKET_BUFFER_SIZE - Static variable in class rice.pastry.wire.WireNodeHandle
 
SocketAddress - class solar.service.transport.SocketAddress.
Network address identified by IP and a port number.
SocketAddress(InetAddress, int) - Constructor for class solar.service.transport.SocketAddress
Constructs a socket address with a inet address and port number.
SocketAddress(InetSocketAddress) - Constructor for class solar.service.transport.SocketAddress
Constructs a socket address with a inet socket address.
SocketAddress(String) - Constructor for class solar.service.transport.SocketAddress
Constructs a socket address with ip_address:port_number argument.
SocketAddress(String, int) - Constructor for class solar.service.transport.SocketAddress
Constructs a socket address with a host name and port number.
SocketChannelWriter - class rice.pastry.wire.SocketChannelWriter.
Class which serves as an "writer" for all of the messages sent across the wire in Pastry.
SocketChannelWriter(WirePastryNode, SocketCommandMessage) - Constructor for class rice.pastry.wire.SocketChannelWriter
Constructor which creates this SocketChannelWriter with a pastry node and an object to write out.
SocketManager - class rice.pastry.wire.SocketManager.
Class which maintains all outgoing open sockets.
SocketManager.SocketConnector - class rice.pastry.wire.SocketManager.SocketConnector.
Private class which is tasked with reading the greeting message off of a newly connected socket.
SocketManager.SocketConnector(SelectionKey) - Constructor for class rice.pastry.wire.SocketManager.SocketConnector
Constructor
SocketManager(WirePastryNode, int, Selector) - Constructor for class rice.pastry.wire.SocketManager
Constructs a new SocketManager.
SocketNodeHandle - class rice.pastry.socket.SocketNodeHandle.
A direct mimic of WireNodeHandle class.
SocketNodeHandle(int, InetSocketAddress, NodeId) - Constructor for class rice.pastry.socket.SocketNodeHandle
 
SocketNodeHandle(int, InetSocketAddress, NodeId, PastryNode) - Constructor for class rice.pastry.socket.SocketNodeHandle
 
SocketNodeHandlePool - class rice.pastry.socket.SocketNodeHandlePool.
A direct mimic to WireNodeHandlePool class.
SocketNodeHandlePool(SocketPastryNode) - Constructor for class rice.pastry.socket.SocketNodeHandlePool
 
SocketPastryNode - class rice.pastry.socket.SocketPastryNode.
A direct mimic of WirePastryNode class.
SocketPastryNode(NodeId) - Constructor for class rice.pastry.socket.SocketPastryNode
 
SocketPastryNodeFactory - class rice.pastry.socket.SocketPastryNodeFactory.
A direct mimic to WirePastryNodeFactory class.
SocketPastryNodeFactory(boolean, NodeIdFactory, int, int) - Constructor for class rice.pastry.socket.SocketPastryNodeFactory
 
SocketPastrySecurityManager - class rice.pastry.socket.SocketPastrySecurityManager.
Security manager for socket connections between nodes.
SocketPastrySecurityManager(SocketNodeHandle, SocketNodeHandlePool) - Constructor for class rice.pastry.socket.SocketPastrySecurityManager
Constructor.
SOFTMAX - Static variable in class versus.meeting.RLearner
 
solar - package solar
Contains some basic Solar classes, such as client facade, Planet, and global constants.
solar.api - package solar.api
Contains some basic Solar APIs, such as event, attribute, and request.
solar.impl - package solar.impl
Contains some implementation of common APIs, such as various formatted events, event factory, etc.
solar.module.cache - package solar.module.cache
Contains the caching module.
solar.module.protocol - package solar.module.protocol
 
solar.service - package solar.service
Contains the core Solar service framework.
solar.service.dan - package solar.service.dan
Contains DAN (Data Aggregation Network) service and related classes.
solar.service.dan.comm - package solar.service.dan.comm
Events and requests for DAN service.
solar.service.dan.lang - package solar.service.dan.lang
Language parser for DAN service.
solar.service.directory - package solar.service.directory
Contains directory service that allows name advertisements and lookups.
solar.service.directory.comm - package solar.service.directory.comm
Events and requests for directory service.
solar.service.dispatch - package solar.service.dispatch
Contains the data dispatching service.
solar.service.fap - package solar.service.fap
Contains FAP (Filter-and-Pipe) service and related classes.
solar.service.fap.comm - package solar.service.fap.comm
Events and requests for FAP service.
solar.service.fork - package solar.service.fork
 
solar.service.fork.client - package solar.service.fork.client
 
solar.service.fork.comm - package solar.service.fork.comm
 
solar.service.mcode - package solar.service.mcode
Contains mobile code service that manages logical mobility.
solar.service.mhost - package solar.service.mhost
Contains mobile host service that manages physical mobility.
solar.service.mhost.comm - package solar.service.mhost.comm
 
solar.service.multicast - package solar.service.multicast
Contains the event multicasting service.
solar.service.multicast.comm - package solar.service.multicast.comm
Events and requests for multicast service.
solar.service.pack - package solar.service.pack
Contains the PACK service that allows customized flow-control polices.
solar.service.pack.client - package solar.service.pack.client
 
solar.service.pack.comm - package solar.service.pack.comm
Events and requests for PACK service.
solar.service.pack.filter - package solar.service.pack.filter
A list of predefined PACK filters that are used to select from or summarize a batch of events.
solar.service.pack.lang - package solar.service.pack.lang
Language parser for PACK service.
solar.service.pack.proto - package solar.service.pack.proto
Contains the suite of PACK protocols.
solar.service.pubsub - package solar.service.pubsub
 
solar.service.pubsub.client - package solar.service.pubsub.client
 
solar.service.pubsub.comm - package solar.service.pubsub.comm
 
solar.service.rmtobj - package solar.service.rmtobj
Contains the service to monitor the liveness of and communicate with remote objects.
solar.service.rmtobj.comm - package solar.service.rmtobj.comm
Events and requests for remote object service.
solar.service.routing - package solar.service.routing
Contains the data routing service, currently not used by Solar.
solar.service.routing.comm - package solar.service.routing.comm
Events and requests for routing service.
solar.service.rpc - package solar.service.rpc
Contains the simulated RPC service.
solar.service.rpc.comm - package solar.service.rpc.comm
Events and requests for RPC service.
solar.service.transport - package solar.service.transport
Contains the data transport service.
solar.test - package solar.test
Contains some sample testing Solar nodes, such as sources, operators, and applications.
solar.util - package solar.util
Contains some basic Solar utilities, such as Queues.
SolarConstants - interface solar.SolarConstants.
This interface contains the constants used throughout the Solar code base.
SolarDanService - class solar.service.dan.SolarDanService.
The Solar implementation of DAN service.
SolarDanService() - Constructor for class solar.service.dan.SolarDanService
 
SolarDispatchService - class solar.service.dispatch.SolarDispatchService.
An event disptaching service for Solar.
SolarDispatchService.NetListener - class solar.service.dispatch.SolarDispatchService.NetListener.
 
SolarDispatchService.NetListener(String) - Constructor for class solar.service.dispatch.SolarDispatchService.NetListener
 
SolarDispatchService() - Constructor for class solar.service.dispatch.SolarDispatchService
 
SolarException - exception solar.util.SolarException.
The base class of all exceptions thrown by Solar.
SolarException() - Constructor for class solar.util.SolarException
Constructs a new SolarException without specified detail message.
SolarException(String) - Constructor for class solar.util.SolarException
Constructs a new SolarException with specified detail message.
SolarException(String, Throwable) - Constructor for class solar.util.SolarException
Constructs a new SolarException with specified detail message and nested Throwable.
SolarException(Throwable) - Constructor for class solar.util.SolarException
Constructs a new SolarException with specified nested Throwable.
SolarFapService - class solar.service.fap.SolarFapService.
Implementation of Filter-and-Pipe (FAP) service.
SolarFapService() - Constructor for class solar.service.fap.SolarFapService
 
SolarForkService - class solar.service.fork.SolarForkService.
An implementation of forking service.
SolarForkService.KillTask - class solar.service.fork.SolarForkService.KillTask.
 
SolarForkService.KillTask(Task) - Constructor for class solar.service.fork.SolarForkService.KillTask
 
SolarForkService.StartTask - class solar.service.fork.SolarForkService.StartTask.
 
SolarForkService.StartTask(Task) - Constructor for class solar.service.fork.SolarForkService.StartTask
 
SolarForkService() - Constructor for class solar.service.fork.SolarForkService
 
SolarMobileHostService - class solar.service.mhost.SolarMobileHostService.
Solar implementation of mobile host service.
SolarMobileHostService() - Constructor for class solar.service.mhost.SolarMobileHostService
 
SolarRemoteObjectService - class solar.service.rmtobj.SolarRemoteObjectService.
This RemoteObjectService uses a softstate protocol to monitoring remote object and uses RPC service to invoke request.
SolarRemoteObjectService.PingTask - class solar.service.rmtobj.SolarRemoteObjectService.PingTask.
The task periodically notifies remote monitors about local objects.
SolarRemoteObjectService.PingTask() - Constructor for class solar.service.rmtobj.SolarRemoteObjectService.PingTask
 
SolarRemoteObjectService() - Constructor for class solar.service.rmtobj.SolarRemoteObjectService
 
SolarRpcService - class solar.service.rpc.SolarRpcService.
An implementation of RPC service and it requires a dispatch service.
SolarRpcService.RpcWorker - class solar.service.rpc.SolarRpcService.RpcWorker.
A worker thread to handle one RPC request.
SolarRpcService.RpcWorker(RequestEvent, Address) - Constructor for class solar.service.rpc.SolarRpcService.RpcWorker
 
SolarRpcService() - Constructor for class solar.service.rpc.SolarRpcService
 
SolarRuntimeException - exception solar.util.SolarRuntimeException.
This is a base class of all runtime exeptions thrown by Solar.
SolarRuntimeException() - Constructor for class solar.util.SolarRuntimeException
Constructs a new SolarRuntimeException without specified detail message.
SolarRuntimeException(String) - Constructor for class solar.util.SolarRuntimeException
Constructs a new SolarRuntimeException with specified detail message.
SolarRuntimeException(String, Throwable) - Constructor for class solar.util.SolarRuntimeException
Constructs a new SolarRuntimeException with specified detail message and nested Throwable.
SolarRuntimeException(Throwable) - Constructor for class solar.util.SolarRuntimeException
Constructs a new SolarRuntimeException with specified nested Throwable.
SolarServices - class solar.service.SolarServices.
The default service manager for Solar system.
SolarServices() - Constructor for class solar.service.SolarServices
 
Source - class solar.service.dan.Source.
An abstract class for all Solar sources.
SOURCE - Static variable in class solar.service.dan.lang.XmlSpecParser
 
Source() - Constructor for class solar.service.dan.Source
 
SourceChannel - interface solar.service.fap.SourceChannel.
A source channel is for filter to receive data.
SpecParser - interface solar.service.dan.lang.SpecParser.
Interface for the parser of graph specifications.
ssLinkedList - class solar.util.ssLinkedList.
The ssLinkedList class is just that - a linked list abstraction that supports very efficient insertion and deletion, as well as an Enumeration interface.
ssLinkedList.ssLinkedListElement - class solar.util.ssLinkedList.ssLinkedListElement.
This inner class is the chaining mechanism for the linked list
ssLinkedList.ssLinkedListElement(Object) - Constructor for class solar.util.ssLinkedList.ssLinkedListElement
 
ssLinkedList.ssLinkedListEnumeration - class solar.util.ssLinkedList.ssLinkedListEnumeration.
A ssLinkedListEnumeration is a java.util.Enumeration over the ssLinkedList elements.
ssLinkedList.ssLinkedListEnumeration() - Constructor for class solar.util.ssLinkedList.ssLinkedListEnumeration
 
ssLinkedList() - Constructor for class solar.util.ssLinkedList
Allocates a brand new ssLinkedList
ssLinkedListComparator - interface solar.util.ssLinkedListComparator.
The ssLinkedListComparator interface allows you to search for elements inside a ssLinkedList.
ssLinkedListEqualityComparator - class solar.util.ssLinkedListEqualityComparator.
This class provides a default comparator for matching objects on ssLinkedLists.
ssLinkedListEqualityComparator() - Constructor for class solar.util.ssLinkedListEqualityComparator
 
START_INDEX - Static variable in class versus.VersusSource
 
start() - Method in class solar.service.BaseService
 
start() - Method in interface solar.service.Service
Start the service.
start() - Method in class solar.service.transport.UdpTransport
Start the UDP transport.
start() - Method in class solar.service.transport.TcpTransport
Start the TCP transport.
start() - Method in class solar.service.dan.NodeHandler
Start this graph node as a thread.
start(Id, Address, String) - Method in class solar.service.fork.SolarForkService
 
start(Id, Address, String) - Method in interface solar.service.fork.ForkService
Execute a command on specified address.
startArgument(Attributes) - Method in class solar.service.pack.lang.XmlPolicyParser
 
startArgument(Attributes) - Method in class solar.service.dan.lang.XmlSpecParser
 
startArgument(Attributes) - Method in class campus.sysnort.XmlConfigParser
 
startBadge(Attributes) - Method in class versus.XmlVersusParser
 
StartButton - Variable in class versus.meeting.MeetingRecorder
 
StartButtonActionPerformed(ActionEvent) - Method in class versus.meeting.MeetingRecorder
 
startCollector(Attributes) - Method in class versus.XmlVersusParser
 
started - Variable in class versus.meeting.MeetingApp
 
startedAt - Variable in class versus.meeting.MeetingRecorder
 
startedAt - Variable in class versus.meeting.LogFormatter
 
startElement(String, String, String, Attributes) - Method in class solar.service.pack.lang.XmlPolicyParser
 
startElement(String, String, String, Attributes) - Method in class solar.service.dan.lang.XmlSpecParser
 
startElement(String, String, String, Attributes) - Method in class versus.XmlVersusParser
Triggered whenever a new XML tag is encountered.
startElement(String, String, String, Attributes) - Method in class campus.sysnort.XmlConfigParser
 
startFilter(Attributes) - Method in class solar.service.pack.lang.XmlPolicyParser
 
startFilter(Attributes) - Method in class solar.service.dan.lang.XmlSpecParser
 
startGraph(Attributes) - Method in class solar.service.dan.lang.XmlSpecParser
 
startGroup(Attributes) - Method in class solar.service.pack.lang.XmlPolicyParser
 
startInport(Attributes) - Method in class solar.service.dan.lang.XmlSpecParser
 
startOutport(Attributes) - Method in class solar.service.dan.lang.XmlSpecParser
 
startPipe(Attributes) - Method in class solar.service.dan.lang.XmlSpecParser
 
startPolicy(Attributes) - Method in class solar.service.pack.lang.XmlPolicyParser
 
startSensor(Attributes) - Method in class versus.XmlVersusParser
 
startSession(PackSession) - Method in class solar.service.pack.PackFilter
Start a packing session.
startSession(PackSession) - Method in class solar.service.pack.filter.RANDOM
 
startSession(PackSession) - Method in class solar.service.pack.filter.EVEN
 
startSession(PackSession) - Method in class solar.service.pack.filter.ODD
 
startSession(PackSession) - Method in class solar.service.pack.filter.GE
 
startSysnort(Attributes) - Method in class campus.sysnort.XmlConfigParser
 
startTask(Task) - Method in class solar.service.fork.SolarForkService
 
startTask(Task) - Method in interface solar.service.fork.TaskBatch.BatchListener
 
StartTaskRequest - class solar.service.fork.comm.StartTaskRequest.
Request to execute an command on remote host.
StartTaskRequest(Task) - Constructor for class solar.service.fork.comm.StartTaskRequest
 
startTrigger(Attributes) - Method in class campus.sysnort.XmlConfigParser
 
startVersus(Attributes) - Method in class versus.XmlVersusParser
 
state - Variable in class versus.meeting.RLearner
 
state - Variable in class rice.pastry.wire.WireNodeHandle
 
State - interface solar.service.mcode.State.
An empty interface for the captured state of an object that can be used to restore the object later.
STATE_USING_TCP - Static variable in class rice.pastry.wire.WireNodeHandle
 
STATE_USING_UDP - Static variable in class rice.pastry.wire.WireNodeHandle
 
STATE_USING_UDP_WAITING_FOR_TCP_DISCONNECT - Static variable in class rice.pastry.wire.WireNodeHandle
 
STATE_USING_UDP_WAITING_TO_DISCONNECT - Static variable in class rice.pastry.wire.WireNodeHandle
 
states - Variable in class versus.meeting.RLPolicy
 
stop() - Method in class solar.service.BaseService
 
stop() - Method in interface solar.service.Service
Shutdown the service.
stop() - Method in class solar.service.transport.UdpTransport
 
stop() - Method in class solar.service.transport.TcpTransport
 
stop() - Method in class solar.service.transport.PastryTransport
 
stop() - Method in interface solar.service.transport.Transport
Stop the transport layer.
StopButton - Variable in class versus.meeting.MeetingRecorder
 
StopButtonActionPerformed(ActionEvent) - Method in class versus.meeting.MeetingRecorder
 
stopService(String) - Method in class solar.service.BaseServiceManager
 
stopService(String) - Method in interface solar.service.ServiceManager
Stop a specified service.
stopServices() - Method in class solar.service.BaseServiceManager
 
stopServices() - Method in interface solar.service.ServiceManager
Stop all services.
StringAdu - class solar.impl.StringAdu.
Application data unit contains only a string.
StringAdu(String) - Constructor for class solar.impl.StringAdu
Constructs a String ADU.
StringUtil - class solar.util.StringUtil.
Some utility methods about string operations.
StringUtil() - Constructor for class solar.util.StringUtil
Prevent object initialization.
SubRegisterRequest - class solar.service.pubsub.comm.SubRegisterRequest.
A reuqest to register a PACK subscriber.
SubRegisterRequest(Id) - Constructor for class solar.service.pubsub.comm.SubRegisterRequest
 
subscribe(Guid, Name) - Method in class solar.service.dan.Monitor
 
subscribe(Id, Id, Object) - Method in class solar.service.pack.ScribePackService
 
subscribe(Id, Id, Object) - Method in class solar.service.pack.ClientPackService
 
subscribe(Id, Id, Object) - Method in interface solar.service.pack.PackService
Make a subscription to a PACK publisher.
subscribe(Id, Id, Object) - Method in class solar.service.pack.client.PackClient
 
subscribe(Id, Id, Object) - Method in class solar.service.pubsub.ScribePubSubService
 
subscribe(Id, Id, Object) - Method in class solar.service.pubsub.ClientPubSubService
 
subscribe(Id, Id, Object) - Method in interface solar.service.pubsub.PubSubService
Make a subscription to a publisher.
subscribe(Id, Id, Object) - Method in class solar.service.pubsub.client.PubSubClient
 
subscribe(String, Application) - Method in class solar.Client
Subscribe to any source whose name matches the query.
subscribe(String, Application) - Method in class solar.service.dan.DanClientService
Subscribe to any source whose name matches specified query.
subscribe(String, String, Application) - Method in class solar.Client
Compose an operator graph and subscribe to one of the operators.
subscribe(String, String, Application) - Method in class solar.service.dan.DanClientService
Subscribe to a specified operator defined in a graph.
subscribe(SubscribeRequest) - Method in class solar.service.dan.AbstractDanService
 
SubscribeEvent - class solar.service.pack.comm.SubscribeEvent.
Periodic subscription event updating the path along multicast tree.
SubscribeEvent(Event) - Constructor for class solar.service.pack.comm.SubscribeEvent
 
SubscribeEvent(Id, Id, Object, Address, boolean) - Constructor for class solar.service.pack.comm.SubscribeEvent
 
subscribeHandler(NodeId, NodeHandle, boolean, Serializable) - Method in class solar.service.pack.ScribeManager
Invoked by Scribe after a child is added to or removed from one of the node's children tables.
subscribeHandler(NodeId, NodeHandle, boolean, Serializable) - Method in class solar.service.pubsub.ScribeManager
Invoked by Scribe after a child is added to or removed from one of the node's children tables.
subscribeHandler(NodeId, NodeHandle, boolean, Serializable) - Method in class solar.service.multicast.ScribeMulticastService.ScribeMember
Invoked by Scribe after a child is added to or removed from one of the node's children tables.
Subscriber - interface solar.service.pubsub.Subscriber.
The interface for the subscriber who receives an event stream.
SubscribeRequest - class solar.service.pack.comm.SubscribeRequest.
A reuqest for PACK subscription.
SubscribeRequest - class solar.service.dan.comm.SubscribeRequest.
A request to make subscription.
SubscribeRequest - class solar.service.pubsub.comm.SubscribeRequest.
A reuqest for PACK subscription.
SubscribeRequest(Id, Id, Object) - Constructor for class solar.service.pack.comm.SubscribeRequest
 
SubscribeRequest(Id, Id, Object) - Constructor for class solar.service.pubsub.comm.SubscribeRequest
 
SubscribeRequest(String, String, Guid) - Constructor for class solar.service.dan.comm.SubscribeRequest
 
suspend() - Method in class solar.service.pack.proto.GroupBufferHandle
 
suspend() - Method in class solar.service.pack.proto.SingleBufferHandle
 
suspend() - Method in interface solar.service.pack.proto.BufferHandle
Suspend all buffers in this handle from output.
suspend() - Method in interface solar.service.mcode.MobileCode
Suspend the code and capture its state before migration.
suspendSubscriber(Object) - Method in class solar.service.pack.proto.FairQueueOBM
 
suspendSubscriber(Object) - Method in interface solar.service.pack.proto.OutputBufferManager
 
suspendSubscriber(Object) - Method in class solar.service.pack.proto.BaseProtocol
Stop delivering the event to subscriber, but continue receiving events.
SyslogConstants - interface campus.syslog.SyslogConstants.
A list of constants defined for Syslog data.
SyslogParser - class campus.syslog.SyslogParser.
Parses the raw Syslog messages with output used for further analysis.
SyslogParser(int) - Constructor for class campus.syslog.SyslogParser
 
SyslogSource - class campus.syslog.SyslogSource.
A syslog source that produces events from syslog messages.
SyslogSource(boolean) - Constructor for class campus.syslog.SyslogSource
 
SYSNORT - Static variable in class campus.sysnort.XmlConfigParser
 
SysnortApp - class campus.sysnort.SysnortApp.
A Syslog application using Solar PACK service.
SysnortApp(Options) - Constructor for class campus.sysnort.SysnortApp
 
SysnortConfig - class campus.sysnort.SysnortConfig.
A Sysnort configuration contains a set of triggers parsed from the configuration file.
SysnortConfig() - Constructor for class campus.sysnort.SysnortConfig
 
SysnortSensor - class campus.sysnort.SysnortSensor.
A Syslog source using Solar PACK service.
SysnortSensor(Options) - Constructor for class campus.sysnort.SysnortSensor
 
SystemUtil - class solar.util.SystemUtil.
System action allows to execute a system command.
SystemUtil() - Constructor for class solar.util.SystemUtil
 

T

TAG_ASSOCIATED - Static variable in interface campus.syslog.SyslogConstants
 
TAG_AUTHENTICATED - Static variable in interface campus.syslog.SyslogConstants
 
TAG_DEASSOCIATING - Static variable in interface campus.syslog.SyslogConstants
 
TAG_DEASSOCIATION - Static variable in interface campus.syslog.SyslogConstants
 
TAG_DEAUTHENTICATING - Static variable in interface campus.syslog.SyslogConstants
 
TAG_DEAUTHENTICATION - Static variable in interface campus.syslog.SyslogConstants
 
TAG_FATAL - Static variable in interface campus.syslog.SyslogConstants
 
TAG_INACTIVITY - Static variable in interface campus.syslog.SyslogConstants
 
TAG_INFO - Static variable in interface campus.syslog.SyslogConstants
 
TAG_REASSOCIATED - Static variable in interface campus.syslog.SyslogConstants
 
TAG_REPEAT_LAST_MSG - Static variable in interface campus.syslog.SyslogConstants
 
TAG_ROAMED - Static variable in interface campus.syslog.SyslogConstants
 
TAG_SYSLOG - Static variable in interface campus.syslog.SyslogConstants
 
TAG_WARNING - Static variable in interface campus.syslog.SyslogConstants
 
takeAction(Object) - Method in class campus.sysnort.Trigger
When the checkCondition returns true, Sysnort retrieves the action object and may call takeAction immediately or defer to a later time.
takeAction(Object) - Method in class campus.sysnort.trigger.HotspotTrigger
 
takeAction(Object) - Method in class campus.sysnort.trigger.FlickerTrigger
 
takeAction(Object) - Method in class campus.sysnort.trigger.MissingCardTrigger
 
Task - class solar.service.fork.Task.
A configuration of a fork task.
Task() - Constructor for class solar.service.fork.Task
 
Task(Id) - Constructor for class solar.service.fork.Task
 
TaskBatch - class solar.service.fork.TaskBatch.
A class contains batch jobs defined in a cfg file.
TaskBatch.BatchListener - interface solar.service.fork.TaskBatch.BatchListener.
 
TaskBatch.RepeatParam - class solar.service.fork.TaskBatch.RepeatParam.
 
TaskBatch.RepeatParam() - Constructor for class solar.service.fork.TaskBatch.RepeatParam
 
TaskBatch(String, TaskBatch.BatchListener) - Constructor for class solar.service.fork.TaskBatch
 
taskFinished(Task) - Method in class solar.service.fork.TaskBatch
 
TaskFinishEvent - class solar.service.fork.comm.TaskFinishEvent.
Notification of task finished.
TaskFinishEvent(Event) - Constructor for class solar.service.fork.comm.TaskFinishEvent
 
TaskFinishEvent(Task) - Constructor for class solar.service.fork.comm.TaskFinishEvent
 
TcpConnection - class solar.service.transport.TcpConnection.
The connection between two TCP peers.
TcpConnection(boolean, Socket, SocketAddress) - Constructor for class solar.service.transport.TcpConnection
Constructs a new connection from a local connected socket.
TcpNodeHandle - class rice.pastry.wire.TcpNodeHandle.
Node handle that use TCP to transmit messages.
TcpNodeHandle(InetSocketAddress, NodeId) - Constructor for class rice.pastry.wire.TcpNodeHandle
 
TcpNodeHandle(InetSocketAddress, NodeId, PastryNode) - Constructor for class rice.pastry.wire.TcpNodeHandle
 
TcpObjectTransport - class solar.service.transport.TcpObjectTransport.
The TCP transport layer using object serialization.
TcpObjectTransport() - Constructor for class solar.service.transport.TcpObjectTransport
 
TcpObjectTransport(int) - Constructor for class solar.service.transport.TcpObjectTransport
 
TcpObjectTransport(String, int) - Constructor for class solar.service.transport.TcpObjectTransport
 
TcpPastryNodeFactory - class rice.pastry.wire.TcpPastryNodeFactory.
A pastry node factory producing TcpNodeHandle, everything else is same to WirePastryNodeFactory.
TcpPastryNodeFactory(NodeIdFactory, int) - Constructor for class rice.pastry.wire.TcpPastryNodeFactory
 
TcpTransport - class solar.service.transport.TcpTransport.
The TCP transport layer, converting ADU to bytes before sending.
TcpTransport() - Constructor for class solar.service.transport.TcpTransport
Constructs a new TCP transport, which listens on an available port.
TcpTransport(int) - Constructor for class solar.service.transport.TcpTransport
Constructs a new TCP transport, which listens on a specified port.
TcpTransport(String, int) - Constructor for class solar.service.transport.TcpTransport
 
TcpTransportService - class solar.service.transport.TcpTransportService.
Transport service that uses TCP, and requires a routing service.
TcpTransportService() - Constructor for class solar.service.transport.TcpTransportService
 
temp - Variable in class versus.meeting.RLearner
 
thisThread - Variable in class versus.meeting.RLearner
 
thisWorld - Variable in class versus.meeting.RLearner
 
TIME_THRESHOLD - Static variable in class campus.sysnort.trigger.FlickerTrigger
 
timer - Variable in class versus.meeting.RLearner
 
toBytes() - Method in class solar.api.Id
 
toBytes() - Method in interface solar.api.Address
Return the byte array representation of this address.
toBytes() - Method in interface solar.api.Adu
Return the byte array format of this ADU.
toBytes() - Method in class solar.impl.SerializedAdu
 
toBytes() - Method in class solar.impl.ByteArrayAdu
 
toBytes() - Method in class solar.impl.SerializedEvent
 
toBytes() - Method in class solar.impl.PlainEvent
 
toBytes() - Method in class solar.impl.PlainAttributeRecord
 
toBytes() - Method in class solar.impl.StringAdu
 
toBytes() - Method in class solar.service.transport.SocketAddress
 
toBytes() - Method in class solar.service.transport.PastryAddress
 
toHexString(byte[]) - Static method in class solar.util.StringUtil
Convert a byte array to a printable hex string.
toLogString() - Method in class campus.Location
 
toPoll(String, String) - Method in class campus.snmp.SnmpLocator
Check whether an AP is pollable at this time.
toString() - Method in class solar.api.Guid
 
toString() - Method in class solar.api.Id
 
toString() - Method in interface solar.api.Address
Return the string representation of this address.
toString() - Method in class solar.api.Attribute
 
toString() - Method in interface solar.api.Adu
Return the string format of this ADU.
toString() - Method in class solar.impl.SerializedAdu
 
toString() - Method in class solar.impl.ByteArrayAdu
 
toString() - Method in class solar.impl.SerializedEvent
 
toString() - Method in class solar.impl.PlainAttributeRecord
 
toString() - Method in class solar.impl.StringAdu
 
toString() - Method in class solar.util.Counter
 
toString() - Method in class solar.util.ssLinkedList
Return a string representation, for debugging purposes
toString() - Method in class solar.service.pack.proto.GroupBufferHandle
 
toString() - Method in class solar.service.pack.proto.SingleBufferHandle
 
toString() - Method in class solar.service.pack.proto.BaseProtocol
Return the string representation of this protocol.
toString() - Method in class solar.service.transport.PastryTransport.MultiplexAddress
 
toString() - Method in class solar.service.transport.Header
 
toString() - Method in class solar.service.transport.SocketAddress
 
toString() - Method in class solar.service.transport.PastryAddress
 
toString() - Method in class solar.service.rmtobj.RemoteObject
 
toString() - Method in class solar.service.fork.Task
 
toString() - Method in class solar.service.fap.Port
 
toString() - Method in class solar.service.directory.NameRecord
Return the string representation of this name record.
toString() - Method in class campus.AccessPoint
Return a string representation of this access point.
toString() - Method in class campus.Location
 
toString() - Method in class campus.sysnort.trigger.FlickerTrigger.ClientState
 
toString() - Method in class campus.snmp.ApStat
 
toString() - Method in class rice.pastry.socket.HelloResponseMessage
 
toString() - Method in class rice.pastry.socket.HelloMessage
 
toString() - Method in class rice.pastry.socket.SocketNodeHandlePool
 
toString(String) - Method in class solar.util.ssLinkedList
 
toStringImpl() - Method in class rice.pastry.wire.WireNodeHandle
 
toStringImpl() - Method in class rice.pastry.socket.SocketNodeHandle
 
trace - Variable in class versus.meeting.RLearner
 
Transport - interface solar.service.transport.Transport.
Interface for transport layer.
TRANSPORT_PASTRY_PORT - Static variable in interface solar.service.transport.TransportConstants
The default pastry listening port.
TRANSPORT_TCP_PORT - Static variable in interface solar.service.transport.TransportConstants
The default tcp listening port.
TRANSPORT_UDP_MSS - Static variable in interface solar.service.transport.TransportConstants
UDP packet size limit.
TRANSPORT_UDP_PORT - Static variable in interface solar.service.transport.TransportConstants
The default udp listening port.
TransportConstants - interface solar.service.transport.TransportConstants.
Constants used by transport service.
TransportException - exception solar.service.transport.TransportException.
The exception thrown by transport layer.
TransportException(String) - Constructor for class solar.service.transport.TransportException
Construct an TransportException with specified detail message.
TransportException(String, Throwable) - Constructor for class solar.service.transport.TransportException
Construct an TransportException with specified detail message and nested Throwable.
TransportException(Throwable) - Constructor for class solar.service.transport.TransportException
Construct an TransportException with specified nested Throwable.
TransportListener - interface solar.service.transport.TransportListener.
Interface for event listener on transport layer.
TransportService - interface solar.service.transport.TransportService.
Interface for transport network layer, either based on IP or P2P.
TreeDirectory - class solar.service.directory.TreeDirectory.
A hierarchical directory containing all or part of registered names, not implemented yet.
TreeDirectory() - Constructor for class solar.service.directory.TreeDirectory
 
Trigger - class campus.sysnort.Trigger.
Abstract class for Sysnort trigger.
TRIGGER - Static variable in class campus.sysnort.XmlConfigParser
 
Trigger() - Constructor for class campus.sysnort.Trigger
 
TriggerConfig - class campus.sysnort.TriggerConfig.
The configuration of a single trigger.
TriggerConfig() - Constructor for class campus.sysnort.TriggerConfig
 
TriggerHandler - class campus.sysnort.TriggerHandler.
A container class for Sysnort triggers.
TriggerHandler(Trigger) - Constructor for class campus.sysnort.TriggerHandler
 
TYPE - Static variable in class solar.service.dan.lang.XmlSpecParser
 

U

UdpNodeHandle - class rice.pastry.wire.UdpNodeHandle.
Node handle that use UDP to transmit messages.
UdpNodeHandle(InetSocketAddress, NodeId) - Constructor for class rice.pastry.wire.UdpNodeHandle
 
UdpObjectTransport - class solar.service.transport.UdpObjectTransport.
The UDP transport layer using object (ADU) serialization.
UdpObjectTransport() - Constructor for class solar.service.transport.UdpObjectTransport
Constructs a new UDP transport, which listens on an available port.
UdpObjectTransport(int) - Constructor for class solar.service.transport.UdpObjectTransport
Constructs a new UDP transport, which listens on a specified port.
UdpObjectTransport(String, int) - Constructor for class solar.service.transport.UdpObjectTransport
 
UdpPastryNodeFactory - class rice.pastry.wire.UdpPastryNodeFactory.
A pastry node factory producing UdpNodeHandle, everything else is same to WirePastryNodeFactory.
UdpPastryNodeFactory(NodeIdFactory, int) - Constructor for class rice.pastry.wire.UdpPastryNodeFactory
 
UdpTransport - class solar.service.transport.UdpTransport.
The UDP transport layer, converting ADU to bytes for sending.
UdpTransport() - Constructor for class solar.service.transport.UdpTransport
 
UdpTransport(int) - Constructor for class solar.service.transport.UdpTransport
 
UdpTransport(String, int) - Constructor for class solar.service.transport.UdpTransport
 
UdpTransportService - class solar.service.transport.UdpTransportService.
Transport service that uses UDP, and requires a routing service.
UdpTransportService() - Constructor for class solar.service.transport.UdpTransportService
 
unadvertise(Name, Id) - Method in class solar.service.directory.DistDirectoryService
 
unadvertise(Name, Id) - Method in class solar.service.directory.CentralDirectoryService
 
unadvertise(Name, Id) - Method in interface solar.service.directory.DirectoryService
Unadvertise a name from the name space.
unadvertise(Name, NameRecord) - Method in class solar.service.directory.FlatDirectory
 
unadvertise(Name, NameRecord) - Method in interface solar.service.directory.Directory
Unadvertise a name from the name space.
UnadvertiseRequest - class solar.service.directory.comm.UnadvertiseRequest.
Request to cancel an advertisement made before.
UnadvertiseRequest(Name, NameRecord) - Constructor for class solar.service.directory.comm.UnadvertiseRequest
 
unknownAP(String) - Method in class campus.syslog.APMapping
return false, if a AP is not in the data file by MAC address of AP.
unregister(Id) - Method in class solar.service.rmtobj.SolarRemoteObjectService
 
unregister(Id) - Method in interface solar.service.rmtobj.RemoteObjectService
Unregister a local object.
unregister(RemoteObject) - Method in class solar.service.rmtobj.SolarRemoteObjectService
 
unregister(RemoteObject) - Method in interface solar.service.rmtobj.RemoteObjectService
Unregister a remote object.
UnregisterRequest - class solar.service.rmtobj.comm.UnregisterRequest.
A request to unregister interest on a remote object.
UnregisterRequest(Id) - Constructor for class solar.service.rmtobj.comm.UnregisterRequest
 
update(Event) - Method in class campus.snmp.SnmpLocator
Update the locator with a published syslog event.
update(Name, Id, Name, Object) - Method in class solar.service.directory.DistDirectoryService
 
update(Name, Id, Name, Object) - Method in class solar.service.directory.CentralDirectoryService
 
update(Name, Id, Name, Object) - Method in interface solar.service.directory.DirectoryService
Update a name advertisement in the name space.
update(Name, NameRecord, Name, NameRecord) - Method in class solar.service.directory.FlatDirectory
 
update(Name, NameRecord, Name, NameRecord) - Method in interface solar.service.directory.Directory
Update a name advertisement in the name space.
update(ProtocolEvent) - Method in interface solar.module.protocol.Protocol
Update the protocol state with control events.
update(ProtocolEvent) - Method in class solar.service.pack.proto.BaseProtocol
 
update(String) - Method in class campus.snmp.SnmpLocator
Update the locator with a parsed syslog message.
update(WireNodeHandle) - Method in class rice.pastry.wire.SocketManager
Method which is designed to be called whenever a node has network activity.
updateCounter(String, int) - Method in class campus.sysnort.trigger.HotspotTrigger
 
UpdateRequest - class solar.service.directory.comm.UpdateRequest.
Request to update a directory.
UpdateRequest(Name, NameRecord, Name, NameRecord) - Constructor for class solar.service.directory.comm.UpdateRequest
 

V

validAction(int) - Method in class versus.meeting.RLMeetingWorld
 
validAction(int) - Method in interface versus.meeting.RLWorld
Returns true if the given action is a valid action on the current state, false if not.
VALUE - Static variable in class solar.impl.PlainAttributeRecord
 
VALUE - Static variable in class solar.service.pack.lang.XmlPolicyParser
 
VALUE - Static variable in class solar.service.dan.lang.XmlSpecParser
 
VALUE - Static variable in class campus.sysnort.XmlConfigParser
 
value() - Method in class solar.util.Counter
 
VERBOSE - Variable in class campus.syslog.CatalogBuildingMapping
 
VERBOSE - Variable in class campus.syslog.BuildingNameConvertor
 
VERBOSE - Variable in class campus.syslog.APMapping
 
verifyAddressBinding(Credentials, Address) - Method in class rice.pastry.socket.SocketPastrySecurityManager
Checks to see if these credentials can be associated with the address.
verifyMessage(Message) - Method in class rice.pastry.socket.SocketPastrySecurityManager
This method takes a message and returns true if the message is safe and false otherwise.
verifyNodeHandle(NodeHandle) - Method in class rice.pastry.socket.SocketPastrySecurityManager
Verify node handle safety.
VERSION - Static variable in class campus.compass.CompassService
 
versus - package versus
Contains various Versus-related Solar source and operators.
versus.meeting - package versus.meeting
Contains a Solar application that detects meeting starts and ends in an office.
VersusFilter - class versus.VersusFilter.
A versus-event filter based on the name atrribute.
VersusFilter() - Constructor for class versus.VersusFilter
 
VersusMapping - class versus.VersusMapping.
A mapping object holding Versus conversion table parsed from a config file.
VersusMapping(String) - Constructor for class versus.VersusMapping
Constructs the table with specified local XML mapping file.
VersusMapping(URL) - Constructor for class versus.VersusMapping
Constructs the table with specified remote XML mapping file.
VersusSource - class versus.VersusSource.
A location source that connects to the Versus badge server.
VersusSource() - Constructor for class versus.VersusSource
 
VersusSource(boolean) - Constructor for class versus.VersusSource
 
VersusTracker - class versus.VersusTracker.
A location aggregator that tracks the latest location of every object.
VersusTracker() - Constructor for class versus.VersusTracker
 
VersusTransformer - class versus.VersusTransformer.
A transformer converts badge and sensor ID numbers in Versus events into symbolic values.
VersusTransformer() - Constructor for class versus.VersusTransformer
 
viewPrefs() - Method in class org.doit.muffin.filter.Logger
 
viewPrefs() - Method in class org.doit.muffin.filter.Compass
 
VISIT_LIMIT - Static variable in class campus.compass.GeobytesSource
 

W

WAIT_INTERVAL - Static variable in class campus.snmp.SnmpLocator
 
waitBlock(Object, long) - Static method in class solar.service.rpc.Block
Wait for reply with specified timeout.
waitingForGreeting - Variable in class rice.pastry.wire.SocketChannelWriter
 
wakeBlock(Object, Object) - Static method in class solar.service.rpc.Block
Wake up the blocks waiting for replies.
wakeup() - Method in class rice.pastry.wire.SocketManager
Specified by the SelectionKeyHandler interface - does nothing.
wakeup() - Method in class rice.pastry.wire.WireNodeHandle
Is called by the SelectorManager every time the manager is awakened.
WhoisSource - class campus.compass.WhoisSource.
Given an IP address, determine its geo location using whois command.
WhoisSource() - Constructor for class campus.compass.WhoisSource
 
WireNodeHandle - class rice.pastry.wire.WireNodeHandle.
Class which represents a node handle in the socket-based pastry protocol.
WireNodeHandle(InetSocketAddress, NodeId) - Constructor for class rice.pastry.wire.WireNodeHandle
Constructor.
WireNodeHandle(InetSocketAddress, NodeId, PastryNode) - Constructor for class rice.pastry.wire.WireNodeHandle
Alternate constructor with local Pastry node.
write() - Method in class rice.pastry.wire.SocketManager.SocketConnector
 
write(DataOutputStream) - Method in class solar.service.transport.Header
 
write(ObjectOutputStream) - Method in class solar.service.transport.Header
 
write(SelectionKey) - Method in class rice.pastry.wire.SocketManager
Specified by the SelectionKeyHandler interface - should NEVER be called!
write(SelectionKey) - Method in class rice.pastry.wire.WireNodeHandle
Called by the socket manager whenever this node handle has registered interest in writing to it's remote node, and the socket is ready for writing.
write(SocketChannel) - Method in class rice.pastry.wire.SocketChannelWriter
Method which is designed to be called when this writer should write out its data.
writer - Variable in class rice.pastry.wire.SocketManager.SocketConnector
 
writer - Variable in class rice.pastry.wire.WireNodeHandle
 

X

x - Variable in class campus.syslog.APLocation
 
XmlConfigParser - class campus.sysnort.XmlConfigParser.
An XML parser that parses the Sysnort configuration file into a set of triggers.
XmlConfigParser() - Constructor for class campus.sysnort.XmlConfigParser
 
XmlPolicyParser - class solar.service.pack.lang.XmlPolicyParser.
An XML parser for PACK policies.
XmlPolicyParser() - Constructor for class solar.service.pack.lang.XmlPolicyParser
 
XmlSpecParser - class solar.service.dan.lang.XmlSpecParser.
An XML parser for FAP graph specification.
XmlSpecParser() - Constructor for class solar.service.dan.lang.XmlSpecParser
 
XmlVersusParser - class versus.XmlVersusParser.
A XML parser for Versus configuration file containing floorplan and badge mapping.
XmlVersusParser() - Constructor for class versus.XmlVersusParser
 

Y

y - Variable in class campus.syslog.APLocation
 

Z

z - Variable in class campus.syslog.APLocation
 
ZipCodeSource - class campus.compass.ZipCodeSource.
Given a zip code, determine associated city/state, or vice versa.
ZipCodeSource() - Constructor for class campus.compass.ZipCodeSource
 

_

_accesspoints - Variable in class campus.CampusMap
 
_action - Variable in class versus.meeting.RLMeetingWorld
 
_action - Variable in class campus.syslog.SyslogParser
 
_actionObject - Variable in class campus.sysnort.Trigger
 
_actionTime - Variable in class versus.meeting.RLMeetingWorld
 
_addr - Variable in class solar.service.fap.RemoteSinkChannel
 
_addr - Variable in class solar.service.fap.RemoteSourceChannel
 
_address - Variable in class solar.api.Guid
 
_address - Variable in class solar.service.pack.EndPointManager.EP
 
_address - Variable in class solar.service.rmtobj.RemoteObject
 
_address - Variable in class solar.service.dan.comm.PipeConnectRequest
 
_address - Variable in class solar.service.dan.lang.FilterSpec
 
_address - Variable in class solar.service.pubsub.EndPointManager.EP
 
_address - Variable in class solar.service.multicast.RemoteMulticastMember
 
_address - Variable in class solar.service.directory.RemoteDirectoryListener
 
_address - Variable in class solar.service.directory.NameRecord
 
_address - Variable in class rice.pastry.socket.SocketPastryNode
 
_adu - Variable in class solar.service.transport.PastryMessage
 
_adu - Variable in class solar.service.dispatch.DispatchUnit
 
_aduFactory - Variable in class solar.service.transport.UdpTransport
The factory to parse received byte array into ADU.
_aduFactory - Variable in class solar.service.transport.TcpConnection
 
_aduFactory - Variable in class solar.service.transport.TcpTransport
The factory to parse received byte array into ADU.
_aduFactory - Variable in class solar.service.transport.BaseTransportService
The factory parses received packets.
_aduFactory - Variable in class solar.service.transport.PastryTransport
 
_agent - Variable in class versus.meeting.RLMeetingWorld
 
_anonymize - Variable in class org.doit.muffin.filter.Logger
 
_antenna - Variable in class campus.AccessPoint
 
_aplist - Variable in class campus.snmp.SnmpLocator
 
_apname - Variable in class campus.syslog.SyslogParser
 
_apname - Variable in class campus.snmp.ApStat
 
_apname - Variable in class campus.snmp.SnmpLocator.SnmpTask
 
_aps - Variable in class campus.sysnort.trigger.HotspotTrigger
 
_apset - Variable in class campus.sysnort.trigger.FlickerTrigger.ClientState
 
_apstat - Variable in class campus.snmp.SnmpLocator
 
_arguments - Variable in class solar.service.pack.lang.FilterConfig
 
_arguments - Variable in class solar.service.dan.lang.FilterSpec
 
_arguments - Variable in class campus.sysnort.TriggerConfig
 
_attached - Variable in class solar.service.mhost.SolarMobileHostService
 
_attr - Variable in class rice.pastry.socket.SocketNodeHandle
 
_attributes - Variable in class solar.impl.AbstractAttributeRecord
 
_badgeHost - Variable in class versus.VersusSource
 
_badgePort - Variable in class versus.VersusSource
 
_badges - Variable in class versus.VersusTransformer
 
_badges - Variable in class versus.XmlVersusParser
 
_badges - Variable in class versus.VersusMapping
 
_batch - Variable in class solar.service.fork.SolarForkService
 
_batch - Variable in class solar.test.PackSender
 
_blocking - Variable in class campus.sysnort.trigger.HotspotTrigger
 
_blocks - Static variable in class solar.service.rpc.Block
 
_buffer - Variable in class solar.module.protocol.Buffer
 
_buffer - Variable in class solar.service.pack.proto.SingleBufferHandle
 
_buffer - Variable in class versus.meeting.MeetingDetector
 
_bufferLimit - Variable in class solar.service.pack.proto.BaseProtocol.ProtocolState
 
_buffers - Variable in class solar.service.pack.proto.BaseProtocol.ProtocolState
 
_building - Variable in class campus.AccessPoint
 
_buildings - Variable in class campus.CampusMap
 
_bytes - Variable in class solar.service.transport.PastryMessage
 
_cache - Variable in class solar.module.cache.BaseCache
 
_cache - Variable in class solar.service.rmtobj.SolarRemoteObjectService
 
_capacity - Variable in class solar.module.cache.BaseCache
 
_cards - Variable in class campus.sysnort.trigger.MissingCardTrigger
 
_category - Variable in class campus.Building
 
_certainty - Variable in class campus.Location
 
_channel - Variable in class campus.AccessPoint
 
_children - Variable in class solar.service.directory.NameNode
 
_city - Variable in class campus.Location
 
_cityurl - Variable in class campus.Location
 
_class - Variable in class solar.service.dan.lang.FilterSpec
 
_classname - Variable in class campus.sysnort.TriggerConfig
 
_client - Variable in class solar.Shell
 
_client - Variable in class solar.service.dan.comm.PipeConnectRequest
 
_client - Variable in class solar.service.mhost.comm.DetachRequest
 
_client - Variable in class solar.service.mhost.comm.AttachRequest
 
_client - Variable in class solar.test.PackSender
 
_clientAp - Variable in class org.doit.muffin.filter.CompassFilter
 
_clienthost - Variable in class campus.syslog.SyslogParser
 
_clientLocation - Variable in class org.doit.muffin.filter.CompassFilter
 
_clientmac - Variable in class campus.syslog.SyslogParser
 
_clientmac - Variable in class campus.snmp.SnmpLocator.SnmpTask
 
_clients - Variable in class solar.service.fap.FapClientService
 
_clients - Variable in class campus.sysnort.trigger.HotspotTrigger
 
_clock - Variable in class campus.LogTracer
 
_clock - Variable in class campus.sysnort.trigger.HotspotTrigger
 
_code - Variable in class campus.Building
 
_codebase - Variable in class solar.service.dan.lang.FilterSpec
 
_codebase - Variable in class campus.sysnort.TriggerConfig
 
_command - Variable in class solar.service.fork.Task
 
_community - Variable in class campus.snmp.SnmpLocator
 
_community - Variable in class campus.snmp.SnmpSource
 
_community - Variable in class campus.compass.CompassService
 
_config - Variable in class solar.service.BaseServiceManager
Configurations used for all the services.
_config - Variable in class campus.sysnort.XmlConfigParser
 
_config - Variable in class campus.sysnort.SysnortConfig
 
_config - Variable in class campus.sysnort.SysnortApp
 
_coolFilter - Variable in class solar.service.pack.PackPolicy
 
_coreRpc - Variable in class solar.service.pack.ScribePackService
 
_coreRpc - Variable in class solar.service.dan.AbstractDanService
 
_coreRpc - Variable in class solar.service.pubsub.ScribePubSubService
 
_coreRpc - Variable in class solar.service.fap.SolarFapService
 
_coreTransport - Variable in class solar.service.pack.ScribePackService
 
_coreTransport - Variable in class solar.service.dan.AbstractDanService
 
_coreTransport - Variable in class solar.service.pubsub.ScribePubSubService
 
_coreTransport - Variable in class solar.service.fap.SolarFapService
 
_coreTransportAddress - Variable in class solar.service.pack.ScribePackService
 
_coreTransportAddress - Variable in class solar.service.pubsub.ScribePubSubService
 
_coreTransportName - Variable in class solar.service.pack.ScribePackService
 
_coreTransportName - Variable in class solar.service.pubsub.ScribePubSubService
 
_counter - Variable in class solar.util.Counter
 
_counter - Variable in class solar.test.PackSender
 
_country - Variable in class campus.Location
 
_country - Static variable in class campus.compass.CountryCode
 
_created - Variable in class solar.module.cache.CachedObject
When created.
_cred - Variable in class solar.service.pack.ScribeManager
 
_cred - Static variable in class solar.service.transport.PastryTransport
Credentials of this Pastry application / our transport layer.
_cred - Variable in class solar.service.pubsub.ScribeManager
 
_cred - Variable in class solar.service.multicast.ScribeMulticastService
 
_currentCollectorTable - Variable in class versus.XmlVersusParser
 
_currentTime - Variable in class versus.meeting.RLMeetingWorld
 
_dan - Variable in class solar.Client
 
_dan - Variable in class solar.service.dan.Monitor
 
_dan - Variable in class solar.service.dan.PipeConnector
 
_dan - Variable in class solar.service.dan.GraphManager
The DAN service to which this graph manager is affiliated.
_datafile - Variable in class campus.sysnort.trigger.HotspotTrigger
 
_datain - Variable in class solar.service.transport.TcpConnection
 
_dataout - Variable in class solar.service.transport.TcpConnection
 
_day - Variable in class campus.syslog.SyslogParser
 
_debug - Variable in class solar.service.transport.PastryTransportService
 
_delta - Variable in class solar.service.fork.TaskBatch.RepeatParam
 
_dest - Variable in class solar.service.pack.proto.BufferedEvent
 
_dest - Variable in class solar.service.transport.Header
 
_dest - Variable in class solar.service.fork.Task
 
_dguid - Variable in class solar.service.dan.comm.PipeConnectRequest
 
_directory - Variable in class solar.service.dan.Monitor
 
_directory - Variable in class solar.service.dan.AbstractDanService
 
_directory - Variable in class solar.service.multicast.NaiveMulticastService
 
_directory - Variable in class solar.service.directory.DistDirectoryService
 
_directory - Variable in class solar.service.directory.FlatDirectory
 
_directory - Variable in class solar.service.directory.CentralDirectoryService
 
_dispatch - Variable in class solar.Client
 
_dispatch - Variable in class solar.service.pack.ScribePackService
 
_dispatch - Variable in class solar.service.pack.ClientPackService
 
_dispatch - Variable in class solar.service.pack.client.PackClient
 
_dispatch - Variable in class solar.service.routing.ManualRoutingService
 
_dispatch - Variable in class solar.service.rmtobj.SolarRemoteObjectService
 
_dispatch - Variable in class solar.service.fork.SolarForkService
 
_dispatch - Variable in class solar.service.fork.client.ForkClient
 
_dispatch - Variable in class solar.service.pubsub.ScribePubSubService
 
_dispatch - Variable in class solar.service.pubsub.ClientPubSubService
 
_dispatch - Variable in class solar.service.pubsub.client.PubSubClient
 
_dispatch - Variable in class solar.service.mhost.SolarMobileHostService
 
_dispatch - Variable in class solar.service.rpc.SolarRpcService
Dependent dispatch service.
_dispatch - Variable in class solar.service.fap.DirectPipe
 
_dispatch - Variable in class solar.service.fap.FapClientService
 
_dispatch - Variable in class solar.service.directory.CentralDirectoryService
 
_drophead - Variable in class solar.module.protocol.Buffer
 
_edgeRpc - Variable in class solar.service.dan.AbstractDanService
 
_edgeRpc - Variable in class solar.service.fap.SolarFapService
 
_edgeTransport - Variable in class solar.service.dan.AbstractDanService
 
_edgeTransport - Variable in class solar.service.fap.SolarFapService
 
_edgeTransportName - Variable in class solar.service.pack.ScribePackService
 
_edgeTransportName - Variable in class solar.service.pubsub.ScribePubSubService
 
_emailto - Variable in class campus.sysnort.trigger.FlickerTrigger
 
_emailto - Variable in class campus.sysnort.trigger.MissingCardTrigger
 
_end - Variable in class solar.service.fork.Task
 
_end - Variable in class solar.service.fork.TaskBatch.RepeatParam
 
_endpoint - Variable in class solar.service.pack.EndPointManager.EP
 
_endpoint - Variable in class solar.service.pubsub.EndPointManager.EP
 
_endpoints - Variable in class solar.service.pack.EndPointManager
 
_endpoints - Variable in class solar.service.pubsub.EndPointManager
 
_endState - Variable in class versus.meeting.RLMeetingWorld
 
_epman - Variable in class solar.service.pack.ScribePackService
 
_epman - Variable in class solar.service.pack.ClientPackService
 
_epman - Variable in class solar.service.pubsub.ScribePubSubService
 
_epman - Variable in class solar.service.pubsub.ClientPubSubService
 
_event - Variable in class solar.service.pack.proto.BufferedEvent
 
_event - Variable in class solar.service.multicast.comm.MulticastRequest
 
_event - Variable in class solar.service.multicast.comm.ReceiveRequest
 
_evt - Variable in class solar.service.rpc.SolarRpcService.RpcWorker
 
_executionThread - Variable in class rice.pastry.socket.SocketPastryNode
 
_expires - Variable in class solar.module.cache.CachedObject
When it expires.
_extra - Variable in class solar.service.dan.comm.AdvertiseRequest
 
_extra - Variable in class solar.service.pubsub.comm.SubscribeRequest
 
_factory - Static variable in class solar.service.pack.lang.XmlPolicyParser
 
_factory - Static variable in class solar.service.dan.lang.XmlSpecParser
 
_factory - Variable in class versus.XmlVersusParser
 
_factory - Static variable in class campus.sysnort.XmlConfigParser
 
_factory - Variable in class rice.pastry.socket.SocketPastryNodeFactory
 
_factory - Variable in class rice.pastry.socket.SocketNodeHandle
 
_fakeids - Variable in class solar.service.pack.ScribePackService
 
_fap - Variable in class solar.Client
 
_fap - Variable in class solar.service.dan.DanClientService
 
_fap - Variable in class solar.service.dan.PipeConnector
 
_fap - Variable in class solar.service.dan.AbstractDanService
 
_fapName - Variable in class solar.service.fap.DirectPipe
 
_fid - Variable in class solar.service.pack.PackFilter
 
_filter - Variable in class solar.service.pack.lang.XmlPolicyParser
 
_filter - Variable in class solar.service.dan.lang.XmlSpecParser
 
_filterAttr - Variable in class solar.service.pack.filter.EVEN
 
_filterAttr - Variable in class solar.service.pack.filter.ODD
 
_filterAttr - Variable in class solar.service.pack.filter.GE
 
_filters - Variable in class solar.service.pack.PackPolicy
 
_filters - Variable in class solar.service.pack.lang.XmlPolicyParser
 
_finished - Variable in class solar.service.fork.Task
 
_floor - Variable in class campus.AccessPoint
 
_floorplan - Variable in class versus.VersusTransformer
 
_floorplan - Variable in class versus.XmlVersusParser
 
_floorplan - Variable in class versus.VersusMapping
 
_flow - Variable in class solar.service.dan.lang.PipeSpec
 
_flows - Variable in class solar.service.transport.TcpTransport
The table of live connections.
_fork - Variable in class solar.service.fork.client.ForkClient
 
_forkName - Variable in class solar.service.fork.SolarForkService
 
_fwdproto - Variable in class solar.service.pack.ScribePackService
 
_gateway - Variable in class campus.AccessPoint
 
_gid - Variable in class solar.service.dan.GraphNode
 
_gkeys - Variable in class solar.service.pack.PackPolicy
 
_gmans - Variable in class solar.service.dan.NodeManager
 
_gnode - Variable in class solar.service.dan.NodeHandler
 
_graph - Variable in class solar.service.dan.comm.AdvertiseRequest
 
_graph - Variable in class solar.service.dan.comm.SubscribeRequest
 
_graph - Variable in class solar.service.dan.lang.XmlSpecParser
 
_graph - Variable in class solar.service.dan.lang.GraphSpec
 
_greeted - Variable in class rice.pastry.socket.SocketNodeHandle
 
_groupId - Variable in class solar.service.multicast.MulticastGroup
 
_groupId - Variable in class solar.service.multicast.comm.MulticastRequest
 
_groupId - Variable in class solar.service.multicast.comm.LeaveRequest
 
_groupId - Variable in class solar.service.multicast.comm.JoinRequest
 
_groups - Variable in class solar.service.multicast.NaiveMulticastService
 
_gs - Variable in class solar.service.dan.GraphManager
The graph spec to be mantained.
_guid - Variable in class solar.service.dan.Monitor
 
_guid - Variable in class solar.service.dan.comm.AdvertiseRequest
 
_guid - Variable in class solar.service.dan.comm.SubscribeRequest
 
_guid - Variable in class solar.service.directory.NameRecord
 
_handler - Variable in class solar.service.dan.ProxyOperator
 
_handler - Variable in class solar.service.dan.GraphNode
 
_hashcode - Variable in class solar.service.transport.SocketAddress
 
_hashcode - Variable in class solar.service.transport.PastryAddress
 
_hashcode - Variable in class solar.service.rmtobj.RemoteObject
 
_header - Variable in class solar.service.transport.PastryMessage
 
_hex - Static variable in class solar.test.GroundHog
 
_hits - Variable in class campus.sysnort.trigger.FlickerTrigger.ClientState
 
_holding - Variable in class versus.meeting.RLMeetingWorld
 
_hostname - Variable in class solar.service.transport.UdpTransport
Particular interface to bind to.
_hostname - Variable in class solar.service.transport.TcpTransport
Particular interface to bind to.
_hotFilter - Variable in class solar.service.pack.PackPolicy
 
_hotThreshold - Variable in class campus.sysnort.trigger.HotspotTrigger
 
_id - Variable in class solar.api.Id
 
_id - Variable in class solar.module.cache.CachedObject
The id for cached object.
_id - Variable in class solar.service.pack.ScribePackService.RootTask
 
_id - Variable in class solar.service.pack.comm.ScribeRootRequest
 
_id - Variable in class solar.service.rmtobj.RemoteObject
 
_id - Variable in class solar.service.rmtobj.comm.RegisterRequest
 
_id - Variable in class solar.service.rmtobj.comm.UnregisterRequest
 
_id - Variable in class solar.service.multicast.RemoteMulticastMember
 
_id - Variable in class solar.service.multicast.comm.ReceiveRequest
 
_id - Variable in class solar.service.directory.RemoteDirectoryListener
 
_id - Variable in class solar.service.directory.comm.NameMigratedRequest
 
_id - Variable in class solar.service.directory.comm.NameUpdatedRequest
 
_id - Variable in class solar.service.directory.comm.NameRemovedRequest
 
_id - Variable in class solar.service.directory.comm.NameAddedRequest
 
_idtable - Variable in class solar.service.pack.ScribeManager
 
_in - Variable in class solar.service.transport.TcpConnection
 
_in - Variable in class versus.VersusSource
 
_in - Variable in class versus.meeting.RLMeetingAgent
 
_in - Variable in class campus.LogTracer
 
_inbufman - Variable in class solar.service.pack.proto.BaseProtocol
 
_inetAddress - Variable in class solar.service.transport.SocketAddress
 
_info - Variable in class campus.AccessPoint
 
_inited - Variable in class solar.service.BaseService
 
_inport - Variable in class solar.service.dan.lang.PipeSpec
 
_inport - Variable in class solar.service.fap.LocalSinkChannel
 
_inport - Variable in class solar.service.fap.RemoteSinkChannel
 
_inports - Variable in class solar.service.dan.lang.FilterSpec
 
_inproto - Variable in class solar.service.pack.ScribePackService
 
_inproto - Variable in class solar.service.pack.ClientPackService
 
_input - Variable in class solar.service.dan.lang.PipeSpec
 
_inputs - Variable in class solar.service.dan.NodeHandler
 
_inputs - Variable in class solar.service.dan.lang.FilterSpec
 
_instance - Static variable in class solar.service.SolarServices
The single instance of this class.
_interval - Variable in class solar.service.routing.ManualRoutingService
 
_interval - Variable in class solar.service.rmtobj.SolarRemoteObjectService
 
_ipaddress - Variable in class campus.AccessPoint
 
_ipLocator - Variable in class campus.snmp.SnmpLocator
 
_key - Variable in class solar.api.Attribute
 
_label - Variable in class solar.service.directory.NameNode
 
_laddr - Variable in class solar.service.transport.UdpTransport
The local address for UDP.
_laddr - Variable in class solar.service.transport.TcpTransport
The local address for TCP.
_laddr - Variable in class solar.service.transport.PastryTransport
The local transport address for Pastry node.
_laddr - Variable in class solar.service.dan.DanClientService
 
_laddr - Variable in class solar.service.dan.PipeConnector
 
_laddr - Variable in class solar.service.dan.AbstractDanService
 
_laddr - Variable in class solar.service.multicast.NaiveMulticastService
 
_laddr - Variable in class solar.service.directory.DistDirectoryService
 
_laddr - Variable in class solar.service.directory.CentralDirectoryService
 
_laddr - Variable in class rice.pastry.socket.SocketPastryNodeFactory
 
_lastVisited - Static variable in class campus.compass.GeobytesSource
 
_learner - Variable in class versus.meeting.RLMeetingAgent
 
_limit - Variable in class solar.module.protocol.Buffer
 
_list - Variable in class solar.util.JavaUnsyncQueue
 
_list - Variable in class solar.util.JavaSyncQueue
 
_list - Variable in class solar.util.FastUnsyncQueue
 
_list - Variable in class solar.util.FastSyncQueue
 
_listener - Variable in class solar.service.pack.ScribeManager
 
_listener - Variable in class solar.service.fork.TaskBatch
 
_listener - Variable in class solar.service.pubsub.ScribeManager
 
_listener - Variable in class solar.service.directory.comm.RemoveListenerRequest
 
_listener - Variable in class solar.service.directory.comm.AddListenerRequest
 
_listeners - Variable in class solar.module.cache.BaseCache
 
_listeners - Variable in class solar.service.transport.UdpTransport
The list of transport listeners.
_listeners - Variable in class solar.service.transport.TcpTransport
The list of TCP listeners.
_listeners - Variable in class solar.service.transport.BaseTransportService
 
_listeners - Variable in class solar.service.transport.PastryTransport
The list of transport listeners.
_listeners - Variable in class solar.service.mhost.SolarMobileHostService
 
_listeners - Variable in class solar.service.directory.DistDirectoryService
 
_listeners - Variable in class solar.service.directory.FlatDirectory.NameInfo
 
_listeners - Variable in class solar.service.directory.CentralDirectoryService
 
_lnodes - Variable in class solar.service.dan.NodeManager
 
_local - Variable in class solar.service.rmtobj.SolarRemoteObjectService
 
_local - Variable in class solar.service.directory.CentralDirectoryService
 
_locator - Variable in class campus.snmp.SnmpLocator.SnmpTask
 
_locfile - Static variable in class campus.compass.CompassService
 
_lock - Variable in class campus.snmp.SnmpLocator
 
_lock - Variable in class rice.pastry.socket.SocketNodeHandle
 
_loctable - Static variable in class campus.compass.CompassService
 
_log - Static variable in class solar.Client
 
_log - Static variable in class solar.Planet
 
_log - Static variable in class solar.service.BaseServiceManager
Logging facility.
_log - Static variable in class solar.service.pack.ScribePackService
Logging facility.
_log - Static variable in class solar.service.pack.ClientPackService
Logging facility.
_log - Static variable in class solar.service.pack.proto.BaseProtocol
 
_log - Static variable in class solar.service.pack.client.PackClient
 
_log - Static variable in class solar.service.transport.UdpTransport
Logging facility.
_log - Static variable in class solar.service.transport.TcpTransport
Logging facility.
_log - Variable in class solar.service.transport.BaseTransportService
The logger for Pastry transport service.
_log - Static variable in class solar.service.transport.PastryTransport
Logging facility.
_log - Variable in class solar.service.routing.ManualRoutingService
 
_log - Static variable in class solar.service.dispatch.SolarDispatchService
Logging facility.
_log - Variable in class solar.service.rmtobj.SolarRemoteObjectService
 
_log - Variable in class solar.service.dan.RelayOperator
 
_log - Static variable in class solar.service.fork.SolarForkService
 
_log - Static variable in class solar.service.fork.TaskBatch
 
_log - Static variable in class solar.service.fork.client.ForkClient
 
_log - Static variable in class solar.service.pubsub.ScribePubSubService
Logging facility.
_log - Static variable in class solar.service.pubsub.ClientPubSubService
Logging facility.
_log - Static variable in class solar.service.pubsub.client.PubSubClient
 
_log - Static variable in class solar.service.mhost.SolarMobileHostService
Logging facility.
_log - Static variable in class solar.service.rpc.SolarRpcService
Logging facility.
_log - Variable in class solar.service.multicast.NaiveMulticastService
The logger for this multicast service.
_log - Variable in class solar.service.multicast.RemoteMulticastMember
 
_log - Variable in class solar.service.fap.SolarFapService
 
_log - Variable in class solar.service.fap.FapClientService
 
_log - Variable in class solar.service.directory.DistDirectoryService
The logger for distributed directory service.
_log - Variable in class solar.service.directory.RemoteDirectoryListener
 
_log - Variable in class solar.service.directory.CentralDirectoryService
The logging facility.
_log - Static variable in class solar.test.GroundHog
 
_log - Static variable in class versus.meeting.MeetingApp
 
_log - Static variable in class campus.sysnort.SysnortSensor
 
_log - Static variable in class campus.sysnort.SysnortApp
 
_log - Static variable in class campus.compass.CompassService
 
_log - Variable in class org.doit.muffin.filter.Logger
 
_logger - Variable in class org.doit.muffin.filter.LoggerFilter
 
_mac - Variable in class campus.sysnort.trigger.FlickerTrigger.ClientState
 
_macaddress - Variable in class campus.AccessPoint
 
_macLocator - Variable in class campus.snmp.SnmpLocator
 
_maddr - Static variable in class solar.service.transport.PastryTransport
Local address, multiplexing over same Pastry node.
_makefile - Variable in class campus.sysnort.trigger.HotspotTrigger
 
_manager - Variable in class solar.service.BaseService
 
_manager - Variable in class solar.service.dispatch.SolarDispatchService
Service manager.
_manager - Variable in class solar.service.rpc.SolarRpcService
The service manager.
_map - Static variable in class campus.compass.CompassService
 
_mappath - Variable in class campus.CampusMap
 
_mappath - Variable in class campus.compass.CompassService
 
_mapping - Variable in class solar.service.BaseServiceManager
Mapping of service names to class names.
_mapping - Static variable in class campus.compass.GeobytesSource
 
_mapping - Static variable in class campus.compass.WhoisSource
 
_maxSteps - Variable in class versus.meeting.RLMeetingAgent
 
_mclientName - Variable in class solar.service.mhost.SolarMobileHostService
 
_mcmember - Variable in class solar.service.multicast.ScribeMulticastService.ScribeMember
 
_md - Variable in class org.doit.muffin.filter.Logger
 
_meetingStarted - Variable in class versus.meeting.MeetingDetector
 
_members - Variable in class solar.service.multicast.ScribeMulticastService
 
_members - Variable in class solar.service.multicast.MulticastGroup
 
_members - Variable in class solar.service.multicast.NaiveMulticastService
 
_memoryLimit - Variable in class solar.service.pack.proto.BaseProtocol.ProtocolState
 
_mhost - Variable in class solar.service.pack.ClientPackService
 
_model - Variable in class campus.AccessPoint
 
_month - Variable in class campus.syslog.SyslogParser
 
_movingChairs - Variable in class versus.meeting.MeetingDetector
 
_msg - Variable in class solar.impl.ByteArrayAdu
 
_msg - Variable in class solar.impl.StringAdu
 
_msgtype - Variable in class campus.syslog.SyslogParser
 
_multiplex - Variable in class solar.service.transport.Header
 
_name - Variable in class solar.service.BaseService
 
_name - Variable in class solar.service.pack.lang.FilterConfig
 
_name - Variable in class solar.service.dan.Monitor
 
_name - Variable in class solar.service.dan.comm.AdvertiseRequest
 
_name - Variable in class solar.service.dan.lang.FilterSpec
 
_name - Variable in class solar.service.dan.lang.PipeSpec
 
_name - Variable in class solar.service.fap.Port
 
_name - Variable in class solar.service.directory.Advertisement
 
_name - Variable in class solar.service.directory.comm.NameMigratedRequest
 
_name - Variable in class solar.service.directory.comm.NameRemovedRequest
 
_name - Variable in class solar.service.directory.comm.NameAddedRequest
 
_name - Variable in class solar.service.directory.comm.UnadvertiseRequest
 
_name - Variable in class solar.service.directory.comm.AdvertiseRequest
 
_name - Variable in class versus.VersusFilter
 
_name - Variable in class campus.AccessPoint
 
_name - Variable in class campus.Building
 
_name - Variable in class campus.sysnort.Trigger
 
_name - Variable in class campus.sysnort.TriggerConfig
 
_nearby - Variable in class solar.service.routing.ManualRoutingService
 
_needparse - Static variable in class campus.compass.CompassService
 
_newname - Variable in class solar.service.directory.comm.NameUpdatedRequest
 
_newname - Variable in class solar.service.directory.comm.UpdateRequest
 
_newrec - Variable in class solar.service.directory.comm.UpdateRequest
 
_newrecord - Variable in class solar.service.directory.comm.NameMigratedRequest
 
_newrecord - Variable in class solar.service.directory.comm.NameUpdatedRequest
 
_nextId - Static variable in class solar.util.StringUtil
 
_nidFactory - Variable in class rice.pastry.wire.UdpPastryNodeFactory
 
_nidFactory - Variable in class rice.pastry.wire.TcpPastryNodeFactory
 
_nidFactory - Variable in class rice.pastry.socket.SocketPastryNodeFactory
 
_nodeId - Variable in class solar.service.transport.PastryAddress
 
_nodeman - Variable in class solar.service.dan.DanClientService
 
_nodeman - Variable in class solar.service.dan.Monitor
 
_nodeman - Variable in class solar.service.dan.PipeConnector
 
_nodeman - Variable in class solar.service.dan.AbstractDanService
 
_nodeman - Variable in class solar.service.dan.GraphManager
The node manager holding the table (node_guid, NodeHandler).
_nodes - Variable in class solar.service.dan.GraphManager
The table of (node_guid, current_address).
_note - Variable in class campus.syslog.SyslogParser
 
_nshost - Variable in class campus.syslog.SyslogParser
 
_nullobj - Static variable in class solar.service.rpc.Block
 
_numClients - Variable in class campus.snmp.ApStat
 
_numMoving - Variable in class versus.meeting.RLMeetingWorld
 
_obj - Variable in class solar.impl.SerializedAdu
 
_obj - Variable in class solar.module.cache.CachedObject
The actual cached object.
_object - Variable in class solar.service.dan.Monitor
 
_object - Variable in class solar.service.directory.NameRecord
 
_objin - Variable in class solar.service.transport.TcpConnection
 
_objout - Variable in class solar.service.transport.TcpConnection
 
_observer - Variable in class campus.LogTracer
 
_oldname - Variable in class solar.service.directory.comm.NameUpdatedRequest
 
_oldname - Variable in class solar.service.directory.comm.UpdateRequest
 
_oldrec - Variable in class solar.service.directory.comm.UpdateRequest
 
_oldrecord - Variable in class solar.service.directory.comm.NameMigratedRequest
 
_oldrecord - Variable in class solar.service.directory.comm.NameUpdatedRequest
 
_optable - Variable in class solar.service.dan.GraphManager
The table of (op_name, node_guid).
_opts - Variable in class solar.test.GroundHog
 
_opts - Variable in class campus.sysnort.SysnortSensor
 
_opts - Variable in class campus.sysnort.SysnortApp
 
_out - Variable in class solar.service.transport.TcpConnection
 
_outbufman - Variable in class solar.service.pack.proto.BaseProtocol
 
_outport - Variable in class solar.service.dan.lang.PipeSpec
 
_outport - Variable in class solar.service.fap.LocalSourceChannel
 
_outport - Variable in class solar.service.fap.RemoteSourceChannel
 
_outports - Variable in class solar.service.dan.lang.FilterSpec
 
_outproto - Variable in class solar.service.pack.ScribePackService
 
_outproto - Variable in class solar.service.pack.ClientPackService
 
_output - Variable in class solar.service.dan.lang.PipeSpec
 
_outputPath - Variable in class campus.snmp.SnmpSource
 
_outputs - Variable in class solar.service.dan.NodeHandler
 
_outputs - Variable in class solar.service.dan.lang.FilterSpec
 
_pack - Variable in class solar.service.pack.client.PackClient
 
_pack - Variable in class campus.sysnort.SysnortSensor
 
_packer - Variable in class solar.service.pack.proto.SingleBufferHandle
 
_packName - Variable in class solar.service.pack.ScribePackService
 
_packName - Variable in class solar.service.pack.ClientPackService
 
_param - Variable in class solar.service.fork.TaskBatch.RepeatParam
 
_param - Variable in class solar.service.fork.TaskBatch
 
_parameters - Variable in class solar.service.fork.Task
 
_parent - Variable in class solar.service.directory.NameNode
 
_parser - Variable in class solar.service.dan.AbstractDanService
 
_parser - Variable in class campus.sysnort.SysnortApp
 
_parser - Static variable in class campus.compass.CompassService
 
_pastry - Variable in class solar.service.multicast.ScribeMulticastService
 
_pattern - Variable in class solar.service.directory.comm.RemoveListenerRequest
 
_pattern - Variable in class solar.service.directory.comm.AddListenerRequest
 
_pattern - Variable in class solar.service.directory.comm.LookupRequest
 
_pc - Variable in class solar.service.dan.DanClientService
 
_pc - Variable in class solar.service.dan.AbstractDanService
 
_peer - Variable in class solar.service.transport.TcpConnection
The peer address.
_peer - Variable in class solar.service.routing.ManualRoutingService
 
_percent - Variable in class solar.service.pack.filter.RANDOM
 
_pid - Variable in class solar.service.dan.comm.PipeConnectRequest
 
_pid - Variable in class solar.service.fap.RemoteSinkChannel
 
_pid - Variable in class solar.service.fap.RemoteSourceChannel
 
_pid - Variable in class solar.service.fap.Pipe
 
_pid - Variable in class solar.service.fap.comm.PipePullRequest
 
_pipe - Variable in class solar.service.dan.lang.XmlSpecParser
 
_pipeNum - Variable in class solar.service.dan.lang.XmlSpecParser
 
_pipes - Variable in class solar.service.fap.FapClientService
 
_planet - Variable in class solar.service.dan.DanClientService
 
_plock - Variable in class solar.service.pack.proto.GroupBufferHandle
 
_plotpath - Variable in class campus.sysnort.trigger.HotspotTrigger
 
_plotRate - Variable in class campus.sysnort.trigger.HotspotTrigger
 
_pname - Variable in class solar.service.dan.Monitor
 
_pnode - Variable in class solar.service.transport.PastryTransport
The pastry node associated with this application.
_policy - Variable in class solar.service.pack.proto.GroupBufferHandle
 
_policy - Variable in class solar.service.pack.proto.SingleBufferHandle
 
_policy - Variable in class solar.service.pack.comm.SubscribeRequest
 
_policy - Variable in class solar.service.pack.lang.XmlPolicyParser
 
_policy - Variable in class versus.meeting.RLMeetingAgent
 
_polled - Variable in class campus.snmp.SnmpLocator
 
_pool - Variable in class campus.snmp.SnmpLocator
 
_pool - Variable in class rice.pastry.socket.SocketPastryNode
 
_port - Variable in class solar.service.transport.UdpTransport
The listening server port.
_port - Variable in class solar.service.transport.TcpTransport
The listening server port.
_port - Variable in class solar.service.transport.PastryTransportService
 
_port - Variable in class solar.service.transport.SocketAddress
 
_port - Variable in class rice.pastry.wire.UdpPastryNodeFactory
 
_port - Variable in class rice.pastry.wire.TcpPastryNodeFactory
 
_port - Variable in class rice.pastry.socket.SocketPastryNodeFactory
 
_power - Variable in class campus.AccessPoint
 
_pquery - Variable in class solar.service.dan.Monitor
 
_prefix - Static variable in class solar.util.StringUtil
 
_privateBuffers - Variable in class solar.service.pack.proto.GroupBufferHandle
 
_process - Variable in class solar.service.fork.SolarForkService
 
_process - Variable in class campus.sysnort.trigger.HotspotTrigger
 
_protocol - Variable in class solar.service.pack.ScribePackService.Forwarder
 
_protocol - Variable in class solar.service.transport.PastryTransportService
 
_protocol - Variable in class rice.pastry.socket.SocketPastryNodeFactory
 
_protocol - Variable in class rice.pastry.socket.SocketNodeHandle
 
_ptime - Variable in class campus.sysnort.trigger.FlickerTrigger.ClientState
 
_pubid - Variable in class solar.service.pack.comm.SubscribeRequest
 
_pubid - Variable in class solar.service.pack.comm.AttachPublisherRequest
 
_pubid - Variable in class solar.service.pack.comm.AttachSubscriberRequest
 
_pubid - Variable in class solar.service.pack.comm.DetachPublisherRequest
 
_pubid - Variable in class solar.service.pack.comm.DetachSubscriberRequest
 
_pubid - Variable in class solar.service.pubsub.comm.PubRegisterRequest
 
_pubid - Variable in class solar.service.pubsub.comm.SubRegisterRequest
 
_pubId - Variable in class solar.service.pack.proto.GroupBufferHandle
 
_pubId - Variable in class solar.service.pack.proto.SingleBufferHandle
 
_pubId - Variable in class solar.service.pack.proto.BufferedEvent
 
_pubId - Variable in class solar.service.pubsub.comm.SubscribeRequest
 
_pubId - Variable in class solar.test.PackSender
 
_pubrootproto - Variable in class solar.service.pack.ScribePackService
 
_pubsub - Variable in class solar.service.pubsub.client.PubSubClient
 
_pubsubName - Variable in class solar.service.pubsub.ScribePubSubService
 
_pubsubName - Variable in class solar.service.pubsub.ClientPubSubService
 
_pullOnly - Variable in class solar.service.dan.NodeHandler
 
_pushOnly - Variable in class solar.service.dan.NodeHandler
 
_query - Variable in class solar.service.dan.Monitor
 
_query - Variable in class solar.service.dan.comm.LookupRequest
 
_query - Variable in class solar.service.dan.lang.PipeSpec
 
_query - Variable in class solar.service.fap.comm.PipePullRequest
 
_queue - Variable in class solar.service.dispatch.SolarDispatchService
Inbound event queue.
_ran - Variable in class solar.test.MutateOperator
 
_random - Variable in class solar.test.ScribeSender
 
_random - Variable in class campus.snmp.SnmpLocator
 
_receiver - Variable in class solar.service.transport.UdpTransport
The receiver thread receiving new messages.
_receiver - Variable in class solar.service.transport.TcpConnection
The thread receiving messages from this connection.
_record - Variable in class solar.service.directory.Advertisement
 
_record - Variable in class solar.service.directory.comm.NameRemovedRequest
 
_record - Variable in class solar.service.directory.comm.NameAddedRequest
 
_record - Variable in class solar.service.directory.comm.UnadvertiseRequest
 
_record - Variable in class solar.service.directory.comm.AdvertiseRequest
 
_records - Variable in class solar.service.directory.FlatDirectory.NameInfo
 
_records - Variable in class solar.service.directory.NameNode
 
_region - Static variable in class campus.compass.ZipCodeSource
 
_registered - Variable in class solar.service.rmtobj.SolarRemoteObjectService
 
_remote - Variable in class solar.service.routing.ManualRoutingService
 
_remote - Variable in class solar.service.rmtobj.SolarRemoteObjectService
 
_repeat - Variable in class solar.service.fork.TaskBatch
 
_reported - Variable in class campus.sysnort.trigger.FlickerTrigger
 
_request - Variable in class org.doit.muffin.filter.LoggerFilter
 
_requestTime - Variable in class org.doit.muffin.filter.LoggerFilter
 
_response - Variable in class rice.pastry.socket.SocketPastryNodeFactory
 
_rmm - Variable in class solar.service.multicast.comm.LeaveRequest
 
_rmm - Variable in class solar.service.multicast.comm.JoinRequest
 
_rmtobjName - Variable in class solar.service.rmtobj.SolarRemoteObjectService
 
_rnodes - Variable in class solar.service.dan.NodeManager
 
_room - Variable in class versus.meeting.MeetingDetector
 
_root - Variable in class solar.service.dan.comm.SubscribeRequest
 
_root - Variable in class solar.service.directory.TreeDirectory
 
_roottasks - Variable in class solar.service.pack.ScribePackService
 
_routing - Variable in class solar.service.transport.BaseTransportService
The routing service has the routing/forwarding table.
_routingName - Variable in class solar.service.routing.ManualRoutingService
 
_rpc - Variable in class solar.service.pack.ClientPackService
 
_rpc - Variable in class solar.service.rmtobj.SolarRemoteObjectService
 
_rpc - Variable in class solar.service.dan.DanClientService
 
_rpc - Variable in class solar.service.dan.PipeConnector
 
_rpc - Variable in class solar.service.fork.SolarForkService
 
_rpc - Variable in class solar.service.pubsub.ClientPubSubService
 
_rpc - Variable in class solar.service.mhost.SolarMobileHostService
 
_rpc - Variable in class solar.service.multicast.NaiveMulticastService
 
_rpc - Variable in class solar.service.multicast.RemoteMulticastMember
 
_rpc - Variable in class solar.service.fap.DirectPipe
 
_rpc - Variable in class solar.service.fap.FapClientService
 
_rpc - Variable in class solar.service.directory.DistDirectoryService
 
_rpc - Variable in class solar.service.directory.RemoteDirectoryListener
 
_rpc - Variable in class solar.service.directory.CentralDirectoryService
 
_rpcAck - Static variable in class solar.service.rpc.SolarRpcService
The reusable RPC acknowledge object.
_rpcName - Variable in class solar.service.rpc.SolarRpcService
The name of this RPC service.
_rtable - Variable in class solar.service.routing.DirectRoutingService
 
_runner - Variable in class solar.service.dan.NodeHandler
 
_scount - Variable in class solar.test.PackReceiver.Profiler
 
_scribe - Variable in class solar.service.pack.ScribeManager
 
_scribe - Variable in class solar.service.pubsub.ScribeManager
 
_scribe - Variable in class solar.service.multicast.ScribeMulticastService
 
_scribeman - Variable in class solar.service.pack.ScribePackService
 
_scribeman - Variable in class solar.service.pubsub.ScribePubSubService
 
_scribeProxies - Variable in class solar.service.pack.ScribePackService
 
_scribeRoots - Variable in class solar.service.pack.ScribePackService
 
_script - Variable in class campus.snmp.SnmpLocator
 
_scriptPath - Variable in class campus.snmp.SnmpSource
 
_serialize - Variable in class solar.service.transport.TcpConnection
 
_serialize - Variable in class solar.service.transport.PastryTransportService
 
_serialize - Variable in class rice.pastry.socket.SocketPastryNodeFactory
 
_server - Variable in class solar.service.pack.ClientPackService
 
_server - Variable in class solar.service.transport.TcpTransport
The server thread accepting new connection.
_server - Variable in class solar.service.pubsub.ClientPubSubService
 
_server - Variable in class solar.service.mhost.SolarMobileHostService
 
_server - Variable in class solar.service.mhost.comm.DetachRequest
 
_server - Variable in class solar.service.mhost.comm.AttachRequest
 
_server - Variable in class solar.service.directory.CentralDirectoryService
 
_service - Variable in class solar.service.dispatch.DispatchUnit
 
_serviceObjects - Variable in class solar.service.BaseServiceManager
A repository of application-specific service objects.
_services - Variable in class solar.service.BaseServiceManager
A repository of service instances.
_servman - Variable in class solar.service.pack.client.PackClient
 
_servman - Variable in class solar.service.fork.client.ForkClient
 
_session - Variable in class solar.service.pack.EndPointManager.EP
 
_session - Variable in class solar.service.pubsub.EndPointManager.EP
 
_sguid - Variable in class solar.service.dan.comm.PipeConnectRequest
 
_sharedBuffer - Variable in class solar.service.pack.proto.GroupBufferHandle
 
_sink - Variable in class solar.service.fap.LocalSinkChannel
 
_sink - Variable in class solar.service.fap.Pipe
 
_size - Variable in class solar.util.JavaUnsyncQueue
 
_size - Variable in class solar.util.JavaSyncQueue
 
_size - Variable in class solar.util.FastUnsyncQueue
 
_size - Variable in class solar.util.FastSyncQueue
 
_size - Variable in class solar.module.cache.BaseCache
 
_size - Variable in class solar.service.pack.proto.GroupBufferHandle
 
_size - Variable in class solar.service.pack.proto.BaseProtocol.ProtocolState
 
_sleep - Variable in class solar.test.ClockSource
 
_smtp - Variable in class campus.sysnort.trigger.FlickerTrigger
 
_smtp - Variable in class campus.sysnort.trigger.MissingCardTrigger
 
_sname - Variable in class solar.service.multicast.RemoteMulticastMember
 
_sname - Variable in class solar.service.directory.RemoteDirectoryListener
 
_snmploc - Static variable in class campus.compass.CompassService
 
_snmpscript - Variable in class campus.compass.CompassService
 
_sock - Variable in class solar.service.transport.TcpConnection
The local socket for the connection.
_source - Variable in class solar.api.Request
 
_source - Variable in class solar.service.dispatch.DispatchUnit
 
_source - Variable in class solar.service.rpc.SolarRpcService.RpcWorker
 
_source - Variable in class solar.service.fap.LocalSourceChannel
 
_source - Variable in class solar.service.fap.Pipe
 
_src - Variable in class solar.service.transport.Header
 
_src - Variable in class solar.service.fork.Task
 
_ssock - Variable in class solar.service.transport.UdpTransport
The socket to listen to.
_ssock - Variable in class solar.service.transport.TcpTransport
The listening server socket.
_stale - Variable in class solar.module.cache.CachedObject
Is this object stale/expired?
_standalone - Variable in class versus.VersusSource
 
_standalone - Variable in class campus.syslog.SyslogSource
 
_start - Variable in class solar.service.fork.Task
 
_start - Variable in class solar.service.fork.TaskBatch.RepeatParam
 
_started - Variable in class versus.meeting.MeetingDetector
 
_state - Variable in class solar.service.pack.proto.DropTailIBM
 
_state - Variable in class solar.service.pack.proto.FairQueueOBM
 
_state - Variable in class solar.service.pack.proto.PackTailIBM
 
_state - Variable in class solar.service.pack.proto.BaseProtocol
 
_state - Variable in class versus.VersusTracker
 
_state - Variable in class versus.meeting.RLMeetingWorld
 
_state - Variable in class campus.Location
 
_state - Variable in class campus.sysnort.trigger.FlickerTrigger
 
_state - Static variable in class campus.compass.ZipCodeSource
 
_status - Variable in class versus.meeting.MeetingDetector
 
_steps - Variable in class versus.meeting.RLMeetingAgent
 
_street - Variable in class campus.Location
 
_string - Variable in class solar.service.transport.SocketAddress
 
_subevt - Variable in class solar.service.pack.ScribePackService.SubscribeTask
 
_subid - Variable in class solar.service.pack.comm.SubscribeRequest
 
_subId - Variable in class solar.service.pack.ScribePackService.SubscribeTask
 
_subId - Variable in class solar.service.pack.proto.SingleBufferHandle
 
_subId - Variable in class solar.service.pack.proto.BufferedEvent
 
_subId - Variable in class solar.service.pubsub.comm.SubscribeRequest
 
_subkey - Variable in class solar.service.pack.proto.GroupBufferHandle
 
_subkey - Variable in class solar.service.pack.proto.SingleBufferHandle
 
_submap - Variable in class solar.service.pubsub.ScribePubSubService
 
_subrootproto - Variable in class solar.service.pack.ScribePackService
 
_subtasks - Variable in class solar.service.pack.ScribePackService
 
_summary - Variable in class solar.test.PackReceiver.Profiler
 
_suspended - Variable in class solar.service.pack.proto.GroupBufferHandle
 
_suspended - Variable in class solar.service.pack.proto.SingleBufferHandle
 
_suspendLimit - Variable in class solar.service.pack.proto.GroupBufferHandle
 
_suspendLimit - Variable in class solar.service.pack.proto.SingleBufferHandle
 
_suspendLimit - Variable in class solar.service.pack.proto.BaseProtocol.ProtocolState
 
_sysloghost - Variable in class campus.compass.CompassService
 
_syslogport - Variable in class campus.compass.CompassService
 
_task - Variable in class solar.service.fork.SolarForkService.KillTask
 
_task - Variable in class solar.service.fork.SolarForkService.StartTask
 
_task - Variable in class solar.service.fork.comm.StartTaskRequest
 
_taskId - Variable in class solar.service.fork.Task
 
_tasks - Variable in class solar.service.fork.TaskBatch
 
_tcount - Variable in class solar.test.PackReceiver.Profiler
 
_threshold - Variable in class solar.service.pack.filter.GE
 
_time - Variable in class campus.syslog.SyslogParser
 
_timeMoving - Variable in class versus.meeting.RLMeetingWorld
 
_timer - Variable in class solar.service.pack.ScribePackService
 
_timer - Variable in class solar.service.routing.ManualRoutingService
 
_timer - Variable in class solar.service.rmtobj.SolarRemoteObjectService
 
_timer - Variable in class solar.service.fork.SolarForkService
 
_timestamp - Variable in class campus.syslog.SyslogParser
 
_timestamp - Variable in class campus.snmp.SnmpLocator.SnmpTask
 
_tlatency - Variable in class solar.test.PackReceiver.Profiler
 
_tracer - Variable in class campus.sysnort.SysnortSensor
 
_transport - Variable in class solar.service.transport.TcpConnection
 
_transport - Variable in class solar.service.transport.BaseTransportService
The actual transport layer.
_transport - Variable in class solar.service.dispatch.SolarDispatchService.NetListener
 
_transport - Variable in class solar.service.dispatch.DispatchUnit
 
_transport - Variable in class solar.service.dan.DanClientService
 
_transport - Variable in class solar.service.multicast.NaiveMulticastService
 
_transport - Variable in class solar.service.fap.FapClientService
 
_transport - Variable in class solar.service.directory.DistDirectoryService
 
_transport - Variable in class solar.service.directory.CentralDirectoryService
 
_transport - Variable in class solar.test.GroundHog
 
_transport - Variable in class rice.pastry.socket.SocketPastryNodeFactory
 
_transport - Variable in class rice.pastry.socket.SocketPastryNode
 
_transportAddress - Variable in class solar.service.pack.ClientPackService
 
_transportAddress - Variable in class solar.service.routing.ManualRoutingService
 
_transportAddress - Variable in class solar.service.rmtobj.SolarRemoteObjectService
 
_transportAddress - Variable in class solar.service.fork.SolarForkService
 
_transportAddress - Variable in class solar.service.pubsub.ClientPubSubService
 
_transportAddress - Variable in class solar.service.mhost.SolarMobileHostService
 
_transportName - Variable in class solar.service.pack.ClientPackService
 
_transportName - Variable in class solar.service.routing.ManualRoutingService
 
_transportName - Variable in class solar.service.rmtobj.SolarRemoteObjectService
 
_transportName - Variable in class solar.service.fork.SolarForkService
 
_transportName - Variable in class solar.service.pubsub.ClientPubSubService
 
_transportName - Variable in class solar.service.mhost.SolarMobileHostService
 
_transportName - Variable in class solar.service.rpc.SolarRpcService
The name of transport service used.
_transportName - Variable in class solar.service.fap.DirectPipe
 
_transports - Variable in class solar.service.dispatch.SolarDispatchService
A table of transport services.
_trigger - Variable in class campus.sysnort.TriggerHandler
 
_trigger - Variable in class campus.sysnort.XmlConfigParser
 
_triggers - Variable in class campus.sysnort.SysnortApp
 
_tstamp - Variable in class campus.LogTracer
 
_ttl - Variable in class solar.module.cache.BaseCache
 
_type - Variable in class solar.service.dan.comm.PipeConnectRequest
 
_type - Variable in class solar.service.dan.lang.PipeSpec
 
_type - Variable in class solar.service.fap.Pipe
 
_unigen - Variable in class solar.service.pack.proto.FairQueueOBM
 
_unigen - Variable in class solar.service.pack.proto.GroupBufferHandle
 
_unigen - Static variable in class solar.service.pack.filter.RANDOM
 
_unigen - Variable in class solar.test.GroundHog
 
_unigen - Variable in class solar.test.PackSender
 
_uptime - Variable in class campus.snmp.ApStat
 
_url - Variable in class campus.Building
 
_value - Variable in class solar.api.Attribute
 
_waiting - Variable in class campus.snmp.SnmpLocator
 
_warmFilter - Variable in class solar.service.pack.PackPolicy
 
_working - Variable in class campus.snmp.SnmpLocator
 
_world - Variable in class versus.meeting.RLMeetingAgent
 
_x - Variable in class campus.AccessPoint
 
_y - Variable in class campus.AccessPoint
 
_year - Variable in class campus.syslog.SyslogParser
 
_z - Variable in class campus.AccessPoint
 
_zipcode - Variable in class campus.Location
 
_zipcode - Static variable in class campus.compass.ZipCodeSource
 

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