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

A

ALLOW_DENY - Static variable in class org.edg.info.SiteFilter
Constant representing allow-then-deny evaluation order
AliasedName - class org.edg.info.sqlutil.parsql.AliasedName.
A name/alias association
Names can have two forms: FORM_TABLE for table names ([schema.]table) FORM_COLUMN for column names ([[schema.]table.]column)
AliasedName() - Constructor for class org.edg.info.sqlutil.parsql.AliasedName
Creates a new AliasedName object.
AliasedName(String, int) - Constructor for class org.edg.info.sqlutil.parsql.AliasedName
Create a new AliasedName given it's full name.
ArchiverInstance - class org.edg.info.ArchiverInstance.
Class is used to provide an Archiving service.
ArchiverInstance(int, int, URL, long, URL, ProducerProperties) - Constructor for class org.edg.info.ArchiverInstance
Creates a new ArchiverInstance using a defined Insertable Object to archive tuples.
ArchiverInstance.ArchiverThread - class org.edg.info.ArchiverInstance.ArchiverThread.
Gets tuples from the Consumer and inserts them into the Insertable.
abort(String, int) - Method in class org.edg.info.CleanableInstance
Aborts the one-time query belonging to the specified consumer.
abort() - Method in class org.edg.info.ConsumerInstance
Aborts the query.
abort(ResourceEndpoint) - Method in class org.edg.info.OnDemandProducerInstance
Aborts streaming to the specified consumer.
add(int, InstanceBase) - Method in class org.edg.info.InstanceTracker
Adds a new InstanceBase to the tracker.
add(InstanceBase) - Method in class org.edg.info.RetentionPeriodTracker
Registers a FSPI to this tracker.
add(ConsumerInstance, long, int) - Method in class org.edg.info.TimeoutThread
 
addColumns(Vector) - Method in class org.edg.info.sqlutil.parsql.InsertStatement
Specifies column names.
addConnection(ServletConnection) - Method in class org.edg.info.StreamingServer
Adds a producer connection.
addFrom(Vector) - Method in class org.edg.info.sqlutil.parsql.SelectStatement
Insert the FROM part of the statement
addGroupBy(GroupBy) - Method in class org.edg.info.sqlutil.parsql.SelectStatement
Insert a GROUP BY...HAVING clause
addOperand(ExpSelConst) - Method in class org.edg.info.sqlutil.parsql.Expression
Add an operand to the current expression.
addOrderBy(Vector) - Method in class org.edg.info.sqlutil.parsql.SelectStatement
Insert an ORDER BY clause
addProducer(ServletConnection) - Method in class org.edg.info.ContinuousConsumerInstance
Adds the Producer URL to the Consumer List and starts executing it necessary.
addReplica(Replica) - Method in class org.edg.info.RegistryInstance
Delegates the replica update to the ReplicaManager.
addResultSets(StringBuffer) - Method in class org.edg.info.QueueManager
Pushes ResultSet objects in resultSets string onto this QueueManager.
addSelect(Vector) - Method in class org.edg.info.sqlutil.parsql.SelectStatement
Insert the SELECT part of the statement
addSet(Expression) - Method in class org.edg.info.sqlutil.parsql.SelectStatement
Insert a SET clause (generally UNION, INTERSECT or MINUS)
addSet(Hashtable) - Method in class org.edg.info.sqlutil.parsql.UpdateStatement
Insert a SET clause in the UPDATE statement
addTables(Vector) - Method in class org.edg.info.sqlutil.parsql.LockTableStatement
Adds a list of table names.
addValueSpec(ExpSelConst) - Method in class org.edg.info.sqlutil.parsql.InsertStatement
Specify the VALUES part or SQL sub-query of the INSERT statement
addWhere(ExpSelConst) - Method in class org.edg.info.sqlutil.parsql.DeleteStatement
Add a WHERE clause to the DELETE statement.
addWhere(ExpSelConst) - Method in class org.edg.info.sqlutil.parsql.SelectStatement
Insert a WHERE clause
addWhere(ExpSelConst) - Method in class org.edg.info.sqlutil.parsql.UpdateStatement
Insert a WHERE clause in the UPDATE statement

B

BUFFER_FULL_RETRY_PERIOD - Static variable in class org.edg.info.ArchiverInstance.ArchiverThread
Defines the sleep interval when no more tuples can be inserted into the producer (due to a full buffer) defined in ms.
build(Object) - Method in class org.edg.info.StatusBuilder
Converts the object graph into a nice XML format.
buildInfo(Hashtable) - Method in class org.edg.info.StatusBuilder
Attempts to build a pretty header usefull for diagnostics/debugging.
buildTupleFromInsert(FastInsertStatement, Vector) - Static method in class org.edg.info.sqlutil.SQLUtils
Builds a tuple from an INSERT statement.

C

COLUMNNAME - Static variable in class org.edg.info.sqlutil.parsql.Constant
Type column name
COLUMN_DELIMITER - Static variable in class org.edg.info.QueueDiskCache
Character used to separate columns.
CONNECT_TIMEOUT_MS - Static variable in class org.edg.info.SocketUtils
Maximum time to wait for socket connect (in ms).
CONSUMER_RECREATE_PERIOD - Static variable in class org.edg.info.ArchiverInstance.ArchiverThread
Period between re-creating new consumer (if current one fails).
CONSUMER_TABLE - Static variable in class org.edg.info.DBConstants
The consumer table name.
CleanableInstance - class org.edg.info.CleanableInstance.
Base class for database (history and latest) producers.
CleanableInstance.CleanUpThread - class org.edg.info.CleanableInstance.CleanUpThread.
Thread used to clean up database in DBProducer
CleanableInstance.CleanUpThread(String, String, long) - Constructor for class org.edg.info.CleanableInstance.CleanUpThread
Set-up thread to clean up specified table.
ColumnDefinition - class org.edg.info.sqlutil.parsql.ColumnDefinition.
Definition of a column in an SQL CREATE TABLE statement.
ColumnDefinition() - Constructor for class org.edg.info.sqlutil.parsql.ColumnDefinition
 
Constant - class org.edg.info.sqlutil.parsql.Constant.
Constant: a representation of SQL constants
Constant(String, int) - Constructor for class org.edg.info.sqlutil.parsql.Constant
Create a new constant, given its name and type.
ConsumerConnection - class org.edg.info.ConsumerConnection.
Details of a single streaming connection to a consumer.
ConsumerConnection(SocketChannel, Expression, Vector, StreamRequest) - Constructor for class org.edg.info.ConsumerConnection
Creates a new ConsumerConnection object.
ConsumerInstance - class org.edg.info.ConsumerInstance.
The "agent" that serves the Consumer.
ContinuousConsumerInstance - class org.edg.info.ContinuousConsumerInstance.
ContinuousConsumerInstances only ever need to contact one publisher in order to answer a query.
ContinuousConsumerInstance(String, URL, int, long, int, StreamingServer, TimeoutThread, ConsumerConfig) - Constructor for class org.edg.info.ContinuousConsumerInstance
Constructs a ContinuousConsumerInstance.
CostModel - class org.edg.info.CostModel.
Determines the best publisher to contact, given a list.
CostModelForComplexQuery - class org.edg.info.CostModelForComplexQuery.
Used for figuring out which is the best publisher to contact, given a list.
CostModelForSimpleQuery - class org.edg.info.CostModelForSimpleQuery.
DOCUMENT ME!
CreateTableStatement - class org.edg.info.sqlutil.parsql.CreateTableStatement.
An SQL CREATE statement.
CreateTableStatement(String) - Constructor for class org.edg.info.sqlutil.parsql.CreateTableStatement
Create a CREATE statement on a given table
canDestroy() - Method in class org.edg.info.InsertableInstance
Determines if this insertable can be destroyed.
canDestroy() - Method in class org.edg.info.InstanceBase
Determines if this instance can be destroyed (i.e.
canPop() - Method in class org.edg.info.ConsumerInstance
Method canPop() checks if any tuples can be popped.
characters(char[], int, int) - Method in class org.edg.info.ODPXMLParser
Process characters
characters(char[], int, int) - Method in class org.edg.info.ReplicaDecoder
Method called by the sax parser when text content is found.
characters(char[], int, int) - Method in class org.edg.info.SiteFilter
Called by the sax parser whenever a text element is found.
checkConnection(SQLException) - Method in class org.edg.info.RemoteDatabase
Checks the SQL state following an exception to determine if the connection needs to be reestablished.
checkDuplicateSelectedColumn() - Method in class org.edg.info.QueryHandler
Throws an RGMAException if there are duplicate column names in the SELECT statement.
checkInsert(FastInsertStatement, SimpleDateFormat) - Method in class org.edg.info.TupleChecker
Parses the array of INSERT statements and checks that each tuple is valid with respect to the producer predicate and the table definition.
checkJoinStar() - Method in class org.edg.info.QueryHandler
Throws an RGMAException if the SELECT includes a join and selects on all columns (*).
checkQueryIsSimple() - Method in class org.edg.info.QueryHandler
Check that the query is simple
clear() - Method in class org.edg.info.Queue
Removes all tuples from the queue and reduces curentTotalMemory appropriately.
clone() - Method in class org.edg.info.Message
Makes a copy of this Message.
clone() - Method in class org.edg.info.Replica
 
clone() - Method in class org.edg.info.ReplicaRow
 
clone() - Method in class org.edg.info.ReplicaTable
 
close() - Method in class org.edg.info.ArchiverInstance.ArchiverThread
Stops the thread and closes the consumer.
close() - Method in class org.edg.info.QueueDiskCache
Closes this disk cache and removes its file.
close() - Method in class org.edg.info.QueueManager
Closes this QueueManager and its disk cache.
close() - Method in class org.edg.info.RemoteDatabase
Closes all connections to this remote database.
close() - Method in class org.edg.info.SiteFilter
Terminates the thread that reads the configFile.
close() - Method in class org.edg.info.TimeoutThread
 
closeSocketChannel(SocketChannel) - Static method in class org.edg.info.SocketUtils
Closes the given socket channel and shuts down its input and output.
closeStatement(Statement) - Static method in class org.edg.info.RemoteDatabase
Closes the given statement if it is not null.
convertListToIntArray(List) - Static method in class org.edg.info.ODPXMLParser
Converts a list of Integer objects to an int array.
convertListToStringArray(List) - Static method in class org.edg.info.ODPXMLParser
Converts a list of String objects to an int array.
convertXMLResponse(String) - Static method in class org.edg.info.ODPXMLParser
Generates a ResultSet derived from the XML string.
count() - Method in class org.edg.info.ConsumerInstance
Returns the number of stored tuples.
createSocketChannel(StreamRequest) - Static method in class org.edg.info.SocketUtils
Create a SocketChannel in blocking mode
createSocketChannel(StreamRequest, boolean) - Static method in class org.edg.info.SocketUtils
Creates a new SocketChannel to the Streaming URL and Port in the request.
createTable(String) - Method in class org.edg.info.SchemaInstance
Creates a new Producer table definition in the Schema.
createTableList(String[], boolean) - Static method in class org.edg.info.sqlutil.SQLUtils
 

D

DATE_FORMAT - Static variable in interface org.edg.info.DateTimeConstants
Date format.
DATE_TIME_FORMAT - Static variable in interface org.edg.info.DateTimeConstants
Combined date and time format.
DBConstants - class org.edg.info.DBConstants.
Holds any error codes that are thrown by the MySQL database and are significant to rgma.
DBConstants() - Constructor for class org.edg.info.DBConstants
 
DBProducerInstance - class org.edg.info.DBProducerInstance.
 
DBProducerInstance(Registry, Schema, PrimaryProducerConfig, ServletConnection, long, Storage) - Constructor for class org.edg.info.DBProducerInstance
 
DB_LOCK - Static variable in class org.edg.info.DBConstants
Semaphore used to co-ordinate updates to the Registry db.
DEFAULT_TERMINATION_INTERVAL_MS - Static variable in class org.edg.info.InstanceBase
Default termination interval in millis.
DENY_ALLOW - Static variable in class org.edg.info.SiteFilter
Constant representing deny-then-allow evaluation order
DateTimeConstants - interface org.edg.info.DateTimeConstants.
Constants related to date and time.
DeclarableInstance - class org.edg.info.DeclarableInstance.
Supports "Declarable" behaviour: declaring and registering tables.
Decoder - class org.edg.info.Decoder.
used for decoding a PublisherDescription.
DeleteStatement - class org.edg.info.sqlutil.parsql.DeleteStatement.
A representation of an SQL DELETE statement.
DeleteStatement(String) - Constructor for class org.edg.info.sqlutil.parsql.DeleteStatement
Create a DELETE statement on a given table.
DiskCacheException - exception org.edg.info.DiskCacheException.
Exception thrown by the QueueDiskCache.
DiskCacheException() - Constructor for class org.edg.info.DiskCacheException
 
DiskCacheException(String) - Constructor for class org.edg.info.DiskCacheException
 
DiskCacheException(String, Throwable) - Constructor for class org.edg.info.DiskCacheException
 
DiskCacheException(Throwable) - Constructor for class org.edg.info.DiskCacheException
 
declareAsArchiver() - Method in class org.edg.info.InsertableInstance
Sets the declareAsArchiverFlag to true
declareTable(String, String, int) - Method in class org.edg.info.ArchiverInstance
Attempts to declare the table using the Insertable Object.
declareTable(String, String, int, int) - Method in class org.edg.info.CleanableInstance
Declares table in Registry (via call to supertype) and creates table in database.
declareTable(String, String, String, long, int, int) - Method in class org.edg.info.CleanableInstance
Declares a table in this producer.
declareTable(String, String) - Method in class org.edg.info.DeclarableInstance
Declares the table in the Schema.
declareTable(String, String, int, int) - Method in class org.edg.info.InsertableInstance
Declares a table with a predicate and history/latest retention period.
decode(String) - Method in class org.edg.info.ReplicaDecoder
Attempts to decode the message into a Replica.
decodePublisherDescription(String) - Static method in class org.edg.info.Decoder
Retrieves a PublisherDescription from it's String representation.
destroy() - Method in class org.edg.info.CleanableInstance
Destroys a CleanableInstance.
destroy() - Method in class org.edg.info.ConsumerInstance
XXX-AC: note, this is called from a syncrhonized block in the instanceTracker.
destroy() - Method in class org.edg.info.ContinuousConsumerInstance
 
destroy() - Method in class org.edg.info.DeclarableInstance
 
destroy() - Method in class org.edg.info.InsertableInstance
Tidies up any open resources.
destroy() - Method in class org.edg.info.OnDemandProducerInstance
 
destroy() - Method in class org.edg.info.OneTimeConsumerInstance
 
destroy() - Method in class org.edg.info.RegistryInstance
This is called when the servlet is destroyed.
destroy() - Method in class org.edg.info.SchemaInstance
Closes the database connection.
disconnect() - Method in class org.edg.info.InstanceBase
Closes the connection between this instance and any API object.
dropTable(String) - Method in class org.edg.info.SchemaInstance
Removes table 'tableName' from the Schema Synchronized to avoid interference between drop and create Table

E

END_ONETIME_RESULT_TOKEN - Static variable in interface org.edg.info.StreamingConstants
Byte sent at the end of all results for a one-time query.
END_RESULTSET_TOKEN - Static variable in interface org.edg.info.StreamingConstants
Byte sent at the end of each ResultSet.
ERROR - Static variable in class org.edg.info.Messenger
Result code indicating that message failed and should be retried.
EXCEPTION - Static variable in interface org.edg.info.ODPXMLConstants
Object type: Exception.
ExpSelConst - interface org.edg.info.sqlutil.parsql.ExpSelConst.
A common interface for all SQL Expressions (SelectStatements, Expressions and Constants are ExpSelConst).
Expression - class org.edg.info.sqlutil.parsql.Expression.
An SQL Expression, an operator and one or more operands.
Expression(String) - Constructor for class org.edg.info.sqlutil.parsql.Expression
Create an SQL Expression given the operator
Expression(String, ExpSelConst) - Constructor for class org.edg.info.sqlutil.parsql.Expression
Create an SQL Expression given the operator and 1st operand
Expression(String, ExpSelConst, ExpSelConst) - Constructor for class org.edg.info.sqlutil.parsql.Expression
Create an SQL Expression given the operator, 1st and 2nd operands
encodeReplica(Replica) - Method in class org.edg.info.ReplicaEncoder
Encodes the Replica into XML.
endElement(String, String, String) - Method in class org.edg.info.ODPXMLParser
Process end tag.
endElement(String, String, String) - Method in class org.edg.info.ReplicaDecoder
Method called by the sax parser when an element is terminated.
endElement(String, String, String) - Method in class org.edg.info.SiteFilter
Method called by the sax parser when an element is terminated.
endHeader() - Method in class org.edg.info.StatusPrinter
DOCUMENT ME!
equals(Object) - Method in class org.edg.info.Message
 
equals(Object) - Method in class org.edg.info.Replica
 
equals(Object) - Method in class org.edg.info.ReplicaRow
 
equals(Object) - Method in class org.edg.info.ReplicaTable
 
equals(Object) - Method in class org.edg.info.StopStreamingRequest
 
equals(Object) - Method in class org.edg.info.sqlutil.parsql.ColumnDefinition
Returns true if cd represents exactly the same ColumnDefinition statement as 'this'.
equals(Object) - Method in class org.edg.info.sqlutil.parsql.CreateTableStatement
Returns true if cts represents exactly the same CREATE TABLE statement as 'this'.
equals(Object) - Method in class org.edg.info.sqlutil.rdb.Tuple
 
error(SAXParseException) - Method in class org.edg.info.ReplicaDecoder
Called when the SAX parser encounters an error.
escapeBackslash(String) - Static method in class org.edg.info.sqlutil.parsql.Constant
Replaces single backslashes with doubles in the given string.
escapeQuotes(String, char) - Static method in class org.edg.info.sqlutil.parsql.Constant
Escapes occurrences of 'quoteChar' by repeating the character.
eval(Tuple, ExpSelConst) - Method in class org.edg.info.sqlutil.rdb.SQLExpEvaluator
Evaluate a boolean expression to true or false (for example, SQL WHERE clauses are boolean expressions)
evalExpValue(Tuple, ExpSelConst) - Method in class org.edg.info.sqlutil.rdb.SQLExpEvaluator
Evaluate a numeric or string expression (example: a+1)
execute(String, String, int, String, int, long, int) - Method in class org.edg.info.CleanableInstance
Executes the specified SQL SELECT statement on this producer and sends the results to the specified consumer via streaming.
execute(String) - Method in class org.edg.info.CleanableInstance
Deprecated.  
execute(String, int) - Method in class org.edg.info.OnDemandProducerInstance
Executes an SQL SELECT query on the user code and returns a result String.
extractServletName(String) - Static method in class org.edg.info.SiteFilter
Extracts the servlet name from the URL e.g http://localhost:8080/R-GMA/RegistryServlet -> servletName = RegistryServlet.

F

FATAL - Static variable in class org.edg.info.Messenger
Result code indicating that message failed and should be removed from list.
FINISH_CONNECT_RETRY_PERIOD_MS - Static variable in class org.edg.info.SocketUtils
Period to wait between attempts to finish connection (in ms).
FINISH_WRITE_ID_RETRY_PERIOD_MS - Static variable in class org.edg.info.SocketUtils
Period to wait between attempts to "finish" writing consumer ID (in ms).
FIREWALL - Static variable in class org.edg.info.Messenger
Result code indicating that a firewall caused the message to fail, so the message and all messages to the same host should be removed from the list.
FIXED_INT_TABLE - Static variable in class org.edg.info.DBConstants
The fixedIntColumns table name.
FIXED_REAL_TABLE - Static variable in class org.edg.info.DBConstants
The fixedRealColumns table name.
FIXED_STRING_TABLE - Static variable in class org.edg.info.DBConstants
The fixedStringColumns table name.
FORM_COLUMN - Static variable in class org.edg.info.sqlutil.parsql.AliasedName
Indicates the name of a column.
FORM_TABLE - Static variable in class org.edg.info.sqlutil.parsql.AliasedName
Indicates the name of a table.
FastInsertParser - class org.edg.info.sqlutil.FastInsertParser.
Parser for SQL INSERT statements.
FastInsertStatement - class org.edg.info.sqlutil.FastInsertStatement.
Represents an SQL INSERT statement.
FastInsertStatement(String) - Constructor for class org.edg.info.sqlutil.FastInsertStatement
Creates an INSERT statement on a given table
FastStreamProducerInstance - class org.edg.info.FastStreamProducerInstance.
Performs same function as StreamProducerInstance, but uses fast SQL INSERT parsing and new faster/more stable streaming.
FastStreamProducerInstance(Registry, Schema, ServletConnection, long, PrimaryProducerConfig) - Constructor for class org.edg.info.FastStreamProducerInstance
Constructor, which sets up a registry and starts a RegistrationThread.
FixedColumn - class org.edg.info.FixedColumn.
Class FixedColumn
FixedColumn(String, String, String) - Constructor for class org.edg.info.FixedColumn
 
FromItem - class org.edg.info.sqlutil.parsql.FromItem.
An SQL FROM clause.
FromItem() - Constructor for class org.edg.info.sqlutil.parsql.FromItem
Create a new FROM clause.
FromItem(String) - Constructor for class org.edg.info.sqlutil.parsql.FromItem
Create a new FROM clause on a given table.
fatalError(SAXParseException) - Method in class org.edg.info.ReplicaDecoder
Called when the SAX parser encounters a 'serious' error.
flushQueue(String, String) - Method in class org.edg.info.ConsumerInstance
 
flushQueue(String, String) - Method in class org.edg.info.ContinuousConsumerInstance
DOCUMENT ME!
flushQueue(String, String) - Method in class org.edg.info.Messenger
 
flushQueue(String, String) - Method in class org.edg.info.OneTimeConsumerInstance
 
flushQueue(String, String) - Method in class org.edg.info.RegistryInstance
 
forceRemoveAll() - Method in class org.edg.info.InstanceTracker
Iterate through tracker and call remove(id) on all instances.

G

GroupBy - class org.edg.info.sqlutil.parsql.GroupBy.
GroupBy: an SQL GROUP BY...HAVING clause
GroupBy(Vector) - Constructor for class org.edg.info.sqlutil.parsql.GroupBy
Creates a GROUP BY given a set of Expressions
get(int) - Method in class org.edg.info.InstanceTracker
Retreives an InstanceBase from the tracker.
getAggregate() - Method in class org.edg.info.sqlutil.parsql.SelectItem
If this item is an aggregate function, return the function name.
getAlias() - Method in class org.edg.info.sqlutil.parsql.AliasedName
Returns the alias associated with the current name.
getAllSchemaTables() - Method in class org.edg.info.SchemaInstance
returns all the
getArchiverThreads() - Method in class org.edg.info.ArchiverInstance
 
getAscOrder() - Method in class org.edg.info.sqlutil.parsql.OrderBy
Get the order (ascending or descending)
getAttIndex(String) - Method in class org.edg.info.sqlutil.rdb.Tuple
Return the index of the attribute corresponding to the name
getAttName(int) - Method in class org.edg.info.sqlutil.rdb.Tuple
Return the name of the attribute corresponding to the index
getAttValue(int) - Method in class org.edg.info.sqlutil.rdb.Tuple
Return the value of the attribute corresponding to the index
getAttValue(String) - Method in class org.edg.info.sqlutil.rdb.Tuple
Return the value of the attribute whith the given name
getAttemptCount() - Method in class org.edg.info.Message
Gets the number of attempts to send.
getClientHostName() - Method in class org.edg.info.ArchiverInstance
 
getClientHostName() - Method in class org.edg.info.ConsumerInstance
 
getClientHostName() - Method in class org.edg.info.DeclarableInstance
 
getColumn() - Method in class org.edg.info.sqlutil.parsql.AliasedName
Returns the column part of the name [[schema.]table.]column
getColumnNames(String[]) - Method in class org.edg.info.SchemaInstance
Method retrieves all column names for each column ID.
getColumnNames() - Method in class org.edg.info.sqlutil.FastInsertStatement
Returns vector of column names if specified in the SQL.
getColumnNames() - Method in class org.edg.info.sqlutil.rdb.Tuple
Gets the array of column names as Strings.
getColumnType(int) - Method in class org.edg.info.SchemaInstance
returns the type of a column that has columnId
getColumnTypes(String, String[]) - Method in class org.edg.info.SchemaInstance
returns the types that correspond to a particular table's columns.
getColumnUpdate(String) - Method in class org.edg.info.sqlutil.parsql.UpdateStatement
Get the SQL expression that specifies a given column's update value.
getColumnValues() - Method in class org.edg.info.sqlutil.FastInsertStatement
Returns the vector of column values for this insert statement
getColumnValues() - Method in class org.edg.info.sqlutil.rdb.Tuple
Gets the column values as a List of Double, Integer or String objects.
getColumnValuesAsStrings() - Method in class org.edg.info.sqlutil.rdb.Tuple
Gets the column values as an array of Strings.
getColumns() - Method in class org.edg.info.sqlutil.parsql.CreateTableStatement
Returns the columns.
getColumns() - Method in class org.edg.info.sqlutil.parsql.InsertStatement
Returns vector of columns if specified in the SQL.
getCommand() - Method in class org.edg.info.Message
Gets the command to send.
getComment() - Method in class org.edg.info.sqlutil.parsql.TransactionStatement
 
getConnectAttempts() - Method in class org.edg.info.ConsumerConnection
Gets the number of connection attempts.
getConnection() - Method in class org.edg.info.RemoteDatabase
Returns a connection to this remote database, creating one if necessary.
getConnectionId() - Method in class org.edg.info.ConsumerConnection
Returns consumer connection ID
getConsumerConnection() - Method in class org.edg.info.ArchiverInstance.ArchiverThread
Returns the servlet connection object used by the consumer.
getConsumerConnections() - Method in class org.edg.info.InsertableInstance
 
getConsumerCreateTimeMillis() - Method in class org.edg.info.ArchiverInstance.ArchiverThread
 
getConsumerId() - Method in class org.edg.info.ArchiverInstance.ArchiverThread
 
getConsumerId() - Method in class org.edg.info.StopStreamingRequest
Returns consumer ID.
getConsumerURL() - Method in class org.edg.info.ArchiverInstance.ArchiverThread
 
getConsumerURL() - Method in class org.edg.info.StopStreamingRequest
Returns URL for the consumer.
getCopyOfCurrentMessageInQueue() - Method in class org.edg.info.Messenger
 
getCopyOfMessageQueue() - Method in class org.edg.info.Messenger
 
getCopyOfMessageQueueWithoutCurrent() - Method in class org.edg.info.Messenger
 
getCreateTable() - Method in class org.edg.info.TupleChecker
DOCUMENT ME!
getCreationDate() - Method in class org.edg.info.Message
Gets the creation date.
getCreationTimeMillis() - Method in class org.edg.info.InstanceBase
 
getCurrentMessageInFastQueue() - Method in class org.edg.info.ConsumerInstance
 
getCurrentMessageInFastQueue() - Method in class org.edg.info.ContinuousConsumerInstance
 
getCurrentMessageInFastQueue() - Method in class org.edg.info.RegistryInstance
 
getCurrentMessageInMediumQueue() - Method in class org.edg.info.RegistryInstance
 
getCurrentMessageInSlowQueue() - Method in class org.edg.info.ConsumerInstance
 
getCurrentMessageInSlowQueue() - Method in class org.edg.info.ContinuousConsumerInstance
 
getCurrentMessageInSlowQueue() - Method in class org.edg.info.RegistryInstance
 
getCurrentResultSetBytes() - Method in class org.edg.info.ConsumerConnection
Gets the serialized bytes for the current ResultSet.
getCurrentStopStreamingRequest() - Method in class org.edg.info.StreamingServer
Gets the current StopStreaming request being processed.
getCurrentTotalMemory() - Static method in class org.edg.info.Queue
Deprecated.  
getDestinationID() - Method in class org.edg.info.Message
Gets the ID for the destination servlet.
getDestinationURL() - Method in class org.edg.info.Message
Gets the URL of the destination servlet.
getDifferenceMessage() - Method in class org.edg.info.sqlutil.parsql.CreateTableStatement
Returns a message outlining the reason for equals() returning false.
getEstimatedSize() - Method in class org.edg.info.sqlutil.rdb.Tuple
Get an estimate for the amount of memory required to store this tuple.
getException() - Method in class org.edg.info.ODPXMLParser
Returns any exception thrown in parsing.
getExpression() - Method in class org.edg.info.sqlutil.parsql.OrderBy
Get the ORDER BY expression.
getExpression() - Method in class org.edg.info.sqlutil.parsql.SelectItem
DOCUMENT ME!
getFixedColumnData(String, int, String) - Method in class org.edg.info.RegistryInstance
Returns the column names, values and types of those columns a producer has declared as fixed.
getFrom() - Method in class org.edg.info.sqlutil.parsql.SelectStatement
Get the FROM part of the statement
getGroupBy() - Method in class org.edg.info.sqlutil.parsql.GroupBy
Gets the GROUP BY expressions
getGroupBy() - Method in class org.edg.info.sqlutil.parsql.SelectStatement
Get the GROUP BY...HAVING part of the statement
getHaving() - Method in class org.edg.info.sqlutil.parsql.GroupBy
Gets the HAVING clause.
getHistoryRetentionPeriod(String) - Method in class org.edg.info.ArchiverInstance
 
getHistoryRetentionPeriod(String) - Method in class org.edg.info.InsertableInstance
Gets the HistoryRetentionPeriod.
getHostname() - Method in class org.edg.info.OnDemandProducerInstance
 
getHrpSec() - Method in class org.edg.info.RetentionPeriods
 
getInfoForOneTimeQuery(String, int) - Method in class org.edg.info.RegistryInstance
Returns information that is needed for planning a latest/history query.
getInstance(String, long) - Static method in class org.edg.info.SiteFilter
Obtains a singleton reference..
getInstances() - Method in class org.edg.info.InstanceTracker
 
getLastCallDuration() - Method in class org.edg.info.Message
Gets the duration of the last call in seconds.
getLastExceptionMessage() - Method in class org.edg.info.ArchiverInstance.ArchiverThread
 
getLastInsertTimeMillis() - Method in class org.edg.info.ArchiverInstance.ArchiverThread
 
getLastInsertTimeMillis() - Method in class org.edg.info.Queue
 
getLastInsertTupleCount() - Method in class org.edg.info.ArchiverInstance.ArchiverThread
 
getLastPopTimeMillis() - Method in class org.edg.info.ConsumerInstance
 
getLastRegistryUpdateIntervalMillis() - Method in class org.edg.info.RegistrationThread
 
getLastRegistryUpdateTimeMillis() - Method in class org.edg.info.InstanceBase
 
getLastRegistryUpdateTimeMillis() - Method in class org.edg.info.RegistrationThread
 
getLastResult() - Method in class org.edg.info.Message
Gets the result of the last call.
getLastResultCode() - Method in class org.edg.info.Message
Gets the result code for the last call.
getLastStreamDurationMillis() - Method in class org.edg.info.InsertableInstance
 
getLastStreamDurationMillis() - Method in class org.edg.info.StreamingThread
 
getLastSuccessfulInsertTimeMillis() - Method in class org.edg.info.ArchiverInstance.ArchiverThread
 
getLastSuccessfulInsertTimeMillis() - Method in class org.edg.info.Queue
 
getLastWriteDurationMillis() - Method in class org.edg.info.ConsumerConnection
Gets the duration of the last write.
getLatestRetentionPeriod(String) - Method in class org.edg.info.InsertableInstance
Gets the LatestRetentionPeriod.
getLockMode() - Method in class org.edg.info.sqlutil.parsql.LockTableStatement
Gets the lock mode.
getLrpSec() - Method in class org.edg.info.RetentionPeriods
 
getMatchingProducersForTables(String[], String, boolean) - Method in class org.edg.info.RegistryInstance
DOCUMENT ME!
getMaxBufferSize() - Method in class org.edg.info.InsertableInstance
 
getMaxTupleMemory() - Static method in class org.edg.info.Queue
Deprecated.  
getMaxTupleMemoryKB() - Method in class org.edg.info.Queue
 
getMessages() - Method in class org.edg.info.Messenger
DOCUMENT ME!
getMessagesInFastQueue() - Method in class org.edg.info.ConsumerInstance
 
getMessagesInFastQueue() - Method in class org.edg.info.ContinuousConsumerInstance
 
getMessagesInFastQueue() - Method in class org.edg.info.RegistryInstance
 
getMessagesInMediumQueue() - Method in class org.edg.info.RegistryInstance
 
getMessagesInSlowQueue() - Method in class org.edg.info.ConsumerInstance
 
getMessagesInSlowQueue() - Method in class org.edg.info.ContinuousConsumerInstance
 
getMessagesInSlowQueue() - Method in class org.edg.info.RegistryInstance
 
getMinRetentionPeriod() - Method in class org.edg.info.InsertableInstance
Deprecated.  
getName() - Method in class org.edg.info.FixedColumn
 
getName() - Method in class org.edg.info.sqlutil.parsql.ColumnDefinition
Returns the name.
getNotifyInterval() - Method in class org.edg.info.Messenger
DOCUMENT ME!
getNumAtt() - Method in class org.edg.info.sqlutil.rdb.Tuple
Return the number of attributes in the tuple.
getNumTuplesInStore() - Method in class org.edg.info.ConsumerInstance
 
getNumberTuplesArchived() - Method in class org.edg.info.ArchiverInstance.ArchiverThread
 
getNumberTuplesDropped() - Method in class org.edg.info.ArchiverInstance.ArchiverThread
 
getOperand(int) - Method in class org.edg.info.sqlutil.parsql.Expression
Get an operand according to its index (position).
getOperands() - Method in class org.edg.info.sqlutil.parsql.Expression
Get this expression's operands.
getOperator() - Method in class org.edg.info.sqlutil.parsql.Expression
Get this expression's operator.
getOrderBy() - Method in class org.edg.info.sqlutil.parsql.SelectStatement
Get the ORDER BY clause
getOrigin() - Method in class org.edg.info.Replica
 
getPortNumber() - Method in class org.edg.info.OnDemandProducerInstance
 
getPredicate() - Method in class org.edg.info.TupleChecker
DOCUMENT ME!
getPrimaryKey(String) - Method in class org.edg.info.SchemaInstance
 
getPrimaryProducerId() - Method in class org.edg.info.ArchiverInstance
 
getPrimaryProducerURL() - Method in class org.edg.info.ArchiverInstance
 
getProducerInfo(String, int) - Method in class org.edg.info.RegistryInstance
Returns the column names of a producers table.
getProducerTableEntryList() - Method in class org.edg.info.ConsumerInstance
 
getProducerTableEntryList() - Method in class org.edg.info.ContinuousConsumerInstance
 
getProducerTableEntryList() - Method in class org.edg.info.OneTimeConsumerInstance
 
getProducerType() - Method in class org.edg.info.ArchiverInstance
 
getProducerType() - Method in class org.edg.info.DeclarableInstance
 
getProducerURL() - Method in class org.edg.info.StopStreamingRequest
Returns URL for the producer.
getQuery() - Method in class org.edg.info.ArchiverInstance.ArchiverThread
 
getQuery() - Method in class org.edg.info.ConsumerInstance
 
getQuery(String[], String) - Static method in class org.edg.info.Decoder
Reconstructs a SELECT query from a list of table names and a predicate (WHERE clause).
getQuery() - Method in class org.edg.info.sqlutil.parsql.InsertStatement
Get the sub-query (ex.
getQueryProperties() - Method in class org.edg.info.ConsumerInstance
 
getQueryTimeoutMillis() - Method in class org.edg.info.ArchiverInstance.ArchiverThread
 
getQueueTracker() - Method in class org.edg.info.InsertableInstance
 
getRegistryUpdateIntervalMillis() - Method in class org.edg.info.InstanceBase
 
getRelevantProducers(String, String, int) - Method in class org.edg.info.RegistryInstance
Returns producers that are relevant to a Consumer's query.
getReplicationIntervalMillis() - Method in class org.edg.info.RegistryInstance
 
getReplicationIntervalMillis() - Method in class org.edg.info.ReplicaManager
 
getRequest() - Method in class org.edg.info.ConsumerConnection
Returns stream request.
getResourceId() - Method in class org.edg.info.InstanceBase
 
getResultSet() - Method in class org.edg.info.ODPXMLParser
Returns the first (or only) ResultSet parsed.
getResultSets() - Method in class org.edg.info.ODPXMLParser
Returns ResultSets parsed from XML
getRetentionPeriods() - Method in class org.edg.info.InsertableInstance
 
getSchema() - Method in class org.edg.info.sqlutil.parsql.AliasedName
Returns the schema part of the name [[schema.]table.]column
getSelect() - Method in class org.edg.info.ConsumerConnection
Returns SELECT items.
getSelect() - Method in class org.edg.info.sqlutil.parsql.SelectStatement
Get the SELECT part of the statement
getServletConnection(String, int) - Method in class org.edg.info.RegistryInstance
This method was added to aid testing, in future a better mechanism should be adopted.
getSet() - Method in class org.edg.info.sqlutil.parsql.SelectStatement
Get the SET clause (generally UNION, INTERSECT or MINUS)
getSet() - Method in class org.edg.info.sqlutil.parsql.UpdateStatement
Get the whole SET...
getSlowQueue() - Method in class org.edg.info.Messenger
DOCUMENT ME!
getSocketChannel() - Method in class org.edg.info.ConsumerConnection
Returns socket channel.
getStartTime() - Method in class org.edg.info.ArchiverInstance.ArchiverThread
 
getStartTimeMS() - Method in class org.edg.info.Message
Gets the start time of the current call.
getState() - Method in class org.edg.info.InstanceTracker
Attempts to build status information for each Object stored within the instance tracker.
getStatement() - Method in class org.edg.info.RemoteDatabase
Returns a Statement object to send SQL to this database.
getStatus() - Method in class org.edg.info.InstanceBase
returns status information for this instance
getStopStreamingRequests() - Method in class org.edg.info.StreamingServer
Gets the array of StopStreaming requests for this server.
getStreamDurationMillis() - Method in class org.edg.info.InsertableInstance
 
getStreamDurationMillis() - Method in class org.edg.info.StreamingThread
 
getTable() - Method in class org.edg.info.sqlutil.FastInsertStatement
Returns the name of the table
getTable() - Method in class org.edg.info.sqlutil.parsql.AliasedName
Returns the table part of the name [[schema.]table.]column
getTable() - Method in class org.edg.info.sqlutil.parsql.UpdateStatement
DOCUMENT ME!
getTableDesc(String) - Method in class org.edg.info.SchemaInstance
Returns a CREATE TABLE statement for the given table.
getTableInfo(int) - Method in class org.edg.info.SchemaInstance
returns the names of columns of the table with tableId.
getTableName() - Method in class org.edg.info.ArchiverInstance.ArchiverThread
 
getTableName() - Method in class org.edg.info.sqlutil.parsql.CreateTableStatement
Returns the tableName.
getTableName() - Method in class org.edg.info.sqlutil.parsql.DeleteStatement
 
getTableName() - Method in class org.edg.info.sqlutil.parsql.InsertStatement
 
getTableNames() - Method in class org.edg.info.ConsumerInstance
 
getTables() - Method in class org.edg.info.sqlutil.parsql.LockTableStatement
Gets a list of table names.
getTerminationInterval() - Method in class org.edg.info.InstanceBase
Returns the terminationInterval in milliseconds.
getTerminationIntervalMillis() - Method in class org.edg.info.InstanceBase
 
getTotalNumberInsertedTuples() - Method in class org.edg.info.Queue
 
getTotalTupleMemoryUsedKB() - Method in class org.edg.info.Queue
 
getTuple() - Method in class org.edg.info.QueueEntry
 
getTupleMemoryUsedKB() - Method in class org.edg.info.Queue
 
getTupleStatus() - Method in class org.edg.info.ArchiverInstance.ArchiverThread
Gets a String giving the status of this archiver thread.
getType() - Method in class org.edg.info.FixedColumn
 
getType() - Method in class org.edg.info.ODPXMLParser
Returns the object type.
getType() - Method in class org.edg.info.sqlutil.parsql.ColumnDefinition
Returns the type.
getType() - Method in class org.edg.info.sqlutil.parsql.Constant
Returns the constant type.
getTypeName() - Method in class org.edg.info.sqlutil.parsql.Constant
Gets the name of the type of this Constant.
getUrl() - Method in class org.edg.info.ConsumerConnection
Returns consumer URL.
getUserLastContactTimeMillis() - Method in class org.edg.info.InstanceBase
 
getVDBName() - Method in class org.edg.info.RegistryInstance
 
getVDBName() - Method in class org.edg.info.SchemaInstance
 
getValue() - Method in class org.edg.info.FixedColumn
 
getValue() - Method in class org.edg.info.sqlutil.parsql.Constant
Returns the constant value.
getValueSpec() - Method in class org.edg.info.sqlutil.parsql.InsertStatement
Returns the valueSpec for this INSERT statement.
getValues() - Method in class org.edg.info.sqlutil.parsql.InsertStatement
Get the VALUES part of the INSERT statement.
getWhere() - Method in class org.edg.info.ConsumerConnection
Returns WHERE clause.
getWhere() - Method in class org.edg.info.sqlutil.parsql.DeleteStatement
Returns the SQL WHERE clause from this DELETE statement.
getWhere() - Method in class org.edg.info.sqlutil.parsql.SelectStatement
Get the WHERE part of the statement
getWhere() - Method in class org.edg.info.sqlutil.parsql.UpdateStatement
Get the WHERE clause of this UPDATE statement.

H

hasAborted() - Method in class org.edg.info.ConsumerInstance
Returns a ResultSet containing the state of the aborted flag.
hasBeenStreamed() - Method in class org.edg.info.QueueEntry
Returns whether this tuple has had its chance to be streamed.
hasPredicate() - Method in class org.edg.info.QueryHandler
DOCUMENT ME!
hashCode() - Method in class org.edg.info.StopStreamingRequest
 
hashCode() - Method in class org.edg.info.sqlutil.rdb.Tuple
 

I

INFO_TABLE - Static variable in class org.edg.info.DBConstants
The info table name.
InsertStatement - class org.edg.info.sqlutil.parsql.InsertStatement.
InsertStatement: an SQL INSERT statement.
InsertStatement(String) - Constructor for class org.edg.info.sqlutil.parsql.InsertStatement
Create an INSERT statement on a given table
InsertableInstance - class org.edg.info.InsertableInstance.
Superclass for all producers that have "insertable" behaviour.
InstanceBase - class org.edg.info.InstanceBase.
InstanceBase is an object that supports the corresponding APIBase.
InstanceTracker - class org.edg.info.InstanceTracker.
InstanceTracker is used to store and track InstanceBase objects.
InstanceTracker(String) - Constructor for class org.edg.info.InstanceTracker
Creates a new InstanceTracker Object.
incCompletedExecutes() - Method in class org.edg.info.ConsumerInstance
 
incCompletedExecutes() - Method in class org.edg.info.OneTimeConsumerInstance
Increments the number of completed executes.
incConnectAttempts() - Method in class org.edg.info.ConsumerConnection
Increments the number of connection attempts by one.
incTotalNumberInsertedTuples() - Method in class org.edg.info.Queue
Increments the total number of inserted tuples by one.
insert(String[]) - Method in class org.edg.info.InsertableInstance
Inserts a number of tuples.
isAttribute(String) - Method in class org.edg.info.sqlutil.rdb.Tuple
To know if an attributes is already defined
isAutoInsertTimestampEnabled() - Method in class org.edg.info.InsertableInstance
Returns state of autoInsertTimestamp.
isCountDistinct() - Method in class org.edg.info.sqlutil.parsql.SelectItem
 
isDestroyed() - Method in class org.edg.info.InstanceBase
Returns the value of the destroyed flag.
isDistinct() - Method in class org.edg.info.sqlutil.parsql.SelectStatement
DOCUMENT ME!
isEmpty() - Method in class org.edg.info.QueueDiskCache
Determines if the disk cache is full.
isEquivalentTo(ColumnDefinition) - Method in class org.edg.info.sqlutil.parsql.ColumnDefinition
Returns true if the given ColumnDefinition is equivalent to (in type terms) this ColumnDefinition.
isEquivalentTo(CreateTableStatement) - Method in class org.edg.info.sqlutil.parsql.CreateTableStatement
Returns true if cts is equivalent to this CreateTableStatement.
isExecuting() - Method in class org.edg.info.ConsumerInstance
Returns the current status of the executing threads.
isExecuting() - Method in class org.edg.info.ContinuousConsumerInstance
DOCUMENT ME!
isExecuting() - Method in class org.edg.info.OneTimeConsumerInstance
Returns the current status of the executing threads.
isExpression() - Method in class org.edg.info.sqlutil.parsql.SelectItem
DOCUMENT ME!
isForUpdate() - Method in class org.edg.info.sqlutil.parsql.SelectStatement
DOCUMENT ME!
isFull() - Method in class org.edg.info.QueueDiskCache
Determines if the disk cache is full.
isHostnameDenied(String, String) - Method in class org.edg.info.SiteFilter
Checks if the hostname is contained in the allow/deny access list.
isNoWait() - Method in class org.edg.info.sqlutil.parsql.LockTableStatement
Gets the noWait flag.
isNotNull() - Method in class org.edg.info.sqlutil.parsql.ColumnDefinition
Returns the notNull flag.
isPrimaryKey() - Method in class org.edg.info.sqlutil.parsql.ColumnDefinition
Returns the primaryKey flag.
isProducerIsFull() - Method in class org.edg.info.ArchiverInstance.ArchiverThread
 
isReadOnly() - Method in class org.edg.info.sqlutil.parsql.TransactionStatement
 
isReplicating() - Method in class org.edg.info.RegistryInstance
 
isReplicating() - Method in class org.edg.info.ReplicaManager
 
isSimpleQuery() - Method in class org.edg.info.QueryHandler
Checks whether the query would be a valid continuous query.
isTupleCheckingEnabled() - Method in class org.edg.info.InstanceBase
Returns the tupleCheckingEnabled.
isURLDenied(String) - Method in class org.edg.info.SiteFilter
Extracts the hostname from the URL and checks if its currently in the allow/denied access list.
isWildcard() - Method in class org.edg.info.sqlutil.parsql.AliasedName
Determines if this name is a wild card.

L

LatestProducerInstance - class org.edg.info.LatestProducerInstance.
 
LatestProducerInstance(Registry, Schema, PrimaryProducerConfig, ServletConnection, long, Storage) - Constructor for class org.edg.info.LatestProducerInstance
Creates a LatestProducer setting up a default internal database.
LockTableStatement - class org.edg.info.sqlutil.parsql.LockTableStatement.
LockTableStatement: an SQL LOCK TABLE statement
LockTableStatement() - Constructor for class org.edg.info.sqlutil.parsql.LockTableStatement
Creates a new LockTableStatement object.

M

MAX_POP_COUNT - Static variable in class org.edg.info.ArchiverInstance.ArchiverThread
Maximum number of tuples to pop at a time.
MEASUREMENT_DATE_FIELD - Static variable in interface org.edg.info.StandardColumnNames
Name of tuple date field.
MEASUREMENT_TIME_FIELD - Static variable in interface org.edg.info.StandardColumnNames
Name of tuple time field.
Message - class org.edg.info.Message.
Simple wrapper of a servlet connection to make it easier to find and compare messages.
Messenger - class org.edg.info.Messenger.
Messages that can't fail can be send by implementations of this.
MessengerWatcher - class org.edg.info.MessengerWatcher.
Thread to watch fast messenger and reset it if it blocks on a single message for too long.
MessengerWatcher(Registrar) - Constructor for class org.edg.info.MessengerWatcher
Creates a new MessengerWatcher.
m_tuplesArchived - Variable in class org.edg.info.ArchiverInstance.ArchiverThread
Number of tuples that have been archived by this thread.
m_tuplesLost - Variable in class org.edg.info.ArchiverInstance.ArchiverThread
Number of tuples that have been lost by this thread.
markAllTuplesAsStreamed() - Method in class org.edg.info.Queue
Mark all tuples in the queue as having had a chance to be streamed.

N

NULL - Static variable in class org.edg.info.sqlutil.parsql.Constant
Type null.
NULL_COLUMN - Static variable in class org.edg.info.QueueDiskCache
Character used to indicate a NULL column.
NUMBER - Static variable in class org.edg.info.sqlutil.parsql.Constant
Type number.
NUMERIC_COLUMN - Static variable in class org.edg.info.QueueDiskCache
Character used to indicate a numeric column.
nbOperands() - Method in class org.edg.info.sqlutil.parsql.Expression
Get the number of operands
nextId() - Method in class org.edg.info.InstanceTracker
Returns the next connection id.
notifyRegistrationThread() - Method in class org.edg.info.InstanceBase
 

O

ODPEXCEPTION - Static variable in interface org.edg.info.ODPXMLConstants
XML token that represents the <XMLException> element.
ODPRESULTSET - Static variable in interface org.edg.info.ODPXMLConstants
XML token that represents the <XMLResultSet> element.
ODPXMLConstants - interface org.edg.info.ODPXMLConstants.
Constants for the XML parser.
ODPXMLParser - class org.edg.info.ODPXMLParser.
Version of XMLConverter that uses SAX parser for increased performance.
ODPXMLParser() - Constructor for class org.edg.info.ODPXMLParser
Creates a new XMLSAXConverter object.
OK - Static variable in class org.edg.info.Messenger
Result code indicating that message was sent successfully so can be removed from list.
OnDemandProducerInstance - class org.edg.info.OnDemandProducerInstance.
OnDemandProducer.
OnDemandProducerInstance(Registry, Schema, int, String, ServletConnection, int) - Constructor for class org.edg.info.OnDemandProducerInstance
Creates a new OnDemandProducer instance with the specified attributes.
OnDemandProducerInstance.ExecuteThread - class org.edg.info.OnDemandProducerInstance.ExecuteThread.
Thread used to execute a single one-time query on this producer.
OnDemandProducerInstance.ExecuteThread(String, ResourceEndpoint, StreamingProperties, int, String) - Constructor for class org.edg.info.OnDemandProducerInstance.ExecuteThread
Creates a new ExecuteThread to stream data to the specified consumer.
OneTimeConsumerInstance - class org.edg.info.OneTimeConsumerInstance.
OneTimeConsumerInstances only ever need to contact one publisher in order to answer a query.
OneTimeConsumerInstance(String, URL, int, long, int, StreamingServer, TimeoutThread, ConsumerConfig) - Constructor for class org.edg.info.OneTimeConsumerInstance
Creates a new OneTimeConsumerInstance object.
OrderBy - class org.edg.info.sqlutil.parsql.OrderBy.
An SQL query ORDER BY clause.
OrderBy(ExpSelConst) - Constructor for class org.edg.info.sqlutil.parsql.OrderBy
 
org.edg.info - package org.edg.info
 
org.edg.info.sqlutil - package org.edg.info.sqlutil
 
org.edg.info.sqlutil.parsql - package org.edg.info.sqlutil.parsql
 
org.edg.info.sqlutil.rdb - package org.edg.info.sqlutil.rdb
 

P

POP_INITIAL_PERIOD - Static variable in class org.edg.info.ArchiverInstance.ArchiverThread
Interval to wait before first pop in thread (ms).
POP_RETRY_PERIOD - Static variable in class org.edg.info.ArchiverInstance.ArchiverThread
Interval to wait after a pop returns no tuples (ms).
PRODUCER_TABLE - Static variable in class org.edg.info.DBConstants
The producer table name.
parse(String) - Static method in class org.edg.info.sqlutil.FastInsertParser
Parses an INSERT statement and creates a FastInsertStatement object from it.
parse(String) - Static method in class org.edg.info.sqlutil.parsql.CreateTableStatement
Parses the CREATE TABLE statement into a CreateTableStatement object.
pop() - Method in class org.edg.info.ConsumerInstance
Attempts to pop the number of tuples of the stack.
pop(int) - Method in class org.edg.info.ConsumerInstance
Attempts to pop the number of tuples off the stack.
printEmptyValue(String) - Method in class org.edg.info.StatusPrinter
DOCUMENT ME!
printEndComplexType() - Method in class org.edg.info.StatusPrinter
DOCUMENT ME!
printEndContainer() - Method in class org.edg.info.StatusPrinter
DOCUMENT ME!
printEndHeader() - Method in class org.edg.info.StatusPrinter
DOCUMENT ME!
printEndTitle() - Method in class org.edg.info.StatusPrinter
DOCUMENT ME!
printStartComplexType(String, String) - Method in class org.edg.info.StatusPrinter
DOCUMENT ME!
printStartContainer(String, String) - Method in class org.edg.info.StatusPrinter
DOCUMENT ME!
printStartHeader() - Method in class org.edg.info.StatusPrinter
DOCUMENT ME!
printStartTitle(String) - Method in class org.edg.info.StatusPrinter
DOCUMENT ME!
printType(String) - Method in class org.edg.info.StatusPrinter
DOCUMENT ME!
printValue(String, String) - Method in class org.edg.info.StatusPrinter
DOCUMENT ME!
project(Vector) - Method in class org.edg.info.sqlutil.rdb.Tuple
Projects this Tuple according to the given SELECT map.

Q

QueryHandler - class org.edg.info.QueryHandler.
QueryHandler acts as an interface to parsql, the SQL Parser.
QueryHandler(String) - Constructor for class org.edg.info.QueryHandler
Creates a new QueryHandler object.
Queue - class org.edg.info.Queue.
Queue of tuples in a producer.
QueueDiskCache - class org.edg.info.QueueDiskCache.
Circular disk cache for storing tuples.
QueueDiskCache(String, int) - Constructor for class org.edg.info.QueueDiskCache
Creates a new QueueDiskCache object.
QueueEntry - class org.edg.info.QueueEntry.
Represents a tuple in a memory queue.
QueueEntry(Tuple) - Constructor for class org.edg.info.QueueEntry
 
QueueManager - class org.edg.info.QueueManager.
Contains a queue that holds tuples the Consumer has obtained from its Producers.
QueueManagerException - exception org.edg.info.QueueManagerException.
Exception generated by QueueManager.
QueueManagerException() - Constructor for class org.edg.info.QueueManagerException
 
QueueManagerException(String) - Constructor for class org.edg.info.QueueManagerException
 
QueueManagerException(String, Throwable) - Constructor for class org.edg.info.QueueManagerException
 
QueueManagerException(Throwable) - Constructor for class org.edg.info.QueueManagerException
 

R

READ_TIMEOUT - Static variable in class org.edg.info.Messenger
Result code indicating that the read time-out was reached.
RESULTSET - Static variable in interface org.edg.info.ODPXMLConstants
Object type: ResultSet.
RESULT_CODES - Static variable in class org.edg.info.Messenger
String representations of result codes.
RS_COLUMNMETADATA - Static variable in interface org.edg.info.ODPXMLConstants
XML token that represents the 'metadata/column' element.
RS_COLUMNMETADATA_NAME - Static variable in interface org.edg.info.ODPXMLConstants
XML token that represents the 'metadata/column/name' element.
RS_COLUMNMETADATA_TABLE - Static variable in interface org.edg.info.ODPXMLConstants
XML token that represents the 'metadata/column/table' element.
RS_COLUMNMETADATA_TYPE - Static variable in interface org.edg.info.ODPXMLConstants
XML token that represents the 'metadata/column/type' element.
RS_ENDOFRESULTS - Static variable in interface org.edg.info.ODPXMLConstants
XML token that represents the 'endOfResults' attribute.
RS_RGMAWARNING_MESSAGE - Static variable in interface org.edg.info.ODPXMLConstants
XML token that represents the <message> element.
RS_ROW - Static variable in interface org.edg.info.ODPXMLConstants
XML token that represents the <row> element.
RS_ROW_COL - Static variable in interface org.edg.info.ODPXMLConstants
XML token that represents the <col> element.
RegistrationThread - class org.edg.info.RegistrationThread.
RegistrationThread used to update the termination interval for Producer and Consumer instances.
RegistrationThread(InstanceBase, InstanceTracker) - Constructor for class org.edg.info.RegistrationThread
Creates a new RegistrationThread instance, used for soft-state registration.
RegistryInstance - class org.edg.info.RegistryInstance.
RegistryInstance is an object that supports the RegistryServlet.
RegistryInstance(RegistryConfig) - Constructor for class org.edg.info.RegistryInstance
Creates a new RegistryInstance object.
RegistryMediator - class org.edg.info.RegistryMediator.
Determines which producers are relevant to consumer queries, and which consumers are relevant to newly-registered producers.
RegistryMediator(Schema, String, RegistryToolKit) - Constructor for class org.edg.info.RegistryMediator
Constructs a new Mediator.
RegistryReplica - class org.edg.info.RegistryReplica.
Convenient wrapper class that takes a Replica that fits into the Registry db structure and provides assorted accessor methods.
RemoteDatabase - class org.edg.info.RemoteDatabase.
Encapsulates a remote database.
RemoteDatabase(String, String, String, String) - Constructor for class org.edg.info.RemoteDatabase
Creates a new RemoteDatabase object.
Replica - class org.edg.info.Replica.
Represents a collection of tables to be replicated.
Replica() - Constructor for class org.edg.info.Replica
 
ReplicaCreator - class org.edg.info.ReplicaCreator.
Creats Replicas derived from the db.
ReplicaDecoder - class org.edg.info.ReplicaDecoder.
Translates an XML message to the local Registry DB.
ReplicaDecoder() - Constructor for class org.edg.info.ReplicaDecoder
Creates a new ReplicaDecoder.
ReplicaEncoder - class org.edg.info.ReplicaEncoder.
Convers Replicas to XML.
ReplicaEncoder() - Constructor for class org.edg.info.ReplicaEncoder
 
ReplicaManager - class org.edg.info.ReplicaManager.
The ReplicaManager is used to issue and recieve regular updates from neighbouring Registries.
ReplicaRow - class org.edg.info.ReplicaRow.
Represents a Row of data to be replicated.
ReplicaStorer - class org.edg.info.ReplicaStorer.
Stores replicas using the local db.
ReplicaTable - class org.edg.info.ReplicaTable.
Represents a table to be replicated with other Registry services.
ReplicaTable(String, Vector) - Constructor for class org.edg.info.ReplicaTable
 
ResponseTester - class org.edg.info.ResponseTester.
Determines which Publisher from a list has the fastest response.
RetentionPeriodTracker - class org.edg.info.RetentionPeriodTracker.
Class is used with the SP.
RetentionPeriodTracker(String, InstanceTracker, long) - Constructor for class org.edg.info.RetentionPeriodTracker
 
RetentionPeriods - class org.edg.info.RetentionPeriods.
 
RetentionPeriods(int, int) - Constructor for class org.edg.info.RetentionPeriods
 
readTuples(int) - Method in class org.edg.info.QueueDiskCache
Reads a list of tuples from this file.
reconnect() - Method in class org.edg.info.InstanceBase
 
registerContinuousQuery(String, int, String, int, long, long) - Method in class org.edg.info.RegistryInstance
Registers consumer with a CONTINUOUS query in database and returns list of relevant producers (can't return republishers, as there is a block at the moment in flags.matches()).
registerProducerTable(String, int, String, String, int, long, long) - Method in class org.edg.info.RegistryInstance
Registers a producer view.
remove(int) - Method in class org.edg.info.InstanceTracker
Closes an InstanceBase and removes it from the tracker.
remove(ConsumerInstance) - Method in class org.edg.info.TimeoutThread
 
removeProducer(ServletConnection) - Method in class org.edg.info.ContinuousConsumerInstance
removeProducer will remove the producer from connections and halt any messages that are still being sent to it.
resetConnectAttempts() - Method in class org.edg.info.ConsumerConnection
Resets the number of connection attempts to zero.
resetPosition() - Method in class org.edg.info.ReplicaTable
Row offset is reset to begining of the row list.
run() - Method in class org.edg.info.ArchiverInstance.ArchiverThread
Main loop.
run() - Method in class org.edg.info.CleanableInstance.CleanUpThread
Thread sleeps for clean-up interval then contacts database to clean-up.
run() - Method in class org.edg.info.Messenger
Main thread loop.
run() - Method in class org.edg.info.MessengerWatcher
Periodically checks the current message in the fast queue and calls registrar.recreateFastMessenger() if it has been blocking for too long.
run() - Method in class org.edg.info.OnDemandProducerInstance.ExecuteThread
Reads data from user code (using execute) and streams to streaming server.
run() - Method in class org.edg.info.RegistrationThread
 
run() - Method in class org.edg.info.ReplicaManager
Thread will copy the db content originating from this Registry with neighboring Registry services.
run() - Method in class org.edg.info.RetentionPeriodTracker
The thread's main loop.
run() - Method in class org.edg.info.SiteFilter
DOCUMENT ME!
run() - Method in class org.edg.info.StreamingServer
Main loop; while the server is active, waits for incoming data and adds it to appropriate QueueManager.
run() - Method in class org.edg.info.StreamingThread
Main loop of thread.
run() - Method in class org.edg.info.TimeoutThread
Waits for correct time interval then aborts each "registered" consumer.

S

SQLExpEvaluator - class org.edg.info.sqlutil.rdb.SQLExpEvaluator.
Evaluate SQL expressions
SQLExpEvaluator() - Constructor for class org.edg.info.sqlutil.rdb.SQLExpEvaluator
 
SQLUtils - class org.edg.info.sqlutil.SQLUtils.
Utilities related to SQL.
STRING - Static variable in class org.edg.info.sqlutil.parsql.Constant
Type string.
STRING_COLUMN - Static variable in class org.edg.info.QueueDiskCache
Character used to indicate a string column.
SchemaInstance - class org.edg.info.SchemaInstance.
SchemaInstance is an object that supports the SchemaServlet.
SchemaInstance(SchemaConfig) - Constructor for class org.edg.info.SchemaInstance
Creates a new SchemaInstance object.
SelectItem - class org.edg.info.sqlutil.parsql.SelectItem.
SelectItem: an item in the SELECT part of an SQL query.
SelectItem() - Constructor for class org.edg.info.sqlutil.parsql.SelectItem
Create a new SELECT item
SelectItem(String) - Constructor for class org.edg.info.sqlutil.parsql.SelectItem
Create a new SELECT item, given its name (for column names and wildcards).
SelectStatement - class org.edg.info.sqlutil.parsql.SelectStatement.
SelectStatement: an SQL SELECT statement
SelectStatement() - Constructor for class org.edg.info.sqlutil.parsql.SelectStatement
Create a new SELECT statement
SiteFilter - class org.edg.info.SiteFilter.
This class is used to allow/deny requests destined to a particular destination.
SocketUtils - class org.edg.info.SocketUtils.
Class SocketUtils
StandardColumnNames - interface org.edg.info.StandardColumnNames.
Class StandardColumnNames
Statement - interface org.edg.info.sqlutil.parsql.Statement.
Statement: a common interface for all SQL statements.
StatusBuilder - class org.edg.info.StatusBuilder.
Builds an XML representation of an Object's state using reflection.
StatusBuilder() - Constructor for class org.edg.info.StatusBuilder
Creates a new StatusBuilder object.
StatusPrinter - class org.edg.info.StatusPrinter.
Formatter used to create fancy status messages.
StatusPrinter() - Constructor for class org.edg.info.StatusPrinter
Creates a new StatusPrinter object.
StopStreamingRequest - class org.edg.info.StopStreamingRequest.
 
StopStreamingRequest(String, int, String) - Constructor for class org.edg.info.StopStreamingRequest
 
StreamingConstants - interface org.edg.info.StreamingConstants.
Constants used by the streaming protocol.
StreamingServer - class org.edg.info.StreamingServer.
Handles incoming requests to stream from StreamProducers on behalf of all local ConsumerInstances.
StreamingServer() - Constructor for class org.edg.info.StreamingServer
Creates a new StreamingServer object.
StreamingServer(InstanceTracker, int, String) - Constructor for class org.edg.info.StreamingServer
Constructs a streaming server, listening on port streamingPort, putting data in consumers from tracker.
StreamingThread - class org.edg.info.StreamingThread.
Thread that periodically initiates streaming for a single producer.
StreamingThread(InsertableInstance) - Constructor for class org.edg.info.StreamingThread
Creates a new StreamingThread for the given producer.
s_dbAdminDriver - Static variable in class org.edg.info.CleanableInstance
Driver for the admin database.
s_dbAdminPassword - Static variable in class org.edg.info.CleanableInstance
Password of the admin user.
s_dbAdminURL - Static variable in class org.edg.info.CleanableInstance
DB URL of the main admin user (required to create new databases).
s_dbAdminUserName - Static variable in class org.edg.info.CleanableInstance
Username of the admin user.
s_duplicateKeyErrorCode - Static variable in class org.edg.info.DBConstants
Error code used by MySQL when duplicate records are found during an SQL update.
s_maxTerminationInterval - Static variable in class org.edg.info.InstanceBase
The largest allowable termination interval.
s_maxTupleMemory - Static variable in class org.edg.info.Queue
Max memory available to tuples (in bytes).
s_minTerminationInterval - Static variable in class org.edg.info.InstanceBase
The smallest allowable termination interval.
serialize(List) - Static method in class org.edg.info.QueueDiskCache
Serializes a list of tuples into a StringBuffer.
serialize(Tuple) - Static method in class org.edg.info.QueueDiskCache
Serializes a tuple into a StringBuffer.
setAggregate(String) - Method in class org.edg.info.sqlutil.parsql.SelectItem
Initialize an aggregate function on this item (generally SUM, AVG, MAX, MIN) Example: SELECT AVG(age) FROM people; -> The aggregate function is AVG.
setAlias(String) - Method in class org.edg.info.sqlutil.parsql.AliasedName
Associate an alias with the current name.
setAscOrder(boolean) - Method in class org.edg.info.sqlutil.parsql.OrderBy
Set the order to ascending or descending (defailt is ascending order).
setAtt(String, Object) - Method in class org.edg.info.sqlutil.rdb.Tuple
Set the value of the given attribute name
setAutoInsertTimestamp(boolean) - Method in class org.edg.info.InsertableInstance
Sets the autoInsertTimestampEnabled.
setClientHostName(String) - Method in class org.edg.info.ArchiverInstance
Sets the hostname of the client (that contacted the resource).
setClientHostName(String) - Method in class org.edg.info.ConsumerInstance
Sets the client hostname that previously contacted this resource.
setClientHostName(String) - Method in class org.edg.info.DeclarableInstance
Sets the hostname of the client (that contacted the resource).
setCloseCalled(boolean) - Method in class org.edg.info.InstanceBase
Sets the value of the closeCalled flag.
setColumnNames(Vector) - Method in class org.edg.info.sqlutil.FastInsertStatement
Sets the vector of column names
setColumnValues(Vector) - Method in class org.edg.info.sqlutil.FastInsertStatement
Sets the vector of VALUES for the INSERT statement
setColumns(Vector) - Method in class org.edg.info.sqlutil.parsql.CreateTableStatement
Sets the list of columns.
setComment(String) - Method in class org.edg.info.sqlutil.parsql.TransactionStatement
 
setConsumerTerminationTime(String, int, long, long) - Method in class org.edg.info.RegistryInstance
Sets the termination time for a consumer.
setCurrentResultSetBytes(ByteBuffer) - Method in class org.edg.info.ConsumerConnection
Sets the serialized bytes for the current ResultSet.
setDestroyed(boolean) - Method in class org.edg.info.InstanceBase
Sets the value of the destroyed flag.
setExpression(ExpSelConst) - Method in class org.edg.info.sqlutil.parsql.SelectItem
Initialize this SELECT item as an SQL expression (not a column name nor wildcard) Example: SELECT a+b FROM table1; (a+b is an expression)
setHaving(ExpSelConst) - Method in class org.edg.info.sqlutil.parsql.GroupBy
Initializes the HAVING part of the GROUP BY.
setLastWriteDurationMillis(long) - Method in class org.edg.info.ConsumerConnection
Sets the duration of the last write.
setLockMode(String) - Method in class org.edg.info.sqlutil.parsql.LockTableStatement
Sets the lock mode.
setMaxTupleMemory(int) - Static method in class org.edg.info.Queue
Sets the maximum tuple memory.
setMinRetentionPeriod(long) - Method in class org.edg.info.InsertableInstance
Deprecated.  
setName(String) - Method in class org.edg.info.FixedColumn
 
setName(String) - Method in class org.edg.info.sqlutil.parsql.ColumnDefinition
Sets the name.
setNoWait(boolean) - Method in class org.edg.info.sqlutil.parsql.LockTableStatement
Sets the noWait flag.
setNotNull(boolean) - Method in class org.edg.info.sqlutil.parsql.ColumnDefinition
Sets the notNull flag.
setOperands(Vector) - Method in class org.edg.info.sqlutil.parsql.Expression
Set the operands list.
setPrimaryKey(boolean) - Method in class org.edg.info.sqlutil.parsql.ColumnDefinition
Sets the primaryKey flag.
setPrimaryKeyColumns(Vector) - Method in class org.edg.info.sqlutil.parsql.CreateTableStatement
Sets the list of primary key columns.
setProducerConnections(Vector) - Method in class org.edg.info.ConsumerInstance
Sets the list of producer connections for this Consumer to contact and sets isGlobalQuery to false.
setProducerConnections(Vector) - Method in class org.edg.info.ContinuousConsumerInstance
DOCUMENT ME!
setProducerConnections(Vector) - Method in class org.edg.info.OneTimeConsumerInstance
 
setProducerTerminationTime(String, int, long, long) - Method in class org.edg.info.RegistryInstance
Sets the termination time for a producer.
setRegistrationThread(RegistrationThread) - Method in class org.edg.info.InstanceBase
 
setRootMessenger(Messenger) - Method in class org.edg.info.Messenger
DOCUMENT ME!
setRow(List) - Method in class org.edg.info.sqlutil.rdb.Tuple
Set the current tuple's column values.
setServletLocation(String) - Method in class org.edg.info.SchemaInstance
sets the location of this instance's servlet.
setSocketChannel(SocketChannel) - Method in class org.edg.info.ConsumerConnection
Sets socket channel.
setStartTimeMS(long) - Method in class org.edg.info.Message
Sets the start time of the current call.
setStreamed() - Method in class org.edg.info.QueueEntry
Set the flag to indicate that this tuple has had a chance to be streamed
setTableName(String) - Method in class org.edg.info.sqlutil.parsql.CreateTableStatement
Sets the tableName.
setTerminationInterval(long) - Method in class org.edg.info.ArchiverInstance
Deprecated.  
setTerminationInterval(long) - Method in class org.edg.info.InstanceBase
Sets the period of inactivity before the InstanceBase Object is unregistered.
setType(String) - Method in class org.edg.info.FixedColumn
 
setType(String) - Method in class org.edg.info.sqlutil.parsql.ColumnDefinition
Sets the type.
setValue(String) - Method in class org.edg.info.FixedColumn
 
setValue(String) - Method in class org.edg.info.sqlutil.parsql.Constant
Sets the value of this Constant.
showSignOfLife() - Method in class org.edg.info.ArchiverInstance
Updates the last contact time for all the Consumer Objects and for the Producer.
showSignOfLife() - Method in class org.edg.info.InstanceBase
Updates the last contact time for this Instance Object.
shutdown() - Method in class org.edg.info.StreamingThread
Stop the streaming thread
size() - Method in class org.edg.info.Replica
 
start(long) - Method in class org.edg.info.ConsumerInstance
Will start executing each request.
start(long, Vector) - Method in class org.edg.info.ConsumerInstance
 
start(String, QueryProperties, int, ResourceEndpoint, StreamingProperties, String) - Method in class org.edg.info.OnDemandProducerInstance
Starts streaming data from the user code to the specified consumer.
startAll() - Method in class org.edg.info.Messenger
Starts this thread and all "slower" messengers that it uses.
startElement(String, String, String, Attributes) - Method in class org.edg.info.ODPXMLParser
Process start tag
startElement(String, String, String, Attributes) - Method in class org.edg.info.ReplicaDecoder
Method called by the sax parser when a new element is found.
startElement(String, String, String, Attributes) - Method in class org.edg.info.SiteFilter
Method called by the sax parser when a new element is found.
startHeader(String) - Method in class org.edg.info.StatusPrinter
DOCUMENT ME!
startStreaming(StreamRequest, String, int) - Method in class org.edg.info.InsertableInstance
Creates a new socket connection back to the consumer that is making the request and adds this to the list of consumer connections.
stopStreaming(StreamRequest) - Method in class org.edg.info.InsertableInstance
Stops streaming to consumer specified by request.
streamChanged() - Method in class org.edg.info.StreamingThread
Indicates to the thread that a new consumer has arrived or more tuples have been inserted (so streaming should be initiated).
streamTuples() - Method in class org.edg.info.InsertableInstance
Sends pending tuples for all tables in this Producer to all registered Consumers.

T

TIME_FORMAT - Static variable in interface org.edg.info.DateTimeConstants
Time format.
TUPLE_DELIMITER - Static variable in class org.edg.info.QueueDiskCache
Character used to separate tuples.
TYPE_RGMA_EXCEPTION - Static variable in interface org.edg.info.ODPXMLConstants
Exception type: RGMAException.
TYPE_UNKNOWN_RESOURCE_EXCEPTION - Static variable in interface org.edg.info.ODPXMLConstants
Exception type: UnknownResourceException.
TimeoutThread - class org.edg.info.TimeoutThread.
Thread to keep track of timeouts for consumers.
TimeoutThread() - Constructor for class org.edg.info.TimeoutThread
Creates a new TimeoutThread object.
TransactionStatement - class org.edg.info.sqlutil.parsql.TransactionStatement.
TransactionStatement: an SQL statement that concerns database transactions (example: COMMIT, ROLLBACK, SET TRANSACTION)
TransactionStatement(String) - Constructor for class org.edg.info.sqlutil.parsql.TransactionStatement
 
Tuple - class org.edg.info.sqlutil.rdb.Tuple.
A relational tuple (row in a table).
Tuple() - Constructor for class org.edg.info.sqlutil.rdb.Tuple
Creates a new empty Tuple.
Tuple(List) - Constructor for class org.edg.info.sqlutil.rdb.Tuple
Creates a new tuple, given it's column names.
Tuple(String[]) - Constructor for class org.edg.info.sqlutil.rdb.Tuple
Creates a new Tuple object.
TupleChecker - class org.edg.info.TupleChecker.
Tuple checker for one table in a producer.
TupleChecker(String, CreateTableStatement) - Constructor for class org.edg.info.TupleChecker
Creates a new TupleChecker object.
terminate() - Method in class org.edg.info.CleanableInstance.CleanUpThread
Stop the clean-up thread.
terminate() - Method in class org.edg.info.StreamingServer
Stops the main loop and shuts down all sockets.
toReversePolish() - Method in class org.edg.info.sqlutil.parsql.Expression
String form of the current expression (reverse polish notation).
toString() - Method in class org.edg.info.ConsumerConnection
 
toString() - Method in class org.edg.info.FixedColumn
 
toString() - Method in class org.edg.info.Message
 
toString() - Method in class org.edg.info.RemoteDatabase
 
toString() - Method in class org.edg.info.Replica
 
toString() - Method in class org.edg.info.ReplicaRow
 
toString() - Method in class org.edg.info.ReplicaTable
 
toString() - Method in class org.edg.info.SiteFilter
Formats the object state into xml.
toString() - Method in class org.edg.info.StopStreamingRequest
 
toString() - Method in class org.edg.info.sqlutil.FastInsertStatement
Converts this statement into a String.
toString() - Method in class org.edg.info.sqlutil.parsql.AliasedName
Returns a String representation of this name.
toString() - Method in class org.edg.info.sqlutil.parsql.ColumnDefinition
Returns object as a string.
toString() - Method in class org.edg.info.sqlutil.parsql.Constant
Return String representation of Constant in a form which SQL can use.
toString() - Method in class org.edg.info.sqlutil.parsql.CreateTableStatement
Returns this CREATE statement as an SQL String.
toString() - Method in class org.edg.info.sqlutil.parsql.DeleteStatement
 
toString() - Method in class org.edg.info.sqlutil.parsql.Expression
Returns a String representation of this Expression.
toString() - Method in class org.edg.info.sqlutil.parsql.GroupBy
 
toString() - Method in class org.edg.info.sqlutil.parsql.InsertStatement
 
toString() - Method in class org.edg.info.sqlutil.parsql.OrderBy
 
toString() - Method in class org.edg.info.sqlutil.parsql.SelectItem
DOCUMENT ME!
toString() - Method in class org.edg.info.sqlutil.parsql.SelectStatement
DOCUMENT ME!
toString() - Method in class org.edg.info.sqlutil.parsql.UpdateStatement
DOCUMENT ME!
toString() - Method in class org.edg.info.sqlutil.rdb.Tuple
 
translateColumnName(int, String) - Method in class org.edg.info.SchemaInstance
returns the columnId for a particular table's columnName.
translateTableName(String) - Method in class org.edg.info.SchemaInstance
returns the tableId that corresponds to a tableName

U

UNKNOWN - Static variable in class org.edg.info.sqlutil.parsql.Constant
Type unknown.
UTC_TIMEZONE - Static variable in interface org.edg.info.DateTimeConstants
UTC TimeZone.
UpdateStatement - class org.edg.info.sqlutil.parsql.UpdateStatement.
UpdateStatement: an SQL UPDATE statement.
UpdateStatement(String) - Constructor for class org.edg.info.sqlutil.parsql.UpdateStatement
Create an UPDATE statement on a given table.
unRegisterConsumer(String, int) - Method in class org.edg.info.RegistryInstance
Unregisters the Consumer.
unRegisterProducer(String, int) - Method in class org.edg.info.RegistryInstance
Attempts to unregister all tables belonging to a Producer.
unRegisterProducerTable(String, int, String) - Method in class org.edg.info.RegistryInstance
Attempts to un registry a Producer table.
undeclareTable(String) - Method in class org.edg.info.CleanableInstance
Deprecated.  
undeclareTable(String) - Method in class org.edg.info.DeclarableInstance
Contacts registry to undeclare given table.
updateLastContactTime() - Method in class org.edg.info.InstanceBase
Sets the last contact time to the current time.
updateLastInsertTime() - Method in class org.edg.info.Queue
Updates the last insert time in milliseconds.
updateLastSuccessfulInsertTime() - Method in class org.edg.info.Queue
Updates the last successful insert time in milliseconds.
updateRegistry(long, boolean) - Method in class org.edg.info.ContinuousConsumerInstance
DOCUMENT ME!
updateRegistry(long, boolean) - Method in class org.edg.info.DeclarableInstance
Attempts to update the termination interval for a producer resource.
updateRegistry(long, boolean) - Method in class org.edg.info.InstanceBase
Sends an update message to the Registry.

V

values() - Method in class org.edg.info.InstanceTracker
Returns the entire collection of instances.

W

WRITE_ID_TIMEOUT_MS - Static variable in class org.edg.info.SocketUtils
Maximum time to wait for ID write (in ms).
wasCloseCalled() - Method in class org.edg.info.InstanceBase
Gets the value of the closeCalled flag.
writeEndResultToken(SocketChannel) - Static method in class org.edg.info.SocketUtils
Writes a ResultSet to a SocketChannel terminated by an END_ONETIME_RESULT_TOKEN.
writeOneOffString(SocketChannel, String) - Static method in class org.edg.info.SocketUtils
 
writeResultSet(SocketChannel, ResultSet) - Static method in class org.edg.info.SocketUtils
Writes a ResultSet to a SocketChannel
writeString(SocketChannel, String) - Static method in class org.edg.info.SocketUtils
 
writeTuples(List) - Method in class org.edg.info.QueueDiskCache
Serializes the tuple list to bytes and writes them to the cache.

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